PostgreSQL Source Code
git master
|
#include "postgres_ext.h"
#include "pg_config.h"
#include "pg_config_manual.h"
#include "pg_config_os.h"
#include <stdio.h>
#include <stdlib.h>
#include <string.h>
#include <stddef.h>
#include <stdarg.h>
#include <stdint.h>
#include <sys/types.h>
#include <errno.h>
#include <locale.h>
#include "port.h"
Go to the source code of this file.
Data Structures | |
struct | varlena |
struct | int2vector |
struct | oidvector |
struct | nameData |
union | PGAlignedBlock |
union | PGAlignedXLogBlock |
Macros | |
#define | __has_attribute(attribute) 0 |
#define | pg_attribute_unused() |
#define | pg_nodiscard |
#define | pg_attribute_no_sanitize_alignment() |
#define | PG_USED_FOR_ASSERTS_ONLY pg_attribute_unused() |
#define | pg_attribute_format_arg(a) |
#define | pg_attribute_printf(f, a) |
#define | pg_attribute_noreturn() |
#define | pg_attribute_always_inline inline |
#define | pg_noinline |
#define | pg_attribute_cold |
#define | pg_attribute_hot |
#define | pg_unreachable() abort() |
#define | likely(x) ((x) != 0) |
#define | unlikely(x) ((x) != 0) |
#define | CppAsString(identifier) #identifier |
#define | CppAsString2(x) CppAsString(x) |
#define | CppConcat(x, y) x##y |
#define | VA_ARGS_NARGS(...) |
#define | VA_ARGS_NARGS_(_01, _02, _03, _04, _05, _06, _07, _08, _09, _10, _11, _12, _13, _14, _15, _16, _17, _18, _19, _20, _21, _22, _23, _24, _25, _26, _27, _28, _29, _30, _31, _32, _33, _34, _35, _36, _37, _38, _39, _40, _41, _42, _43, _44, _45, _46, _47, _48, _49, _50, _51, _52, _53, _54, _55, _56, _57, _58, _59, _60, _61, _62, _63, N, ...) (N) |
#define | dummyret char |
#define | FLEXIBLE_ARRAY_MEMBER /* empty */ |
#define | PG_FUNCNAME_MACRO NULL |
#define | true ((bool) 1) |
#define | false ((bool) 0) |
#define | INT64_FORMAT "%" INT64_MODIFIER "d" |
#define | UINT64_FORMAT "%" INT64_MODIFIER "u" |
#define | PG_INT8_MIN (-0x7F-1) |
#define | PG_INT8_MAX (0x7F) |
#define | PG_UINT8_MAX (0xFF) |
#define | PG_INT16_MIN (-0x7FFF-1) |
#define | PG_INT16_MAX (0x7FFF) |
#define | PG_UINT16_MAX (0xFFFF) |
#define | PG_INT32_MIN (-0x7FFFFFFF-1) |
#define | PG_INT32_MAX (0x7FFFFFFF) |
#define | PG_UINT32_MAX (0xFFFFFFFFU) |
#define | PG_INT64_MIN (-INT64CONST(0x7FFFFFFFFFFFFFFF) - 1) |
#define | PG_INT64_MAX INT64CONST(0x7FFFFFFFFFFFFFFF) |
#define | PG_UINT64_MAX UINT64CONST(0xFFFFFFFFFFFFFFFF) |
#define | HAVE_INT64_TIMESTAMP |
#define | FLOAT8PASSBYVAL false |
#define | InvalidSubTransactionId ((SubTransactionId) 0) |
#define | TopSubTransactionId ((SubTransactionId) 1) |
#define | FirstCommandId ((CommandId) 0) |
#define | InvalidCommandId (~(CommandId)0) |
#define | VARHDRSZ ((int32) sizeof(int32)) |
#define | NameStr(name) ((name).data) |
#define | BoolIsValid(boolean) ((boolean) == false || (boolean) == true) |
#define | PointerIsValid(pointer) ((const void*)(pointer) != NULL) |
#define | PointerIsAligned(pointer, type) (((uintptr_t)(pointer) % (sizeof (type))) == 0) |
#define | OffsetToPointer(base, offset) ((void *)((char *) base + offset)) |
#define | OidIsValid(objectId) ((bool) ((objectId) != InvalidOid)) |
#define | RegProcedureIsValid(p) OidIsValid(p) |
#define | offsetof(type, field) ((long) &((type *)0)->field) |
#define | lengthof(array) (sizeof (array) / sizeof ((array)[0])) |
#define | TYPEALIGN(ALIGNVAL, LEN) (((uintptr_t) (LEN) + ((ALIGNVAL) - 1)) & ~((uintptr_t) ((ALIGNVAL) - 1))) |
#define | SHORTALIGN(LEN) TYPEALIGN(ALIGNOF_SHORT, (LEN)) |
#define | INTALIGN(LEN) TYPEALIGN(ALIGNOF_INT, (LEN)) |
#define | LONGALIGN(LEN) TYPEALIGN(ALIGNOF_LONG, (LEN)) |
#define | DOUBLEALIGN(LEN) TYPEALIGN(ALIGNOF_DOUBLE, (LEN)) |
#define | MAXALIGN(LEN) TYPEALIGN(MAXIMUM_ALIGNOF, (LEN)) |
#define | BUFFERALIGN(LEN) TYPEALIGN(ALIGNOF_BUFFER, (LEN)) |
#define | CACHELINEALIGN(LEN) TYPEALIGN(PG_CACHE_LINE_SIZE, (LEN)) |
#define | TYPEALIGN_DOWN(ALIGNVAL, LEN) (((uintptr_t) (LEN)) & ~((uintptr_t) ((ALIGNVAL) - 1))) |
#define | SHORTALIGN_DOWN(LEN) TYPEALIGN_DOWN(ALIGNOF_SHORT, (LEN)) |
#define | INTALIGN_DOWN(LEN) TYPEALIGN_DOWN(ALIGNOF_INT, (LEN)) |
#define | LONGALIGN_DOWN(LEN) TYPEALIGN_DOWN(ALIGNOF_LONG, (LEN)) |
#define | DOUBLEALIGN_DOWN(LEN) TYPEALIGN_DOWN(ALIGNOF_DOUBLE, (LEN)) |
#define | MAXALIGN_DOWN(LEN) TYPEALIGN_DOWN(MAXIMUM_ALIGNOF, (LEN)) |
#define | BUFFERALIGN_DOWN(LEN) TYPEALIGN_DOWN(ALIGNOF_BUFFER, (LEN)) |
#define | TYPEALIGN64(ALIGNVAL, LEN) (((uint64) (LEN) + ((ALIGNVAL) - 1)) & ~((uint64) ((ALIGNVAL) - 1))) |
#define | MAXALIGN64(LEN) TYPEALIGN64(MAXIMUM_ALIGNOF, (LEN)) |
#define | Assert(condition) ((void)true) |
#define | AssertMacro(condition) ((void)true) |
#define | AssertArg(condition) ((void)true) |
#define | AssertState(condition) ((void)true) |
#define | AssertPointerAlignment(ptr, bndr) ((void)true) |
#define | Trap(condition, errorType) ((void)true) |
#define | TrapMacro(condition, errorType) (true) |
#define | StaticAssertStmt(condition, errmessage) ((void) sizeof(struct { int static_assert_failure : (condition) ? 1 : -1; })) |
#define | StaticAssertExpr(condition, errmessage) StaticAssertStmt(condition, errmessage) |
#define | StaticAssertDecl(condition, errmessage) extern void static_assert_func(int static_assert_failure[(condition) ? 1 : -1]) |
#define | AssertVariableIsOfType(varname, typename) |
#define | AssertVariableIsOfTypeMacro(varname, typename) |
#define | Max(x, y) ((x) > (y) ? (x) : (y)) |
#define | Min(x, y) ((x) < (y) ? (x) : (y)) |
#define | Abs(x) ((x) >= 0 ? (x) : -(x)) |
#define | LONG_ALIGN_MASK (sizeof(long) - 1) |
#define | MemSet(start, val, len) |
#define | MemSetAligned(start, val, len) |
#define | MemSetTest(val, len) |
#define | MemSetLoop(start, val, len) |
#define | FLOAT4_FITS_IN_INT16(num) ((num) >= (float4) PG_INT16_MIN && (num) < -((float4) PG_INT16_MIN)) |
#define | FLOAT4_FITS_IN_INT32(num) ((num) >= (float4) PG_INT32_MIN && (num) < -((float4) PG_INT32_MIN)) |
#define | FLOAT4_FITS_IN_INT64(num) ((num) >= (float4) PG_INT64_MIN && (num) < -((float4) PG_INT64_MIN)) |
#define | FLOAT8_FITS_IN_INT16(num) ((num) >= (float8) PG_INT16_MIN && (num) < -((float8) PG_INT16_MIN)) |
#define | FLOAT8_FITS_IN_INT32(num) ((num) >= (float8) PG_INT32_MIN && (num) < -((float8) PG_INT32_MIN)) |
#define | FLOAT8_FITS_IN_INT64(num) ((num) >= (float8) PG_INT64_MIN && (num) < -((float8) PG_INT64_MIN)) |
#define | INVERT_COMPARE_RESULT(var) ((var) = ((var) < 0) ? 1 : -(var)) |
#define | HIGHBIT (0x80) |
#define | IS_HIGHBIT_SET(ch) ((unsigned char)(ch) & HIGHBIT) |
#define | SQL_STR_DOUBLE(ch, escape_backslash) ((ch) == '\'' || ((ch) == '\\' && (escape_backslash))) |
#define | ESCAPE_STRING_SYNTAX 'E' |
#define | STATUS_OK (0) |
#define | STATUS_ERROR (-1) |
#define | STATUS_EOF (-2) |
#define | gettext(x) (x) |
#define | dgettext(d, x) (x) |
#define | ngettext(s, p, n) ((n) == 1 ? (s) : (p)) |
#define | dngettext(d, s, p, n) ((n) == 1 ? (s) : (p)) |
#define | _(x) gettext(x) |
#define | gettext_noop(x) (x) |
#define | PG_TEXTDOMAIN(domain) (domain "-" PG_MAJORVERSION) |
#define | unconstify(underlying_type, expr) ((underlying_type) (expr)) |
#define | unvolatize(underlying_type, expr) ((underlying_type) (expr)) |
#define | PG_BINARY 0 |
#define | PG_BINARY_A "a" |
#define | PG_BINARY_R "r" |
#define | PG_BINARY_W "w" |
#define | PGDLLIMPORT |
#define | PGDLLEXPORT |
#define | SIGNAL_ARGS int postgres_signal_arg |
#define | NON_EXEC_STATIC static |
Typedefs | |
typedef void(* | pg_funcptr_t) (void) |
typedef unsigned char | bool |
typedef char * | Pointer |
typedef signed char | int8 |
typedef signed short | int16 |
typedef signed int | int32 |
typedef unsigned char | uint8 |
typedef unsigned short | uint16 |
typedef unsigned int | uint32 |
typedef uint8 | bits8 |
typedef uint16 | bits16 |
typedef uint32 | bits32 |
typedef size_t | Size |
typedef unsigned int | Index |
typedef signed int | Offset |
typedef float | float4 |
typedef double | float8 |
typedef Oid | regproc |
typedef regproc | RegProcedure |
typedef uint32 | TransactionId |
typedef uint32 | LocalTransactionId |
typedef uint32 | SubTransactionId |
typedef TransactionId | MultiXactId |
typedef uint32 | MultiXactOffset |
typedef uint32 | CommandId |
typedef struct varlena | bytea |
typedef struct varlena | text |
typedef struct varlena | BpChar |
typedef struct varlena | VarChar |
typedef struct nameData | NameData |
typedef NameData * | Name |
typedef union PGAlignedBlock | PGAlignedBlock |
typedef union PGAlignedXLogBlock | PGAlignedXLogBlock |
Functions | |
void | ExceptionalCondition (const char *conditionName, const char *errorType, const char *fileName, int lineNumber) pg_attribute_noreturn() |
#define Abs | ( | x | ) | ((x) >= 0 ? (x) : -(x)) |
Definition at line 992 of file c.h.
Referenced by _ltree_picksplit(), AppendSeconds(), brincostestimate(), calc_rank_and(), cash_dist(), check_new_partition_bound(), date_dist(), div_var_fast(), estimate_ln_dweight(), estimate_variable_size(), exp_var(), float4_dist(), float8_dist(), g_int_picksplit(), g_intbig_picksplit(), gbt_float8_dist(), gbt_intv_dist(), gbt_time_dist(), gbt_ts_dist(), gbt_var_penalty(), gdb_date_dist(), gimme_edge(), gimme_gene(), gist_box_picksplit(), gtsvector_picksplit(), int2_dist(), int4_dist(), int8_dist(), interval_div(), interval_mul(), pg_size_pretty(), power_var(), power_var_int(), range_gist_picksplit(), remove_gene(), restore(), rt_cube_size(), rt_seg_size(), and seg_size().
#define Assert | ( | condition | ) | ((void)true) |
Definition at line 804 of file c.h.
Referenced by _bt_afternewitemoff(), _bt_begin_parallel(), _bt_binsrch(), _bt_binsrch_insert(), _bt_binsrch_posting(), _bt_bottomupdel_finish_pending(), _bt_bottomupdel_pass(), _bt_buildadd(), _bt_check_natts(), _bt_check_rowcompare(), _bt_check_unique(), _bt_checkkeys(), _bt_clear_incomplete_split(), _bt_compare(), _bt_compare_scankey_args(), _bt_deadblocks(), _bt_dedup_finish_pending(), _bt_dedup_pass(), _bt_dedup_save_htid(), _bt_dedup_start_pending(), _bt_delete_or_dedup_one_page(), _bt_delitems_cmp(), _bt_delitems_delete(), _bt_delitems_delete_check(), _bt_delitems_update(), _bt_delitems_vacuum(), _bt_doinsert(), _bt_endpoint(), _bt_find_extreme_element(), _bt_findinsertloc(), _bt_findsplitloc(), _bt_finish_split(), _bt_first(), _bt_fix_scankey_strategy(), _bt_form_posting(), _bt_getbuf(), _bt_getroot(), _bt_getrootheight(), _bt_insert_parent(), _bt_insertonpg(), _bt_interval_edges(), _bt_keep_natts(), _bt_killitems(), _bt_load(), _bt_lock_subtree_parent(), _bt_mark_page_halfdead(), _bt_mark_scankey_required(), _bt_metaversion(), _bt_mkscankey(), _bt_newroot(), _bt_pagedel(), _bt_preprocess_array_keys(), _bt_preprocess_keys(), _bt_readpage(), _bt_recsplitloc(), _bt_relandgetbuf(), _bt_restore_array_keys(), _bt_restore_meta(), _bt_rightsib_halfdeadflag(), _bt_saveitem(), _bt_search(), _bt_search_insert(), _bt_set_cleanup_info(), _bt_setuppostingitems(), _bt_simpledel_pass(), _bt_slideleft(), _bt_sort_dedup_finish_pending(), _bt_split(), _bt_start_array_keys(), _bt_steppage(), _bt_swap_posting(), _bt_truncate(), _bt_unlink_halfdead_page(), _bt_update_posting(), _bt_upgrademetapage(), _bt_uppershutdown(), _equalList(), _h_indexbuild(), _hash_addovflpage(), _hash_binsearch(), _hash_binsearch_last(), _hash_doinsert(), _hash_expandtable(), _hash_finish_split(), _hash_first(), _hash_freeovflpage(), _hash_getbucketbuf_from_hashkey(), _hash_getcachedmetap(), _hash_init_metabuffer(), _hash_kill_items(), _hash_load_qualified_items(), _hash_readnext(), _hash_readpage(), _hash_readprev(), _hash_splitbucket(), _hash_squeezebucket(), _int_matchsel(), _mdfd_getseg(), _mdfd_openseg(), _ShowOption(), _SPI_execute_plan(), _SPI_find_ENR_by_name(), _SPI_make_plan_non_temp(), _SPI_prepare_plan(), _SPI_save_plan(), _tarReadRaw(), AbortBufferIO(), AbortOutOfAnyTransaction(), AbortStrongLockAcquire(), AbortTransaction(), accum_sum_carry(), accum_sum_final(), accum_sum_rescale(), accumArrayResult(), accumArrayResultArr(), aclparse(), aclupdate(), acquire_inherited_sample_rows(), acquire_sample_rows(), AcquireRewriteLocks(), activate_interpreter(), ActivateCommitTs(), add_abs(), add_child_join_rel_equivalences(), add_child_rel_equivalences(), add_eq_member(), add_exact_object_address(), add_foreign_final_paths(), add_foreign_grouping_paths(), add_foreign_ordered_paths(), add_join_rel(), add_local_reloption(), add_merged_range_bounds(), add_module_to_inline_search_path(), add_object_address(), add_part_relids(), add_partial_path(), add_paths_to_append_rel(), add_paths_to_grouping_rel(), add_rtes_to_flat_rtable(), add_vars_to_targetlist(), addArcs(), AddCatcacheInvalidationMessage(), addConstrChildIdxDeps(), AddEventToPendingNotifies(), addItemPointersToLeafTuple(), addItemsToLeaf(), addOrReplaceTuple(), AddPendingSync(), AddQual(), addRangeTableEntry(), addRangeTableEntryForCTE(), addRangeTableEntryForENR(), addRangeTableEntryForFunction(), addRangeTableEntryForJoin(), addRangeTableEntryForRelation(), addRangeTableEntryForSubquery(), addRangeTableEntryForTableFunc(), addRangeTableEntryForValues(), AddRelationNewConstraints(), addressOK(), AddRoleMems(), addTargetToSortList(), AddWaitEventToSet(), adjacent_cmp_bounds(), adjust_appendrel_attrs(), adjust_appendrel_attrs_multilevel(), adjust_appendrel_attrs_mutator(), adjust_inherited_tlist(), adjust_partition_tlist(), adjust_paths_for_srfs(), advance_windowaggregate(), advance_windowaggregate_base(), advanceConnectionState(), AdvanceNextFullTransactionIdPastXid(), AdvanceXLInsertBuffer(), afterTriggerAddEvent(), AfterTriggerBeginXact(), afterTriggerDeleteHeadEventChunk(), AfterTriggerEndQuery(), AfterTriggerEndSubXact(), AfterTriggerEnlargeQueryState(), AfterTriggerFireDeferred(), AfterTriggerSaveEvent(), agg_refill_hash_table(), agg_retrieve_direct(), AggregateCreate(), alloc_object(), AllocateVfd(), AllocSetAlloc(), AllocSetContextCreateInternal(), AllocSetDelete(), AllocSetFreeIndex(), AllocSetReset(), AllocSetStats(), AlterObjectNamespace_internal(), AlterObjectOwner_internal(), AlterObjectRename_internal(), AlterPolicy(), AlterPublicationTables(), AlterRelationNamespaceInternal(), AlterSchemaOwner_internal(), AlterSeqNamespaces(), AlterSequence(), AlterStatistics(), AlterSubscription(), AlterTableNamespaceInternal(), analyze_row_processor(), analyzeCTE(), analyzeCTETargetList(), appendBinaryStringInfo(), appendBinaryStringInfoNT(), appendElement(), appendGroupByClause(), appendKey(), appendOrderByClause(), AppendSeconds(), appendStringInfoRegexpSubstr(), appendStringInfoStringQuoted(), appendStringInfoVA(), AppendStringToManifest(), appendValue(), apply_child_basequals(), apply_handle_commit(), apply_handle_stream_abort(), apply_handle_stream_commit(), apply_handle_stream_start(), apply_handle_stream_stop(), apply_handle_tuple_routing(), apply_handle_update(), apply_scanjoin_target_to_paths(), apply_tlist_labeling(), apply_typmod_special(), ApplyLauncherMain(), applyLockingClause(), ApplyLogicalMappingFile(), applyRemoteGucs(), ApplyRetrieveRule(), approximate_joinrel_size(), apw_load_buffers(), array_agg_array_finalfn(), array_agg_finalfn(), array_bitmap_copy(), array_cmp(), array_create_iterator(), array_dim_to_json(), array_dim_to_jsonb(), array_fill_internal(), array_get_element_expanded(), array_out(), array_prepend(), array_set_element_expanded(), array_set_slice(), array_subscript_fetch(), array_subscript_fetch_slice(), array_subscript_transform(), ArrayCastAndSet(), ArrayGetNItems(), ascii(), AssertChangeLsnOrder(), AssertTXNLsnOrder(), assign_aggregate_collations(), assign_collations_walker(), assign_hypothetical_collations(), assign_param_for_placeholdervar(), assign_record_type_identifier(), assign_record_type_typmod(), assign_record_var(), assign_simple_var(), AssignTransactionId(), asyncQueueAdvance(), asyncQueueAdvanceTail(), asyncQueueFillWarning(), asyncQueueNotificationToEntry(), asyncQueuePageDiff(), asyncQueueReadAllNotifications(), asyncQueueUnregister(), ATAddCheckConstraint(), ATAddForeignKeyConstraint(), AtCleanup_Memory(), AtCleanup_Portals(), ATColumnChangeRequiresRewrite(), AtCommit_Memory(), ATDetachCheckNoForeignKeyRefs(), AtEOSubXact_cleanup(), AtEOSubXact_Inval(), AtEOSubXact_PgStat(), AtEOXact_Buffers(), AtEOXact_cleanup(), AtEOXact_GUC(), AtEOXact_Inval(), AtEOXact_PgStat(), AtEOXact_RelationCache(), AtEOXact_RelationMap(), AtEOXact_SMgr(), AtEOXact_Snapshot(), ATExecAddColumn(), ATExecAddConstraint(), ATExecAddIndex(), ATExecAddIndexConstraint(), ATExecAlterColumnType(), ATExecAttachPartition(), ATExecCmd(), ATExecDetachPartition(), ATExecDropColumn(), ATExecSetStatistics(), ATExecSetStorage(), ATExecSetTableSpace(), ATExecSetTableSpaceNoStorage(), AtPrepare_PgStat(), AtPrepare_PredicateLocks(), ATPrepCmd(), ATPrepDropNotNull(), ATRewriteTable(), AtStart_Memory(), AtStart_ResourceOwner(), AtSubAbort_Memory(), AtSubAbort_Snapshot(), AtSubCleanup_Memory(), AtSubCommit_childXids(), AtSubCommit_Memory(), AtSubCommit_Notify(), AtSubStart_Memory(), AtSubStart_ResourceOwner(), attach_internal(), AttachSerializableXact(), ATTypedTableRecursion(), auth_peer(), autoprewarm_database_main(), AutoVacuumShmemInit(), AuxiliaryProcKill(), avl_sigusr2_handler(), backend_read_statsfile(), BackendRun(), BackgroundWorkerShmemInit(), BackgroundWorkerUnblockSignals(), BarrierArriveAndDetachExceptLast(), BarrierArriveAndWait(), BarrierAttach(), BarrierDetachImpl(), base_yylex(), BaseBackup(), be_gssapi_read(), be_gssapi_write(), be_lo_from_bytea(), be_lo_put(), be_tls_open_server(), BecomeLockGroupLeader(), BecomeLockGroupMember(), begin_cb_wrapper(), begin_parallel_vacuum(), begin_prepare_cb_wrapper(), BeginCopyFrom(), BeginCopyTo(), beginmerge(), BeginStrongLockAcquire(), BgBufferSync(), binaryheap_first(), binaryheap_remove_first(), binaryheap_replace_first(), bitmap_hash(), bitmap_match(), BitmapHeapNext(), blbulkdelete(), blinsert(), BlockSampler_Next(), BloomFillMetapage(), BloomInitMetapage(), BloomPageAddItem(), blowfish_decrypt_cbc(), blowfish_decrypt_ecb(), blowfish_encrypt_cbc(), blowfish_encrypt_ecb(), blowfish_setkey(), bootstrap_signals(), BootStrapCLOG(), BootstrapModeMain(), BootStrapMultiXact(), BootStrapSUBTRANS(), BootStrapXLOG(), bottomup_nblocksfavorable(), bottomup_sort_and_shrink(), bounds_adjacent(), bpchar(), brin_doinsert(), brin_doupdate(), brin_evacuate_page(), brin_form_tuple(), brin_free_desc(), brin_getinsertbuffer(), brin_inclusion_add_value(), brin_inclusion_consistent(), brin_inclusion_union(), brin_minmax_consistent(), brin_minmax_union(), brin_xlog_createidx(), brin_xlog_insert_update(), brin_xlog_revmap_extend(), brinbuild(), brincostestimate(), bringetbitmap(), brinGetTupleForHeapBlock(), brinRevmapExtend(), brinsummarize(), bt_check_every_level(), bt_check_level_from_leftmost(), bt_child_check(), bt_downlink_missing_check(), bt_normalize_tuple(), bt_page_print_tuples(), bt_posting_plain_tuple(), bt_rootdescend(), bt_tuple_present_callback(), btbeginscan(), btcostestimate(), BTPageGetDeleteXid(), BTPageIsRecyclable(), btparallelrescan(), btree_xlog_dedup(), btree_xlog_insert(), btree_xlog_split(), btree_xlog_unlink_page(), BTreeShmemInit(), BTreeTupleGetHeapTIDCareful(), BTreeTupleGetMaxHeapTID(), BTreeTupleGetNPosting(), BTreeTupleGetPostingOffset(), BTreeTupleSetNAtts(), BTreeTupleSetPosting(), btvacuumcleanup(), btvacuumpage(), BufferAlloc(), BufferGetBlockNumber(), BufferGetLSNAtomic(), BufferGetTag(), BufferIsPermanent(), BufferSync(), BufFileAppend(), BufFileCreateTemp(), BufFileDumpBuffer(), BufFileExportShared(), BufFileFlush(), BufFileRead(), BufFileSize(), BufFileWrite(), BufTableInsert(), build_attnums_array(), build_child_join_rel(), build_client_first_message(), build_coercion_expression(), build_column_frequencies(), build_distinct_groups(), build_function_result_tupdesc_d(), build_function_result_tupdesc_t(), build_hash_table(), build_hash_tables(), build_index_paths(), build_join_rel(), build_join_rel_hash(), build_joinrel_partition_info(), build_merged_partition_bounds(), build_minmax_path(), build_partition_pathkeys(), build_pertrans_for_aggref(), build_regexp_match_result(), build_regexp_split_result(), build_reloptions(), build_remote_returning(), build_replindex_scan_key(), build_row_from_vars(), build_simple_rel(), build_sorted_items(), build_subplan(), build_test_match_result(), buildACLCommands(), BuildCachedPlan(), BuildDescFromLists(), BuildIndexValueDescription(), buildMatViewRefreshDependencies(), buildNSItemFromLists(), buildNSItemFromTupleDesc(), buildRelationAliases(), BuildRelationExtStatistics(), BuildSpeculativeIndexInfo(), buildSubPlanHash(), BuildTupleHashTableExt(), buildVarFromNSColumn(), buildWorkerCommand(), bytea_string_agg_finalfn(), CachedPlanAllowsSimpleValidityCheck(), CachedPlanGetTargetList(), CachedPlanIsSimplyValid(), CachedPlanIsValid(), CachedPlanSetParentContext(), calc_hist_selectivity(), calc_inet_union_params(), calc_inet_union_params_indexed(), calc_length_hist_frac(), calc_nestloop_required_outer(), calc_non_nestloop_required_outer(), calcstrlen(), CallSyscacheCallbacks(), can_minmax_aggs(), canonicalize_qual(), CatalogCacheComputeTupleHashValue(), CatalogCacheCreateEntry(), CatalogCacheInitializeCache(), CatalogIndexInsert(), CatCacheFreeKeys(), CatCacheInvalidate(), CatCacheRemoveCList(), CatCacheRemoveCTup(), change_cb_wrapper(), ChangeVarNodes_walker(), char2wchar(), check_agglevels_and_constraints(), check_circularity(), check_cluster_versions(), check_for_freed_segments_locked(), check_foreign_key(), check_generic_type_consistency(), check_index_predicates(), check_new_partition_bound(), check_of_type(), check_relation_privileges(), check_sql_fn_retval(), check_srf_call_placement(), check_timezone_abbreviations(), check_ungrouped_columns_walker(), CheckCachedPlan(), checkclass_str(), checkDataDir(), CheckDateTokenTables(), CheckDeadLock(), CheckForBufferLeaks(), CheckForLocalBufferLeaks(), CheckForSerializableConflictOut(), CheckIndexCompatible(), checkMatch(), CheckOpSlotCompatibility(), CheckPWChallengeAuth(), CheckRADIUSAuth(), CheckRecoveryConflictDeadlock(), CheckRecoveryConsistency(), checkRuleResultList(), CheckSCRAMAuth(), CheckSelectLocking(), checkSplitConditions(), CheckTableForSerializableConflictIn(), CheckTargetForConflictsIn(), checkTempNamespaceStatus(), checkWellFormedRecursion(), checkXLogConsistency(), choose_bitmap_and(), choose_next_subplan_for_leader(), choose_next_subplan_for_worker(), choose_next_subplan_locally(), cidr_set_masklen_internal(), clean_NOT_intree(), clean_stopword_intree(), cleanup_rel_sync_cache(), CleanupInvalidationState(), CleanUpLock(), CleanupProcSignalState(), CleanupTempFiles(), ClearOldPredicateLocks(), ClientAuthentication(), clog_redo(), CloneArchive(), CloneForeignKeyConstraints(), close_destination_dir(), closeAllVfds(), CloseMatViewIncrementalMaintenance(), ClosePipeFromProgram(), ClosePipeToProgram(), cmpcmdflag(), coerce_function_result_tuple(), CollationCreate(), collectMatchesForHeapRow(), CommandIsReadOnly(), commit_cb_wrapper(), commit_prepared_cb_wrapper(), commit_ts_redo(), CommitTransaction(), CommitTransactionCommand(), CommitTsShmemInit(), commute_restrictinfo(), comp_keyword_case_hook(), compact_palloc0(), CompactCheckpointerRequestQueue(), compactify_tuples(), compareJsonbContainers(), comparetup_index_btree(), comparetup_index_hash(), compile_pltcl_function(), CompleteCachedPlan(), compute_array_stats(), compute_new_xmax_infomask(), compute_parallel_delay(), compute_partition_bounds(), compute_partition_hash_value(), compute_range_stats(), compute_return_type(), compute_scalar_stats(), compute_tsvector_stats(), computeDistance(), ComputeIndexAttrs(), ComputePartitionAttrs(), ComputeXidHorizons(), concat_internal(), conditional_stack_set_paren_depth(), conditional_stack_set_query_len(), ConditionalLockBuffer(), ConditionalLockBufferForCleanup(), ConditionalXactLockTableWait(), ConditionVariableBroadcast(), ConditionVariableTimedSleep(), connectDatabase(), ConnectDatabase(), connectOptions2(), consider_abort_common(), consider_groupingsets_paths(), consider_parallel_nestloop(), ConstraintSetParentConstraint(), ConstructTupleDescriptor(), contain_agg_clause_walker(), contain_outer_selfref(), convert_ANY_sublink_to_join(), convert_combining_aggrefs(), convert_EXISTS_sublink_to_join(), convert_EXISTS_to_ANY(), convert_int_from_base_unit(), convert_prep_stmt_params(), convert_real_from_base_unit(), convert_string_datum(), convert_subquery_pathkeys(), convertJsonbArray(), ConvertTimeZoneAbbrevs(), convertToJsonb(), cookDefault(), copy_plpgsql_datums(), copy_replication_slot(), copy_table(), copy_table_data(), CopyCachedPlan(), CopyErrorData(), CopyFrom(), CopyMultiInsertBufferCleanup(), CopyMultiInsertInfoNextFreeSlot(), CopyMultiInsertInfoStore(), CopyReadAttributesCSV(), CopyReadAttributesText(), CopyReadLine(), CopySnapshot(), CopyXLogRecordToWAL(), cost_agg(), cost_append(), cost_bitmap_heap_scan(), cost_ctescan(), cost_functionscan(), cost_gather_merge(), cost_incremental_sort(), cost_index(), cost_namedtuplestorescan(), cost_resultscan(), cost_samplescan(), cost_seqscan(), cost_subqueryscan(), cost_tablefuncscan(), cost_tidrangescan(), cost_tidscan(), cost_valuesscan(), count_distinct_groups(), count_nulls(), create_append_path(), create_append_plan(), create_bitmap_scan_plan(), create_bitmap_subplan(), create_ctescan_plan(), create_distinct_paths(), create_foreign_modify(), create_foreign_upper_path(), create_foreignscan_path(), create_foreignscan_plan(), create_functionscan_plan(), create_gather_merge_path(), create_gather_merge_plan(), create_gather_path(), create_gating_plan(), create_groupingsets_path(), create_groupingsets_plan(), create_hash_bounds(), create_hashjoin_plan(), create_index_paths(), create_indexscan_plan(), create_internal(), create_lateral_join_info(), create_LifetimeEnd(), create_list_bounds(), create_logical_replication_slot(), create_material_path(), create_merge_append_path(), create_merge_append_plan(), create_mergejoin_plan(), create_minmaxagg_plan(), create_modifytable_path(), create_namedtuplestorescan_plan(), create_ordered_paths(), create_ordinary_grouping_paths(), create_partial_grouping_paths(), create_partitionwise_grouping_paths(), create_physical_replication_slot(), create_plan(), create_plan_recurse(), create_range_bounds(), create_resultscan_plan(), create_samplescan_plan(), create_seqscan_plan(), create_subqueryscan_plan(), create_tablefuncscan_plan(), create_target(), create_tidrangescan_plan(), create_tidscan_plan(), create_toast_table(), create_unique_path(), create_unique_plan(), create_valuesscan_plan(), create_windowagg_plan(), create_worktablescan_plan(), CreateAnonymousSegment(), CreateAuxProcessResourceOwner(), CreateCachedPlan(), CreateConstraintEntry(), CreateFunction(), CreateLocalPredicateLockHash(), CreateOneShotCachedPlan(), CreateParallelContext(), createPartitions(), CreateProceduralLanguage(), CreatePublication(), CreateReplicationSlot(), CreateStatistics(), CreateSubscription(), CreateTrigger(), createViewAsClause(), dataBeginPlaceToPage(), dataBeginPlaceToPageLeaf(), DataChecksumsEnabled(), dataFindChildPtr(), dataGetLeftMostPage(), dataLeafPageGetUncompressed(), dataLocateItem(), dataPlaceToPageLeafRecompress(), dataPlaceToPageLeafSplit(), date_cmp_timestamp_internal(), datum_to_json(), datum_to_jsonb(), datum_write(), DatumGetAnyArrayP(), DatumGetEOHP(), DatumGetExpandedArray(), DatumGetExpandedArrayX(), DatumGetExpandedRecord(), datumGetSize(), datumRestore(), dbase_redo(), DCH_cache_getnew(), DCH_from_char(), DeadLockCheck(), decide_file_action(), decimalLength(), DeCloneArchive(), decode_varbyte(), DecodeDelete(), DecodeInterval(), DecodeMultiInsert(), decodePageSplitRecord(), DecodeXLogRecord(), DecodeXLogTuple(), deconstruct_array(), deconstruct_jointree(), deconstruct_recurse(), decr_dcc_refcount(), DecrementParentLocks(), DecrTupleDescRefCount(), define_custom_variable(), DefineAggregate(), DefineAttr(), DefineIndex(), DefineQueryRewrite(), DefineRange(), DefineRelation(), DefineSequence(), DefineType(), DefineVirtualRelation(), Delete(), delete_item(), DeleteChildTargetLocks(), DeleteExpandedObject(), DeleteLockTarget(), DeleteSecurityLabel(), DelRoleMems(), deparse_context_for_plan_tree(), deparseAggref(), deparseColumnRef(), deparseDistinctExpr(), deparseFromExpr(), deparseFromExprForRel(), deparseOpExpr(), deparseRangeTblRef(), deparseScalarArrayOpExpr(), deparseSelectStmtForRel(), deparseSortGroupClause(), deparseSubqueryTargetList(), dependency_degree(), DependencyGenerator_init(), describeOneTableDetails(), destroy_superblock(), determineRecursiveColTypes(), detoast_attr(), detoast_attr_slice(), detoast_external_attr(), dir_close(), dir_get_current_pos(), dir_realloc(), dir_sync(), dir_write(), disable_timeout(), disable_timeouts(), discard_query_text(), disconnect_cached_connections(), disconnectDatabase(), DiscreteKnapsack(), DisownLatch(), dist_ppath_internal(), distribute_qual_to_rels(), div_var(), div_var_fast(), dlist_head_element_off(), dlist_next_node(), dlist_pop_head_node(), dlist_prev_node(), dlist_tail_element_off(), do_compile(), do_connect(), do_numeric_discard(), do_pg_abort_backup(), do_pg_stop_backup(), do_pset(), do_start_bgworker(), do_to_timestamp(), DoCopy(), doDeletion(), doLog(), doPickSplit(), DoPortalRunFetch(), dopr(), double_to_shortest_decimal_buf(), DropAllPredicateLocksFromTable(), DropCachedPlan(), DropErrorMsgNonExistent(), DropErrorMsgWrongType(), DropReplicationSlot(), DropSubscription(), dsa_allocate_extended(), dsa_free(), dsa_get_address(), dsa_get_handle(), dsa_pin_mapping(), dsa_release_in_place(), dsa_unpin(), dshash_attach(), dshash_delete_entry(), dshash_delete_key(), dshash_destroy(), dshash_detach(), dshash_dump(), dshash_find(), dshash_find_or_insert(), dshash_get_hash_table_handle(), dshash_release_lock(), dsm_attach(), dsm_backend_startup(), dsm_create(), dsm_detach(), dsm_impl_op(), dsm_postmaster_startup(), dsm_segment_address(), dsm_segment_map_length(), dsm_unpin_mapping(), dsm_unpin_segment(), dummy_ssl_passwd_cb(), dumpTableData(), dumpTableSchema(), dumptuples(), DynaHashAlloc(), EA_flatten_into(), EA_get_flat_size(), each_worker_jsonb(), ec_member_matches_indexcol(), echo_hidden_hook(), echo_hook(), eclass_useful_for_merging(), ECPGconnect(), editFile(), eliminate_duplicate_dependencies(), enable_statement_timeout(), enable_timeout(), EnableDisableRule(), EnablePortalManager(), EnableSyncRequestForwarding(), EncodeDateOnly(), EncodeDateTime(), end_parallel_vacuum(), EndParallelWorkerTransaction(), EndPrepare(), EndTransactionBlock(), enforce_generic_type_consistency(), enlarge_list(), ENRMetadataGetTupDesc(), ensure_active_superblock(), EnterParallelMode(), entry_alloc(), entryFindChildPtr(), entryGetItem(), entryGetLeftMostPage(), entryIsEnoughSpace(), entryLocateEntry(), entryLocateLeafEntry(), entryPreparePage(), enum_cmp_internal(), ER_flatten_into(), ER_get_flat_size(), esc_decode(), esc_encode(), estimate_multivariate_ndistinct(), estimate_num_groups(), estimate_path_cost_size(), EstimateSnapshotSpace(), eval_const_expressions_mutator(), eval_windowaggregates(), evalLazyFunc(), EvalPlanQual(), EvalPlanQualFetchRowMark(), EvalPlanQualSlot(), EvalPlanQualStart(), evalStandardFunc(), EventTriggerCollectAlterTableSubcmd(), EventTriggerSQLDropAddObject(), examine_clause_args(), examine_simple_variable(), examine_variable(), exec_check_rw_parameter(), exec_command_endif(), exec_describe_statement_message(), exec_eval_simple_expr(), exec_execute_message(), exec_move_row_from_datum(), exec_move_row_from_fields(), exec_replication_command(), exec_run_select(), exec_save_simple_expr(), exec_simple_check_plan(), exec_stmt_assign(), exec_stmt_block(), exec_stmt_call(), exec_stmt_execsql(), exec_stmt_forc(), exec_stmt_return_query(), ExecAggTransReparent(), ExecAlterExtensionContentsStmt(), ExecAlterObjectDependsStmt(), ExecAlterObjectSchemaStmt(), ExecAlterOwnerStmt(), ExecAppend(), ExecARDeleteTriggers(), ExecASUpdateTriggers(), ExecBitmapHeapInitializeWorker(), ExecBRDeleteTriggers(), ExecBRUpdateTriggers(), ExecBSUpdateTriggers(), ExecBuildAggTrans(), ExecBuildAggTransCall(), ExecBuildGroupingEqual(), ExecCallTriggerFunc(), ExecCheck(), ExecCheckRTPerms(), ExecCheckTupleVisible(), ExecChooseHashTableSize(), ExecCloseResultRelations(), ExecComputeSlotInfo(), ExecComputeStoredGenerated(), ExecConstraints(), ExecCopySlot(), ExecCopySlotHeapTuple(), ExecCreatePartitionPruneState(), ExecCreateTableAs(), execCurrentOf(), ExecCustomScan(), ExecDelete(), ExecDropSingleTupleTableSlot(), ExecEndAgg(), ExecEndCustomScan(), ExecEvalConvertRowtype(), ExecEvalFieldSelect(), ExecEvalFuncArgs(), ExecEvalMinMax(), ExecEvalParamExec(), ExecEvalStepOp(), ExecEvalWholeRowVar(), ExecEvalXmlExpr(), ExecFetchSlotHeapTuple(), ExecFetchSlotMinimalTuple(), ExecFindInitialMatchingSubPlans(), ExecFindMatchingSubPlans(), ExecFindPartition(), ExecGetJunkAttribute(), ExecGetRangeTableRelation(), ExecHashIncreaseNumBatches(), ExecHashIncreaseNumBuckets(), ExecHashJoinImpl(), ExecHashRemoveNextSkewBucket(), ExecHashSkewTableInsert(), ExecHashSubPlanResultRelsByOid(), ExecHashTableCreate(), ExecHashTableDetachBatch(), ExecHashTableInsert(), ExecIncrementalSort(), ExecIndexBuildScanKeys(), ExecIndexMarkPos(), ExecIndexOnlyMarkPos(), ExecIndexOnlyRestrPos(), ExecIndexRestrPos(), ExecInitAgg(), ExecInitAppend(), ExecInitBitmapAnd(), ExecInitBitmapHeapScan(), ExecInitBitmapIndexScan(), ExecInitBitmapOr(), ExecInitCheck(), ExecInitCteScan(), ExecInitExprRec(), ExecInitForeignScan(), ExecInitFunctionResultSet(), ExecInitFunctionScan(), ExecInitGather(), ExecInitGatherMerge(), ExecInitGroup(), ExecInitHash(), ExecInitHashJoin(), ExecInitIncrementalSort(), ExecInitIndexScan(), ExecInitJunkFilterInsertion(), ExecInitLimit(), ExecInitLockRows(), ExecInitMergeAppend(), ExecInitMergeJoin(), ExecInitModifyTable(), ExecInitNamedTuplestoreScan(), ExecInitNestLoop(), ExecInitNode(), ExecInitPartitionDispatchInfo(), ExecInitPartitionInfo(), ExecInitProjectSet(), ExecInitPruningContext(), ExecInitQual(), ExecInitRecursiveUnion(), ExecInitResult(), ExecInitRoutingInfo(), ExecInitSampleScan(), ExecInitSeqScan(), ExecInitSetOp(), ExecInitSubPlan(), ExecInitSubqueryScan(), ExecInitSubscriptingRef(), ExecInitTableFuncScan(), ExecInitUnique(), ExecInitValuesScan(), ExecInitWindowAgg(), ExecInitWorkTableScan(), ExecInsert(), ExecInsertIndexTuples(), ExecInterpExpr(), ExecJustAssignVarVirtImpl(), ExecJustVarVirtImpl(), ExecLimit(), ExecLockRows(), ExecMakeTableFunctionResult(), ExecMaterial(), ExecMaterialMarkPos(), ExecMaterialRestrPos(), ExecMergeJoin(), ExecModifyTable(), ExecNestLoop(), ExecOnConflictUpdate(), ExecParallelCreateReaders(), ExecParallelHashFirstTuple(), ExecParallelHashIncreaseNumBatches(), ExecParallelHashIncreaseNumBuckets(), ExecParallelHashJoinPartitionOuter(), ExecParallelHashJoinSetUpBatches(), ExecParallelHashNextTuple(), ExecParallelHashRepartitionFirst(), ExecParallelHashTableInsert(), ExecParallelHashTableInsertCurrentBatch(), ExecParallelHashTableSetCurrentBatch(), ExecParallelHashTupleAlloc(), ExecParallelHashTuplePrealloc(), ExecParallelReinitialize(), ExecParallelReportInstrumentation(), ExecProjectSRF(), ExecQual(), ExecQueryUsingCursor(), ExecReadyInterpretedExpr(), ExecRefreshMatView(), ExecRenameStmt(), ExecReScanCustomScan(), ExecReScanHashJoin(), ExecRunCompiledExpr(), ExecScanFetch(), ExecScanReScan(), ExecScanSubPlan(), ExecSetParamPlan(), ExecSetParamPlanMulti(), ExecSetSlotDescriptor(), ExecSetVariableStmt(), ExecSimpleRelationInsert(), ExecSimpleRelationUpdate(), ExecSort(), ExecStoreAllNullTuple(), ExecStoreBufferHeapTuple(), ExecStoreHeapTuple(), ExecStoreMinimalTuple(), ExecStorePinnedBufferHeapTuple(), ExecStoreVirtualTuple(), ExecSupportsMarkRestore(), execTuplesHashPrepare(), ExecUpdate(), execute_attr_map_slot(), execute_attr_map_tuple(), execute_foreign_modify(), executeAnyItem(), ExecuteCallStmt(), executeItemOptUnwrapResult(), executeItemOptUnwrapTarget(), executeItemUnwrapTargetArray(), executeJsonPath(), executeKeyValueMethod(), executeMetaCommand(), ExecuteRecoveryCommand(), ExecuteTruncateGuts(), ExecutorRewind(), ExecVacuum(), ExecWindowAgg(), ExecWorkTableScan(), exitArchiveRecovery(), ExitParallelMode(), expand_all_col_privileges(), expand_appendrel_subquery(), expand_array(), expand_grouping_sets(), expand_groupingset_node(), expand_inherited_rtentry(), expand_partitioned_rtentry(), expand_planner_arrays(), expand_single_inheritance_child(), expand_table(), expand_tuple(), expand_vacuum_rel(), ExpandAllTables(), ExpandColumnRefStar(), ExpandConstraints(), expanded_record_set_field_internal(), expanded_record_set_fields(), expanded_record_set_tuple(), expandNSItemAttrs(), expandNSItemVars(), expandRecordVariable(), ExpandRowReference(), expandRTE(), expandTableLikeClause(), expandTupleDesc(), ExpireTreeKnownAssignedTransactionIds(), ExplainCloseWorker(), ExplainIndentText(), ExplainJSONLineEnding(), ExplainOnePlan(), ExplainOneUtility(), ExplainOpenWorker(), ExplainPrintPlan(), ExplainQuery(), ExplainTargetRel(), ExplainYAMLLineStarting(), exprCollation(), exprSetCollation(), exprType(), exprTypmod(), extendBufFile(), ExtendCommitTs(), extract_actual_join_clauses(), extract_autovac_opts(), extract_grouping_ops(), extract_lateral_references(), extract_or_clause(), extract_query_dependencies_walker(), extract_restriction_or_clauses(), extract_rollup_sets(), extract_variadic_args(), extractPageMap(), extractRelOptions(), ExtractReplicaIdentity(), FastPathGrantRelationLock(), FastPathUnGrantRelationLock(), fetch_fp_info(), fetch_more_data(), fetch_remote_table_info(), fetch_statentries_for_relation(), fetch_table_list(), fetch_tuple_flag(), FetchDynamicTimeZone(), FetchPreparedStatementResultDesc(), FetchStatementTargetList(), file_acquire_sample_rows(), FileClose(), FileGetRawDesc(), FileGetRawFlags(), FileGetRawMode(), FilePathName(), FilePrefetch(), FileRead(), FileSize(), FileSync(), FileTruncate(), FileWrite(), FileWriteback(), fill_hba_line(), fill_in_constant_lengths(), fill_seq_with_data(), fill_val(), fillJsonbValue(), fillQT(), filter_by_origin_cb_wrapper(), filter_prepare_cb_wrapper(), final_cost_hashjoin(), finalize_aggregates(), finalize_grouping_exprs_walker(), finalize_plan(), find_base_rel(), find_childrel_parents(), find_cols_walker(), find_dependent_phvs_walker(), find_derived_clause_for_ec_member(), find_lateral_references(), find_multixact_start(), find_option(), find_or_make_matching_shared_tupledesc(), find_param_referent(), find_partition_scheme(), find_placeholder_info(), find_placeholders_in_jointree(), find_update_path(), find_var_for_subquery_tle(), find_window_functions_walker(), findeq(), findJsonbValueFromContainer(), FindLockCycleRecurse(), FindLockCycleRecurseMember(), findoprnd_recurse(), FindReplTupleInLocalRel(), finish_foreign_modify(), FinishPreparedTransaction(), fix_alternative_subplan(), fix_append_rel_relids(), fix_expr_common(), fix_indexqual_clause(), fix_indexqual_operand(), fix_merged_indexes(), fix_scan_expr_mutator(), fix_scan_expr_walker(), flagInhIndexes(), FlagRWConflict(), FlagSxactUnsafe(), flatCopyTargetEntry(), flatten_join_alias_vars_mutator(), flatten_set_variable_args(), flatten_simple_union_all(), float_to_shortest_decimal_buf(), FlushOneBuffer(), FlushRelationsAllBuffers(), fmgr_sql(), for_each_from_setup(), foreign_grouping_ok(), foreign_join_ok(), ForgetBackgroundWorker(), ForgetPrivateRefCountEntry(), ForgetUnstartedBackgroundWorkers(), format_numeric_locale(), format_operator_extended(), format_procedure_extended(), FormIndexDatum(), FormPartitionKeyDatum(), free_plperl_function(), FreeCachedExpression(), freeHyperLogLog(), FreePageBtreeAdjustAncestorKeys(), FreePageBtreeCleanup(), FreePageBtreeConsolidate(), FreePageBtreeFindLeftSibling(), FreePageBtreeFindRightSibling(), FreePageBtreeFirstKey(), FreePageBtreeGetRecycled(), FreePageBtreeInsertInternal(), FreePageBtreeInsertLeaf(), FreePageBtreeRemove(), FreePageBtreeRemovePage(), FreePageBtreeSearch(), FreePageBtreeSearchInternal(), FreePageBtreeSearchLeaf(), FreePageBtreeSplitPage(), FreePageBtreeUpdateParentPointers(), FreePageManagerGet(), FreePageManagerGetInternal(), FreePageManagerPut(), FreePageManagerPutInternal(), FreePagePopSpanLeader(), FreeQueryDesc(), FreeSnapshot(), FreeTupleDesc(), FreezeMultiXactId(), from_char_parse_int_len(), fsm_get_avail(), fsm_get_child(), fsm_get_heap_blk(), fsm_get_parent(), fsm_set_avail(), fsm_space_avail_to_cat(), fsm_truncate_avail(), fsm_vacuum_page(), FullXidRelativeTo(), func_get_detail(), FuncnameGetCandidates(), function_parse_error_transpose(), gather_merge_init(), gather_merge_readnext(), gather_readnext(), gbt_inet_compress(), gbt_inet_consistent(), gbt_num_compress(), gbt_num_fetch(), gen_partprune_steps_internal(), gen_prune_step_op(), gen_prune_steps_from_opexps(), generate_append_tlist(), generate_base_implied_equalities(), generate_base_implied_equalities_const(), generate_base_implied_equalities_no_const(), generate_bitmap_or_paths(), generate_function_name(), generate_implied_equalities_for_column(), generate_join_implied_equalities(), generate_join_implied_equalities_for_ecs(), generate_matching_part_pairs(), generate_mergejoin_paths(), generate_normalized_query(), generate_operator_clause(), generate_orderedappend_paths(), generate_partition_qual(), generate_partitionwise_join_paths(), generate_recursion_path(), generate_setop_grouplist(), generate_setop_tlist(), generate_union_paths(), generate_useful_gather_paths(), generateClonedExtStatsStmt(), generateClonedIndexStmt(), GenerateRecoveryConfig(), GenerationAlloc(), GenerationFree(), GenerationReset(), GenerationStats(), generator_init(), generic_redo(), geqo_eval(), get_actual_clauses(), get_actual_variable_range(), get_agg_expr(), get_aggregate_argtypes(), get_appendrel_parampathinfo(), get_baserel_parampathinfo(), get_best_segment(), get_catalog_object_by_oid(), get_cheapest_parameterized_child_path(), get_code_decomposition(), get_configdata(), get_delete_query_def(), get_destination_dir(), get_eclass_for_sort_expr(), get_eclass_indexes_for_relids(), get_ENR(), get_expr_result_type(), get_from_clause_coldeflist(), get_func_arg_info(), get_func_result_name(), get_func_signature(), get_func_sql_syntax(), get_function_rows(), get_hash_mem(), get_hash_partition_greatest_modulus(), get_index_column_opclass(), get_insert_query_def(), get_join_index_paths(), get_joinrel_parampathinfo(), get_loop_count(), get_matching_hash_bounds(), get_matching_list_bounds(), get_matching_part_pairs(), get_matching_partitions(), get_matching_range_bounds(), get_merged_range_bounds(), get_name_for_var_field(), get_number_of_groups(), get_object_address(), get_object_namespace(), get_op_btree_interpretation(), get_parallel_object_list(), get_path_all(), get_qual_for_list(), get_qual_from_partbound(), get_range_partition(), get_range_partition_internal(), get_record_type_from_query(), get_rel_data_width(), get_rel_sync_entry(), get_relation_foreign_keys(), get_relation_info(), get_rels_with_domain(), get_returning_data(), get_rewrite_oid(), get_rolespec_oid(), get_rolespec_tuple(), get_row_security_policies(), get_rtable_name(), get_rte_attribute_is_dropped(), get_rule_expr(), get_rule_sortgroupclause(), get_rule_windowspec(), get_segment_by_index(), get_setop_query(), get_singleton_append_subpath(), get_steps_using_prefix(), get_steps_using_prefix_recurse(), get_switched_clauses(), get_tablespace_page_costs(), get_text_array_contents(), get_update_query_def(), get_update_query_targetlist_def(), get_useful_ecs_for_relation(), get_variable(), get_view_query(), get_visible_ENR_metadata(), get_worker(), GetActiveSnapshot(), GetAfterTriggersTableData(), GetBackgroundWorkerPid(), getBaseTypeAndTypmod(), GetBlockerStatusData(), GetCachedPlan(), GetConfigOptionByNum(), GetConnection(), GetCTEForRTE(), GetCurrentCommandId(), GetDatabasePath(), GetExistingLocalJoinPath(), getExponentialRand(), getGaussianRand(), gethba_options(), getid(), getInsertSelectQuery(), getJsonPathVariable(), getKeyJsonValueFromContainer(), GetLatestSnapshot(), GetLocalBufferStorage(), GetLockmodeName(), GetLocksMethodTable(), GetLockStatusData(), GetLockTagsMethodTable(), GetLWLockIdentifier(), GetMemoryChunkContext(), getMessageFromWorker(), getmissingattr(), GetMockAuthenticationNonce(), GetMultiXactIdMembers(), GetNewObjectId(), GetNewOidWithIndex(), GetNewRelFileNode(), GetNewTransactionId(), GetNSItemByRangeTablePosn(), getObjectDescription(), getObjectIdentityParts(), GetOldestActiveTransactionId(), GetOldestSafeDecodingTransactionId(), GetOldSnapshotFromTimeMapping(), GetOverrideSearchPath(), GetParentPredicateLockTag(), GetPredicateLockStatusData(), GetPrivateRefCount(), GetPrivateRefCountEntry(), GetPublicationRelations(), GetRealCmax(), GetRealCmin(), GetRelationPath(), getRootTableInfo(), GetRTEByRangeTablePosn(), GetRunningTransactionData(), GetRunningTransactionLocks(), GetSafeSnapshot(), getScalar(), GetSerializableTransactionSnapshot(), GetSerializableTransactionSnapshotInt(), GetSnapshotData(), GetSnapshotDataReuse(), GetStableLatestTransactionId(), GetSubscription(), GetSysCacheOid(), GetSystemIdentifier(), GetTableAmRoutine(), GetTableInfo(), GetTempTablespaces(), GetTempToastNamespace(), getTimelineHistory(), gettoken_tsvector(), GetTransactionSnapshot(), GetTupleForTrigger(), GetTypeCollations(), getVariable(), GetVisibilityMapPins(), GetXLogBuffer(), GetXLogReceiptTime(), getZipfianRand(), gin_consistent_jsonb(), gin_consistent_jsonb_path(), gin_trgm_triconsistent(), gin_triconsistent_jsonb(), gin_triconsistent_jsonb_path(), ginbeginscan(), ginbulkdelete(), ginCombineData(), ginCompressPostingList(), gincost_pattern(), gincost_scalararrayopexpr(), GinDataPageAddPostingItem(), ginDeletePage(), ginFindLeafPage(), ginFindParents(), ginFinishSplit(), GinFormTuple(), ginGetBAEntry(), ginHeapTupleFastInsert(), ginInsertBAEntries(), ginInsertCleanup(), GinPageDeletePostingItem(), ginPlaceToPage(), ginPostingListDecodeAllSegments(), ginRedoDeleteListPages(), ginRedoDeletePage(), ginRedoInsert(), ginRedoInsertData(), ginRedoInsertEntry(), ginRedoInsertListPage(), ginRedoRecompress(), ginRedoUpdateMetapage(), ginRedoVacuumDataLeafPage(), ginScanToDelete(), gintuple_get_attrnum(), ginvacuumcleanup(), ginVacuumPostingTreeLeaves(), gist_box_picksplit(), gist_point_consistent(), gistbufferinginserttuples(), gistbuild(), gistchoose(), gistdeletepage(), gistdoinsert(), gistFindPath(), gistfinishsplit(), gistfixsplit(), gistGetFakeLSN(), gistGetItupFromPage(), gistindex_keytest(), gistkillitems(), gistMemorizeAllDownlinks(), GistPageGetDeleteXid(), GistPageSetDeleted(), gistPlaceItupToPage(), gistplacetopage(), gistPopItupFromNodeBuffer(), gistProcessItup(), gistprunepage(), gistRedoPageSplitRecord(), gistRedoPageUpdateRecord(), gistRelocateBuildBuffersOnSplit(), gistrescan(), gistScanPage(), gistSplit(), gistSplitByKey(), gistUserPicksplit(), gistvacuum_delete_empty_pages(), GlobalVisTestFor(), GlobalVisTestIsRemovableFullXid(), GrantLock(), GrantLockLocal(), group_by_has_partkey(), grouping_planner(), gtsvector_same(), GUCArrayAdd(), GUCArrayDelete(), handle_streamed_transaction(), HandleSlashCmds(), HandleWalSndInitStopping(), hash_agg_enter_spill_mode(), hash_array(), hash_array_extended(), hash_create(), hash_destroy(), hash_get_shared_size(), hash_inner_and_outer(), hash_numeric(), hash_numeric_extended(), hash_object_field_end(), hash_record(), hash_record_extended(), hash_scalar(), hash_search_with_hash_value(), hash_xlog_add_ovfl_page(), hash_xlog_init_meta_page(), hash_xlog_move_page_contents(), hash_xlog_squeeze_page(), hashagg_recompile_expressions(), hashagg_spill_tuple(), hashbeginscan(), hashbucketcleanup(), hashbulkdelete(), have_partkey_equi_join(), have_relevant_eclass_joinclause(), heap_abort_speculative(), heap_attisnull(), heap_beginscan(), heap_compare_slots(), heap_create(), heap_create_with_catalog(), heap_delete(), heap_fetch_toast_slice(), heap_fill_tuple(), heap_finish_speculative(), heap_force_common(), heap_get_latest_tid(), heap_get_root_tuples(), heap_getsysattr(), heap_hot_search_buffer(), heap_index_delete_tuples(), heap_insert(), heap_lock_tuple(), heap_lock_updated_tuple_rec(), heap_multi_insert(), heap_page_is_all_visible(), heap_prepare_freeze_tuple(), heap_prepare_insert(), heap_prune_chain(), heap_prune_record_dead(), heap_prune_record_prunable(), heap_prune_record_redirect(), heap_prune_record_unused(), heap_prune_satisfies_vacuum(), heap_setscanlimits(), heap_toast_delete(), heap_toast_insert_or_update(), heap_tuple_attr_equals(), heap_tuple_infomask_flags(), heap_update(), heap_vacuum_rel(), heap_xlog_clean(), heap_xlog_cleanup_info(), heap_xlog_insert(), heap_xlog_multi_insert(), heap_xlog_update(), heapam_fetch_row_version(), heapam_index_build_range_scan(), heapam_index_fetch_tuple(), heapam_index_validate_scan(), heapam_relation_copy_for_cluster(), heapam_relation_set_new_filenode(), heapam_scan_analyze_next_tuple(), heapam_scan_bitmap_next_block(), heapam_scan_bitmap_next_tuple(), heapam_scan_sample_next_block(), heapam_scan_sample_next_tuple(), heapam_tuple_lock(), heapam_tuple_satisfies_snapshot(), HeapCheckForSerializableConflictOut(), heapgetpage(), heapgettup(), heapgettup_pagemode(), HeapTupleHeaderGetCmax(), HeapTupleHeaderGetCmin(), HeapTupleHeaderIsOnlyLocked(), HeapTupleIsSurelyDead(), HeapTupleSatisfiesDirty(), HeapTupleSatisfiesHistoricMVCC(), HeapTupleSatisfiesMVCC(), HeapTupleSatisfiesNonVacuumable(), HeapTupleSatisfiesSelf(), HeapTupleSatisfiesToast(), HeapTupleSatisfiesUpdate(), HeapTupleSatisfiesVacuum(), HeapTupleSatisfiesVacuumHorizon(), hemdist(), histcontrol_hook(), histogram_selectivity(), HistoricSnapshotGetTupleCids(), hk_breadth_search(), HotStandbyActiveInReplay(), hstore_exec_setup(), hstore_from_array(), hstore_from_arrays(), hstore_from_record(), hstore_hash(), hstore_hash_extended(), hstore_subscript_fetch(), hstore_subscript_transform(), hstore_to_array_internal(), hypothetical_dense_rank_final(), hypothetical_rank_common(), identify_join_columns(), ieee_float32_to_uint32(), in_range_numeric_numeric(), inclusion_get_strategy_procinfo(), IncrBufferRefCount(), IncrTupleDescRefCount(), index_beginscan_parallel(), index_build(), index_close(), index_compute_xid_horizon_for_tuples(), index_concurrently_build(), index_concurrently_create_copy(), index_constraint_create(), index_create(), index_deform_tuple(), index_drop(), index_form_tuple(), index_getnext_slot(), index_getnext_tid(), index_getprocid(), index_getprocinfo(), index_opclass_options(), index_pages_fetched(), index_register(), index_reloptions(), index_rescan(), index_restrpos(), index_set_state_flags(), index_store_float8_orderby_distances(), index_truncate_tuple(), index_update_stats(), indexam_property(), IndexGetRelation(), IndexNextWithReorder(), IndexOnlyNext(), IndexSetParentIndex(), inet_gist_consistent(), inet_spg_choose(), inet_spg_inner_consistent(), inheritance_planner(), init_params(), init_ps_display(), init_rel_sync_cache(), init_returning_filter(), init_sexpr(), init_span(), initArrayResultAny(), InitAuxiliaryProcess(), InitBufferPool(), InitCatalogCache(), InitCatalogCachePhase2(), InitCatCache(), InitCatCachePhase2(), InitFileAccess(), initial_cost_mergejoin(), initialize_environment(), initialize_mergeclause_eclasses(), initialize_phase(), initialize_reloptions(), InitializeClientEncoding(), InitializeLatchSupport(), InitializeLatchWaitSet(), InitializeMaxBackends(), InitializeOneGUCOption(), InitLatch(), InitPlan(), InitPostgres(), InitPostmasterDeathWatchHandle(), InitPredicateLocks(), InitProcess(), InitProcessPhase2(), InitProcGlobal(), InitShmemAllocation(), InitStandaloneProcess(), inittapes(), InitTempTableNamespace(), InitWalSenderSlot(), InitXLOGAccess(), inline_cte(), inline_set_returning_function(), Insert(), insert_item_into_bucket(), insert_new_cell(), insert_timeout(), InsertOneNull(), instantiate_empty_record_variable(), int2vectorrecv(), interpret_AS_clause(), interval_support(), intorel_startup(), intset_add_member(), intset_is_member(), intset_iterate_next(), intset_update_upper(), inv_close(), inv_getsize(), inv_read(), inv_seek(), inv_tell(), inv_truncate(), inv_write(), InvalidateBuffer(), InvalidateConstraintCacheCallBack(), InvalidateOprCacheCallBack(), InvalidateOprProofCacheCallBack(), invariant_g_offset(), invariant_l_nontarget_offset(), invariant_l_offset(), invariant_leq_offset(), is_code_in_table(), is_dummy_partition(), is_libpq_option(), is_safe_append_member(), is_simple_union_all_recurse(), is_simple_values(), is_strict_saop(), is_subquery_var(), is_valid_option(), IsAffixFlagInUse(), IsBufferCleanupOK(), IsCheckpointOnSchedule(), IsPostmasterChildWalSender(), IsTidEqualAnyClause(), itemptr_to_uint64(), iterate_word_similarity(), IteratorConcat(), iteratorFromContainer(), join_search_one_level(), json_agg_finalfn(), json_lex_string(), json_object_agg_finalfn(), jsonb_agg_finalfn(), jsonb_concat(), jsonb_delete(), jsonb_delete_array(), jsonb_delete_idx(), jsonb_delete_path(), jsonb_get_element(), jsonb_in_object_field_start(), jsonb_in_scalar(), jsonb_insert(), jsonb_object_agg_finalfn(), jsonb_set(), jsonb_strip_nulls(), jsonb_subscript_fetch(), jsonb_subscript_transform(), jsonb_to_plpython(), JsonbArraySize(), JsonbDeepContains(), JsonbExtractScalar(), JsonbToCStringWorker(), JsonbType(), JsonbValueToJsonb(), jspGetArg(), jspGetArraySubscript(), jspGetBool(), jspGetLeftArg(), jspGetNext(), jspGetNumeric(), jspGetRightArg(), jspGetString(), jspInit(), JumbleQuery(), keyGetItem(), KnownAssignedXidExists(), KnownAssignedXidsAdd(), KnownAssignedXidsRemove(), KnownAssignedXidsRemovePreceding(), KnownAssignedXidsSearch(), label_sort_with_costsize(), LagTrackerRead(), lappend(), lappend_int(), lappend_oid(), lastval(), LaunchParallelWorkers(), lazy_cleanup_all_indexes(), lazy_cleanup_index(), lazy_parallel_vacuum_indexes(), lazy_scan_heap(), lazy_vacuum_all_indexes(), lazy_vacuum_index(), lazy_vacuum_page(), lcons(), lcons_int(), lcons_oid(), LCS_asString(), leader_takeover_tapes(), leafRepackItems(), lengthCompareJsonbStringValue(), libpqrcv_connect(), libpqrcv_get_conninfo(), libpqrcv_get_senderinfo(), libpqrcv_readtimelinehistoryfile(), libpqrcv_startstreaming(), like_fixed_prefix(), like_regex_support(), list_cell_number(), list_concat(), list_concat_copy(), list_concat_unique(), list_concat_unique_int(), list_concat_unique_oid(), list_concat_unique_ptr(), list_copy_deep(), list_deduplicate_oid(), list_delete(), list_delete_int(), list_delete_nth_cell(), list_delete_oid(), list_delete_ptr(), list_difference(), list_difference_int(), list_difference_oid(), list_difference_ptr(), list_free_deep(), list_insert_nth(), list_insert_nth_int(), list_insert_nth_oid(), list_intersection(), list_intersection_int(), list_last_cell(), list_member(), list_member_int(), list_member_oid(), list_member_ptr(), list_nth(), list_nth_cell(), list_nth_int(), list_nth_oid(), list_union(), list_union_int(), list_union_oid(), list_union_ptr(), llvm_assert_in_fatal_section(), llvm_build_inline_plan(), llvm_compile_expr(), llvm_execute_inline_plan(), llvm_expand_funcname(), llvm_pg_var_func_type(), llvm_pg_var_type(), llvm_resolve_symbol(), llvm_split_symbol_name(), lnext(), lo_get_fragment_internal(), lo_import_internal(), load_hba(), load_ident(), load_relcache_init_file(), load_return_type(), load_typcache_tupdesc(), LocalBufferAlloc(), LocalProcessControlFile(), LocalSetXLogInsertAllowed(), lock_twophase_postcommit(), lock_twophase_recover(), lock_twophase_standby_recover(), LockAcquireExtended(), LockBuffer(), LockBufferForCleanup(), LockCheckConflicts(), LockReassignCurrentOwner(), LockRefindAndRelease(), LockRelease(), LockReleaseAll(), LockWaiterCount(), log10Pow2(), log10Pow5(), log_heap_clean(), log_heap_freeze(), log_heap_new_cid(), log_heap_update(), log_heap_visible(), log_newpage_buffer(), logical_heap_rewrite_flush_mappings(), LogicalConfirmReceivedLocation(), LogicalIncreaseRestartDecodingForSlot(), LogicalIncreaseXminForSlot(), logicalmsg_desc(), LogicalOutputWrite(), logicalrep_read_stream_abort(), logicalrep_read_stream_start(), logicalrep_sync_worker_count(), logicalrep_typmap_gettypname(), logicalrep_worker_attach(), logicalrep_worker_cleanup(), logicalrep_worker_find(), logicalrep_worker_launch(), logicalrep_worker_wakeup_ptr(), logicalrep_workers_find(), logicalrep_write_delete(), logicalrep_write_stream_abort(), logicalrep_write_stream_commit(), logicalrep_write_stream_start(), logicalrep_write_update(), LogicalRepSyncTableStart(), LogicalTapeBackspace(), LogicalTapeFreeze(), LogicalTapeRead(), LogicalTapeRewindForRead(), LogicalTapeRewindForWrite(), LogicalTapeSeek(), LogicalTapeSetBlocks(), LogicalTapeSetCreate(), LogicalTapeTell(), LogicalTapeWrite(), LogLogicalInvalidations(), LogLogicalMessage(), LogRecoveryConflict(), LogStandbySnapshot(), lookup_collation_cache(), lookup_proof_cache(), lookup_rowtype_tupdesc_internal(), lookup_ts_config_cache(), lookup_ts_dictionary_cache(), lookup_ts_parser_cache(), lookup_type_cache(), lookup_var_attr_stats(), LookupFuncNameInternal(), LookupFuncWithArgs(), LookupOpclassInfo(), LookupOperWithArgs(), LookupTupleHashEntry(), LookupTupleHashEntryHash(), LookupTypeNameExtended(), lowerstr_with_len(), LruDelete(), LruInsert(), ltree_gist_alloc(), ltsConcatWorkerTapes(), ltsGetPreallocBlock(), ltsInitReadBuffer(), LWLockAcquire(), LWLockAcquireOrWait(), LWLockDequeueSelf(), LWLockRelease(), LWLockUpdateVar(), LWLockWaitForVar(), LWLockWaitListUnlock(), LWLockWakeup(), main(), MainLoop(), MaintainLatestCompletedXid(), MaintainLatestCompletedXidRecovery(), MaintainOldSnapshotTimeMapping(), make_bound_box(), make_bounded_heap(), make_datum_param(), make_expanded_record_from_datum(), make_greater_string(), make_inh_translation_list(), make_join_rel(), make_modifytable(), make_new_connection(), make_new_heap(), make_new_segment(), make_one_partition_rbound(), make_one_rel(), make_oper_cache_entry(), make_outerjoininfo(), make_partition_op_expr(), make_partition_pruneinfo(), make_partitionedrel_pruneinfo(), make_pathkeys_for_sortclauses(), make_recursive_union(), make_restrictinfo(), make_restrictinfo_internal(), make_result_opt_error(), make_ruledef(), make_scalar_key(), make_setop(), make_sort_input_target(), make_subplan(), make_trigrams(), make_tuple_from_result_row(), make_unique_from_pathkeys(), make_unique_from_sortclauses(), make_viewdef(), make_window_input_target(), makeArrayResultArr(), makeCompoundFlags(), makeDependencyGraph(), makeIndexInfo(), makeMdArrayResult(), MakeNewSharedSegment(), makeObjectName(), makeSublist(), makeUniqueTypeName(), map_sql_identifier_to_xml_name(), map_variable_attnos_mutator(), mark_invalid_subplans_as_finished(), mark_partial_aggref(), MarkAsPrepared(), MarkAsPreparing(), MarkAsPreparingGuts(), MarkBufferDirty(), MarkBufferDirtyHint(), MarkLocalBufferDirty(), MarkLockClear(), MarkPortalDone(), MarkPortalFailed(), MarkPostmasterChildActive(), MarkPostmasterChildInactive(), MarkPostmasterChildWalSender(), MarkSubTransactionAssigned(), markVarForSelectPriv(), match_clause_to_indexcol(), match_clause_to_ordering_op(), match_clause_to_partition_key(), match_eclasses_to_foreign_key_col(), match_expr_to_partition_keys(), match_pattern_prefix(), match_unsorted_outer(), MatchNamedCall(), materializeResult(), max_parallel_hazard_test(), MaxPredicateChildLocks(), maybe_reread_subscription(), mcelem_tsquery_selec(), mcv_get_match_bitmap(), md5_crypt_verify(), mdcreate(), mdextend(), mdnblocks(), mdopenfork(), mdprefetch(), mdread(), mdtruncate(), mdwrite(), mdwriteback(), MemoryContextCreate(), MemoryContextDelete(), MemoryContextSetParent(), merge_children(), merge_default_partitions(), merge_fdw_options(), merge_list_bounds(), merge_matching_partitions(), merge_null_partitions(), merge_partition_with_dummy(), merge_range_bounds(), MergeAffix(), MergeAttributes(), MergeAttributesIntoExisting(), MergeCheckConstraint(), MergeConstraintsIntoExisting(), mergejoinscansel(), mergeruns(), mergeStates(), MergeWithExistingConstraint(), message_cb_wrapper(), minimal_tuple_from_heap_tuple(), minmax_get_strategy_procinfo(), MJExamineQuals(), mod_m(), mode_final(), ModifyWaitEvent(), moveLeafs(), mq_putmessage(), mul_var(), mulShift(), multi_sort_init(), MultiExecParallelHash(), multirange_contains_range_internal(), multirange_get_bounds(), multirange_get_range(), multirange_overleft_range(), multirange_overright_range(), multirange_union_range_equal(), multixact_redo(), multixact_twophase_postcommit(), multixact_twophase_recover(), MultiXactAdvanceOldest(), MultiXactIdCreate(), MultiXactIdExpand(), MultiXactIdGetUpdateXid(), MultiXactShmemInit(), n_choose_k(), NamedTuplestoreScanNext(), NamespaceCreate(), network_abbrev_convert(), network_subset_support(), new_intArrayType(), new_list(), newLOfd(), NewPrivateRefCountEntry(), next_token(), NextCopyFrom(), NextCopyFromRawFields(), NextPredXact(), nextval_internal(), NISortDictionary(), nocache_index_getattr(), nocachegetattr(), NormalTransactionIdOlder(), notification_hash(), notification_match(), NUM_cache_getnew(), numeric_abbrev_convert(), numeric_add_opt_error(), numeric_div_opt_error(), numeric_div_trunc(), numeric_log(), numeric_mul_opt_error(), numeric_power(), numeric_sign(), numeric_sign_internal(), numeric_sub_opt_error(), numeric_support(), numericvar_to_int64(), numericvar_to_uint64(), objectNamesToOids(), OffsetVarNodes_walker(), oidvectorrecv(), on_error_rollback_hook(), OnConflict_CheckForSerializationFailure(), open_file_in_directory(), OpernameGetCandidates(), ordered_set_startup(), ordered_set_transition_multi(), OwnLatch(), p_isEOF(), p_iswhat(), packGraph(), PageIndexMultiDelete(), PageIndexTupleDelete(), PageIndexTupleDeleteNoCompact(), PageIndexTupleOverwrite(), PageInit(), PageValidateSpecialPointer(), pairingheap_first(), pairingheap_remove(), pairingheap_remove_first(), parallel_restore(), parallel_vacuum_main(), ParallelBackupEnd(), ParallelBackupStart(), ParallelQueryMain(), ParallelSlotsSetup(), ParallelWorkerMain(), ParallelWorkerReportLastRecEnd(), parse_analyze(), parse_analyze_varparams(), parse_datetime(), parse_hba_line(), parse_ident_line(), parse_int_param(), parse_object(), parse_output_parameters(), parse_subscription_options(), parse_tsquery(), parseCheckAggregates(), ParseFractionalSecond(), ParseFuncOrColumn(), parseNameAndArgTypes(), parseQuery(), parseWorkerCommand(), parseWorkerResponse(), partition_bounds_copy(), partition_bounds_create(), partition_bounds_equal(), partition_bounds_merge(), PartitionDirectoryLookup(), partitions_are_ordered(), partkey_datum_from_expr(), path_inter(), patternsel_common(), patternToSQLRegex(), percentile_cont_final_common(), percentile_cont_multi_final_common(), percentile_disc_final(), percentile_disc_multi_final(), perform_base_backup(), perform_pruning_base_step(), perform_pruning_combine_step(), perform_pullup_replace_vars(), perform_work_item(), PerformCursorOpen(), PersistHoldablePortal(), pg_analyze_and_rewrite_params(), pg_atomic_fetch_sub_u32(), pg_atomic_fetch_sub_u64(), pg_atomic_sub_fetch_u32(), pg_atomic_sub_fetch_u64(), pg_b64_decode(), pg_b64_encode(), pg_base64_decode(), pg_base64_encode(), pg_be_scram_exchange(), pg_blocking_pids(), pg_checksum_block(), pg_checksum_final(), pg_checksum_page(), pg_checksum_type_name(), pg_decode_change(), pg_decode_startup(), pg_decode_stream_abort(), pg_encoding_max_length(), pg_encoding_to_char(), pg_fe_scram_init(), pg_fsync(), pg_get_constraintdef_worker(), pg_get_functiondef(), pg_get_indexdef_worker(), pg_get_partkeydef_worker(), pg_get_replication_slots(), pg_get_statisticsobj_worker(), pg_GSS_read(), pg_GSS_write(), pg_hex_decode(), pg_hex_encode(), pg_isolation_test_session_is_blocked(), pg_leftmost_one_pos32(), pg_leftmost_one_pos64(), pg_log_generic_v(), pg_logical_replication_slot_advance(), pg_logical_slot_get_changes_guts(), pg_lsn_in_internal(), pg_newlocale_from_collation(), pg_nextpower2_32(), pg_nextpower2_64(), pg_partition_root(), pg_physical_replication_slot_advance(), pg_plan_query(), pg_pwritev_with_retry(), pg_queue_signal(), pg_re_throw(), pg_relation_filepath(), pg_replication_origin_progress(), pg_replication_slot_advance(), pg_rightmost_one_pos32(), pg_rightmost_one_pos64(), pg_saslprep(), pg_start_backup_callback(), pg_stat_statements_internal(), pg_stats_ext_mcvlist_items(), pg_stop_backup_callback(), pg_strfromd(), pg_timer_thread(), pg_ultostr_zeropad(), pg_usleep(), pg_verify_mbstr(), pg_verify_mbstr_len(), pg_visibility_tupdesc(), pg_xact_status(), pgarch_start(), pgfdw_inval_callback(), pgoutput_change(), pgoutput_stream_abort(), pgoutput_stream_commit(), pgoutput_stream_start(), pgoutput_stream_stop(), PGSemaphoreCreate(), PGSharedMemoryCreate(), PGSharedMemoryNoReAttach(), PGSharedMemoryReAttach(), pgss_post_parse_analyze(), pgss_store(), pgstat_bestart(), pgstat_collect_oids(), pgstat_initialize(), pgstat_progress_update_multi_param(), pgstat_progress_update_param(), pgstat_read_current_status(), pgstat_recv_replslot(), pgstat_replslot_index(), pgstat_report_stat(), pgstat_reset_all(), pgwin32_dispatch_queued_signals(), pgwin32_ReserveSharedMemoryRegion(), pgwin32_select(), pgwin32_SharedMemoryDelete(), PhysicalConfirmReceivedLocation(), PinBuffer(), PinBuffer_Locked(), placeChar(), plan_set_operations(), PlanCacheComputeResultDesc(), PlanCacheObjectCallback(), PlanCacheRelCallback(), plperl_call_perl_func(), plperl_return_next_internal(), plperl_sv_to_datum(), plperl_trigger_handler(), plpgsql_append_source_text(), plpgsql_build_recfield(), plpgsql_destroy_econtext(), plpgsql_exec_trigger(), plpgsql_free_function_memory(), plpgsql_HashTableInit(), plpgsql_inline_handler(), plpgsql_ns_additem(), plpgsql_ns_pop(), plpgsql_param_compile(), plpgsql_param_eval_generic(), plpgsql_param_eval_generic_ro(), plpgsql_param_eval_recfield(), plpgsql_param_eval_var(), plpgsql_param_eval_var_ro(), plpgsql_param_fetch(), pltcl_func_handler(), pltcl_handler(), pltcl_init_tuple_store(), pltcl_trigger_handler(), PLy_abort_open_subtransactions(), PLy_cursor_plan(), PLy_cursor_query(), PLy_elog_impl(), PLy_exec_function(), PLy_exec_trigger(), PLy_generate_spi_exceptions(), PLy_global_args_pop(), PLy_input_setup_tuple(), PLy_output_setup_record(), PLy_output_setup_tuple(), PLy_procedure_call(), PLy_procedure_create(), PLy_procedure_munge_source(), PLy_spi_prepare(), PLy_traceback(), PLyDict_FromTuple(), PLyList_FromArray(), PLyMapping_ToComposite(), PLyObject_ToComposite(), PLySequence_ToComposite(), PLySequence_ToJsonbValue(), PLyString_FromJsonbValue(), point_inside(), poly_contain_poly(), poly_overlap(), poly_to_circle(), PopActiveSnapshot(), populate_array(), populate_array_assign_ndims(), populate_array_dim_jsonb(), populate_array_element(), populate_array_element_end(), populate_array_json(), populate_array_report_expected_array(), populate_array_scalar(), populate_domain(), populate_record_worker(), populate_recordset_object_field_end(), populate_recordset_worker(), populate_scalar(), populate_typ_array(), PortalCreateHoldStore(), PortalRun(), PortalRunFetch(), PortalRunMulti(), PortalRunSelect(), PortalStart(), postgres_fdw_get_connections(), postgresBeginForeignInsert(), postgresEndForeignInsert(), postgresExplainForeignScan(), postgresGetForeignModifyBatchSize(), postgresGetForeignPaths(), postgresGetForeignPlan(), postgresIterateDirectModify(), postgresPlanDirectModify(), postgresRecheckForeignScan(), PostmasterMain(), PostmasterMarkPIDForWorkerNotify(), PostmasterStateMachine(), PostPrepare_Locks(), PostPrepare_PredicateLocks(), postprocess_setop_tlist(), postprocess_sql_command(), postquel_start(), postquel_sub_params(), pow5bits(), pow5Factor(), pq_discardbytes(), pq_endmsgread(), pq_endtypsend(), pq_getbyte(), pq_getbyte_if_available(), pq_getbytes(), pq_getmessage(), pq_init(), pq_peekbyte(), pq_putmessage_v2(), pq_set_parallel_leader(), pq_writeint16(), pq_writeint32(), pq_writeint64(), pq_writeint8(), pq_writestring(), PQconnectPoll(), PreCommit_CheckForSerializationFailure(), PreCommit_on_commit_actions(), predicate_classify(), predicate_implied_by_recurse(), predicate_refuted_by_recurse(), predicatelock_hash(), predicatelock_twophase_recover(), PredicateLockPageSplit(), PrefetchBuffer(), PrefetchSharedBuffer(), prefix_selectivity(), prepare_cb_wrapper(), prepare_index_statistics(), prepare_query_params(), prepare_sort_from_pathkeys(), prepare_vacuum_command(), PrepareInvalidationState(), PrepareRedoAdd(), PrepareRedoRemove(), PrepareSortSupportFromGistIndexRel(), PrepareSortSupportFromIndexRel(), PrepareSortSupportFromOrderingOp(), PrepareToInvalidateCacheTuple(), PrepareTransaction(), PrepareTransactionBlock(), preprocess_aggref(), preprocess_aggrefs_walker(), preprocess_groupclause(), preprocess_limit(), preprocess_minmax_aggregates(), preprocess_rowmarks(), preprocess_targetlist(), PrescanPreparedTransactions(), print_expr(), print_function_arguments(), PrintBufferLeakWarning(), PrintCatCacheLeakWarning(), printCrosstab(), printJsonPathItem(), printPsetInfo(), printQuery(), PrintResultsInCrosstab(), printTypmod(), ProcArrayApplyRecoveryInfo(), ProcArrayApplyXidAssignment(), ProcArrayClearTransaction(), ProcArrayEndTransaction(), ProcArrayEndTransactionInternal(), ProcArrayGroupClearXid(), ProcArrayInitRecovery(), ProcArrayInstallImportedXmin(), ProcArrayInstallRestoredXmin(), ProcArrayRemove(), ProcArraySetReplicationSlotXmin(), ProcedureCreate(), process_equivalence(), process_implied_equality(), process_inner_partition(), process_ordered_aggregate_single(), process_outer_partition(), process_owned_by(), process_security_barrier_quals(), process_startup_options(), process_sublinks_mutator(), process_subquery_nestloop_params(), process_syncing_tables_for_apply(), process_target_wal_block_change(), ProcessGUCArray(), processIndirection(), ProcessInterrupts(), processPendingPage(), ProcessProcSignalBarrier(), processQueryResult(), ProcessRecords(), ProcessSyncRequests(), ProcessTwoPhaseBuffer(), processTypesSpec(), ProcessUtility(), ProcessUtilitySlow(), ProcKill(), proclist_contains_offset(), proclist_delete_offset(), proclist_pop_head_node_offset(), proclist_push_head_offset(), proclist_push_tail_offset(), proclock_hash(), ProcLockWakeup(), ProcSignalInit(), ProcSleep(), ProcWakeup(), progress_report(), prune_append_rel_partitions(), pset_value_string(), PublicationAddTables(), pull_up_simple_subquery(), pull_up_simple_union_all(), pull_up_simple_values(), pull_up_subqueries(), pull_up_subqueries_recurse(), pull_var_clause(), pull_varattnos_walker(), pullup_replace_vars_subquery(), push_old_value(), push_stmt_mcontext(), PushActiveSnapshot(), pushJsonbValue(), pushJsonbValueScalar(), pushOperator(), puttuple_common(), qc_is_allowed(), qsortCompareItemPointers(), qual_is_pushdown_safe(), query_is_distinct_for(), query_planner(), query_tree_mutator(), query_tree_walker(), QueryRewrite(), QueuePartitionConstraintValidation(), quote_if_needed(), range_adjacent_multirange_internal(), range_after_multirange_internal(), range_before_multirange_internal(), range_contains_multirange_internal(), range_deserialize(), range_gist_class_split(), range_gist_double_sorting_split(), range_gist_picksplit(), range_gist_single_sorting_split(), range_overlaps_multirange_internal(), range_overleft_multirange_internal(), range_overright_multirange_internal(), range_serialize(), rangeTableEntry_used_walker(), RangeVarGetAndCheckCreationNamespace(), RangeVarGetRelidExtended(), rank_up(), raw_heap_insert(), rbt_create(), RE_compile_and_cache(), read_binary_file(), read_client_final_message(), read_seq_tuple(), ReadArrayStr(), ReadBuffer_common(), ReadBufferBI(), ReadBufferWithoutRelcache(), readCommandResponse(), readMessageFromPipe(), ReadPageInternal(), readtup_alloc(), readtup_datum(), ready_list_remove(), reaper(), rebuildInsertSql(), recheck_cast_function_args(), reconsider_full_join_clause(), reconsider_outer_join_clause(), record_cmp(), record_image_cmp(), recordDependencyOnCurrentExtension(), RecordKnownAssignedTransactionIds(), recordMultipleDependencies(), RecordNewMultiXact(), recordSharedDependencyOn(), RecordTransactionCommit(), RecoverPreparedTransactions(), RecoveryConflictInterrupt(), recurse_push_qual(), recurse_pushdown_safe(), recurse_set_operations(), reduce_dependencies(), reduce_outer_joins_pass2(), refresh_by_match_merge(), regexp_fixed_prefix(), regexp_match(), register_dirty_segment(), register_ENR(), register_unlink_segment(), RegisterDynamicBackgroundWorker(), RegisterPredicateLockingXid(), RegisterTemporaryFile(), RegisterTimeout(), reindex_error_callback(), reindex_one_database(), reindex_relation(), ReindexMultipleInternal(), ReindexMultipleTables(), ReindexPartitions(), ReindexRelationConcurrently(), ReinitializeParallelWorkers(), relation_close(), relation_excluded_by_constraints(), relation_has_unique_index_for(), relation_is_updatable(), relation_mark_replica_identity(), relation_open(), RelationBuildDesc(), RelationBuildLocalRelation(), RelationBuildPartitionKey(), RelationBuildRuleLock(), RelationBuildTupleDesc(), RelationCacheInitializePhase3(), RelationCacheInvalidate(), RelationClearRelation(), RelationCreateStorage(), RelationDecrementReferenceCount(), RelationDestroyRelation(), RelationFindReplTupleSeq(), RelationForgetRelation(), RelationGetBufferForTuple(), RelationGetDummyIndexExpressions(), RelationGetIndexExpressions(), RelationGetIndexPredicate(), RelationGetNumberOfBlocksInFork(), RelationGetPrimaryKeyIndex(), RelationGetReplicaIndex(), RelationIdGetRelation(), RelationIdIsInInitFile(), RelationInitIndexAccessInfo(), RelationInitLockInfo(), RelationInitTableAccessMethod(), RelationMapFinishBootstrap(), RelationPutHeapTuple(), RelationReloadIndexInfo(), RelationReloadNailed(), RelationSetNewRelfilenode(), ReleaseAndReadBuffer(), ReleaseBuffer(), ReleaseCachedPlan(), ReleaseCatCache(), ReleaseCatCacheList(), ReleaseCurrentSubTransaction(), ReleaseExternalFD(), ReleaseGenericPlan(), ReleaseLockIfHeld(), ReleaseLruFile(), ReleaseOneSerializableXact(), ReleasePostmasterChildSlot(), ReleasePredicateLocks(), ReleasePredXact(), ReleaseSavepoint(), RelfilenodeMapInvalidateCallback(), RelidByRelfilenode(), relmap_redo(), remap_groupColIdx(), RememberSyncRequest(), RememberToFreeTupleDescAtEOX(), remove_join_clause_from_rels(), remove_rel_from_query(), remove_result_refs(), remove_target(), remove_timeout_index(), remove_useless_groupby_columns(), remove_useless_result_rtes(), remove_useless_results_recurse(), RemoveFromWaitQueue(), RemoveGXact(), RemoveLocalLock(), RemoveObjects(), RemoveProcFromArray(), RemoveRelations(), RemoveRoleFromObjectPolicy(), RemoveScratchTarget(), RemoveTargetIfNoLongerUsed(), RenameTypeInternal(), reorder_function_arguments(), ReorderBufferAddInvalidations(), ReorderBufferAllocate(), ReorderBufferAssignChild(), ReorderBufferBuildTupleCidHash(), ReorderBufferChangeMemoryUpdate(), ReorderBufferCheckMemoryLimit(), ReorderBufferCleanupTXN(), ReorderBufferFinishPrepared(), ReorderBufferForget(), ReorderBufferGetOldestTXN(), ReorderBufferInvalidate(), ReorderBufferIterTXNFinish(), ReorderBufferIterTXNNext(), ReorderBufferLargestTXN(), ReorderBufferPrepare(), ReorderBufferProcessPartialChange(), ReorderBufferProcessTXN(), ReorderBufferQueueChange(), ReorderBufferQueueMessage(), ReorderBufferReplay(), ReorderBufferRestoreChange(), ReorderBufferRestoreChanges(), ReorderBufferRestoreCleanup(), ReorderBufferSerializeChange(), ReorderBufferSerializeTXN(), ReorderBufferSetBaseSnapshot(), ReorderBufferStreamCommit(), ReorderBufferStreamTXN(), ReorderBufferToastAppendChunk(), ReorderBufferToastInitHash(), ReorderBufferToastReplace(), ReorderBufferTransferSnapToParent(), ReorderBufferTruncateTXN(), ReorderBufferTXNByXid(), repalloc(), repalloc_huge(), replace_domain_constraint_value(), replace_nestloop_params_mutator(), replace_outer_agg(), replace_outer_grouping(), replace_outer_placeholdervar(), replace_outer_var(), replace_vars_in_jointree(), ReplicationSlotAcquireInternal(), ReplicationSlotCleanup(), ReplicationSlotCreate(), ReplicationSlotDrop(), ReplicationSlotDropAcquired(), ReplicationSlotDropAtPubNode(), ReplicationSlotMarkDirty(), ReplicationSlotPersist(), ReplicationSlotRelease(), ReplicationSlotReserveWal(), ReplicationSlotSave(), ReplicationSlotsComputeRequiredLSN(), ReplicationSlotsComputeRequiredXmin(), replorigin_advance(), replorigin_by_oid(), replorigin_create(), replorigin_drop_by_name(), replorigin_session_advance(), replorigin_session_get_progress(), replorigin_session_reset(), replorigin_session_setup(), report_namespace_conflict(), ReportBackgroundWorkerExit(), ReportBackgroundWorkerPID(), ReportChangedGUCOptions(), RequestNamedLWLockTranche(), RequestXLogStreaming(), ReservePrivateRefCountEntry(), ReserveXLogInsertLocation(), ReserveXLogSwitch(), ResetBackgroundWorkerCrashTimes(), ResetCatalogCache(), ResetLatch(), ResetPlanCache(), ResetSequence(), ResetUnloggedRelationsInDbspaceDir(), resize(), resize_intArrayType(), resolve_aggregate_transtype(), resolve_column_ref(), ResolveCminCmaxDuringDecoding(), ResolveRecoveryConflictWithBufferPin(), ResolveRecoveryConflictWithLock(), ResolveRecoveryConflictWithVirtualXIDs(), ResourceArrayAdd(), ResourceArrayEnlarge(), ResourceArrayInit(), ResourceArrayRemove(), ResourceOwnerDelete(), ResourceOwnerEnlargeBuffers(), ResourceOwnerForgetLock(), ResourceOwnerNewParent(), ResourceOwnerReleaseInternal(), ResourceOwnerRememberLock(), restore_toc_entries_parallel(), RestoreArchive(), RestoreArchivedFile(), RestoreComboCIDState(), RestorePendingSyncs(), restorePsetInfo(), RestoreReindexState(), RestoreScratchTarget(), RestoreUncommittedEnums(), ReThrowError(), RetrieveDataDirCreatePerm(), RetrieveWalSegSize(), revalidate_rectypeid(), RevalidateCachedQuery(), revmap_get_buffer(), rewrite_heap_dead_tuple(), rewrite_heap_tuple(), RewriteQuery(), rewriteRuleAction(), rewriteSearchAndCycle(), rewriteTargetView(), rewriteValuesRTE(), ri_Check_Pk_Match(), RI_FKey_fk_upd_check_required(), ri_HashCompareOp(), ri_HashPreparedPlan(), ri_LoadConstraintInfo(), rollback_prepared_cb_wrapper(), RollbackToSavepoint(), rot13_passphrase(), round_var(), row_is_in_frame(), run_reindex_command(), run_ssl_passphrase_command(), RunFunctionExecuteHook(), RunIdentifySystem(), RunNamespaceSearchHook(), RunObjectDropHook(), RunObjectPostAlterHook(), RunObjectPostCreateHook(), RunObjectTruncateHook(), RWConflictExists(), SaveCachedPlan(), savePsetInfo(), scalararraysel(), scan_file(), scanGetItem(), ScanKeyEntryInitialize(), ScanQueryForLocks(), ScheduleBufferTagForWriteback(), scram_build_secret(), scram_HMAC_final(), scram_HMAC_update(), SearchCatCacheInternal(), SearchCatCacheList(), SearchNamedReplicationSlot(), SearchSysCache(), SearchSysCache1(), SearchSysCache2(), SearchSysCache3(), SearchSysCache4(), secure_read(), secure_write(), select_active_windows(), select_common_type(), select_common_type_from_oids(), select_outer_pathkeys_for_merge(), selectColorTrigrams(), SendCopyEnd(), sendFile(), SendRecoveryConflictWithBufferPin(), sepgsql_audit_log(), sepgsql_compute_avd(), sepgsql_compute_create(), sepgsql_fmgr_hook(), sepgsql_get_client_label(), sepgsql_object_access(), sepgsql_relation_setattr_extra(), SerialAdd(), SerialGetMinConflictCommitSeqNo(), SerialInit(), SerializeGUCState(), SerializeLibraryState(), SerializeRelationMap(), SerializeSnapshot(), SerializeTransactionState(), SerializeUncommittedEnums(), SerialPagePrecedesLogically(), SerialSetActiveSerXmin(), ServerLoop(), set_append_references(), set_append_rel_size(), set_base_rel_pathlists(), set_base_rel_sizes(), set_baserel_partition_key_exprs(), set_baserel_size_estimates(), set_cheapest(), set_cte_pathlist(), set_cte_size_estimates(), set_deparse_context_plan(), set_errdata_field(), set_foreign_size_estimates(), set_function_size_estimates(), set_hash_references(), set_indexsafe_procflags(), set_join_column_names(), set_mergeappend_references(), set_namedtuplestore_size_estimates(), set_param_references(), set_pathtarget_cost_width(), set_plan_refs(), set_rel_consider_parallel(), set_rel_size(), set_rel_width(), set_relation_column_names(), set_relation_partition_info(), set_result_size_estimates(), set_status_by_pages(), set_subquery_pathlist(), set_subquery_size_estimates(), set_tablefunc_size_estimates(), set_using_names(), set_values_size_estimates(), setalarm(), SetCommitTsLimit(), SetConstraintStateAddItem(), SetCurrentStatementStartTimestamp(), SetDatabaseEncoding(), SetDatabasePath(), setitimer(), SetMatViewPopulatedState(), SetMessageEncoding(), SetMultiXactIdLimit(), SetNewSxactGlobalXmin(), SetOffsetVacuumLimit(), SetOldSnapshotThresholdTimestamp(), setop_fill_hash_table(), SetParallelStartTimestamps(), setPath(), setPathArray(), setPathObject(), SetPossibleUnsafeConflict(), setRedirectionTuple(), SetReindexProcessing(), SetRelationTableSpace(), SetRemoteDestReceiverParams(), SetRWConflict(), SetSerializableTransactionSnapshot(), SetTempNamespaceState(), SetTempTablespaces(), SetTransactionIdLimit(), SetTransactionSnapshot(), SetTuplestoreDestReceiverParams(), setup_param_list(), setup_simple_rel_arrays(), setup_test_matches(), SetupHistoricSnapshot(), SetupLockInTable(), SharedFileSetInit(), SharedFileSetOnDetach(), SharedFileSetUnregister(), SharedInvalBackendInit(), SharedRecordTypmodRegistryAttach(), SharedRecordTypmodRegistryInit(), shiftList(), shiftright128(), shm_mq_attach(), shm_mq_create(), shm_mq_detach_internal(), shm_mq_inc_bytes_read(), shm_mq_receive(), shm_mq_receive_bytes(), shm_mq_send_bytes(), shm_mq_sendv(), shm_mq_set_handle(), shm_mq_set_receiver(), shm_mq_set_sender(), shm_mq_wait_for_attach(), shm_toc_attach(), shm_toc_create(), shm_toc_freespace(), shm_toc_insert(), ShmemAllocRaw(), ShmemAllocUnlocked(), ShmemInitStruct(), SHMQueueDelete(), SHMQueueElemInit(), SHMQueueEmpty(), SHMQueueInit(), SHMQueueInsertAfter(), SHMQueueInsertBefore(), SHMQueueIsDetached(), SHMQueueNext(), SHMQueuePrev(), show_context_hook(), show_eval_params(), shutdown_cb_wrapper(), ShutdownXLOG(), SignalBackends(), sigusr1_handler(), simple8b_encode(), SimpleLruInit(), SimpleLruReadPage(), SimpleLruWriteAll(), SimpleLruZeroPage(), SimpleXLogPageRead(), simplify_boolean_equality(), simplify_EXISTS_query(), simplify_function(), skip_parallel_vacuum_index(), SlabAlloc(), SlabFree(), SlabGetChunkSpace(), SlabIsEmpty(), SlabRealloc(), SlabReset(), SlabStats(), slist_delete(), slist_head_element_off(), slist_next_node(), slist_pop_head_node(), slot_compile_deform(), slot_fill_defaults(), slot_getsomeattrs_int(), slot_modify_data(), slot_store_data(), slru_entry(), SlruInternalWritePage(), SlruMayDeleteSegment(), smgr_redo(), smgrDoPendingSyncs(), smgrsetowner(), sn_scalar(), SnapBuildAddCommittedTxn(), SnapBuildBuildSnapshot(), SnapBuildCommitTxn(), SnapBuildDistributeNewCatalogSnapshot(), SnapBuildFindSnapshot(), SnapBuildFreeSnapshot(), SnapBuildGetOrBuildSnapshot(), SnapBuildInitialSnapshot(), SnapBuildRestore(), SnapBuildSerialize(), SnapBuildSnapDecRefcount(), SnapshotTooOldMagicForTest(), socket_putmessage(), socket_putmessage_noblock(), sort_bounded_heap(), sort_inner_and_outer(), SpeculativeInsertionWait(), spg_kd_choose(), spg_kd_inner_consistent(), spg_quad_choose(), spg_quad_inner_consistent(), spg_range_quad_choose(), spg_range_quad_inner_consistent(), spg_text_inner_consistent(), spg_text_leaf_consistent(), spgAddNodeAction(), spgbuild(), spgClearPendingList(), spgdoinsert(), spgFormDeadTuple(), spgGetCache(), spgInnerTest(), SpGistGetBuffer(), SpGistInitBuffer(), SpGistPageAddNewItem(), spgLeafTest(), spgRedoAddLeaf(), spgRedoAddNode(), spgRedoPickSplit(), spgRedoVacuumLeaf(), spgRedoVacuumRedirect(), spgSplitNodeAction(), spgTestLeafTuple(), spgWalk(), SPI_connect_ext(), SPI_cursor_open_internal(), SPI_plan_get_cached_plan(), SPI_plan_get_plan_sources(), SPI_plan_is_valid(), SPI_sql_row_to_xmlelement(), split_array(), split_part(), SplitIdentifierString(), sql_fn_post_column_ref(), sqrt_var(), SS_process_ctes(), ssl_external_passwd_cb(), sslVerifyProtocolRange(), standard_ExecutorEnd(), standard_ExecutorFinish(), standard_ExecutorRun(), standard_ExecutorStart(), standard_join_search(), standard_planner(), standby_redo(), StandbyAcquireAccessExclusiveLock(), StandbyRecoverPreparedTransactions(), StandbyReleaseLockList(), StandbyReleaseOldLocks(), StandbyTransactionIdIsPrepared(), StartBufferIO(), StartChildProcess(), StartLogicalReplication(), StartParallelWorkerTransaction(), StartReplication(), StartTransaction(), StartTransactionCommand(), startup_cb_wrapper(), StartupReplicationOrigin(), StartupXLOG(), statapprox_heap(), statext_compute_stattarget(), statext_dependencies_build(), statext_dependencies_deserialize(), statext_dependencies_serialize(), statext_mcv_build(), statext_mcv_clauselist_selectivity(), statext_mcv_deserialize(), statext_mcv_serialize(), statext_ndistinct_build(), statext_ndistinct_deserialize(), statext_ndistinct_serialize(), stop_postmaster(), storeBitmap(), storeGettuple(), StoreIndexTuple(), StorePartitionBound(), StorePartitionKey(), storeRow(), StrategyGetBuffer(), StrategyInitialize(), stream_abort_cb_wrapper(), stream_change_cb_wrapper(), stream_cleanup_files(), stream_close_file(), stream_commit_cb_wrapper(), stream_message_cb_wrapper(), stream_open_file(), stream_prepare_cb_wrapper(), stream_start_cb_wrapper(), stream_stop_cb_wrapper(), stream_truncate_cb_wrapper(), stream_write_change(), StreamServerPort(), StrictNamesCheck(), string_agg_finalfn(), string_to_datum(), strip_quotes(), sts_attach(), sts_begin_parallel_scan(), sts_initialize(), sts_puttuple(), sub_abs(), subbuild_joinrel_joinlist(), subquery_is_pushdown_safe(), substitute_phv_relids_walker(), SubTransGetParent(), SubTransGetTopmostTransaction(), SubTransSetParent(), subxact_info_add(), subxact_info_read(), subxact_info_write(), summarize_range(), swap_relation_files(), SwitchBackToLocalLatch(), SwitchToSharedLatch(), SyncRepGetNthLatestSyncRecPtr(), SyncRepQueueInsert(), SyncRepUpdateSyncStandbysDefined(), SyncRepWaitForLSN(), SyncRepWakeQueue(), SyncScanShmemInit(), SysCacheGetAttr(), SysLogger_Start(), systable_endscan_ordered(), systable_getnext(), systable_getnext_ordered(), systable_recheck_tuple(), table_beginscan_parallel(), table_parallelscan_estimate(), table_parallelscan_initialize(), table_rescan_tidrange(), table_scan_getnextslot_tidrange(), table_scan_update_snapshot(), table_slot_callbacks(), TablespaceCreateDbspace(), tar_close(), tar_get_current_pos(), tar_open_for_write(), tar_sync(), tar_write(), tblspc_redo(), tbm_add_tuples(), tbm_begin_iterate(), tbm_create_pagetable(), tbm_find_pageentry(), tbm_intersect(), tbm_intersect_page(), tbm_iterate(), tbm_lossify(), tbm_page_is_lossy(), tbm_prepare_shared_iterate(), tbm_union(), TemporalSimplify(), TerminateBackgroundWorker(), TerminateBufferIO(), test_indoption(), test_predtest(), TestForOldSnapshot(), text_format(), text_position_get_match_pos(), text_position_next(), text_position_next_internal(), text_position_setup(), tfuncFetchRows(), TidExprListCreate(), TidListEval(), TidQualFromRestrictInfoList(), tlist_matches_tupdesc(), to_chars_df(), to_chars_f(), toast_build_flattened_tuple(), toast_compress_datum(), toast_datum_size(), toast_decompress_datum(), toast_decompress_datum_slice(), toast_fetch_datum_slice(), toast_flatten_tuple(), toast_flatten_tuple_to_datum(), toast_open_indexes(), toast_raw_datum_size(), toast_save_datum(), TopoSort(), TParserGet(), TransactionGroupUpdateXidStatus(), TransactionIdGetCommitTsData(), TransactionIdInRecentPast(), TransactionIdIsInProgress(), TransactionIdLimitedForOldSnapshots(), TransactionIdSetCommitTs(), TransactionIdSetPageStatusInternal(), TransactionIdSetStatusBit(), TransactionIdSetTreeStatus(), TransferExpandedObject(), TransferPredicateLocksToNewTarget(), transformAExprBetween(), transformAggregateCall(), transformArrayExpr(), transformAssignedExpr(), transformAssignmentIndirection(), transformAssignmentSubscripts(), transformCaseExpr(), transformColumnDefinition(), transformColumnRef(), transformCreateStmt(), transformCurrentOfExpr(), transformDistinctOnClause(), transformExpr(), transformExpressionList(), transformFkeyCheckAttrs(), transformFkeyGetPrimaryKey(), transformFrameOffset(), transformFromClauseItem(), transformFuncCall(), transformGroupClause(), transformGroupingSet(), transformIndexConstraint(), transformIndexConstraints(), transformIndirection(), transformInsertStmt(), transformMultiAssignRef(), transformOptionalSelectInto(), transformPartitionBound(), transformPartitionBoundValue(), transformPartitionCmd(), transformRangeFunction(), transformRangeSubselect(), transformRangeTableFunc(), transformSetOperationStmt(), transformSetOperationTree(), transformSubLink(), transformTargetList(), transformValuesClause(), transformWindowFuncCall(), transformWithClause(), transformXmlExpr(), transientrel_startup(), traverse_lacons(), TriggerEnabled(), trivial_subqueryscan(), truncate_cb_wrapper(), TruncateMultiXact(), try_partial_hashjoin_path(), try_partial_mergejoin_path(), try_partial_nestloop_path(), try_partitionwise_join(), try_relation_open(), TryReuseForeignKey(), TS_phrase_execute(), TS_phrase_output(), ts_setup_firstcall(), tsmatchsel(), tsqueryrecv(), tstoreStartupReceiver(), tsvector_concat(), tsvector_delete_by_indices(), tsvectorin(), tts_buffer_heap_clear(), tts_buffer_heap_copy_heap_tuple(), tts_buffer_heap_copy_minimal_tuple(), tts_buffer_heap_copyslot(), tts_buffer_heap_get_heap_tuple(), tts_buffer_heap_getsomeattrs(), tts_buffer_heap_getsysattr(), tts_buffer_heap_materialize(), tts_buffer_heap_store_tuple(), tts_heap_copy_heap_tuple(), tts_heap_get_heap_tuple(), tts_heap_getsomeattrs(), tts_heap_getsysattr(), tts_heap_materialize(), tts_minimal_getsomeattrs(), tts_minimal_materialize(), tts_minimal_store_tuple(), tts_virtual_copy_heap_tuple(), tts_virtual_copy_minimal_tuple(), tts_virtual_copyslot(), TupleDescInitBuiltinEntry(), TupleHashTableMatch(), TupleQueueReaderNext(), tuples_equal(), tuplesort_begin_cluster(), tuplesort_begin_common(), tuplesort_estimate_shared(), tuplesort_gettuple_common(), tuplesort_heap_insert(), tuplesort_heap_replace_top(), tuplesort_initialize_shared(), tuplesort_markpos(), tuplesort_rescan(), tuplesort_restorepos(), tuplesort_set_bound(), tuplesort_skiptuples(), tuplesort_sort_memtuples(), tuplesort_space_type_name(), tuplestore_copy_read_pointer(), tuplestore_gettuple(), tuplestore_puttuple_common(), tuplestore_rescan(), tuplestore_select_read_pointer(), tuplestore_skiptuples(), tuplestore_trim(), TwoPhaseGetGXact(), TwoPhaseShmemInit(), TypeCacheRelCallback(), TypeCategory(), TypeShellMake(), typeStringToTypeName(), uint32_hash(), uint64_to_itemptr(), UnGrantLock(), unicode_is_normalized(), unicode_normalize(), unicode_normalize_func(), unionkey(), uniqueentry(), uniqueifyJsonbObject(), unlink_segment(), UnpinBuffer(), UnregisterSnapshotFromOwner(), update_frameheadpos(), update_frametailpos(), update_grouptailpos(), update_index_statistics(), update_mergeclause_eclasses(), update_placeholder_eval_levels(), update_relispartition(), UpdateActiveSnapshotCommandId(), UpdateXmaxHintBits(), UserAbortTransactionBlock(), vac_open_indexes(), vac_truncate_clog(), vac_update_datfrozenxid(), vacuum(), vacuum_indexes_leader(), vacuum_is_relation_owner(), vacuum_one_database(), vacuum_open_relation(), vacuum_rel(), vacuum_set_xid_limits(), vacuumLeafPage(), vacuumLeafRoot(), vacuumRedirectAndPlaceholder(), validArcLabel(), validatePartitionedIndex(), validateRecoveryParameters(), ValuesNext(), valueTruth(), valueTypeName(), varbit_support(), varchar_support(), VariableHasHook(), varstr_abbrev_abort(), verbosity_hook(), verify_heapam_tupdesc(), view_cols_are_auto_updatable(), VirtualXactLock(), VirtualXactLockTableCleanup(), VirtualXactLockTableInsert(), visibilitymap_clear(), visibilitymap_count(), visibilitymap_set(), WaitEventSetWait(), WaitForCommands(), WaitForParallelWorkersToAttach(), WaitForParallelWorkersToFinish(), WaitForProcSignalBarrier(), WaitForTerminatingWorkers(), WaitForWALToBecomeAvailable(), WaitForWorkers(), WaitLatch(), WaitLatchOrSocket(), walkStatEntryTree(), WalRcvDie(), WalRcvWaitForStartPosition(), WALRead(), WalReceiverMain(), WalSndKill(), WalSndSetState(), wchar2char(), width_bucket_array_fixed(), width_bucket_array_variable(), window_cume_dist(), window_gettupleslot(), window_percent_rank(), WinGetCurrentPosition(), WinGetFuncArgCurrent(), WinGetFuncArgInFrame(), WinGetFuncArgInPartition(), WinGetPartitionLocalMemory(), WinGetPartitionRowCount(), WinRowsArePeers(), WinSetMarkPosition(), worker_freeze_result_tape(), worker_get_identifier(), worker_nomergeruns(), worker_spi_launch(), WorkTableScanNext(), write_pipe_chunks(), write_relcache_init_file(), write_relmap_file(), WritebackContextInit(), writeFragment(), writeListPage(), WriteRecoveryConfig(), writeTimeLineHistory(), writetup_datum(), xact_redo(), xact_redo_abort(), xact_redo_commit(), xactGetCommittedInvalidationMessages(), XactLockTableWait(), XactLogAbortRecord(), XactLogCommitRecord(), XidCacheRemoveRunningXids(), XidIsConcurrent(), xlog_redo(), XLogBeginInsert(), XLogBeginRead(), XLogEnsureRecordSpace(), XLogFileClose(), XLogInsertRecord(), XLogPageRead(), XLogReadBufferExtended(), XLogReadBufferForRedoExtended(), XLogReadDetermineTimeline(), XLogReaderValidatePageHeader(), XLogReadRecord(), XLogRecGetFullXid(), XLogRecPtrToBytePos(), XLogRegisterBlock(), XLogRegisterBufData(), XLogRegisterBuffer(), XLogRegisterData(), XLogSaveBufferForHint(), XLogSendPhysical(), XLogSetRecordFlags(), XLOGShmemInit(), XLOGShmemSize(), xlogVacuumPage(), XLogWrite(), xml_is_document(), xmldata_root_element_start(), and XmlTableGetValue().
#define AssertArg | ( | condition | ) | ((void)true) |
Definition at line 806 of file c.h.
Referenced by _soundex(), addFkRecurseReferencing(), AllocSetAlloc(), AllocSetDelete(), AllocSetReset(), CollationCreate(), CreatePortal(), CreateTemplateTupleDesc(), ExecCopySlot(), expand_dynamic_library_name(), file_exists(), find_in_dynamic_libpath(), GenerationReset(), get_controlfile(), get_db_info(), GetMemoryChunkContext(), heap_multi_insert(), InsertOneValue(), LWLockAcquire(), LWLockAttemptLock(), LWLockConditionalAcquire(), MemoryContextAlloc(), MemoryContextAllocExtended(), MemoryContextAllocHuge(), MemoryContextAllocZero(), MemoryContextAllocZeroAligned(), MemoryContextAllowInCriticalSection(), MemoryContextDelete(), MemoryContextDeleteChildren(), MemoryContextGetParent(), MemoryContextIsEmpty(), MemoryContextMemAllocated(), MemoryContextRegisterResetCallback(), MemoryContextReset(), MemoryContextResetChildren(), MemoryContextResetOnly(), MemoryContextSetIdentifier(), MemoryContextSetParent(), MemoryContextStatsInternal(), MemoryContextStatsPrint(), MultiXactIdCreate(), MultiXactIdExpand(), palloc(), palloc0(), palloc_extended(), ParseLongOption(), PortalCleanup(), PortalDefineQuery(), PortalDrop(), PortalRun(), PortalRunFetch(), PortalStart(), PutMemoryContextsStatsTupleStore(), ReindexMultipleTables(), relation_needs_vacanalyze(), RelationBuildLocalRelation(), rename_constraint_internal(), ReorderBufferSetBaseSnapshot(), ReplicationSlotAcquireInternal(), SetDataDir(), SetOuterUserId(), SetSessionUserId(), slot_attisnull(), slot_getattr(), slot_getsysattr(), SSL_CTX_set_max_proto_version(), StoreCatalogInheritance(), substitute_libpath_macro(), transformOfType(), TupleDescCopyEntry(), TupleDescInitBuiltinEntry(), TupleDescInitEntry(), TupleDescInitEntryCollation(), tuplesort_begin_heap(), and XmlTableSetColumnFilter().
#define AssertPointerAlignment | ( | ptr, | |
bndr | |||
) | ((void)true) |
Definition at line 808 of file c.h.
Referenced by pg_atomic_add_fetch_u32(), pg_atomic_add_fetch_u64(), pg_atomic_compare_exchange_u32(), pg_atomic_compare_exchange_u64(), pg_atomic_exchange_u32(), pg_atomic_exchange_u64(), pg_atomic_fetch_add_u32(), pg_atomic_fetch_add_u64(), pg_atomic_fetch_and_u32(), pg_atomic_fetch_and_u64(), pg_atomic_fetch_or_u32(), pg_atomic_fetch_or_u64(), pg_atomic_fetch_sub_u32(), pg_atomic_fetch_sub_u64(), pg_atomic_init_u32(), pg_atomic_init_u64(), pg_atomic_read_u32(), pg_atomic_read_u64(), pg_atomic_sub_fetch_u32(), pg_atomic_sub_fetch_u64(), pg_atomic_unlocked_write_u32(), pg_atomic_write_u32(), and pg_atomic_write_u64().
#define AssertState | ( | condition | ) | ((void)true) |
Definition at line 807 of file c.h.
Referenced by _bt_load(), ChangeToDataDir(), CommitTransactionCommand(), find_in_dynamic_libpath(), GetAuthenticatedUserId(), GetOuterUserId(), GetSessionUserId(), GetUserId(), InitializeSessionUserId(), InitializeSessionUserIdStandalone(), InitTempTableNamespace(), MemoryContextInit(), PortalDefineQuery(), PortalStart(), RollbackAndReleaseCurrentSubTransaction(), SetOuterUserId(), SetSessionAuthorization(), SetSessionUserId(), tuplesort_begin_cluster(), tuplesort_begin_index_btree(), and tuplesort_begin_index_gist().
#define AssertVariableIsOfType | ( | varname, | |
typename | |||
) |
#define AssertVariableIsOfTypeMacro | ( | varname, | |
typename | |||
) |
Definition at line 692 of file c.h.
Referenced by init_params().
#define BUFFERALIGN | ( | LEN | ) | TYPEALIGN(ALIGNOF_BUFFER, (LEN)) |
Definition at line 759 of file c.h.
Referenced by _bt_parallel_estimate_shared(), InitializeParallelDSM(), shm_toc_allocate(), shm_toc_estimate(), shm_toc_freespace(), SimpleLruInit(), and SimpleLruShmemSize().
#define BUFFERALIGN_DOWN | ( | LEN | ) | TYPEALIGN_DOWN(ALIGNOF_BUFFER, (LEN)) |
Definition at line 770 of file c.h.
Referenced by shm_toc_create().
#define CACHELINEALIGN | ( | LEN | ) | TYPEALIGN(PG_CACHE_LINE_SIZE, (LEN)) |
Definition at line 760 of file c.h.
Referenced by InitCatCache(), InitShmemAllocation(), ShmemAllocRaw(), and ShmemInitStruct().
#define CppAsString2 | ( | x | ) | CppAsString(x) |
Definition at line 289 of file c.h.
Referenced by buildMatViewRefreshDependencies(), check_for_data_type_usage(), database_get_xml_visible_tables(), describeOneTableDetails(), describeTypes(), get_parallel_object_list(), get_rel_infos(), getTables(), listPartitionedTables(), listTables(), main(), permissionsList(), postgresImportForeignSchema(), schema_get_xml_visible_tables(), set_frozenxids(), setup_privileges(), sql_exec_dumpalltables(), sql_exec_searchtables(), vacuum_one_database(), and vacuumlo().
#define dgettext | ( | d, | |
x | |||
) | (x) |
Definition at line 1181 of file c.h.
Referenced by ECPGis_noind_null(), PLy_elog_impl(), PLy_exception_set(), PLy_output(), and PQenv2encoding().
#define dngettext | ( | d, | |
s, | |||
p, | |||
n | |||
) | ((n) == 1 ? (s) : (p)) |
Definition at line 1183 of file c.h.
Referenced by PLy_exception_set_plural(), and PQenv2encoding().
#define DOUBLEALIGN_DOWN | ( | LEN | ) | TYPEALIGN_DOWN(ALIGNOF_DOUBLE, (LEN)) |
#define ESCAPE_STRING_SYNTAX 'E' |
Definition at line 1167 of file c.h.
Referenced by appendStringLiteralConn(), deparseStringLiteral(), quote_literal_internal(), quote_postgres(), and serialize_deflist().
#define false ((bool) 0) |
Definition at line 399 of file c.h.
Referenced by ecpg_get_data(), file_exists(), is_visible_fxid(), mcv_get_match_bitmap(), next_insert(), replace_variables(), and SPI_connect_ext().
#define FirstCommandId ((CommandId) 0) |
Definition at line 603 of file c.h.
Referenced by fill_seq_with_data(), heap_xlog_delete(), heap_xlog_insert(), heap_xlog_lock(), heap_xlog_multi_insert(), heap_xlog_update(), ReorderBufferReplay(), ReorderBufferStreamTXN(), SnapBuildBuildSnapshot(), SnapBuildFreeSnapshot(), SnapBuildSnapDecRefcount(), and StartTransaction().
#define FLEXIBLE_ARRAY_MEMBER /* empty */ |
Definition at line 350 of file c.h.
Referenced by satisfies_hash_partition().
#define FLOAT4_FITS_IN_INT16 | ( | num | ) | ((num) >= (float4) PG_INT16_MIN && (num) < -((float4) PG_INT16_MIN)) |
#define FLOAT4_FITS_IN_INT32 | ( | num | ) | ((num) >= (float4) PG_INT32_MIN && (num) < -((float4) PG_INT32_MIN)) |
#define FLOAT4_FITS_IN_INT64 | ( | num | ) | ((num) >= (float4) PG_INT64_MIN && (num) < -((float4) PG_INT64_MIN)) |
#define FLOAT8_FITS_IN_INT16 | ( | num | ) | ((num) >= (float8) PG_INT16_MIN && (num) < -((float8) PG_INT16_MIN)) |
#define FLOAT8_FITS_IN_INT32 | ( | num | ) | ((num) >= (float8) PG_INT32_MIN && (num) < -((float8) PG_INT32_MIN)) |
#define FLOAT8_FITS_IN_INT64 | ( | num | ) | ((num) >= (float8) PG_INT64_MIN && (num) < -((float8) PG_INT64_MIN)) |
Definition at line 1107 of file c.h.
Referenced by coerceToInt(), dtoi8(), and interval_mul().
#define FLOAT8PASSBYVAL false |
Definition at line 570 of file c.h.
Referenced by bootstrap_template1(), build_minmax_path(), compute_range_stats(), float4_accum(), float8_accum(), float8_combine(), float8_regr_accum(), float8_regr_combine(), GuessControlValues(), hash_metapage_info(), make_const(), percentile_cont_float8_multi_final(), percentile_cont_multi_final_common(), percentile_disc_multi_final(), rewriteSearchAndCycle(), TupleDescInitBuiltinEntry(), and WriteControlFile().
#define gettext | ( | x | ) | (x) |
Definition at line 1180 of file c.h.
Referenced by err_gettext(), report_backup_error(), report_fatal_error(), and report_manifest_error().
#define gettext_noop | ( | x | ) | (x) |
Definition at line 1197 of file c.h.
Referenced by _PG_init(), aclcheck_error(), auth_failed(), cannotCastJsonbValue(), coerce_function_result_tuple(), describeAccessMethods(), describeAggregates(), describeFunctions(), describeOneTableDetails(), describeOneTSConfig(), describeOneTSParser(), describeOperators(), describePublications(), DescribeQuery(), describeRoles(), describeSubscriptions(), describeTablespaces(), describeTypes(), do_lo_list(), does_not_exist_skipping(), error_severity(), exec_stmt_block(), exec_stmt_return_next(), exec_stmt_return_query(), ExecAlterDefaultPrivilegesStmt(), ExecuteGrantStmt(), get_recovery_conflict_desc(), listAllDbs(), listCasts(), listCollations(), listConversions(), listDbRoleSettings(), listDefaultACLs(), listDomains(), listEventTriggers(), listExtendedStats(), listExtensions(), listForeignDataWrappers(), listForeignServers(), listForeignTables(), listLanguages(), listOneExtensionContents(), listOperatorClasses(), listOperatorFamilies(), listOpFamilyFunctions(), listOpFamilyOperators(), listPartitionedTables(), listPublications(), listSchemas(), listTables(), listTSConfigs(), listTSDictionaries(), listTSParsers(), listTSTemplates(), listUserMappings(), objectDescription(), owningrel_does_not_exist_skipping(), parse_hba_auth_opt(), parse_int(), permissionsList(), plpgsql_exec_event_trigger(), plpgsql_exec_function(), plpgsql_exec_trigger(), printACLColumn(), report_name_conflict(), report_namespace_conflict(), schema_does_not_exist_skipping(), type_in_list_does_not_exist_skipping(), vacuum_one_database(), view_col_is_auto_updatable(), view_query_is_auto_updatable(), XactLockTableWaitErrorCb(), and xml_is_document().
#define HIGHBIT (0x80) |
Definition at line 1155 of file c.h.
Referenced by bit_in(), brin_form_placeholder_tuple(), brin_form_tuple(), fill_val(), heap_fill_tuple(), iso8859_1_to_utf8(), latin2mic_with_table(), local2local(), mic2latin_with_table(), and varbit_in().
#define INT64_FORMAT "%" INT64_MODIFIER "d" |
Definition at line 483 of file c.h.
Referenced by _PrintExtraToc(), _ShowOption(), _tarAddFile(), _tarPositionTo(), brin_desummarize_range(), brin_summarize_range(), bt_check_every_level(), bt_metap(), bt_page_items_internal(), build_pgstattuple_type(), cash_in(), compute_array_stats(), create_and_test_bloom(), createPartitions(), do_setval(), doLog(), dumpSequence(), evalStandardFunc(), ExecIncrementalSort(), ExecQueryUsingCursor(), ExplainPropertyInteger(), FilePrefetch(), FileRead(), FileWrite(), FileWriteback(), getVariable(), init_params(), initGenerateDataClientSide(), initGenerateDataServerSide(), inv_seek(), inv_truncate(), macaddr_abbrev_abort(), main(), map_sql_type_to_xmlschema_type(), mergeruns(), network_abbrev_abort(), nextval_internal(), nfalsepos_for_missing_strings(), numeric_abbrev_abort(), parseScriptWeight(), pg_prewarm(), pg_size_pretty(), pgstatindex_impl(), pgtypes_fmt_replace(), populate_with_dummy_strings(), printProgressReport(), printResults(), process_queued_fetch_requests(), progress_report(), send_int8_string(), sequence_options(), show_hashagg_info(), show_incremental_sort_group_info(), show_sort_info(), switchToPresortedPrefixMode(), uuid_abbrev_abort(), WinRowsArePeers(), and writezone().
#define INTALIGN | ( | LEN | ) | TYPEALIGN(ALIGNOF_INT, (LEN)) |
Definition at line 754 of file c.h.
Referenced by alignStringInfoInt(), fillJsonbValue(), gbt_bit_xfrm(), gbt_var_key_copy(), gbt_var_key_readable(), gbt_var_node_truncate(), jspInitByBuffer(), and padBufferToInt().
#define INTALIGN_DOWN | ( | LEN | ) | TYPEALIGN_DOWN(ALIGNOF_INT, (LEN)) |
#define InvalidCommandId (~(CommandId)0) |
Definition at line 604 of file c.h.
Referenced by ApplyLogicalMappingFile(), CommandCounterIncrement(), heap_delete(), heap_lock_tuple(), heap_update(), HeapTupleSatisfiesHistoricMVCC(), log_heap_new_cid(), ReorderBufferBuildTupleCidHash(), ReorderBufferGetTXN(), ReorderBufferProcessTXN(), ReorderBufferStreamTXN(), and SnapBuildProcessNewCid().
#define InvalidSubTransactionId ((SubTransactionId) 0) |
Definition at line 593 of file c.h.
Referenced by _SPI_end_call(), AtAbort_Portals(), AtCleanup_Portals(), AtEOSubXact_cleanup(), AtEOSubXact_Namespace(), AtEOSubXact_on_commit_actions(), AtEOSubXact_SPI(), AtEOXact_cleanup(), AtEOXact_Namespace(), AtEOXact_on_commit_actions(), CleanupTransaction(), CommitTransaction(), CopyFrom(), DefineIndex(), formrdesc(), generateClonedIndexStmt(), HoldPortal(), InitTempTableNamespace(), load_relcache_init_file(), PersistHoldablePortal(), PreCommit_on_commit_actions(), PreCommit_Portals(), PrepareTransaction(), PushTransaction(), register_on_commit_action(), RelationAssumeNewRelfilenode(), RelationBuildDesc(), RelationBuildLocalRelation(), RelationCacheInvalidate(), RelationClearRelation(), RelationClose(), RelationFlushRelation(), RelationForgetRelation(), RelationIdGetRelation(), RelationInitPhysicalAddr(), RelationReloadIndexInfo(), RememberToFreeTupleDescAtEOX(), SetTempNamespaceState(), SPI_connect_ext(), and transformIndexConstraint().
#define INVERT_COMPARE_RESULT | ( | var | ) | ((var) = ((var) < 0) ? 1 : -(var)) |
Definition at line 1125 of file c.h.
Referenced by _bt_check_rowcompare(), _bt_compare(), _bt_compare_array_elements(), ApplySortAbbrevFullComparator(), ApplySortComparator(), and heap_compare_slots().
#define IS_HIGHBIT_SET | ( | ch | ) | ((unsigned char)(ch) & HIGHBIT) |
Definition at line 1156 of file c.h.
Referenced by appendStringLiteral(), big52euc_tw(), big52mic(), bitncmp(), CopyAttributeOutCSV(), CopyAttributeOutText(), CopyReadAttributesText(), CopyReadLineText(), downcase_identifier(), esc_enc_len(), esc_encode(), euc_cn2mic(), euc_jis_20042shift_jis_2004(), euc_jp2mic(), euc_jp2sjis(), euc_kr2mic(), euc_tw2big5(), euc_tw2mic(), is_ident_start(), iso8859_1_to_utf8(), latin2mic(), latin2mic_with_table(), local2local(), LocalToUtf(), mic2big5(), mic2euc_cn(), mic2euc_jp(), mic2euc_kr(), mic2euc_tw(), mic2latin(), mic2latin_with_table(), mic2sjis(), parseVariable(), pattern_char_isalpha(), pg_any_to_server(), pg_big5_dsplen(), pg_big5_mblen(), pg_big5_verifystr(), pg_euc2wchar_with_len(), pg_euc_dsplen(), pg_euc_mblen(), pg_euccn2wchar_with_len(), pg_euccn_dsplen(), pg_euccn_mblen(), pg_eucjp_dsplen(), pg_eucjp_increment(), pg_eucjp_verifychar(), pg_eucjp_verifystr(), pg_euckr_verifychar(), pg_euckr_verifystr(), pg_euctw2wchar_with_len(), pg_euctw_dsplen(), pg_euctw_mblen(), pg_euctw_verifychar(), pg_euctw_verifystr(), pg_gb18030_dsplen(), pg_gb18030_mblen(), pg_gb18030_verifychar(), pg_gb18030_verifystr(), pg_gbk_dsplen(), pg_gbk_mblen(), pg_gbk_verifystr(), pg_is_ascii(), pg_johab_verifychar(), pg_johab_verifystr(), pg_mule_verifychar(), pg_mule_verifystr(), pg_sjis_dsplen(), pg_sjis_mblen(), pg_sjis_verifystr(), pg_strcasecmp(), pg_strncasecmp(), pg_tolower(), pg_toupper(), pg_uhc_dsplen(), pg_uhc_mblen(), pg_uhc_verifystr(), pg_utf8_verifystr(), pg_verify_mbstr_len(), pq_send_ascii_string(), PQescapeInternal(), PQescapeStringInternal(), report_json_context(), shift_jis_20042euc_jis_2004(), sjis2euc_jp(), sjis2mic(), utf8_to_iso8859_1(), valid_variable_name(), and varbit_out().
#define lengthof | ( | array | ) | (sizeof (array) / sizeof ((array)[0])) |
Definition at line 734 of file c.h.
Referenced by _dosmaperr(), add_object_address(), AddNewAttributeTuples(), applyRemoteGucs(), ATExecAddColumn(), attribute_reloptions(), avl_sigusr2_handler(), BackendRun(), BackgroundWorkerUnblockSignals(), bloptions(), brinoptions(), btoptions(), build_test_info_result(), BuildV1Call(), calc_rank_cd(), cannotCastJsonbValue(), connectDatabase(), ConnectDatabase(), create_LifetimeEnd(), CreateStatistics(), default_reloptions(), describeAccessMethods(), describeFunctions(), describeOneTableDetails(), describeOneTSParser(), describeSubscriptions(), dioptions(), do_pset(), dsa_allocate_extended(), euc_jis_2004_to_utf8(), ExceptionalCondition(), exec_command_crosstabview(), exec_move_row(), exec_move_row_from_fields(), ExecInterpExpr(), executeDateTimeMethod(), fetch_remote_table_info(), fill_hba_line(), findBuiltin(), get_code_entry(), get_encoding_name_for_icu(), get_object_property_data(), GetCommandTagEnum(), GetLockConflicts(), GetLockmodeName(), GetLocksMethodTable(), GetLockTagsMethodTable(), getWeights(), ginoptions(), gistoptions(), hashoptions(), index_delete_sort(), InitCatalogCache(), initCreateFKeys(), initCreatePKeys(), initCreateTables(), initialize_data_directory(), is_objectclass_supported(), iso8859_to_utf8(), listAvailableScripts(), listCasts(), listCollations(), listConversions(), listDefaultACLs(), listEventTriggers(), listOperatorClasses(), listOperatorFamilies(), listOpFamilyFunctions(), listOpFamilyOperators(), listPartitionedTables(), listPublications(), listTables(), llvm_compile_expr(), lock_twophase_postcommit(), lock_twophase_recover(), lock_twophase_standby_recover(), LockAcquireExtended(), LockHasWaiters(), LockRelease(), LockReleaseAll(), LockReleaseSession(), LockWaiterCount(), lookup_prop_name(), LookupBackgroundWorkerFunction(), LookupParallelWorkerFunction(), makeRangeConstructors(), objectDescription(), p_isspecial(), permissionsList(), pg_char_to_encoding(), pg_collation_actual_version(), pg_get_catalog_foreign_keys(), pg_stat_get_activity(), pgarch_start(), PGLC_localeconv(), pgstat_reset_all(), plpgsql_token_is_unreserved_keyword(), read_objtype_from_string(), recompose_code(), RemoveFromWaitQueue(), SendQuery(), set_backtrace(), SharedFileSetInit(), shift_jis_2004_to_utf8(), slot_compile_deform(), spgoptions(), StartChildProcess(), SysLogger_Start(), SystemAttributeByName(), SystemAttributeDefinition(), tablespace_reloptions(), test_integerset(), utf8_to_euc_jis_2004(), utf8_to_iso8859(), utf8_to_shift_jis_2004(), utf8_to_win(), view_reloptions(), win_to_utf8(), and XLogFileInit().
#define likely | ( | x | ) | ((x) != 0) |
Definition at line 272 of file c.h.
Referenced by exec_eval_simple_expr(), ExecEvalParamExtern(), ExecFindPartition(), ExecInterpExpr(), expanded_record_get_field(), expanded_record_get_tupdesc(), GetSnapshotData(), pg_strtoint16(), pg_strtoint32(), and tts_buffer_heap_materialize().
#define LONGALIGN_DOWN | ( | LEN | ) | TYPEALIGN_DOWN(ALIGNOF_LONG, (LEN)) |
#define Max | ( | x, | |
y | |||
) | ((x) > (y) ? (x) : (y)) |
Definition at line 980 of file c.h.
Referenced by _bt_bottomupdel_pass(), _bt_deadblocks(), _bt_readpage(), accumArrayResultArr(), add_paths_to_append_rel(), addHyperLogLog(), AfterTriggerEnlargeQueryState(), agg_retrieve_direct(), allocate_recordbuf(), AllocSetContextCreateInternal(), AllocSetRealloc(), appendContextKeyword(), applyLockingClause(), array_set_element_expanded(), array_set_slice(), autovac_balance_cost(), bitsubstring(), bloom_create(), brincostestimate(), bt_check_every_level(), build_pertrans_for_aggref(), bytea_substring(), calc_hist_selectivity_scalar(), CheckArchiveTimeout(), clean_stopword_intree(), CLOGShmemBuffers(), CommitTsShmemBuffers(), compute_array_stats(), compute_bitmap_pages(), compute_max_dead_tuples(), compute_parallel_vacuum_workers(), compute_parallel_worker(), compute_semi_anti_join_factors(), compute_tsvector_stats(), consider_groupingsets_paths(), CopyStreamPoll(), cost_agg(), cost_recursive_union(), cube_cmp_v0(), cube_contains_v0(), cube_coord_llur(), cube_inter(), cube_overlap_v0(), cube_union_v0(), cube_ur_coord(), DecodeXLogRecord(), DetermineSleepTime(), distance_1D(), enlarge_list(), entry_dealloc(), errstart(), estimate_hash_bucket_stats(), evalStandardFunc(), ExecBuildAggTrans(), ExecChooseHashTableSize(), ExecEndAgg(), ExecHashAccumInstrumentation(), ExecHashTableDetachBatch(), ExecInitAgg(), ExecInitExprRec(), ExecParallelHashIncreaseNumBatches(), ExecParallelHashTuplePrealloc(), ExecReScanAgg(), find_arguments(), find_hash_columns(), finish_spin_delay(), fmtint(), fsm_rebuild_page(), fsm_set_avail(), FuncnameGetCandidates(), g_cube_distance(), gbt_date_penalty(), gbt_time_penalty(), gbt_var_picksplit(), generate_matching_part_pairs(), generate_union_paths(), get_foreign_key_join_selectivity(), get_last_attnums_walker(), get_position(), get_sock_dir(), GetLocalBufferStorage(), GetSingleProcBlockerStatusData(), gincostestimate(), GinFormTuple(), ginHeapTupleFastCollect(), ginvacuumcleanup(), gtsvectorout(), hash_choose_num_buckets(), heap_page_prune_opt(), heap_vacuum_rel(), helpSQL(), index_pages_fetched(), inet_hist_value_sel(), inetand(), inetor(), initialize_aggregates(), initializeInput(), iterate_word_similarity(), lazy_scan_heap(), ltree_penalty(), LWLockRegisterTranche(), merge_fdw_options(), mergeruns(), multirange_cmp(), multirange_size_estimate(), new_list(), optimal_k(), output(), parse_manifest_file(), pg_get_replication_slots(), pgss_shmem_startup(), pgstat_recv_tabstat(), pgstat_report_analyze(), prefix_selectivity(), process_equivalence(), process_syncing_tables_for_apply(), prsd_headline(), RE_compile_and_cache(), ReadPageInternal(), reaper(), record_cmp(), record_eq(), record_image_cmp(), record_image_eq(), repoint_table_dependencies(), save_state_data(), set_foreign_size(), SetConstraintStateAddItem(), setup_pct_info(), shm_mq_receive(), show_hash_info(), show_trgm(), SnapBuildProcessNewCid(), split_pathtarget_walker(), StartPrepare(), statapprox_heap(), StreamLogicalLog(), sts_read_tuple(), subquery_planner(), table_block_parallelscan_startblock_init(), tbm_calculate_entries(), test_rb_tree(), text_substring(), TS_phrase_execute(), tsquery_opr_selec(), tuplesort_begin_common(), tuplesort_merge_order(), tuplestore_begin_common(), varstr_abbrev_convert(), varstrfastcmp_locale(), and WinGetFuncArgInFrame().
#define MAXALIGN | ( | LEN | ) | TYPEALIGN(MAXIMUM_ALIGNOF, (LEN)) |
Definition at line 757 of file c.h.
Referenced by _bt_afternewitemoff(), _bt_buildadd(), _bt_check_third_page(), _bt_checkpage(), _bt_dedup_finish_pending(), _bt_dedup_save_htid(), _bt_dedup_start_pending(), _bt_delitems_delete(), _bt_delitems_vacuum(), _bt_doinsert(), _bt_findsplitloc(), _bt_form_posting(), _bt_insert_parent(), _bt_insertonpg(), _bt_recsplitloc(), _bt_restore_page(), _bt_saveitem(), _bt_setuppostingitems(), _bt_singleval_fillfactor(), _bt_split(), _bt_split_penalty(), _bt_truncate(), _bt_update_posting(), _hash_checkpage(), _hash_doinsert(), _hash_init(), _hash_pgaddmultitup(), _hash_splitbucket(), _hash_squeezebucket(), _PG_init(), AllocSetAlloc(), AllocSetContextCreateInternal(), AllocSetRealloc(), AllocSetStats(), ApplyLauncherShmemSize(), attach_internal(), AutoVacuumShmemInit(), AutoVacuumShmemSize(), begin_parallel_vacuum(), brin_doinsert(), brin_doupdate(), brin_form_placeholder_tuple(), brin_form_tuple(), brin_inclusion_opcinfo(), brin_memtuple_initialize(), brin_minmax_opcinfo(), brin_new_memtuple(), bt_page_print_tuples(), bt_rootdescend(), BTPageSetDeleted(), btree_xlog_insert(), btree_xlog_split(), btree_xlog_updates(), BTreeTupleSetPosting(), build_column_frequencies(), build_dummy_expanded_header(), CatalogCacheCreateEntry(), check_tuple_header_and_visibilty(), choose_hashed_setop(), choose_nelem_alloc(), compact_palloc0(), ConvertTimeZoneAbbrevs(), copy_plpgsql_datums(), create_internal(), CreateWaitEventSet(), DecodeXLogRecord(), dense_alloc(), dsa_minimum_size(), element_alloc(), entryIsEnoughSpace(), entrySplitPage(), ER_get_flat_size(), estimate_rel_size(), estimate_size(), ExecChooseHashTableSize(), ExecHashIncreaseNumBatches(), ExecHashIncreaseNumBuckets(), ExecInitParallelPlan(), ExecInitSubscriptingRef(), ExecParallelHashIncreaseNumBuckets(), ExecParallelHashRepartitionFirst(), ExecParallelHashRepartitionRest(), ExecParallelHashTableInsert(), ExecParallelHashTupleAlloc(), ExecParallelHashTuplePrealloc(), expand_tuple(), FinishPreparedTransaction(), gbt_tstz_consistent(), gbt_tstz_distance(), GenerationAlloc(), GenerationContextCreate(), GenerationStats(), get_agg_clause_costs(), get_segment_by_index(), GetMemoryChunkContext(), gin_leafpage_items(), GinFormInteriorTuple(), GinFormTuple(), gistcheckpage(), gistGetItupFromPage(), gistInitBuffering(), GistPageGetDeleteXid(), GistPageSetDeleted(), gistPlaceItupToPage(), gistPushItupToNodeBuffer(), gtrgm_consistent(), gtrgm_distance(), gtrgm_penalty(), hash_agg_entry_size(), hash_estimate_size(), hash_xlog_move_page_contents(), hash_xlog_squeeze_page(), heap_form_minimal_tuple(), heap_form_tuple(), heap_mask(), heap_multi_insert(), heap_page_items(), heap_toast_insert_or_update(), heap_update(), heapam_relation_needs_toast_table(), index_form_tuple(), index_parallelscan_estimate(), index_parallelscan_initialize(), insert_into_bucket(), jsonb_exec_setup(), lca_inner(), make_expanded_record_from_exprecord(), make_expanded_record_from_tupdesc(), make_expanded_record_from_typeid(), make_new_segment(), makeSublist(), MakeTupleTableSlot(), MemoryContextContains(), PageAddItemExtended(), PageIndexMultiDelete(), PageIndexTupleDelete(), PageIndexTupleDeleteNoCompact(), PageIndexTupleOverwrite(), PageInit(), PageIsVerifiedExtended(), PageRepairFragmentation(), parse_lquery(), parse_ltree(), ParsePrepareRecord(), PGSharedMemoryCreate(), pgss_memsize(), pgstat_hash_page(), pgstathashindex(), plpgsql_finish_datums(), postgresGetForeignRelSize(), PrepareRedoAdd(), ProcessRecords(), ProcessTwoPhaseBuffer(), range_serialize(), raw_heap_insert(), ReadTwoPhaseFile(), RecoverPreparedTransactions(), relation_byte_size(), RelationGetBufferForTuple(), ReserveXLogInsertLocation(), ReserveXLogSwitch(), save_state_data(), set_rel_width(), shm_mq_create(), shm_mq_receive(), shm_mq_send_bytes(), ShmemAllocUnlocked(), SimpleLruInit(), SimpleLruShmemSize(), SlabContextCreate(), SpGistGetTypeSize(), SpGistInitPage(), SpGistPageAddNewItem(), statext_mcv_deserialize(), statext_mcv_serialize(), statext_ndistinct_deserialize(), StrategyShmemSize(), subpath_is_hashable(), subplan_is_hashable(), toast_flatten_tuple_to_datum(), toast_tuple_find_biggest_attribute(), tuplesort_estimate_shared(), TwoPhaseShmemInit(), TwoPhaseShmemSize(), verify_hash_page(), verify_heapam(), writezone(), XLogReaderValidatePageHeader(), and XLogReadRecord().
#define MAXALIGN64 | ( | LEN | ) | TYPEALIGN64(MAXIMUM_ALIGNOF, (LEN)) |
Definition at line 782 of file c.h.
Referenced by CopyXLogRecordToWAL().
#define MAXALIGN_DOWN | ( | LEN | ) | TYPEALIGN_DOWN(MAXIMUM_ALIGNOF, (LEN)) |
Definition at line 769 of file c.h.
Referenced by _bt_load(), shm_mq_create(), and shm_mq_sendv().
#define MemSet | ( | start, | |
val, | |||
len | |||
) |
Definition at line 1008 of file c.h.
Referenced by _bt_mark_page_halfdead(), _hash_init_metabuffer(), _hash_initbitmapbuffer(), _ltree_picksplit(), aclexplode(), addArcs(), addKey(), AddRoleMems(), AdvanceXLInsertBuffer(), agg_refill_hash_table(), allocate_record_info(), AllocateVfd(), AlterDatabase(), AlterDomainDefault(), AlterRole(), apw_start_database_worker(), apw_start_leader_worker(), array_set_element(), array_set_slice(), ATAddForeignKeyConstraint(), ATDetachCheckNoForeignKeyRefs(), ATExecAlterColumnType(), BaseBackup(), begin_parallel_vacuum(), bitshiftleft(), bitshiftright(), blcostestimate(), brin_metapage_info(), brin_page_items(), btcostestimate(), btree_xlog_mark_page_halfdead(), btree_xlog_unlink_page(), build_paths_for_OR(), calc_rank_cd(), CastCreate(), check_wal_consistency_checking(), CheckpointerShmemInit(), compute_function_hashkey(), conninfo_init(), ConstructTupleDescriptor(), CopyXLogRecordToWAL(), cost_agg(), create_grouping_paths(), create_index_paths(), create_partial_grouping_paths(), CreateCheckPoint(), createdb(), CreateReplicationSlot(), CreateRestartPoint(), CreateRole(), CreateSharedBackendStatus(), CreateTableSpace(), CreateTransform(), DefineAttr(), DelRoleMems(), dir_realloc(), errstart(), estimate_path_cost_size(), EvalPlanQualBegin(), examine_variable(), ExecGrant_Attribute(), ExecGrant_Database(), ExecGrant_Fdw(), ExecGrant_ForeignServer(), ExecGrant_Function(), ExecGrant_Language(), ExecGrant_Largeobject(), ExecGrant_Namespace(), ExecGrant_Relation(), ExecGrant_Tablespace(), ExecGrant_Type(), ExecHashIncreaseNumBatches(), ExecIndexBuildScanKeys(), ExecReScanAgg(), ExecReScanWindowAgg(), ExecStoreAllNullTuple(), expand_planner_arrays(), expandRecordVariable(), expression_planner_with_deps(), extract_query_dependencies(), fetch_fp_info(), find_arguments(), format_elog_string(), g_intbig_picksplit(), generate_series_timestamp(), generate_series_timestamptz(), get_join_index_paths(), getCopyStart(), GetErrorContextStack(), getParamDescriptions(), getRowDescriptions(), ghstore_picksplit(), gistcostestimate(), gtrgm_picksplit(), gtsvector_picksplit(), hash_bitmap_info(), hash_create(), hash_metapage_info(), hash_page_items(), hash_page_stats(), hash_record(), hash_record_extended(), hashcostestimate(), hdefault(), heap_get_root_tuples(), heap_tuple_infomask_flags(), heap_xlog_insert(), heap_xlog_multi_insert(), heap_xlog_update(), hstore_from_record(), hstore_populate_record(), IdentifySystem(), InitFileAccess(), initGinState(), InitializeRelfilenodeMap(), InitProcGlobal(), InitResultRelInfo(), InsertRule(), internal_load_library(), inv_read(), inv_truncate(), inv_write(), lo_initialize(), load_relcache_init_file(), lock_twophase_recover(), LockAcquireExtended(), LockHasWaiters(), LockHeldByMe(), LockRelease(), LogStreamerMain(), lookup_ts_config_cache(), lookup_ts_dictionary_cache(), lookup_ts_parser_cache(), lookup_type_cache(), ltsWriteBlock(), make_oper_cache_key(), makeEmptyPGconn(), makesign(), MarkAsPreparingGuts(), mdread(), movedb(), MultiXactShmemInit(), newLOfd(), NextCopyFrom(), NUM_processor(), PageInit(), parse_basebackup_options(), parse_hba_auth_opt(), PerformRadiusTransaction(), pg_cursor(), pg_event_trigger_ddl_commands(), pg_event_trigger_dropped_objects(), pg_getnameinfo_all(), pg_lock_status(), pg_malloc_internal(), pg_partition_tree(), pg_prepared_statement(), pg_prepared_xact(), pg_stat_get_activity(), pg_stat_get_archiver(), pg_stat_get_progress_info(), pg_stat_get_replication_slots(), pg_stat_get_slru(), pg_stat_get_subscription(), pg_stat_get_wal(), pg_stat_get_wal_receiver(), pg_stat_get_wal_senders(), pg_stat_statements_info(), pg_stop_backup_v2(), pg_timezone_abbrevs(), pg_timezone_names(), pg_visibility(), pg_visibility_map(), pg_visibility_map_rel(), pg_visibility_map_summary(), pg_visibility_rel(), pgstat_bestart(), pgstat_init_function_usage(), pgstat_progress_start_command(), pgstat_report_stat(), pgstat_send_bgwriter(), pgstat_send_funcstats(), pgstat_send_slru(), pgstat_send_wal(), pgstathashindex(), plperl_call_handler(), plperl_inline_handler(), plpgsql_inline_handler(), plpgsql_validator(), plpython_inline_handler(), PMSignalShmemInit(), populate_record(), postgres_fdw_get_connections(), pq_parse_errornotice(), PQconnectPoll(), ProcSignalInit(), ProcSignalShmemInit(), reached_end_position(), ReadArrayStr(), ReadBuffer_common(), ReceiveTarCopyChunk(), ReceiveTarFile(), record_cmp(), record_eq(), record_image_cmp(), record_image_eq(), record_in(), record_out(), record_recv(), record_send(), recordDependencyOnSingleRelExpr(), recordExtensionInitPrivWorker(), RelidByRelfilenode(), RemoveAttributeById(), ReplicationOriginShmemInit(), ReplicationSlotsShmemInit(), report_corruption(), RestoreBlockImage(), ScanKeyEntryInitialize(), schedule_alarm(), seg_alloc(), sendFile(), sendFileWithContent(), SerializePendingSyncs(), set_ps_display(), SetAttrMissing(), SetDefaultACL(), setitimer(), SetupLockInTable(), SimpleLruZeroLSNs(), SimpleLruZeroPage(), SlruPhysicalReadPage(), spgcostestimate(), sql_exec(), StartReplication(), StartupXLOG(), StoreAttrDefault(), StorePartitionKey(), StreamLog(), StreamServerPort(), tar_close(), tar_finish(), tbm_get_pageentry(), tbm_mark_page_lossy(), test_predtest(), TopoSort(), transformGraph(), TrimCLOG(), TrimMultiXact(), TupleDescInitEntry(), UpdateIndexRelation(), validateForeignKeyConstraint(), variable_paramref_hook(), visibilitymap_prepare_truncate(), WalRcvShmemInit(), WalSndShmemInit(), and XLogEnsureRecordSpace().
#define MemSetAligned | ( | start, | |
val, | |||
len | |||
) |
Definition at line 1041 of file c.h.
Referenced by AllocSetContextCreateInternal(), AllocSetReset(), MemoryContextAllocExtended(), MemoryContextAllocZero(), palloc0(), and palloc_extended().
#define MemSetLoop | ( | start, | |
val, | |||
len | |||
) |
#define MemSetTest | ( | val, | |
len | |||
) |
#define Min | ( | x, | |
y | |||
) | ((x) < (y) ? (x) : (y)) |
Definition at line 986 of file c.h.
Referenced by _bt_bestsplitloc(), _bt_compare(), _bt_dedup_pass(), _bt_interval_edges(), _bt_mkscankey(), _bt_parallel_scan_and_sort(), _bt_readpage(), _bt_recsplitloc(), _bt_truncate(), acquire_inherited_sample_rows(), add_paths_to_append_rel(), afterTriggerAddEvent(), append_nonpartial_cost(), AppendJumble(), apply_child_basequals(), array_cmp(), array_set_slice(), AtSubCommit_childXids(), autovac_balance_cost(), AutoVacLauncherMain(), be_gssapi_read(), begin_parallel_vacuum(), binaryCompareStrings(), bit(), bit_cmp(), bitfromint4(), bitfromint8(), bitsubstring(), BlockSampler_Init(), bloom_create(), bms_compare(), bms_del_members(), bms_difference(), bms_int_members(), bms_is_subset(), bms_nonempty_difference(), bms_overlap(), bms_subset_compare(), bottomup_sort_and_shrink(), bpcharfastcmp_c(), brincostestimate(), brinsummarize(), buildSubPlanHash(), BuildTupleHashTableExt(), byteacmp(), byteage(), byteagt(), byteale(), bytealt(), calc_hist_selectivity_contained(), calc_hist_selectivity_contains(), check_agg_arguments(), CheckpointerMain(), cliplen(), CLOGShmemBuffers(), CommitTsShmemBuffers(), compute_array_stats(), compute_bitmap_pages(), compute_max_dead_tuples(), compute_parallel_vacuum_workers(), compute_parallel_worker(), compute_tsvector_stats(), computeRegionDelta(), consider_groupingsets_paths(), consider_new_or_clause(), convert_bytea_to_scalar(), CopyReadBinaryData(), cost_append(), cost_bitmap_or_node(), cost_incremental_sort(), create_recursiveunion_plan(), create_setop_plan(), cube_cmp_v0(), cube_contains_v0(), cube_coord_llur(), cube_inter(), cube_ll_coord(), cube_overlap_v0(), cube_union_v0(), dataBeginPlaceToPageLeaf(), DebugFileOpen(), distance_1D(), distribute_restrictinfo_to_rels(), do_watch(), doPickSplit(), dopr_outchmulti(), dostr(), entry_dealloc(), eqjoinsel(), eqjoinsel_semi(), estimate_path_cost_size(), evalStandardFunc(), ExecChooseHashTableSize(), ExecHashIncreaseNumBatches(), ExecIncrementalSort(), ExecParallelHashIncreaseNumBatches(), find_my_exec(), findCommonAncestorTimeline(), finish_spin_delay(), fmtfloat(), FreePageManagerGetInternal(), FreePagePopSpanLeader(), FreePagePushSpanLeader(), g_box_consider_split(), g_cube_distance(), gbt_var_node_cp_len(), gbt_var_node_truncate(), generate_nonunion_paths(), generate_union_paths(), geqo_set_seed(), get_position(), get_prompt(), GetAccessStrategy(), GetLocalBufferStorage(), gincostestimate(), gist_tqcmp(), HandleParallelMessage(), hashbuild(), heap_deform_tuple(), heap_index_delete_tuples(), hstore_cmp(), inet_gist_consistent(), inet_gist_penalty(), inet_hist_match_divider(), inet_inclusion_cmp(), inet_merge(), inet_semi_join_sel(), inet_spg_choose(), inet_spg_consistent_bitmap(), InitializeGUCOptionsFromEnvironment(), initializeInput(), inner_int_inter(), InsertPgAttributeTuples(), int_query_opr_selec(), internal_bpchar_pattern_compare(), internal_citext_pattern_cmp(), internal_text_pattern_compare(), lazy_parallel_vacuum_indexes(), lca_inner(), leftmostLoc(), libpq_queue_fetch_range(), log_heap_update(), ltree_compare(), ltsConcatWorkerTapes(), make_agg(), make_new_segment(), mcelem_array_contain_overlap_selec(), mcelem_array_contained_selec(), MinXLogRecPtr(), n_choose_k(), network_cmp_internal(), network_overlap(), networkjoinsel_inner(), networkjoinsel_semi(), optimal_k(), parse_manifest_file(), perform_base_backup(), pg_GSS_read(), pg_pwritev_with_retry(), pg_replication_slot_advance(), pglz_decompress(), pglz_maximum_compressed_size(), pgstat_get_crashed_backend_activity(), pgstat_report_activity(), plan_create_index_workers(), pqSendSome(), preprocess_limit(), pretty_format_node_dump(), process_equivalence(), range_gist_consider_split(), record_image_cmp(), recordMultipleDependencies(), reindex_one_database(), relation_needs_vacanalyze(), RelationAddExtraBlocks(), report_invalid_encoding(), report_untranslatable_char(), restore(), scalarineqsel(), SendBackupManifest(), sendFile(), set_max_safe_fds(), shm_mq_receive(), shm_mq_receive_bytes(), shm_mq_send_bytes(), SIInsertDataEntries(), slot_deform_heap_tuple(), spg_text_inner_consistent(), spg_text_leaf_consistent(), spg_text_picksplit(), spgdoinsert(), SpGistGetBuffer(), string_hash(), sts_puttuple(), sts_read_tuple(), summarize_range(), switchToPresortedPrefixMode(), SyncRepWaitForLSN(), system_rows_samplescangetsamplesize(), system_time_samplescangetsamplesize(), table_block_parallelscan_startblock_init(), tar_write_padding_data(), tarCreateHeader(), tbm_calculate_entries(), tbm_lossify(), text_substring(), toast_save_datum(), TS_phrase_execute(), tsCompareString(), tsquery_opr_selec(), tuplesort_merge_order(), tuplestore_trim(), vacuum_set_xid_limits(), validate_pkattnums(), varbit_in(), varstr_abbrev_convert(), varstr_cmp(), varstr_levenshtein(), varstrfastcmp_c(), varstrfastcmp_locale(), WinGetFuncArgInFrame(), XLogFileInit(), XLogReadDetermineTimeline(), and XLogReadRecord().
Definition at line 681 of file c.h.
Referenced by aclitemout(), add_cast_to(), AddEnumLabel(), AddRelationNewConstraints(), adjust_partition_tlist(), AlterDomainAddConstraint(), AlterDomainDefault(), AlterDomainNotNull(), AlterEventTriggerOwner_internal(), AlterExtensionNamespace(), AlterForeignDataWrapperOwner_internal(), AlterForeignServerOwner_internal(), AlterObjectNamespace_internal(), AlterObjectOwner_internal(), AlterObjectRename_internal(), AlterOperator(), AlterPublicationOwner_internal(), AlterPublicationTables(), AlterRelationNamespaceInternal(), AlterRole(), AlterSchemaOwner_internal(), AlterSubscriptionOwner_internal(), AlterTableMoveAll(), AlterTypeNamespaceInternal(), appendFunctionName(), ATDetachCheckNoForeignKeyRefs(), ATExecAddOf(), ATExecAttachPartition(), ATExecChangeOwner(), ATExecDetachPartition(), ATExecReplicaIdentity(), ATExecSetStatistics(), ATPrepChangePersistence(), ATRewriteTable(), AttrDefaultFetch(), BeginCopyFrom(), BeginCopyTo(), blvalidate(), boot_openrel(), bpchar_name(), brinvalidate(), btnametextcmp(), bttextnamecmp(), btvalidate(), build_attrmap_by_name(), build_column_default(), build_datatype(), BuildEventTriggerCache(), BuildOnConflictExcludedTargetlist(), buildRelationAliases(), check_safe_enum_use(), check_selective_binary_conversion(), check_TSCurrentConfig(), CheckAttributeNamesTypes(), CheckAttributeType(), CheckConstraintFetch(), CheckFunctionValidatorAccess(), checkInsertTargets(), CheckMyDatabase(), CheckPointReplicationSlots(), checkRuleResultList(), checkViewTupleDesc(), CloneFkReferenced(), CloneFkReferencing(), CloneRowTriggersToPartition(), CollationIsVisible(), compile_plperl_function(), compile_pltcl_function(), composite_to_json(), composite_to_jsonb(), compute_function_hashkey(), ComputeIndexAttrs(), ConstructTupleDescriptor(), conversion_error_callback(), ConversionIsVisible(), convert_string_datum(), copy_replication_slot(), CreateDecodingContext(), CreateFunction(), CreateInitDecodingContext(), CreateReplicationSlot(), CreateRole(), CreateSchemaCommand(), CreateSlotOnDisk(), CreateTrigger(), currtid_for_view(), DefineAttr(), DefineCollation(), DefineIndex(), DefineOpClass(), deparseAnalyzeSql(), deparseOperatorName(), do_autovacuum(), do_compile(), DoCopyTo(), DropSubscription(), EnableDisableTrigger(), enum_out(), enum_send(), equalTupleDescs(), errdatatype(), errtablecol(), EventTriggerSQLDropAddObject(), exec_object_restorecon(), ExecBuildSlotValueDescription(), ExecConstraints(), ExecGrant_Attribute(), ExecGrant_Database(), ExecGrant_Fdw(), ExecGrant_ForeignServer(), ExecGrant_Function(), ExecGrant_Language(), ExecGrant_Namespace(), ExecGrant_Relation(), ExecGrant_Tablespace(), ExecGrant_Type(), ExecTypeSetColNames(), ExecuteDoStmt(), expand_single_inheritance_child(), expand_targetlist(), ExpandRowReference(), expandTableLikeClause(), expandTupleDesc(), fetch_fp_info(), fetch_statentries_for_relation(), find_composite_type_dependencies(), fmgr_sql_validator(), format_operator_extended(), format_operator_parts(), format_procedure_extended(), format_procedure_parts(), format_type_extended(), FunctionIsVisible(), generate_collation_name(), generate_function_name(), generate_operator_clause(), generate_operator_name(), generate_qualified_relation_name(), generate_qualified_type_name(), generate_relation_name(), generateClonedIndexStmt(), get_am_name(), get_am_type_oid(), get_attname(), get_collation(), get_collation_name(), get_collation_version_for_oid(), get_constraint_name(), get_database_list(), get_database_name(), get_db_info(), get_extension_name(), get_file_fdw_attribute_options(), get_func_name(), get_language_name(), get_name_for_var_field(), get_namespace_name(), get_opclass(), get_opclass_name(), get_opname(), get_publication_name(), get_rel_name(), get_rolespec_name(), get_simple_values_rte(), get_sql_delete(), get_sql_insert(), get_sql_update(), get_subscription_list(), get_subscription_name(), get_tablespace_name(), get_target_list(), get_tuple_of_interest(), GetFdwRoutineByServerId(), GetForeignDataWrapperExtended(), GetForeignServerExtended(), GetIndexAmRoutineByAmId(), getObjectDescription(), getObjectIdentityParts(), getOpFamilyDescription(), getOpFamilyIdentity(), GetPublication(), getRelationDescription(), getRelationIdentity(), GetSubscription(), gettype(), GetUserNameFromId(), ginvalidate(), gistvalidate(), has_any_column_privilege_name_id(), has_any_column_privilege_name_name(), has_column_privilege_name_id_attnum(), has_column_privilege_name_id_name(), has_column_privilege_name_name_attnum(), has_column_privilege_name_name_name(), has_database_privilege_name_id(), has_database_privilege_name_name(), has_foreign_data_wrapper_privilege_name_id(), has_foreign_data_wrapper_privilege_name_name(), has_function_privilege_name_id(), has_function_privilege_name_name(), has_language_privilege_name_id(), has_language_privilege_name_name(), has_schema_privilege_name_id(), has_schema_privilege_name_name(), has_sequence_privilege_name_id(), has_sequence_privilege_name_name(), has_server_privilege_name_id(), has_server_privilege_name_name(), has_table_privilege_name_id(), has_table_privilege_name_name(), has_tablespace_privilege_name_id(), has_tablespace_privilege_name_name(), has_type_privilege_name_id(), has_type_privilege_name_name(), hashname(), hashnameextended(), hashvalidate(), hstore_from_record(), hstore_populate_record(), index_check_primary_key(), index_concurrently_create_copy(), index_concurrently_swap(), index_create(), init_sql_fcache(), InitializeSessionUserId(), InitPostgres(), inline_function(), inline_set_returning_function(), InsertOneNull(), internal_get_result_type(), intorel_startup(), InvalidateObsoleteReplicationSlots(), length_in_encoding(), load_domaintype_info(), logicalrep_rel_open(), logicalrep_write_attrs(), logicalrep_write_typ(), lookup_collation_cache(), lookup_ts_dictionary_cache(), lookup_type_cache(), make_inh_translation_list(), make_ruledef(), map_sql_table_to_xmlschema(), map_sql_type_to_xml_name(), MergeAttributes(), MergeAttributesIntoExisting(), MergeConstraintsIntoExisting(), name_bpchar(), name_text(), namecmp(), nameconcatoid(), nameeqfast(), nameeqtext(), namefastcmp_c(), namefastcmp_locale(), namehashfast(), nameicregexeq(), nameicregexne(), namein(), namelike(), namenetext(), namenlike(), nameout(), nameregexeq(), nameregexne(), namesend(), namestrcmp(), namestrcpy(), NextCopyFrom(), NotNullImpliedByRelConstraints(), OpClassCacheLookup(), OpclassIsVisible(), OperatorIsVisible(), OpFamilyCacheLookup(), OpfamilyIsVisible(), output_plugin_error_callback(), ParseComplexProjection(), PG_char_to_encoding(), pg_convert(), pg_create_logical_replication_slot(), pg_create_physical_replication_slot(), pg_database_size_name(), pg_decode_change(), pg_decode_truncate(), pg_drop_replication_slot(), pg_extension_update_paths(), pg_get_constraintdef_worker(), pg_get_functiondef(), pg_get_indexdef_worker(), pg_get_statisticsobj_worker(), pg_get_triggerdef_worker(), pg_get_userbyid(), pg_has_role_id_name(), pg_has_role_name(), pg_has_role_name_id(), pg_has_role_name_name(), pg_identify_object(), pg_logical_slot_get_changes_guts(), pg_newlocale_from_collation(), pg_nextoid(), pg_replication_slot_advance(), pg_tablespace_size_name(), plperl_hash_from_tuple(), plsample_func_handler(), pltcl_build_tuple_argument(), pltcl_set_tuple_values(), pltcl_trigger_handler(), PLy_procedure_create(), PLy_result_colnames(), PLyDict_FromTuple(), PLyGenericObject_ToComposite(), PLyMapping_ToComposite(), populate_record(), prepare_sql_fn_parse_info(), printatt(), printsimple_startup(), recomputeNamespacePath(), refresh_by_match_merge(), regclassout(), regcollationout(), regconfigout(), regdictionaryout(), regoperout(), regprocout(), regtypeout(), relation_needs_vacanalyze(), RelationBuildPartitionKey(), RelationBuildRowSecurity(), RelationIsVisible(), RemoveInheritance(), RemoveRoleFromObjectPolicy(), renameatt_check(), RenameEnumLabel(), RenameRole(), ReorderBufferAllocate(), ReorderBufferFree(), ReorderBufferSerializedPath(), ReplicationSlotAcquireInternal(), ReplicationSlotCreate(), ReplicationSlotDropPtr(), ReplicationSlotSave(), ReplicationSlotsDropDBSlots(), resolve_polymorphic_tupdesc(), RestoreSlotFromDisk(), rewriteTargetListIU(), RI_FKey_check(), ri_GenerateQualCollation(), RI_Initial_Check(), ri_PerformCheck(), ri_ReportViolation(), schema_to_xml(), schema_to_xml_and_xmlschema(), schema_to_xmlschema(), SearchNamedReplicationSlot(), SendRowDescriptionMessage(), sepgsql_attribute_post_create(), sepgsql_database_post_create(), sepgsql_proc_post_create(), sepgsql_proc_setattr(), sepgsql_relation_post_create(), sepgsql_relation_setattr(), sepgsql_schema_post_create(), set_relation_column_names(), spgvalidate(), SPI_fname(), SPI_gettype(), StartupDecodingContext(), StatisticsObjIsVisible(), swap_relation_files(), SystemAttributeByName(), text_name(), texteqname(), textnename(), tfuncInitialize(), tfuncLoadRows(), to_ascii_encname(), transformFkeyGetPrimaryKey(), transformIndexConstraint(), transformOfType(), transformTableLikeClause(), triggered_change_notification(), truncate_check_perms(), truncate_check_rel(), TSConfigIsVisible(), TSDictionaryIsVisible(), TSParserIsVisible(), TSTemplateIsVisible(), tuple_to_stringinfo(), TupleDescInitEntry(), TypeIsVisible(), typeTypeName(), UpdateDecodingStats(), vacuum_is_relation_owner(), validateDomainConstraint(), and verify_dictoptions().
#define ngettext | ( | s, | |
p, | |||
n | |||
) | ((n) == 1 ? (s) : (p)) |
Definition at line 1182 of file c.h.
Referenced by _tarGetHeader(), adjust_array(), appendQualifiedRelation(), checkSharedDependencies(), describeRoles(), digestControlFile(), dump_lo_buf(), dumpSequence(), dumpSequenceData(), EndRestoreBlobs(), ExecuteSqlQueryForSingleRow(), footers_with_default(), getTableAttrs(), handle_args(), lazy_parallel_vacuum_indexes(), lazy_scan_heap(), main(), open_walfile(), printPsetInfo(), progress_report(), read_controlfile(), repairDependencyLoop(), reportDependentObjects(), RetrieveWalSegSize(), search_directory(), and storeObjectDescription().
#define NON_EXEC_STATIC static |
Definition at line 1351 of file c.h.
Referenced by pgarch_start(), pgstat_send_slru(), and StartAutoVacWorker().
#define offsetof | ( | type, | |
field | |||
) | ((long) &((type *)0)->field) |
Definition at line 727 of file c.h.
Referenced by _bt_delitems_delete_check(), _bt_mkscankey(), _bt_steppage(), _ltree_gist_options(), _PG_init(), AddInvalidationMessage(), allocate_record_info(), AllocSetContextCreateInternal(), Async_Notify(), AsyncShmemInit(), AsyncShmemSize(), AtPrepare_PredicateLocks(), attribute_reloptions(), BackgroundWorkerShmemSize(), binaryheap_allocate(), bloom_create(), BootStrapXLOG(), box_poly(), brin_build_desc(), brin_page_items(), brinoptions(), bt_pivot_tuple_identical(), btoptions(), btree_xlog_updates(), BTreeShmemSize(), btreevacuumposting(), btrestrpos(), build_tlist_index(), build_tlist_index_other_vars(), check_temp_tablespaces(), checkControlFile(), CheckpointerShmemSize(), CheckRADIUSAuth(), CheckTableForSerializableConflictIn(), CheckTargetForConflictsIn(), circle_poly(), ClearOldPredicateLocks(), collect_visibility_data(), ConvertTimeZoneAbbrevs(), create_reloptions_table(), CreatePredXact(), CreateSharedProcArray(), CreateTableSpace(), CreateTemplateTupleDesc(), cube_recv(), decide_file_actions(), default_reloptions(), DeleteChildTargetLocks(), DeleteLockTarget(), DropAllPredicateLocksFromTable(), dsm_control_bytes_needed(), dsm_control_segment_sane(), entryExecPlaceToPage(), ER_get_flat_size(), EstimateReindexStateSpace(), ExecAggEstimate(), ExecAggInitializeDSM(), ExecAggRetrieveInstrumentation(), ExecAppendEstimate(), ExecBitmapHeapEstimate(), ExecCreatePartitionPruneState(), ExecHashEstimate(), ExecHashInitializeDSM(), ExecHashRetrieveInstrumentation(), ExecIncrementalSortEstimate(), ExecIncrementalSortInitializeDSM(), ExecIncrementalSortRetrieveInstrumentation(), ExecInitParallelPlan(), ExecInitPartitionDispatchInfo(), ExecParallelRetrieveInstrumentation(), ExecParallelRetrieveJitInstrumentation(), ExecSortEstimate(), ExecSortInitializeDSM(), ExecSortRetrieveInstrumentation(), expand_tuple(), FindLockCycleRecurseMember(), FirstPredXact(), FlagSxactUnsafe(), FuncnameGetCandidates(), g_int_options(), g_intbig_options(), GenerationContextCreate(), get_controlfile(), GetAccessStrategy(), GetLockConflicts(), GetLockmodeName(), GetOldSnapshotTimeMapping(), GetSafeSnapshotBlockingPids(), GetSingleProcBlockerStatusData(), ghstore_options(), ginCompressPostingList(), ginoptions(), gistoptions(), GistPageGetDeleteXid(), gistPushItupToNodeBuffer(), gtrgm_options(), gtsvector_options(), hash_record(), hash_record_extended(), hashoptions(), heap_form_tuple(), heap_tuple_from_minimal_tuple(), hstore_from_record(), hstore_populate_record(), index_parallelscan_estimate(), index_parallelscan_initialize(), internal_load_library(), load_enum_cache_data(), load_relmap_file(), LockCheckConflicts(), LockReleaseAll(), LogAccessExclusiveLocks(), ltree_gist_options(), make_jsp_entry_node(), make_jsp_expr_node(), makeParamList(), multi_sort_init(), mXactCachePut(), new_list(), NextPredXact(), OnConflict_CheckForSerializationFailure(), path_add(), path_in(), path_poly(), path_recv(), pg_getnameinfo_all(), pgstat_drop_database(), pgstat_read_db_statsfile_timestamp(), pgstat_read_statsfiles(), pgstat_send_funcstats(), pgstat_send_tabstat(), pgstat_vacuum_stat(), pgstat_write_statsfiles(), plpgsql_ns_additem(), PLy_function_save_args(), PMSignalShmemSize(), poly_in(), poly_path(), poly_recv(), populate_record(), PostPrepare_Locks(), pqSaveMessageField(), PreCommit_CheckForSerializationFailure(), PrintCatCacheLeakWarning(), ProcArrayShmemSize(), process_pipe_input(), ProcSignalShmemSize(), ProcSleep(), queue_listen(), read_controlfile(), ReadControlFile(), record_cmp(), record_eq(), record_image_cmp(), record_image_eq(), record_in(), record_out(), record_recv(), record_send(), ReleaseCatCache(), ReleaseOneSerializableXact(), ReleasePredicateLocks(), ReleasePredXact(), ReorderBufferRestoreChange(), ReplicationOriginShmemSize(), ReplicationSlotsShmemSize(), RWConflictExists(), satisfies_hash_partition(), SearchCatCacheList(), setalarm(), SetConstraintStateAddItem(), SetConstraintStateCreate(), SetPossibleUnsafeConflict(), SetRWConflict(), setup_background_workers(), shm_mq_create(), shm_toc_allocate(), shm_toc_attach(), shm_toc_create(), shm_toc_estimate(), shm_toc_freespace(), shm_toc_insert(), simple_string_list_append(), SInvalShmemSize(), SlabContextCreate(), SnapMgrShmemSize(), spgoptions(), statext_dependencies_build(), statext_dependencies_deserialize(), statext_mcv_build(), statext_mcv_deserialize(), statext_ndistinct_build(), statext_ndistinct_deserialize(), sts_estimate(), SummarizeOldestCommittedSxact(), SyncRepQueueInsert(), SyncRepUpdateSyncStandbysDefined(), SyncRepWakeQueue(), tablespace_reloptions(), TransferPredicateLocksToNewTarget(), tuplesort_estimate_shared(), TwoPhaseShmemInit(), TwoPhaseShmemSize(), update_controlfile(), ValidXLogRecord(), view_reloptions(), WalSndShmemSize(), write_relmap_file(), WriteControlFile(), WriteEmptyXLOG(), WriteSetTimestampXlogRec(), and XLogInsertRecord().
#define OffsetToPointer | ( | base, | |
offset | |||
) | ((void *)((char *) base + offset)) |
Definition at line 707 of file c.h.
Referenced by _bt_parallel_advance_array_keys(), _bt_parallel_done(), _bt_parallel_release(), _bt_parallel_seize(), btparallelrescan(), and index_parallelscan_initialize().
#define OidIsValid | ( | objectId | ) | ((bool) ((objectId) != InvalidOid)) |
Definition at line 710 of file c.h.
Referenced by _bt_allequalimage(), _bt_compare_scankey_args(), _bt_find_extreme_element(), AccessTempTableNamespace(), activate_interpreter(), add_column_collation_dependency(), add_function_cost(), AddEnumLabel(), addFkRecurseReferenced(), addFkRecurseReferencing(), AddNewAttributeTuples(), addTargetToSortList(), adjust_appendrel_attrs_mutator(), adjust_inherited_tlist(), advance_windowaggregate(), AggregateCreate(), AlterForeignDataWrapper(), AlterFunction(), AlterObjectOwner_internal(), AlterObjectRename_internal(), AlterOperator(), AlterStatistics(), AlterTableMoveAll(), AlterTableNamespace(), AlterTableNamespaceInternal(), AlterTypeNamespace_oid(), AlterTypeNamespaceInternal(), AlterTypeOwnerInternal(), AlterTypeRecurse(), AlterUserMapping(), am_tablesync_worker(), analyzeCTETargetList(), ApplyWorkerMain(), array_cmp(), array_contain_compare(), array_eq(), array_fill(), array_fill_with_lower_bounds(), array_position_common(), array_positions(), array_recv(), array_replace_internal(), array_send(), array_typanalyze(), assign_collations_walker(), assign_hypothetical_collations(), assignOperTypes(), assignProcTypes(), AssignTypeArrayOid(), AssignTypeMultirangeArrayOid(), AssignTypeMultirangeOid(), ATAddForeignKeyConstraint(), ATDetachCheckNoForeignKeyRefs(), ATExecAddIndex(), ATExecAddIndexConstraint(), ATExecAttachPartition(), ATExecAttachPartitionIdx(), ATExecChangeOwner(), ATExecClusterOn(), ATExecDetachPartition(), ATExecDropOf(), ATExecReplicaIdentity(), ATExecSetRelOptions(), ATExecSetTableSpace(), ATPostAlterTypeCleanup(), ATPrepSetTableSpace(), ATRewriteTable(), ATRewriteTables(), AttachPartitionEnsureIndexes(), autoprewarm_database_main(), AutoVacWorkerMain(), binary_oper_exact(), binary_upgrade_set_pg_class_oids(), binary_upgrade_set_type_oids_by_rel_oid(), binary_upgrade_set_type_oids_by_type_oid(), blvalidate(), boot_get_type_io_data(), bounds_adjacent(), brin_desummarize_range(), brin_summarize_range(), brinvalidate(), bt_index_check_internal(), btadjustmembers(), btcostestimate(), btvalidate(), build_aggregate_transfn_expr(), build_coercion_expression(), build_concat_foutcache(), build_datatype(), build_pertrans_for_aggref(), build_replindex_scan_key(), build_subplan(), BuildParamLogString(), BuildSpeculativeIndexInfo(), cache_array_element_properties(), cache_multirange_element_properties(), cache_range_element_properties(), cache_record_field_properties(), CacheInvalidateHeapTuple(), calc_arraycontsel(), calc_hist_selectivity(), calculate_table_size(), can_minmax_aggs(), CastCreate(), check_collation_set(), check_default_table_access_method(), check_default_tablespace(), check_generic_type_consistency(), check_nested_generated_walker(), check_of_type(), check_relation_updatable(), check_TSCurrentConfig(), CheckAttributeType(), CheckCmdReplicaIdentity(), checkTempNamespaceStatus(), ChooseExtendedStatisticName(), ChooseRelationName(), CloneFkReferenced(), CloneRowTriggersToPartition(), cluster(), cluster_rel(), CollationCreate(), CollationGetCollid(), CommentObject(), CommuteOpExpr(), compile_pltcl_function(), compute_partition_hash_value(), compute_range_stats(), compute_return_type(), compute_semijoin_info(), ComputeIndexAttrs(), ComputePartitionAttrs(), concat_internal(), ConstraintSetParentConstraint(), ConstructTupleDescriptor(), contain_leaked_vars_walker(), ConversionGetConid(), convert_EXISTS_to_ANY(), convert_function_name(), convert_type_name(), cookDefault(), copy_table_data(), copyParamList(), count_nulls(), CountDBBackends(), CountDBConnections(), create_ctas_nodata(), create_indexscan_plan(), create_toast_table(), create_unique_plan(), create_windowagg_plan(), CreateAccessMethod(), CreateCast(), CreateConstraintEntry(), createdb(), createDummyViewAsClause(), CreateExtensionInternal(), CreateForeignDataWrapper(), CreateFunction(), CreateProceduralLanguage(), CreatePublication(), CreateRole(), CreateSubscription(), CreateTableSpace(), CreateTransform(), CreateTrigger(), CreateUserMapping(), DefineAttr(), DefineCollation(), DefineCompositeType(), DefineDomain(), DefineEnum(), DefineIndex(), DefineOpClass(), DefineOperator(), DefineQueryRewrite(), DefineRange(), DefineRelation(), DefineSequence(), DefineTSConfiguration(), DefineTSDictionary(), DefineTSParser(), DefineTSTemplate(), DefineType(), DefineVirtualRelation(), DeleteInheritsTuple(), disconnect_cached_connections(), do_autovacuum(), do_collation_version_update(), do_compile(), DropClonedTriggersFromPartition(), DropErrorMsgNonExistent(), dropOperators(), dropProcedures(), DropSetting(), DropSubscription(), dumpBaseType(), dumpCast(), dumpCompositeType(), dumpDomain(), dumpOpr(), dumpProcLang(), dumpRangeType(), dumpSequence(), dumpTableSchema(), dumpTransform(), dumpTrigger(), enforce_generic_type_consistency(), enum_first(), enum_last(), enum_range_internal(), eqjoinsel(), eqjoinsel_semi(), eqsel_internal(), EstimateParamExecSpace(), EstimateParamListSpace(), eval_const_expressions_mutator(), eval_windowaggregates(), EvalPlanQualFetchRowMark(), EventTriggerCollectAlterTableSubcmd(), examine_attribute(), exec_stmt_foreach_a(), ExecAlterExtensionContentsStmt(), ExecBuildAggTrans(), ExecCreatePartitionPruneState(), ExecEvalParamExtern(), ExecFindPartition(), ExecHashBuildSkewHash(), ExecHashTableCreate(), ExecInitAgg(), ExecInitExprRec(), ExecInitWindowAgg(), ExecLockRows(), ExecReindex(), ExecuteDoStmt(), ExecuteTruncateGuts(), expand_indexqual_rowcompare(), expand_vacuum_rel(), expandRTE(), expandTableLikeClause(), exprSetCollation(), exprType(), extract_grouping_ops(), extract_query_dependencies_walker(), extract_variadic_args(), ExtractExtensionList(), fetch_array_arg_replace_nulls(), fetch_cursor_param_value(), fetch_fp_info(), finalize_aggregate(), finalize_partialaggregate(), finalize_windowaggregate(), find_coercion_pathway(), find_composite_type_dependencies(), find_expr_references_walker(), find_typmod_coercion_function(), FindDefaultConversionProc(), findDependentObjects(), findRangeCanonicalFunction(), findRangeSubOpclass(), findRangeSubtypeDiffFunction(), FindReplTupleInLocalRel(), findTypeAnalyzeFunction(), findTypeInputFunction(), findTypeOutputFunction(), findTypeReceiveFunction(), findTypeSendFunction(), findTypeSubscriptingFunction(), findTypeTypmodinFunction(), findTypeTypmodoutFunction(), finish_heap_swap(), FinishSortSupportFunction(), fixed_paramref_hook(), fmgr_security_definer(), foreign_expr_walker(), func_get_detail(), FuncNameAsType(), FuncnameGetCandidates(), generate_base_implied_equalities_const(), generate_base_implied_equalities_no_const(), generate_function_name(), generate_implied_equalities_for_column(), generate_join_implied_equalities_normal(), generateClonedExtStatsStmt(), generateClonedIndexStmt(), GenerateTypeDependencies(), Generic_Text_IC_like(), get_agg_clause_costs(), get_am_type_oid(), get_cast_oid(), get_catalog_object_by_oid(), get_collation(), get_collation_oid(), get_compatible_hash_operators(), get_const_collation(), get_conversion_oid(), get_database_oid(), get_distance(), get_domain_constraint_oid(), get_event_trigger_oid(), get_extension_oid(), get_foreign_data_wrapper_oid(), get_foreign_server_oid(), get_from_clause_coldeflist(), get_function_rows(), get_index_clause_from_support(), get_insert_query_def(), get_language_oid(), get_multirange_io_data(), get_namespace_oid(), get_object_address(), get_object_address_attrdef(), get_object_address_publication_rel(), get_object_address_relobject(), get_op_btree_interpretation(), get_op_hash_functions(), get_opclass_name(), get_ordering_op_for_equality_op(), get_other_operator(), get_partition_operator(), get_partition_parent(), get_position(), get_promoted_array_type(), get_publication_oid(), get_range_io_data(), get_relation_constraint_attnos(), get_relation_constraint_oid(), get_relation_info(), get_rels_with_domain(), get_required_extension(), get_role_oid(), get_rte_attribute_is_dropped(), get_sort_group_operators(), get_statistics_object_oid(), get_subscription_oid(), get_tablespace_oid(), get_transform_oid(), get_ts_config_oid(), get_ts_dict_oid(), get_ts_parser_oid(), get_ts_template_oid(), GetAuthenticatedUserId(), GetColumnDefCollation(), GetConflictingVirtualXIDs(), getConstraintTypeDescription(), GetFdwRoutineByServerId(), GetForeignDataWrapperByName(), GetForeignServerByName(), getObjectDescription(), getObjectIdentityParts(), GetOuterUserId(), getOwnedSeqs(), GetParentedForeignKeyRefs(), GetPublicationByName(), GetRelationIdentityOrPK(), GetSessionUserId(), getSubscriptingRoutines(), GetTempToastNamespace(), getTokenTypes(), getTriggers(), GetTSConfigTuple(), getTSCurrentConfig(), getTypeBinaryInputInfo(), getTypeBinaryOutputInfo(), GetTypeCollations(), getTypeInputInfo(), getTypeIOParam(), getTypeOutputInfo(), GetUserId(), gincost_pattern(), ginInitConsistentFunction(), ginvalidate(), gistbuild(), gistcanreturn(), gistCompressValues(), gistdentryinit(), gistproperty(), gistrescan(), gistvalidate(), grouping_is_sortable(), hash_array(), hash_array_extended(), hash_multirange(), hash_multirange_extended(), hash_range(), hash_range_extended(), hash_record(), hash_record_extended(), hashadjustmembers(), hashvalidate(), have_partkey_equi_join(), heap_create(), heap_create_with_catalog(), heap_drop_with_catalog(), heap_truncate_find_FKs(), heap_truncate_one_rel(), heapam_index_build_range_scan(), heapam_index_validate_scan(), ImportForeignSchema(), ImportSnapshot(), index_concurrently_swap(), index_constraint_create(), index_create(), index_opclass_options(), indexam_property(), IndexSetParentIndex(), IndexSupportInitialize(), initArrayResultAny(), initArrayResultArr(), initGinState(), initGISTstate(), initialize_peragg(), InitializeClientEncoding(), InitializeSessionUserId(), InitializeSessionUserIdStandalone(), InitPostgres(), InitTempTableNamespace(), inline_function(), interpret_func_support(), interpret_function_parameter_list(), intorel_startup(), is_complex_array(), is_member(), IsBinaryCoercible(), isTempNamespace(), isTempOrTempToastNamespace(), isTempToastNamespace(), json_categorize_type(), jsonb_categorize_type(), LargeObjectCreate(), launch_worker(), lc_collate_is_c(), lc_ctype_is_c(), left_oper(), like_fixed_prefix(), load_multirangetype_info(), load_rangetype_info(), load_typcache_tupdesc(), logicalrep_rel_open(), logicalrep_sync_worker_count(), logicalrep_typmap_gettypname(), logicalrep_worker_launch(), logicalrep_write_tuple(), LogicalRepSyncTableStart(), lookup_agg_function(), lookup_collation(), lookup_collation_cache(), lookup_proof_cache(), lookup_shippable(), lookup_ts_config_cache(), lookup_ts_dictionary_cache(), lookup_ts_parser_cache(), lookup_type_cache(), LookupExplicitNamespace(), LookupFuncName(), LookupFuncWithArgs(), LookupNamespaceNoError(), LookupOperName(), LookupTypeNameExtended(), make_new_heap(), make_pathkey_from_sortinfo(), make_pathkeys_for_sortclauses(), make_range(), make_recursive_union(), make_row_comparison_op(), make_scalar_array_op(), make_setop(), make_unique_from_pathkeys(), make_unique_from_sortclauses(), makeOperatorDependencies(), makeParserDependencies(), makeTSTemplateDependencies(), makeWholeRowVar(), map_sql_table_to_xmlschema(), map_variable_attnos_mutator(), mark_index_clustered(), mark_partial_aggref(), match_clause_to_partition_key(), match_foreign_keys_to_quals(), match_opclause_to_indexcol(), mergejoinscansel(), MJExamineQuals(), mode_final(), moveArrayTypeName(), multirange_gist_consistent(), NamespaceCreate(), OpClassCacheLookup(), OpclassnameGetOpcid(), OpenTemporaryFile(), oper(), operator_predicate_proof(), OperatorCreate(), OperatorLookup(), OperatorUpd(), OpernameGetCandidates(), OpernameGetOprid(), opfamily_can_sort_type(), OpFamilyCacheLookup(), OpfamilynameGetOpfid(), ordered_set_startup(), owningrel_does_not_exist_skipping(), paramlist_param_ref(), ParseFuncOrColumn(), patternsel(), patternsel_common(), perform_pruning_base_step(), pg_describe_object(), pg_do_encoding_conversion(), pg_event_trigger_ddl_commands(), pg_filenode_relation(), pg_get_constraintdef_worker(), pg_get_expr(), pg_get_expr_ext(), pg_get_expr_worker(), pg_get_indexdef_worker(), pg_get_partkeydef_worker(), pg_get_replica_identity_index(), pg_get_serial_sequence(), pg_get_triggerdef_worker(), pg_identify_object(), pg_import_system_collations(), pg_newlocale_from_collation(), pg_partition_root(), pg_partition_tree(), pg_relation_filenode(), pg_relation_filepath(), pg_replication_origin_oid(), pg_replication_origin_progress(), pg_replication_slot_advance(), pg_set_regex_collation(), pg_stat_get_subscription(), pgstat_beshutdown_hook(), pgstat_send_tabstat(), pgstat_vacuum_stat(), plperl_call_perl_func(), plperl_hash_from_tuple(), plperl_ref_from_pg_array(), plperl_return_next_internal(), plperl_sv_to_literal(), plpgsql_parse_cwordrowtype(), plpgsql_parse_cwordtype(), plpgsql_parse_wordrowtype(), PLyString_ToComposite(), prepare_sort_from_pathkeys(), PrepareClientEncoding(), preparePresortedCols(), PrepareSortSupportFromGistIndexRel(), preprocess_aggref(), preprocess_groupclause(), preprocess_grouping_sets(), preprocess_minmax_aggregates(), ProcedureCreate(), ProcessCommittedInvalidationMessages(), processIndirection(), ProcessUtilitySlow(), PublicationDropTables(), PushOverrideSearchPath(), QualifiedNameGetCreationNamespace(), query_is_distinct_for(), range_gist_consistent(), range_gist_double_sorting_split(), range_gist_penalty(), RangeCreate(), RangeVarCallbackForAttachIndex(), RangeVarCallbackForDropRelation(), RangeVarCallbackForLockTable(), RangeVarCallbackForReindexIndex(), RangeVarCallbackForTruncate(), RangeVarCallbackOwnsRelation(), RangeVarCallbackOwnsTable(), RangeVarGetAndCheckCreationNamespace(), RangeVarGetCreationNamespace(), RangeVarGetRelidExtended(), rebuild_database_list(), rebuild_relation(), recomputeNamespacePath(), reconsider_full_join_clause(), reconsider_outer_join_clause(), record_cmp(), record_eq(), recordDependencyOnCurrentExtension(), refnameNamespaceItem(), refresh_by_match_merge(), refuseDupeIndexAttach(), regoperatorin(), reindex_index(), reindex_relation(), ReindexMultipleInternal(), ReindexMultipleTables(), ReindexRelationConcurrently(), relation_mark_replica_identity(), relation_needs_vacanalyze(), relation_openrv_extended(), RelationBuildPartitionKey(), RelationBuildTriggers(), RelationGetIndexList(), RelationGetIndexRawAttOptions(), RelationInitLockInfo(), RelationInitPhysicalAddr(), RelationIsVisible(), RelnameGetRelid(), RememberConstraintForRebuilding(), RememberIndexForRebuilding(), RemoveConstraintById(), RemoveObjects(), RemoveOperatorById(), RemoveRelations(), RemoveSubscriptionRel(), RemoveTempRelationsCallback(), RemoveUserMapping(), renameatt(), RenameConstraint(), RenameConstraintById(), RenameDatabase(), RenameRelation(), RenameRelationInternal(), RenameSchema(), RenameTypeInternal(), replorigin_by_oid(), replorigin_drop_by_name(), report_namespace_conflict(), report_triggers(), ReportSlotConnectionError(), ResetTempTableNamespace(), resolve_anyarray_from_others(), resolve_anyelement_from_others(), resolve_anymultirange_from_others(), resolve_anyrange_from_others(), resolve_polymorphic_argtypes(), resolve_polymorphic_tupdesc(), ResolveOpClass(), RestoreUncommittedEnums(), ri_AttributesEqual(), ri_FetchConstraintInfo(), ri_GenerateQualCollation(), ri_HashCompareOp(), roles_has_privs_of(), roles_is_member_of(), satisfies_hash_partition(), scalararraysel(), scalararraysel_containment(), ScanPgRelation(), schema_does_not_exist_skipping(), searchRangeTableForRel(), select_equality_operator(), selectDumpableType(), SerializeParamExecParams(), SerializeParamList(), set_foreign_rel_properties(), SetCurrentRoleId(), SetDefaultACL(), SetOuterUserId(), SetReindexProcessing(), SetRelationTableSpace(), SetSessionAuthorization(), SetSessionUserId(), shdepDropDependency(), show_role(), show_sortorder_options(), simplify_function(), spgdoinsert(), spgGetCache(), spgproperty(), spgvalidate(), sql_fn_make_param(), StandbyAcquireAccessExclusiveLock(), statistic_proc_security_check(), std_typanalyze(), StoreCatalogInheritance(), storeOperators(), StorePartitionBound(), StorePartitionKey(), str_initcap(), str_tolower(), str_toupper(), stream_open_file(), superuser_arg(), swap_relation_files(), TablespaceCreateDbspace(), text_format(), to_regclass(), to_regcollation(), to_regnamespace(), to_regoperator(), to_regrole(), to_regtype(), toast_save_datum(), transformAExprIn(), transformAggregateCall(), transformAlterTableStmt(), transformArrayExpr(), transformCaseExpr(), transformColumnType(), transformContainerSubscripts(), transformCreateStmt(), transformFkeyGetPrimaryKey(), transformGenericOptions(), transformIndexConstraint(), transformRangeTableSample(), transformTypeCast(), tryAttachPartitionForeignKey(), ts_headline_byid_opt(), ts_headline_json_byid_opt(), ts_headline_jsonb_byid_opt(), tt_setup_firstcall(), tuples_equal(), type_in_list_does_not_exist_skipping(), type_is_collatable(), TypeCreate(), TypenameGetTypidExtended(), TypeShellMake(), unaccent_dict(), ValidateJoinEstimator(), verify_dictoptions(), and width_bucket_array().
#define pg_attribute_always_inline inline |
Definition at line 196 of file c.h.
Referenced by ExecAggPlainTransByVal(), ExecEvalAggOrderedTransTuple(), ExecJustConst(), ExecJustScanVar(), ExecJustScanVarVirt(), ShutdownTupleDescRef(), and tts_buffer_heap_store_tuple().
#define pg_attribute_cold |
Definition at line 237 of file c.h.
Referenced by err_gettext().
static void static void pg_attribute_noreturn | ( | ) |
Definition at line 179 of file c.h.
Referenced by surrogate_pair_to_codepoint(), and walrcv_clear_result().
#define pg_attribute_printf | ( | f, | |
a | |||
) |
Definition at line 164 of file c.h.
Referenced by MemoryContextSwitchTo().
#define PG_BINARY 0 |
Definition at line 1271 of file c.h.
Referenced by _mdfd_openseg(), AddToDataDirLockFile(), ApplyLogicalMappingFile(), be_lo_export(), check_file_clone(), CheckPointLogicalRewriteHeap(), CheckPointReplicationOrigin(), cloneFile(), copy_file(), copyFile(), dir_existsfile(), dir_open_for_write(), durable_rename(), FindStreamingStart(), fsync_fname_ext(), get_controlfile(), heap_xlog_logical_rewrite(), initializeInput(), lo_export(), lo_import_internal(), load_relmap_file(), local_fetch_file_range(), logical_rewrite_log_mapping(), mdcreate(), mdopenfork(), mdsyncfiletag(), open_file_in_directory(), open_target_file(), OpenTemporaryFileInTablespace(), parse_manifest_file(), PathNameCreateTemporaryFile(), PathNameOpenTemporaryFile(), perform_base_backup(), pg_open_tzfile(), pg_truncate(), qtext_load_file(), qtext_store(), read_controlfile(), ReadControlFile(), readfile(), readRecoverySignalFile(), ReadTwoPhaseFile(), RecheckDataDirLockFile(), RecreateTwoPhaseFile(), ReorderBufferRestoreChanges(), ReorderBufferSerializeTXN(), RestoreArchivedFile(), RestoreSlotFromDisk(), rewriteVisibilityMap(), SaveSlotToPath(), scan_file(), sendFile(), SendTimeLineHistory(), SimpleLruDoesPhysicalPageExist(), SimpleXLogPageRead(), SlruPhysicalReadPage(), SlruPhysicalWritePage(), SlruSyncFileTag(), slurpFile(), SnapBuildRestore(), SnapBuildSerialize(), StartupReplicationOrigin(), StreamLogicalLog(), tar_open_for_write(), test_file_descriptor_sync(), test_non_sync(), test_open(), test_open_sync(), test_sync(), update_controlfile(), verify_file_checksum(), wal_segment_open(), walkdir(), WalSndSegmentOpen(), write_relmap_file(), WriteControlFile(), WriteEmptyXLOG(), XLogFileCopy(), XLogFileInit(), XLogFileOpen(), and XLogFileRead().
#define PG_BINARY_A "a" |
Definition at line 1272 of file c.h.
Referenced by dumpDatabases(), and SetOutput().
#define PG_BINARY_R "r" |
Definition at line 1273 of file c.h.
Referenced by _discoverArchiveFormat(), _LoadBlobs(), _PrintFileData(), _ReopenArchive(), BeginCopyFrom(), checkControlFile(), do_copy(), do_edit(), ImportSnapshot(), InitArchiveFmt_Custom(), InitArchiveFmt_Directory(), InitArchiveFmt_Tar(), load_relcache_init_file(), main(), pgss_shmem_startup(), pgstat_read_db_statsfile(), pgstat_read_db_statsfile_timestamp(), pgstat_read_statsfiles(), PostmasterMarkPIDForWorkerNotify(), process_file(), read_binary_file(), read_whole_file(), and SortTocFromFile().
#define PG_BINARY_W "w" |
Definition at line 1274 of file c.h.
Referenced by _CloseArchive(), _StartBlob(), _StartData(), BackendRun(), BeginCopyTo(), do_copy(), entry_reset(), ExportSnapshot(), gc_qtexts(), InitArchiveFmt_Custom(), InitArchiveFmt_Tar(), main(), pgss_shmem_shutdown(), pgss_shmem_startup(), pgstat_write_db_statsfile(), pgstat_write_statsfiles(), set_null_conf(), SetOutput(), write_relcache_init_file(), and write_version_file().
#define PG_INT16_MAX (0x7FFF) |
Definition at line 521 of file c.h.
Referenced by dumpSequence(), init_params(), int82(), pg_add_s16_overflow(), pg_atomic_compare_exchange_u32_impl(), pg_atomic_fetch_add_u32_impl(), pg_mul_s16_overflow(), pg_sub_s16_overflow(), and test_atomic_uint32().
#define PG_INT16_MIN (-0x7FFF-1) |
Definition at line 520 of file c.h.
Referenced by dumpSequence(), init_params(), int2_dist(), int2abs(), int2div(), int2um(), int82(), pg_add_s16_overflow(), pg_atomic_compare_exchange_u32_impl(), pg_atomic_fetch_add_u32_impl(), pg_mul_s16_overflow(), pg_strtoint16(), pg_sub_s16_overflow(), and test_atomic_uint32().
#define PG_INT32_MAX (0x7FFFFFFF) |
Definition at line 524 of file c.h.
Referenced by create_and_test_bloom(), dumpSequence(), exec_stmt_fori(), init_params(), int84(), mark_hl_fragments(), numeric_cmp_abbrev(), pg_add_s32_overflow(), pg_mul_s32_overflow(), pg_mul_s64_overflow(), pg_sub_s32_overflow(), and writezone().
#define PG_INT32_MIN (-0x7FFFFFFF-1) |
Definition at line 523 of file c.h.
Referenced by dumpSequence(), exec_stmt_fori(), init_params(), int42div(), int4_dist(), int4abs(), int4div(), int4gcd_internal(), int4lcm(), int4um(), int84(), pg_add_s32_overflow(), pg_mul_s32_overflow(), pg_mul_s64_overflow(), pg_strtoint32(), pg_sub_s32_overflow(), and writezone().
#define PG_INT64_MAX INT64CONST(0x7FFFFFFFFFFFFFFF) |
Definition at line 527 of file c.h.
Referenced by dumpSequence(), g_int_compress(), init_params(), numeric_cmp_abbrev(), pg_add_s64_overflow(), pg_mul_s64_overflow(), pg_sub_s64_overflow(), threadRun(), timerange_option(), timestamp_part(), timestamptz_part(), ts_dist(), and tstz_dist().
#define PG_INT64_MIN (-INT64CONST(0x7FFFFFFFFFFFFFFF) - 1) |
Definition at line 526 of file c.h.
Referenced by cash_dist(), cash_in(), dumpSequence(), evalStandardFunc(), init_params(), int82div(), int84div(), int8_dist(), int8abs(), int8div(), int8gcd_internal(), int8lcm(), int8um(), leftmostvalue_int8(), leftmostvalue_money(), numericvar_to_int64(), pg_add_s64_overflow(), pg_atomic_fetch_sub_u64(), pg_atomic_sub_fetch_u64(), pg_mul_s64_overflow(), pg_sub_s64_overflow(), scanint8(), strtoint64(), and timerange_option().
#define pg_noinline |
Definition at line 212 of file c.h.
Referenced by build_dummy_expanded_header(), check_domain_for_new_field(), float_overflow_error(), float_underflow_error(), and SearchCatCacheInternal().
#define PG_TEXTDOMAIN | ( | domain | ) | (domain "-" PG_MAJORVERSION) |
Definition at line 1215 of file c.h.
Referenced by ECPGis_noind_null(), errstart(), format_elog_string(), main(), PQenv2encoding(), regression_main(), set_errcontext_domain(), and set_pglocale_pgservice().
#define PG_UINT16_MAX (0xFFFF) |
Definition at line 522 of file c.h.
Referenced by _bt_form_posting(), ItemPointerDec(), ItemPointerInc(), pg_mul_u16_overflow(), replorigin_create(), statext_mcv_serialize(), and TidRangeEval().
#define PG_UINT32_MAX (0xFFFFFFFFU) |
Definition at line 525 of file c.h.
Referenced by bernoulli_beginsamplescan(), executeAnyItem(), i8tooid(), mod_m(), mulShift(), parse_manifest_file(), parse_output_parameters(), pg_mul_u32_overflow(), pg_nextpower2_32(), printJsonPathItem(), shm_toc_insert(), and system_beginsamplescan().
#define PG_UINT64_MAX UINT64CONST(0xFFFFFFFFFFFFFFFF) |
Definition at line 528 of file c.h.
Referenced by CleanupProcSignalState(), pg_mul_u64_overflow(), pg_nextpower2_64(), ProcSignalShmemInit(), test_empty(), test_integerset(), test_single_value(), test_single_value_and_filler(), and WALInsertLockAcquireExclusive().
#define pg_unreachable | ( | ) | abort() |
Definition at line 258 of file c.h.
Referenced by bottomup_sort_and_shrink_cmp(), CreateDestReceiver(), index_delete_sort_cmp(), LWLockAttemptLock(), and slot_compile_deform().
static bool IsPageLockHeld PG_USED_FOR_ASSERTS_ONLY pg_attribute_unused() |
Definition at line 155 of file c.h.
Referenced by _bt_killitems(), _bt_upgrademetapage(), _hash_freeovflpage(), AllocSetDelete(), AllocSetReset(), AuxiliaryProcKill(), be_lo_from_bytea(), be_lo_put(), brinRevmapExtend(), convert_string_datum(), copy_table_data(), create_resultscan_plan(), DecrementParentLocks(), DefineRange(), DeleteChildTargetLocks(), ExecMaterial(), ExecProjectSRF(), get_index_column_opclass(), hash_xlog_add_ovfl_page(), hash_xlog_split_allocate_page(), hashbucketcleanup(), InitializeLatchWaitSet(), JsonbExtractScalar(), lo_get_fragment_internal(), lo_import_internal(), LWLockAcquire(), LWLockAcquireOrWait(), LWLockDequeueSelf(), LWLockWaitForVar(), LWLockWaitListUnlock(), plperl_trigger_handler(), pltcl_trigger_handler(), PLy_exec_trigger(), pq_init(), RelationFindReplTupleSeq(), RemoveTargetIfNoLongerUsed(), s_ksqr(), setop_fill_hash_table(), slist_delete(), socket_putmessage_noblock(), statext_mcv_deserialize(), statext_mcv_serialize(), sts_begin_parallel_scan(), and XLogPageRead().
#define PointerIsAligned | ( | pointer, | |
type | |||
) | (((uintptr_t)(pointer) % (sizeof (type))) == 0) |
Definition at line 704 of file c.h.
Referenced by pg_comp_crc32c_armv8().
#define PointerIsValid | ( | pointer | ) | ((const void*)(pointer) != NULL) |
Definition at line 698 of file c.h.
Referenced by AlterForeignDataWrapper(), AlterForeignServer(), AlterUserMapping(), array_create_iterator(), AtAbort_Portals(), AtCleanup_Portals(), ATExecAlterColumnGenericOptions(), ATExecGenericOptions(), AtSubAbort_Portals(), AtSubCleanup_Portals(), CleanupInvalidationState(), CreateForeignDataWrapper(), CreateForeignServer(), CreateForeignTable(), CreatePortal(), CreateUserMapping(), datumGetSize(), ExceptionalCondition(), get_pgstat_tabentry_relid(), getObjectIdentityParts(), GetPortalByName(), GetSysCacheHashValue(), index_build(), index_reloptions(), InitCatalogCache(), inv_close(), inv_getsize(), inv_read(), inv_seek(), inv_tell(), inv_truncate(), inv_write(), MarkPortalDone(), MarkPortalFailed(), outDatum(), parseRelOptions(), PortalDrop(), PrepareToInvalidateCacheTuple(), ProcedureCreate(), relation_needs_vacanalyze(), RelationCacheInvalidateEntry(), RelationCloseSmgrByOid(), RelationForgetRelation(), ReleaseSavepoint(), RollbackToSavepoint(), SearchSysCache(), SearchSysCache1(), SearchSysCache2(), SearchSysCache3(), SearchSysCache4(), SearchSysCacheList(), ShowTransactionStateRec(), SysCacheGetAttr(), SysCacheInvalidate(), transformRelOptions(), TupleDescCopyEntry(), TupleDescInitBuiltinEntry(), TupleDescInitEntry(), TupleDescInitEntryCollation(), TypeShellMake(), untransformRelOptions(), and XmlTableSetColumnFilter().
#define RegProcedureIsValid | ( | p | ) | OidIsValid(p) |
Definition at line 712 of file c.h.
Referenced by _bt_compare_scankey_args(), _bt_find_extreme_element(), _bt_first(), _bt_sort_array_elements(), _hash_datum2hashkey_type(), ExecIndexBuildScanKeys(), GetIndexAmRoutineByAmId(), inclusion_get_procinfo(), inclusion_get_strategy_procinfo(), index_getprocinfo(), load_rangetype_info(), make_op(), make_scalar_array_op(), minmax_get_strategy_procinfo(), OperatorGet(), OperatorLookup(), and ScanKeyEntryInitialize().
#define SHORTALIGN | ( | LEN | ) | TYPEALIGN(ALIGNOF_SHORT, (LEN)) |
Definition at line 753 of file c.h.
Referenced by checkclass_str(), computeLeafRecompressWALData(), DecodeMultiInsert(), desc_recompress_leaf(), ginCompressPostingList(), GinFormTuple(), ginRedoRecompress(), heap_multi_insert(), heap_xlog_multi_insert(), make_tsvector(), tsvector_concat(), tsvector_delete_by_indices(), tsvector_filter(), tsvectorin(), tsvectorrecv(), and uniqueentry().
#define SHORTALIGN_DOWN | ( | LEN | ) | TYPEALIGN_DOWN(ALIGNOF_SHORT, (LEN)) |
Definition at line 765 of file c.h.
Referenced by ginCompressPostingList().
#define SIGNAL_ARGS int postgres_signal_arg |
Definition at line 1333 of file c.h.
Referenced by WaitEventSetWait().
#define SQL_STR_DOUBLE | ( | ch, | |
escape_backslash | |||
) | ((ch) == '\'' || ((ch) == '\\' && (escape_backslash))) |
Definition at line 1164 of file c.h.
Referenced by appendStringLiteral(), deparseStringLiteral(), escape_single_quotes_ascii(), PQescapeStringInternal(), print_literal(), quote_literal_internal(), serialize_deflist(), and simple_quote_literal().
#define StaticAssertDecl | ( | condition, | |
errmessage | |||
) | extern void static_assert_func(int static_assert_failure[(condition) ? 1 : -1]) |
#define StaticAssertExpr | ( | condition, | |
errmessage | |||
) | StaticAssertStmt(condition, errmessage) |
#define StaticAssertStmt | ( | condition, | |
errmessage | |||
) | ((void) sizeof(struct { int static_assert_failure : (condition) ? 1 : -1; })) |
Definition at line 918 of file c.h.
Referenced by _bt_check_natts(), add_object_address(), AllocSetContextCreateInternal(), AllocSetFreeIndex(), count_nondeletable_pages(), CreateLWLocks(), CreateWaitEventSet(), ExecInterpExpr(), fill_hba_line(), GenerationContextCreate(), get_encoding_name_for_icu(), gin_tsquery_consistent(), heap_finish_speculative(), hstoreValidOldFormat(), index_delete_sort(), InitCatalogCache(), InitializeParallelDSM(), int128_add_int64_mul_int64(), ItemPointerEquals(), pg_atomic_init_flag_impl(), pg_atomic_init_u32_impl(), pg_atomic_init_u64_impl(), pg_checksum_final(), pg_current_snapshot(), pgstat_init(), scram_mock_salt(), SlabContextCreate(), table_block_parallelscan_startblock_init(), TransactionIdSetPageStatus(), update_controlfile(), visibilitymap_count(), and WriteControlFile().
#define STATUS_EOF (-2) |
Definition at line 1172 of file c.h.
Referenced by auth_failed(), auth_peer(), CheckMD5Auth(), CheckPasswordAuth(), CheckRADIUSAuth(), CheckSCRAMAuth(), and PerformRadiusTransaction().
#define STATUS_ERROR (-1) |
Definition at line 1171 of file c.h.
Referenced by auth_peer(), BackendStartup(), check_usermap(), CheckMD5Auth(), CheckPasswordAuth(), CheckPWChallengeAuth(), CheckRADIUSAuth(), CheckSCRAMAuth(), ClientAuthentication(), ident_inet(), md5_crypt_verify(), PerformRadiusTransaction(), pg_fe_sendauth(), pg_GSS_load_servicename(), pg_local_sendauth(), pg_password_sendauth(), pg_SASL_continue(), pg_SASL_init(), plain_crypt_verify(), pq_putmessage_v2(), pq_setkeepalivescount(), pq_setkeepalivesidle(), pq_setkeepalivesinterval(), pq_settcpusertimeout(), pqPacketSend(), ProcessStartupPacket(), ServerLoop(), StreamConnection(), and StreamServerPort().
#define STATUS_OK (0) |
Definition at line 1170 of file c.h.
Referenced by AlterRole(), auth_delay_checks(), auth_peer(), BackendInitialize(), BackendStartup(), check_password(), check_usermap(), CheckPWChallengeAuth(), CheckRADIUSAuth(), CheckSCRAMAuth(), ClientAuthentication(), ConnCreate(), CreateRole(), md5_crypt_verify(), PerformRadiusTransaction(), pg_fe_sendauth(), pg_GSS_load_servicename(), pg_local_sendauth(), pg_SASL_continue(), pg_SASL_init(), plain_crypt_verify(), PostmasterMain(), pq_putmessage_v2(), pq_setkeepalivescount(), pq_setkeepalivesidle(), pq_setkeepalivesinterval(), pq_settcpusertimeout(), PQconnectPoll(), pqPacketSend(), pqsecure_open_gss(), ProcessStartupPacket(), sepgsql_client_auth(), StreamConnection(), and StreamServerPort().
#define TopSubTransactionId ((SubTransactionId) 1) |
Definition at line 594 of file c.h.
Referenced by RelationInitPhysicalAddr(), and StartTransaction().
#define true ((bool) 1) |
Definition at line 395 of file c.h.
Referenced by ArchiveEntry(), create_bitmap_heap_path(), create_seqscan_path(), dataIsMoveRight(), exec_command_d(), exec_command_list(), getTables(), HeapTupleIsSurelyDead(), inner_int_contains(), PQsetnonblocking(), QTNEq(), regression_main(), searchstoplist(), spgWalk(), TParserGet(), and UtilityReturnsTuples().
#define TYPEALIGN | ( | ALIGNVAL, | |
LEN | |||
) | (((uintptr_t) (LEN) + ((ALIGNVAL) - 1)) & ~((uintptr_t) ((ALIGNVAL) - 1))) |
Definition at line 750 of file c.h.
Referenced by BootStrapXLOG(), pg_popcount(), prepare_buf(), slot_compile_deform(), tarPaddingBytesRequired(), and XLOGShmemInit().
#define TYPEALIGN64 | ( | ALIGNVAL, | |
LEN | |||
) | (((uint64) (LEN) + ((ALIGNVAL) - 1)) & ~((uint64) ((ALIGNVAL) - 1))) |
#define TYPEALIGN_DOWN | ( | ALIGNVAL, | |
LEN | |||
) | (((uintptr_t) (LEN)) & ~((uintptr_t) ((ALIGNVAL) - 1))) |
#define UINT64_FORMAT "%" INT64_MODIFIER "u" |
Definition at line 484 of file c.h.
Referenced by _tarGetHeader(), check_foreign_key(), check_with_filler(), CopyFromErrorCallback(), create_and_test_bloom(), EndCommand(), ExplainPropertyUInteger(), get_prompt(), IdentifySystem(), pg_log_generic_v(), pg_lsn_mi(), pg_lsn_mii(), pg_lsn_pli(), pg_snapshot_out(), pg_stat_get_wal(), pg_stat_statements_internal(), ReplicationSlotNameForTablesync(), set_random_seed(), shm_toc_lookup(), show_hashagg_info(), show_wal_usage(), StartupXLOG(), test_empty(), test_huge_distances(), test_pattern(), test_single_value(), test_single_value_and_filler(), TransactionIdInRecentPast(), WalReceiverMain(), and xid8out().
#define unconstify | ( | underlying_type, | |
expr | |||
) | ((underlying_type) (expr)) |
Definition at line 1243 of file c.h.
Referenced by add_placeholder_variable(), auth_peer(), BaseBackup(), brin_doupdate(), call_pltcl_start_proc(), CreateDestReceiver(), EndCompressor(), exec_bind_message(), first_dir_separator(), first_path_var_separator(), gbt_num_bin_union(), gbt_num_union(), get_prompt(), initPQExpBuffer(), IsValidJsonNumber(), last_dir_separator(), lo_write(), load_dh_buffer(), localsub(), LogLogicalMessage(), markPQExpBufferBroken(), mp_int_read_cstring(), parse_datetime(), perform_default_encoding_conversion(), pg_any_to_server(), pg_convert(), pg_get_keywords(), pg_server_to_any(), pgwin32_setlocale(), pltcl_set_tuple_values(), printTableCleanup(), seq_search_localized(), show_incremental_sort_group_info(), tar_write(), termPQExpBuffer(), text_to_cstring(), text_to_cstring_buffer(), to_timestamp(), typeStringToTypeName(), XactLogAbortRecord(), and XactLogCommitRecord().
#define unlikely | ( | x | ) | ((x) != 0) |
Definition at line 273 of file c.h.
Referenced by _bt_binsrch(), _bt_binsrch_insert(), _bt_buildadd(), _bt_doinsert(), _bt_findinsertloc(), _bt_insertonpg(), _bt_pgaddtup(), AdvanceNextFullTransactionIdPastXid(), appendPQExpBufferVA(), check_domain_for_new_field(), check_for_freed_segments(), check_for_freed_segments_locked(), dacos(), dacosd(), dasin(), dasind(), datan(), datan2(), datan2d(), datand(), dcbrt(), dcos(), dcosd(), dcosh(), dexp(), dlog1(), dlog10(), dpow(), drandom(), dsa_get_address(), dsin(), dsind(), dsqrt(), dtanh(), dtof(), dtoi2(), dtoi4(), dtoi8(), exec_assign_value(), exec_eval_datum(), exec_eval_simple_expr(), ExecEvalFieldStoreDeForm(), ExecEvalParamExec(), ExecEvalParamExtern(), ExecEvalSysVar(), ExecInterpExpr(), ExecStoreBufferHeapTuple(), ExecStoreHeapTuple(), ExecStoreMinimalTuple(), ExecStorePinnedBufferHeapTuple(), executeMetaCommand(), expanded_record_fetch_field(), expanded_record_set_field_internal(), expanded_record_set_fields(), float4_div(), float4_mi(), float4_mul(), float4_pl(), float8_combine(), float8_div(), float8_mi(), float8_mul(), float8_pl(), float8_regr_combine(), ftoi2(), ftoi4(), ftoi8(), get_segment_by_index(), GetSnapshotDataReuse(), heap_getnext(), i4toi2(), i8tooid(), in_range_int2_int4(), in_range_int4_int4(), in_range_int4_int8(), in_range_int8_int8(), int24div(), int24mi(), int24mul(), int24pl(), int28div(), int28mi(), int28mul(), int28pl(), int2abs(), int2div(), int2mi(), int2mod(), int2mul(), int2pl(), int2um(), int42div(), int42mi(), int42mul(), int42pl(), int48div(), int48mi(), int48mul(), int48pl(), int4abs(), int4div(), int4inc(), int4lcm(), int4mi(), int4mod(), int4mul(), int4pl(), int4um(), int82(), int82div(), int82mi(), int82mul(), int82pl(), int84(), int84div(), int84mi(), int84mul(), int84pl(), int8abs(), int8dec(), int8div(), int8inc(), int8lcm(), int8mi(), int8mod(), int8mul(), int8pl(), int8um(), line_eq(), MemoryContextAlloc(), MemoryContextAllocExtended(), MemoryContextAllocHuge(), MemoryContextAllocZero(), MemoryContextAllocZeroAligned(), numericvar_to_int64(), numericvar_to_uint64(), PageRepairFragmentation(), palloc(), palloc0(), palloc_extended(), pg_hypot(), pg_strtoint16(), pg_strtoint32(), pglz_decompress(), plpgsql_exec_get_datum_type(), plpgsql_exec_get_datum_type_info(), plpgsql_param_eval_generic(), plpgsql_param_eval_generic_ro(), plpgsql_param_eval_recfield(), plpgsql_param_fetch(), point_eq_point(), pvsnprintf(), RelationGetBufferForTuple(), RelationGetPartitionDesc(), RelationGetPartitionKey(), repalloc(), repalloc_huge(), repeat(), s_check_valid(), scanint8(), SearchCatCacheInternal(), slot_getsomeattrs_int(), strtodouble(), strtoint64(), table_index_fetch_tuple(), table_scan_bitmap_next_block(), table_scan_bitmap_next_tuple(), table_scan_getnextslot(), table_scan_sample_next_block(), table_scan_sample_next_tuple(), table_tuple_fetch_row_version(), table_tuple_get_latest_tid(), text_format_parse_digits(), tts_virtual_clear(), WaitEventSetWait(), and XLogRecGetFullXid().
#define unvolatize | ( | underlying_type, | |
expr | |||
) | ((underlying_type) (expr)) |
Definition at line 1245 of file c.h.
Referenced by pgstat_bestart(), pgstat_read_current_status(), and PMSignalShmemInit().
#define VA_ARGS_NARGS | ( | ... | ) |
#define VA_ARGS_NARGS_ | ( | _01, | |
_02, | |||
_03, | |||
_04, | |||
_05, | |||
_06, | |||
_07, | |||
_08, | |||
_09, | |||
_10, | |||
_11, | |||
_12, | |||
_13, | |||
_14, | |||
_15, | |||
_16, | |||
_17, | |||
_18, | |||
_19, | |||
_20, | |||
_21, | |||
_22, | |||
_23, | |||
_24, | |||
_25, | |||
_26, | |||
_27, | |||
_28, | |||
_29, | |||
_30, | |||
_31, | |||
_32, | |||
_33, | |||
_34, | |||
_35, | |||
_36, | |||
_37, | |||
_38, | |||
_39, | |||
_40, | |||
_41, | |||
_42, | |||
_43, | |||
_44, | |||
_45, | |||
_46, | |||
_47, | |||
_48, | |||
_49, | |||
_50, | |||
_51, | |||
_52, | |||
_53, | |||
_54, | |||
_55, | |||
_56, | |||
_57, | |||
_58, | |||
_59, | |||
_60, | |||
_61, | |||
_62, | |||
_63, | |||
N, | |||
... | |||
) | (N) |
Definition at line 627 of file c.h.
Referenced by anychar_typmodin(), anychar_typmodout(), apply_typmod(), apply_typmod_special(), array_send(), array_to_tsvector(), be_loread(), binary_decode(), binary_encode(), bitsubstring(), bpchar(), bpchar_input(), bpcharoctetlen(), brin_page_type(), bt_page_items_bytea(), bytea_catenate(), bytea_string_agg_finalfn(), byteaeq(), byteain(), byteane(), byteaoctetlen(), bytearecv(), byteaSetBit(), byteaSetByte(), catenate_stringinfo_string(), char_bpchar(), char_text(), check_toast_tuple(), chr(), concat_text(), convertToJsonb(), CopyOneRowTo(), copytext(), cryptohash_internal(), cstring_to_text_with_len(), datum_image_eq(), decrypt_internal(), detoast_attr(), detoast_attr_slice(), dobyteatrim(), ECPGget_desc(), encrypt_internal(), formTextDatum(), gbt_bit_xfrm(), gbt_bytea_pf_match(), gbt_var_key_copy(), gbt_var_key_from_datum(), gbt_var_key_readable(), gbt_var_node_cp_len(), gbt_var_node_truncate(), gbt_var_penalty(), generateHeadline(), get_raw_page_internal(), getdatafield(), ghstore_consistent(), gin_extract_hstore_query(), gin_extract_jsonb_query(), gist_page_items_bytea(), gistInitBuffering(), gtrgm_consistent(), gtrgm_distance(), heap_fetch_toast_slice(), heap_page_items(), hstore_from_array(), hstore_from_arrays(), hstore_hash(), hstore_hash_extended(), hstore_slice_to_array(), hstoreArrayToPairs(), inv_truncate(), inv_write(), jsonb_exists_all(), jsonb_exists_any(), jsonb_get_element(), JsonbToJsonbValue(), JsonbValueToJsonb(), lo_get_fragment_internal(), LogicalOutputWrite(), logicalrep_write_tuple(), lpad(), ltree2text(), make_greater_string(), make_text_key(), makeitem(), map_sql_type_to_xml_name(), map_sql_type_to_xmlschema_type(), MatchText(), multirange_send(), numeric(), numeric_abbrev_convert(), numeric_maximum_size(), numeric_sortsupport(), numeric_support(), numeric_to_number(), numerictypmodin(), numerictypmodout(), optionListToArray(), page_checksum_internal(), page_header(), parseRelOptionsInternal(), pg_armor(), pg_convert(), pg_dearmor(), pg_decrypt(), pg_decrypt_iv(), pg_digest(), pg_encrypt(), pg_encrypt_iv(), pg_hmac(), pg_random_bytes(), pgp_key_id_w(), PLyObject_ToBytea(), populate_record_worker(), pq_endtypsend(), printtup(), quote_literal(), range_send(), read_binary_file(), read_text_file(), record_image_cmp(), record_send(), ReorderBufferToastAppendChunk(), ReorderBufferToastReplace(), repeat(), rpad(), SendFunctionResult(), show_trgm(), similar_escape_internal(), spg_text_inner_consistent(), spg_text_leaf_consistent(), SPI_sql_row_to_xmlelement(), statext_dependencies_serialize(), statext_mcv_deserialize(), statext_mcv_serialize(), statext_ndistinct_serialize(), string_to_bytea_const(), text_catenate(), text_length(), text_reverse(), text_substring(), texteq(), textne(), textoctetlen(), toast_decompress_datum(), toast_decompress_datum_slice(), toast_fetch_datum(), toast_fetch_datum_slice(), toast_raw_datum_size(), toast_save_datum(), transformRelOptions(), translate(), tsquerytree(), tsvector_delete_arr(), tsvector_setweight_by_filter(), tuple_data_split(), tuple_data_split_internal(), type_maximum_size(), unicode_normalize_func(), varchar(), varchar_input(), varchar_support(), verify_brin_page(), xml_recv(), xmlconcat(), and xmlroot().
typedef uint32 LocalTransactionId |
typedef TransactionId MultiXactId |
typedef uint32 MultiXactOffset |
typedef union PGAlignedBlock PGAlignedBlock |
typedef union PGAlignedXLogBlock PGAlignedXLogBlock |
typedef regproc RegProcedure |
typedef uint32 SubTransactionId |
typedef uint32 TransactionId |
void ExceptionalCondition | ( | const char * | conditionName, |
const char * | errorType, | ||
const char * | fileName, | ||
int | lineNumber | ||
) |
Definition at line 30 of file assert.c.
References buf, lengthof, PointerIsValid, and write_stderr.
Referenced by pg_re_throw().