Header And Logo

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

Functions | Variables

parse_expr.c File Reference

#include "postgres.h"
#include "catalog/pg_type.h"
#include "commands/dbcommands.h"
#include "miscadmin.h"
#include "nodes/makefuncs.h"
#include "nodes/nodeFuncs.h"
#include "optimizer/var.h"
#include "parser/analyze.h"
#include "parser/parse_coerce.h"
#include "parser/parse_collate.h"
#include "parser/parse_expr.h"
#include "parser/parse_func.h"
#include "parser/parse_oper.h"
#include "parser/parse_relation.h"
#include "parser/parse_target.h"
#include "parser/parse_type.h"
#include "utils/builtins.h"
#include "utils/lsyscache.h"
#include "utils/xml.h"
Include dependency graph for parse_expr.c:

Go to the source code of this file.

Functions

static NodetransformExprRecurse (ParseState *pstate, Node *expr)
static NodetransformParamRef (ParseState *pstate, ParamRef *pref)
static NodetransformAExprOp (ParseState *pstate, A_Expr *a)
static NodetransformAExprAnd (ParseState *pstate, A_Expr *a)
static NodetransformAExprOr (ParseState *pstate, A_Expr *a)
static NodetransformAExprNot (ParseState *pstate, A_Expr *a)
static NodetransformAExprOpAny (ParseState *pstate, A_Expr *a)
static NodetransformAExprOpAll (ParseState *pstate, A_Expr *a)
static NodetransformAExprDistinct (ParseState *pstate, A_Expr *a)
static NodetransformAExprNullIf (ParseState *pstate, A_Expr *a)
static NodetransformAExprOf (ParseState *pstate, A_Expr *a)
static NodetransformAExprIn (ParseState *pstate, A_Expr *a)
static NodetransformFuncCall (ParseState *pstate, FuncCall *fn)
static NodetransformCaseExpr (ParseState *pstate, CaseExpr *c)
static NodetransformSubLink (ParseState *pstate, SubLink *sublink)
static NodetransformArrayExpr (ParseState *pstate, A_ArrayExpr *a, Oid array_type, Oid element_type, int32 typmod)
static NodetransformRowExpr (ParseState *pstate, RowExpr *r)
static NodetransformCoalesceExpr (ParseState *pstate, CoalesceExpr *c)
static NodetransformMinMaxExpr (ParseState *pstate, MinMaxExpr *m)
static NodetransformXmlExpr (ParseState *pstate, XmlExpr *x)
static NodetransformXmlSerialize (ParseState *pstate, XmlSerialize *xs)
static NodetransformBooleanTest (ParseState *pstate, BooleanTest *b)
static NodetransformCurrentOfExpr (ParseState *pstate, CurrentOfExpr *cexpr)
static NodetransformColumnRef (ParseState *pstate, ColumnRef *cref)
static NodetransformWholeRowRef (ParseState *pstate, RangeTblEntry *rte, int location)
static NodetransformIndirection (ParseState *pstate, Node *basenode, List *indirection)
static NodetransformTypeCast (ParseState *pstate, TypeCast *tc)
static NodetransformCollateClause (ParseState *pstate, CollateClause *c)
static Nodemake_row_comparison_op (ParseState *pstate, List *opname, List *largs, List *rargs, int location)
static Nodemake_row_distinct_op (ParseState *pstate, List *opname, RowExpr *lrow, RowExpr *rrow, int location)
static Exprmake_distinct_op (ParseState *pstate, List *opname, Node *ltree, Node *rtree, int location)
NodetransformExpr (ParseState *pstate, Node *expr, ParseExprKind exprKind)
static void unknown_attribute (ParseState *pstate, Node *relref, char *attname, int location)
static bool exprIsNullConstant (Node *arg)
const char * ParseExprKindName (ParseExprKind exprKind)

Variables

bool Transform_null_equals = false

Function Documentation

static bool exprIsNullConstant ( Node arg  )  [static]

Definition at line 829 of file parse_expr.c.

References IsA, T_Null, Value::type, and A_Const::val.

Referenced by transformAExprOp().

{
    if (arg && IsA(arg, A_Const))
    {
        A_Const    *con = (A_Const *) arg;

        if (con->val.type == T_Null)
            return true;
    }
    return false;
}

static Expr * make_distinct_op ( ParseState pstate,
List opname,
Node ltree,
Node rtree,
int  location 
) [static]

Definition at line 2534 of file parse_expr.c.

References BOOLOID, ereport, errcode(), errmsg(), ERROR, make_op(), NodeSetTag, parser_errposition(), and T_DistinctExpr.

Referenced by make_row_distinct_op(), and transformAExprDistinct().

{
    Expr       *result;

    result = make_op(pstate, opname, ltree, rtree, location);
    if (((OpExpr *) result)->opresulttype != BOOLOID)
        ereport(ERROR,
                (errcode(ERRCODE_DATATYPE_MISMATCH),
             errmsg("IS DISTINCT FROM requires = operator to yield boolean"),
                 parser_errposition(pstate, location)));

    /*
     * We rely on DistinctExpr and OpExpr being same struct
     */
    NodeSetTag(result, T_DistinctExpr);

    return result;
}

static Node * make_row_comparison_op ( ParseState pstate,
List opname,
List largs,
List rargs,
int  location 
) [static]

Definition at line 2284 of file parse_expr.c.

References AND_EXPR, OpExpr::args, Assert, bms_add_member(), bms_first_member(), bms_int_members(), BOOLOID, cmp(), ereport, errcode(), errdetail(), errhint(), errmsg(), ERROR, expression_returns_set(), forboth, format_type_be(), get_op_btree_interpretation(), i, RowCompareExpr::inputcollids, IsA, lappend(), lappend_oid(), RowCompareExpr::largs, lfirst, linitial, list_length(), llast, lsecond, make_op(), makeBoolExpr(), makeNode, OidIsValid, RowCompareExpr::opfamilies, OpBtreeInterpretation::opfamily_id, OpExpr::opno, RowCompareExpr::opnos, OpExpr::opresulttype, OR_EXPR, palloc(), parser_errposition(), RowCompareExpr::rargs, RowCompareExpr::rctype, ROWCOMPARE_EQ, ROWCOMPARE_NE, OpBtreeInterpretation::strategy, and strVal.

Referenced by transformAExprIn(), transformAExprOp(), and transformSubLink().

{
    RowCompareExpr *rcexpr;
    RowCompareType rctype;
    List       *opexprs;
    List       *opnos;
    List       *opfamilies;
    ListCell   *l,
               *r;
    List      **opinfo_lists;
    Bitmapset  *strats;
    int         nopers;
    int         i;

    nopers = list_length(largs);
    if (nopers != list_length(rargs))
        ereport(ERROR,
                (errcode(ERRCODE_SYNTAX_ERROR),
                 errmsg("unequal number of entries in row expressions"),
                 parser_errposition(pstate, location)));

    /*
     * We can't compare zero-length rows because there is no principled basis
     * for figuring out what the operator is.
     */
    if (nopers == 0)
        ereport(ERROR,
                (errcode(ERRCODE_FEATURE_NOT_SUPPORTED),
                 errmsg("cannot compare rows of zero length"),
                 parser_errposition(pstate, location)));

    /*
     * Identify all the pairwise operators, using make_op so that behavior is
     * the same as in the simple scalar case.
     */
    opexprs = NIL;
    forboth(l, largs, r, rargs)
    {
        Node       *larg = (Node *) lfirst(l);
        Node       *rarg = (Node *) lfirst(r);
        OpExpr     *cmp;

        cmp = (OpExpr *) make_op(pstate, opname, larg, rarg, location);
        Assert(IsA(cmp, OpExpr));

        /*
         * We don't use coerce_to_boolean here because we insist on the
         * operator yielding boolean directly, not via coercion.  If it
         * doesn't yield bool it won't be in any index opfamilies...
         */
        if (cmp->opresulttype != BOOLOID)
            ereport(ERROR,
                    (errcode(ERRCODE_DATATYPE_MISMATCH),
                   errmsg("row comparison operator must yield type boolean, "
                          "not type %s",
                          format_type_be(cmp->opresulttype)),
                     parser_errposition(pstate, location)));
        if (expression_returns_set((Node *) cmp))
            ereport(ERROR,
                    (errcode(ERRCODE_DATATYPE_MISMATCH),
                     errmsg("row comparison operator must not return a set"),
                     parser_errposition(pstate, location)));
        opexprs = lappend(opexprs, cmp);
    }

    /*
     * If rows are length 1, just return the single operator.  In this case we
     * don't insist on identifying btree semantics for the operator (but we
     * still require it to return boolean).
     */
    if (nopers == 1)
        return (Node *) linitial(opexprs);

    /*
     * Now we must determine which row comparison semantics (= <> < <= > >=)
     * apply to this set of operators.  We look for btree opfamilies
     * containing the operators, and see which interpretations (strategy
     * numbers) exist for each operator.
     */
    opinfo_lists = (List **) palloc(nopers * sizeof(List *));
    strats = NULL;
    i = 0;
    foreach(l, opexprs)
    {
        Oid         opno = ((OpExpr *) lfirst(l))->opno;
        Bitmapset  *this_strats;
        ListCell   *j;

        opinfo_lists[i] = get_op_btree_interpretation(opno);

        /*
         * convert strategy numbers into a Bitmapset to make the intersection
         * calculation easy.
         */
        this_strats = NULL;
        foreach(j, opinfo_lists[i])
        {
            OpBtreeInterpretation *opinfo = lfirst(j);

            this_strats = bms_add_member(this_strats, opinfo->strategy);
        }
        if (i == 0)
            strats = this_strats;
        else
            strats = bms_int_members(strats, this_strats);
        i++;
    }

    /*
     * If there are multiple common interpretations, we may use any one of
     * them ... this coding arbitrarily picks the lowest btree strategy
     * number.
     */
    i = bms_first_member(strats);
    if (i < 0)
    {
        /* No common interpretation, so fail */
        ereport(ERROR,
                (errcode(ERRCODE_FEATURE_NOT_SUPPORTED),
                 errmsg("could not determine interpretation of row comparison operator %s",
                        strVal(llast(opname))),
                 errhint("Row comparison operators must be associated with btree operator families."),
                 parser_errposition(pstate, location)));
    }
    rctype = (RowCompareType) i;

    /*
     * For = and <> cases, we just combine the pairwise operators with AND or
     * OR respectively.
     *
     * Note: this is presently the only place where the parser generates
     * BoolExpr with more than two arguments.  Should be OK since the rest of
     * the system thinks BoolExpr is N-argument anyway.
     */
    if (rctype == ROWCOMPARE_EQ)
        return (Node *) makeBoolExpr(AND_EXPR, opexprs, location);
    if (rctype == ROWCOMPARE_NE)
        return (Node *) makeBoolExpr(OR_EXPR, opexprs, location);

    /*
     * Otherwise we need to choose exactly which opfamily to associate with
     * each operator.
     */
    opfamilies = NIL;
    for (i = 0; i < nopers; i++)
    {
        Oid         opfamily = InvalidOid;
        ListCell   *j;

        foreach(j, opinfo_lists[i])
        {
            OpBtreeInterpretation *opinfo = lfirst(j);

            if (opinfo->strategy == rctype)
            {
                opfamily = opinfo->opfamily_id;
                break;
            }
        }
        if (OidIsValid(opfamily))
            opfamilies = lappend_oid(opfamilies, opfamily);
        else    /* should not happen */
            ereport(ERROR,
                    (errcode(ERRCODE_FEATURE_NOT_SUPPORTED),
                     errmsg("could not determine interpretation of row comparison operator %s",
                            strVal(llast(opname))),
               errdetail("There are multiple equally-plausible candidates."),
                     parser_errposition(pstate, location)));
    }

    /*
     * Now deconstruct the OpExprs and create a RowCompareExpr.
     *
     * Note: can't just reuse the passed largs/rargs lists, because of
     * possibility that make_op inserted coercion operations.
     */
    opnos = NIL;
    largs = NIL;
    rargs = NIL;
    foreach(l, opexprs)
    {
        OpExpr     *cmp = (OpExpr *) lfirst(l);

        opnos = lappend_oid(opnos, cmp->opno);
        largs = lappend(largs, linitial(cmp->args));
        rargs = lappend(rargs, lsecond(cmp->args));
    }

    rcexpr = makeNode(RowCompareExpr);
    rcexpr->rctype = rctype;
    rcexpr->opnos = opnos;
    rcexpr->opfamilies = opfamilies;
    rcexpr->inputcollids = NIL; /* assign_expr_collations will fix this */
    rcexpr->largs = largs;
    rcexpr->rargs = rargs;

    return (Node *) rcexpr;
}

