PostgreSQL Source Code  git master
makefuncs.h File Reference
#include "nodes/execnodes.h"
#include "nodes/parsenodes.h"
Include dependency graph for makefuncs.h:
This graph shows which files directly or indirectly include this file:

Go to the source code of this file.

Functions

A_ExprmakeA_Expr (A_Expr_Kind kind, List *name, Node *lexpr, Node *rexpr, int location)
 
A_ExprmakeSimpleA_Expr (A_Expr_Kind kind, char *name, Node *lexpr, Node *rexpr, int location)
 
VarmakeVar (int varno, AttrNumber varattno, Oid vartype, int32 vartypmod, Oid varcollid, Index varlevelsup)
 
VarmakeVarFromTargetEntry (int varno, TargetEntry *tle)
 
VarmakeWholeRowVar (RangeTblEntry *rte, int varno, Index varlevelsup, bool allowScalar)
 
TargetEntrymakeTargetEntry (Expr *expr, AttrNumber resno, char *resname, bool resjunk)
 
TargetEntryflatCopyTargetEntry (TargetEntry *src_tle)
 
FromExprmakeFromExpr (List *fromlist, Node *quals)
 
ConstmakeConst (Oid consttype, int32 consttypmod, Oid constcollid, int constlen, Datum constvalue, bool constisnull, bool constbyval)
 
ConstmakeNullConst (Oid consttype, int32 consttypmod, Oid constcollid)
 
NodemakeBoolConst (bool value, bool isnull)
 
ExprmakeBoolExpr (BoolExprType boolop, List *args, int location)
 
AliasmakeAlias (const char *aliasname, List *colnames)
 
RelabelTypemakeRelabelType (Expr *arg, Oid rtype, int32 rtypmod, Oid rcollid, CoercionForm rformat)
 
RangeVarmakeRangeVar (char *schemaname, char *relname, int location)
 
TypeNamemakeTypeName (char *typnam)
 
TypeNamemakeTypeNameFromNameList (List *names)
 
TypeNamemakeTypeNameFromOid (Oid typeOid, int32 typmod)
 
ColumnDefmakeColumnDef (const char *colname, Oid typeOid, int32 typmod, Oid collOid)
 
FuncExprmakeFuncExpr (Oid funcid, Oid rettype, List *args, Oid funccollid, Oid inputcollid, CoercionForm fformat)
 
FuncCallmakeFuncCall (List *name, List *args, CoercionForm funcformat, int location)
 
Exprmake_opclause (Oid opno, Oid opresulttype, bool opretset, Expr *leftop, Expr *rightop, Oid opcollid, Oid inputcollid)
 
Exprmake_andclause (List *andclauses)
 
Exprmake_orclause (List *orclauses)
 
Exprmake_notclause (Expr *notclause)
 
Nodemake_and_qual (Node *qual1, Node *qual2)
 
Exprmake_ands_explicit (List *andclauses)
 
Listmake_ands_implicit (Expr *clause)
 
IndexInfomakeIndexInfo (int numattrs, int numkeyattrs, Oid amoid, List *expressions, List *predicates, bool unique, bool nulls_not_distinct, bool isready, bool concurrent, bool summarizing)
 
DefElemmakeDefElem (char *name, Node *arg, int location)
 
DefElemmakeDefElemExtended (char *nameSpace, char *name, Node *arg, DefElemAction defaction, int location)
 
GroupingSetmakeGroupingSet (GroupingSetKind kind, List *content, int location)
 
VacuumRelationmakeVacuumRelation (RangeVar *relation, Oid oid, List *va_cols)
 

Function Documentation

◆ flatCopyTargetEntry()

TargetEntry* flatCopyTargetEntry ( TargetEntry src_tle)

Definition at line 273 of file makefuncs.c.

274 {
276 
277  Assert(IsA(src_tle, TargetEntry));
278  memcpy(tle, src_tle, sizeof(TargetEntry));
279  return tle;
280 }
Assert(fmt[strlen(fmt) - 1] !='\n')
#define IsA(nodeptr, _type_)
Definition: nodes.h:179
#define makeNode(_type_)
Definition: nodes.h:176

References Assert(), IsA, and makeNode.

Referenced by expand_insert_targetlist(), process_matched_tle(), rewriteTargetListIU(), set_dummy_tlist_references(), and set_upper_references().

◆ make_and_qual()

Node* make_and_qual ( Node qual1,
Node qual2 
)

Definition at line 691 of file makefuncs.c.

692 {
693  if (qual1 == NULL)
694  return qual2;
695  if (qual2 == NULL)
696  return qual1;
697  return (Node *) make_andclause(list_make2(qual1, qual2));
698 }
Expr * make_andclause(List *andclauses)
Definition: makefuncs.c:638
#define list_make2(x1, x2)
Definition: pg_list.h:214
Definition: nodes.h:129

References list_make2, and make_andclause().

Referenced by AddQual(), and subquery_push_qual().

◆ make_andclause()

Expr* make_andclause ( List andclauses)

Definition at line 638 of file makefuncs.c.

