PostgreSQL Source Code git master
|
#include "nodes/nodes.h"
Go to the source code of this file.
Data Structures | |
union | ListCell |
struct | List |
struct | ForEachState |
struct | ForBothState |
struct | ForBothCellState |
struct | ForThreeState |
struct | ForFourState |
struct | ForFiveState |
Macros | |
#define | NIL ((List *) NULL) |
#define | lfirst(lc) ((lc)->ptr_value) |
#define | lfirst_int(lc) ((lc)->int_value) |
#define | lfirst_oid(lc) ((lc)->oid_value) |
#define | lfirst_xid(lc) ((lc)->xid_value) |
#define | lfirst_node(type, lc) castNode(type, lfirst(lc)) |
#define | linitial(l) lfirst(list_nth_cell(l, 0)) |
#define | linitial_int(l) lfirst_int(list_nth_cell(l, 0)) |
#define | linitial_oid(l) lfirst_oid(list_nth_cell(l, 0)) |
#define | linitial_node(type, l) castNode(type, linitial(l)) |
#define | lsecond(l) lfirst(list_nth_cell(l, 1)) |
#define | lsecond_int(l) lfirst_int(list_nth_cell(l, 1)) |
#define | lsecond_oid(l) lfirst_oid(list_nth_cell(l, 1)) |
#define | lsecond_node(type, l) castNode(type, lsecond(l)) |
#define | lthird(l) lfirst(list_nth_cell(l, 2)) |
#define | lthird_int(l) lfirst_int(list_nth_cell(l, 2)) |
#define | lthird_oid(l) lfirst_oid(list_nth_cell(l, 2)) |
#define | lthird_node(type, l) castNode(type, lthird(l)) |
#define | lfourth(l) lfirst(list_nth_cell(l, 3)) |
#define | lfourth_int(l) lfirst_int(list_nth_cell(l, 3)) |
#define | lfourth_oid(l) lfirst_oid(list_nth_cell(l, 3)) |
#define | lfourth_node(type, l) castNode(type, lfourth(l)) |
#define | llast(l) lfirst(list_last_cell(l)) |
#define | llast_int(l) lfirst_int(list_last_cell(l)) |
#define | llast_oid(l) lfirst_oid(list_last_cell(l)) |
#define | llast_xid(l) lfirst_xid(list_last_cell(l)) |
#define | llast_node(type, l) castNode(type, llast(l)) |
#define | list_make_ptr_cell(v) ((ListCell) {.ptr_value = (v)}) |
#define | list_make_int_cell(v) ((ListCell) {.int_value = (v)}) |
#define | list_make_oid_cell(v) ((ListCell) {.oid_value = (v)}) |
#define | list_make_xid_cell(v) ((ListCell) {.xid_value = (v)}) |
#define | list_make1(x1) list_make1_impl(T_List, list_make_ptr_cell(x1)) |
#define | list_make2(x1, x2) list_make2_impl(T_List, list_make_ptr_cell(x1), list_make_ptr_cell(x2)) |
#define | list_make3(x1, x2, x3) |
#define | list_make4(x1, x2, x3, x4) |
#define | list_make5(x1, x2, x3, x4, x5) |
#define | list_make1_int(x1) list_make1_impl(T_IntList, list_make_int_cell(x1)) |
#define | list_make2_int(x1, x2) list_make2_impl(T_IntList, list_make_int_cell(x1), list_make_int_cell(x2)) |
#define | list_make3_int(x1, x2, x3) |
#define | list_make4_int(x1, x2, x3, x4) |
#define | list_make5_int(x1, x2, x3, x4, x5) |
#define | list_make1_oid(x1) list_make1_impl(T_OidList, list_make_oid_cell(x1)) |
#define | list_make2_oid(x1, x2) list_make2_impl(T_OidList, list_make_oid_cell(x1), list_make_oid_cell(x2)) |
#define | list_make3_oid(x1, x2, x3) |
#define | list_make4_oid(x1, x2, x3, x4) |
#define | list_make5_oid(x1, x2, x3, x4, x5) |
#define | list_make1_xid(x1) list_make1_impl(T_XidList, list_make_xid_cell(x1)) |
#define | list_make2_xid(x1, x2) list_make2_impl(T_XidList, list_make_xid_cell(x1), list_make_xid_cell(x2)) |
#define | list_make3_xid(x1, x2, x3) |
#define | list_make4_xid(x1, x2, x3, x4) |
#define | list_make5_xid(x1, x2, x3, x4, x5) |
#define | list_nth_node(type, list, n) castNode(type, list_nth(list, n)) |
#define | foreach(cell, lst) |
#define | foreach_delete_current(lst, var_or_cell) ((List *) (var_or_cell##__state.l = list_delete_nth_cell(lst, var_or_cell##__state.i--))) |
#define | foreach_current_index(var_or_cell) (var_or_cell##__state.i) |
#define | for_each_from(cell, lst, N) |
#define | for_each_cell(cell, lst, initcell) |
#define | foreach_ptr(type, var, lst) foreach_internal(type, *, var, lst, lfirst) |
#define | foreach_int(var, lst) foreach_internal(int, , var, lst, lfirst_int) |
#define | foreach_oid(var, lst) foreach_internal(Oid, , var, lst, lfirst_oid) |
#define | foreach_xid(var, lst) foreach_internal(TransactionId, , var, lst, lfirst_xid) |
#define | foreach_internal(type, pointer, var, lst, func) |
#define | foreach_node(type, var, lst) |
#define | forboth(cell1, list1, cell2, list2) |
#define | multi_for_advance_cell(cell, state, l, i) |
#define | for_both_cell(cell1, list1, initcell1, cell2, list2, initcell2) |
#define | forthree(cell1, list1, cell2, list2, cell3, list3) |
#define | forfour(cell1, list1, cell2, list2, cell3, list3, cell4, list4) |
#define | forfive(cell1, list1, cell2, list2, cell3, list3, cell4, list4, cell5, list5) |
Typedefs | |
typedef union ListCell | ListCell |
typedef struct List | List |
typedef struct ForEachState | ForEachState |
typedef struct ForBothState | ForBothState |
typedef struct ForBothCellState | ForBothCellState |
typedef struct ForThreeState | ForThreeState |
typedef struct ForFourState | ForFourState |
typedef struct ForFiveState | ForFiveState |
typedef int(* | list_sort_comparator) (const ListCell *a, const ListCell *b) |
#define for_both_cell | ( | cell1, | |
list1, | |||
initcell1, | |||
cell2, | |||
list2, | |||
initcell2 | |||
) |
#define for_each_cell | ( | cell, | |
lst, | |||
initcell | |||
) |
#define for_each_from | ( | cell, | |
lst, | |||
N | |||
) |
#define forboth | ( | cell1, | |
list1, | |||
cell2, | |||
list2 | |||
) |
#define foreach | ( | cell, | |
lst | |||
) |
#define foreach_current_index | ( | var_or_cell | ) | (var_or_cell##__state.i) |
#define foreach_delete_current | ( | lst, | |
var_or_cell | |||
) | ((List *) (var_or_cell##__state.l = list_delete_nth_cell(lst, var_or_cell##__state.i--))) |
#define foreach_int | ( | var, | |
lst | |||
) | foreach_internal(int, , var, lst, lfirst_int) |
#define foreach_internal | ( | type, | |
pointer, | |||
var, | |||
lst, | |||
func | |||
) |
#define foreach_node | ( | type, | |
var, | |||
lst | |||
) |
#define foreach_oid | ( | var, | |
lst | |||
) | foreach_internal(Oid, , var, lst, lfirst_oid) |
#define foreach_ptr | ( | type, | |
var, | |||
lst | |||
) | foreach_internal(type, *, var, lst, lfirst) |
#define foreach_xid | ( | var, | |
lst | |||
) | foreach_internal(TransactionId, , var, lst, lfirst_xid) |
#define forfive | ( | cell1, | |
list1, | |||
cell2, | |||
list2, | |||
cell3, | |||
list3, | |||
cell4, | |||
list4, | |||
cell5, | |||
list5 | |||
) |
#define forfour | ( | cell1, | |
list1, | |||
cell2, | |||
list2, | |||
cell3, | |||
list3, | |||
cell4, | |||
list4 | |||
) |
#define forthree | ( | cell1, | |
list1, | |||
cell2, | |||
list2, | |||
cell3, | |||
list3 | |||
) |
#define lfourth | ( | l | ) | lfirst(list_nth_cell(l, 3)) |
#define lfourth_int | ( | l | ) | lfirst_int(list_nth_cell(l, 3)) |
#define lfourth_oid | ( | l | ) | lfirst_oid(list_nth_cell(l, 3)) |
#define linitial | ( | l | ) | lfirst(list_nth_cell(l, 0)) |
#define linitial_int | ( | l | ) | lfirst_int(list_nth_cell(l, 0)) |
#define linitial_oid | ( | l | ) | lfirst_oid(list_nth_cell(l, 0)) |
#define list_make1 | ( | x1 | ) | list_make1_impl(T_List, list_make_ptr_cell(x1)) |
#define list_make1_int | ( | x1 | ) | list_make1_impl(T_IntList, list_make_int_cell(x1)) |
#define list_make1_oid | ( | x1 | ) | list_make1_impl(T_OidList, list_make_oid_cell(x1)) |
#define list_make1_xid | ( | x1 | ) | list_make1_impl(T_XidList, list_make_xid_cell(x1)) |
#define list_make2 | ( | x1, | |
x2 | |||
) | list_make2_impl(T_List, list_make_ptr_cell(x1), list_make_ptr_cell(x2)) |
#define list_make2_int | ( | x1, | |
x2 | |||
) | list_make2_impl(T_IntList, list_make_int_cell(x1), list_make_int_cell(x2)) |
#define list_make2_oid | ( | x1, | |
x2 | |||
) | list_make2_impl(T_OidList, list_make_oid_cell(x1), list_make_oid_cell(x2)) |
#define list_make2_xid | ( | x1, | |
x2 | |||
) | list_make2_impl(T_XidList, list_make_xid_cell(x1), list_make_xid_cell(x2)) |
#define list_make3 | ( | x1, | |
x2, | |||
x3 | |||
) |
#define list_make3_int | ( | x1, | |
x2, | |||
x3 | |||
) |
#define list_make3_oid | ( | x1, | |
x2, | |||
x3 | |||
) |
#define list_make3_xid | ( | x1, | |
x2, | |||
x3 | |||
) |
#define list_make4 | ( | x1, | |
x2, | |||
x3, | |||
x4 | |||
) |
#define list_make4_int | ( | x1, | |
x2, | |||
x3, | |||
x4 | |||
) |
#define list_make4_oid | ( | x1, | |
x2, | |||
x3, | |||
x4 | |||
) |
#define list_make4_xid | ( | x1, | |
x2, | |||
x3, | |||
x4 | |||
) |
#define list_make5 | ( | x1, | |
x2, | |||
x3, | |||
x4, | |||
x5 | |||
) |
#define list_make5_int | ( | x1, | |
x2, | |||
x3, | |||
x4, | |||
x5 | |||
) |
#define list_make5_oid | ( | x1, | |
x2, | |||
x3, | |||
x4, | |||
x5 | |||
) |
#define list_make5_xid | ( | x1, | |
x2, | |||
x3, | |||
x4, | |||
x5 | |||
) |
#define list_make_int_cell | ( | v | ) | ((ListCell) {.int_value = (v)}) |
#define list_make_oid_cell | ( | v | ) | ((ListCell) {.oid_value = (v)}) |
#define list_make_ptr_cell | ( | v | ) | ((ListCell) {.ptr_value = (v)}) |
#define list_make_xid_cell | ( | v | ) | ((ListCell) {.xid_value = (v)}) |
#define llast | ( | l | ) | lfirst(list_last_cell(l)) |
#define llast_int | ( | l | ) | lfirst_int(list_last_cell(l)) |
#define llast_oid | ( | l | ) | lfirst_oid(list_last_cell(l)) |
#define llast_xid | ( | l | ) | lfirst_xid(list_last_cell(l)) |
#define lsecond | ( | l | ) | lfirst(list_nth_cell(l, 1)) |
#define lsecond_int | ( | l | ) | lfirst_int(list_nth_cell(l, 1)) |
#define lsecond_oid | ( | l | ) | lfirst_oid(list_nth_cell(l, 1)) |
#define lthird | ( | l | ) | lfirst(list_nth_cell(l, 2)) |
#define lthird_int | ( | l | ) | lfirst_int(list_nth_cell(l, 2)) |
#define lthird_oid | ( | l | ) | lfirst_oid(list_nth_cell(l, 2)) |
typedef struct ForBothCellState ForBothCellState |
typedef struct ForBothState ForBothState |
typedef struct ForEachState ForEachState |
typedef struct ForFiveState ForFiveState |
typedef struct ForFourState ForFourState |
typedef struct ForThreeState ForThreeState |
|
inlinestatic |
Definition at line 549 of file pg_list.h.
References list_cell_number(), and list_length().
|
inlinestatic |
Definition at line 447 of file pg_list.h.
References list_cell_number(), and list_length().
|
inlinestatic |
pg_nodiscard List * lappend | ( | List * | list, |
void * | datum | ||
) |
Definition at line 339 of file list.c.
References Assert, check_list_invariants, IsPointerList, sort-test::list, llast, new_list(), new_tail_cell(), and NIL.
Referenced by _SPI_make_plan_non_temp(), _SPI_prepare_oneshot_plan(), _SPI_prepare_plan(), _SPI_save_plan(), accumulate_append_subpath(), AcquireRewriteLocks(), add_base_clause_to_rel(), add_column_to_pathtarget(), add_dummy_return(), add_eq_member(), add_join_clause_to_rels(), add_join_rel(), add_local_reloption(), add_merged_range_bounds(), add_outer_joins_to_relids(), add_part_relids(), add_paths_to_append_rel(), add_placeholders_to_base_rels(), add_placeholders_to_joinrel(), add_row_identity_var(), add_rte_to_flat_rtable(), add_security_quals(), add_to_flat_tlist(), add_unique_group_var(), add_vars_to_targetlist(), add_with_check_options(), addArc(), AddEventToPendingNotifies(), addFamilyMember(), addFkRecurseReferencing(), addKey(), addKeyToQueue(), addNSItemToQuery(), addRangeTableEntry(), addRangeTableEntryForCTE(), addRangeTableEntryForENR(), addRangeTableEntryForFunction(), addRangeTableEntryForGroup(), addRangeTableEntryForJoin(), addRangeTableEntryForRelation(), addRangeTableEntryForSubquery(), addRangeTableEntryForTableFunc(), addRangeTableEntryForValues(), AddRelationNewConstraints(), AddRelationNotNullConstraints(), addRTEPermissionInfo(), addTargetToGroupList(), addTargetToSortList(), AlterPublicationTables(), AlterTableMoveAll(), AlterTSDictionary(), analyzeCTE(), analyzeCTETargetList(), append_pathkeys(), apply_child_basequals(), apply_handle_truncate(), apply_scanjoin_target_to_paths(), applyLockingClause(), ApplyRetrieveRule(), array_subscript_transform(), assign_param_for_placeholdervar(), assign_param_for_var(), ATAddCheckNNConstraint(), ATExecAddColumn(), ATExecSetExpression(), ATExecValidateConstraint(), ATGetQueueEntry(), ATParseTransformCmd(), ATPostAlterTypeParse(), ATPrepAlterColumnType(), ATPrepCmd(), BaseBackupAddTarget(), btcostestimate(), build_aggregate_finalfn_expr(), build_aggregate_transfn_expr(), build_coercion_expression(), build_index_pathkeys(), build_index_paths(), build_index_tlist(), build_join_rel(), build_joinrel_tlist(), build_partition_pathkeys(), build_path_tlist(), build_physical_tlist(), build_remote_returning(), build_subplan(), BuildEventTriggerCache(), BuildOnConflictExcludedTargetlist(), buildRelationAliases(), cached_scansel(), calc_joinrel_size_estimate(), can_minmax_aggs(), check_index_predicates(), check_selective_binary_conversion(), check_sql_fn_retval(), check_tuple_attribute(), CheckDuplicateColumnOrPathNames(), checkInsertTargets(), checkSharedDependencies(), checkWellFormedRecursionWalker(), choose_bitmap_and(), ChooseIndexColumnNames(), classifyConditions(), clauselist_apply_dependencies(), CloneFkReferenced(), CloneFkReferencing(), CloneRowTriggersToPartition(), coerce_fn_result_column(), coerce_record_to_complex(), compute_common_attribute(), compute_semi_anti_join_factors(), compute_semijoin_info(), ComputeIndexAttrs(), ComputePartitionAttrs(), consider_groupingsets_paths(), consider_new_or_clause(), convert_ANY_sublink_to_join(), convert_EXISTS_to_ANY(), convert_subquery_pathkeys(), CopyMultiInsertInfoFlush(), CopyMultiInsertInfoSetupBuffer(), cost_incremental_sort(), create_append_plan(), create_bitmap_scan_plan(), create_bitmap_subplan(), create_ctas_nodata(), create_customscan_plan(), create_degenerate_grouping_paths(), create_edata_for_relation(), create_groupingsets_plan(), create_hashjoin_plan(), create_index_paths(), create_indexscan_plan(), create_join_clause(), create_merge_append_plan(), create_nestloop_path(), create_one_window_path(), create_partitionwise_grouping_paths(), create_tidrangescan_plan(), create_tidscan_plan(), create_unique_plan(), CreateStatistics(), database_to_xmlschema_internal(), deconstruct_distribute(), deconstruct_recurse(), DefineRelation(), DefineSequence(), DefineTSDictionary(), DefineView(), DefineVirtualRelation(), deparseFromExprForRel(), deparseParam(), deparseVar(), deserialize_deflist(), DetachPartitionFinalize(), determineRecursiveColTypes(), distribute_qual_to_rels(), distribute_row_identity_vars(), do_pg_backup_start(), DoCopy(), estimate_multivariate_ndistinct(), estimate_num_groups(), eval_const_expressions_mutator(), EvalPlanQualStart(), EventTriggerAlterTableEnd(), EventTriggerCollectAlterDefPrivs(), EventTriggerCollectAlterOpFam(), EventTriggerCollectAlterTableSubcmd(), EventTriggerCollectAlterTSConfig(), EventTriggerCollectCreateOpClass(), EventTriggerCollectGrant(), EventTriggerCollectSimpleCommand(), Exec_ListenCommit(), ExecAllocTableSlot(), ExecEvalXmlExpr(), ExecGetAncestorResultRels(), ExecGetTriggerResultRel(), ExecInitExprList(), ExecInitExprRec(), ExecInitInsertProjection(), ExecInitJsonExpr(), ExecInitLockRows(), ExecInitMerge(), ExecInitModifyTable(), ExecInitNode(), ExecInitPartitionInfo(), ExecInitResultRelation(), ExecInitSubPlan(), ExecInitSubPlanExpr(), ExecInsert(), ExecPrepareExprList(), ExecSerializePlan(), ExecuteGrantStmt(), ExecuteTruncate(), ExecuteTruncateGuts(), expand_grouping_sets(), expand_groupingset_node(), expand_inherited_rtentry(), expand_insert_targetlist(), expand_single_inheritance_child(), expand_vacuum_rel(), expandNSItemAttrs(), expandNSItemVars(), ExpandRowReference(), expandRTE(), expandTableLikeClause(), expandTupleDesc(), ExplainNode(), ExportSnapshot(), expr_setup_walker(), expression_tree_mutator_impl(), extract_actual_clauses(), extract_actual_join_clauses(), extract_jsp_path_expr_nodes(), extract_lateral_references(), extract_lateral_vars_from_PHVs(), extract_nonindex_conditions(), extract_or_clause(), extract_rollup_sets(), extractRemainingColumns(), fetch_remote_table_info(), fetch_statentries_for_relation(), fetch_table_list(), fetch_upper_rel(), FetchTableStates(), file_fdw_validator(), fill_hba_line(), FilterWalSummaries(), find_duplicate_ors(), find_hash_columns(), find_indexpath_quals(), find_list_position(), find_mergeclauses_for_outer_pathkeys(), find_partition_scheme(), find_placeholder_info(), find_window_functions_walker(), find_window_run_conditions(), findTargetlistEntrySQL99(), fireRIRrules(), fireRules(), fix_indexorderby_references(), fix_indexqual_references(), flatten_grouping_sets(), flatten_join_alias_vars_mutator(), flatten_simple_union_all(), fmgr_security_definer(), fmgr_sql_validator(), foreign_grouping_ok(), foreign_join_ok(), format_operator_parts(), format_procedure_parts(), func_get_detail(), gen_partprune_steps_internal(), gen_prune_step_combine(), gen_prune_step_op(), gen_prune_steps_from_opexps(), generate_append_tlist(), generate_base_implied_equalities_const(), generate_bitmap_or_paths(), generate_implied_equalities_for_column(), generate_join_implied_equalities_broken(), generate_join_implied_equalities_normal(), generate_matching_part_pairs(), generate_orderedappend_paths(), generate_partitionwise_join_paths(), generate_setop_tlist(), generate_subquery_params(), generate_subquery_vars(), generate_union_paths(), generateClonedExtStatsStmt(), generateClonedIndexStmt(), generateJsonTablePathName(), generateSerialExtraStmts(), get_actual_clauses(), get_all_vacuum_rels(), get_appendrel_parampathinfo(), get_baserel_parampathinfo(), get_database_list(), get_eclass_for_sort_expr(), get_ext_ver_info(), get_ext_ver_list(), get_file_fdw_attribute_options(), get_foreign_key_join_selectivity(), get_func_expr(), get_index_clause_from_support(), get_index_paths(), get_insert_query_def(), get_join_index_paths(), get_joinrel_parampathinfo(), get_local_synced_slots(), get_matching_part_pairs(), get_merge_query_def(), get_op_btree_interpretation(), get_policies_for_relation(), get_qual_for_hash(), get_qual_for_list(), get_qual_for_range(), get_quals_from_indexclauses(), get_range_nulltest(), get_rel_sync_entry(), get_relation_constraints(), get_relation_foreign_keys(), get_relation_statistics_worker(), get_rels_with_domain(), get_required_extension(), get_sortgrouplist_exprs(), get_steps_using_prefix_recurse(), get_subscription_list(), get_switched_clauses(), get_tables_to_cluster(), get_tables_to_cluster_partitioned(), get_tlist_exprs(), get_update_query_targetlist_def(), get_useful_ecs_for_relation(), get_useful_group_keys_orderings(), get_useful_pathkeys_for_distinct(), get_useful_pathkeys_for_relation(), get_windowfunc_expr_helper(), GetAfterTriggersTableData(), getObjectIdentityParts(), getState(), GetSubscriptionRelations(), getTokenTypes(), GetWalSummaries(), gistFindPath(), gistfixsplit(), gistplacetopage(), group_keys_reorder_by_pathkeys(), group_similar_or_args(), grouping_planner(), hash_inner_and_outer(), hashagg_spill_finish(), heap_truncate(), identify_current_nestloop_params(), identify_opfamily_groups(), index_concurrently_create_copy(), infer_arbiter_indexes(), init_execution_state(), init_sql_fcache(), initialize_target_list(), InitPlan(), injection_points_attach(), innerrel_is_unique(), interpret_AS_clause(), interpret_function_parameter_list(), intorel_startup(), is_innerrel_unique_for(), join_is_removable(), jsonb_ops__extract_nodes(), jsonb_path_ops__extract_nodes(), jsonb_subscript_transform(), JsonTableInitOpaque(), JsonValueListAppend(), list_append_unique(), list_append_unique_ptr(), list_concat_unique(), list_concat_unique_ptr(), list_difference(), list_difference_ptr(), list_intersection(), list_union(), list_union_ptr(), llvm_compile_module(), load_hba(), load_ident(), LoadPublications(), Lock_AF_UNIX(), logicalrep_workers_find(), make_bitmap_paths_for_or_group(), make_canonical_pathkey(), make_copy_attnamelist(), make_group_input_target(), make_inh_translation_list(), make_inner_pathkeys_for_merge(), make_modifytable(), make_partial_grouping_target(), make_partition_op_expr(), make_partition_pruneinfo(), make_partitionedrel_pruneinfo(), make_path_rowexpr(), make_pathkeys_for_sortclauses_extended(), make_pathtarget_from_tlist(), make_rel_from_joinlist(), make_row_comparison_op(), make_setop_translation_list(), make_sort_input_target(), make_sub_restrictinfos(), make_tlist_from_pathtarget(), make_window_input_target(), makeDependencyGraphWalker(), manifest_process_wal_range(), MarkGUCPrefixReserved(), markRelsAsNulledBy(), match_clause_to_index(), match_clause_to_partition_key(), match_foreign_keys_to_quals(), match_join_clauses_to_index(), match_network_subset(), match_orclause_to_indexcol(), match_pathkeys_to_index(), match_pattern_prefix(), matchLocks(), mbms_add_member(), mbms_add_members(), merge_clump(), merge_list_bounds(), merge_publications(), MergeAttributes(), MergeCheckConstraint(), negate_clause(), next_field_expand(), nodeRead(), ObjectsInPublicationToOids(), OpenTableList(), order_qual_clauses(), pa_launch_parallel_worker(), paraminfo_get_equal_hashops(), parse_hba_line(), parseCheckAggregates(), ParseFuncOrColumn(), PartConstraintImpliedByRelConstraint(), perform_base_backup(), pg_get_backend_memory_contexts(), pg_get_object_address(), pg_get_publication_tables(), pg_logical_slot_get_changes_guts(), pg_plan_queries(), pg_rewrite_query(), pgfdw_abort_cleanup_begin(), pgfdw_finish_abort_cleanup(), pgfdw_finish_pre_commit_cleanup(), pgfdw_subxact_callback(), pgfdw_xact_callback(), pgoutput_row_filter_init(), plan_union_children(), populate_typ_list(), postgresGetForeignPaths(), postgresGetForeignPlan(), postgresImportForeignSchema(), prep_domain_constraints(), prepare_sort_from_pathkeys(), preprocess_aggref(), preprocess_groupclause(), preprocess_grouping_sets(), preprocess_rowmarks(), preprocess_targetlist(), process_duplicate_ors(), process_equivalence(), process_pipe_input(), process_sublinks_mutator(), process_subquery_nestloop_params(), ProcessStartupPacket(), pull_ands(), pull_ors(), pull_up_simple_values(), pull_up_sublinks_jointree_recurse(), pull_up_sublinks_qual_recurse(), pull_up_union_leaf_queries(), pull_var_clause_walker(), pull_vars_walker(), query_tree_mutator_impl(), QueryRewrite(), queue_listen(), range_table_mutator_impl(), read_tablespace_map(), rebuild_fdw_scan_tlist(), RebuildConstraintComment(), record_plan_function_dependency(), record_plan_type_dependency(), reduce_outer_joins_pass1(), register_ENR(), register_label_provider(), register_reloptions_validator(), ReindexRelationConcurrently(), relation_excluded_by_constraints(), relation_has_unique_index_for(), RelationCacheInvalidate(), RelationGetDummyIndexExpressions(), RelationGetFKeyList(), RelationGetNotNullConstraints(), remap_to_groupclause_idx(), RememberConstraintForRebuilding(), RememberIndexForRebuilding(), RememberStatisticsForRebuilding(), RememberSyncRequest(), remove_rel_from_joinlist(), remove_useless_groupby_columns(), RemoveInheritance(), reorder_function_arguments(), reparameterize_path(), reparameterize_path_by_child(), reparameterize_pathlist_by_child(), replace_empty_jointree(), replace_nestloop_param_placeholdervar(), replace_nestloop_param_var(), replace_outer_agg(), replace_outer_grouping(), replace_outer_merge_support(), report_reduced_full_join(), resolve_unique_index_expr(), RewriteQuery(), rewriteSearchAndCycle(), rewriteTargetListIU(), rewriteTargetView(), rewriteValuesRTE(), rewriteValuesRTEToNulls(), RI_Initial_Check(), ScanSourceDatabasePgClassPage(), schema_to_xmlschema_internal(), SearchCatCacheList(), select_active_windows(), select_mergejoin_clauses(), select_outer_pathkeys_for_merge(), sepgsql_set_client_label(), sequence_options(), set_append_rel_pathlist(), set_append_rel_size(), set_cheapest(), set_deparse_for_query(), set_dummy_tlist_references(), set_indexonlyscan_references(), set_joinrel_partition_key_exprs(), set_plan_references(), set_plan_refs(), set_rtable_names(), set_simple_column_names(), set_subquery_pathlist(), set_upper_references(), set_using_names(), show_grouping_set_keys(), show_incremental_sort_group_info(), show_modifytable_info(), show_plan_tlist(), show_sort_group_keys(), show_tablesample(), simplify_and_arguments(), simplify_or_arguments(), split_pathtarget_at_srfs(), split_pathtarget_walker(), SplitDirectoriesString(), SplitGUCList(), SplitIdentifierString(), SS_make_initplan_from_plan(), SS_process_ctes(), statext_is_compatible_clause_internal(), statext_mcv_clauselist_selectivity(), stringToQualifiedNameList(), subquery_planner(), synchronize_slots(), table_slot_create(), textarray_to_stringlist(), textarray_to_strvaluelist(), textToQualifiedNameList(), TidExprListCreate(), TidRangeQualFromRestrictInfoList(), tokenize_auth_file(), tokenize_expand_file(), transform_MERGE_to_join(), transformAExprIn(), transformAggregateCall(), transformAlterTableStmt(), transformArrayExpr(), transformAssignmentIndirection(), transformBoolExpr(), transformCallStmt(), transformCaseExpr(), transformCoalesceExpr(), transformColumnDefinition(), transformCreateSchemaStmtElements(), transformCreateStmt(), transformDistinctClause(), transformDistinctOnClause(), transformExpressionList(), transformFKConstraints(), transformFkeyGetPrimaryKey(), transformFromClause(), transformFromClauseItem(), transformFuncCall(), transformGenericOptions(), transformGroupClause(), transformGroupClauseExpr(), transformGroupingFunc(), transformGroupingSet(), TransformGUCArray(), transformIndexConstraint(), transformIndexConstraints(), transformIndirection(), transformInsertRow(), transformInsertStmt(), transformJoinUsingClause(), transformJsonArrayConstructor(), transformJsonObjectConstructor(), transformJsonPassingArgs(), transformJsonTableColumns(), transformMergeStmt(), transformMinMaxExpr(), transformMultiAssignRef(), transformOfType(), transformPartitionBound(), transformPartitionRangeBounds(), transformPartitionSpec(), transformPLAssignStmt(), transformRangeFunction(), transformRangeTableFunc(), transformRangeTableSample(), transformRowExpr(), transformRuleStmt(), transformSetOperationStmt(), transformSetOperationTree(), transformSubLink(), transformTableConstraint(), transformTableLikeClause(), transformTargetList(), transformValuesClause(), transformWindowDefinitions(), transformWindowFuncCall(), transformWithClause(), transformXmlExpr(), trim_mergeclauses_for_inner_pathkeys(), TS_execute_locations_recurse(), untransformRelOptions(), UpdateLogicalMappings(), WaitForLockersMultiple(), and xmlelement().
pg_nodiscard List * lappend_int | ( | List * | list, |
int | datum | ||
) |
Definition at line 357 of file list.c.
References Assert, check_list_invariants, IsIntegerList, sort-test::list, llast_int, new_list(), new_tail_cell(), and NIL.
Referenced by add_merged_range_bounds(), addRangeTableEntryForCTE(), addRangeTableEntryForENR(), addRangeTableEntryForFunction(), addRangeTableEntryForGroup(), addRangeTableEntryForSubquery(), AddRelationNotNullConstraints(), adjust_inherited_attnums(), adjust_partition_colnos_using_map(), analyzeCTETargetList(), ATRewriteTable(), build_merged_partition_bounds(), build_subplan(), checkInsertTargets(), convert_EXISTS_to_ANY(), CopyGetAttnums(), deparseAnalyzeSql(), deparseExplicitTargetList(), deparseTargetList(), ExecBuildAggTrans(), ExecBuildGroupingEqual(), ExecBuildHash32Expr(), ExecBuildParamSetEqual(), ExecInitExprRec(), ExecInitJsonExpr(), ExecInitQual(), ExecInitSubscriptingRef(), expand_indexqual_rowcompare(), extract_update_targetlist_colnos(), extractRemainingColumns(), fetch_statentries_for_relation(), finalize_grouping_exprs_walker(), find_all_inheritors(), find_compatible_agg(), fix_expr_common(), gen_partprune_steps_internal(), generate_subquery_params(), grouping_planner(), list_append_unique_int(), list_concat_unique_int(), list_difference_int(), list_intersection_int(), list_union_int(), match_pathkeys_to_index(), merge_list_bounds(), nodeRead(), plan_union_children(), postgresBeginForeignInsert(), postgresPlanForeignModify(), rel_is_distinct_for(), remap_to_groupclause_idx(), RemoveInheritance(), reorder_grouping_sets(), rewriteSearchAndCycle(), set_plan_refs(), split_pathtarget_at_srfs(), SS_process_ctes(), substitute_grouped_columns_mutator(), TerminateOtherDBBackends(), transformDistinctOnClause(), transformFromClauseItem(), transformGroupClauseList(), transformJsonTableColumns(), transformRangeTableFunc(), transformSetOperationTree(), transformValuesClause(), and translate_sub_tlist().
pg_nodiscard List * lappend_oid | ( | List * | list, |
Oid | datum | ||
) |
Definition at line 375 of file list.c.
References Assert, check_list_invariants, IsOidList, sort-test::list, llast_oid, new_list(), new_tail_cell(), and NIL.
Referenced by add_rte_to_flat_rtable(), addRangeTableEntryForCTE(), addRangeTableEntryForENR(), addRangeTableEntryForFunction(), addRangeTableEntryForGroup(), addRangeTableEntryForSubquery(), AfterTriggerSetState(), AlterTableMoveAll(), analyzeCTETargetList(), apply_handle_truncate(), ApplyExtensionUpdates(), assign_collations_walker(), assign_param_for_placeholdervar(), assign_param_for_var(), assign_special_exec_param(), binary_upgrade_create_empty_extension(), check_functional_grouping(), CheckAttributeType(), CloneFkReferenced(), CloneFkReferencing(), compute_semijoin_info(), convert_EXISTS_to_ANY(), create_hashjoin_plan(), create_indexscan_plan(), CreateExtensionInternal(), CreateFunction(), DefineRelation(), do_autovacuum(), EventTriggerCommonSetup(), ExecAlterDefaultPrivilegesStmt(), ExecInitPartitionInfo(), ExecInsertIndexTuples(), ExecuteGrantStmt(), ExecuteTruncate(), ExecuteTruncateGuts(), expand_indexqual_rowcompare(), extract_query_dependencies_walker(), ExtractExtensionList(), finalNamespacePath(), find_all_inheritors(), find_inheritance_children_extended(), find_typed_table_dependencies(), fireRIRrules(), fix_expr_common(), generate_new_exec_param(), get_index_ref_constraints(), get_mergejoin_opfamilies(), get_partition_ancestors_worker(), get_steps_using_prefix_recurse(), GetAllTablesPublicationRelations(), GetAllTablesPublications(), getAutoExtensionsOfObject(), getOwnedSequences_internal(), GetParentedForeignKeyRefs(), GetPublicationSchemas(), GetPubPartitionOptionRelations(), GetRelationPublications(), getRelationsInNamespace(), GetSchemaPublicationRelations(), GetSchemaPublications(), heap_truncate_check_FKs(), heap_truncate_find_FKs(), index_concurrently_swap(), infer_arbiter_indexes(), InitConflictIndexes(), inline_function(), interpret_function_parameter_list(), list_append_unique_oid(), list_concat_unique_oid(), list_difference_oid(), list_union_oid(), LockViewRecurse(), logicalrep_read_truncate(), make_row_comparison_op(), nodeRead(), objectNamesToOids(), objectsInSchemaToOids(), oid_array_to_list(), OpenTableList(), paraminfo_get_equal_hashops(), PreCommit_on_commit_actions(), preprocessNamespacePath(), query_to_oid_list(), ReindexMultipleTables(), ReindexPartitions(), ReindexRelationConcurrently(), rel_is_distinct_for(), relation_is_updatable(), RelationGetIndexList(), RelationGetStatExtList(), RememberConstraintForRebuilding(), RememberIndexForRebuilding(), RememberStatisticsForRebuilding(), remove_dbtablespaces(), replace_outer_agg(), replace_outer_grouping(), replace_outer_merge_support(), RestoreReindexState(), rewriteSearchAndCycle(), roles_list_append(), roleSpecsToIds(), transformAggregateCall(), transformJsonTableColumns(), transformRangeTableFunc(), transformSetOperationTree(), transformValuesClause(), TryReuseForeignKey(), and typeInheritsFrom().
pg_nodiscard List * lappend_xid | ( | List * | list, |
TransactionId | datum | ||
) |
Definition at line 393 of file list.c.
References Assert, check_list_invariants, IsXidList, sort-test::list, llast_xid, new_list(), new_tail_cell(), and NIL.
Referenced by nodeRead(), pa_start_subtrans(), and set_schema_sent_in_streamed_txn().
pg_nodiscard List * lcons | ( | void * | datum, |
List * | list | ||
) |
Definition at line 495 of file list.c.
References Assert, check_list_invariants, IsPointerList, linitial, sort-test::list, new_head_cell(), new_list(), and NIL.
Referenced by build_minmax_path(), checkWellFormedRecursionWalker(), consider_groupingsets_paths(), CreateExprContextInternal(), CreateLockFile(), ExecInitModifyTable(), expandTableLikeClause(), ExplainNode(), ExplainSubPlans(), extract_rollup_sets(), find_expr_references_walker(), find_update_path(), generateSerialExtraStmts(), get_name_for_var_field(), get_object_address_rv(), get_query_def(), get_relation_info(), get_rule_expr(), gistEmptyAllBuffers(), gistFindPath(), gistGetNodeBuffer(), gistPushItupToNodeBuffer(), load_domaintype_info(), makeDependencyGraphWalker(), pg_get_object_address(), plan_union_children(), PLy_subtransaction_enter(), PrepareClientEncoding(), push_child_plan(), pushOperator(), pushStop(), pushValue_internal(), readTimeLineHistory(), register_on_commit_action(), RelationBuildRowSecurity(), RelationCacheInvalidate(), RememberConstraintForRebuilding(), reorder_grouping_sets(), RewriteQuery(), rewriteSearchAndCycle(), rewriteTargetView(), sepgsql_avc_compute(), set_cheapest(), show_agg_keys(), show_group_keys(), sort_inner_and_outer(), and transformCaseExpr().
pg_nodiscard List * lcons_int | ( | int | datum, |
List * | list | ||
) |
Definition at line 513 of file list.c.
References Assert, check_list_invariants, IsIntegerList, linitial_int, sort-test::list, new_head_cell(), new_list(), and NIL.
Referenced by ExecInitAgg(), ExplainBeginOutput(), ExplainOpenGroup(), ExplainOpenSetAsideGroup(), ExplainRestoreGroup(), and PutMemoryContextsStatsTupleStore().
pg_nodiscard List * lcons_oid | ( | Oid | datum, |
List * | list | ||
) |
Definition at line 531 of file list.c.
References Assert, check_list_invariants, IsOidList, linitial_oid, sort-test::list, new_head_cell(), new_list(), and NIL.
Referenced by finalNamespacePath(), pg_partition_ancestors(), ReindexMultipleTables(), and RememberConstraintForRebuilding().
pg_nodiscard List * list_append_unique | ( | List * | list, |
void * | datum | ||
) |
Definition at line 1343 of file list.c.
References lappend(), sort-test::list, and list_member().
Referenced by add_security_quals(), add_with_check_options(), check_publications_origin(), and create_index_paths().
pg_nodiscard List * list_append_unique_int | ( | List * | list, |
int | datum | ||
) |
Definition at line 1368 of file list.c.
References lappend_int(), sort-test::list, and list_member_int().
pg_nodiscard List * list_append_unique_oid | ( | List * | list, |
Oid | datum | ||
) |
Definition at line 1380 of file list.c.
References lappend_oid(), sort-test::list, and list_member_oid().
Referenced by ATExecAlterConstrRecurse(), btvalidate(), DropRole(), hashvalidate(), heap_truncate_find_FKs(), LogicalRepWorkersWakeupAtCommit(), map_sql_typecoll_to_xmlschema_types(), and ObjectsInPublicationToOids().
pg_nodiscard List * list_append_unique_ptr | ( | List * | list, |
void * | datum | ||
) |
Definition at line 1356 of file list.c.
References lappend(), sort-test::list, and list_member_ptr().
Referenced by get_useful_ecs_for_relation(), postgresGetForeignPaths(), subbuild_joinrel_joinlist(), and subbuild_joinrel_restrictlist().
Definition at line 333 of file pg_list.h.
References Assert, List::elements, and List::length.
Referenced by for_both_cell_setup(), for_each_cell_setup(), push_ancestor_plan(), subquery_planner(), and SyncPostCheckpoint().
pg_nodiscard List * list_concat | ( | List * | list1, |
const List * | list2 | ||
) |
Definition at line 561 of file list.c.
References Assert, check_list_invariants, List::elements, enlarge_list(), List::length, list_copy(), List::max_length, NIL, and List::type.
Referenced by accumulate_append_subpath(), add_predicate_to_index_quals(), addRangeTableEntryForJoin(), addRangeTableEntryForTableFunc(), ATParseTransformCmd(), ATPostAlterTypeParse(), AtSubCommit_Notify(), build_joinrel_restrictlist(), build_paths_for_OR(), check_index_predicates(), choose_bitmap_and(), clean_up_removed_plan_level(), CombineRangeTables(), consider_groupingsets_paths(), ConstraintImpliedByRelConstraint(), cost_index(), create_append_path(), create_append_plan(), create_bitmap_subplan(), create_index_paths(), create_join_plan(), deconstruct_distribute(), deconstruct_recurse(), DefineRelation(), deparseDirectDeleteSql(), deparseDirectUpdateSql(), deparseFromExprForRel(), estimate_path_cost_size(), expand_groupingset_node(), ExpandAllTables(), expandRTE(), extract_or_clause(), extract_rollup_sets(), fileBeginForeignScan(), fileGetOptions(), find_indexpath_quals(), find_mergeclauses_for_outer_pathkeys(), fireRIRrules(), flatten_grouping_sets(), foreign_grouping_ok(), foreign_join_ok(), gen_partprune_steps_internal(), gen_prune_steps_from_opexps(), generate_bitmap_or_paths(), generate_join_implied_equalities(), generate_join_implied_equalities_for_ecs(), generate_join_implied_equalities_normal(), generate_partition_qual(), get_baserel_parampathinfo(), get_batch_size_option(), get_foreign_key_join_selectivity(), get_from_clause_item(), get_index_paths(), get_join_index_paths(), get_joinrel_parampathinfo(), get_relation_constraints(), get_rels_with_domain(), get_steps_using_prefix_recurse(), GetAllSchemaPublicationRelations(), GetPubPartitionOptionRelations(), is_parallel_safe(), objectsInSchemaToOids(), optimize_window_clauses(), paraminfo_get_equal_hashops(), PrepareForIncrementalBackup(), process_equivalence(), process_sublinks_mutator(), ProcessUtilitySlow(), pull_ands(), pull_ors(), pull_up_simple_subquery(), reduce_unique_semijoins(), remove_useless_results_recurse(), reorder_grouping_sets(), RewriteQuery(), rewriteRuleAction(), rewriteTargetListIU(), selectColorTrigrams(), set_joinrel_partition_key_exprs(), set_plan_refs(), split_pathtarget_at_srfs(), split_pathtarget_walker(), subquery_planner(), TidQualFromRestrictInfoList(), transformAExprIn(), transformAlterTableStmt(), transformCreateSchemaStmtElements(), transformCreateStmt(), transformExpressionList(), transformFromClause(), transformFromClauseItem(), transformIndexConstraints(), transformTableLikeClause(), transformTargetList(), TS_execute_locations_recurse(), and vacuum().
pg_nodiscard List * list_concat_copy | ( | const List * | list1, |
const List * | list2 | ||
) |
Definition at line 598 of file list.c.
References Assert, check_list_invariants, List::elements, List::length, list_copy(), new_list(), NIL, and List::type.
Referenced by add_function_defaults(), ATExecAttachPartition(), btadjustmembers(), build_paths_for_OR(), choose_bitmap_and(), cost_subqueryscan(), create_scan_plan(), DefineIndex(), gen_partprune_steps(), generate_bitmap_or_paths(), get_parameterized_baserel_size(), hashadjustmembers(), max_parallel_hazard_walker(), preprocess_targetlist(), process_matched_tle(), set_joinrel_partition_key_exprs(), simplify_and_arguments(), and simplify_or_arguments().
pg_nodiscard List * list_concat_unique | ( | List * | list1, |
const List * | list2 | ||
) |
Definition at line 1405 of file list.c.
References Assert, check_list_invariants, IsPointerList, lappend(), lfirst, and list_member().
Referenced by create_bitmap_subplan(), and select_active_windows().
pg_nodiscard List * list_concat_unique_int | ( | List * | list1, |
const List * | list2 | ||
) |
Definition at line 1448 of file list.c.
References Assert, check_list_invariants, IsIntegerList, lappend_int(), lfirst_int, and list_member_int().
pg_nodiscard List * list_concat_unique_oid | ( | List * | list1, |
const List * | list2 | ||
) |
Definition at line 1469 of file list.c.
References Assert, check_list_invariants, IsOidList, lappend_oid(), lfirst_oid, and list_member_oid().
Referenced by AlterPublicationOptions(), GetSchemaPublicationRelations(), pg_get_publication_tables(), and RelationBuildPublicationDesc().
pg_nodiscard List * list_concat_unique_ptr | ( | List * | list1, |
const List * | list2 | ||
) |
Definition at line 1427 of file list.c.
References Assert, check_list_invariants, IsPointerList, lappend(), lfirst, and list_member_ptr().
Referenced by get_useful_pathkeys_for_distinct(), and group_keys_reorder_by_pathkeys().
pg_nodiscard List * list_copy | ( | const List * | oldlist | ) |
Definition at line 1573 of file list.c.
References check_list_invariants, List::elements, List::length, new_list(), NIL, and List::type.
Referenced by addRangeTableEntryForCTE(), adjust_group_pathkeys_for_groupagg(), arrayconst_startup_fn(), arrayexpr_startup_fn(), build_subplan(), check_index_predicates(), check_publications(), consider_groupingsets_paths(), ConstraintImpliedByRelConstraint(), copy_pathtarget(), copyObjectImpl(), CopySearchPathMatcher(), EventTriggerCollectGrant(), ExecuteTruncateGuts(), expression_tree_mutator_impl(), fetch_search_path(), foreign_join_ok(), generate_bitmap_or_paths(), generate_mergejoin_paths(), generateSerialExtraStmts(), get_eclass_for_sort_expr(), get_foreign_key_join_selectivity(), get_query_def(), get_required_extension(), get_steps_using_prefix_recurse(), get_switched_clauses(), get_useful_pathkeys_for_relation(), GetSearchPathMatcher(), heap_truncate_find_FKs(), list_concat(), list_concat_copy(), list_difference(), list_difference_int(), list_difference_oid(), list_difference_ptr(), list_union(), list_union_int(), list_union_oid(), list_union_ptr(), merge_publications(), plpgsql_parse_cwordtype(), preprocess_groupclause(), recomputeNamespacePath(), RelationGetIndexList(), RelationGetStatExtList(), remove_rel_from_query(), reorder_grouping_sets(), roles_is_member_of(), select_active_windows(), select_outer_pathkeys_for_merge(), set_joinrel_partition_key_exprs(), set_using_names(), SetReindexPending(), simplify_and_arguments(), simplify_or_arguments(), sort_inner_and_outer(), standard_qp_callback(), transformPLAssignStmt(), transformWithClause(), and WalSummariesAreComplete().
pg_nodiscard List * list_copy_deep | ( | const List * | oldlist | ) |
Definition at line 1639 of file list.c.
References Assert, check_list_invariants, copyObjectImpl(), List::elements, i, IsA, List::length, lfirst, new_list(), NIL, and List::type.
Referenced by copyObjectImpl().
pg_nodiscard List * list_copy_head | ( | const List * | oldlist, |
int | len | ||
) |
Definition at line 1593 of file list.c.
References check_list_invariants, List::elements, len, List::length, Min, new_list(), NIL, and List::type.
Referenced by accumulate_append_subpath(), build_index_paths(), create_agg_path(), create_append_plan(), create_merge_append_plan(), does_not_exist_skipping(), expand_indexqual_rowcompare(), gather_grouping_paths(), get_object_address_attrdef(), get_object_address_attribute(), get_object_address_opf_member(), get_object_address_relobject(), get_useful_pathkeys_for_relation(), group_keys_reorder_by_pathkeys(), owningrel_does_not_exist_skipping(), process_owned_by(), select_outer_pathkeys_for_merge(), and truncate_useless_pathkeys().
pg_nodiscard List * list_copy_tail | ( | const List * | oldlist, |
int | nskip | ||
) |
Definition at line 1613 of file list.c.
References check_list_invariants, List::elements, List::length, new_list(), NIL, and List::type.
Referenced by accumulate_append_subpath(), addRangeTableEntryForJoin(), addRangeTableEntryForTableFunc(), does_not_exist_skipping(), expandRTE(), get_name_for_var_field(), get_object_address_opcf(), ParseFuncOrColumn(), push_ancestor_plan(), and transformAggregateCall().
void list_deduplicate_oid | ( | List * | list | ) |
Definition at line 1495 of file list.c.
References Assert, check_list_invariants, i, IsOidList, j, len, sort-test::list, list_length(), and ListCell::oid_value.
Referenced by GetPublicationRelations(), and heap_truncate_find_FKs().
pg_nodiscard List * list_delete | ( | List * | list, |
void * | datum | ||
) |
Definition at line 853 of file list.c.
References Assert, check_list_invariants, equal(), IsPointerList, lfirst, sort-test::list, and list_delete_cell().
Referenced by check_publications(), generate_bitmap_or_paths(), injection_points_detach(), postgresGetForeignPlan(), and unregister_ENR().
pg_nodiscard List * list_delete_cell | ( | List * | list, |
ListCell * | cell | ||
) |
Definition at line 841 of file list.c.
References sort-test::list, and list_delete_nth_cell().
Referenced by list_delete(), list_delete_int(), list_delete_oid(), list_delete_ptr(), remove_useless_joins(), simplify_EXISTS_query(), and transformGenericOptions().
pg_nodiscard List * list_delete_first | ( | List * | list | ) |
Definition at line 943 of file list.c.
References check_list_invariants, sort-test::list, list_delete_nth_cell(), and NIL.
Referenced by checkWellFormedRecursionWalker(), CopyMultiInsertInfoFlush(), ExplainCloseGroup(), ExplainEndOutput(), ExplainNode(), ExplainSaveGroup(), ExplainSubPlans(), fetch_search_path(), find_expr_references_walker(), get_rule_expr(), GetSearchPathMatcher(), gistEmptyAllBuffers(), gistFindPath(), gistProcessEmptyingQueue(), jsonb_path_query_internal(), makeDependencyGraphWalker(), plan_union_children(), PLy_abort_open_subtransactions(), PLy_subtransaction_exit(), pop_child_plan(), ProcessUtilitySlow(), show_agg_keys(), show_group_keys(), simplify_and_arguments(), simplify_or_arguments(), transformPLAssignStmt(), and transformWithClause().
pg_nodiscard List * list_delete_first_n | ( | List * | list, |
int | n | ||
) |
Definition at line 983 of file list.c.
References check_list_invariants, GetMemoryChunkContext(), sort-test::list, list_free(), list_length(), MemoryContextAlloc(), NIL, pfree(), and VALGRIND_MAKE_MEM_NOACCESS.
Referenced by add_function_defaults(), func_get_detail(), and SyncPostCheckpoint().
pg_nodiscard List * list_delete_int | ( | List * | list, |
int | datum | ||
) |
Definition at line 891 of file list.c.
References Assert, check_list_invariants, IsIntegerList, lfirst_int, sort-test::list, and list_delete_cell().
Referenced by reorder_grouping_sets().
pg_nodiscard List * list_delete_last | ( | List * | list | ) |
Definition at line 957 of file list.c.
References check_list_invariants, sort-test::list, list_free(), list_length(), list_truncate(), and NIL.
Referenced by agg_refill_hash_table(), CheckAttributeType(), fireRIRrules(), inline_function(), LockViewRecurse(), plpgsql_parse_cwordtype(), relation_is_updatable(), RewriteQuery(), transformMultiAssignRef(), and transformOnConflictClause().
pg_nodiscard List * list_delete_nth_cell | ( | List * | list, |
int | n | ||
) |
Definition at line 767 of file list.c.
References Assert, check_list_invariants, GetMemoryChunkContext(), sort-test::list, list_free(), MemoryContextAlloc(), NIL, pfree(), and VALGRIND_MAKE_MEM_NOACCESS.
Referenced by AddRelationNotNullConstraints(), list_delete_cell(), list_delete_first(), MergeAttributes(), process_equivalence(), reconsider_full_join_clause(), and sort_inner_and_outer().
pg_nodiscard List * list_delete_oid | ( | List * | list, |
Oid | datum | ||
) |
Definition at line 910 of file list.c.
References Assert, check_list_invariants, IsOidList, lfirst_oid, sort-test::list, and list_delete_cell().
Referenced by RemoveReindexPending().
pg_nodiscard List * list_delete_ptr | ( | List * | list, |
void * | datum | ||
) |
Definition at line 872 of file list.c.
References Assert, check_list_invariants, IsPointerList, lfirst, sort-test::list, and list_delete_cell().
Referenced by FreeExprContext(), pa_free_worker_info(), and remove_join_clause_from_rels().
Definition at line 1237 of file list.c.
References Assert, check_list_invariants, IsPointerList, lappend(), lfirst, list_copy(), list_member(), and NIL.
Referenced by create_hashjoin_plan(), create_mergejoin_plan(), create_tidscan_plan(), get_useful_group_keys_orderings(), infer_arbiter_indexes(), and process_duplicate_ors().
Definition at line 1288 of file list.c.
References Assert, check_list_invariants, IsIntegerList, lappend_int(), lfirst_int, list_copy(), list_member_int(), and NIL.
Referenced by reorder_grouping_sets().
Definition at line 1313 of file list.c.
References Assert, check_list_invariants, IsOidList, lappend_oid(), lfirst_oid, list_copy(), list_member_oid(), and NIL.
Referenced by AlterPublicationSchemas().
Definition at line 1263 of file list.c.
References Assert, check_list_invariants, IsPointerList, lappend(), lfirst, list_copy(), list_member_ptr(), and NIL.
Referenced by create_bitmap_scan_plan(), ExecuteTruncateGuts(), and get_useful_group_keys_orderings().
void list_free | ( | List * | list | ) |
Definition at line 1546 of file list.c.
References sort-test::list, and list_free_private().
Referenced by AfterTriggerSetState(), AlterIndexNamespaces(), arrayconst_cleanup_fn(), arrayexpr_cleanup_fn(), ATCheckPartitionsNotInUse(), ATExecChangeOwner(), ATExecSetTableSpace(), build_base_rel_tlists(), build_remote_returning(), BuildRelationExtStatistics(), cachedNamespacePath(), calc_joinrel_size_estimate(), calculate_indexes_size(), calculate_toast_table_size(), check_createrole_self_grant(), check_datestyle(), check_debug_io_direct(), check_log_destination(), check_restrict_nonsystem_relation_kind(), check_search_path(), check_synchronized_standby_slots(), check_temp_tablespaces(), check_wal_consistency_checking(), choose_bitmap_and(), compute_semi_anti_join_factors(), CopyFrom(), CopyMultiInsertBufferFlush(), CopyMultiInsertInfoCleanup(), CreateExtensionInternal(), CreateTriggerFiringOn(), current_schema(), current_schemas(), DefineIndex(), DefineRelation(), deparseFromExprForRel(), distribute_qual_to_rels(), do_analyze_rel(), DropSubscription(), EventTriggerDDLCommandEnd(), EventTriggerDDLCommandStart(), EventTriggerOnLogin(), EventTriggerSQLDrop(), EventTriggerTableRewrite(), ExecInitPartitionInfo(), ExecInsert(), ExecOpenIndices(), ExecPendingInserts(), ExecResetTupleTable(), ExecSimpleRelationInsert(), ExecSimpleRelationUpdate(), ExecUpdateEpilogue(), expandTableLikeClause(), extract_lateral_references(), extract_lateral_vars_from_PHVs(), ExtractExtensionList(), find_all_inheritors(), find_compatible_agg(), find_computable_ec_member(), find_hash_columns(), find_placeholders_in_expr(), fix_placeholder_input_needed_levels(), generate_base_implied_equalities_no_const(), generate_bitmap_or_paths(), generate_partitionwise_join_paths(), get_rel_sync_entry(), get_relation_info(), get_relation_statistics(), get_steps_using_prefix_recurse(), get_windowclause_startup_tuples(), getIdentitySequence(), GetTopMostAncestorInPublication(), group_keys_reorder_by_pathkeys(), heap_truncate_find_FKs(), index_concurrently_swap(), index_get_partition(), index_unchanged_by_update(), infer_arbiter_indexes(), list_delete_first_n(), list_delete_last(), list_delete_nth_cell(), llvm_release_context(), make_group_input_target(), make_partial_grouping_target(), make_sort_input_target(), make_window_input_target(), match_orclause_to_indexcol(), max_parallel_hazard_walker(), merge_list_bounds(), merge_range_bounds(), ObjectsInPublicationToOids(), OpenTableList(), paraminfo_get_equal_hashops(), parse_hba_auth_opt(), pg_partition_root(), plpgsql_extra_checks_check_hook(), pop_ancestor_plan(), PostmasterMain(), PrepareTempTablespaces(), preprocess_targetlist(), preprocessNamespacePath(), process_implied_equality(), ProcessGUCArray(), processState(), ProcessUtilitySlow(), PutMemoryContextsStatsTupleStore(), qual_is_pushdown_safe(), rebuild_eclass_attr_needed(), rebuild_joinclause_attr_needed(), rebuild_placeholder_attr_needed(), recomputeNamespacePath(), refresh_by_match_merge(), RefreshMatViewByOid(), RelationCacheInvalidate(), RelationDestroyRelation(), RelationGetIndexAttrBitmap(), RelationGetIndexList(), RelationGetPrimaryKeyIndex(), RelationGetReplicaIndex(), RelationGetStatExtList(), relationHasPrimaryKey(), remove_dbtablespaces(), reorder_grouping_sets(), reparameterize_pathlist_by_child(), roles_is_member_of(), sepgsql_dml_privileges(), simplify_and_arguments(), simplify_or_arguments(), statext_mcv_clauselist_selectivity(), stringToQualifiedNameList(), textToQualifiedNameList(), toast_open_indexes(), transformFkeyCheckAttrs(), transformFkeyGetPrimaryKey(), transformValuesClause(), triggered_change_notification(), typeInheritsFrom(), vac_open_indexes(), and WaitForLockers().
void list_free_deep | ( | List * | list | ) |
Definition at line 1560 of file list.c.
References Assert, IsPointerList, sort-test::list, and list_free_private().
Referenced by AfterTriggerFreeQuery(), checkSharedDependencies(), CloseTableList(), copy_table(), CreateDatabaseUsingWalLog(), deconstruct_jointree(), deparseDirectDeleteSql(), deparseDirectUpdateSql(), deparseFromExpr(), deparseFromExprForRel(), DetachPartitionFinalize(), Exec_UnlistenAllCommit(), fetch_remote_table_info(), FetchTableStates(), FreeSubscription(), gettype(), gistbufferinginserttuples(), hashagg_reset_spill_state(), load_libraries(), lookup_proof_cache(), pgoutput_row_filter_init(), PostmasterMain(), RelationDestroyRelation(), RelationGetFKeyList(), rescanLatestTimeLine(), StartReplication(), synchronize_slots(), SyncPostCheckpoint(), verify_heapam(), WaitForLockersMultiple(), XLogReadDetermineTimeline(), and XLogSendPhysical().
Definition at line 128 of file pg_list.h.
References List::elements.
Referenced by add_setop_child_rel_equivalences(), analyzeCTE(), appendTypeNameToBuffer(), arrayexpr_startup_fn(), assign_hypothetical_collations(), ATAddForeignKeyConstraint(), boolexpr_startup_fn(), build_index_tlist(), buildRelationAliases(), CheckRADIUSAuth(), checkWellFormedRecursionWalker(), coerce_record_to_complex(), compare_tlist_datatypes(), ComputeIndexAttrs(), consider_groupingsets_paths(), ConstructTupleDescriptor(), cost_bitmap_and_node(), cost_bitmap_or_node(), create_ctas_nodata(), create_mergejoin_plan(), DefineView(), deparseSubscriptingRef(), deparseTruncateSql(), do_analyze_rel(), dump_getdiag(), examine_variable(), exec_stmt_raise(), ExecInitJunkFilterConversion(), expand_insert_targetlist(), expandRTE(), extract_rollup_sets(), fix_indexqual_operand(), flatten_set_variable_args(), FormIndexDatum(), FormPartitionKeyDatum(), funcname_signature_string(), gen_prune_steps_from_opexps(), generate_append_tlist(), generate_setop_child_grouplist(), generate_setop_grouplist(), generateClonedIndexStmt(), get_attr_expr(), get_param_path_clause_serials(), get_qual_for_hash(), get_qual_for_range(), get_range_nulltest(), get_steps_using_prefix(), get_update_query_targetlist_def(), GetIndexInputType(), has_partition_attrs(), InitPartitionPruneContext(), intorel_startup(), jsonb_path_query_internal(), list_startup_fn(), make_inner_pathkeys_for_merge(), makeDependencyGraphWalker(), match_index_to_operand(), NameListToQuotedString(), NameListToString(), parse_hba_line(), parse_ident_line(), perform_pruning_base_step(), pg_get_indexdef_worker(), pg_get_partkeydef_worker(), postprocess_setop_tlist(), PreCommit_Notify(), print_function_arguments(), printSubscripts(), process_startup_options(), query_is_distinct_for(), RelationBuildPartitionKey(), SearchPathMatchesCurrentEnvironment(), SendRowDescriptionMessage(), set_baserel_partition_key_exprs(), sort_inner_and_outer(), tfuncLoadRows(), tlist_matches_tupdesc(), tlist_same_collations(), tlist_same_datatypes(), transformAssignedExpr(), transformPLAssignStmt(), transformUpdateTargetList(), trim_mergeclauses_for_inner_pathkeys(), try_partitionwise_join(), and TypeNameListToString().
pg_nodiscard List * list_insert_nth | ( | List * | list, |
int | pos, | ||
void * | datum | ||
) |
Definition at line 439 of file list.c.
References Assert, check_list_invariants, insert_new_cell(), IsPointerList, lfirst, sort-test::list, list_make1, and NIL.
Referenced by add_partial_path(), add_path(), and merge_clump().
pg_nodiscard List * list_insert_nth_int | ( | List * | list, |
int | pos, | ||
int | datum | ||
) |
Definition at line 453 of file list.c.
References Assert, check_list_invariants, insert_new_cell(), IsIntegerList, lfirst_int, sort-test::list, list_make1_int, and NIL.
pg_nodiscard List * list_insert_nth_oid | ( | List * | list, |
int | pos, | ||
Oid | datum | ||
) |
Definition at line 467 of file list.c.
References Assert, check_list_invariants, insert_new_cell(), IsOidList, lfirst_oid, sort-test::list, list_make1_oid, and NIL.
Definition at line 1691 of file list.c.
References lfirst_int, p2, and pg_cmp_s32().
Referenced by expand_grouping_sets().
Definition at line 1174 of file list.c.
References Assert, check_list_invariants, IsPointerList, lappend(), lfirst, list_member(), and NIL.
Definition at line 1200 of file list.c.
References Assert, check_list_invariants, IsIntegerList, lappend_int(), lfirst_int, list_member_int(), and NIL.
Referenced by parseCheckAggregates().
|
inlinestatic |
Definition at line 152 of file pg_list.h.
References List::length.
Referenced by _outForeignKeyOptInfo(), _SPI_execute_plan(), acquire_inherited_sample_rows(), add_child_join_rel_equivalences(), add_child_rel_equivalences(), add_column_to_pathtarget(), add_function_defaults(), add_paths_to_append_rel(), add_paths_to_grouping_rel(), add_paths_with_pathkeys_for_rel(), add_row_identity_var(), add_security_quals(), add_setop_child_rel_equivalences(), add_sp_item_to_pathtarget(), add_to_flat_tlist(), add_with_check_options(), AddEventToPendingNotifies(), addRangeTableEntry(), addRangeTableEntryForCTE(), addRangeTableEntryForENR(), addRangeTableEntryForFunction(), addRangeTableEntryForGroup(), addRangeTableEntryForJoin(), addRangeTableEntryForRelation(), addRangeTableEntryForSubquery(), addRangeTableEntryForTableFunc(), addRangeTableEntryForValues(), AddRelationNewConstraints(), AddRelationNotNullConstraints(), AddRoleMems(), addRTEPermissionInfo(), adjust_appendrel_attrs_mutator(), adjust_inherited_attnums(), adjust_paths_for_srfs(), AlterDatabase(), AlterSubscription_refresh(), analyzeCTETargetList(), apply_tlist_labeling(), ApplyRetrieveRule(), array_subscript_transform(), assign_hypothetical_collations(), assign_ordered_set_collations(), assign_param_for_placeholdervar(), assign_param_for_var(), assign_special_exec_param(), ATAddCheckNNConstraint(), ATAddForeignKeyConstraint(), ATExecAlterColumnType(), AttachPartitionEnsureIndexes(), basebackup_progress_wait_wal_archive(), bbsink_end_backup(), bbsink_progress_begin_backup(), bbsink_progress_end_archive(), BeginCopyFrom(), BeginCopyTo(), btvalidate(), build_expr_data(), build_index_paths(), build_local_reloptions(), build_merged_partition_bounds(), build_pertrans_for_aggref(), build_remote_returning(), build_simple_rel(), build_subplan(), build_tlist_index(), build_tlist_index_other_vars(), BuildDescForRelation(), BuildDescFromLists(), buildNSItemFromLists(), buildNSItemFromTupleDesc(), buildRelationAliases(), BuildRelationExtStatistics(), cached_plan_cost(), CallStmtResultDesc(), can_minmax_aggs(), check_and_push_window_quals(), check_hashjoinable(), check_memoizable(), check_mergejoinable(), check_publications(), check_publications_origin(), check_selective_binary_conversion(), check_sql_fn_retval(), check_synchronized_standby_slots(), check_temp_tablespaces(), CheckIndexCompatible(), CheckRADIUSAuth(), choose_best_statistics(), choose_bitmap_and(), ChoosePortalStrategy(), classify_index_clause_usage(), clause_is_strict_for(), clauselist_selectivity_ext(), cmp_list_len_asc(), coerce_fn_result_column(), CombineRangeTables(), common_prefix_cmp(), commute_restrictinfo(), CommuteOpExpr(), compute_partition_bounds(), compute_semijoin_info(), ComputeIndexAttrs(), connect_pg_server(), consider_groupingsets_paths(), consider_index_join_clauses(), consider_index_join_outer_rels(), conversion_error_callback(), convert_ANY_sublink_to_join(), convert_EXISTS_sublink_to_join(), convert_requires_to_datum(), convert_subquery_pathkeys(), convert_testexpr_mutator(), cookConstraint(), copy_pathtarget(), CopyAttributeOutCSV(), CopyFrom(), CopyMultiInsertInfoFlush(), CopyOneRowTo(), CopyReadAttributesCSV(), CopyReadAttributesText(), cost_agg(), cost_incremental_sort(), cost_tidscan(), cost_windowagg(), count_rowexpr_columns(), CountJsonPathVars(), create_agg_path(), create_agg_plan(), create_append_path(), create_append_plan(), create_bitmap_subplan(), create_ctescan_plan(), create_degenerate_grouping_paths(), create_final_distinct_paths(), create_foreign_modify(), create_group_path(), create_group_plan(), create_groupingsets_path(), create_groupingsets_plan(), create_hashjoin_plan(), create_indexscan_plan(), create_limit_plan(), create_memoize_plan(), create_merge_append_path(), create_merge_append_plan(), create_mergejoin_plan(), create_modifytable_path(), create_one_window_path(), create_partial_distinct_paths(), create_partial_grouping_paths(), create_setop_path(), create_tidscan_plan(), create_unique_path(), create_unique_plan(), create_windowagg_plan(), CreateFunction(), CreatePartitionPruneState(), CreateStatistics(), CreateTriggerFiringOn(), current_schemas(), currtid_for_view(), deconstruct_recurse(), DeconstructQualifiedName(), DefineAggregate(), DefineCollation(), DefineDomain(), DefineIndex(), DefineQueryRewrite(), DefineRelation(), DefineVirtualRelation(), DelRoleMems(), deparse_context_for_plan_tree(), deparseDistinctExpr(), deparseOpExpr(), deparseRangeTblRef(), deparseScalarArrayOpExpr(), dependencies_clauselist_selectivity(), dependency_is_compatible_clause(), dependency_is_compatible_expression(), do_analyze_rel(), does_not_exist_skipping(), eclass_useful_for_merging(), elem_contained_by_range_support(), EnumValuesCreate(), equalRSDesc(), estimate_array_length(), estimate_hashagg_tablesize(), estimate_multivariate_ndistinct(), estimate_path_cost_size(), EstimateReindexStateSpace(), eval_const_expressions_mutator(), EvalPlanQualBegin(), EvalPlanQualStart(), EvaluateParams(), examine_opclause_args(), examine_simple_variable(), exec_eval_using_params(), exec_is_simple_query(), exec_parse_message(), exec_save_simple_expr(), exec_simple_query(), ExecBuildAggTrans(), ExecBuildHash32Expr(), ExecBuildParamSetEqual(), ExecBuildUpdateProjection(), ExecCheckPermissions(), ExecCreateTableAs(), ExecEvalXmlExpr(), ExecIndexBuildScanKeys(), ExecInitAgg(), ExecInitAppend(), ExecInitBitmapAnd(), ExecInitBitmapOr(), ExecInitExprRec(), ExecInitFunc(), ExecInitFunctionScan(), ExecInitHashJoin(), ExecInitIndexScan(), ExecInitMergeAppend(), ExecInitMergeJoin(), ExecInitModifyTable(), ExecInitPartitionInfo(), ExecInitProjectSet(), ExecInitRangeTable(), ExecInitSubPlan(), ExecInitSubPlanExpr(), ExecInitSubscriptingRef(), ExecInitValuesScan(), ExecInitWindowAgg(), ExecMakeTableFunctionResult(), ExecOpenIndices(), ExecSecLabelStmt(), ExecSupportsMarkRestore(), ExecTargetListLength(), ExecTypeFromExprList(), execute_extension_script(), ExecuteCallStmt(), ExecuteQuery(), ExecuteTruncateGuts(), expand_function_arguments(), expand_grouping_sets(), expand_groupingset_node(), expand_indexqual_rowcompare(), expand_inherited_rtentry(), expand_single_inheritance_child(), ExpandColumnRefStar(), ExpandIndirectionStar(), expandRecordVariable(), expandRTE(), expandTupleDesc(), ExplainCustomChildren(), ExplainNode(), ExplainOneUtility(), ExplainPrintPlan(), ExplainPrintTriggers(), ExplainTargetRel(), ExportSnapshot(), exprIsLengthCoercion(), extract_grouping_collations(), extract_grouping_cols(), extract_grouping_ops(), extract_jsp_path_expr(), extract_rollup_sets(), filter_list_to_array(), final_cost_mergejoin(), finalize_plan(), find_all_inheritors(), find_duplicate_ors(), find_expr_references_walker(), find_install_path(), find_join_rel(), find_minmax_agg_replacement_param(), find_modifytable_subplan(), findTargetlistEntrySQL92(), fireRIRrules(), fix_indexqual_clause(), fix_param_node(), flatten_join_alias_vars_mutator(), flatten_set_variable_args(), flatten_simple_union_all(), for_both_cell_setup(), for_each_cell_setup(), foreign_expr_walker(), foreign_grouping_ok(), foreign_join_ok(), func_get_detail(), funcname_signature_string(), gather_grouping_paths(), gen_partprune_steps_internal(), gen_prune_step_op(), generate_append_tlist(), generate_base_implied_equalities(), generate_base_implied_equalities_const(), generate_implied_equalities_for_column(), generate_join_implied_equalities(), generate_join_implied_equalities_for_ecs(), generate_mergejoin_paths(), generate_new_exec_param(), generate_orderedappend_paths(), generate_series_int4_support(), generate_series_int8_support(), generate_series_numeric_support(), generate_union_paths(), genericcostestimate(), geqo_eval(), get_agg_expr_helper(), get_aggregate_argtypes(), get_call_expr_arg_stable(), get_call_expr_argtype(), get_eclass_for_sort_expr(), get_expr_result_type(), get_foreign_key_join_selectivity(), get_from_clause_item(), get_func_expr(), get_func_sql_syntax(), get_join_variables(), get_matching_partitions(), get_memoize_path(), get_name_for_var_field(), get_nullingrels(), get_number_of_groups(), get_object_address_attrdef(), get_object_address_attribute(), get_object_address_defacl(), get_object_address_opf_member(), get_object_address_relobject(), get_oper_expr(), get_partition_qual_relid(), get_qual_for_range(), get_query_def(), get_rel_sync_entry(), get_relation_foreign_keys(), get_restriction_variable(), get_rightop(), get_rtable_name(), get_rte_attribute_is_dropped(), get_rte_attribute_name(), get_rule_expr(), get_rule_groupingset(), get_simple_binary_op_name(), get_simple_values_rte(), get_singleton_append_subpath(), get_steps_using_prefix_recurse(), get_update_query_targetlist_def(), get_useful_group_keys_orderings(), get_useful_pathkeys_for_distinct(), get_useful_pathkeys_for_relation(), get_variable(), get_view_query(), get_windowfunc_expr_helper(), getIdentitySequence(), getInsertSelectQuery(), GetOldestUnsummarizedLSN(), GetRTEByRangeTablePosn(), getRTEPermissionInfo(), getTokenTypes(), gimme_tree(), gincostestimate(), gistbufferinginserttuples(), gistfinishsplit(), gistRelocateBuildBuffersOnSplit(), group_keys_reorder_by_pathkeys(), group_similar_or_args(), grouping_planner(), has_relevant_eclass_joinclause(), hash_ok_operator(), hashvalidate(), have_relevant_eclass_joinclause(), have_relevant_joinclause(), hstore_subscript_transform(), identify_join_columns(), init_sexpr(), initial_cost_hashjoin(), initialize_peragg(), InitPartitionPruneContext(), inline_function(), inline_set_returning_function(), int_list_to_array(), interpret_AS_clause(), interpret_function_parameter_list(), interval_support(), InvalidatePublicationRels(), is_safe_append_member(), is_simple_values(), is_strict_saop(), IsBinaryTidClause(), IsTidEqualAnyClause(), IsTransactionExitStmtList(), IsTransactionStmtList(), JsonTableInitOpaque(), JsonValueListLength(), like_regex_support(), list_deduplicate_oid(), list_delete_first_n(), list_delete_last(), list_sort(), list_truncate(), lookup_var_attr_stats(), LookupFuncWithArgs(), LookupOperWithArgs(), LookupTypeNameExtended(), make_ands_explicit(), make_build_data(), make_callstmt_target(), make_jsp_expr_node_args(), make_memoize(), make_modifytable(), make_partition_op_expr(), make_partition_pruneinfo(), make_path_rowexpr(), make_pathtarget_from_tlist(), make_plain_restrictinfo(), make_recursive_union(), make_rel_from_joinlist(), make_row_comparison_op(), make_row_distinct_op(), make_ruledef(), make_setop(), make_setop_translation_list(), make_sort_from_groupcols(), make_sort_from_sortclauses(), make_sort_input_target(), make_unique_from_pathkeys(), make_unique_from_sortclauses(), make_viewdef(), MakeConfigurationMapping(), makeRangeVarFromNameList(), makeWholeRowVar(), markNullableIfNeeded(), markRelsAsNulledBy(), markRTEForSelectPriv(), markTargetListOrigin(), match_clause_to_partition_key(), match_foreign_keys_to_quals(), match_opclause_to_indexcol(), match_orclause_to_indexcol(), MatchNamedCall(), mbms_add_member(), mbms_add_members(), mbms_int_members(), mbms_is_member(), mcv_get_match_bitmap(), merge_clump(), merge_list_bounds(), merge_range_bounds(), MergeAttributes(), MJExamineQuals(), network_subset_support(), NextCopyFrom(), NextCopyFromRawFields(), numeric_support(), operator_predicate_proof(), optimize_window_clauses(), order_qual_clauses(), ordered_set_startup(), owningrel_does_not_exist_skipping(), pa_free_worker(), pa_stream_abort(), paraminfo_get_equal_hashops(), parse_hba_line(), parse_tsquery(), parseCheckAggregates(), ParseFuncOrColumn(), parseLocalRelOptions(), pathkeys_count_contained_in(), perform_pruning_base_step(), PerformCursorOpen(), pg_get_function_arg_default(), pg_get_object_address(), pg_get_publication_tables(), pg_get_statisticsobj_worker(), pg_listening_channels(), pg_partition_ancestors(), pg_partition_tree(), pgoutput_column_list_init(), plpgsql_parse_cwordtype(), PLy_abort_open_subtransactions(), PLy_procedure_call(), policy_role_list_to_array(), postgresBeginDirectModify(), postgresBeginForeignScan(), postgresExplainForeignScan(), postgresGetForeignModifyBatchSize(), predicate_classify(), predicate_implied_by(), predicate_implied_by_simple_clause(), predicate_refuted_by(), prepare_sort_from_pathkeys(), PrepareForIncrementalBackup(), PrepareQuery(), PrepareTempTablespaces(), preprocess_aggref(), preprocess_groupclause(), preprocess_grouping_sets(), preprocess_minmax_aggregates(), preprocess_targetlist(), print_expr(), print_function_arguments(), ProcedureCreate(), process_duplicate_ors(), process_owned_by(), processIndirection(), processTypesSpec(), ProcessUtilitySlow(), prune_append_rel_partitions(), publicationListToArray(), pull_up_constant_function(), pull_up_simple_subquery(), pull_up_simple_union_all(), pull_up_simple_values(), pull_up_sublinks_qual_recurse(), pullup_replace_vars_callback(), PutMemoryContextsStatsTupleStore(), query_is_distinct_for(), query_planner(), range_contains_elem_support(), rebuild_eclass_attr_needed(), rebuild_fdw_scan_tlist(), ReceiveCopyBegin(), recheck_cast_function_args(), reconsider_full_join_clause(), reduce_outer_joins_pass2(), refresh_matview_datafill(), RefreshMatViewByOid(), regnamespacein(), regrolein(), relation_has_unique_index_for(), RelationBuildPartitionDesc(), remap_groupColIdx(), remove_dbtablespaces(), remove_useless_groupby_columns(), remove_useless_results_recurse(), RemoveInheritance(), RemoveRelations(), reorder_function_arguments(), reorder_grouping_sets(), replace_domain_constraint_value(), replace_empty_jointree(), replace_outer_agg(), replace_outer_grouping(), replace_outer_merge_support(), resolve_column_ref(), resolve_special_varno(), RewriteQuery(), rewriteRuleAction(), rewriteSearchAndCycle(), rewriteTargetView(), rewriteValuesRTE(), RI_Initial_Check(), roles_list_append(), scalararraysel(), SearchCatCacheList(), select_active_windows(), select_outer_pathkeys_for_merge(), selectColorTrigrams(), SendCopyBegin(), SendNegotiateProtocolVersion(), SerializeReindexState(), set_append_references(), set_cte_pathlist(), set_deparse_context_plan(), set_deparse_for_query(), set_join_column_names(), set_mergeappend_references(), set_plan_references(), set_plan_refs(), set_relation_column_names(), set_rtable_names(), set_simple_column_names(), set_subquery_pathlist(), set_using_names(), set_values_size_estimates(), setup_simple_rel_arrays(), show_incremental_sort_group_info(), simplify_boolean_equality(), sort_inner_and_outer(), SPI_cursor_open_internal(), SPI_is_cursor_plan(), SPI_plan_get_cached_plan(), split_pathtarget_walker(), sql_fn_post_column_ref(), SS_make_initplan_from_plan(), SS_process_ctes(), standard_ExecutorStart(), standard_join_search(), standard_planner(), standard_qp_callback(), statext_is_compatible_clause_internal(), statext_mcv_clauselist_selectivity(), StoreRelCheck(), strlist_to_textarray(), subquery_planner(), substitute_grouped_columns_mutator(), tablesample_init(), TemporalSimplify(), test_opexpr_is_hashable(), test_predtest(), TidExprListCreate(), TidListEval(), TidQualFromRestrictInfoList(), tlist_same_exprs(), toast_open_indexes(), tokenize_auth_file(), transform_MERGE_to_join(), transformAExprBetween(), transformAExprIn(), transformAExprOp(), transformAggregateCall(), transformCallStmt(), transformColumnDefinition(), transformColumnRef(), transformFromClauseItem(), transformGroupingFunc(), transformGroupingSet(), transformIndexConstraint(), transformIndexStmt(), transformInsertRow(), transformInsertStmt(), transformJoinUsingClause(), transformJsonTableColumns(), transformMergeStmt(), transformMultiAssignRef(), transformPartitionBound(), transformPartitionRangeBounds(), transformPartitionSpec(), transformPLAssignStmt(), transformRangeFunction(), transformRangeTableFunc(), transformRangeTableSample(), transformRowExpr(), transformRuleStmt(), transformSetOperationStmt(), transformSetOperationTree(), transformStatsStmt(), transformSubLink(), transformValuesClause(), transformWholeRowRef(), transformWindowDefinitions(), transformWindowFuncCall(), transformWithClause(), trivial_subqueryscan(), truncate_useless_pathkeys(), tsvector_update_trigger(), TypeGetTupleDesc(), typenameTypeMod(), typeStringToTypeName(), unify_hypothetical_args(), vac_open_indexes(), vacuum(), ValuesNext(), varbit_support(), varchar_support(), view_cols_are_auto_updatable(), and view_query_is_auto_updatable().
Definition at line 236 of file list.c.
References check_list_invariants, sort-test::list, and new_list().
Definition at line 246 of file list.c.
References check_list_invariants, sort-test::list, and new_list().
Definition at line 257 of file list.c.
References check_list_invariants, sort-test::list, and new_list().
List * list_make4_impl | ( | NodeTag | t, |
ListCell | datum1, | ||
ListCell | datum2, | ||
ListCell | datum3, | ||
ListCell | datum4 | ||
) |
Definition at line 270 of file list.c.
References check_list_invariants, sort-test::list, and new_list().
List * list_make5_impl | ( | NodeTag | t, |
ListCell | datum1, | ||
ListCell | datum2, | ||
ListCell | datum3, | ||
ListCell | datum4, | ||
ListCell | datum5 | ||
) |
Definition at line 284 of file list.c.
References check_list_invariants, sort-test::list, and new_list().
bool list_member | ( | const List * | list, |
const void * | datum | ||
) |
Definition at line 661 of file list.c.
References Assert, check_list_invariants, equal(), IsPointerList, lfirst, and sort-test::list.
Referenced by add_new_column_to_pathtarget(), analyzeCTE(), build_minmax_path(), consider_index_join_outer_rels(), create_bitmap_scan_plan(), ec_member_matches_foreign(), fetch_table_list(), find_computable_ec_member(), find_window_functions_walker(), get_join_index_paths(), infer_arbiter_indexes(), list_append_unique(), list_concat_unique(), list_difference(), list_intersection(), list_union(), paraminfo_get_equal_hashops(), process_duplicate_ors(), split_pathtarget_at_srfs(), and split_pathtarget_walker().
bool list_member_int | ( | const List * | list, |
int | datum | ||
) |
Definition at line 702 of file list.c.
References Assert, check_list_invariants, IsIntegerList, lfirst_int, and sort-test::list.
Referenced by BeginCopyFrom(), BeginCopyTo(), buildGroupedVar(), contain_exec_param_walker(), CopyGetAttnums(), estimate_num_groups(), ExecRelationIsTargetRelation(), init_returning_filter(), list_append_unique_int(), list_concat_unique_int(), list_difference_int(), list_intersection_int(), list_union_int(), max_parallel_hazard_walker(), parseCheckAggregates(), reorder_grouping_sets(), substitute_grouped_columns_mutator(), and transformDistinctOnClause().
Definition at line 722 of file list.c.
References Assert, check_list_invariants, IsOidList, lfirst_oid, and sort-test::list.
Referenced by AfterTriggerSaveEvent(), AlterTableMoveAll(), apply_handle_truncate(), ATExecAddInherit(), ATExecAttachPartition(), BeginCopyTo(), CheckAndReportConflict(), CheckAttributeType(), CloneFkReferenced(), CloneFkReferencing(), CollationIsVisibleExt(), ConversionIsVisibleExt(), DefineRelation(), ec_member_matches_indexcol(), ExecAlterObjectDependsStmt(), ExecCheckIndexConstraints(), ExecInitPartitionInfo(), ExecInsertIndexTuples(), ExecuteTruncate(), exprs_known_equal(), finalNamespacePath(), fireRIRrules(), FunctionIsVisibleExt(), get_rel_sync_entry(), get_transform_fromsql(), get_transform_tosql(), GetTopMostAncestorInPublication(), has_privs_of_role(), hashvalidate(), have_partkey_equi_join(), heap_truncate_check_FKs(), heap_truncate_find_FKs(), inline_function(), is_member_of_role(), is_member_of_role_nosuper(), list_append_unique_oid(), list_concat_unique_oid(), list_difference_oid(), list_union_oid(), LockViewRecurse_walker(), lookup_shippable(), member_can_set_role(), OpclassIsVisibleExt(), OpenTableList(), OperatorIsVisibleExt(), OpfamilyIsVisibleExt(), PlanCacheRelCallback(), ReindexIsProcessingIndex(), relation_has_unique_index_for(), relation_is_updatable(), RelationIsVisibleExt(), RememberConstraintForRebuilding(), RememberIndexForRebuilding(), RememberStatisticsForRebuilding(), roles_list_append(), StatisticsObjIsVisibleExt(), TSConfigIsVisibleExt(), TSDictionaryIsVisibleExt(), TSParserIsVisibleExt(), TSTemplateIsVisibleExt(), typeInheritsFrom(), and TypeIsVisibleExt().
bool list_member_ptr | ( | const List * | list, |
const void * | datum | ||
) |
Definition at line 682 of file list.c.
References Assert, check_list_invariants, IsPointerList, lfirst, and sort-test::list.
Referenced by create_bitmap_scan_plan(), create_tidrangescan_plan(), create_tidscan_plan(), ExecInsert(), get_foreign_key_join_selectivity(), get_useful_pathkeys_for_distinct(), group_keys_reorder_by_pathkeys(), list_append_unique_ptr(), list_concat_unique_ptr(), list_difference_ptr(), list_union_ptr(), pathkeys_useful_for_distinct(), pathkeys_useful_for_grouping(), postgresGetForeignPlan(), preprocess_groupclause(), and remove_join_clause_from_rels().
bool list_member_xid | ( | const List * | list, |
TransactionId | datum | ||
) |
Definition at line 742 of file list.c.
References Assert, check_list_invariants, IsXidList, lfirst_xid, and sort-test::list.
Referenced by get_schema_sent_in_streamed_txn(), and pa_start_subtrans().
|
inlinestatic |
Definition at line 299 of file pg_list.h.
References Assert, IsA, lfirst, sort-test::list, and list_nth_cell().
Referenced by add_child_join_rel_equivalences(), add_child_rel_equivalences(), AddRelationNotNullConstraints(), adjust_appendrel_attrs_mutator(), adjust_inherited_attnums(), apply_handle_update(), ATAddForeignKeyConstraint(), bbsink_copystream_begin_archive(), build_joinrel_tlist(), CallStmtResultDesc(), check_and_push_window_quals(), check_new_partition_bound(), consider_index_join_outer_rels(), conversion_error_callback(), convert_subquery_pathkeys(), convert_testexpr_mutator(), dependencies_clauselist_selectivity(), errorMissingColumn(), eval_const_expressions_mutator(), examine_simple_variable(), exec_rt_fetch(), ExecInitAppend(), ExecInitCteScan(), ExecInitMemoize(), ExecInitMerge(), ExecInitMergeAppend(), ExecInitModifyTable(), ExecInitSubPlan(), ExecInitUpdateProjection(), expand_indexqual_rowcompare(), expand_single_inheritance_child(), expandRecordVariable(), expandRTE(), ExplainTargetRel(), finalize_plan(), find_expr_references_walker(), find_hash_columns(), find_modifytable_subplan(), find_window_run_conditions(), fix_param_node(), flatten_group_exprs_mutator(), flatten_join_alias_vars_mutator(), generate_implied_equalities_for_column(), generate_join_implied_equalities(), get_call_expr_arg_stable(), get_call_expr_argtype(), get_name_for_var_field(), get_rtable_name(), get_rte_attribute_is_dropped(), get_rte_attribute_name(), get_tupdesc_for_join_scan_tuples(), get_variable(), GetOldestUnsummarizedLSN(), gimme_tree(), gistfinishsplit(), group_similar_or_args(), has_dangerous_join_using(), has_relevant_eclass_joinclause(), have_relevant_eclass_joinclause(), infer_collation_opclass_match(), interpret_AS_clause(), JsonTableGetValue(), make_callstmt_target(), make_path_rowexpr(), markNullableIfNeeded(), match_eclasses_to_foreign_key_col(), merge_clump(), pg_get_function_arg_default(), pg_get_publication_tables(), pg_listening_channels(), postgresBeginDirectModify(), postgresBeginForeignModify(), postgresBeginForeignScan(), postgresExplainDirectModify(), postgresExplainForeignModify(), postgresExplainForeignScan(), postgresGetForeignPlan(), postgresPlanDirectModify(), postgresPlanForeignModify(), PrepareForIncrementalBackup(), reorder_grouping_sets(), resolve_special_varno(), rewriteSearchAndCycle(), set_cte_pathlist(), set_deparse_plan(), set_join_column_names(), set_relation_column_names(), set_using_names(), show_modifytable_info(), substitute_actual_parameters_mutator(), substitute_actual_srf_parameters_mutator(), SyncPostCheckpoint(), transformInsertRow(), transformMultiAssignRef(), transformPartitionRangeBounds(), transformSetOperationStmt(), TypeGetTupleDesc(), validateFkOnDeleteSetColumns(), WinGetFuncArgCurrent(), WinGetFuncArgInFrame(), and WinGetFuncArgInPartition().
Definition at line 277 of file pg_list.h.
References Assert, sort-test::list, and NIL.
Referenced by build_subplan(), expandTupleDesc(), find_all_inheritors(), list_nth(), list_nth_int(), list_nth_oid(), markRelsAsNulledBy(), mbms_add_member(), pa_stream_abort(), ProcedureCreate(), split_pathtarget_at_srfs(), split_pathtarget_walker(), and unify_hypothetical_args().
|
inlinestatic |
Definition at line 310 of file pg_list.h.
References Assert, IsA, lfirst_int, sort-test::list, and list_nth_cell().
Referenced by CopyReadAttributesCSV(), CopyReadAttributesText(), create_ctescan_plan(), examine_simple_variable(), make_path_rowexpr(), rewriteSearchAndCycle(), and set_cte_pathlist().
Definition at line 321 of file pg_list.h.
References Assert, IsA, lfirst_oid, sort-test::list, and list_nth_cell().
Referenced by EstimateParamExecSpace(), expand_indexqual_rowcompare(), get_rte_attribute_is_dropped(), interpret_AS_clause(), make_path_rowexpr(), pg_partition_ancestors(), pg_partition_tree(), rewriteSearchAndCycle(), and SerializeParamExecParams().
Definition at line 1703 of file list.c.
References lfirst_oid, p2, and pg_cmp_u32().
Referenced by GetPublicationRelations(), heap_truncate_find_FKs(), RelationGetIndexList(), and RelationGetStatExtList().
Definition at line 142 of file pg_list.h.
References List::elements, and List::length.
Referenced by JsonValueListInitIterator(), and select_common_type().
void list_sort | ( | List * | list, |
list_sort_comparator | cmp | ||
) |
Definition at line 1674 of file list.c.
References a, b, check_list_invariants, cmp(), len, sort-test::list, list_length(), and qsort.
Referenced by create_append_path(), expand_grouping_sets(), GetPublicationRelations(), heap_truncate_find_FKs(), perform_base_backup(), RelationGetIndexList(), RelationGetStatExtList(), sort_policies_by_name(), UpdateLogicalMappings(), and WalSummariesAreComplete().
Definition at line 135 of file pg_list.h.
References List::elements, and List::length.
pg_nodiscard List * list_truncate | ( | List * | list, |
int | new_size | ||
) |
Definition at line 631 of file list.c.
References sort-test::list, list_length(), and NIL.
Referenced by choose_bitmap_and(), expand_indexqual_rowcompare(), ExpandIndirectionStar(), expandRTE(), generate_mergejoin_paths(), geqo_eval(), list_delete_last(), mbms_int_members(), pa_stream_abort(), ParseFuncOrColumn(), transformAggregateCall(), transformFromClauseItem(), transformSetOperationStmt(), and transformWholeRowRef().
Definition at line 1066 of file list.c.
References Assert, check_list_invariants, IsPointerList, lappend(), lfirst, list_copy(), and list_member().
Referenced by AddRelationNewConstraints(), and process_duplicate_ors().
Definition at line 1113 of file list.c.
References Assert, check_list_invariants, IsIntegerList, lappend_int(), lfirst_int, list_copy(), and list_member_int().
Referenced by expand_grouping_sets().
Definition at line 1136 of file list.c.
References Assert, check_list_invariants, IsOidList, lappend_oid(), lfirst_oid, list_copy(), and list_member_oid().
Definition at line 1090 of file list.c.
References Assert, check_list_invariants, IsPointerList, lappend(), lfirst, list_copy(), and list_member_ptr().
Definition at line 343 of file pg_list.h.
References Assert, List::elements, and List::length.
Referenced by _outList(), add_setop_child_rel_equivalences(), analyzeCTE(), arrayexpr_next_fn(), assign_hypothetical_collations(), asyncQueueAddEntries(), ATAddForeignKeyConstraint(), build_index_tlist(), buildRelationAliases(), CheckRADIUSAuth(), coerce_record_to_complex(), compare_tlist_datatypes(), ComputeIndexAttrs(), consider_groupingsets_paths(), ConstructTupleDescriptor(), create_ctas_nodata(), create_mergejoin_plan(), create_one_window_path(), DefineView(), deparseAggref(), deparseFuncExpr(), deparseSubscriptingRef(), do_analyze_rel(), examine_variable(), exec_simple_query(), exec_stmt_raise(), ExecInitJunkFilterConversion(), ExecLockRows(), expand_insert_targetlist(), expandRTE(), expandTupleDesc(), ExplainExecuteQuery(), ExplainQuery(), extract_rollup_sets(), find_param_referent(), fix_indexqual_operand(), fmgr_sql(), FormIndexDatum(), FormPartitionKeyDatum(), funcname_signature_string(), generate_append_tlist(), generate_setop_child_grouplist(), generate_setop_grouplist(), generateClonedIndexStmt(), get_attr_expr(), get_func_expr(), get_qual_for_hash(), get_qual_for_range(), get_range_key_properties(), get_range_nulltest(), get_rule_expr(), get_update_query_targetlist_def(), GetIndexInputType(), has_partition_attrs(), InitPartitionPruneContext(), intorel_startup(), JsonValueListNext(), list_next_fn(), make_inner_pathkeys_for_merge(), match_index_to_operand(), parse_hba_line(), parse_ident_line(), perform_base_backup(), perform_pruning_base_step(), pg_get_functiondef(), pg_get_indexdef_worker(), pg_get_partkeydef_worker(), PortalRunMulti(), postprocess_setop_tlist(), print_expr(), print_function_arguments(), print_pathkeys(), printSubscripts(), ProcedureCreate(), process_startup_options(), query_is_distinct_for(), RelationBuildPartitionKey(), SearchPathMatchesCurrentEnvironment(), SendRowDescriptionMessage(), serialize_deflist(), set_baserel_partition_key_exprs(), split_pathtarget_at_srfs(), tfuncLoadRows(), tlist_matches_tupdesc(), tlist_same_collations(), tlist_same_datatypes(), transformAssignmentIndirection(), transformUpdateTargetList(), transformWithClause(), trim_mergeclauses_for_inner_pathkeys(), and try_partitionwise_join().