static Node * make_row_distinct_op ( ParseState pstate,
List opname,
RowExpr lrow,
RowExpr rrow,
int  location 
) [static]

Definition at line 2490 of file parse_expr.c.

References RowExpr::args, ereport, errcode(), errmsg(), ERROR, forboth, lfirst, list_length(), list_make2, make_distinct_op(), makeBoolConst(), makeBoolExpr(), NULL, OR_EXPR, and parser_errposition().

Referenced by transformAExprDistinct().

{
    Node       *result = NULL;
    List       *largs = lrow->args;
    List       *rargs = rrow->args;
    ListCell   *l,
               *r;

    if (list_length(largs) != list_length(rargs))
        ereport(ERROR,
                (errcode(ERRCODE_SYNTAX_ERROR),
                 errmsg("unequal number of entries in row expressions"),
                 parser_errposition(pstate, location)));

    forboth(l, largs, r, rargs)
    {
        Node       *larg = (Node *) lfirst(l);
        Node       *rarg = (Node *) lfirst(r);
        Node       *cmp;

        cmp = (Node *) make_distinct_op(pstate, opname, larg, rarg, location);
        if (result == NULL)
            result = cmp;
        else
            result = (Node *) makeBoolExpr(OR_EXPR,
                                           list_make2(result, cmp),
                                           location);
    }

    if (result == NULL)
    {
        /* zero-length rows?  Generate constant FALSE */
        result = makeBoolConst(false, false);
    }

    return result;
}

const char* ParseExprKindName ( ParseExprKind  exprKind  ) 

Definition at line 2562 of file parse_expr.c.

References EXPR_KIND_ALTER_COL_TRANSFORM, EXPR_KIND_CHECK_CONSTRAINT, EXPR_KIND_COLUMN_DEFAULT, EXPR_KIND_DISTINCT_ON, EXPR_KIND_DOMAIN_CHECK, EXPR_KIND_EXECUTE_PARAMETER, EXPR_KIND_FROM_FUNCTION, EXPR_KIND_FROM_SUBSELECT, EXPR_KIND_FUNCTION_DEFAULT, EXPR_KIND_GROUP_BY, EXPR_KIND_HAVING, EXPR_KIND_INDEX_EXPRESSION, EXPR_KIND_INDEX_PREDICATE, EXPR_KIND_INSERT_TARGET, EXPR_KIND_JOIN_ON, EXPR_KIND_JOIN_USING, EXPR_KIND_LIMIT, EXPR_KIND_NONE, EXPR_KIND_OFFSET, EXPR_KIND_ORDER_BY, EXPR_KIND_OTHER, EXPR_KIND_RETURNING, EXPR_KIND_SELECT_TARGET, EXPR_KIND_TRIGGER_WHEN, EXPR_KIND_UPDATE_SOURCE, EXPR_KIND_UPDATE_TARGET, EXPR_KIND_VALUES, EXPR_KIND_WHERE, EXPR_KIND_WINDOW_FRAME_RANGE, EXPR_KIND_WINDOW_FRAME_ROWS, EXPR_KIND_WINDOW_ORDER, and EXPR_KIND_WINDOW_PARTITION.

Referenced by checkTargetlistEntrySQL92(), findTargetlistEntrySQL92(), transformAggregateCall(), and transformWindowFuncCall().

{
    switch (exprKind)
    {
        case EXPR_KIND_NONE:
            return "invalid expression context";
        case EXPR_KIND_OTHER:
            return "extension expression";
        case EXPR_KIND_JOIN_ON:
            return "JOIN/ON";
        case EXPR_KIND_JOIN_USING:
            return "JOIN/USING";
        case EXPR_KIND_FROM_SUBSELECT:
            return "sub-SELECT in FROM";
        case EXPR_KIND_FROM_FUNCTION:
            return "function in FROM";
        case EXPR_KIND_WHERE:
            return "WHERE";
        case EXPR_KIND_HAVING:
            return "HAVING";
        case EXPR_KIND_WINDOW_PARTITION:
            return "window PARTITION BY";
        case EXPR_KIND_WINDOW_ORDER:
            return "window ORDER BY";
        case EXPR_KIND_WINDOW_FRAME_RANGE:
            return "window RANGE";
        case EXPR_KIND_WINDOW_FRAME_ROWS:
            return "window ROWS";
        case EXPR_KIND_SELECT_TARGET:
            return "SELECT";
        case EXPR_KIND_INSERT_TARGET:
            return "INSERT";
        case EXPR_KIND_UPDATE_SOURCE:
        case EXPR_KIND_UPDATE_TARGET:
            return "UPDATE";
        case EXPR_KIND_GROUP_BY:
            return "GROUP BY";
        case EXPR_KIND_ORDER_BY:
            return "ORDER BY";
        case EXPR_KIND_DISTINCT_ON:
            return "DISTINCT ON";
        case EXPR_KIND_LIMIT:
            return "LIMIT";
        case EXPR_KIND_OFFSET:
            return "OFFSET";
        case EXPR_KIND_RETURNING:
            return "RETURNING";
        case EXPR_KIND_VALUES:
            return "VALUES";
        case EXPR_KIND_CHECK_CONSTRAINT:
        case EXPR_KIND_DOMAIN_CHECK:
            return "CHECK";
        case EXPR_KIND_COLUMN_DEFAULT:
        case EXPR_KIND_FUNCTION_DEFAULT:
            return "DEFAULT";
        case EXPR_KIND_INDEX_EXPRESSION:
            return "index expression";
        case EXPR_KIND_INDEX_PREDICATE:
            return "index predicate";
        case EXPR_KIND_ALTER_COL_TRANSFORM:
            return "USING";
        case EXPR_KIND_EXECUTE_PARAMETER:
            return "EXECUTE";
        case EXPR_KIND_TRIGGER_WHEN:
            return "WHEN";

            /*
             * There is intentionally no default: case here, so that the
             * compiler will warn if we add a new ParseExprKind without
             * extending this switch.  If we do see an unrecognized value at
             * runtime, we'll fall through to the "unrecognized" return.
             */
    }
    return "unrecognized expression kind";
}

static Node * transformAExprAnd ( ParseState pstate,
A_Expr a 
) [static]

Definition at line 921 of file parse_expr.c.

References AND_EXPR, coerce_to_boolean(), A_Expr::lexpr, list_make2, A_Expr::location, makeBoolExpr(), A_Expr::rexpr, and transformExprRecurse().

Referenced by transformExprRecurse().

{
    Node       *lexpr = transformExprRecurse(pstate, a->lexpr);
    Node       *rexpr = transformExprRecurse(pstate, a->rexpr);

    lexpr = coerce_to_boolean(pstate, lexpr, "AND");
    rexpr = coerce_to_boolean(pstate, rexpr, "AND");

    return (Node *) makeBoolExpr(AND_EXPR,
                                 list_make2(lexpr, rexpr),
                                 a->location);
}

static Node * transformAExprDistinct ( ParseState pstate,
A_Expr a 
) [static]

Definition at line 989 of file parse_expr.c.

References IsA, A_Expr::lexpr, A_Expr::location, make_distinct_op(), make_row_distinct_op(), A_Expr::name, A_Expr::rexpr, and transformExprRecurse().

Referenced by transformExprRecurse().

{
    Node       *lexpr = transformExprRecurse(pstate, a->lexpr);
    Node       *rexpr = transformExprRecurse(pstate, a->rexpr);

    if (lexpr && IsA(lexpr, RowExpr) &&
        rexpr && IsA(rexpr, RowExpr))
    {
        /* "row op row" */
        return make_row_distinct_op(pstate, a->name,
                                    (RowExpr *) lexpr,
                                    (RowExpr *) rexpr,
                                    a->location);
    }
    else
    {
        /* Ordinary scalar operator */
        return (Node *) make_distinct_op(pstate,
                                         a->name,
                                         lexpr,
                                         rexpr,
                                         a->location);
    }
}

static Node * transformAExprIn ( ParseState pstate,
A_Expr a 
) [static]

Definition at line 1088 of file parse_expr.c.

References AND_EXPR, ArrayExpr::array_typeid, coerce_to_boolean(), coerce_to_common_type(), contain_vars_of_level(), copyObject(), ArrayExpr::element_typeid, ArrayExpr::elements, ereport, errcode(), errmsg(), ERROR, get_array_type(), InvalidOid, IsA, lappend(), A_Expr::lexpr, lfirst, linitial, list_concat(), list_length(), list_make1, list_make2, A_Expr::location, ArrayExpr::location, make_op(), make_row_comparison_op(), make_scalar_array_op(), makeBoolExpr(), makeNode, ArrayExpr::multidims, A_Expr::name, NULL, OidIsValid, OR_EXPR, parser_errposition(), A_Expr::rexpr, select_common_type(), strVal, and transformExprRecurse().

Referenced by transformExprRecurse().

{
    Node       *result = NULL;
    Node       *lexpr;
    List       *rexprs;
    List       *rvars;
    List       *rnonvars;
    bool        useOr;
    bool        haveRowExpr;
    ListCell   *l;

    /*
     * If the operator is <>, combine with AND not OR.
     */
    if (strcmp(strVal(linitial(a->name)), "<>") == 0)
        useOr = false;
    else
        useOr = true;

    /*
     * We try to generate a ScalarArrayOpExpr from IN/NOT IN, but this is only
     * possible if the inputs are all scalars (no RowExprs) and there is a
     * suitable array type available.  If not, we fall back to a boolean
     * condition tree with multiple copies of the lefthand expression. Also,
     * any IN-list items that contain Vars are handled as separate boolean
     * conditions, because that gives the planner more scope for optimization
     * on such clauses.
     *
     * First step: transform all the inputs, and detect whether any are
     * RowExprs or contain Vars.
     */
    lexpr = transformExprRecurse(pstate, a->lexpr);
    haveRowExpr = (lexpr && IsA(lexpr, RowExpr));
    rexprs = rvars = rnonvars = NIL;
    foreach(l, (List *) a->rexpr)
    {
        Node       *rexpr = transformExprRecurse(pstate, lfirst(l));

        haveRowExpr |= (rexpr && IsA(rexpr, RowExpr));
        rexprs = lappend(rexprs, rexpr);
        if (contain_vars_of_level(rexpr, 0))
            rvars = lappend(rvars, rexpr);
        else
            rnonvars = lappend(rnonvars, rexpr);
    }

    /*
     * ScalarArrayOpExpr is only going to be useful if there's more than one
     * non-Var righthand item.  Also, it won't work for RowExprs.
     */
    if (!haveRowExpr && list_length(rnonvars) > 1)
    {
        List       *allexprs;
        Oid         scalar_type;
        Oid         array_type;

        /*
         * Try to select a common type for the array elements.  Note that
         * since the LHS' type is first in the list, it will be preferred when
         * there is doubt (eg, when all the RHS items are unknown literals).
         *
         * Note: use list_concat here not lcons, to avoid damaging rnonvars.
         */
        allexprs = list_concat(list_make1(lexpr), rnonvars);
        scalar_type = select_common_type(pstate, allexprs, NULL, NULL);

        /* Do we have an array type to use? */
        if (OidIsValid(scalar_type))
            array_type = get_array_type(scalar_type);
        else
            array_type = InvalidOid;
        if (array_type != InvalidOid)
        {
            /*
             * OK: coerce all the right-hand non-Var inputs to the common type
             * and build an ArrayExpr for them.
             */
            List       *aexprs;
            ArrayExpr  *newa;

            aexprs = NIL;
            foreach(l, rnonvars)
            {
                Node       *rexpr = (Node *) lfirst(l);

                rexpr = coerce_to_common_type(pstate, rexpr,
                                              scalar_type,
                                              "IN");
                aexprs = lappend(aexprs, rexpr);
            }
            newa = makeNode(ArrayExpr);
            newa->array_typeid = array_type;
            /* array_collid will be set by parse_collate.c */
            newa->element_typeid = scalar_type;
            newa->elements = aexprs;
            newa->multidims = false;
            newa->location = -1;

            result = (Node *) make_scalar_array_op(pstate,
                                                   a->name,
                                                   useOr,
                                                   lexpr,
                                                   (Node *) newa,
                                                   a->location);

            /* Consider only the Vars (if any) in the loop below */
            rexprs = rvars;
        }
    }

    /*
     * Must do it the hard way, ie, with a boolean expression tree.
     */
    foreach(l, rexprs)
    {
        Node       *rexpr = (Node *) lfirst(l);
        Node       *cmp;

        if (haveRowExpr)
        {
            if (!IsA(lexpr, RowExpr) ||
                !IsA(rexpr, RowExpr))
                ereport(ERROR,
                        (errcode(ERRCODE_SYNTAX_ERROR),
                   errmsg("arguments of row IN must all be row expressions"),
                         parser_errposition(pstate, a->location)));
            cmp = make_row_comparison_op(pstate,
                                         a->name,
                              (List *) copyObject(((RowExpr *) lexpr)->args),
                                         ((RowExpr *) rexpr)->args,
                                         a->location);
        }
        else
            cmp = (Node *) make_op(pstate,
                                   a->name,
                                   copyObject(lexpr),
                                   rexpr,
                                   a->location);

        cmp = coerce_to_boolean(pstate, cmp, "IN");
        if (result == NULL)
            result = cmp;
        else
            result = (Node *) makeBoolExpr(useOr ? OR_EXPR : AND_EXPR,
                                           list_make2(result, cmp),
                                           a->location);
    }

    return result;
}