639 {
640  BoolExpr *expr = makeNode(BoolExpr);
641 
642  expr->boolop = AND_EXPR;
643  expr->args = andclauses;
644  expr->location = -1;
645  return (Expr *) expr;
646 }
@ AND_EXPR
Definition: primnodes.h:858
int location
Definition: primnodes.h:868
BoolExprType boolop
Definition: primnodes.h:866
List * args
Definition: primnodes.h:867

References AND_EXPR, BoolExpr::args, BoolExpr::boolop, BoolExpr::location, and makeNode.

Referenced by eval_const_expressions_mutator(), ExplainNode(), find_duplicate_ors(), make_and_qual(), make_ands_explicit(), make_sub_restrictinfos(), negate_clause(), process_duplicate_ors(), process_sublinks_mutator(), and pull_up_sublinks_qual_recurse().

◆ make_ands_explicit()

Expr* make_ands_explicit ( List andclauses)

Definition at line 710 of file makefuncs.c.

711 {
712  if (andclauses == NIL)
713  return (Expr *) makeBoolConst(true, false);
714  else if (list_length(andclauses) == 1)
715  return (Expr *) linitial(andclauses);
716  else
717  return make_andclause(andclauses);
718 }
Node * makeBoolConst(bool value, bool isnull)
Definition: makefuncs.c:359
static int list_length(const List *l)
Definition: pg_list.h:152
#define NIL
Definition: pg_list.h:68
#define linitial(l)
Definition: pg_list.h:178

References linitial, list_length(), make_andclause(), makeBoolConst(), and NIL.

Referenced by ATExecAttachPartition(), check_default_partition_contents(), convert_EXISTS_to_ANY(), create_bitmap_subplan(), DetachAddConstraintIfNeeded(), ExecInitCheck(), extract_or_clause(), get_proposed_default_constraint(), get_qual_for_list(), show_qual(), and UpdateIndexRelation().

◆ make_ands_implicit()

List* make_ands_implicit ( Expr clause)

Definition at line 721 of file makefuncs.c.

722 {
723  /*
724  * NB: because the parser sets the qual field to NULL in a query that has
725  * no WHERE clause, we must consider a NULL input clause as TRUE, even
726  * though one might more reasonably think it FALSE.
727  */
728  if (clause == NULL)
729  return NIL; /* NULL -> NIL list == TRUE */
730  else if (is_andclause(clause))
731  return ((BoolExpr *) clause)->args;
732  else if (IsA(clause, Const) &&
733  !((Const *) clause)->constisnull &&
734  DatumGetBool(((Const *) clause)->constvalue))
735  return NIL; /* constant TRUE input -> NIL list */
736  else
737  return list_make1(clause);
738 }
static bool is_andclause(const void *clause)
Definition: nodeFuncs.h:105
#define list_make1(x1)
Definition: pg_list.h:212
static bool DatumGetBool(Datum X)
Definition: postgres.h:90

References DatumGetBool(), is_andclause(), IsA, list_make1, and NIL.

Referenced by apply_child_basequals(), ConstraintImpliedByRelConstraint(), convert_EXISTS_to_ANY(), cost_subplan(), DefineIndex(), DoCopy(), get_proposed_default_constraint(), get_relation_constraints(), index_concurrently_create_copy(), preprocess_expression(), RelationGetIndexPredicate(), test_predtest(), and TriggerEnabled().

◆ make_notclause()

Expr* make_notclause ( Expr notclause)

Definition at line 670 of file makefuncs.c.

671 {
672  BoolExpr *expr = makeNode(BoolExpr);
673 
674  expr->boolop = NOT_EXPR;
675  expr->args = list_make1(notclause);
676  expr->location = -1;
677  return (Expr *) expr;
678 }
@ NOT_EXPR
Definition: primnodes.h:858

References BoolExpr::args, BoolExpr::boolop, list_make1, BoolExpr::location, makeNode, and NOT_EXPR.

Referenced by negate_clause().

◆ make_opclause()

Expr* make_opclause ( Oid  opno,
Oid  opresulttype,
bool  opretset,
Expr leftop,
Expr rightop,
Oid  opcollid,
Oid  inputcollid 
)

Definition at line 612 of file makefuncs.c.

615 {
616  OpExpr *expr = makeNode(OpExpr);
617 
618  expr->opno = opno;
619  expr->opfuncid = InvalidOid;
620  expr->opresulttype = opresulttype;
621  expr->opretset = opretset;
622  expr->opcollid = opcollid;
623  expr->inputcollid = inputcollid;
624  if (rightop)
625  expr->args = list_make2(leftop, rightop);
626  else
627  expr->args = list_make1(leftop);
628  expr->location = -1;
629  return (Expr *) expr;
630 }
#define InvalidOid
Definition: postgres_ext.h:36
int location
Definition: primnodes.h:766
Oid opno
Definition: primnodes.h:745
List * args
Definition: primnodes.h:763

References OpExpr::args, InvalidOid, list_make1, list_make2, OpExpr::location, makeNode, and OpExpr::opno.

Referenced by build_implied_join_equality(), convert_EXISTS_to_ANY(), expand_indexqual_rowcompare(), find_window_run_conditions(), make_partition_op_expr(), match_boolean_index_clause(), match_clause_to_partition_key(), match_network_subset(), match_pattern_prefix(), operator_predicate_proof(), process_implied_equality(), and rewriteSearchAndCycle().

