OSDN Git Service

Fix SEGV caused by duplicate memoize hints
[pghintplan/pg_hint_plan.git] / core.c
diff --git a/core.c b/core.c
index ebed66d..e1eb785 100644 (file)
--- a/core.c
+++ b/core.c
  *
  * src/backend/optimizer/path/allpaths.c
  *
- *     static functions:
- *        set_plain_rel_pathlist()
- *     add_paths_to_append_rel()
- *     try_partitionwise_join()
- *
  *  public functions:
  *     standard_join_search(): This funcion is not static. The reason for
  *        including this function is make_rels_by_clause_joins. In order to
  *        change the behavior of make_join_rel, which is called under this
  *        function.
  *
+ *     static functions:
+ *        set_rel_pathlist()
+ *        set_plain_rel_pathlist()
+ *        set_tablesample_rel_pathlist
+ *        set_foreign_pathlist()
+ *        set_append_rel_pathlist()
+ *        set_function_pathlist()
+ *        set_values_pathlist()
+ *        set_tablefunc_pathlist()
+ *        create_plain_partial_paths()
+ *
  * src/backend/optimizer/path/joinrels.c
  *
  *     public functions:
  *     make_rels_by_clauseless_joins()
  *     join_is_legal()
  *     has_join_restriction()
- *     is_dummy_rel()
  *     restriction_is_constant_false()
+ *     build_child_join_sjinfo()
+ *     get_matching_part_pairs()
+ *     compute_partition_bounds()
+ *     try_partitionwise_join()
  *
- *
- * Portions Copyright (c) 1996-2018, PostgreSQL Global Development Group
+ * Portions Copyright (c) 1996-2020, PostgreSQL Global Development Group
  * Portions Copyright (c) 1994, Regents of the University of California
  *
  *-------------------------------------------------------------------------
  */
 