static Node * transformAExprNot ( ParseState pstate,
A_Expr a 
) [static]

Definition at line 949 of file parse_expr.c.

References coerce_to_boolean(), list_make1, A_Expr::location, makeBoolExpr(), NOT_EXPR, A_Expr::rexpr, and transformExprRecurse().

Referenced by transformExprRecurse().

{
    Node       *rexpr = transformExprRecurse(pstate, a->rexpr);

    rexpr = coerce_to_boolean(pstate, rexpr, "NOT");

    return (Node *) makeBoolExpr(NOT_EXPR,
                                 list_make1(rexpr),
                                 a->location);
}

static Node * transformAExprNullIf ( ParseState pstate,
A_Expr a 
) [static]

Definition at line 1015 of file parse_expr.c.

References OpExpr::args, BOOLOID, ereport, errcode(), errmsg(), ERROR, exprType(), A_Expr::lexpr, linitial, A_Expr::location, make_op(), A_Expr::name, NodeSetTag, OpExpr::opresulttype, parser_errposition(), A_Expr::rexpr, T_NullIfExpr, and transformExprRecurse().

Referenced by transformExprRecurse().

{
    Node       *lexpr = transformExprRecurse(pstate, a->lexpr);
    Node       *rexpr = transformExprRecurse(pstate, a->rexpr);
    OpExpr     *result;

    result = (OpExpr *) make_op(pstate,
                                a->name,
                                lexpr,
                                rexpr,
                                a->location);

    /*
     * The comparison operator itself should yield boolean ...
     */
    if (result->opresulttype != BOOLOID)
        ereport(ERROR,
                (errcode(ERRCODE_DATATYPE_MISMATCH),
                 errmsg("NULLIF requires = operator to yield boolean"),
                 parser_errposition(pstate, a->location)));

    /*
     * ... but the NullIfExpr will yield the first operand's type.
     */
    result->opresulttype = exprType((Node *) linitial(result->args));

    /*
     * We rely on NullIfExpr and OpExpr being the same struct
     */
    NodeSetTag(result, T_NullIfExpr);

    return (Node *) result;
}

static Node * transformAExprOf ( ParseState pstate,
A_Expr a 
) [static]

Definition at line 1050 of file parse_expr.c.

References exprLocation(), exprType(), A_Expr::lexpr, lfirst, linitial, Const::location, makeBoolConst(), A_Expr::name, A_Expr::rexpr, strVal, transformExprRecurse(), and typenameTypeId().

Referenced by transformExprRecurse().

{
    /*
     * Checking an expression for match to a list of type names. Will result
     * in a boolean constant node.
     */
    Node       *lexpr = transformExprRecurse(pstate, a->lexpr);
    Const      *result;
    ListCell   *telem;
    Oid         ltype,
                rtype;
    bool        matched = false;

    ltype = exprType(lexpr);
    foreach(telem, (List *) a->rexpr)
    {
        rtype = typenameTypeId(pstate, lfirst(telem));
        matched = (rtype == ltype);
        if (matched)
            break;
    }

    /*
     * We have two forms: equals or not equals. Flip the sense of the result
     * for not equals.
     */
    if (strcmp(strVal(linitial(a->name)), "<>") == 0)
        matched = (!matched);

    result = (Const *) makeBoolConst(matched, false);

    /* Make the result have the original input's parse location */
    result->location = exprLocation((Node *) a);

    return (Node *) result;
}

static Node * transformAExprOp ( ParseState pstate,
A_Expr a 
) [static]

Definition at line 842 of file parse_expr.c.

References NullTest::arg, Assert, EXPR_SUBLINK, exprIsNullConstant(), IsA, A_Expr::lexpr, linitial, list_length(), A_Expr::location, SubLink::location, make_op(), make_row_comparison_op(), makeNode, A_Expr::name, NullTest::nulltesttype, SubLink::operName, A_Expr::rexpr, strVal, SubLink::subLinkType, SubLink::testexpr, Transform_null_equals, and transformExprRecurse().

Referenced by transformExprRecurse().

{
    Node       *lexpr = a->lexpr;
    Node       *rexpr = a->rexpr;
    Node       *result;

    /*
     * Special-case "foo = NULL" and "NULL = foo" for compatibility with
     * standards-broken products (like Microsoft's).  Turn these into IS NULL
     * exprs. (If either side is a CaseTestExpr, then the expression was
     * generated internally from a CASE-WHEN expression, and
     * transform_null_equals does not apply.)
     */
    if (Transform_null_equals &&
        list_length(a->name) == 1 &&
        strcmp(strVal(linitial(a->name)), "=") == 0 &&
        (exprIsNullConstant(lexpr) || exprIsNullConstant(rexpr)) &&
        (!IsA(lexpr, CaseTestExpr) &&!IsA(rexpr, CaseTestExpr)))
    {
        NullTest   *n = makeNode(NullTest);

        n->nulltesttype = IS_NULL;

        if (exprIsNullConstant(lexpr))
            n->arg = (Expr *) rexpr;
        else
            n->arg = (Expr *) lexpr;

        result = transformExprRecurse(pstate, (Node *) n);
    }
    else if (lexpr && IsA(lexpr, RowExpr) &&
             rexpr && IsA(rexpr, SubLink) &&
             ((SubLink *) rexpr)->subLinkType == EXPR_SUBLINK)
    {
        /*
         * Convert "row op subselect" into a ROWCOMPARE sublink. Formerly the
         * grammar did this, but now that a row construct is allowed anywhere
         * in expressions, it's easier to do it here.
         */
        SubLink    *s = (SubLink *) rexpr;

        s->subLinkType = ROWCOMPARE_SUBLINK;
        s->testexpr = lexpr;
        s->operName = a->name;
        s->location = a->location;
        result = transformExprRecurse(pstate, (Node *) s);
    }
    else if (lexpr && IsA(lexpr, RowExpr) &&
             rexpr && IsA(rexpr, RowExpr))
    {
        /* "row op row" */
        lexpr = transformExprRecurse(pstate, lexpr);
        rexpr = transformExprRecurse(pstate, rexpr);
        Assert(IsA(lexpr, RowExpr));
        Assert(IsA(rexpr, RowExpr));

        result = make_row_comparison_op(pstate,
                                        a->name,
                                        ((RowExpr *) lexpr)->args,
                                        ((RowExpr *) rexpr)->args,
                                        a->location);
    }
    else
    {
        /* Ordinary scalar operator */
        lexpr = transformExprRecurse(pstate, lexpr);
        rexpr = transformExprRecurse(pstate, rexpr);

        result = (Node *) make_op(pstate,
                                  a->name,
                                  lexpr,
                                  rexpr,
                                  a->location);
    }

    return result;
}

static Node * transformAExprOpAll ( ParseState pstate,
A_Expr a 
) [static]

Definition at line 975 of file parse_expr.c.

References A_Expr::lexpr, A_Expr::location, make_scalar_array_op(), A_Expr::name, A_Expr::rexpr, and transformExprRecurse().

Referenced by transformExprRecurse().

{
    Node       *lexpr = transformExprRecurse(pstate, a->lexpr);
    Node       *rexpr = transformExprRecurse(pstate, a->rexpr);

    return (Node *) make_scalar_array_op(pstate,
                                         a->name,
                                         false,
                                         lexpr,
                                         rexpr,
                                         a->location);
}

static Node * transformAExprOpAny ( ParseState pstate,
A_Expr a 
) [static]

Definition at line 961 of file parse_expr.c.

References A_Expr::lexpr, A_Expr::location, make_scalar_array_op(), A_Expr::name, A_Expr::rexpr, and transformExprRecurse().

Referenced by transformExprRecurse().

{
    Node       *lexpr = transformExprRecurse(pstate, a->lexpr);
    Node       *rexpr = transformExprRecurse(pstate, a->rexpr);

    return (Node *) make_scalar_array_op(pstate,
                                         a->name,
                                         true,
                                         lexpr,
                                         rexpr,
                                         a->location);
}

static Node * transformAExprOr ( ParseState pstate,
A_Expr a 
) [static]

Definition at line 935 of file parse_expr.c.

References coerce_to_boolean(), A_Expr::lexpr, list_make2, A_Expr::location, makeBoolExpr(), OR_EXPR, A_Expr::rexpr, and transformExprRecurse().

Referenced by transformExprRecurse().

{
    Node       *lexpr = transformExprRecurse(pstate, a->lexpr);
    Node       *rexpr = transformExprRecurse(pstate, a->rexpr);

    lexpr = coerce_to_boolean(pstate, lexpr, "OR");
    rexpr = coerce_to_boolean(pstate, rexpr, "OR");

    return (Node *) makeBoolExpr(OR_EXPR,
                                 list_make2(lexpr, rexpr),
                                 a->location);
}

static Node * transformArrayExpr ( ParseState pstate,
A_ArrayExpr a,
Oid  array_type,
Oid  element_type,
int32  typmod 
) [static]

Definition at line 1625 of file parse_expr.c.

References ArrayExpr::array_typeid, Assert, COERCE_EXPLICIT_CAST, coerce_to_common_type(), coerce_to_target_type(), COERCION_EXPLICIT, ArrayExpr::element_typeid, ArrayExpr::elements, A_ArrayExpr::elements, ereport, errcode(), errhint(), errmsg(), ERROR, exprLocation(), exprType(), format_type_be(), get_array_type(), get_element_type(), InvalidOid, IsA, lappend(), lfirst, ArrayExpr::location, A_ArrayExpr::location, makeNode, ArrayExpr::multidims, NIL, NULL, OidIsValid, parser_errposition(), select_common_type(), transformExprRecurse(), and type_is_array.

Referenced by transformExprRecurse().