◆ make_orclause()

Expr* make_orclause ( List orclauses)

◆ makeA_Expr()

A_Expr* makeA_Expr ( A_Expr_Kind  kind,
List name,
Node lexpr,
Node rexpr,
int  location 
)

Definition at line 30 of file makefuncs.c.

32 {
33  A_Expr *a = makeNode(A_Expr);
34 
35  a->kind = kind;
36  a->name = name;
37  a->lexpr = lexpr;
38  a->rexpr = rexpr;
39  a->location = location;
40  return a;
41 }
const char * name
Definition: encode.c:571
int a
Definition: isn.c:69

References a, makeNode, and name.

◆ makeAlias()

◆ makeBoolConst()

Node* makeBoolConst ( bool  value,
bool  isnull 
)

Definition at line 359 of file makefuncs.c.

360 {
361  /* note that pg_type.h hardwires size of bool as 1 ... duplicate it */
362  return (Node *) makeConst(BOOLOID, -1, InvalidOid, 1,
363  BoolGetDatum(value), isnull, true);
364 }
static struct @143 value
Const * makeConst(Oid consttype, int32 consttypmod, Oid constcollid, int constlen, Datum constvalue, bool constisnull, bool constbyval)
Definition: makefuncs.c:301
static Datum BoolGetDatum(bool X)
Definition: postgres.h:102

References BoolGetDatum(), InvalidOid, makeConst(), and value.

Referenced by create_append_plan(), eval_const_expressions_mutator(), find_duplicate_ors(), get_qual_for_range(), make_ands_explicit(), make_row_distinct_op(), match_boolean_index_clause(), match_boolean_partition_clause(), negate_clause(), process_duplicate_ors(), and reconsider_outer_join_clauses().

◆ makeBoolExpr()

◆ makeColumnDef()

ColumnDef* makeColumnDef ( const char *  colname,
Oid  typeOid,
int32  typmod,
Oid  collOid 
)

Definition at line 492 of file makefuncs.c.

493 {
495 
496  n->colname = pstrdup(colname);
497  n->typeName = makeTypeNameFromOid(typeOid, typmod);
498  n->inhcount = 0;
499  n->is_local = true;
500  n->is_not_null = false;
501  n->is_from_type = false;
502  n->storage = 0;
503  n->raw_default = NULL;
504  n->cooked_default = NULL;
505  n->collClause = NULL;
506  n->collOid = collOid;
507  n->constraints = NIL;
508  n->fdwoptions = NIL;
509  n->location = -1;
510 
511  return n;
512 }
TypeName * makeTypeNameFromOid(Oid typeOid, int32 typmod)
Definition: makefuncs.c:474
bool is_not_null
Definition: parsenodes.h:726
CollateClause * collClause
Definition: parsenodes.h:736
int location
Definition: parsenodes.h:740
List * constraints
Definition: parsenodes.h:738
Node * cooked_default
Definition: parsenodes.h:731
int inhcount
Definition: parsenodes.h:724
char * colname
Definition: parsenodes.h:721
TypeName * typeName
Definition: parsenodes.h:722
bool is_from_type
Definition: parsenodes.h:727
List * fdwoptions
Definition: parsenodes.h:739
Node * raw_default
Definition: parsenodes.h:730
char storage
Definition: parsenodes.h:728
Oid collOid
Definition: parsenodes.h:737
bool is_local
Definition: parsenodes.h:725

References ColumnDef::collClause, ColumnDef::collOid, ColumnDef::colname, ColumnDef::constraints, ColumnDef::cooked_default, ColumnDef::fdwoptions, ColumnDef::inhcount, ColumnDef::is_from_type, ColumnDef::is_local, ColumnDef::is_not_null, ColumnDef::location, makeNode, makeTypeNameFromOid(), NIL, pstrdup(), ColumnDef::raw_default, ColumnDef::storage, and ColumnDef::typeName.

Referenced by create_ctas_nodata(), DefineVirtualRelation(), and intorel_startup().

◆ makeConst()

Const* makeConst ( Oid  consttype,
int32  consttypmod,
Oid  constcollid,
int  constlen,
Datum  constvalue,
bool  constisnull,
bool  constbyval 
)

Definition at line 301 of file makefuncs.c.

308 {
309  Const *cnst = makeNode(Const);
310 
311  /*
312  * If it's a varlena value, force it to be in non-expanded (non-toasted)
313  * format; this avoids any possible dependency on external values and
314  * improves consistency of representation, which is important for equal().
315  */
316  if (!constisnull && constlen == -1)
317  constvalue = PointerGetDatum(PG_DETOAST_DATUM(constvalue));
318 
319  cnst->consttype = consttype;
320  cnst->consttypmod = consttypmod;
321  cnst->constcollid = constcollid;
322  cnst->constlen = constlen;
323  cnst->constvalue = constvalue;
324  cnst->constisnull = constisnull;
325  cnst->constbyval = constbyval;
326  cnst->location = -1; /* "unknown" */
327 
328  return cnst;
329 }
#define PG_DETOAST_DATUM(datum)
Definition: fmgr.h:240
static Datum PointerGetDatum(const void *X)
Definition: postgres.h:322
Oid consttype
Definition: primnodes.h:290

