Header And Logo

PostgreSQL
| The world's most advanced open source database.

Functions

nodeSubplan.h File Reference

#include "nodes/execnodes.h"
Include dependency graph for nodeSubplan.h:
This graph shows which files directly or indirectly include this file:

Go to the source code of this file.

Functions

SubPlanStateExecInitSubPlan (SubPlan *subplan, PlanState *parent)
AlternativeSubPlanStateExecInitAlternativeSubPlan (AlternativeSubPlan *asplan, PlanState *parent)
void ExecReScanSetParamPlan (SubPlanState *node, PlanState *parent)
void ExecSetParamPlan (SubPlanState *node, ExprContext *econtext)

Function Documentation

AlternativeSubPlanState* ExecInitAlternativeSubPlan ( AlternativeSubPlan asplan,
PlanState parent 
)

Definition at line 1103 of file nodeSubplan.c.

References AlternativeSubPlanState::active, Assert, ExprState::evalfunc, ExecAlternativeSubPlan(), ExecInitExpr(), ExprState::expr, linitial, list_length(), lsecond, makeNode, SubPlan::per_call_cost, PlanState::plan, Plan::plan_rows, SubPlan::startup_cost, AlternativeSubPlan::subplans, AlternativeSubPlanState::subplans, and AlternativeSubPlanState::xprstate.

Referenced by ExecInitExpr().

{
    AlternativeSubPlanState *asstate = makeNode(AlternativeSubPlanState);
    double      num_calls;
    SubPlan    *subplan1;
    SubPlan    *subplan2;
    Cost        cost1;
    Cost        cost2;

    asstate->xprstate.evalfunc = (ExprStateEvalFunc) ExecAlternativeSubPlan;
    asstate->xprstate.expr = (Expr *) asplan;

    /*
     * Initialize subplans.  (Can we get away with only initializing the one
     * we're going to use?)
     */
    asstate->subplans = (List *) ExecInitExpr((Expr *) asplan->subplans,
                                              parent);

    /*
     * Select the one to be used.  For this, we need an estimate of the number
     * of executions of the subplan.  We use the number of output rows
     * expected from the parent plan node.  This is a good estimate if we are
     * in the parent's targetlist, and an underestimate (but probably not by
     * more than a factor of 2) if we are in the qual.
     */
    num_calls = parent->plan->plan_rows;

    /*
     * The planner saved enough info so that we don't have to work very hard
     * to estimate the total cost, given the number-of-calls estimate.
     */
    Assert(list_length(asplan->subplans) == 2);
    subplan1 = (SubPlan *) linitial(asplan->subplans);
    subplan2 = (SubPlan *) lsecond(asplan->subplans);

    cost1 = subplan1->startup_cost + num_calls * subplan1->per_call_cost;
    cost2 = subplan2->startup_cost + num_calls * subplan2->per_call_cost;

    if (cost1 < cost2)
        asstate->active = 0;
    else
        asstate->active = 1;

    return asstate;
}

SubPlanState* ExecInitSubPlan ( SubPlan subplan,
PlanState parent 
)

Definition at line 658 of file nodeSubplan.c.

References ALLOCSET_DEFAULT_INITSIZE, ALLOCSET_DEFAULT_MAXSIZE, ALLOCSET_DEFAULT_MINSIZE, ALLOCSET_SMALL_INITSIZE, ALLOCSET_SMALL_MAXSIZE, ALLOCSET_SMALL_MINSIZE, AllocSetContextCreate(), and_clause(), FuncExprState::args, SubPlan::args, SubPlanState::args, Assert, CreateExprContext(), CTE_SUBLINK, SubPlanState::cur_eq_funcs, SubPlanState::curArray, CurrentMemoryContext, SubPlanState::curTuple, elog, ERROR, EState::es_param_exec_vals, EState::es_subplanstates, ExprState::evalfunc, ExecBuildProjectionInfo(), ExecInitExpr(), ExecInitExtraTupleSlot(), ParamExecData::execPlan, ExecSetSlotDescriptor(), ExecSubPlan(), ExecTypeFromTL(), ExprState::expr, fmgr_info(), fmgr_info_set_expr, get_compatible_hash_operators(), get_op_hash_functions(), get_opcode(), SubPlanState::hashnulls, SubPlanState::hashtable, SubPlanState::hashtablecxt, SubPlanState::hashtempcxt, i, SubPlanState::innerecontext, IsA, SubPlanState::keyColIdx, lappend(), lfirst, lfirst_int, SubPlanState::lhs_hash_funcs, linitial, list_length(), list_make1, list_nth(), lsecond, makeNode, makeTargetEntry(), NIL, nodeTag, NULL, OpExpr::opfuncid, palloc(), SubPlan::paramIds, SubPlan::plan_id, SubPlanState::planstate, PointerGetDatum, SubPlanState::projLeft, SubPlanState::projRight, SubPlan::setParam, PlanState::state, SubPlan::subLinkType, SubPlanState::tab_eq_funcs, SubPlanState::tab_hash_funcs, SubPlan::testexpr, SubPlanState::testexpr, SubPlan::useHashTable, FuncExprState::xprstate, and SubPlanState::xprstate.