{
    ArrayExpr  *newa = makeNode(ArrayExpr);
    List       *newelems = NIL;
    List       *newcoercedelems = NIL;
    ListCell   *element;
    Oid         coerce_type;
    bool        coerce_hard;

    /*
     * Transform the element expressions
     *
     * Assume that the array is one-dimensional unless we find an array-type
     * element expression.
     */
    newa->multidims = false;
    foreach(element, a->elements)
    {
        Node       *e = (Node *) lfirst(element);
        Node       *newe;

        /*
         * If an element is itself an A_ArrayExpr, recurse directly so that we
         * can pass down any target type we were given.
         */
        if (IsA(e, A_ArrayExpr))
        {
            newe = transformArrayExpr(pstate,
                                      (A_ArrayExpr *) e,
                                      array_type,
                                      element_type,
                                      typmod);
            /* we certainly have an array here */
            Assert(array_type == InvalidOid || array_type == exprType(newe));
            newa->multidims = true;
        }
        else
        {
            newe = transformExprRecurse(pstate, e);

            /*
             * Check for sub-array expressions, if we haven't already found
             * one.
             */
            if (!newa->multidims && type_is_array(exprType(newe)))
                newa->multidims = true;
        }

        newelems = lappend(newelems, newe);
    }

    /*
     * Select a target type for the elements.
     *
     * If we haven't been given a target array type, we must try to deduce a
     * common type based on the types of the individual elements present.
     */
    if (OidIsValid(array_type))
    {
        /* Caller must ensure array_type matches element_type */
        Assert(OidIsValid(element_type));
        coerce_type = (newa->multidims ? array_type : element_type);
        coerce_hard = true;
    }
    else
    {
        /* Can't handle an empty array without a target type */
        if (newelems == NIL)
            ereport(ERROR,
                    (errcode(ERRCODE_INDETERMINATE_DATATYPE),
                     errmsg("cannot determine type of empty array"),
                     errhint("Explicitly cast to the desired type, "
                             "for example ARRAY[]::integer[]."),
                     parser_errposition(pstate, a->location)));

        /* Select a common type for the elements */
        coerce_type = select_common_type(pstate, newelems, "ARRAY", NULL);

        if (newa->multidims)
        {
            array_type = coerce_type;
            element_type = get_element_type(array_type);
            if (!OidIsValid(element_type))
                ereport(ERROR,
                        (errcode(ERRCODE_UNDEFINED_OBJECT),
                       errmsg("could not find element type for data type %s",
                              format_type_be(array_type)),
                         parser_errposition(pstate, a->location)));
        }
        else
        {
            element_type = coerce_type;
            array_type = get_array_type(element_type);
            if (!OidIsValid(array_type))
                ereport(ERROR,
                        (errcode(ERRCODE_UNDEFINED_OBJECT),
                         errmsg("could not find array type for data type %s",
                                format_type_be(element_type)),
                         parser_errposition(pstate, a->location)));
        }
        coerce_hard = false;
    }

    /*
     * Coerce elements to target type
     *
     * If the array has been explicitly cast, then the elements are in turn
     * explicitly coerced.
     *
     * If the array's type was merely derived from the common type of its
     * elements, then the elements are implicitly coerced to the common type.
     * This is consistent with other uses of select_common_type().
     */
    foreach(element, newelems)
    {
        Node       *e = (Node *) lfirst(element);
        Node       *newe;

        if (coerce_hard)
        {
            newe = coerce_to_target_type(pstate, e,
                                         exprType(e),
                                         coerce_type,
                                         typmod,
                                         COERCION_EXPLICIT,
                                         COERCE_EXPLICIT_CAST,
                                         -1);
            if (newe == NULL)
                ereport(ERROR,
                        (errcode(ERRCODE_CANNOT_COERCE),
                         errmsg("cannot cast type %s to %s",
                                format_type_be(exprType(e)),
                                format_type_be(coerce_type)),
                         parser_errposition(pstate, exprLocation(e))));
        }
        else
            newe = coerce_to_common_type(pstate, e,
                                         coerce_type,
                                         "ARRAY");
        newcoercedelems = lappend(newcoercedelems, newe);
    }

    newa->array_typeid = array_type;
    /* array_collid will be set by parse_collate.c */
    newa->element_typeid = element_type;
    newa->elements = newcoercedelems;
    newa->location = a->location;

    return (Node *) newa;
}

static Node * transformBooleanTest ( ParseState pstate,
BooleanTest b 
) [static]

Definition at line 2067 of file parse_expr.c.

References BooleanTest::arg, BooleanTest::booltesttype, coerce_to_boolean(), elog, ERROR, IS_FALSE, IS_NOT_FALSE, IS_NOT_TRUE, IS_NOT_UNKNOWN, IS_TRUE, IS_UNKNOWN, and transformExprRecurse().

Referenced by transformExprRecurse().

{
    const char *clausename;

    switch (b->booltesttype)
    {
        case IS_TRUE:
            clausename = "IS TRUE";
            break;
        case IS_NOT_TRUE:
            clausename = "IS NOT TRUE";
            break;
        case IS_FALSE:
            clausename = "IS FALSE";
            break;
        case IS_NOT_FALSE:
            clausename = "IS NOT FALSE";
            break;
        case IS_UNKNOWN:
            clausename = "IS UNKNOWN";
            break;
        case IS_NOT_UNKNOWN:
            clausename = "IS NOT UNKNOWN";
            break;
        default:
            elog(ERROR, "unrecognized booltesttype: %d",
                 (int) b->booltesttype);
            clausename = NULL;  /* keep compiler quiet */
    }

    b->arg = (Expr *) transformExprRecurse(pstate, (Node *) b->arg);

    b->arg = (Expr *) coerce_to_boolean(pstate,
                                        (Node *) b->arg,
                                        clausename);

    return (Node *) b;
}

static Node * transformCaseExpr ( ParseState pstate,
CaseExpr c 
) [static]

Definition at line 1267 of file parse_expr.c.

References AEXPR_OP, CaseExpr::arg, arg, CaseExpr::args, Assert, assign_expr_collations(), CaseExpr::casetype, coerce_to_boolean(), coerce_to_common_type(), CaseTestExpr::collation, CaseExpr::defresult, CaseWhen::expr, exprCollation(), exprType(), exprTypmod(), IsA, lappend(), lcons(), lfirst, CaseExpr::location, A_Const::location, CaseWhen::location, makeNode, makeSimpleA_Expr(), NULL, OidIsValid, CaseWhen::result, select_common_type(), TEXTOID, transformExprRecurse(), Value::type, CaseTestExpr::typeId, CaseTestExpr::typeMod, UNKNOWNOID, and A_Const::val.

Referenced by transformExprRecurse().

{
    CaseExpr   *newc;
    Node       *arg;
    CaseTestExpr *placeholder;
    List       *newargs;
    List       *resultexprs;
    ListCell   *l;
    Node       *defresult;
    Oid         ptype;

    /* If we already transformed this node, do nothing */
    if (OidIsValid(c->casetype))
        return (Node *) c;

    newc = makeNode(CaseExpr);

    /* transform the test expression, if any */
    arg = transformExprRecurse(pstate, (Node *) c->arg);

    /* generate placeholder for test expression */
    if (arg)
    {
        /*
         * If test expression is an untyped literal, force it to text. We have
         * to do something now because we won't be able to do this coercion on
         * the placeholder.  This is not as flexible as what was done in 7.4
         * and before, but it's good enough to handle the sort of silly coding
         * commonly seen.
         */
        if (exprType(arg) == UNKNOWNOID)
            arg = coerce_to_common_type(pstate, arg, TEXTOID, "CASE");

        /*
         * Run collation assignment on the test expression so that we know
         * what collation to mark the placeholder with.  In principle we could
         * leave it to parse_collate.c to do that later, but propagating the
         * result to the CaseTestExpr would be unnecessarily complicated.
         */
        assign_expr_collations(pstate, arg);

        placeholder = makeNode(CaseTestExpr);
        placeholder->typeId = exprType(arg);
        placeholder->typeMod = exprTypmod(arg);
        placeholder->collation = exprCollation(arg);
    }
    else
        placeholder = NULL;

    newc->arg = (Expr *) arg;

    /* transform the list of arguments */
    newargs = NIL;
    resultexprs = NIL;
    foreach(l, c->args)
    {
        CaseWhen   *w = (CaseWhen *) lfirst(l);
        CaseWhen   *neww = makeNode(CaseWhen);
        Node       *warg;

        Assert(IsA(w, CaseWhen));

        warg = (Node *) w->expr;
        if (placeholder)
        {
            /* shorthand form was specified, so expand... */
            warg = (Node *) makeSimpleA_Expr(AEXPR_OP, "=",
                                             (Node *) placeholder,
                                             warg,
                                             w->location);
        }
        neww->expr = (Expr *) transformExprRecurse(pstate, warg);

        neww->expr = (Expr *) coerce_to_boolean(pstate,
                                                (Node *) neww->expr,
                                                "CASE/WHEN");

        warg = (Node *) w->result;
        neww->result = (Expr *) transformExprRecurse(pstate, warg);
        neww->location = w->location;

        newargs = lappend(newargs, neww);
        resultexprs = lappend(resultexprs, neww->result);
    }

    newc->args = newargs;

    /* transform the default clause */
    defresult = (Node *) c->defresult;
    if (defresult == NULL)
    {
        A_Const    *n = makeNode(A_Const);

        n->val.type = T_Null;
        n->location = -1;
        defresult = (Node *) n;
    }
    newc->defresult = (Expr *) transformExprRecurse(pstate, defresult);

    /*
     * Note: default result is considered the most significant type in
     * determining preferred type. This is how the code worked before, but it
     * seems a little bogus to me --- tgl
     */
    resultexprs = lcons(newc->defresult, resultexprs);

    ptype = select_common_type(pstate, resultexprs, "CASE", NULL);
    Assert(OidIsValid(ptype));
    newc->casetype = ptype;
    /* casecollid will be set by parse_collate.c */

    /* Convert default result clause, if necessary */
    newc->defresult = (Expr *)
        coerce_to_common_type(pstate,
                              (Node *) newc->defresult,
                              ptype,
                              "CASE/ELSE");

    /* Convert when-clause results, if necessary */
    foreach(l, newc->args)
    {
        CaseWhen   *w = (CaseWhen *) lfirst(l);

        w->result = (Expr *)
            coerce_to_common_type(pstate,
                                  (Node *) w->result,
                                  ptype,
                                  "CASE/WHEN");
    }

    newc->location = c->location;

    return (Node *) newc;
}

static Node * transformCoalesceExpr ( ParseState pstate,
CoalesceExpr c 
) [static]

Definition at line 1813 of file parse_expr.c.

References CoalesceExpr::args, CoalesceExpr::coalescetype, coerce_to_common_type(), lappend(), lfirst, CoalesceExpr::location, makeNode, NULL, select_common_type(), and transformExprRecurse().

Referenced by transformExprRecurse().

{
    CoalesceExpr *newc = makeNode(CoalesceExpr);
    List       *newargs = NIL;
    List       *newcoercedargs = NIL;
    ListCell   *args;

    foreach(args, c->args)
    {
        Node       *e = (Node *) lfirst(args);
        Node       *newe;

        newe = transformExprRecurse(pstate, e);
        newargs = lappend(newargs, newe);
    }

    newc->coalescetype = select_common_type(pstate, newargs, "COALESCE", NULL);
    /* coalescecollid will be set by parse_collate.c */

    /* Convert arguments if necessary */
    foreach(args, newargs)
    {
        Node       *e = (Node *) lfirst(args);
        Node       *newe;

        newe = coerce_to_common_type(pstate, e,
                                     newc->coalescetype,
                                     "COALESCE");
        newcoercedargs = lappend(newcoercedargs, newe);
    }

    newc->args = newcoercedargs;
    newc->location = c->location;
    return (Node *) newc;
}

static Node * transformCollateClause ( ParseState pstate,
CollateClause c 
) [static]

Definition at line 2244 of file parse_expr.c.

References CollateClause::arg, CollateExpr::arg, CollateClause::collname, CollateExpr::collOid, ereport, errcode(), errmsg(), ERROR, exprType(), format_type_be(), CollateExpr::location, CollateClause::location, LookupCollation(), makeNode, parser_errposition(), transformExprRecurse(), type_is_collatable(), and UNKNOWNOID.

Referenced by transformExprRecurse().

{
    CollateExpr *newc;
    Oid         argtype;

    newc = makeNode(CollateExpr);
    newc->arg = (Expr *) transformExprRecurse(pstate, c->arg);

    argtype = exprType((Node *) newc->arg);

    /*
     * The unknown type is not collatable, but coerce_type() takes care of it
     * separately, so we'll let it go here.
     */
    if (!type_is_collatable(argtype) && argtype != UNKNOWNOID)
        ereport(ERROR,
                (errcode(ERRCODE_DATATYPE_MISMATCH),
                 errmsg("collations are not supported by type %s",
                        format_type_be(argtype)),
                 parser_errposition(pstate, c->location)));

    newc->collOid = LookupCollation(pstate, c->collname, c->location);
    newc->location = c->location;

    return (Node *) newc;
}

static Node * transformColumnRef ( ParseState pstate,
ColumnRef cref 
) [static]

Definition at line 491 of file parse_expr.c.

References Assert, colNameToVar(), copyObject(), ereport, errcode(), errmsg(), ERROR, errorMissingColumn(), errorMissingRTE(), ColumnRef::fields, get_database_name(), IsA, lfourth, linitial, list_length(), list_make1, ColumnRef::location, lsecond, lthird, makeRangeVar(), makeString(), MyDatabaseId, NameListToString(), NIL, NULL, ParseState::p_post_columnref_hook, ParseState::p_pre_columnref_hook, ParseState::p_value_substitute, ParseFuncOrColumn(), parser_errposition(), refnameRangeTblEntry(), scanRTEForColumn(), strVal, and transformWholeRowRef().

Referenced by transformExprRecurse().