References Const::consttype, makeNode, PG_DETOAST_DATUM, and PointerGetDatum().

Referenced by add_security_quals(), add_with_check_options(), array_subscript_transform(), build_coercion_expression(), build_minmax_path(), check_sql_fn_retval(), create_final_distinct_paths(), eval_const_expressions_mutator(), evaluate_expr(), expand_insert_targetlist(), generate_setop_tlist(), get_qual_for_hash(), get_qual_for_list(), get_typdefault(), make_const(), makeBoolConst(), makeNullConst(), match_clause_to_partition_key(), match_network_subset(), pattern_fixed_prefix(), RelationGetDummyIndexExpressions(), rewriteSearchAndCycle(), rewriteTargetListIU(), rewriteValuesRTE(), scalararraysel(), set_fn_opclass_options(), string_to_bytea_const(), and string_to_const().

◆ makeDefElem()

DefElem* makeDefElem ( char *  name,
Node arg,
int  location 
)

Definition at line 548 of file makefuncs.c.

549 {
551 
552  res->defnamespace = NULL;
553  res->defname = name;
554  res->arg = arg;
555  res->defaction = DEFELEM_UNSPEC;
556  res->location = location;
557 
558  return res;
559 }
@ DEFELEM_UNSPEC
Definition: parsenodes.h:800
void * arg

References arg, DEFELEM_UNSPEC, makeNode, name, and res.

Referenced by buildDefItem(), copy_table(), DefineView(), fileGetForeignPaths(), generateSerialExtraStmts(), get_file_fdw_attribute_options(), pg_logical_slot_get_changes_guts(), sequence_options(), transformAlterTableStmt(), and untransformRelOptions().

◆ makeDefElemExtended()

DefElem* makeDefElemExtended ( char *  nameSpace,
char *  name,
Node arg,
DefElemAction  defaction,
int  location 
)

Definition at line 566 of file makefuncs.c.

568 {
570 
571  res->defnamespace = nameSpace;
572  res->defname = name;
573  res->arg = arg;
574  res->defaction = defaction;
575  res->location = location;
576 
577  return res;
578 }

References arg, makeNode, name, and res.

◆ makeFromExpr()

◆ makeFuncCall()

FuncCall* makeFuncCall ( List name,
List args,
CoercionForm  funcformat,
int  location 
)

Definition at line 587 of file makefuncs.c.

588 {
589  FuncCall *n = makeNode(FuncCall);
590 
591  n->funcname = name;
592  n->args = args;
593  n->agg_order = NIL;
594  n->agg_filter = NULL;
595  n->over = NULL;
596  n->agg_within_group = false;
597  n->agg_star = false;
598  n->agg_distinct = false;
599  n->func_variadic = false;
600  n->funcformat = funcformat;
601  n->location = location;
602  return n;
603 }
bool agg_within_group
Definition: parsenodes.h:429
int location
Definition: parsenodes.h:434
CoercionForm funcformat
Definition: parsenodes.h:433
Node * agg_filter
Definition: parsenodes.h:427
List * agg_order
Definition: parsenodes.h:426
List * funcname
Definition: parsenodes.h:424
List * args
Definition: parsenodes.h:425
bool agg_star
Definition: parsenodes.h:430
bool agg_distinct
Definition: parsenodes.h:431
bool func_variadic
Definition: parsenodes.h:432
struct WindowDef * over
Definition: parsenodes.h:428

References FuncCall::agg_distinct, FuncCall::agg_filter, FuncCall::agg_order, FuncCall::agg_star, FuncCall::agg_within_group, generate_unaccent_rules::args, FuncCall::args, FuncCall::func_variadic, FuncCall::funcformat, FuncCall::funcname, FuncCall::location, makeNode, name, NIL, and FuncCall::over.

Referenced by test_rls_hooks_permissive(), test_rls_hooks_restrictive(), transformColumnDefinition(), and transformRangeFunction().

◆ makeFuncExpr()

FuncExpr* makeFuncExpr ( Oid  funcid,
Oid  rettype,
List args,
Oid  funccollid,
Oid  inputcollid,
CoercionForm  fformat 
)

Definition at line 521 of file makefuncs.c.

523 {
524  FuncExpr *funcexpr;
525 
526  funcexpr = makeNode(FuncExpr);
527  funcexpr->funcid = funcid;
528  funcexpr->funcresulttype = rettype;
529  funcexpr->funcretset = false; /* only allowed case here */
530  funcexpr->funcvariadic = false; /* only allowed case here */
531  funcexpr->funcformat = fformat;
532  funcexpr->funccollid = funccollid;
533  funcexpr->inputcollid = inputcollid;
534  funcexpr->args = args;
535  funcexpr->location = -1;
536 
537  return funcexpr;
538 }
Oid funcid
Definition: primnodes.h:677
List * args
Definition: primnodes.h:695
int location
Definition: primnodes.h:697

References generate_unaccent_rules::args, FuncExpr::args, FuncExpr::funcid, FuncExpr::location, and makeNode.