Referenced by ExecInitExpr(), and ExecInitNode().

{
    SubPlanState *sstate = makeNode(SubPlanState);
    EState     *estate = parent->state;

    sstate->xprstate.evalfunc = (ExprStateEvalFunc) ExecSubPlan;
    sstate->xprstate.expr = (Expr *) subplan;

    /* Link the SubPlanState to already-initialized subplan */
    sstate->planstate = (PlanState *) list_nth(estate->es_subplanstates,
                                               subplan->plan_id - 1);

    /* Initialize subexpressions */
    sstate->testexpr = ExecInitExpr((Expr *) subplan->testexpr, parent);
    sstate->args = (List *) ExecInitExpr((Expr *) subplan->args, parent);

    /*
     * initialize my state
     */
    sstate->curTuple = NULL;
    sstate->curArray = PointerGetDatum(NULL);
    sstate->projLeft = NULL;
    sstate->projRight = NULL;
    sstate->hashtable = NULL;
    sstate->hashnulls = NULL;
    sstate->hashtablecxt = NULL;
    sstate->hashtempcxt = NULL;
    sstate->innerecontext = NULL;
    sstate->keyColIdx = NULL;
    sstate->tab_hash_funcs = NULL;
    sstate->tab_eq_funcs = NULL;
    sstate->lhs_hash_funcs = NULL;
    sstate->cur_eq_funcs = NULL;

    /*
     * If this plan is un-correlated or undirect correlated one and want to
     * set params for parent plan then mark parameters as needing evaluation.
     *
     * A CTE subplan's output parameter is never to be evaluated in the normal
     * way, so skip this in that case.
     *
     * Note that in the case of un-correlated subqueries we don't care about
     * setting parent->chgParam here: indices take care about it, for others -
     * it doesn't matter...
     */
    if (subplan->setParam != NIL && subplan->subLinkType != CTE_SUBLINK)
    {
        ListCell   *lst;

        foreach(lst, subplan->setParam)
        {
            int         paramid = lfirst_int(lst);
            ParamExecData *prm = &(estate->es_param_exec_vals[paramid]);

            prm->execPlan = sstate;
        }
    }

    /*
     * If we are going to hash the subquery output, initialize relevant stuff.
     * (We don't create the hashtable until needed, though.)
     */
    if (subplan->useHashTable)
    {
        int         ncols,
                    i;
        TupleDesc   tupDesc;
        TupleTableSlot *slot;
        List       *oplist,
                   *lefttlist,
                   *righttlist,
                   *leftptlist,
                   *rightptlist;
        ListCell   *l;

        /* We need a memory context to hold the hash table(s) */
        sstate->hashtablecxt =
            AllocSetContextCreate(CurrentMemoryContext,
                                  "Subplan HashTable Context",
                                  ALLOCSET_DEFAULT_MINSIZE,
                                  ALLOCSET_DEFAULT_INITSIZE,
                                  ALLOCSET_DEFAULT_MAXSIZE);
        /* and a small one for the hash tables to use as temp storage */
        sstate->hashtempcxt =
            AllocSetContextCreate(CurrentMemoryContext,
                                  "Subplan HashTable Temp Context",
                                  ALLOCSET_SMALL_MINSIZE,
                                  ALLOCSET_SMALL_INITSIZE,
                                  ALLOCSET_SMALL_MAXSIZE);
        /* and a short-lived exprcontext for function evaluation */
        sstate->innerecontext = CreateExprContext(estate);
        /* Silly little array of column numbers 1..n */
        ncols = list_length(subplan->paramIds);
        sstate->keyColIdx = (AttrNumber *) palloc(ncols * sizeof(AttrNumber));
        for (i = 0; i < ncols; i++)
            sstate->keyColIdx[i] = i + 1;

        /*
         * We use ExecProject to evaluate the lefthand and righthand
         * expression lists and form tuples.  (You might think that we could
         * use the sub-select's output tuples directly, but that is not the
         * case if we had to insert any run-time coercions of the sub-select's
         * output datatypes; anyway this avoids storing any resjunk columns
         * that might be in the sub-select's output.) Run through the
         * combining expressions to build tlists for the lefthand and
         * righthand sides.  We need both the ExprState list (for ExecProject)
         * and the underlying parse Exprs (for ExecTypeFromTL).
         *
         * We also extract the combining operators themselves to initialize
         * the equality and hashing functions for the hash tables.
         */
        if (IsA(sstate->testexpr->expr, OpExpr))
        {
            /* single combining operator */
            oplist = list_make1(sstate->testexpr);
        }
        else if (and_clause((Node *) sstate->testexpr->expr))
        {
            /* multiple combining operators */
            Assert(IsA(sstate->testexpr, BoolExprState));
            oplist = ((BoolExprState *) sstate->testexpr)->args;
        }
        else
        {
            /* shouldn't see anything else in a hashable subplan */
            elog(ERROR, "unrecognized testexpr type: %d",
                 (int) nodeTag(sstate->testexpr->expr));
            oplist = NIL;       /* keep compiler quiet */
        }
        Assert(list_length(oplist) == ncols);

        lefttlist = righttlist = NIL;
        leftptlist = rightptlist = NIL;
        sstate->tab_hash_funcs = (FmgrInfo *) palloc(ncols * sizeof(FmgrInfo));
        sstate->tab_eq_funcs = (FmgrInfo *) palloc(ncols * sizeof(FmgrInfo));
        sstate->lhs_hash_funcs = (FmgrInfo *) palloc(ncols * sizeof(FmgrInfo));
        sstate->cur_eq_funcs = (FmgrInfo *) palloc(ncols * sizeof(FmgrInfo));
        i = 1;
        foreach(l, oplist)
        {
            FuncExprState *fstate = (FuncExprState *) lfirst(l);
            OpExpr     *opexpr = (OpExpr *) fstate->xprstate.expr;
            ExprState  *exstate;
            Expr       *expr;
            TargetEntry *tle;
            GenericExprState *tlestate;
            Oid         rhs_eq_oper;
            Oid         left_hashfn;
            Oid         right_hashfn;

            Assert(IsA(fstate, FuncExprState));
            Assert(IsA(opexpr, OpExpr));
            Assert(list_length(fstate->args) == 2);

            /* Process lefthand argument */
            exstate = (ExprState *) linitial(fstate->args);
            expr = exstate->expr;
            tle = makeTargetEntry(expr,
                                  i,
                                  NULL,
                                  false);
            tlestate = makeNode(GenericExprState);
            tlestate->xprstate.expr = (Expr *) tle;
            tlestate->xprstate.evalfunc = NULL;
            tlestate->arg = exstate;
            lefttlist = lappend(lefttlist, tlestate);
            leftptlist = lappend(leftptlist, tle);

            /* Process righthand argument */
            exstate = (ExprState *) lsecond(fstate->args);
            expr = exstate->expr;
            tle = makeTargetEntry(expr,
                                  i,
                                  NULL,
                                  false);
            tlestate = makeNode(GenericExprState);
            tlestate->xprstate.expr = (Expr *) tle;
            tlestate->xprstate.evalfunc = NULL;
            tlestate->arg = exstate;
            righttlist = lappend(righttlist, tlestate);
            rightptlist = lappend(rightptlist, tle);

            /* Lookup the equality function (potentially cross-type) */
            fmgr_info(opexpr->opfuncid, &sstate->cur_eq_funcs[i - 1]);
            fmgr_info_set_expr((Node *) opexpr, &sstate->cur_eq_funcs[i - 1]);

            /* Look up the equality function for the RHS type */
            if (!get_compatible_hash_operators(opexpr->opno,
                                               NULL, &rhs_eq_oper))
                elog(ERROR, "could not find compatible hash operator for operator %u",
                     opexpr->opno);
            fmgr_info(get_opcode(rhs_eq_oper), &sstate->tab_eq_funcs[i - 1]);

            /* Lookup the associated hash functions */
            if (!get_op_hash_functions(opexpr->opno,
                                       &left_hashfn, &right_hashfn))
                elog(ERROR, "could not find hash function for hash operator %u",
                     opexpr->opno);
            fmgr_info(left_hashfn, &sstate->lhs_hash_funcs[i - 1]);
            fmgr_info(right_hashfn, &sstate->tab_hash_funcs[i - 1]);

            i++;
        }

        /*
         * Construct tupdescs, slots and projection nodes for left and right
         * sides.  The lefthand expressions will be evaluated in the parent
         * plan node's exprcontext, which we don't have access to here.
         * Fortunately we can just pass NULL for now and fill it in later
         * (hack alert!).  The righthand expressions will be evaluated in our
         * own innerecontext.
         */
        tupDesc = ExecTypeFromTL(leftptlist, false);
        slot = ExecInitExtraTupleSlot(estate);
        ExecSetSlotDescriptor(slot, tupDesc);
        sstate->projLeft = ExecBuildProjectionInfo(lefttlist,
                                                   NULL,
                                                   slot,
                                                   NULL);

        tupDesc = ExecTypeFromTL(rightptlist, false);
        slot = ExecInitExtraTupleSlot(estate);
        ExecSetSlotDescriptor(slot, tupDesc);
        sstate->projRight = ExecBuildProjectionInfo(righttlist,
                                                    sstate->innerecontext,
                                                    slot,
                                                    NULL);
    }

    return sstate;
}