{
    Node       *node = NULL;
    char       *nspname = NULL;
    char       *relname = NULL;
    char       *colname = NULL;
    RangeTblEntry *rte;
    int         levels_up;
    enum
    {
        CRERR_NO_COLUMN,
        CRERR_NO_RTE,
        CRERR_WRONG_DB,
        CRERR_TOO_MANY
    }           crerr = CRERR_NO_COLUMN;

    /*
     * Give the PreParseColumnRefHook, if any, first shot.  If it returns
     * non-null then that's all, folks.
     */
    if (pstate->p_pre_columnref_hook != NULL)
    {
        node = (*pstate->p_pre_columnref_hook) (pstate, cref);
        if (node != NULL)
            return node;
    }

    /*----------
     * The allowed syntaxes are:
     *
     * A        First try to resolve as unqualified column name;
     *          if no luck, try to resolve as unqualified table name (A.*).
     * A.B      A is an unqualified table name; B is either a
     *          column or function name (trying column name first).
     * A.B.C    schema A, table B, col or func name C.
     * A.B.C.D  catalog A, schema B, table C, col or func D.
     * A.*      A is an unqualified table name; means whole-row value.
     * A.B.*    whole-row value of table B in schema A.
     * A.B.C.*  whole-row value of table C in schema B in catalog A.
     *
     * We do not need to cope with bare "*"; that will only be accepted by
     * the grammar at the top level of a SELECT list, and transformTargetList
     * will take care of it before it ever gets here.  Also, "A.*" etc will
     * be expanded by transformTargetList if they appear at SELECT top level,
     * so here we are only going to see them as function or operator inputs.
     *
     * Currently, if a catalog name is given then it must equal the current
     * database name; we check it here and then discard it.
     *----------
     */
    switch (list_length(cref->fields))
    {
        case 1:
            {
                Node       *field1 = (Node *) linitial(cref->fields);

                Assert(IsA(field1, String));
                colname = strVal(field1);

                /* Try to identify as an unqualified column */
                node = colNameToVar(pstate, colname, false, cref->location);

                if (node == NULL)
                {
                    /*
                     * Not known as a column of any range-table entry.
                     *
                     * Consider the possibility that it's VALUE in a domain
                     * check expression.  (We handle VALUE as a name, not a
                     * keyword, to avoid breaking a lot of applications that
                     * have used VALUE as a column name in the past.)
                     */
                    if (pstate->p_value_substitute != NULL &&
                        strcmp(colname, "value") == 0)
                    {
                        node = (Node *) copyObject(pstate->p_value_substitute);

                        /*
                         * Try to propagate location knowledge.  This should
                         * be extended if p_value_substitute can ever take on
                         * other node types.
                         */
                        if (IsA(node, CoerceToDomainValue))
                            ((CoerceToDomainValue *) node)->location = cref->location;
                        break;
                    }

                    /*
                     * Try to find the name as a relation.  Note that only
                     * relations already entered into the rangetable will be
                     * recognized.
                     *
                     * This is a hack for backwards compatibility with
                     * PostQUEL-inspired syntax.  The preferred form now is
                     * "rel.*".
                     */
                    rte = refnameRangeTblEntry(pstate, NULL, colname,
                                               cref->location,
                                               &levels_up);
                    if (rte)
                        node = transformWholeRowRef(pstate, rte,
                                                    cref->location);
                }
                break;
            }
        case 2:
            {
                Node       *field1 = (Node *) linitial(cref->fields);
                Node       *field2 = (Node *) lsecond(cref->fields);

                Assert(IsA(field1, String));
                relname = strVal(field1);

                /* Locate the referenced RTE */
                rte = refnameRangeTblEntry(pstate, nspname, relname,
                                           cref->location,
                                           &levels_up);
                if (rte == NULL)
                {
                    crerr = CRERR_NO_RTE;
                    break;
                }

                /* Whole-row reference? */
                if (IsA(field2, A_Star))
                {
                    node = transformWholeRowRef(pstate, rte, cref->location);
                    break;
                }

                Assert(IsA(field2, String));
                colname = strVal(field2);

                /* Try to identify as a column of the RTE */
                node = scanRTEForColumn(pstate, rte, colname, cref->location);
                if (node == NULL)
                {
                    /* Try it as a function call on the whole row */
                    node = transformWholeRowRef(pstate, rte, cref->location);
                    node = ParseFuncOrColumn(pstate,
                                             list_make1(makeString(colname)),
                                             list_make1(node),
                                             NIL, false, false, false,
                                             NULL, true, cref->location);
                }
                break;
            }
        case 3:
            {
                Node       *field1 = (Node *) linitial(cref->fields);
                Node       *field2 = (Node *) lsecond(cref->fields);
                Node       *field3 = (Node *) lthird(cref->fields);

                Assert(IsA(field1, String));
                nspname = strVal(field1);
                Assert(IsA(field2, String));
                relname = strVal(field2);

                /* Locate the referenced RTE */
                rte = refnameRangeTblEntry(pstate, nspname, relname,
                                           cref->location,
                                           &levels_up);
                if (rte == NULL)
                {
                    crerr = CRERR_NO_RTE;
                    break;
                }

                /* Whole-row reference? */
                if (IsA(field3, A_Star))
                {
                    node = transformWholeRowRef(pstate, rte, cref->location);
                    break;
                }

                Assert(IsA(field3, String));
                colname = strVal(field3);

                /* Try to identify as a column of the RTE */
                node = scanRTEForColumn(pstate, rte, colname, cref->location);
                if (node == NULL)
                {
                    /* Try it as a function call on the whole row */
                    node = transformWholeRowRef(pstate, rte, cref->location);
                    node = ParseFuncOrColumn(pstate,
                                             list_make1(makeString(colname)),
                                             list_make1(node),
                                             NIL, false, false, false,
                                             NULL, true, cref->location);
                }
                break;
            }
        case 4:
            {
                Node       *field1 = (Node *) linitial(cref->fields);
                Node       *field2 = (Node *) lsecond(cref->fields);
                Node       *field3 = (Node *) lthird(cref->fields);
                Node       *field4 = (Node *) lfourth(cref->fields);
                char       *catname;

                Assert(IsA(field1, String));
                catname = strVal(field1);
                Assert(IsA(field2, String));
                nspname = strVal(field2);
                Assert(IsA(field3, String));
                relname = strVal(field3);

                /*
                 * We check the catalog name and then ignore it.
                 */
                if (strcmp(catname, get_database_name(MyDatabaseId)) != 0)
                {
                    crerr = CRERR_WRONG_DB;
                    break;
                }

                /* Locate the referenced RTE */
                rte = refnameRangeTblEntry(pstate, nspname, relname,
                                           cref->location,
                                           &levels_up);
                if (rte == NULL)
                {
                    crerr = CRERR_NO_RTE;
                    break;
                }

                /* Whole-row reference? */
                if (IsA(field4, A_Star))
                {
                    node = transformWholeRowRef(pstate, rte, cref->location);
                    break;
                }

                Assert(IsA(field4, String));
                colname = strVal(field4);

                /* Try to identify as a column of the RTE */
                node = scanRTEForColumn(pstate, rte, colname, cref->location);
                if (node == NULL)
                {
                    /* Try it as a function call on the whole row */
                    node = transformWholeRowRef(pstate, rte, cref->location);
                    node = ParseFuncOrColumn(pstate,
                                             list_make1(makeString(colname)),
                                             list_make1(node),
                                             NIL, false, false, false,
                                             NULL, true, cref->location);
                }
                break;
            }
        default:
            crerr = CRERR_TOO_MANY;     /* too many dotted names */
            break;
    }

    /*
     * Now give the PostParseColumnRefHook, if any, a chance.  We pass the
     * translation-so-far so that it can throw an error if it wishes in the
     * case that it has a conflicting interpretation of the ColumnRef. (If it
     * just translates anyway, we'll throw an error, because we can't undo
     * whatever effects the preceding steps may have had on the pstate.) If it
     * returns NULL, use the standard translation, or throw a suitable error
     * if there is none.
     */
    if (pstate->p_post_columnref_hook != NULL)
    {
        Node       *hookresult;

        hookresult = (*pstate->p_post_columnref_hook) (pstate, cref, node);
        if (node == NULL)
            node = hookresult;
        else if (hookresult != NULL)
            ereport(ERROR,
                    (errcode(ERRCODE_AMBIGUOUS_COLUMN),
                     errmsg("column reference \"%s\" is ambiguous",
                            NameListToString(cref->fields)),
                     parser_errposition(pstate, cref->location)));
    }

    /*
     * Throw error if no translation found.
     */
    if (node == NULL)
    {
        switch (crerr)
        {
            case CRERR_NO_COLUMN:
                errorMissingColumn(pstate, relname, colname, cref->location);
                break;
            case CRERR_NO_RTE:
                errorMissingRTE(pstate, makeRangeVar(nspname, relname,
                                                     cref->location));
                break;
            case CRERR_WRONG_DB:
                ereport(ERROR,
                        (errcode(ERRCODE_FEATURE_NOT_SUPPORTED),
                  errmsg("cross-database references are not implemented: %s",
                         NameListToString(cref->fields)),
                         parser_errposition(pstate, cref->location)));
                break;
            case CRERR_TOO_MANY:
                ereport(ERROR,
                        (errcode(ERRCODE_SYNTAX_ERROR),
                errmsg("improper qualified name (too many dotted names): %s",
                       NameListToString(cref->fields)),
                         parser_errposition(pstate, cref->location)));
                break;
        }
    }

    return node;
}

static Node * transformCurrentOfExpr ( ParseState pstate,
CurrentOfExpr cexpr 
) [static]

Definition at line 2107 of file parse_expr.c.

References Assert, CurrentOfExpr::cursor_name, CurrentOfExpr::cursor_param, CurrentOfExpr::cvarno, ColumnRef::fields, IsA, list_make1, ColumnRef::location, makeNode, makeString(), NULL, ParseState::p_post_columnref_hook, ParseState::p_pre_columnref_hook, ParseState::p_target_rangetblentry, PARAM_EXTERN, Param::paramid, Param::paramkind, Param::paramtype, REFCURSOROID, and RTERangeTablePosn().

Referenced by transformExprRecurse().

{
    int         sublevels_up;

    /* CURRENT OF can only appear at top level of UPDATE/DELETE */
    Assert(pstate->p_target_rangetblentry != NULL);
    cexpr->cvarno = RTERangeTablePosn(pstate,
                                      pstate->p_target_rangetblentry,
                                      &sublevels_up);
    Assert(sublevels_up == 0);

    /*
     * Check to see if the cursor name matches a parameter of type REFCURSOR.
     * If so, replace the raw name reference with a parameter reference. (This
     * is a hack for the convenience of plpgsql.)
     */
    if (cexpr->cursor_name != NULL)     /* in case already transformed */
    {
        ColumnRef  *cref = makeNode(ColumnRef);
        Node       *node = NULL;

        /* Build an unqualified ColumnRef with the given name */
        cref->fields = list_make1(makeString(cexpr->cursor_name));
        cref->location = -1;

        /* See if there is a translation available from a parser hook */
        if (pstate->p_pre_columnref_hook != NULL)
            node = (*pstate->p_pre_columnref_hook) (pstate, cref);
        if (node == NULL && pstate->p_post_columnref_hook != NULL)
            node = (*pstate->p_post_columnref_hook) (pstate, cref, NULL);

        /*
         * XXX Should we throw an error if we get a translation that isn't a
         * refcursor Param?  For now it seems best to silently ignore false
         * matches.
         */
        if (node != NULL && IsA(node, Param))
        {
            Param      *p = (Param *) node;

            if (p->paramkind == PARAM_EXTERN &&
                p->paramtype == REFCURSOROID)
            {
                /* Matches, so convert CURRENT OF to a param reference */
                cexpr->cursor_name = NULL;
                cexpr->cursor_param = p->paramid;
            }
        }
    }

    return (Node *) cexpr;
}

Node* transformExpr ( ParseState pstate,
Node expr,
ParseExprKind  exprKind 
)
static Node * transformExprRecurse ( ParseState pstate,
Node expr 
) [static]

Definition at line 124 of file parse_expr.c.