Referenced by build_aggregate_deserialfn_expr(), build_aggregate_finalfn_expr(), build_aggregate_serialfn_expr(), build_aggregate_transfn_expr(), build_coercion_expression(), get_qual_for_hash(), make_path_cat_expr(), and rewriteSearchAndCycle().

◆ makeGroupingSet()

GroupingSet* makeGroupingSet ( GroupingSetKind  kind,
List content,
int  location 
)

Definition at line 804 of file makefuncs.c.

805 {
807 
808  n->kind = kind;
809  n->content = content;
810  n->location = location;
811  return n;
812 }
List * content
Definition: parsenodes.h:1464

References GroupingSet::content, GroupingSet::location, and makeNode.

Referenced by flatten_grouping_sets(), transformGroupClause(), and transformGroupingSet().

◆ makeIndexInfo()

IndexInfo* makeIndexInfo ( int  numattrs,
int  numkeyattrs,
Oid  amoid,
List expressions,
List predicates,
bool  unique,
bool  nulls_not_distinct,
bool  isready,
bool  concurrent,
bool  summarizing 
)

Definition at line 745 of file makefuncs.c.

748 {
750 
751  n->ii_NumIndexAttrs = numattrs;
752  n->ii_NumIndexKeyAttrs = numkeyattrs;
753  Assert(n->ii_NumIndexKeyAttrs != 0);
755  n->ii_Unique = unique;
756  n->ii_NullsNotDistinct = nulls_not_distinct;
757  n->ii_ReadyForInserts = isready;
758  n->ii_CheckedUnchanged = false;
759  n->ii_IndexUnchanged = false;
760  n->ii_Concurrent = concurrent;
761  n->ii_Summarizing = summarizing;
762 
763  /* summarizing indexes cannot contain non-key attributes */
764  Assert(!summarizing || (numkeyattrs == numattrs));
765 
766  /* expressions */
767  n->ii_Expressions = expressions;
769 
770  /* predicates */
771  n->ii_Predicate = predicates;
772  n->ii_PredicateState = NULL;
773 
774  /* exclusion constraints */
775  n->ii_ExclusionOps = NULL;
776  n->ii_ExclusionProcs = NULL;
777  n->ii_ExclusionStrats = NULL;
778 
779  /* opclass options */
780  n->ii_OpclassOptions = NULL;
781 
782  /* speculative inserts */
783  n->ii_UniqueOps = NULL;
784  n->ii_UniqueProcs = NULL;
785  n->ii_UniqueStrats = NULL;
786 
787  /* initialize index-build state to default */
788  n->ii_BrokenHotChain = false;
789  n->ii_ParallelWorkers = 0;
790 
791  /* set up for possible use by index AM */
792  n->ii_Am = amoid;
793  n->ii_AmCache = NULL;
795 
796  return n;
797 }
MemoryContext CurrentMemoryContext
Definition: mcxt.c:135
bool ii_Unique
Definition: execnodes.h:191
uint16 * ii_ExclusionStrats
Definition: execnodes.h:186
bool ii_BrokenHotChain
Definition: execnodes.h:197
int ii_NumIndexAttrs
Definition: execnodes.h:177
void * ii_AmCache
Definition: execnodes.h:201
bool ii_CheckedUnchanged
Definition: execnodes.h:194
Datum * ii_OpclassOptions
Definition: execnodes.h:190
Oid * ii_UniqueOps
Definition: execnodes.h:187
ExprState * ii_PredicateState
Definition: execnodes.h:183
Oid * ii_ExclusionOps
Definition: execnodes.h:184
bool ii_NullsNotDistinct
Definition: execnodes.h:192
int ii_ParallelWorkers
Definition: execnodes.h:199
bool ii_Concurrent
Definition: execnodes.h:196
uint16 * ii_UniqueStrats
Definition: execnodes.h:189
int ii_NumIndexKeyAttrs
Definition: execnodes.h:178
List * ii_ExpressionsState
Definition: execnodes.h:181
List * ii_Expressions
Definition: execnodes.h:180
bool ii_IndexUnchanged
Definition: execnodes.h:195
Oid * ii_ExclusionProcs
Definition: execnodes.h:185
Oid ii_Am
Definition: execnodes.h:200
bool ii_Summarizing
Definition: execnodes.h:198
Oid * ii_UniqueProcs
Definition: execnodes.h:188
MemoryContext ii_Context
Definition: execnodes.h:202
bool ii_ReadyForInserts
Definition: execnodes.h:193
List * ii_Predicate
Definition: execnodes.h:182

References Assert(), CurrentMemoryContext, IndexInfo::ii_Am, IndexInfo::ii_AmCache, IndexInfo::ii_BrokenHotChain, IndexInfo::ii_CheckedUnchanged, IndexInfo::ii_Concurrent, IndexInfo::ii_Context, IndexInfo::ii_ExclusionOps, IndexInfo::ii_ExclusionProcs, IndexInfo::ii_ExclusionStrats, IndexInfo::ii_Expressions, IndexInfo::ii_ExpressionsState, IndexInfo::ii_IndexUnchanged, IndexInfo::ii_NullsNotDistinct, IndexInfo::ii_NumIndexAttrs, IndexInfo::ii_NumIndexKeyAttrs, IndexInfo::ii_OpclassOptions, IndexInfo::ii_ParallelWorkers, IndexInfo::ii_Predicate, IndexInfo::ii_PredicateState, IndexInfo::ii_ReadyForInserts, IndexInfo::ii_Summarizing, IndexInfo::ii_Unique, IndexInfo::ii_UniqueOps, IndexInfo::ii_UniqueProcs, IndexInfo::ii_UniqueStrats, makeNode, and NIL.