-static void populate_joinrel_with_paths(PlannerInfo *root, RelOptInfo *rel1,
-                                                               RelOptInfo *rel2, RelOptInfo *joinrel,
-                                                               SpecialJoinInfo *sjinfo, List *restrictlist);
+#include "access/tsmapi.h"
+#include "catalog/pg_operator.h"
+#include "foreign/fdwapi.h"
 
 /*
  * set_plain_rel_pathlist
@@ -81,6 +89,283 @@ set_plain_rel_pathlist(PlannerInfo *root, RelOptInfo *rel, RangeTblEntry *rte)
 
 
 /*
+ * set_tablesample_rel_pathlist
+ *       Build access paths for a sampled relation
+ */
+static void
+set_tablesample_rel_pathlist(PlannerInfo *root, RelOptInfo *rel, RangeTblEntry *rte)
+{
+       Relids          required_outer;
+       Path       *path;
+
+       /*
+        * We don't support pushing join clauses into the quals of a samplescan,
+        * but it could still have required parameterization due to LATERAL refs
+        * in its tlist or TABLESAMPLE arguments.
+        */
+       required_outer = rel->lateral_relids;
+
+       /* Consider sampled scan */
+       path = create_samplescan_path(root, rel, required_outer);
+
+       /*
+        * If the sampling method does not support repeatable scans, we must avoid
+        * plans that would scan the rel multiple times.  Ideally, we'd simply
+        * avoid putting the rel on the inside of a nestloop join; but adding such
+        * a consideration to the planner seems like a great deal of complication
+        * to support an uncommon usage of second-rate sampling methods.  Instead,
+        * if there is a risk that the query might perform an unsafe join, just
+        * wrap the SampleScan in a Materialize node.  We can check for joins by
+        * counting the membership of all_baserels (note that this correctly
+        * counts inheritance trees as single rels).  If we're inside a subquery,
+        * we can't easily check whether a join might occur in the outer query, so
+        * just assume one is possible.
+        *
+        * GetTsmRoutine is relatively expensive compared to the other tests here,
+        * so check repeatable_across_scans last, even though that's a bit odd.
+        */
+       if ((root->query_level > 1 ||
+                bms_membership(root->all_baserels) != BMS_SINGLETON) &&
+               !(GetTsmRoutine(rte->tablesample->tsmhandler)->repeatable_across_scans))
+       {
+               path = (Path *) create_material_path(rel, path);
+       }
+
+       add_path(rel, path);
+
+       /* For the moment, at least, there are no other paths to consider */
+}
+
+
+/*
+ * set_foreign_pathlist
+ *             Build access paths for a foreign table RTE
+ */
+static void
+set_foreign_pathlist(PlannerInfo *root, RelOptInfo *rel, RangeTblEntry *rte)
+{
+       /* Call the FDW's GetForeignPaths function to generate path(s) */
+       rel->fdwroutine->GetForeignPaths(root, rel, rte->relid);
+}
+
+
+/*
+ * set_function_pathlist
+ *             Build the (single) access path for a function RTE
+ */
+static void
+set_function_pathlist(PlannerInfo *root, RelOptInfo *rel, RangeTblEntry *rte)
+{
+       Relids          required_outer;
+       List       *pathkeys = NIL;
+
+       /*
+        * We don't support pushing join clauses into the quals of a function
+        * scan, but it could still have required parameterization due to LATERAL
+        * refs in the function expression.
+        */
+       required_outer = rel->lateral_relids;
+
+       /*
+        * The result is considered unordered unless ORDINALITY was used, in which
+        * case it is ordered by the ordinal column (the last one).  See if we
+        * care, by checking for uses of that Var in equivalence classes.
+        */
+       if (rte->funcordinality)
+       {
+               AttrNumber      ordattno = rel->max_attr;
+               Var                *var = NULL;
+               ListCell   *lc;
+
+               /*
+                * Is there a Var for it in rel's targetlist?  If not, the query did
+                * not reference the ordinality column, or at least not in any way
+                * that would be interesting for sorting.
+                */
+               foreach(lc, rel->reltarget->exprs)
+               {
+                       Var                *node = (Var *) lfirst(lc);
+
+                       /* checking varno/varlevelsup is just paranoia */
+                       if (IsA(node, Var) &&
+                               node->varattno == ordattno &&
+                               node->varno == rel->relid &&
+                               node->varlevelsup == 0)
+                       {
+                               var = node;
+                               break;
+                       }
+               }
+
+               /*
+                * Try to build pathkeys for this Var with int8 sorting.  We tell
+                * build_expression_pathkey not to build any new equivalence class; if
+                * the Var isn't already mentioned in some EC, it means that nothing
+                * cares about the ordering.
+                */
+               if (var)
+                       pathkeys = build_expression_pathkey(root,
+                                                                                               (Expr *) var,
+                                                                                               NULL,   /* below outer joins */
+                                                                                               Int8LessOperator,
+                                                                                               rel->relids,
+                                                                                               false);
+       }
+
+       /* Generate appropriate path */
+       add_path(rel, create_functionscan_path(root, rel,
+                                                                                  pathkeys, required_outer));
+}
+
+
+/*
+ * set_values_pathlist
+ *             Build the (single) access path for a VALUES RTE
+ */
+static void
+set_values_pathlist(PlannerInfo *root, RelOptInfo *rel, RangeTblEntry *rte)
+{
+       Relids          required_outer;
+
+       /*
+        * We don't support pushing join clauses into the quals of a values scan,
+        * but it could still have required parameterization due to LATERAL refs
+        * in the values expressions.
+        */
+       required_outer = rel->lateral_relids;
+
+       /* Generate appropriate path */
+       add_path(rel, create_valuesscan_path(root, rel, required_outer));
+}
+
+/*
+ * set_tablefunc_pathlist
+ *             Build the (single) access path for a table func RTE
+ */
+static void
+set_tablefunc_pathlist(PlannerInfo *root, RelOptInfo *rel, RangeTblEntry *rte)
+{
+       Relids          required_outer;
+
+       /*
+        * We don't support pushing join clauses into the quals of a tablefunc
+        * scan, but it could still have required parameterization due to LATERAL
+        * refs in the function expression.
+        */
+       required_outer = rel->lateral_relids;
+
+       /* Generate appropriate path */
+       add_path(rel, create_tablefuncscan_path(root, rel,
+                                                                                       required_outer));
+}
+
+
+/*
+ * set_rel_pathlist
+ *       Build access paths for a base relation
+ */
+static void
+set_rel_pathlist(PlannerInfo *root, RelOptInfo *rel,
+                                Index rti, RangeTblEntry *rte)
+{
+       if (IS_DUMMY_REL(rel))
+       {
+               /* We already proved the relation empty, so nothing more to do */
+       }
+       else if (rte->inh)
+       {
+               /* It's an "append relation", process accordingly */
+               set_append_rel_pathlist(root, rel, rti, rte);
+       }
+       else
+       {
+               switch (rel->rtekind)
+               {
+                       case RTE_RELATION:
+                               if (rte->relkind == RELKIND_FOREIGN_TABLE)
+                               {
+                                       /* Foreign table */
+                                       set_foreign_pathlist(root, rel, rte);
+                               }
+                               else if (rte->tablesample != NULL)
+                               {
+                                       /* Sampled relation */
+                                       set_tablesample_rel_pathlist(root, rel, rte);
+                               }
+                               else
+                               {
+                                       /* Plain relation */
+                                       set_plain_rel_pathlist(root, rel, rte);
+                               }
+                               break;
+                       case RTE_SUBQUERY:
+                               /* Subquery --- fully handled during set_rel_size */
+                               break;
+                       case RTE_FUNCTION:
+                               /* RangeFunction */
+                               set_function_pathlist(root, rel, rte);
+                               break;
+                       case RTE_TABLEFUNC:
+                               /* Table Function */
+                               set_tablefunc_pathlist(root, rel, rte);
+                               break;
+                       case RTE_VALUES:
+                               /* Values list */
+                               set_values_pathlist(root, rel, rte);
+                               break;
+                       case RTE_CTE:
+                               /* CTE reference --- fully handled during set_rel_size */
+                               break;
+                       case RTE_NAMEDTUPLESTORE:
+                               /* tuplestore reference --- fully handled during set_rel_size */
+                               break;
+                       case RTE_RESULT:
+                               /* simple Result --- fully handled during set_rel_size */
+                               break;
+                       default:
+                               elog(ERROR, "unexpected rtekind: %d", (int) rel->rtekind);
+                               break;
+               }
+       }
+
+       /*
+        * Allow a plugin to editorialize on the set of Paths for this base
+        * relation.  It could add new paths (such as CustomPaths) by calling
+        * add_path(), or add_partial_path() if parallel aware.  It could also
+        * delete or modify paths added by the core code.
+        */
+       if (set_rel_pathlist_hook)
+               (*set_rel_pathlist_hook) (root, rel, rti, rte);
+
+       /*
+        * If this is a baserel, we should normally consider gathering any partial
+        * paths we may have created for it.  We have to do this after calling the
+        * set_rel_pathlist_hook, else it cannot add partial paths to be included
+        * here.
+        *
+        * However, if this is an inheritance child, skip it.  Otherwise, we could
+        * end up with a very large number of gather nodes, each trying to grab
+        * its own pool of workers.  Instead, we'll consider gathering partial
+        * paths for the parent appendrel.
+        *
+        * Also, if this is the topmost scan/join rel (that is, the only baserel),
+        * we postpone gathering until the final scan/join targetlist is available
+        * (see grouping_planner).
+        */
+       if (rel->reloptkind == RELOPT_BASEREL &&
+               bms_membership(root->all_baserels) != BMS_SINGLETON)
+               generate_useful_gather_paths(root, rel, false);
+
+       /* Now find the cheapest of the paths for this rel */
+       set_cheapest(rel);
+
+#ifdef OPTIMIZER_DEBUG
+       debug_print_rel(root, rel);
+#endif
+}
+
+
+/*
  * set_append_rel_pathlist
  *       Build access paths for an "append relation"
  */