References AEXPR_AND, AEXPR_DISTINCT, AEXPR_IN, AEXPR_NOT, AEXPR_NULLIF, AEXPR_OF, AEXPR_OP, AEXPR_OP_ALL, AEXPR_OP_ANY, AEXPR_OR, NullTest::arg, NamedArgExpr::arg, TypeCast::arg, A_Indirection::arg, NullTest::argisrow, check_stack_depth(), copyObject(), elog, ERROR, exprType(), get_element_type(), getBaseTypeAndTypmod(), A_Indirection::indirection, InvalidOid, IsA, A_Expr::kind, A_Const::location, make_const(), nodeTag, NULL, OidIsValid, T_A_ArrayExpr, T_A_Const, T_A_Expr, T_A_Indirection, T_Aggref, T_ArrayCoerceExpr, T_ArrayExpr, T_ArrayRef, T_BooleanTest, T_BoolExpr, T_CaseExpr, T_CaseTestExpr, T_CoalesceExpr, T_CoerceToDomain, T_CoerceToDomainValue, T_CoerceViaIO, T_CollateClause, T_CollateExpr, T_ColumnRef, T_Const, T_ConvertRowtypeExpr, T_CurrentOfExpr, T_DistinctExpr, T_FieldSelect, T_FieldStore, T_FuncCall, T_FuncExpr, T_MinMaxExpr, T_NamedArgExpr, T_NullIfExpr, T_NullTest, T_OpExpr, T_Param, T_ParamRef, T_RelabelType, T_RowExpr, T_ScalarArrayOpExpr, T_SetToDefault, T_SubLink, T_TypeCast, T_Var, T_WindowFunc, T_XmlExpr, T_XmlSerialize, transformAExprAnd(), transformAExprDistinct(), transformAExprIn(), transformAExprNot(), transformAExprNullIf(), transformAExprOf(), transformAExprOp(), transformAExprOpAll(), transformAExprOpAny(), transformAExprOr(), transformArrayExpr(), transformBooleanTest(), transformCaseExpr(), transformCoalesceExpr(), transformCollateClause(), transformColumnRef(), transformCurrentOfExpr(), transformFuncCall(), transformIndirection(), transformMinMaxExpr(), transformParamRef(), transformRowExpr(), transformSubLink(), transformTypeCast(), transformXmlExpr(), transformXmlSerialize(), type_is_rowtype(), TypeCast::typeName, typenameTypeIdAndMod(), A_Const::val, and val.

Referenced by transformAExprAnd(), transformAExprDistinct(), transformAExprIn(), transformAExprNot(), transformAExprNullIf(), transformAExprOf(), transformAExprOp(), transformAExprOpAll(), transformAExprOpAny(), transformAExprOr(), transformArrayExpr(), transformBooleanTest(), transformCaseExpr(), transformCoalesceExpr(), transformCollateClause(), transformExpr(), transformFuncCall(), transformMinMaxExpr(), transformSubLink(), transformTypeCast(), transformXmlExpr(), and transformXmlSerialize().

{
    Node       *result;

    if (expr == NULL)
        return NULL;

    /* Guard against stack overflow due to overly complex expressions */
    check_stack_depth();

    switch (nodeTag(expr))
    {
        case T_ColumnRef:
            result = transformColumnRef(pstate, (ColumnRef *) expr);
            break;

        case T_ParamRef:
            result = transformParamRef(pstate, (ParamRef *) expr);
            break;

        case T_A_Const:
            {
                A_Const    *con = (A_Const *) expr;
                Value      *val = &con->val;

                result = (Node *) make_const(pstate, val, con->location);
                break;
            }

        case T_A_Indirection:
            {
                A_Indirection *ind = (A_Indirection *) expr;

                result = transformExprRecurse(pstate, ind->arg);
                result = transformIndirection(pstate, result,
                                              ind->indirection);
                break;
            }

        case T_A_ArrayExpr:
            result = transformArrayExpr(pstate, (A_ArrayExpr *) expr,
                                        InvalidOid, InvalidOid, -1);
            break;

        case T_TypeCast:
            {
                TypeCast   *tc = (TypeCast *) expr;

                /*
                 * If the subject of the typecast is an ARRAY[] construct and
                 * the target type is an array type, we invoke
                 * transformArrayExpr() directly so that we can pass down the
                 * type information.  This avoids some cases where
                 * transformArrayExpr() might not infer the correct type.
                 */
                if (IsA(tc->arg, A_ArrayExpr))
                {
                    Oid         targetType;
                    Oid         elementType;
                    int32       targetTypmod;

                    typenameTypeIdAndMod(pstate, tc->typeName,
                                         &targetType, &targetTypmod);

                    /*
                     * If target is a domain over array, work with the base
                     * array type here.  transformTypeCast below will cast the
                     * array type to the domain.  In the usual case that the
                     * target is not a domain, transformTypeCast is a no-op.
                     */
                    targetType = getBaseTypeAndTypmod(targetType,
                                                      &targetTypmod);
                    elementType = get_element_type(targetType);
                    if (OidIsValid(elementType))
                    {
                        tc = copyObject(tc);
                        tc->arg = transformArrayExpr(pstate,
                                                     (A_ArrayExpr *) tc->arg,
                                                     targetType,
                                                     elementType,
                                                     targetTypmod);
                    }
                }

                result = transformTypeCast(pstate, tc);
                break;
            }

        case T_CollateClause:
            result = transformCollateClause(pstate, (CollateClause *) expr);
            break;

        case T_A_Expr:
            {
                A_Expr     *a = (A_Expr *) expr;

                switch (a->kind)
                {
                    case AEXPR_OP:
                        result = transformAExprOp(pstate, a);
                        break;
                    case AEXPR_AND:
                        result = transformAExprAnd(pstate, a);
                        break;
                    case AEXPR_OR:
                        result = transformAExprOr(pstate, a);
                        break;
                    case AEXPR_NOT:
                        result = transformAExprNot(pstate, a);
                        break;
                    case AEXPR_OP_ANY:
                        result = transformAExprOpAny(pstate, a);
                        break;
                    case AEXPR_OP_ALL:
                        result = transformAExprOpAll(pstate, a);
                        break;
                    case AEXPR_DISTINCT:
                        result = transformAExprDistinct(pstate, a);
                        break;
                    case AEXPR_NULLIF:
                        result = transformAExprNullIf(pstate, a);
                        break;
                    case AEXPR_OF:
                        result = transformAExprOf(pstate, a);
                        break;
                    case AEXPR_IN:
                        result = transformAExprIn(pstate, a);
                        break;
                    default:
                        elog(ERROR, "unrecognized A_Expr kind: %d", a->kind);
                        result = NULL;      /* keep compiler quiet */
                        break;
                }
                break;
            }

        case T_FuncCall:
            result = transformFuncCall(pstate, (FuncCall *) expr);
            break;

        case T_NamedArgExpr:
            {
                NamedArgExpr *na = (NamedArgExpr *) expr;

                na->arg = (Expr *) transformExprRecurse(pstate, (Node *) na->arg);
                result = expr;
                break;
            }

        case T_SubLink:
            result = transformSubLink(pstate, (SubLink *) expr);
            break;

        case T_CaseExpr:
            result = transformCaseExpr(pstate, (CaseExpr *) expr);
            break;

        case T_RowExpr:
            result = transformRowExpr(pstate, (RowExpr *) expr);
            break;

        case T_CoalesceExpr:
            result = transformCoalesceExpr(pstate, (CoalesceExpr *) expr);
            break;

        case T_MinMaxExpr:
            result = transformMinMaxExpr(pstate, (MinMaxExpr *) expr);
            break;

        case T_XmlExpr:
            result = transformXmlExpr(pstate, (XmlExpr *) expr);
            break;

        case T_XmlSerialize:
            result = transformXmlSerialize(pstate, (XmlSerialize *) expr);
            break;

        case T_NullTest:
            {
                NullTest   *n = (NullTest *) expr;

                n->arg = (Expr *) transformExprRecurse(pstate, (Node *) n->arg);
                /* the argument can be any type, so don't coerce it */
                n->argisrow = type_is_rowtype(exprType((Node *) n->arg));
                result = expr;
                break;
            }

        case T_BooleanTest:
            result = transformBooleanTest(pstate, (BooleanTest *) expr);
            break;

        case T_CurrentOfExpr:
            result = transformCurrentOfExpr(pstate, (CurrentOfExpr *) expr);
            break;

            /*********************************************
             * Quietly accept node types that may be presented when we are
             * called on an already-transformed tree.
             *
             * Do any other node types need to be accepted?  For now we are
             * taking a conservative approach, and only accepting node
             * types that are demonstrably necessary to accept.
             *********************************************/
        case T_Var:
        case T_Const:
        case T_Param:
        case T_Aggref:
        case T_WindowFunc:
        case T_ArrayRef:
        case T_FuncExpr:
        case T_OpExpr:
        case T_DistinctExpr:
        case T_NullIfExpr:
        case T_ScalarArrayOpExpr:
        case T_BoolExpr:
        case T_FieldSelect:
        case T_FieldStore:
        case T_RelabelType:
        case T_CoerceViaIO:
        case T_ArrayCoerceExpr:
        case T_ConvertRowtypeExpr:
        case T_CollateExpr:
        case T_CaseTestExpr:
        case T_ArrayExpr:
        case T_CoerceToDomain:
        case T_CoerceToDomainValue:
        case T_SetToDefault:
            {
                result = (Node *) expr;
                break;
            }

        default:
            /* should not reach here */
            elog(ERROR, "unrecognized node type: %d", (int) nodeTag(expr));
            result = NULL;      /* keep compiler quiet */
            break;
    }

    return result;
}

static Node * transformFuncCall ( ParseState pstate,
FuncCall fn 
) [static]

Definition at line 1240 of file parse_expr.c.

References FuncCall::agg_distinct, FuncCall::agg_order, FuncCall::agg_star, FuncCall::args, FuncCall::func_variadic, FuncCall::funcname, lappend(), lfirst, FuncCall::location, FuncCall::over, ParseFuncOrColumn(), and transformExprRecurse().

Referenced by transformExprRecurse().

{
    List       *targs;
    ListCell   *args;

    /* Transform the list of arguments ... */
    targs = NIL;
    foreach(args, fn->args)
    {
        targs = lappend(targs, transformExprRecurse(pstate,
                                                    (Node *) lfirst(args)));
    }

    /* ... and hand off to ParseFuncOrColumn */
    return ParseFuncOrColumn(pstate,
                             fn->funcname,
                             targs,
                             fn->agg_order,
                             fn->agg_star,
                             fn->agg_distinct,
                             fn->func_variadic,
                             fn->over,
                             false,
                             fn->location);
}

static Node * transformIndirection ( ParseState pstate,
Node basenode,
List indirection 
) [static]

Definition at line 420 of file parse_expr.c.

References Assert, ereport, errcode(), errmsg(), ERROR, exprLocation(), exprType(), exprTypmod(), i, IsA, lappend(), lfirst, list_make1, NIL, NULL, ParseFuncOrColumn(), parser_errposition(), strVal, transformArraySubscripts(), and unknown_attribute().

Referenced by transformExprRecurse().

{
    Node       *result = basenode;
    List       *subscripts = NIL;
    int         location = exprLocation(basenode);
    ListCell   *i;

    /*
     * We have to split any field-selection operations apart from
     * subscripting.  Adjacent A_Indices nodes have to be treated as a single
     * multidimensional subscript operation.
     */
    foreach(i, indirection)
    {
        Node       *n = lfirst(i);

        if (IsA(n, A_Indices))
            subscripts = lappend(subscripts, n);
        else if (IsA(n, A_Star))
        {
            ereport(ERROR,
                    (errcode(ERRCODE_FEATURE_NOT_SUPPORTED),
                     errmsg("row expansion via \"*\" is not supported here"),
                     parser_errposition(pstate, location)));
        }
        else
        {
            Node       *newresult;

            Assert(IsA(n, String));

            /* process subscripts before this field selection */
            if (subscripts)
                result = (Node *) transformArraySubscripts(pstate,
                                                           result,
                                                           exprType(result),
                                                           InvalidOid,
                                                           exprTypmod(result),
                                                           subscripts,
                                                           NULL);
            subscripts = NIL;

            newresult = ParseFuncOrColumn(pstate,
                                          list_make1(n),
                                          list_make1(result),
                                          NIL, false, false, false,
                                          NULL, true, location);
            if (newresult == NULL)
                unknown_attribute(pstate, result, strVal(n), location);
            result = newresult;
        }
    }
    /* process trailing subscripts, if any */
    if (subscripts)
        result = (Node *) transformArraySubscripts(pstate,
                                                   result,
                                                   exprType(result),
                                                   InvalidOid,
                                                   exprTypmod(result),
                                                   subscripts,
                                                   NULL);

    return result;
}

static Node * transformMinMaxExpr ( ParseState pstate,
MinMaxExpr m 
) [static]

Definition at line 1850 of file parse_expr.c.

References MinMaxExpr::args, coerce_to_common_type(), lappend(), lfirst, MinMaxExpr::location, makeNode, MinMaxExpr::minmaxtype, NULL, MinMaxExpr::op, select_common_type(), and transformExprRecurse().

Referenced by transformExprRecurse().