void ExecReScanSetParamPlan ( SubPlanState node,
PlanState parent 
)

Definition at line 1057 of file nodeSubplan.c.

References bms_add_member(), bms_is_empty(), PlanState::chgParam, CTE_SUBLINK, elog, ERROR, ParamExecData::execPlan, ExprState::expr, Plan::extParam, lfirst_int, NIL, SubPlan::parParam, PlanState::plan, SubPlanState::planstate, SubPlan::setParam, PlanState::state, SubPlan::subLinkType, and SubPlanState::xprstate.

Referenced by ExecReScan().

{
    PlanState  *planstate = node->planstate;
    SubPlan    *subplan = (SubPlan *) node->xprstate.expr;
    EState     *estate = parent->state;
    ListCell   *l;

    /* sanity checks */
    if (subplan->parParam != NIL)
        elog(ERROR, "direct correlated subquery unsupported as initplan");
    if (subplan->setParam == NIL)
        elog(ERROR, "setParam list of initplan is empty");
    if (bms_is_empty(planstate->plan->extParam))
        elog(ERROR, "extParam set of initplan is empty");

    /*
     * Don't actually re-scan: it'll happen inside ExecSetParamPlan if needed.
     */

    /*
     * Mark this subplan's output parameters as needing recalculation.
     *
     * CTE subplans are never executed via parameter recalculation; instead
     * they get run when called by nodeCtescan.c.  So don't mark the output
     * parameter of a CTE subplan as dirty, but do set the chgParam bit for it
     * so that dependent plan nodes will get told to rescan.
     */
    foreach(l, subplan->setParam)
    {
        int         paramid = lfirst_int(l);
        ParamExecData *prm = &(estate->es_param_exec_vals[paramid]);

        if (subplan->subLinkType != CTE_SUBLINK)
            prm->execPlan = node;

        parent->chgParam = bms_add_member(parent->chgParam, paramid);
    }
}