@@ -132,12 +417,6 @@ set_append_rel_pathlist(PlannerInfo *root, RelOptInfo *rel,
                if (IS_DUMMY_REL(childrel))
                        continue;
 
-               /* Bubble up childrel's partitioned children. */
-               if (rel->part_scheme)
-                       rel->partitioned_child_rels =
-                               list_concat(rel->partitioned_child_rels,
-                                                       list_copy(childrel->partitioned_child_rels));
-
                /*
                 * Child is live, so add it to the live_childrels list for use below.
                 */
@@ -217,10 +496,11 @@ standard_join_search(PlannerInfo *root, int levels_needed, List *initial_rels)
                join_search_one_level(root, lev);
 
                /*
-                * Run generate_partitionwise_join_paths() and generate_gather_paths()
-                * for each just-processed joinrel.  We could not do this earlier
-                * because both regular and partial paths can get added to a
-                * particular joinrel at multiple times within join_search_one_level.
+                * Run generate_partitionwise_join_paths() and
+                * generate_useful_gather_paths() for each just-processed joinrel.  We
+                * could not do this earlier because both regular and partial paths
+                * can get added to a particular joinrel at multiple times within
+                * join_search_one_level.
                 *
                 * After that, we're done creating paths for the joinrel, so run
                 * set_cheapest().
@@ -238,7 +518,7 @@ standard_join_search(PlannerInfo *root, int levels_needed, List *initial_rels)
                         * once we know the final targetlist (see grouping_planner).
                         */
                        if (lev < levels_needed)
-                               generate_gather_paths(root, rel, false);
+                               generate_useful_gather_paths(root, rel, false);
 
                        /* Find and save the cheapest paths for this rel */
                        set_cheapest(rel);
@@ -263,6 +543,7 @@ standard_join_search(PlannerInfo *root, int levels_needed, List *initial_rels)
        return rel;
 }
 
+
 /*
  * create_plain_partial_paths
  *       Build partial access paths for parallel scan of a plain relation
@@ -336,15 +617,23 @@ join_search_one_level(PlannerInfo *root, int level)
                         * to each initial rel they don't already include but have a join
                         * clause or restriction with.
                         */
+                       List       *other_rels_list;
                        ListCell   *other_rels;
 
                        if (level == 2)         /* consider remaining initial rels */
-                               other_rels = lnext(r);
+                       {
+                               other_rels_list = joinrels[level - 1];
+                               other_rels = lnext(other_rels_list, r);
+                       }
                        else                            /* consider all initial rels */
-                               other_rels = list_head(joinrels[1]);
+                       {
+                               other_rels_list = joinrels[1];
+                               other_rels = list_head(other_rels_list);
+                       }
 
                        make_rels_by_clause_joins(root,
                                                                          old_rel,
+                                                                         other_rels_list,
                                                                          other_rels);
                }
                else