Referenced by BuildDummyIndexInfo(), BuildIndexInfo(), CheckIndexCompatible(), DefineIndex(), and index_concurrently_create_copy().

◆ makeNullConst()

Const* makeNullConst ( Oid  consttype,
int32  consttypmod,
Oid  constcollid 
)

Definition at line 339 of file makefuncs.c.

340 {
341  int16 typLen;
342  bool typByVal;
343 
344  get_typlenbyval(consttype, &typLen, &typByVal);
345  return makeConst(consttype,
346  consttypmod,
347  constcollid,
348  (int) typLen,
349  (Datum) 0,
350  true,
351  typByVal);
352 }
signed short int16
Definition: c.h:477
void get_typlenbyval(Oid typid, int16 *typlen, bool *typbyval)
Definition: lsyscache.c:2209
uintptr_t Datum
Definition: postgres.h:64

References get_typlenbyval(), and makeConst().

Referenced by adjust_appendrel_attrs_mutator(), ATExecAddColumn(), build_subplan(), BuildOnConflictExcludedTargetlist(), coerce_record_to_complex(), eval_const_expressions_mutator(), evaluate_function(), ExecInitExprRec(), expandRTE(), expandTupleDesc(), remove_unused_subquery_outputs(), ReplaceVarsFromTargetList_callback(), rewriteValuesRTE(), rewriteValuesRTEToNulls(), set_plan_refs(), and transformAssignedExpr().

◆ makeRangeVar()

RangeVar* makeRangeVar ( char *  schemaname,
char *  relname,
int  location 
)

◆ makeRelabelType()

RelabelType* makeRelabelType ( Expr arg,
Oid  rtype,
int32  rtypmod,
Oid  rcollid,
CoercionForm  rformat 
)

Definition at line 404 of file makefuncs.c.

406 {
408 
409  r->arg = arg;
410  r->resulttype = rtype;
411  r->resulttypmod = rtypmod;
412  r->resultcollid = rcollid;
413  r->relabelformat = rformat;
414  r->location = -1;
415 
416  return r;
417 }
Oid resulttype
Definition: primnodes.h:1112
Expr * arg
Definition: primnodes.h:1111

References arg, RelabelType::arg, RelabelType::location, makeNode, and RelabelType::resulttype.

Referenced by assign_hypothetical_collations(), buildMergedJoinVar(), coerce_type(), and make_partition_op_expr().

◆ makeSimpleA_Expr()

A_Expr* makeSimpleA_Expr ( A_Expr_Kind  kind,
char *  name,
Node lexpr,
Node rexpr,
int  location 
)

Definition at line 48 of file makefuncs.c.

50 {
51  A_Expr *a = makeNode(A_Expr);
52 
53  a->kind = kind;
54  a->name = list_make1(makeString((char *) name));
55  a->lexpr = lexpr;
56  a->rexpr = rexpr;
57  a->location = location;
58  return a;
59 }
String * makeString(char *str)
Definition: value.c:63

References a, list_make1, makeNode, makeString(), and name.

Referenced by test_rls_hooks_permissive(), test_rls_hooks_restrictive(), transformAExprBetween(), transformCaseExpr(), and transformJoinUsingClause().

◆ makeTargetEntry()

TargetEntry* makeTargetEntry ( Expr expr,
AttrNumber  resno,
char *  resname,
bool  resjunk 
)

Definition at line 240 of file makefuncs.c.

244 {
246 
247  tle->expr = expr;
248  tle->resno = resno;
249  tle->resname = resname;
250 
251  /*
252  * We always set these fields to 0. If the caller wants to change them he
253  * must do so explicitly. Few callers do that, so omitting these
254  * arguments reduces the chance of error.
255  */
256  tle->ressortgroupref = 0;
257  tle->resorigtbl = InvalidOid;
258  tle->resorigcol = 0;
259 
260  tle->resjunk = resjunk;
261 
262  return tle;
263 }
Expr * expr
Definition: primnodes.h:1731
AttrNumber resno
Definition: primnodes.h:1733
Index ressortgroupref
Definition: primnodes.h:1737

References TargetEntry::expr, InvalidOid, makeNode, TargetEntry::resno, and TargetEntry::ressortgroupref.