{
    MinMaxExpr *newm = makeNode(MinMaxExpr);
    List       *newargs = NIL;
    List       *newcoercedargs = NIL;
    const char *funcname = (m->op == IS_GREATEST) ? "GREATEST" : "LEAST";
    ListCell   *args;

    newm->op = m->op;
    foreach(args, m->args)
    {
        Node       *e = (Node *) lfirst(args);
        Node       *newe;

        newe = transformExprRecurse(pstate, e);
        newargs = lappend(newargs, newe);
    }

    newm->minmaxtype = select_common_type(pstate, newargs, funcname, NULL);
    /* minmaxcollid and inputcollid will be set by parse_collate.c */

    /* Convert arguments if necessary */
    foreach(args, newargs)
    {
        Node       *e = (Node *) lfirst(args);
        Node       *newe;

        newe = coerce_to_common_type(pstate, e,
                                     newm->minmaxtype,
                                     funcname);
        newcoercedargs = lappend(newcoercedargs, newe);
    }

    newm->args = newcoercedargs;
    newm->location = m->location;
    return (Node *) newm;
}

static Node * transformParamRef ( ParseState pstate,
ParamRef pref 
) [static]

Definition at line 805 of file parse_expr.c.

References ereport, errcode(), errmsg(), ERROR, ParamRef::location, NULL, ParamRef::number, ParseState::p_paramref_hook, and parser_errposition().

Referenced by transformExprRecurse().

{
    Node       *result;

    /*
     * The core parser knows nothing about Params.  If a hook is supplied,
     * call it.  If not, or if the hook returns NULL, throw a generic error.
     */
    if (pstate->p_paramref_hook != NULL)
        result = (*pstate->p_paramref_hook) (pstate, pref);
    else
        result = NULL;

    if (result == NULL)
        ereport(ERROR,
                (errcode(ERRCODE_UNDEFINED_PARAMETER),
                 errmsg("there is no parameter $%d", pref->number),
                 parser_errposition(pstate, pref->location)));

    return result;
}

static Node * transformRowExpr ( ParseState pstate,
RowExpr r 
) [static]

Definition at line 1778 of file parse_expr.c.

References RowExpr::args, RowExpr::colnames, lappend(), RowExpr::location, makeNode, makeString(), OidIsValid, ParseState::p_expr_kind, pstrdup(), RowExpr::row_format, RowExpr::row_typeid, snprintf(), and transformExpressionList().

Referenced by transformExprRecurse().

{
    RowExpr    *newr;
    char        fname[16];
    int         fnum;
    ListCell   *lc;

    /* If we already transformed this node, do nothing */
    if (OidIsValid(r->row_typeid))
        return (Node *) r;

    newr = makeNode(RowExpr);

    /* Transform the field expressions */
    newr->args = transformExpressionList(pstate, r->args, pstate->p_expr_kind);

    /* Barring later casting, we consider the type RECORD */
    newr->row_typeid = RECORDOID;
    newr->row_format = COERCE_IMPLICIT_CAST;

    /* ROW() has anonymous columns, so invent some field names */
    newr->colnames = NIL;
    fnum = 1;
    foreach(lc, newr->args)
    {
        snprintf(fname, sizeof(fname), "f%d", fnum++);
        newr->colnames = lappend(newr->colnames, makeString(pstrdup(fname)));
    }

    newr->location = r->location;

    return (Node *) newr;
}

static Node * transformSubLink ( ParseState pstate,
SubLink sublink 
) [static]

Definition at line 1403 of file parse_expr.c.

References _, ARRAY_SUBLINK, Assert, CMD_SELECT, Query::commandType, elog, ereport, errcode(), errmsg(), errmsg_internal(), ERROR, EXISTS_SUBLINK, TargetEntry::expr, EXPR_KIND_ALTER_COL_TRANSFORM, EXPR_KIND_CHECK_CONSTRAINT, EXPR_KIND_COLUMN_DEFAULT, EXPR_KIND_DISTINCT_ON, EXPR_KIND_DOMAIN_CHECK, EXPR_KIND_EXECUTE_PARAMETER, EXPR_KIND_FROM_FUNCTION, EXPR_KIND_FROM_SUBSELECT, EXPR_KIND_FUNCTION_DEFAULT, EXPR_KIND_GROUP_BY, EXPR_KIND_HAVING, EXPR_KIND_INDEX_EXPRESSION, EXPR_KIND_INDEX_PREDICATE, EXPR_KIND_INSERT_TARGET, EXPR_KIND_JOIN_ON, EXPR_KIND_JOIN_USING, EXPR_KIND_LIMIT, EXPR_KIND_NONE, EXPR_KIND_OFFSET, EXPR_KIND_ORDER_BY, EXPR_KIND_OTHER, EXPR_KIND_RETURNING, EXPR_KIND_SELECT_TARGET, EXPR_KIND_TRIGGER_WHEN, EXPR_KIND_UPDATE_SOURCE, EXPR_KIND_UPDATE_TARGET, EXPR_KIND_VALUES, EXPR_KIND_WHERE, EXPR_KIND_WINDOW_FRAME_RANGE, EXPR_KIND_WINDOW_FRAME_ROWS, EXPR_KIND_WINDOW_ORDER, EXPR_KIND_WINDOW_PARTITION, EXPR_SUBLINK, exprCollation(), exprType(), exprTypmod(), IsA, lappend(), lfirst, list_head(), list_length(), list_make1, lnext, Param::location, SubLink::location, make_row_comparison_op(), makeNode, NULL, SubLink::operName, ParseState::p_expr_kind, ParseState::p_hasSubLinks, Param::paramcollid, Param::paramid, Param::paramkind, Param::paramtype, Param::paramtypmod, parse_sub_analyze(), parser_errposition(), TargetEntry::resjunk, TargetEntry::resno, SubLink::subLinkType, SubLink::subselect, Query::targetList, SubLink::testexpr, transformExprRecurse(), and Query::utilityStmt.

Referenced by transformExprRecurse().

{
    Node       *result = (Node *) sublink;
    Query      *qtree;
    const char *err;

    /* If we already transformed this node, do nothing */
    if (IsA(sublink->subselect, Query))
        return result;

    /*
     * Check to see if the sublink is in an invalid place within the query.
     * We allow sublinks everywhere in SELECT/INSERT/UPDATE/DELETE, but
     * generally not in utility statements.
     */
    err = NULL;
    switch (pstate->p_expr_kind)
    {
        case EXPR_KIND_NONE:
            Assert(false);      /* can't happen */
            break;
        case EXPR_KIND_OTHER:
            /* Accept sublink here; caller must throw error if wanted */
            break;
        case EXPR_KIND_JOIN_ON:
        case EXPR_KIND_JOIN_USING:
        case EXPR_KIND_FROM_SUBSELECT:
        case EXPR_KIND_FROM_FUNCTION:
        case EXPR_KIND_WHERE:
        case EXPR_KIND_HAVING:
        case EXPR_KIND_WINDOW_PARTITION:
        case EXPR_KIND_WINDOW_ORDER:
        case EXPR_KIND_WINDOW_FRAME_RANGE:
        case EXPR_KIND_WINDOW_FRAME_ROWS:
        case EXPR_KIND_SELECT_TARGET:
        case EXPR_KIND_INSERT_TARGET:
        case EXPR_KIND_UPDATE_SOURCE:
        case EXPR_KIND_UPDATE_TARGET:
        case EXPR_KIND_GROUP_BY:
        case EXPR_KIND_ORDER_BY:
        case EXPR_KIND_DISTINCT_ON:
        case EXPR_KIND_LIMIT:
        case EXPR_KIND_OFFSET:
        case EXPR_KIND_RETURNING:
        case EXPR_KIND_VALUES:
            /* okay */
            break;
        case EXPR_KIND_CHECK_CONSTRAINT:
        case EXPR_KIND_DOMAIN_CHECK:
            err = _("cannot use subquery in check constraint");
            break;
        case EXPR_KIND_COLUMN_DEFAULT:
        case EXPR_KIND_FUNCTION_DEFAULT:
            err = _("cannot use subquery in DEFAULT expression");
            break;
        case EXPR_KIND_INDEX_EXPRESSION:
            err = _("cannot use subquery in index expression");
            break;
        case EXPR_KIND_INDEX_PREDICATE:
            err = _("cannot use subquery in index predicate");
            break;
        case EXPR_KIND_ALTER_COL_TRANSFORM:
            err = _("cannot use subquery in transform expression");
            break;
        case EXPR_KIND_EXECUTE_PARAMETER:
            err = _("cannot use subquery in EXECUTE parameter");
            break;
        case EXPR_KIND_TRIGGER_WHEN:
            err = _("cannot use subquery in trigger WHEN condition");
            break;

            /*
             * There is intentionally no default: case here, so that the
             * compiler will warn if we add a new ParseExprKind without
             * extending this switch.  If we do see an unrecognized value at
             * runtime, the behavior will be the same as for EXPR_KIND_OTHER,
             * which is sane anyway.
             */
    }
    if (err)
        ereport(ERROR,
                (errcode(ERRCODE_FEATURE_NOT_SUPPORTED),
                 errmsg_internal("%s", err),
                 parser_errposition(pstate, sublink->location)));

    pstate->p_hasSubLinks = true;

    /*
     * OK, let's transform the sub-SELECT.
     */
    qtree = parse_sub_analyze(sublink->subselect, pstate, NULL, false);

    /*
     * Check that we got something reasonable.  Many of these conditions are
     * impossible given restrictions of the grammar, but check 'em anyway.
     */
    if (!IsA(qtree, Query) ||
        qtree->commandType != CMD_SELECT ||
        qtree->utilityStmt != NULL)
        elog(ERROR, "unexpected non-SELECT command in SubLink");

    sublink->subselect = (Node *) qtree;

    if (sublink->subLinkType == EXISTS_SUBLINK)
    {
        /*
         * EXISTS needs no test expression or combining operator. These fields
         * should be null already, but make sure.
         */
        sublink->testexpr = NULL;
        sublink->operName = NIL;
    }
    else if (sublink->subLinkType == EXPR_SUBLINK ||
             sublink->subLinkType == ARRAY_SUBLINK)
    {
        ListCell   *tlist_item = list_head(qtree->targetList);

        /*
         * Make sure the subselect delivers a single column (ignoring resjunk
         * targets).
         */
        if (tlist_item == NULL ||
            ((TargetEntry *) lfirst(tlist_item))->resjunk)
            ereport(ERROR,
                    (errcode(ERRCODE_SYNTAX_ERROR),
                     errmsg("subquery must return a column"),
                     parser_errposition(pstate, sublink->location)));
        while ((tlist_item = lnext(tlist_item)) != NULL)
        {
            if (!((TargetEntry *) lfirst(tlist_item))->resjunk)
                ereport(ERROR,
                        (errcode(ERRCODE_SYNTAX_ERROR),
                         errmsg("subquery must return only one column"),
                         parser_errposition(pstate, sublink->location)));
        }

        /*
         * EXPR and ARRAY need no test expression or combining operator. These
         * fields should be null already, but make sure.
         */
        sublink->testexpr = NULL;
        sublink->operName = NIL;
    }
    else
    {
        /* ALL, ANY, or ROWCOMPARE: generate row-comparing expression */
        Node       *lefthand;
        List       *left_list;
        List       *right_list;
        ListCell   *l;

        /*
         * Transform lefthand expression, and convert to a list
         */
        lefthand = transformExprRecurse(pstate, sublink->testexpr);
        if (lefthand && IsA(lefthand, RowExpr))
            left_list = ((RowExpr *) lefthand)->args;
        else
            left_list = list_make1(lefthand);

        /*
         * Build a list of PARAM_SUBLINK nodes representing the output columns
         * of the subquery.
         */
        right_list = NIL;
        foreach(l, qtree->targetList)
        {
            TargetEntry *tent = (TargetEntry *) lfirst(l);
            Param      *param;

            if (tent->resjunk)
                continue;

            param = makeNode(Param);
            param->paramkind = PARAM_SUBLINK;
            param->paramid = tent->resno;
            param->paramtype = exprType((Node *) tent->expr);
            param->paramtypmod = exprTypmod((Node *) tent->expr);
            param->paramcollid = exprCollation((Node *) tent->expr);
            param->location = -1;

            right_list = lappend(right_list, param);
        }

        /*
         * We could rely on make_row_comparison_op to complain if the list
         * lengths differ, but we prefer to generate a more specific error
         * message.
         */
        if (list_length(left_list) < list_length(right_list))
            ereport(ERROR,
                    (errcode(ERRCODE_SYNTAX_ERROR),
                     errmsg("subquery has too many columns"),
                     parser_errposition(pstate, sublink->location)));
        if (list_length(left_list) > list_length(right_list))
            ereport(ERROR,
                    (errcode(ERRCODE_SYNTAX_ERROR),
                     errmsg("subquery has too few columns"),
                     parser_errposition(pstate, sublink->location)));

        /*
         * Identify the combining operator(s) and generate a suitable
         * row-comparison expression.
         */
        sublink->testexpr = make_row_comparison_op(pstate,
                                                   sublink->operName,
                                                   left_list,
                                                   right_list,
                                                   sublink->location);
    }

    return result;
}