@@ -363,7 +652,7 @@ join_search_one_level(PlannerInfo *root, int level)
                         */
                        make_rels_by_clauseless_joins(root,
                                                                                  old_rel,
-                                                                                 list_head(joinrels[1]));
+                                                                                 joinrels[1]);
                }
        }
 
@@ -389,6 +678,7 @@ join_search_one_level(PlannerInfo *root, int level)
                foreach(r, joinrels[k])
                {
                        RelOptInfo *old_rel = (RelOptInfo *) lfirst(r);
+                       List       *other_rels_list;
                        ListCell   *other_rels;
                        ListCell   *r2;
 
@@ -402,11 +692,18 @@ join_search_one_level(PlannerInfo *root, int level)
                                continue;
 
                        if (k == other_level)
-                               other_rels = lnext(r);  /* only consider remaining rels */
+                       {
+                               /* only consider remaining rels */
+                               other_rels_list = joinrels[k];
+                               other_rels = lnext(other_rels_list, r);
+                       }
                        else
-                               other_rels = list_head(joinrels[other_level]);
+                       {
+                               other_rels_list = joinrels[other_level];
+                               other_rels = list_head(other_rels_list);
+                       }
 
-                       for_each_cell(r2, other_rels)
+                       for_each_cell(r2, other_rels_list, other_rels)
                        {
                                RelOptInfo *new_rel = (RelOptInfo *) lfirst(r2);
 
@@ -458,7 +755,7 @@ join_search_one_level(PlannerInfo *root, int level)
 
                        make_rels_by_clauseless_joins(root,
                                                                                  old_rel,
-                                                                                 list_head(joinrels[1]));
+                                                                                 joinrels[1]);
                }
 
                /*----------
@@ -501,8 +798,9 @@ join_search_one_level(PlannerInfo *root, int level)
  * automatically ensures that each new joinrel is only added to the list once.
  *
  * 'old_rel' is the relation entry for the relation to be joined
- * 'other_rels': the first cell in a linked list containing the other
+ * 'other_rels_list': a list containing the other
  * rels to be considered for joining
+ * 'other_rels': the first cell to be considered
  *
  * Currently, this is only used with initial rels in other_rels, but it
  * will work for joining to joinrels too.
@@ -510,11 +808,12 @@ join_search_one_level(PlannerInfo *root, int level)
 static void
 make_rels_by_clause_joins(PlannerInfo *root,
                                                  RelOptInfo *old_rel,
+                                                 List *other_rels_list,
                                                  ListCell *other_rels)
 {
        ListCell   *l;
 
-       for_each_cell(l, other_rels)
+       for_each_cell(l, other_rels_list, other_rels)
        {
                RelOptInfo *other_rel = (RelOptInfo *) lfirst(l);
 
@@ -536,8 +835,7 @@ make_rels_by_clause_joins(PlannerInfo *root,
  *       The join rels are returned in root->join_rel_level[join_cur_level].
  *
  * 'old_rel' is the relation entry for the relation to be joined
- * 'other_rels': the first cell of a linked list containing the
- * other rels to be considered for joining
+ * 'other_rels': a list containing the other rels to be considered for joining
  *
  * Currently, this is only used with initial rels in other_rels, but it would
  * work for joining to joinrels too.
@@ -545,11 +843,11 @@ make_rels_by_clause_joins(PlannerInfo *root,
 static void
 make_rels_by_clauseless_joins(PlannerInfo *root,
                                                          RelOptInfo *old_rel,
-                                                         ListCell *other_rels)
+                                                         List *other_rels)
 {
        ListCell   *l;
 
-       for_each_cell(l, other_rels)
+       foreach(l, other_rels)
        {
                RelOptInfo *other_rel = (RelOptInfo *) lfirst(l);
 
@@ -860,6 +1158,10 @@ join_is_legal(PlannerInfo *root, RelOptInfo *rel1, RelOptInfo *rel2,
                                {
                                        SpecialJoinInfo *sjinfo = (SpecialJoinInfo *) lfirst(l);
 
+                                       /* ignore full joins --- their ordering is predetermined */
+                                       if (sjinfo->jointype == JOIN_FULL)
+                                               continue;
+
                                        if (bms_overlap(sjinfo->min_lefthand, join_plus_rhs) &&
                                                !bms_is_subset(sjinfo->min_righthand, join_plus_rhs))
                                        {
@@ -867,15 +1169,6 @@ join_is_legal(PlannerInfo *root, RelOptInfo *rel1, RelOptInfo *rel2,
                                                                                                                sjinfo->min_righthand);
                                                more = true;
                                        }
-                                       /* full joins constrain both sides symmetrically */
-                                       if (sjinfo->jointype == JOIN_FULL &&
-                                               bms_overlap(sjinfo->min_righthand, join_plus_rhs) &&
-                                               !bms_is_subset(sjinfo->min_lefthand, join_plus_rhs))
-                                       {
-                                               join_plus_rhs = bms_add_members(join_plus_rhs,
-                                                                                                               sjinfo->min_lefthand);
-                                               more = true;
-                                       }
                                }
                        } while (more);
                        if (bms_overlap(join_plus_rhs, join_lateral_rels))