Referenced by add_row_identity_var(), add_to_flat_tlist(), ApplyRetrieveRule(), build_index_tlist(), build_minmax_path(), build_path_tlist(), build_physical_tlist(), build_remote_returning(), BuildOnConflictExcludedTargetlist(), check_sql_fn_retval(), coerce_fn_result_column(), convert_combining_aggrefs(), convert_EXISTS_to_ANY(), create_unique_plan(), determineRecursiveColTypes(), ExecInitSubPlan(), expand_inherited_rtentry(), expand_insert_targetlist(), expandNSItemAttrs(), ExpandRowReference(), foreign_grouping_ok(), generate_append_tlist(), generate_setop_tlist(), make_tlist_from_pathtarget(), prepare_sort_from_pathkeys(), preprocess_targetlist(), pull_up_constant_function(), pull_up_simple_values(), rebuild_fdw_scan_tlist(), rewriteSearchAndCycle(), rewriteTargetListIU(), transformAggregateCall(), transformMergeStmt(), transformMultiAssignRef(), transformReturnStmt(), transformSetOperationStmt(), transformSetOperationTree(), and transformTargetEntry().

◆ makeTypeName()

TypeName* makeTypeName ( char *  typnam)

Definition at line 446 of file makefuncs.c.

447 {
449 }
TypeName * makeTypeNameFromNameList(List *names)
Definition: makefuncs.c:458

References list_make1, makeString(), and makeTypeNameFromNameList().

Referenced by plpgsql_parse_wordrowtype(), and plpgsql_parse_wordtype().

◆ makeTypeNameFromNameList()

◆ makeTypeNameFromOid()

TypeName* makeTypeNameFromOid ( Oid  typeOid,
int32  typmod 
)

Definition at line 474 of file makefuncs.c.

475 {
476  TypeName *n = makeNode(TypeName);
477 
478  n->typeOid = typeOid;
479  n->typemod = typmod;
480  n->location = -1;
481  return n;
482 }
Oid typeOid
Definition: parsenodes.h:267

References TypeName::location, makeNode, TypeName::typemod, and TypeName::typeOid.

Referenced by DefineSequence(), generateSerialExtraStmts(), makeColumnDef(), MergeAttributes(), transformAlterTableStmt(), transformOfType(), and transformTableLikeClause().

◆ makeVacuumRelation()

VacuumRelation* makeVacuumRelation ( RangeVar relation,
Oid  oid,
List va_cols 
)

Definition at line 819 of file makefuncs.c.

820 {
822 
823  v->relation = relation;
824  v->oid = oid;
825  v->va_cols = va_cols;
826  return v;
827 }
RangeVar * relation
Definition: parsenodes.h:3576

References makeNode, VacuumRelation::oid, VacuumRelation::relation, and VacuumRelation::va_cols.

Referenced by autovacuum_do_vac_analyze(), expand_vacuum_rel(), and get_all_vacuum_rels().

◆ makeVar()

Var* makeVar ( int  varno,
AttrNumber  varattno,
Oid  vartype,
int32  vartypmod,
Oid  varcollid,
Index  varlevelsup 
)

Definition at line 66 of file makefuncs.c.

72 {
73  Var *var = makeNode(Var);
74 
75  var->varno = varno;
76  var->varattno = varattno;
77  var->vartype = vartype;
78  var->vartypmod = vartypmod;
79  var->varcollid = varcollid;
80  var->varlevelsup = varlevelsup;
81 
82  /*
83  * Only a few callers need to make Var nodes with non-null varnullingrels,
84  * or with varnosyn/varattnosyn different from varno/varattno. We don't
85  * provide separate arguments for them, but just initialize them to NULL
86  * and the given varno/varattno. This reduces code clutter and chance of
87  * error for most callers.
88  */
89  var->varnullingrels = NULL;
90  var->varnosyn = (Index) varno;
91  var->varattnosyn = varattno;
92 
93  /* Likewise, we just set location to "unknown" here */
94  var->location = -1;
95 
96  return var;
97 }
unsigned int Index
Definition: c.h:598
Definition: primnodes.h:226
AttrNumber varattno
Definition: primnodes.h:238
int varno
Definition: primnodes.h:233
Index varlevelsup
Definition: primnodes.h:258
int location
Definition: primnodes.h:271

References Var::location, makeNode, Var::varattno, Var::varlevelsup, and Var::varno.

Referenced by add_row_identity_columns(), ATPrepAlterColumnType(), build_index_tlist(), build_physical_tlist(), build_remote_returning(), BuildOnConflictExcludedTargetlist(), buildVarFromNSColumn(), eval_const_expressions_mutator(), expand_inherited_rtentry(), expand_single_inheritance_child(), expandNSItemVars(), expandRTE(), expandTupleDesc(), fix_indexqual_operand(), generate_append_tlist(), generate_setop_tlist(), get_qual_for_hash(), get_qual_for_list(), get_range_key_properties(), get_range_nulltest(), get_relation_constraints(), make_inh_translation_list(), make_path_cat_expr(), make_path_rowexpr(), makeVarFromTargetEntry(), makeWholeRowVar(), NotNullImpliedByRelConstraints(), PartConstraintImpliedByRelConstraint(), postgresAddForeignUpdateTargets(), preprocess_targetlist(), rewriteSearchAndCycle(), scanNSItemForColumn(), set_baserel_partition_key_exprs(), set_dummy_tlist_references(), transformAssignedExpr(), and transformSetOperationStmt().

◆ makeVarFromTargetEntry()

Var* makeVarFromTargetEntry ( int  varno,
TargetEntry tle 
)

Definition at line 105 of file makefuncs.c.