static Node * transformTypeCast ( ParseState pstate,
TypeCast tc 
) [static]

Definition at line 2199 of file parse_expr.c.

References TypeCast::arg, COERCE_EXPLICIT_CAST, coerce_to_target_type(), COERCION_EXPLICIT, ereport, errcode(), errmsg(), ERROR, exprType(), format_type_be(), InvalidOid, TypeName::location, TypeCast::location, NULL, parser_coercion_errposition(), transformExprRecurse(), TypeCast::typeName, and typenameTypeIdAndMod().

Referenced by transformExprRecurse().

{
    Node       *result;
    Node       *expr = transformExprRecurse(pstate, tc->arg);
    Oid         inputType = exprType(expr);
    Oid         targetType;
    int32       targetTypmod;
    int         location;

    typenameTypeIdAndMod(pstate, tc->typeName, &targetType, &targetTypmod);

    if (inputType == InvalidOid)
        return expr;            /* do nothing if NULL input */

    /*
     * Location of the coercion is preferentially the location of the :: or
     * CAST symbol, but if there is none then use the location of the type
     * name (this can happen in TypeName 'string' syntax, for instance).
     */
    location = tc->location;
    if (location < 0)
        location = tc->typeName->location;

    result = coerce_to_target_type(pstate, expr, inputType,
                                   targetType, targetTypmod,
                                   COERCION_EXPLICIT,
                                   COERCE_EXPLICIT_CAST,
                                   location);
    if (result == NULL)
        ereport(ERROR,
                (errcode(ERRCODE_CANNOT_COERCE),
                 errmsg("cannot cast type %s to %s",
                        format_type_be(inputType),
                        format_type_be(targetType)),
                 parser_coercion_errposition(pstate, location, expr)));

    return result;
}

static Node * transformWholeRowRef ( ParseState pstate,
RangeTblEntry rte,
int  location 
) [static]

Definition at line 2164 of file parse_expr.c.

References Var::location, makeWholeRowVar(), markVarForSelectPriv(), and RTERangeTablePosn().

Referenced by transformColumnRef().

{
    Var        *result;
    int         vnum;
    int         sublevels_up;

    /* Find the RTE's rangetable location */
    vnum = RTERangeTablePosn(pstate, rte, &sublevels_up);

    /*
     * Build the appropriate referencing node.  Note that if the RTE is a
     * function returning scalar, we create just a plain reference to the
     * function value, not a composite containing a single column.  This is
     * pretty inconsistent at first sight, but it's what we've done
     * historically.  One argument for it is that "rel" and "rel.*" mean the
     * same thing for composite relations, so why not for scalar functions...
     */
    result = makeWholeRowVar(rte, vnum, sublevels_up, true);

    /* location is not filled in by makeWholeRowVar */
    result->location = location;

    /* mark relation as requiring whole-row SELECT access */
    markVarForSelectPriv(pstate, result, rte);

    return (Node *) result;
}

static Node * transformXmlExpr ( ParseState pstate,
XmlExpr x 
) [static]

Definition at line 1889 of file parse_expr.c.

References XmlExpr::arg_names, XmlExpr::args, Assert, coerce_to_boolean(), coerce_to_specific_type(), ereport, errcode(), errmsg(), ERROR, FigureColname(), i, INT4OID, IS_DOCUMENT, IS_XMLCONCAT, IS_XMLELEMENT, IS_XMLFOREST, IS_XMLPARSE, IS_XMLPI, IS_XMLROOT, IS_XMLSERIALIZE, IsA, lappend(), lfirst, ResTarget::location, XmlExpr::location, makeNode, makeString(), map_sql_identifier_to_xml_name(), ResTarget::name, XmlExpr::name, XmlExpr::named_args, OidIsValid, XmlExpr::op, parser_errposition(), strVal, TEXTOID, transformExprRecurse(), XmlExpr::type, XmlExpr::typmod, ResTarget::val, XMLOID, and XmlExpr::xmloption.

Referenced by transformExprRecurse().

{
    XmlExpr    *newx;
    ListCell   *lc;
    int         i;

    /* If we already transformed this node, do nothing */
    if (OidIsValid(x->type))
        return (Node *) x;

    newx = makeNode(XmlExpr);
    newx->op = x->op;
    if (x->name)
        newx->name = map_sql_identifier_to_xml_name(x->name, false, false);
    else
        newx->name = NULL;
    newx->xmloption = x->xmloption;
    newx->type = XMLOID;        /* this just marks the node as transformed */
    newx->typmod = -1;
    newx->location = x->location;

    /*
     * gram.y built the named args as a list of ResTarget.  Transform each,
     * and break the names out as a separate list.
     */
    newx->named_args = NIL;
    newx->arg_names = NIL;

    foreach(lc, x->named_args)
    {
        ResTarget  *r = (ResTarget *) lfirst(lc);
        Node       *expr;
        char       *argname;

        Assert(IsA(r, ResTarget));

        expr = transformExprRecurse(pstate, r->val);

        if (r->name)
            argname = map_sql_identifier_to_xml_name(r->name, false, false);
        else if (IsA(r->val, ColumnRef))
            argname = map_sql_identifier_to_xml_name(FigureColname(r->val),
                                                     true, false);
        else
        {
            ereport(ERROR,
                    (errcode(ERRCODE_SYNTAX_ERROR),
                     x->op == IS_XMLELEMENT
            ? errmsg("unnamed XML attribute value must be a column reference")
            : errmsg("unnamed XML element value must be a column reference"),
                     parser_errposition(pstate, r->location)));
            argname = NULL;     /* keep compiler quiet */
        }

        /* reject duplicate argnames in XMLELEMENT only */
        if (x->op == IS_XMLELEMENT)
        {
            ListCell   *lc2;

            foreach(lc2, newx->arg_names)
            {
                if (strcmp(argname, strVal(lfirst(lc2))) == 0)
                    ereport(ERROR,
                            (errcode(ERRCODE_SYNTAX_ERROR),
                    errmsg("XML attribute name \"%s\" appears more than once",
                           argname),
                             parser_errposition(pstate, r->location)));
            }
        }

        newx->named_args = lappend(newx->named_args, expr);
        newx->arg_names = lappend(newx->arg_names, makeString(argname));
    }

    /* The other arguments are of varying types depending on the function */
    newx->args = NIL;
    i = 0;
    foreach(lc, x->args)
    {
        Node       *e = (Node *) lfirst(lc);
        Node       *newe;

        newe = transformExprRecurse(pstate, e);
        switch (x->op)
        {
            case IS_XMLCONCAT:
                newe = coerce_to_specific_type(pstate, newe, XMLOID,
                                               "XMLCONCAT");
                break;
            case IS_XMLELEMENT:
                /* no coercion necessary */
                break;
            case IS_XMLFOREST:
                newe = coerce_to_specific_type(pstate, newe, XMLOID,
                                               "XMLFOREST");
                break;
            case IS_XMLPARSE:
                if (i == 0)
                    newe = coerce_to_specific_type(pstate, newe, TEXTOID,
                                                   "XMLPARSE");
                else
                    newe = coerce_to_boolean(pstate, newe, "XMLPARSE");
                break;
            case IS_XMLPI:
                newe = coerce_to_specific_type(pstate, newe, TEXTOID,
                                               "XMLPI");
                break;
            case IS_XMLROOT:
                if (i == 0)
                    newe = coerce_to_specific_type(pstate, newe, XMLOID,
                                                   "XMLROOT");
                else if (i == 1)
                    newe = coerce_to_specific_type(pstate, newe, TEXTOID,
                                                   "XMLROOT");
                else
                    newe = coerce_to_specific_type(pstate, newe, INT4OID,
                                                   "XMLROOT");
                break;
            case IS_XMLSERIALIZE:
                /* not handled here */
                Assert(false);
                break;
            case IS_DOCUMENT:
                newe = coerce_to_specific_type(pstate, newe, XMLOID,
                                               "IS DOCUMENT");
                break;
        }
        newx->args = lappend(newx->args, newe);
        i++;
    }

    return (Node *) newx;
}

static Node * transformXmlSerialize ( ParseState pstate,
XmlSerialize xs 
) [static]

Definition at line 2024 of file parse_expr.c.

References XmlExpr::args, COERCE_IMPLICIT_CAST, coerce_to_specific_type(), coerce_to_target_type(), COERCION_IMPLICIT, ereport, errcode(), errmsg(), ERROR, XmlSerialize::expr, format_type_be(), list_make1, XmlSerialize::location, XmlExpr::location, makeNode, NULL, XmlExpr::op, parser_errposition(), TEXTOID, transformExprRecurse(), XmlExpr::type, XmlSerialize::typeName, typenameTypeIdAndMod(), XmlExpr::typmod, XMLOID, XmlSerialize::xmloption, and XmlExpr::xmloption.

Referenced by transformExprRecurse().

{
    Node       *result;
    XmlExpr    *xexpr;
    Oid         targetType;
    int32       targetTypmod;

    xexpr = makeNode(XmlExpr);
    xexpr->op = IS_XMLSERIALIZE;
    xexpr->args = list_make1(coerce_to_specific_type(pstate,
                                        transformExprRecurse(pstate, xs->expr),
                                                     XMLOID,
                                                     "XMLSERIALIZE"));

    typenameTypeIdAndMod(pstate, xs->typeName, &targetType, &targetTypmod);

    xexpr->xmloption = xs->xmloption;
    xexpr->location = xs->location;
    /* We actually only need these to be able to parse back the expression. */
    xexpr->type = targetType;
    xexpr->typmod = targetTypmod;

    /*
     * The actual target type is determined this way.  SQL allows char and
     * varchar as target types.  We allow anything that can be cast implicitly
     * from text.  This way, user-defined text-like data types automatically
     * fit in.
     */
    result = coerce_to_target_type(pstate, (Node *) xexpr,
                                   TEXTOID, targetType, targetTypmod,
                                   COERCION_IMPLICIT,
                                   COERCE_IMPLICIT_CAST,
                                   -1);
    if (result == NULL)
        ereport(ERROR,
                (errcode(ERRCODE_CANNOT_COERCE),
                 errmsg("cannot cast XMLSERIALIZE result to %s",
                        format_type_be(targetType)),
                 parser_errposition(pstate, xexpr->location)));
    return result;
}

static void unknown_attribute ( ParseState pstate,
Node relref,
char *  attname,
int  location 
) [static]

Definition at line 374 of file parse_expr.c.

References Alias::aliasname, RangeTblEntry::eref, ereport, errcode(), errmsg(), ERROR, exprType(), format_type_be(), GetRTEByRangeTablePosn(), InvalidAttrNumber, IsA, ISCOMPLEX, parser_errposition(), and RECORDOID.

Referenced by transformIndirection().

{
    RangeTblEntry *rte;

    if (IsA(relref, Var) &&
        ((Var *) relref)->varattno == InvalidAttrNumber)
    {
        /* Reference the RTE by alias not by actual table name */
        rte = GetRTEByRangeTablePosn(pstate,
                                     ((Var *) relref)->varno,
                                     ((Var *) relref)->varlevelsup);
        ereport(ERROR,
                (errcode(ERRCODE_UNDEFINED_COLUMN),
                 errmsg("column %s.%s does not exist",
                        rte->eref->aliasname, attname),
                 parser_errposition(pstate, location)));
    }
    else
    {
        /* Have to do it by reference to the type of the expression */
        Oid         relTypeId = exprType(relref);

        if (ISCOMPLEX(relTypeId))
            ereport(ERROR,
                    (errcode(ERRCODE_UNDEFINED_COLUMN),
                     errmsg("column \"%s\" not found in data type %s",
                            attname, format_type_be(relTypeId)),
                     parser_errposition(pstate, location)));
        else if (relTypeId == RECORDOID)
            ereport(ERROR,
                    (errcode(ERRCODE_UNDEFINED_COLUMN),
               errmsg("could not identify column \"%s\" in record data type",
                      attname),
                     parser_errposition(pstate, location)));
        else
            ereport(ERROR,
                    (errcode(ERRCODE_WRONG_OBJECT_TYPE),
                     errmsg("column notation .%s applied to type %s, "
                            "which is not a composite type",
                            attname, format_type_be(relTypeId)),
                     parser_errposition(pstate, location)));
    }
}


Variable Documentation

Definition at line 38 of file parse_expr.c.

Referenced by transformAExprOp().