@@ -942,60 +1235,6 @@ has_join_restriction(PlannerInfo *root, RelOptInfo *rel)
 
 
 /*
- * is_dummy_rel --- has relation been proven empty?
- */
-static bool
-is_dummy_rel(RelOptInfo *rel)
-{
-       return IS_DUMMY_REL(rel);
-}
-
-/*
- * Mark a relation as proven empty.
- *
- * During GEQO planning, this can get invoked more than once on the same
- * baserel struct, so it's worth checking to see if the rel is already marked
- * dummy.
- *
- * Also, when called during GEQO join planning, we are in a short-lived
- * memory context.  We must make sure that the dummy path attached to a
- * baserel survives the GEQO cycle, else the baserel is trashed for future
- * GEQO cycles.  On the other hand, when we are marking a joinrel during GEQO,
- * we don't want the dummy path to clutter the main planning context.  Upshot
- * is that the best solution is to explicitly make the dummy path in the same
- * context the given RelOptInfo is in.
- */
-void
-mark_dummy_rel(RelOptInfo *rel)
-{
-       MemoryContext oldcontext;
-
-       /* Already marked? */
-       if (is_dummy_rel(rel))
-               return;
-
-       /* No, so choose correct context to make the dummy path in */
-       oldcontext = MemoryContextSwitchTo(GetMemoryChunkContext(rel));
-
-       /* Set dummy size estimate */
-       rel->rows = 0;
-
-       /* Evict any previously chosen paths */
-       rel->pathlist = NIL;
-       rel->partial_pathlist = NIL;
-
-       /* Set up the dummy path */
-       add_path(rel, (Path *) create_append_path(NULL, rel, NIL, NIL, NULL,
-                                                                                         0, false, NIL, -1));
-
-       /* Set or update cheapest_total_path and related fields */
-       set_cheapest(rel);
-
-       MemoryContextSwitchTo(oldcontext);
-}
-
-
-/*
  * restriction_is_constant_false --- is a restrictlist just FALSE?
  *
  * In cases where a qual is provably constant FALSE, eval_const_expressions
@@ -1041,6 +1280,240 @@ restriction_is_constant_false(List *restrictlist,
        return false;
 }
 
+
+/*
+ * Construct the SpecialJoinInfo for a child-join by translating
+ * SpecialJoinInfo for the join between parents. left_relids and right_relids
+ * are the relids of left and right side of the join respectively.
+ */
+static SpecialJoinInfo *
+build_child_join_sjinfo(PlannerInfo *root, SpecialJoinInfo *parent_sjinfo,
+                                               Relids left_relids, Relids right_relids)
+{
+       SpecialJoinInfo *sjinfo = makeNode(SpecialJoinInfo);
+       AppendRelInfo **left_appinfos;
+       int                     left_nappinfos;
+       AppendRelInfo **right_appinfos;
+       int                     right_nappinfos;
+
+       memcpy(sjinfo, parent_sjinfo, sizeof(SpecialJoinInfo));
+       left_appinfos = find_appinfos_by_relids(root, left_relids,
+                                                                                       &left_nappinfos);
+       right_appinfos = find_appinfos_by_relids(root, right_relids,
+                                                                                        &right_nappinfos);
+
+       sjinfo->min_lefthand = adjust_child_relids(sjinfo->min_lefthand,
+                                                                                          left_nappinfos, left_appinfos);
+       sjinfo->min_righthand = adjust_child_relids(sjinfo->min_righthand,
+                                                                                               right_nappinfos,
+                                                                                               right_appinfos);
+       sjinfo->syn_lefthand = adjust_child_relids(sjinfo->syn_lefthand,
+                                                                                          left_nappinfos, left_appinfos);
+       sjinfo->syn_righthand = adjust_child_relids(sjinfo->syn_righthand,
+                                                                                               right_nappinfos,
+                                                                                               right_appinfos);
+       sjinfo->semi_rhs_exprs = (List *) adjust_appendrel_attrs(root,
+                                                                                                                        (Node *) sjinfo->semi_rhs_exprs,
+                                                                                                                        right_nappinfos,
+                                                                                                                        right_appinfos);
+
+       pfree(left_appinfos);
+       pfree(right_appinfos);
+
+       return sjinfo;
+}
+
+
+/*
+ * get_matching_part_pairs
+ *             Generate pairs of partitions to be joined from inputs
+ */
+static void
+get_matching_part_pairs(PlannerInfo *root, RelOptInfo *joinrel,
+                                               RelOptInfo *rel1, RelOptInfo *rel2,
+                                               List **parts1, List **parts2)
+{
+       bool            rel1_is_simple = IS_SIMPLE_REL(rel1);
+       bool            rel2_is_simple = IS_SIMPLE_REL(rel2);
+       int                     cnt_parts;
+
+       *parts1 = NIL;
+       *parts2 = NIL;
+
+       for (cnt_parts = 0; cnt_parts < joinrel->nparts; cnt_parts++)
+       {
+               RelOptInfo *child_joinrel = joinrel->part_rels[cnt_parts];
+               RelOptInfo *child_rel1;
+               RelOptInfo *child_rel2;
+               Relids          child_relids1;
+               Relids          child_relids2;
+
+               /*
+                * If this segment of the join is empty, it means that this segment
+                * was ignored when previously creating child-join paths for it in
+                * try_partitionwise_join() as it would not contribute to the join
+                * result, due to one or both inputs being empty; add NULL to each of
+                * the given lists so that this segment will be ignored again in that
+                * function.
+                */
+               if (!child_joinrel)
+               {
+                       *parts1 = lappend(*parts1, NULL);
+                       *parts2 = lappend(*parts2, NULL);
+                       continue;
+               }
+
+               /*
+                * Get a relids set of partition(s) involved in this join segment that
+                * are from the rel1 side.
+                */
+               child_relids1 = bms_intersect(child_joinrel->relids,
+                                                                         rel1->all_partrels);
+               Assert(bms_num_members(child_relids1) == bms_num_members(rel1->relids));
+
+               /*
+                * Get a child rel for rel1 with the relids.  Note that we should have
+                * the child rel even if rel1 is a join rel, because in that case the
+                * partitions specified in the relids would have matching/overlapping
+                * boundaries, so the specified partitions should be considered as
+                * ones to be joined when planning partitionwise joins of rel1,
+                * meaning that the child rel would have been built by the time we get
+                * here.
+                */
+               if (rel1_is_simple)
+               {
+                       int                     varno = bms_singleton_member(child_relids1);
+
+                       child_rel1 = find_base_rel(root, varno);
+               }
+               else
+                       child_rel1 = find_join_rel(root, child_relids1);
+               Assert(child_rel1);
+
+               /*
+                * Get a relids set of partition(s) involved in this join segment that
+                * are from the rel2 side.
+                */
+               child_relids2 = bms_intersect(child_joinrel->relids,
+                                                                         rel2->all_partrels);
+               Assert(bms_num_members(child_relids2) == bms_num_members(rel2->relids));
+
+               /*
+                * Get a child rel for rel2 with the relids.  See above comments.
+                */
+               if (rel2_is_simple)
+               {
+                       int                     varno = bms_singleton_member(child_relids2);
+
+                       child_rel2 = find_base_rel(root, varno);
+               }
+               else
+                       child_rel2 = find_join_rel(root, child_relids2);
+               Assert(child_rel2);
+
+               /*
+                * The join of rel1 and rel2 is legal, so is the join of the child
+                * rels obtained above; add them to the given lists as a join pair
+                * producing this join segment.
+                */
+               *parts1 = lappend(*parts1, child_rel1);
+               *parts2 = lappend(*parts2, child_rel2);
+       }
+}
+
+
+/*
+ * compute_partition_bounds
+ *             Compute the partition bounds for a join rel from those for inputs
+ */
+static void
+compute_partition_bounds(PlannerInfo *root, RelOptInfo *rel1,
+                                                RelOptInfo *rel2, RelOptInfo *joinrel,
+                                                SpecialJoinInfo *parent_sjinfo,
+                                                List **parts1, List **parts2)
+{
+       /*
+        * If we don't have the partition bounds for the join rel yet, try to
+        * compute those along with pairs of partitions to be joined.
+        */
+       if (joinrel->nparts == -1)
+       {
+               PartitionScheme part_scheme = joinrel->part_scheme;
+               PartitionBoundInfo boundinfo = NULL;
+               int                     nparts = 0;
+
+               Assert(joinrel->boundinfo == NULL);
+               Assert(joinrel->part_rels == NULL);
+
+               /*
+                * See if the partition bounds for inputs are exactly the same, in
+                * which case we don't need to work hard: the join rel have the same
+                * partition bounds as inputs, and the partitions with the same
+                * cardinal positions form the pairs.
+                *
+                * Note: even in cases where one or both inputs have merged bounds, it
+                * would be possible for both the bounds to be exactly the same, but
+                * it seems unlikely to be worth the cycles to check.
+                */
+               if (!rel1->partbounds_merged &&
+                       !rel2->partbounds_merged &&
+                       rel1->nparts == rel2->nparts &&
+                       partition_bounds_equal(part_scheme->partnatts,
+                                                                  part_scheme->parttyplen,
+                                                                  part_scheme->parttypbyval,
+                                                                  rel1->boundinfo, rel2->boundinfo))
+               {
+                       boundinfo = rel1->boundinfo;
+                       nparts = rel1->nparts;
+               }
+               else
+               {
+                       /* Try merging the partition bounds for inputs. */
+                       boundinfo = partition_bounds_merge(part_scheme->partnatts,
+                                                                                          part_scheme->partsupfunc,
+                                                                                          part_scheme->partcollation,
+                                                                                          rel1, rel2,
+                                                                                          parent_sjinfo->jointype,
+                                                                                          parts1, parts2);
+                       if (boundinfo == NULL)
+                       {
+                               joinrel->nparts = 0;
+                               return;
+                       }
+                       nparts = list_length(*parts1);
+                       joinrel->partbounds_merged = true;
+               }
+
+               Assert(nparts > 0);
+               joinrel->boundinfo = boundinfo;
+               joinrel->nparts = nparts;
+               joinrel->part_rels =
+                       (RelOptInfo **) palloc0(sizeof(RelOptInfo *) * nparts);
+       }
+       else
+       {
+               Assert(joinrel->nparts > 0);
+               Assert(joinrel->boundinfo);
+               Assert(joinrel->part_rels);
+
+               /*
+                * If the join rel's partbounds_merged flag is true, it means inputs
+                * are not guaranteed to have the same partition bounds, therefore we
+                * can't assume that the partitions at the same cardinal positions
+                * form the pairs; let get_matching_part_pairs() generate the pairs.
+                * Otherwise, nothing to do since we can assume that.
+                */
+               if (joinrel->partbounds_merged)
+               {
+                       get_matching_part_pairs(root, joinrel, rel1, rel2,
+                                                                       parts1, parts2);
+                       Assert(list_length(*parts1) == joinrel->nparts);
+                       Assert(list_length(*parts2) == joinrel->nparts);
+               }
+       }
+}
+
+
 /*
  * Assess whether join between given two partitioned relations can be broken
  * down into joins between matching partitions; a technique called
@@ -1066,25 +1539,31 @@ try_partitionwise_join(PlannerInfo *root, RelOptInfo *rel1, RelOptInfo *rel2,
                                           RelOptInfo *joinrel, SpecialJoinInfo *parent_sjinfo,
                                           List *parent_restrictlist)
 {
-       int                     nparts;
+       bool            rel1_is_simple = IS_SIMPLE_REL(rel1);
+       bool            rel2_is_simple = IS_SIMPLE_REL(rel2);
+       List       *parts1 = NIL;
+       List       *parts2 = NIL;
+       ListCell   *lcr1 = NULL;
+       ListCell   *lcr2 = NULL;
        int                     cnt_parts;
 
        /* Guard against stack overflow due to overly deep partition hierarchy. */
        check_stack_depth();
 
        /* Nothing to do, if the join relation is not partitioned. */