107 {
108  return makeVar(varno,
109  tle->resno,
110  exprType((Node *) tle->expr),
111  exprTypmod((Node *) tle->expr),
112  exprCollation((Node *) tle->expr),
113  0);
114 }
Var * makeVar(int varno, AttrNumber varattno, Oid vartype, int32 vartypmod, Oid varcollid, Index varlevelsup)
Definition: makefuncs.c:66
Oid exprType(const Node *expr)
Definition: nodeFuncs.c:43
int32 exprTypmod(const Node *expr)
Definition: nodeFuncs.c:266
Oid exprCollation(const Node *expr)
Definition: nodeFuncs.c:764

References TargetEntry::expr, exprCollation(), exprType(), exprTypmod(), makeVar(), and TargetEntry::resno.

Referenced by build_physical_tlist(), coerce_fn_result_column(), generate_subquery_vars(), make_setop_translation_list(), search_indexed_tlist_for_non_var(), search_indexed_tlist_for_phv(), search_indexed_tlist_for_sortgroupref(), and transformInsertStmt().

◆ makeWholeRowVar()

Var* makeWholeRowVar ( RangeTblEntry rte,
int  varno,
Index  varlevelsup,
bool  allowScalar 
)

Definition at line 135 of file makefuncs.c.

139 {
140  Var *result;
141  Oid toid;
142  Node *fexpr;
143 
144  switch (rte->rtekind)
145  {
146  case RTE_RELATION:
147  /* relation: the rowtype is a named composite type */
148  toid = get_rel_type_id(rte->relid);
149  if (!OidIsValid(toid))
150  ereport(ERROR,
151  (errcode(ERRCODE_WRONG_OBJECT_TYPE),
152  errmsg("relation \"%s\" does not have a composite type",
153  get_rel_name(rte->relid))));
154  result = makeVar(varno,
156  toid,
157  -1,
158  InvalidOid,
159  varlevelsup);
160  break;
161 
162  case RTE_FUNCTION:
163 
164  /*
165  * If there's more than one function, or ordinality is requested,
166  * force a RECORD result, since there's certainly more than one
167  * column involved and it can't be a known named type.
168  */
169  if (rte->funcordinality || list_length(rte->functions) != 1)
170  {
171  /* always produces an anonymous RECORD result */
172  result = makeVar(varno,
174  RECORDOID,
175  -1,
176  InvalidOid,
177  varlevelsup);
178  break;
179  }
180 
181  fexpr = ((RangeTblFunction *) linitial(rte->functions))->funcexpr;
182  toid = exprType(fexpr);
183  if (type_is_rowtype(toid))
184  {
185  /* func returns composite; same as relation case */
186  result = makeVar(varno,
188  toid,
189  -1,
190  InvalidOid,
191  varlevelsup);
192  }
193  else if (allowScalar)
194  {
195  /* func returns scalar; just return its output as-is */
196  result = makeVar(varno,
197  1,
198  toid,
199  -1,
200  exprCollation(fexpr),
201  varlevelsup);
202  }
203  else
204  {
205  /* func returns scalar, but we want a composite result */
206  result = makeVar(varno,
208  RECORDOID,
209  -1,
210  InvalidOid,
211  varlevelsup);
212  }
213  break;
214 
215  default:
216 
217  /*
218  * RTE is a join, subselect, tablefunc, or VALUES. We represent
219  * this as a whole-row Var of RECORD type. (Note that in most
220  * cases the Var will be expanded to a RowExpr during planning,
221  * but that is not our concern here.)
222  */
223  result = makeVar(varno,
225  RECORDOID,
226  -1,
227  InvalidOid,
228  varlevelsup);
229  break;
230  }
231 
232  return result;
233 }
#define InvalidAttrNumber
Definition: attnum.h:23
#define OidIsValid(objectId)
Definition: c.h:759
int errcode(int sqlerrcode)
Definition: elog.c:858
int errmsg(const char *fmt,...)
Definition: elog.c:1069
#define ERROR
Definition: elog.h:39
#define ereport(elevel,...)
Definition: elog.h:149
bool type_is_rowtype(Oid typid)
Definition: lsyscache.c:2613
Oid get_rel_type_id(Oid relid)
Definition: lsyscache.c:1961
char * get_rel_name(Oid relid)
Definition: lsyscache.c:1910
@ RTE_FUNCTION
Definition: parsenodes.h:1017
@ RTE_RELATION
Definition: parsenodes.h:1014
unsigned int Oid
Definition: postgres_ext.h:31
bool funcordinality
Definition: parsenodes.h:1149
List * functions
Definition: parsenodes.h:1148
RTEKind rtekind
Definition: parsenodes.h:1033

References ereport, errcode(), errmsg(), ERROR, exprCollation(), exprType(), RangeTblEntry::funcordinality, RangeTblEntry::functions, get_rel_name(), get_rel_type_id(), InvalidAttrNumber, InvalidOid, linitial, list_length(), makeVar(), OidIsValid, RangeTblEntry::relid, RTE_FUNCTION, RTE_RELATION, RangeTblEntry::rtekind, and type_is_rowtype().

Referenced by ApplyRetrieveRule(), expand_inherited_rtentry(), preprocess_targetlist(), and transformWholeRowRef().