void ExecSetParamPlan ( SubPlanState node,
ExprContext econtext 
)

Definition at line 904 of file nodeSubplan.c.

References accumArrayResult(), ALL_SUBLINK, ANY_SUBLINK, ARRAY_SUBLINK, Assert, tupleDesc::attrs, BoolGetDatum, construct_empty_array(), CTE_SUBLINK, SubPlanState::curArray, SubPlanState::curTuple, DatumGetPointer, ExprContext::ecxt_param_exec_vals, ExprContext::ecxt_per_query_memory, elog, ereport, errcode(), errmsg(), ERROR, ExecCopySlotTuple(), ParamExecData::execPlan, ExecProcNode(), EXISTS_SUBLINK, ExprState::expr, EXPR_SUBLINK, SubPlan::firstColType, heap_freetuple(), heap_getattr, i, ParamExecData::isnull, lfirst_int, linitial_int, makeArrayResult(), MemoryContextSwitchTo(), NULL, pfree(), SubPlanState::planstate, PointerGetDatum, ROWCOMPARE_SUBLINK, SubPlan::setParam, slot_getattr(), SubPlan::subLinkType, TupIsNull, ParamExecData::value, and SubPlanState::xprstate.

Referenced by ExecEvalParamExec().

{
    SubPlan    *subplan = (SubPlan *) node->xprstate.expr;
    PlanState  *planstate = node->planstate;
    SubLinkType subLinkType = subplan->subLinkType;
    MemoryContext oldcontext;
    TupleTableSlot *slot;
    ListCell   *l;
    bool        found = false;
    ArrayBuildState *astate = NULL;

    if (subLinkType == ANY_SUBLINK ||
        subLinkType == ALL_SUBLINK)
        elog(ERROR, "ANY/ALL subselect unsupported as initplan");
    if (subLinkType == CTE_SUBLINK)
        elog(ERROR, "CTE subplans should not be executed via ExecSetParamPlan");

    /*
     * Must switch to per-query memory context.
     */
    oldcontext = MemoryContextSwitchTo(econtext->ecxt_per_query_memory);

    /*
     * Run the plan.  (If it needs to be rescanned, the first ExecProcNode
     * call will take care of that.)
     */
    for (slot = ExecProcNode(planstate);
         !TupIsNull(slot);
         slot = ExecProcNode(planstate))
    {
        TupleDesc   tdesc = slot->tts_tupleDescriptor;
        int         i = 1;

        if (subLinkType == EXISTS_SUBLINK)
        {
            /* There can be only one setParam... */
            int         paramid = linitial_int(subplan->setParam);
            ParamExecData *prm = &(econtext->ecxt_param_exec_vals[paramid]);

            prm->execPlan = NULL;
            prm->value = BoolGetDatum(true);
            prm->isnull = false;
            found = true;
            break;
        }

        if (subLinkType == ARRAY_SUBLINK)
        {
            Datum       dvalue;
            bool        disnull;

            found = true;
            /* stash away current value */
            Assert(subplan->firstColType == tdesc->attrs[0]->atttypid);
            dvalue = slot_getattr(slot, 1, &disnull);
            astate = accumArrayResult(astate, dvalue, disnull,
                                      subplan->firstColType, oldcontext);
            /* keep scanning subplan to collect all values */
            continue;
        }

        if (found &&
            (subLinkType == EXPR_SUBLINK ||
             subLinkType == ROWCOMPARE_SUBLINK))
            ereport(ERROR,
                    (errcode(ERRCODE_CARDINALITY_VIOLATION),
                     errmsg("more than one row returned by a subquery used as an expression")));

        found = true;

        /*
         * We need to copy the subplan's tuple into our own context, in case
         * any of the params are pass-by-ref type --- the pointers stored in
         * the param structs will point at this copied tuple! node->curTuple
         * keeps track of the copied tuple for eventual freeing.
         */
        if (node->curTuple)
            heap_freetuple(node->curTuple);
        node->curTuple = ExecCopySlotTuple(slot);

        /*
         * Now set all the setParam params from the columns of the tuple
         */
        foreach(l, subplan->setParam)
        {
            int         paramid = lfirst_int(l);
            ParamExecData *prm = &(econtext->ecxt_param_exec_vals[paramid]);

            prm->execPlan = NULL;
            prm->value = heap_getattr(node->curTuple, i, tdesc,
                                      &(prm->isnull));
            i++;
        }
    }

    if (subLinkType == ARRAY_SUBLINK)
    {
        /* There can be only one setParam... */
        int         paramid = linitial_int(subplan->setParam);
        ParamExecData *prm = &(econtext->ecxt_param_exec_vals[paramid]);

        /*
         * We build the result array in query context so it won't disappear;
         * to avoid leaking memory across repeated calls, we have to remember
         * the latest value, much as for curTuple above.
         */
        if (node->curArray != PointerGetDatum(NULL))
            pfree(DatumGetPointer(node->curArray));
        if (astate != NULL)
            node->curArray = makeArrayResult(astate,
                                             econtext->ecxt_per_query_memory);
        else
        {
            MemoryContextSwitchTo(econtext->ecxt_per_query_memory);
            node->curArray = PointerGetDatum(construct_empty_array(subplan->firstColType));
        }
        prm->execPlan = NULL;
        prm->value = node->curArray;
        prm->isnull = false;
    }
    else if (!found)
    {
        if (subLinkType == EXISTS_SUBLINK)
        {
            /* There can be only one setParam... */
            int         paramid = linitial_int(subplan->setParam);
            ParamExecData *prm = &(econtext->ecxt_param_exec_vals[paramid]);

            prm->execPlan = NULL;
            prm->value = BoolGetDatum(false);
            prm->isnull = false;
        }
        else
        {
            foreach(l, subplan->setParam)
            {
                int         paramid = lfirst_int(l);
                ParamExecData *prm = &(econtext->ecxt_param_exec_vals[paramid]);

                prm->execPlan = NULL;
                prm->value = (Datum) 0;
                prm->isnull = true;
            }
        }
    }

    MemoryContextSwitchTo(oldcontext);
}