-       if (!IS_PARTITIONED_REL(joinrel))
+       if (joinrel->part_scheme == NULL || joinrel->nparts == 0)
                return;
 
        /* The join relation should have consider_partitionwise_join set. */
        Assert(joinrel->consider_partitionwise_join);
 
        /*
-        * Since this join relation is partitioned, all the base relations
-        * participating in this join must be partitioned and so are all the
-        * intermediate join relations.
+        * We can not perform partitionwise join if either of the joining
+        * relations is not partitioned.
         */
-       Assert(IS_PARTITIONED_REL(rel1) && IS_PARTITIONED_REL(rel2));
+       if (!IS_PARTITIONED_REL(rel1) || !IS_PARTITIONED_REL(rel2))
+               return;
+
        Assert(REL_HAS_ALL_PART_PROPS(rel1) && REL_HAS_ALL_PART_PROPS(rel2));
 
        /* The joining relations should have consider_partitionwise_join set. */
@@ -1098,31 +1577,28 @@ try_partitionwise_join(PlannerInfo *root, RelOptInfo *rel1, RelOptInfo *rel2,
        Assert(joinrel->part_scheme == rel1->part_scheme &&
                   joinrel->part_scheme == rel2->part_scheme);
 
-       /*
-        * Since we allow partitionwise join only when the partition bounds of the
-        * joining relations exactly match, the partition bounds of the join
-        * should match those of the joining relations.
-        */
-       Assert(partition_bounds_equal(joinrel->part_scheme->partnatts,
-                                                                 joinrel->part_scheme->parttyplen,
-                                                                 joinrel->part_scheme->parttypbyval,
-                                                                 joinrel->boundinfo, rel1->boundinfo));
-       Assert(partition_bounds_equal(joinrel->part_scheme->partnatts,
-                                                                 joinrel->part_scheme->parttyplen,
-                                                                 joinrel->part_scheme->parttypbyval,
-                                                                 joinrel->boundinfo, rel2->boundinfo));
+       Assert(!(joinrel->partbounds_merged && (joinrel->nparts <= 0)));
 
-       nparts = joinrel->nparts;
+       compute_partition_bounds(root, rel1, rel2, joinrel, parent_sjinfo,
+                                                        &parts1, &parts2);
+
+       if (joinrel->partbounds_merged)
+       {
+               lcr1 = list_head(parts1);
+               lcr2 = list_head(parts2);
+       }
 
        /*
         * Create child-join relations for this partitioned join, if those don't
         * exist. Add paths to child-joins for a pair of child relations
         * corresponding to the given pair of parent relations.
         */
-       for (cnt_parts = 0; cnt_parts < nparts; cnt_parts++)
+       for (cnt_parts = 0; cnt_parts < joinrel->nparts; cnt_parts++)
        {
-               RelOptInfo *child_rel1 = rel1->part_rels[cnt_parts];
-               RelOptInfo *child_rel2 = rel2->part_rels[cnt_parts];
+               RelOptInfo *child_rel1;
+               RelOptInfo *child_rel2;
+               bool            rel1_empty;
+               bool            rel2_empty;
                SpecialJoinInfo *child_sjinfo;
                List       *child_restrictlist;
                RelOptInfo *child_joinrel;
@@ -1130,6 +1606,88 @@ try_partitionwise_join(PlannerInfo *root, RelOptInfo *rel1, RelOptInfo *rel2,
                AppendRelInfo **appinfos;
                int                     nappinfos;
 
+               if (joinrel->partbounds_merged)
+               {
+                       child_rel1 = lfirst_node(RelOptInfo, lcr1);
+                       child_rel2 = lfirst_node(RelOptInfo, lcr2);
+                       lcr1 = lnext(parts1, lcr1);
+                       lcr2 = lnext(parts2, lcr2);
+               }
+               else
+               {
+                       child_rel1 = rel1->part_rels[cnt_parts];
+                       child_rel2 = rel2->part_rels[cnt_parts];
+               }
+
+               rel1_empty = (child_rel1 == NULL || IS_DUMMY_REL(child_rel1));
+               rel2_empty = (child_rel2 == NULL || IS_DUMMY_REL(child_rel2));
+
+               /*
+                * Check for cases where we can prove that this segment of the join
+                * returns no rows, due to one or both inputs being empty (including
+                * inputs that have been pruned away entirely).  If so just ignore it.
+                * These rules are equivalent to populate_joinrel_with_paths's rules
+                * for dummy input relations.
+                */
+               switch (parent_sjinfo->jointype)
+               {
+                       case JOIN_INNER:
+                       case JOIN_SEMI:
+                               if (rel1_empty || rel2_empty)
+                                       continue;       /* ignore this join segment */
+                               break;
+                       case JOIN_LEFT:
+                       case JOIN_ANTI:
+                               if (rel1_empty)
+                                       continue;       /* ignore this join segment */
+                               break;
+                       case JOIN_FULL:
+                               if (rel1_empty && rel2_empty)
+                                       continue;       /* ignore this join segment */
+                               break;
+                       default:
+                               /* other values not expected here */
+                               elog(ERROR, "unrecognized join type: %d",
+                                        (int) parent_sjinfo->jointype);
+                               break;
+               }
+
+               /*
+                * If a child has been pruned entirely then we can't generate paths
+                * for it, so we have to reject partitionwise joining unless we were
+                * able to eliminate this partition above.
+                */
+               if (child_rel1 == NULL || child_rel2 == NULL)
+               {
+                       /*
+                        * Mark the joinrel as unpartitioned so that later functions treat
+                        * it correctly.
+                        */
+                       joinrel->nparts = 0;
+                       return;
+               }
+
+               /*
+                * If a leaf relation has consider_partitionwise_join=false, it means
+                * that it's a dummy relation for which we skipped setting up tlist
+                * expressions and adding EC members in set_append_rel_size(), so
+                * again we have to fail here.
+                */
+               if (rel1_is_simple && !child_rel1->consider_partitionwise_join)
+               {
+                       Assert(child_rel1->reloptkind == RELOPT_OTHER_MEMBER_REL);
+                       Assert(IS_DUMMY_REL(child_rel1));
+                       joinrel->nparts = 0;
+                       return;
+               }
+               if (rel2_is_simple && !child_rel2->consider_partitionwise_join)
+               {
+                       Assert(child_rel2->reloptkind == RELOPT_OTHER_MEMBER_REL);
+                       Assert(IS_DUMMY_REL(child_rel2));
+                       joinrel->nparts = 0;
+                       return;
+               }
+
                /* We should never try to join two overlapping sets of rels. */
                Assert(!bms_overlap(child_rel1->relids, child_rel2->relids));
                child_joinrelids = bms_union(child_rel1->relids, child_rel2->relids);
@@ -1161,6 +1719,8 @@ try_partitionwise_join(PlannerInfo *root, RelOptInfo *rel1, RelOptInfo *rel2,
                                                                                                 child_sjinfo,
                                                                                                 child_sjinfo->jointype);
                        joinrel->part_rels[cnt_parts] = child_joinrel;
+                       joinrel->all_partrels = bms_add_members(joinrel->all_partrels,
+                                                                                                       child_joinrel->relids);
                }
 
                Assert(bms_equal(child_joinrel->relids, child_joinrelids));