Header And Logo

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

Data Structures | Defines | Typedefs | Functions

c.h File Reference

#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 <sys/types.h>
#include <errno.h>
#include <locale.h>
#include "port.h"
Include dependency graph for c.h:
This graph shows which files directly or indirectly include this file:

Go to the source code of this file.

Data Structures

struct  IntArray
struct  varlena
struct  int2vector
struct  oidvector
struct  nameData

Defines

#define _(x)   gettext(x)
#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 gettext_noop(x)   (x)
#define CppAsString(identifier)   "identifier"
#define _priv_CppIdentity(x)   x
#define CppConcat(x, y)   _priv_CppIdentity(x)y
#define dummyret   char
#define __attribute__(_arg_)
#define true   ((bool) 1)
#define false   ((bool) 0)
#define TRUE   1
#define FALSE   0
#define NULL   ((void *) 0)
#define INT64CONST(x)   ((int64) x)
#define UINT64CONST(x)   ((uint64) x)
#define InvalidSubTransactionId   ((SubTransactionId) 0)
#define TopSubTransactionId   ((SubTransactionId) 1)
#define FirstCommandId   ((CommandId) 0)
#define MAXDIM   6
#define VARHDRSZ   ((int32) sizeof(int32))
#define NameStr(name)   ((name).data)
#define SQL_STR_DOUBLE(ch, escape_backslash)   ((ch) == '\'' || ((ch) == '\\' && (escape_backslash)))
#define ESCAPE_STRING_SYNTAX   'E'
#define BoolIsValid(boolean)   ((boolean) == false || (boolean) == true)
#define PointerIsValid(pointer)   ((const void*)(pointer) != NULL)
#define PointerIsAligned(pointer, type)   (((intptr_t)(pointer) % (sizeof (type))) == 0)
#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 endof(array)   (&(array)[lengthof(array)])
#define TYPEALIGN(ALIGNVAL, LEN)   (((intptr_t) (LEN) + ((ALIGNVAL) - 1)) & ~((intptr_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 TYPEALIGN_DOWN(ALIGNVAL, LEN)   (((intptr_t) (LEN)) & ~((intptr_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 Assert(condition)
#define AssertMacro(condition)   ((void)true)
#define AssertArg(condition)
#define AssertState(condition)
#define StaticAssertStmt(condition, errmessage)   ((void) sizeof(struct { int static_assert_failure : (condition) ? 1 : -1; }))
#define StaticAssertExpr(condition, errmessage)   StaticAssertStmt(condition, errmessage)
#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 StrNCpy(dst, src, len)
#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 pg_unreachable()   abort()
#define STATIC_IF_INLINE
#define HIGHBIT   (0x80)
#define IS_HIGHBIT_SET(ch)   ((unsigned char)(ch) & HIGHBIT)
#define STATUS_OK   (0)
#define STATUS_ERROR   (-1)
#define STATUS_EOF   (-2)
#define STATUS_FOUND   (1)
#define STATUS_WAITING   (2)
#define PG_USED_FOR_ASSERTS_ONLY   __attribute__((unused))
#define CppAsString2(x)   CppAsString(x)
#define PG_TEXTDOMAIN(domain)   (domain "-" PG_MAJORVERSION)
#define PG_BINARY   0
#define PG_BINARY_A   "a"
#define PG_BINARY_R   "r"
#define PG_BINARY_W   "w"
#define memmove(d, s, c)   bcopy(s, d, c)
#define PGDLLIMPORT
#define PGDLLEXPORT
#define SIGNAL_ARGS   int postgres_signal_arg
#define sigjmp_buf   jmp_buf
#define sigsetjmp(x, y)   setjmp(x)
#define siglongjmp   longjmp
#define NON_EXEC_STATIC   static

Typedefs

typedef char bool
typedef boolBoolPtr
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 int sig_atomic_t
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 NameDataName

Functions

int snprintf (char *str, size_t count, const char *fmt,...) __attribute__((format(PG_PRINTF_ATTRIBUTE
int int vsnprintf (char *str, size_t count, const char *fmt, va_list args)

Define Documentation

#define _ (   x  )     gettext(x)

Definition at line 98 of file c.h.

#define __attribute__ (   _arg_  ) 

Definition at line 167 of file c.h.

#define _priv_CppIdentity (   x  )     x

Definition at line 152 of file c.h.

#define Abs (   x  )     ((x) >= 0 ? (x) : -(x))
#define Assert (   condition  ) 

Definition at line 572 of file c.h.

Referenced by _bt_binsrch(), _bt_buildadd(), _bt_check_rowcompare(), _bt_checkkeys(), _bt_compare_scankey_args(), _bt_delitems_delete(), _bt_endpoint(), _bt_find_extreme_element(), _bt_first(), _bt_fix_scankey_strategy(), _bt_getbuf(), _bt_getroot(), _bt_getrootheight(), _bt_insert_parent(), _bt_insertonpg(), _bt_isequal(), _bt_killitems(), _bt_mark_scankey_required(), _bt_next(), _bt_pagedel(), _bt_preprocess_array_keys(), _bt_preprocess_keys(), _bt_readpage(), _bt_relandgetbuf(), _bt_restore_array_keys(), _bt_restore_meta(), _bt_split(), _bt_start_array_keys(), _bt_steppage(), _bt_uppershutdown(), _copyList(), _equalList(), _hash_binsearch(), _hash_binsearch_last(), _hash_doinsert(), _hash_expandtable(), _hash_first(), _hash_form_tuple(), _hash_freeovflpage(), _hash_getovflpage(), _hash_metapinit(), _hash_next(), _hash_pageinit(), _hash_splitbucket(), _hash_squeezebucket(), _hash_step(), _MasterEndParallelItem(), _MasterStartParallelItem(), _mdfd_getseg(), _mdfd_openseg(), _SPI_execute_plan(), _SPI_make_plan_non_temp(), _SPI_pquery(), _SPI_prepare_plan(), _SPI_save_plan(), AbortBufferIO(), AbortOutOfAnyTransaction(), AbortStrongLockAcquire(), AbortTransaction(), accumArrayResult(), aclparse(), aclupdate(), acquire_inherited_sample_rows(), acquire_sample_rows(), AcquireExecutorLocks(), AcquirePlannerLocks(), AcquireRewriteLocks(), activate_interpreter(), add_abs(), add_eq_member(), add_exact_object_address(), add_lateral_info(), add_object_address(), add_vars_to_targetlist(), AddCatcacheInvalidationMessage(), addItemPointersToLeafTuple(), addOrReplaceTuple(), AddQual(), addRangeTableEntryForCTE(), addRangeTableEntryForFunction(), addRangeTableEntryForSubquery(), AddRelationNewConstraints(), addressOK(), AddRoleMems(), addTargetToSortList(), adjust_appendrel_attrs_mutator(), adjust_inherited_tlist(), adjust_rowcompare_for_index(), adjust_view_column_set(), advance_aggregates(), afterTriggerAddEvent(), AfterTriggerBeginQuery(), AfterTriggerBeginXact(), AfterTriggerEndQuery(), AfterTriggerEndSubXact(), AfterTriggerFireDeferred(), AfterTriggerSaveEvent(), agg_retrieve_hash_table(), AggregateCreate(), AllocateVfd(), AllocSetAlloc(), AllocSetFree(), AllocSetFreeIndex(), AllocSetRealloc(), AlterDatabase(), AlterObjectNamespace_internal(), AlterObjectOwner_internal(), AlterObjectRename_internal(), AlterOpFamilyAdd(), AlterOpFamilyDrop(), AlterRelationNamespaceInternal(), AlterSchemaOwner_internal(), AlterTableNamespaceInternal(), analyze_row_processor(), analyzeCTE(), analyzeCTETargetList(), AppendAttributeTuples(), appendBinaryStringInfo(), appendStringInfoRegexpSubstr(), appendStringInfoVA(), applyRemoteGucs(), ApplyRetrieveRule(), array_agg_finalfn(), array_bitmap_copy(), array_create_iterator(), array_dim_to_json(), array_fill_internal(), array_map(), array_set_slice(), ArrayCastAndSet(), ArrayGetNItems(), ascii(), assign_collations_walker(), assign_nestloop_param_placeholdervar(), assign_nestloop_param_var(), assign_param_for_placeholdervar(), assign_record_type_typmod(), AssignTransactionId(), asyncQueueAdvance(), asyncQueueNotificationToEntry(), asyncQueuePagePrecedes(), asyncQueueReadAllNotifications(), asyncQueueUnregister(), ATAddCheckConstraint(), ATAddForeignKeyConstraint(), AtCleanup_Memory(), AtCleanup_Portals(), ATColumnChangeRequiresRewrite(), AtCommit_Memory(), AtEOSubXact_Inval(), AtEOSubXact_PgStat(), AtEOXact_Buffers(), AtEOXact_CatCache(), AtEOXact_cleanup(), AtEOXact_GUC(), AtEOXact_Inval(), AtEOXact_LocalBuffers(), AtEOXact_PgStat(), AtEOXact_RelationMap(), AtEOXact_SMgr(), AtEOXact_Snapshot(), ATExecAddConstraint(), ATExecAddIndex(), ATExecAddIndexConstraint(), ATExecAlterColumnType(), ATExecSetOptions(), ATExecSetStatistics(), ATExecSetStorage(), ATPostAlterTypeParse(), AtPrepare_PgStat(), AtProcExit_Buffers(), AtProcExit_LocalBuffers(), AtStart_Inval(), AtStart_Memory(), AtStart_ResourceOwner(), AtSubAbort_Memory(), AtSubAbort_Snapshot(), AtSubCleanup_Memory(), AtSubCleanup_Portals(), AtSubCommit_childXids(), AtSubCommit_Memory(), AtSubCommit_Notify(), AtSubStart_Inval(), AtSubStart_Memory(), AtSubStart_Notify(), AtSubStart_ResourceOwner(), ATTypedTableRecursion(), AutoVacuumShmemInit(), AuxiliaryProcessMain(), AuxiliaryProcKill(), backend_read_statsfile(), BackendRun(), BeginCopy(), BeginCopyFrom(), BeginCopyTo(), beginmerge(), BeginStrongLockAcquire(), BgBufferSync(), binaryheap_first(), binaryheap_remove_first(), binaryheap_replace_first(), bitgetpage(), bitmap_hash(), bitmap_match(), BitmapHeapNext(), BlockSampler_Next(), blowfish_decrypt_cbc(), blowfish_decrypt_ecb(), blowfish_encrypt_cbc(), blowfish_encrypt_ecb(), blowfish_setkey(), BootStrapCLOG(), BootstrapModeMain(), BootStrapMultiXact(), BootStrapSUBTRANS(), bounds_adjacent(), bpchar(), btbeginscan(), btcostestimate(), btree_xlog_delete_get_latestRemovedXid(), btree_xlog_delete_page(), btree_xlog_newroot(), btree_xlog_reuse_page(), btree_xlog_split(), BTreeShmemInit(), BufferAlloc(), BufferGetBlockNumber(), BufferGetLSNAtomic(), BufferGetTag(), BufferIsPermanent(), BufFileCreateTemp(), BufFileDumpBuffer(), BufFileRead(), BufFileWrite(), BufTableInsert(), build_coercion_expression(), build_datatype(), build_dummy_tuple(), build_function_result_tupdesc_d(), build_function_result_tupdesc_t(), build_hash_table(), build_join_rel(), build_join_rel_hash(), build_minmax_path(), build_simple_rel(), build_subplan(), BuildCachedPlan(), BuildDescFromLists(), buildMatViewRefreshDependencies(), buildRelationAliases(), buildScalarFunctionAlias(), buildSubPlanHash(), BuildTupleHashTable(), bytea_string_agg_finalfn(), CachedPlanGetTargetList(), CachedPlanIsValid(), CachedPlanSetParentContext(), calc_hist_selectivity(), calc_joinrel_size_estimate(), calc_length_hist_frac(), calc_nestloop_required_outer(), calc_non_nestloop_required_outer(), CatalogCacheComputeTupleHashValue(), CatalogCacheIdInvalidate(), CatalogCacheInitializeCache(), CatalogIndexInsert(), CatCacheRemoveCList(), CatCacheRemoveCTup(), ChangeVarNodes_walker(), check_circularity(), check_of_type(), check_relation_privileges(), check_sql_fn_retval(), check_timezone_abbreviations(), check_ungrouped_columns_walker(), CheckCachedPlan(), checkDataDir(), CheckDateTokenTables(), CheckDeadLock(), CheckForSerializableConflictOut(), CheckIndexCompatible(), checkMatch(), CheckRADIUSAuth(), CheckRecoveryConflictDeadlock(), checkSplitConditions(), checksum_block(), CheckTableForSerializableConflictIn(), CheckTargetForConflictsIn(), checkWellFormedRecursion(), choose_bitmap_and(), clean_fakeval_intree(), clean_NOT_intree(), CleanupBackgroundWorker(), CleanupInvalidationState(), CleanUpLock(), CleanupProcSignalState(), CleanupTempFiles(), ClearOldPredicateLocks(), ClientAuthentication(), clog_redo(), CloneArchive(), close_pl(), close_ps(), closeAllVfds(), ClosePipeToProgram(), CollationCreate(), collectMatchesForHeapRow(), CommitTransaction(), CommitTransactionCommand(), compact_palloc0(), CompactCheckpointerRequestQueue(), comparetup_index_btree(), comparetup_index_hash(), CompleteCachedPlan(), compute_array_stats(), compute_new_xmax_infomask(), compute_return_type(), compute_scalar_stats(), compute_semi_anti_join_factors(), compute_tsvector_stats(), computeDistance(), ComputeIndexAttrs(), concat_internal(), ConditionalLockBuffer(), ConditionalLockBufferForCleanup(), ConditionalXactLockTableWait(), contain_agg_clause_walker(), ConversionCreate(), convert_ANY_sublink_to_join(), convert_EXISTS_sublink_to_join(), convert_EXISTS_to_ANY(), convert_prep_stmt_params(), convert_string_datum(), convert_subquery_pathkeys(), ConvertTimeZoneAbbrevs(), cookDefault(), copy_heap_data(), CopyCachedPlan(), CopyErrorData(), CopyFrom(), CopyReadAttributesCSV(), CopyReadLine(), CopySnapshot(), cost_agg(), cost_bitmap_heap_scan(), cost_ctescan(), cost_functionscan(), cost_index(), cost_seqscan(), cost_subqueryscan(), cost_tidscan(), cost_valuesscan(), cost_windowagg(), count_agg_clauses_walker(), create_append_path(), create_append_plan(), create_bitmap_scan_plan(), create_bitmap_subplan(), create_ctescan_plan(), create_foreignscan_plan(), create_functionscan_plan(), create_hashjoin_plan(), create_index_paths(), create_indexscan_plan(), create_lateral_join_info(), create_material_path(), create_merge_append_path(), create_merge_append_plan(), create_mergejoin_plan(), create_or_index_quals(), create_plan(), create_result_plan(), create_seqscan_plan(), create_subqueryscan_plan(), create_tidscan_plan(), create_toast_table(), create_unique_path(), create_unique_plan(), create_valuesscan_plan(), create_worktablescan_plan(), CreateCachedPlan(), CreateCommandTag(), CreateConstraintEntry(), CreateExtension(), CreateFakeRelcacheEntry(), CreateOneShotCachedPlan(), createPostingTree(), CreateSharedMemoryAndSemaphores(), CreateTrigger(), createViewAsClause(), DataChecksumsEnabled(), dataFindChildPtr(), dataGetLeftMostPage(), dataIsEnoughSpace(), dataLocateItem(), dataLocateLeafItem(), dataPlaceToPage(), dataPrepareData(), datum_write(), datumGetSize(), dbase_redo(), DeadLockCheck(), DecodeInterval(), decodePageSplitRecord(), deconstruct_array(), deconstruct_jointree(), DecrementParentLocks(), DecrTupleDescRefCount(), define_custom_variable(), DefineCompositeType(), DefineIndex(), DefineOpClass(), DefineRelation(), DefineSequence(), DefineView(), DefineVirtualRelation(), Delete(), DeleteChildTargetLocks(), DeleteLockTarget(), DeleteSecurityLabel(), DelRoleMems(), deparseColumnRef(), deparseDistinctExpr(), deparseOpExpr(), deparseScalarArrayOpExpr(), determineRecursiveColTypes(), dir_realloc(), disable_timeout(), disable_timeouts(), DisownLatch(), DispatchJobForTocEntry(), dist_ppath(), distribute_qual_to_rels(), div_var(), div_var_fast(), do_compile(), do_pg_abort_backup(), do_pg_stop_backup(), do_pset(), DoCopy(), doDeletion(), doPickSplit(), DoPortalRunFetch(), drop_indexable_join_clauses(), DropAllPredicateLocksFromTable(), DropCachedPlan(), DropErrorMsgNonExistent(), DropErrorMsgWrongType(), dumptuples(), DynaHashAlloc(), eclass_useful_for_merging(), editFile(), eliminate_duplicate_dependencies(), enable_timeout(), EnableDisableRule(), EnablePortalManager(), EncodeDateOnly(), EncodeDateTime(), EndPrepare(), entry_alloc(), entryFindChildPtr(), entryGetItem(), entryGetLeftMostPage(), entryIsEnoughSpace(), entryLocateEntry(), entryLocateLeafEntry(), entryPreparePage(), estimate_num_groups(), estimate_path_cost_size(), eval_const_expressions_mutator(), EvalPlanQual(), EvalPlanQualFetchRowMarks(), EvalPlanQualGetTuple(), EvalPlanQualSetTuple(), EvalPlanQualStart(), EventTriggerSQLDropAddObject(), EventTriggerSupportsObjectClass(), examine_simple_variable(), exec_assign_value(), exec_describe_statement_message(), exec_eval_datum(), exec_eval_simple_expr(), exec_execute_message(), exec_run_select(), exec_simple_check_plan(), exec_stmt_assign(), exec_stmt_block(), exec_stmt_execsql(), exec_stmt_forc(), exec_stmt_return(), exec_stmt_return_query(), ExecAlternativeSubPlan(), ExecAlterObjectSchemaStmt(), ExecAlterOwnerStmt(), ExecBuildAuxRowMark(), ExecCallTriggerFunc(), ExecCheckRTPerms(), ExecCleanTargetListLength(), ExecClearTuple(), ExecConstraints(), ExecCopySlotMinimalTuple(), ExecCopySlotTuple(), ExecCreateTableAs(), execCurrentOf(), ExecDelete(), ExecDropSingleTupleTableSlot(), ExecEvalConvertRowtype(), ExecEvalDistinct(), ExecEvalFieldStore(), ExecEvalFuncArgs(), ExecEvalNullIf(), ExecEvalParamExec(), ExecEvalScalarArrayOp(), ExecEvalScalarVar(), ExecEvalWholeRowSlow(), ExecEvalWholeRowVar(), ExecEvalXml(), ExecFetchSlotMinimalTuple(), ExecFetchSlotTuple(), ExecGetJunkAttribute(), ExecHashIncreaseNumBatches(), ExecHashJoin(), ExecHashRemoveNextSkewBucket(), ExecHashTableCreate(), ExecHashTableInsert(), ExecIndexBuildScanKeys(), ExecInitAgg(), ExecInitAlternativeSubPlan(), ExecInitAppend(), ExecInitBitmapAnd(), ExecInitBitmapHeapScan(), ExecInitBitmapIndexScan(), ExecInitBitmapOr(), ExecInitCteScan(), ExecInitExpr(), ExecInitForeignScan(), ExecInitFunctionScan(), ExecInitGroup(), ExecInitHash(), ExecInitHashJoin(), ExecInitLimit(), ExecInitLockRows(), ExecInitMergeAppend(), ExecInitMergeJoin(), ExecInitModifyTable(), ExecInitNestLoop(), ExecInitNode(), ExecInitRecursiveUnion(), ExecInitResult(), ExecInitSeqScan(), ExecInitSetOp(), ExecInitSubPlan(), ExecInitSubqueryScan(), ExecInitUnique(), ExecInitValuesScan(), ExecInitWindowAgg(), ExecInitWorkTableScan(), ExecLimit(), ExecLockRows(), ExecMakeFunctionResult(), ExecMaterial(), ExecMaterializeSlot(), ExecMaterialMarkPos(), ExecMaterialRestrPos(), ExecMergeJoin(), ExecNestLoop(), ExecProject(), ExecQueryUsingCursor(), ExecRefreshMatView(), ExecRenameStmt(), ExecResetTupleTable(), ExecScan(), ExecScanFetch(), ExecScanReScan(), ExecScanSubPlan(), ExecSetParamPlan(), ExecSetVariableStmt(), ExecStoreAllNullTuple(), ExecStoreMinimalTuple(), ExecStoreTuple(), ExecStoreVirtualTuple(), execTuplesHashPrepare(), ExecTypeFromExprList(), ExecUpdate(), ExecuteRecoveryCommand(), ExecutorRewind(), ExecWindowAgg(), ExecWorkTableScan(), exp_var_internal(), expand_all_col_privileges(), expand_boolean_index_clause(), expand_indexqual_conditions(), expand_inherited_rtentry(), expand_table(), ExpandAllTables(), ExpandColumnRefStar(), ExpandConstraints(), expandRecordVariable(), expandRelAttrs(), ExpandRowReference(), expandRTE(), ExpireTreeKnownAssignedTransactionIds(), ExplainJSONLineEnding(), ExplainModifyTarget(), ExplainOneUtility(), ExplainPrintPlan(), ExplainQuery(), ExplainTargetRel(), ExplainYAMLLineStarting(), exprCollation(), expression_tree_walker(), exprSetCollation(), exprType(), exprTypmod(), extendBufFile(), extract_actual_clauses(), extract_actual_join_clauses(), extract_autovac_opts(), extract_grouping_ops(), extract_lateral_references(), extract_query_dependencies_walker(), extractRelOptions(), extractRemainingColumns(), FastPathGrantRelationLock(), FastPathUnGrantRelationLock(), fetch_fp_info(), fetch_function_defaults(), fetch_tuple_flag(), FetchPreparedStatementResultDesc(), FetchStatementTargetList(), file_acquire_sample_rows(), FileClose(), FilePathName(), FilePrefetch(), FileRead(), FileSeek(), FileSync(), FileTruncate(), FileWrite(), fill_in_constant_lengths(), fill_seq_with_data(), fillQT(), final_cost_hashjoin(), find_base_rel(), find_childrel_appendrelinfo(), find_lateral_references(), find_minmax_aggs_walker(), find_option(), find_param_referent(), find_placeholder_info(), find_placeholders_in_jointree(), find_unaggregated_cols_walker(), find_update_path(), find_window_functions_walker(), findeq(), FindLockCycleRecurse(), findoprnd_recurse(), FinishPreparedTransaction(), fix_append_rel_relids(), fix_indexqual_operand(), fix_indexqual_references(), fix_scan_expr_mutator(), fix_scan_expr_walker(), FlagRWConflict(), FlagSxactUnsafe(), flatCopyTargetEntry(), flatten_join_alias_vars_mutator(), flatten_join_using_qual(), flatten_set_variable_args(), flatten_simple_union_all(), fmgr_sql(), FormIndexDatum(), free_plperl_function(), FreeQueryDesc(), FreeSnapshot(), FreeTupleDesc(), from_char_parse_int_len(), from_char_seq_search(), fsm_get_avail(), fsm_get_child(), fsm_get_heap_blk(), fsm_get_parent(), fsm_set_avail(), fsm_space_avail_to_cat(), fsm_truncate_avail(), func_get_detail(), FuncnameGetCandidates(), function_parse_error_transpose(), 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_mergeappend_paths(), generate_normalized_query(), generate_recursion_plan(), generate_setop_grouplist(), generate_setop_tlist(), generateClonedIndexStmt(), geqo_eval(), get_actual_clauses(), get_actual_variable_range(), get_agg_expr(), get_all_actual_clauses(), get_appendrel_parampathinfo(), get_baserel_parampathinfo(), get_btree_test_op(), get_catalog_object_by_oid(), get_delete_query_def(), get_first_col_type(), get_from_clause_coldeflist(), get_func_arg_info(), get_func_result_name(), get_func_signature(), get_insert_query_def(), get_join_index_paths(), get_joinrel_parampathinfo(), get_loop_count(), get_name_for_var_field(), get_object_address(), get_object_address_opcf(), get_object_namespace(), get_op_btree_interpretation(), get_rel_data_width(), get_relation_info(), get_rels_with_domain(), get_rewrite_oid(), get_rtable_name(), get_rte_attribute_type(), get_rule_expr(), get_rule_sortgroupclause(), get_rule_windowspec(), get_setop_query(), get_sublink_expr(), get_switched_clauses(), get_tablespace_page_costs(), get_text_array_contents(), get_update_query_def(), get_variable(), get_view_query(), get_windowfunc_expr(), get_worker(), GetActiveSnapshot(), getBaseTypeAndTypmod(), getbytealen(), GetCachedPlan(), GetConfigOptionByNum(), GetCTEForRTE(), getdatabaseencoding(), GetDatabaseEncoding(), GetDatabaseEncodingName(), GetDatabasePath(), getid(), getInsertSelectQuery(), GetLocalBufferStorage(), GetLockmodeName(), GetLocksMethodTable(), GetLockStatusData(), GetMemoryChunkContext(), GetMemoryChunkSpace(), getMessageFromWorker(), GetMultiXactIdMembers(), GetNewMultiXactId(), GetNewOid(), GetNewTransactionId(), GetOldestActiveTransactionId(), GetOldestXmin(), GetOverrideSearchPath(), GetParentPredicateLockTag(), GetPredicateLockStatusData(), GetRealCmax(), GetRealCmin(), GetRedoRecPtr(), GetRTEByRangeTablePosn(), GetRunningTransactionData(), GetSafeSnapshot(), GetSerializableTransactionSnapshot(), GetSerializableTransactionSnapshotInt(), GetSnapshotData(), GetStableLatestTransactionId(), GetSystemIdentifier(), GetTempToastNamespace(), gettoken_tsvector(), GetTransactionSnapshot(), GetTupleForTrigger(), GetVisibilityMapPins(), GetXLogReceiptTime(), ginbeginscan(), ginbulkdelete(), ginCombineData(), gincost_scalararrayopexpr(), gincostestimate(), ginDeletePage(), ginFindLeafPage(), ginFindParents(), GinFormTuple(), ginGetBAEntry(), ginHeapTupleFastInsert(), ginInsertBAEntries(), ginInsertCleanup(), ginInsertValue(), GinPageDeletePostingItem(), ginRedoCreateIndex(), ginRedoCreatePTree(), ginRedoDeleteListPages(), ginRedoDeletePage(), ginRedoInsert(), ginRedoInsertListPage(), ginRedoSplit(), ginScanToDelete(), GinShortenTuple(), gintuple_get_attrnum(), ginvacuumcleanup(), ginVacuumPostingTree(), ginVacuumPostingTreeLeaves(), gist_box_picksplit(), gist_point_consistent(), gistbufferinginserttuples(), gistbuild(), gistchoose(), gistdoinsert(), gistfinishsplit(), gistfixsplit(), gistGetFakeLSN(), gistGetItupFromPage(), gistindex_keytest(), gistMemorizeAllDownlinks(), gistPlaceItupToPage(), gistPopItupFromNodeBuffer(), gistProcessItup(), gistRedoCreateIndex(), gistRedoPageSplitRecord(), gistRelocateBuildBuffersOnSplit(), gistrescan(), gistScanPage(), GISTSearchTreeItemCombiner(), gistSplitByKey(), gistUserPicksplit(), GrantLock(), GrantLockLocal(), grouping_planner(), GUCArrayAdd(), GUCArrayDelete(), HandleSlashCmds(), hash_create(), hash_destroy(), hash_get_shared_size(), hash_inner_and_outer(), hash_numeric(), hash_search_with_hash_value(), hashbeginscan(), hashbulkdelete(), hashgettuple(), hashname(), heap_compare_slots(), heap_create(), heap_create_with_catalog(), heap_delete(), heap_fill_tuple(), heap_freeze_tuple(), heap_get_root_tuples(), heap_getsysattr(), heap_hot_search_buffer(), heap_is_matview_init_state(), heap_lock_tuple(), heap_multi_insert(), heap_page_is_all_visible(), heap_prepare_insert(), heap_prune_chain(), heap_prune_record_dead(), heap_prune_record_prunable(), heap_prune_record_redirect(), heap_prune_record_unused(), heap_tuple_attr_equals(), heap_update(), heap_xlog_clean(), heap_xlog_cleanup_info(), heap_xlog_insert(), heap_xlog_multi_insert(), heap_xlog_newpage(), heap_xlog_update(), heap_xlog_visible(), heapgetpage(), heapgettup(), heapgettup_pagemode(), HeapTupleHeaderGetCmax(), HeapTupleHeaderGetCmin(), HeapTupleSatisfiesMVCC(), HeapTupleSatisfiesVacuum(), histogram_selectivity(), hstore_from_array(), hstore_from_arrays(), hstore_hash(), hstore_to_array_internal(), identify_join_columns(), IncrBufferRefCount(), IncrTupleDescRefCount(), index_build(), index_close(), index_constraint_create(), index_create(), index_deform_tuple(), index_getnext(), index_getnext_tid(), index_getprocid(), index_getprocinfo(), index_pages_fetched(), index_register(), index_reloptions(), index_rescan(), index_restrpos(), index_set_state_flags(), index_update_stats(), IndexBuildHeapScan(), IndexGetRelation(), inheritance_planner(), init_execution_state(), init_fcache(), init_params(), init_ps_display(), InitAuxiliaryProcess(), InitBufferPool(), InitCatalogCache(), InitCatalogCachePhase2(), InitCatCache(), InitFileAccess(), initial_cost_mergejoin(), initialize_mergeclause_eclasses(), initialize_peragg(), InitializeClientEncoding(), InitializeLatchSupport(), InitializeMaxBackends(), InitializeOneGUCOption(), InitLatch(), InitPlan(), InitPostgres(), InitPostmasterDeathWatchHandle(), InitProcess(), InitProcessPhase2(), InitProcGlobal(), InitShmemAllocation(), inittapes(), InitTempTableNamespace(), InitWalSenderSlot(), InitXLOGAccess(), inline_function(), inline_set_returning_function(), Insert(), InsertOneNull(), int2vectorrecv(), interpret_AS_clause(), interval_transform(), intorel_startup(), inv_close(), inv_getsize(), inv_read(), inv_seek(), inv_tell(), inv_truncate(), inv_write(), InvalidateConstraintCacheCallBack(), InvalidateOprCacheCallBack(), InvalidateOprProofCacheCallBack(), is_foreign_expr(), is_libpq_option(), is_simple_union_all(), is_simple_union_all_recurse(), is_strict_saop(), is_valid_option(), IsCheckpointOnSchedule(), IsPostmasterChildWalSender(), IsTidEqualAnyClause(), join_is_legal(), join_search_one_level(), json_agg_finalfn(), JumbleExpr(), JumbleQuery(), JumbleRangeTable(), keyGetItem(), KnownAssignedXidExists(), KnownAssignedXidsAdd(), KnownAssignedXidsRemove(), KnownAssignedXidsRemovePreceding(), KnownAssignedXidsSearch(), lappend(), lappend_cell(), lappend_cell_int(), lappend_cell_oid(), lappend_int(), lappend_oid(), LargeObjectCreate(), lastval(), lazy_scan_heap(), lazy_vacuum_page(), lcons(), lcons_int(), lcons_oid(), libpq_select(), like_fixed_prefix(), list_concat(), list_concat_unique(), list_concat_unique_int(), list_concat_unique_oid(), list_concat_unique_ptr(), list_delete(), list_delete_cell(), list_delete_int(), list_delete_oid(), list_delete_ptr(), list_difference(), list_difference_int(), list_difference_oid(), list_difference_ptr(), list_free_deep(), list_intersection(), list_member(), list_member_int(), list_member_oid(), list_member_ptr(), list_nth(), list_nth_cell(), list_nth_int(), list_nth_oid(), list_truncate(), list_union(), list_union_int(), list_union_oid(), list_union_ptr(), ListenToWorkers(), lo_import_internal(), load_relcache_init_file(), load_typcache_tupdesc(), LocalBufferAlloc(), LocalSetXLogInsertAllowed(), locate_grouping_columns(), lock_twophase_postcommit(), lock_twophase_recover(), lock_twophase_standby_recover(), LockAcquireExtended(), LockBuffer(), LockBufferForCleanup(), LockReassignCurrentOwner(), LockRelease(), LockReleaseAll(), lockTableNoWait(), log_heap_clean(), log_heap_freeze(), log_heap_update(), log_heap_visible(), log_newpage_buffer(), LogicalTapeBackspace(), LogicalTapeFreeze(), LogicalTapeRead(), LogicalTapeRewind(), LogicalTapeSeek(), LogicalTapeSetCreate(), LogicalTapeTell(), LogicalTapeWrite(), LogStandbySnapshot(), lookup_collation_cache(), lookup_ts_config_cache(), lookup_ts_dictionary_cache(), lookup_ts_parser_cache(), lookup_type_cache(), LookupOpclassInfo(), LookupTypeName(), lowerstr_with_len(), LruDelete(), LruInsert(), ltsDumpBuffer(), ltsRewindFrozenIndirectBlock(), ltsRewindIndirectBlock(), LWLockAcquire(), LWLockRelease(), make_bounded_heap(), make_datum_param(), make_join_rel(), make_modifytable(), make_new_heap(), make_one_rel(), make_oper_cache_entry(), make_outerjoininfo(), make_pathkeys_for_sortclauses(), make_recursive_union(), make_restrictinfo(), make_restrictinfo_from_bitmapqual(), make_restrictinfo_internal(), make_result(), make_row_comparison_op(), make_ruledef(), make_setop(), make_subplan(), make_subplanTargetList(), make_trigrams(), make_tuple_from_result_row(), make_unique(), make_windowInputTargetList(), makeDependencyGraph(), makeObjectName(), makeSublist(), map_sql_identifier_to_xml_name(), MarkAsPrepared(), MarkAsPreparing(), MarkBufferDirty(), MarkBufferDirtyHint(), MarkLocalBufferDirty(), MarkPortalDone(), MarkPortalFailed(), MarkPostmasterChildActive(), MarkPostmasterChildInactive(), MarkPostmasterChildWalSender(), markRTEForSelectPriv(), markTargetListOrigin(), markVarForSelectPriv(), match_clauses_to_index(), match_unsorted_outer(), MatchNamedCall(), materializeQueryResult(), materializeResult(), mcelem_tsquery_selec(), mdcreate(), mdextend(), mdopen(), mdprefetch(), mdread(), mdsync(), mdtruncate(), mdwrite(), MemoryContextCreate(), MemoryContextDelete(), MergeAttributes(), MergeCheckConstraint(), mergejoinscansel(), mergeprereadone(), mergeruns(), mergeStates(), MergeWithExistingConstraint(), minimal_tuple_from_heap_tuple(), MJExamineQuals(), moveLeafs(), mul_var(), multixact_redo(), multixact_twophase_postcommit(), multixact_twophase_recover(), MultiXactIdCreate(), MultiXactIdGetUpdateXid(), MultiXactShmemInit(), NamespaceCreate(), newLOfd(), next_token(), NextCopyFrom(), NextCopyFromRawFields(), NextPredXact(), nextval_internal(), NISortDictionary(), nocache_index_getattr(), nocachegetattr(), numeric_transform(), numericvar_to_int8(), objectNamesToOids(), OffsetVarNodes_walker(), oid_hash(), oidvectorrecv(), OldSerXidAdd(), OldSerXidGetMinConflictCommitSeqNo(), OldSerXidPagePrecedesLogically(), OldSerXidSetActiveSerXmin(), OnConflict_CheckForSerializationFailure(), OpernameGetCandidates(), OwnLatch(), p_iseq(), p_iswhat(), packGraph(), PageCalcChecksum16(), PageIndexMultiDelete(), PageIndexTupleDelete(), PageInit(), parallel_restore(), ParallelBackupEnd(), ParallelBackupStart(), parse_analyze(), parse_analyze_varparams(), parse_ident_line(), parseCheckAggregates(), ParseComplexProjection(), ParseFractionalSecond(), ParseFuncOrColumn(), parseNameAndArgTypes(), parseRelOptions(), perform_base_backup(), PerformCursorOpen(), PersistHoldablePortal(), pfree(), pg_analyze_and_rewrite_params(), pg_any_to_server(), pg_client_encoding(), pg_client_to_server(), pg_encoding_dsplen(), pg_encoding_max_length(), pg_encoding_mblen(), pg_encoding_to_char(), pg_encoding_verifymb(), pg_get_client_encoding(), pg_get_client_encoding_name(), pg_get_functiondef(), pg_get_indexdef_worker(), pg_newlocale_from_collation(), pg_plan_query(), pg_re_throw(), pg_relation_filepath(), pg_server_to_any(), pg_server_to_client(), pg_start_backup_callback(), pg_stat_statements(), pg_timer_thread(), pg_timezone_abbrevs(), pg_verify_mbstr_len(), PGSemaphoreCreate(), PGSharedMemoryCreate(), PGSharedMemoryReAttach(), pgss_post_parse_analyze(), pgss_store(), pgstat_beshutdown_hook(), pgstat_bestart(), pgstat_initialize(), pgstat_read_current_status(), pgstat_report_activity(), pgstat_report_appname(), pgstat_report_stat(), pgstat_report_xact_timestamp(), pgwin32_ReserveSharedMemoryRegion(), pgwin32_select(), PinBuffer(), PinBuffer_Locked(), plainto_tsquery_byid(), plan_set_operations(), PlanCacheComputeResultDesc(), PlanCacheFuncCallback(), PlanCacheRelCallback(), plperl_return_next(), plpgsql_append_source_text(), plpgsql_destroy_econtext(), plpgsql_free_function_memory(), plpgsql_HashTableInit(), plpgsql_inline_handler(), plpgsql_ns_additem(), plpgsql_ns_pop(), plpgsql_param_fetch(), plpgsql_xact_cb(), PLy_abort_open_subtransactions(), PLy_cursor_plan(), PLy_cursor_query(), PLy_elog(), PLy_exec_function(), PLy_exec_trigger(), PLy_generate_spi_exceptions(), PLy_input_tuple_funcs(), PLy_output_record_funcs(), PLy_output_tuple_funcs(), PLy_procedure_argument_valid(), PLy_procedure_call(), PLy_procedure_create(), PLy_procedure_munge_source(), PLy_procedure_valid(), PLy_spi_prepare(), PLy_spi_subtransaction_abort(), PLy_traceback(), PLyGenericObject_ToComposite(), PLyMapping_ToComposite(), PLyObject_ToBool(), PLyObject_ToBytea(), PLyObject_ToDatum(), PLySequence_ToArray(), PLySequence_ToComposite(), PopActiveSnapshot(), PortalCreateHoldStore(), PortalRunMulti(), PortalRunSelect(), PortalStart(), postgresBeginForeignModify(), postgresGetForeignPaths(), postgresGetForeignPlan(), PostgresMain(), PostmasterMain(), PostmasterStateMachine(), PostPrepare_Locks(), PostPrepare_PredicateLocks(), postprocess_setop_tlist(), postquel_start(), postquel_sub_params(), pq_endtypsend(), pq_putbytes(), pq_putmessage_noblock(), PreCommit_CheckForSerializationFailure(), PreCommit_on_commit_actions(), predicate_classify(), predicate_implied_by_recurse(), predicate_refuted_by_recurse(), predicatelock_hash(), predicatelock_twophase_recover(), PredicateLockPageSplit(), PredicateLockPromotionThreshold(), PrefetchBuffer(), prefix_quals(), prefix_selectivity(), prepare_sort_from_pathkeys(), PrepareSortSupportFromOrderingOp(), PrepareToInvalidateCacheTuple(), PrepareTransaction(), PrepareTransactionBlock(), preprocess_groupclause(), preprocess_limit(), preprocess_minmax_aggregates(), preprocess_rowmarks(), PrescanPreparedTransactions(), print_expr(), print_function_arguments(), PrintBufferLeakWarning(), PrintCatCacheLeakWarning(), printtup_20(), printtup_internal_20(), printTypmod(), ProcArrayApplyRecoveryInfo(), ProcArrayApplyXidAssignment(), ProcArrayEndTransaction(), ProcArrayInstallImportedXmin(), ProcArrayRemove(), ProcedureCreate(), process_equivalence(), process_implied_equality(), process_ordered_aggregate_single(), process_owned_by(), process_startup_options(), process_sublinks_mutator(), process_subquery_nestloop_params(), ProcessGUCArray(), processIndirection(), ProcessInterrupts(), processPendingPage(), ProcessRecords(), processTypesSpec(), ProcessUtility(), ProcessUtilitySlow(), ProcKill(), proclock_hash(), ProcLockWakeup(), ProcSignalInit(), ProcSleep(), ProcWakeup(), pull_up_simple_subquery(), pull_up_simple_union_all(), pull_up_subqueries_recurse(), pull_varattnos_walker(), pullup_replace_vars_subquery(), push_old_value(), PushActiveSnapshot(), pushOperator(), puttuple_common(), qsortCompareItemPointers(), qual_is_pushdown_safe(), query_is_distinct_for(), query_planner(), query_tree_mutator(), query_tree_walker(), QueryRewrite(), quote_if_needed(), range_deserialize(), range_gist_class_split(), range_gist_double_sorting_split(), range_gist_picksplit(), range_gist_single_sorting_split(), range_serialize(), rangeTableEntry_used_walker(), RangeVarGetAndCheckCreationNamespace(), rank_up(), raw_expression_tree_walker(), raw_heap_insert(), rb_create(), RE_compile_and_cache(), read_seq_tuple(), ReadArrayStr(), ReadBuffer_common(), ReadBufferWithoutRelcache(), readMessageFromPipe(), ReadPageInternal(), readtup_datum(), reaper(), recheck_cast_function_args(), reconsider_full_join_clause(), reconsider_outer_join_clause(), recordDependencyOnCurrentExtension(), RecordKnownAssignedTransactionIds(), RecordNewMultiXact(), recordSharedDependencyOn(), RecordTransactionCommit(), RecoverPreparedTransactions(), RecoveryConflictInterrupt(), recurse_push_qual(), recurse_pushdown_safe(), recurse_set_operations(), reduce_outer_joins_pass2(), regexp_fixed_prefix(), register_dirty_segment(), register_unlink(), RegisterPredicateLockingXid(), RegisterTimeout(), regress_dist_ptpath(), reindex_relation(), relation_close(), relation_has_unique_index_for(), relation_open(), RelationBuildDesc(), RelationBuildLocalRelation(), RelationBuildRuleLock(), RelationBuildTupleDesc(), RelationCacheInitializePhase3(), RelationCacheInvalidate(), RelationClearRelation(), RelationDecrementReferenceCount(), RelationDestroyRelation(), RelationGetBufferForTuple(), RelationGetIndexExpressions(), RelationGetIndexList(), RelationGetIndexPredicate(), RelationGetOidIndex(), RelationInitIndexAccessInfo(), RelationInitLockInfo(), RelationMapFinishBootstrap(), RelationReloadIndexInfo(), RelationSetIndexList(), RelationSetNewRelfilenode(), ReleaseAndReadBuffer(), ReleaseBuffer(), ReleaseCachedPlan(), ReleaseCatCache(), ReleaseCatCacheList(), ReleaseCurrentSubTransaction(), ReleaseGenericPlan(), ReleaseLockIfHeld(), ReleaseLruFile(), ReleaseOneSerializableXact(), ReleasePostmasterChildSlot(), ReleasePredicateLocks(), ReleasePredXact(), ReleaseSavepoint(), relmap_redo(), relpathbackend(), RememberFsyncRequest(), remove_join_clause_from_rels(), remove_rel_from_query(), RemoveFromWaitQueue(), RemoveLocalLock(), RemoveProcFromArray(), RemoveRelations(), RemoveScratchTarget(), RemoveTargetIfNoLongerUsed(), RenameTypeInternal(), reorder_function_arguments(), repalloc(), replace_aggs_with_params_mutator(), replace_nestloop_params_mutator(), replace_outer_agg(), replace_outer_placeholdervar(), replace_outer_var(), replace_vars_in_jointree(), report_namespace_conflict(), RequestXLogStreaming(), ResetCatalogCache(), ResetLatch(), ResetPlanCache(), ResetUnloggedRelationsInDbspaceDir(), resolve_column_ref(), ResolveRecoveryConflictWithBufferPin(), ResolveRecoveryConflictWithVirtualXIDs(), ResourceOwnerDelete(), ResourceOwnerForgetLock(), ResourceOwnerNewParent(), ResourceOwnerReleaseInternal(), ResourceOwnerRememberBuffer(), ResourceOwnerRememberCatCacheListRef(), ResourceOwnerRememberCatCacheRef(), ResourceOwnerRememberFile(), ResourceOwnerRememberPlanCacheRef(), ResourceOwnerRememberRelationRef(), ResourceOwnerRememberSnapshot(), ResourceOwnerRememberTupleDesc(), restore_toc_entries_parallel(), RestoreArchive(), RestoreArchivedFile(), RestoreBackupBlockContents(), RestoreScratchTarget(), restriction_is_constant_false(), ReThrowError(), RevalidateCachedQuery(), rewrite_heap_dead_tuple(), rewrite_heap_tuple(), RewriteQuery(), rewriteRuleAction(), rewriteTargetView(), rewriteValuesRTE(), ri_Check_Pk_Match(), RI_FKey_check(), ri_GenerateQual(), ri_HashCompareOp(), ri_HashPreparedPlan(), ri_LoadConstraintInfo(), RollbackToSavepoint(), round_var(), row_is_in_frame(), RunFunctionExecuteHook(), RunNamespaceSearchHook(), RunObjectDropHook(), RunObjectPostAlterHook(), RunObjectPostCreateHook(), RWConflictExists(), SaveCachedPlan(), scalararraysel(), scanGetItem(), ScanKeyEntryInitialize(), ScanQueryForLocks(), scanstr(), SearchCatCacheList(), select_active_windows(), select_common_type(), select_loop(), select_outer_pathkeys_for_merge(), selectColorTrigrams(), selectSourceSchema(), SendCopyEnd(), SendRecoveryConflictWithBufferPin(), sepgsql_audit_log(), sepgsql_compute_avd(), sepgsql_compute_create(), sepgsql_fmgr_hook(), sepgsql_get_client_label(), sepgsql_object_access(), sepgsql_relation_setattr_extra(), seq_redo(), set_append_rel_pathlist(), set_append_rel_size(), set_base_rel_pathlists(), set_base_rel_sizes(), set_baserel_size_estimates(), set_cheapest(), set_cte_pathlist(), set_cte_size_estimates(), set_errdata_field(), set_foreign_size_estimates(), set_function_size_estimates(), set_join_column_names(), set_plan_references(), set_plan_refs(), set_rel_width(), set_relation_column_names(), set_subquery_pathlist(), set_subquery_size_estimates(), set_subqueryscan_references(), set_using_names(), set_values_size_estimates(), SetConstraintStateAddItem(), SetDatabaseEncoding(), SetDatabasePath(), SetForwardFsyncRequests(), setitimer(), SetMatViewToPopulated(), SetMultiXactIdLimit(), SetNewSxactGlobalXmin(), setop_fill_hash_table(), SetPossibleUnsafeConflict(), setRedirectionTuple(), SetReindexProcessing(), SetRemoteDestReceiverParams(), SetRWConflict(), SetSerializableTransactionSnapshot(), setTargetTable(), SetTempTablespaces(), SetTransactionIdLimit(), SetTransactionSnapshot(), SetTuplestoreDestReceiverParams(), setup_param_list(), SetupLockInTable(), SetupWorker(), SharedInvalBackendInit(), shiftList(), ShmemAlloc(), ShmemInitStruct(), SHMQueueDelete(), SHMQueueElemInit(), SHMQueueEmpty(), SHMQueueInit(), SHMQueueInsertAfter(), SHMQueueInsertBefore(), SHMQueueIsDetached(), SHMQueueNext(), SHMQueuePrev(), show_hash_info(), show_sort_info(), sigusr1_handler(), SimpleLruFlush(), SimpleLruInit(), SimpleLruReadPage(), SimpleLruZeroPage(), simplify_boolean_equality(), slist_delete(), SlruInternalWritePage(), smgr_redo(), smgrsetowner(), sort_bounded_heap(), sort_inner_and_outer(), 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(), SpGistGetBuffer(), SpGistInitBuffer(), SpGistPageAddNewItem(), spgLeafTest(), spgRedoAddLeaf(), spgRedoAddNode(), spgRedoCreateIndex(), spgRedoPickSplit(), spgRedoVacuumLeaf(), spgRedoVacuumRedirect(), spgSplitNodeAction(), spgWalk(), SPI_connect(), SPI_cursor_open_internal(), SPI_plan_get_cached_plan(), SPI_plan_get_plan_sources(), SPI_plan_is_valid(), SPI_pop_conditional(), SPI_push_conditional(), SPI_restore_connection(), SplitIdentifierString(), sql_fn_post_column_ref(), SS_process_ctes(), standard_ExecutorEnd(), standard_ExecutorFinish(), standard_ExecutorRun(), standard_ExecutorStart(), standard_join_search(), standard_planner(), standard_ProcessUtility(), standby_redo(), StandbyAcquireAccessExclusiveLock(), StandbyRecoverPreparedTransactions(), StandbyReleaseOldLocks(), StandbyTransactionIdIsPrepared(), StartBufferIO(), StartChildProcess(), StartReplication(), StartTransaction(), StartTransactionCommand(), StartupXLOG(), storeGettuple(), StoreIndexTuple(), storeRow(), StrategyGetBuffer(), StrategyInitialize(), string_agg_finalfn(), string_to_datum(), strip_quotes(), sub_abs(), subquery_is_pushdown_safe(), substitute_multiple_relids_walker(), SubTransGetParent(), SubTransGetTopmostTransaction(), SubTransSetParent(), swap_relation_files(), SyncRepQueueInsert(), SyncRepReleaseWaiters(), SyncRepWaitForLSN(), SyncRepWakeQueue(), SyncScanShmemInit(), SysCacheGetAttr(), systable_endscan_ordered(), systable_getnext_ordered(), systable_recheck_tuple(), TablespaceCreateDbspace(), 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_union(), TemporalTransform(), TerminateBufferIO(), text_format(), text_position_next(), TidListCreate(), tlist_matches_tupdesc(), to_tsquery_byid(), toast_compress_datum(), toast_delete(), toast_fetch_datum(), toast_fetch_datum_slice(), toast_flatten_tuple(), toast_flatten_tuple_attribute(), toast_insert_or_update(), toast_save_datum(), TopoSort(), TParserGet(), TransactionIdIsInProgress(), TransactionIdSetPageStatus(), TransactionIdSetStatusBit(), TransactionIdSetTreeStatus(), TransferPredicateLocksToNewTarget(), transformAExprOp(), transformAggregateCall(), transformAlterTableStmt(), transformArrayExpr(), transformArraySubscripts(), transformAssignedExpr(), transformAssignmentIndirection(), transformAssignmentSubscripts(), transformCaseExpr(), transformColumnDefinition(), transformColumnRef(), transformCreateStmt(), transformCurrentOfExpr(), transformExpr(), transformFkeyCheckAttrs(), transformFkeyGetPrimaryKey(), transformFrameOffset(), transformFromClauseItem(), transformIndexConstraint(), transformIndexConstraints(), transformIndirection(), transformInsertRow(), transformInsertStmt(), transformRangeFunction(), transformRangeSubselect(), transformRelOptions(), transformSetOperationStmt(), transformSetOperationTree(), transformSubLink(), transformTableLikeClause(), transformTopLevelStmt(), transformUpdateStmt(), transformValuesClause(), transformWindowFuncCall(), transformWithClause(), transformXmlExpr(), transientrel_startup(), translate_col_privs(), TriggerEnabled(), trivial_subqueryscan(), try_relation_open(), TryReuseForeignKey(), ts_setup_firstcall(), tsmatchsel(), tsqueryrecv(), tsvector_concat(), tsvectorin(), TupleHashTableMatch(), tuplesort_begin_cluster(), tuplesort_gettuple_common(), tuplesort_heap_insert(), tuplesort_markpos(), tuplesort_rescan(), tuplesort_restorepos(), tuplesort_set_bound(), tuplestore_copy_read_pointer(), tuplestore_gettuple(), tuplestore_puttuple_common(), tuplestore_rescan(), tuplestore_select_read_pointer(), tuplestore_trim(), TwoPhaseShmemInit(), TypeCacheRelCallback(), TypeCategory(), TypeNameListToString(), TypeShellMake(), UnGrantLock(), uniqueentry(), UnpinBuffer(), UnregisterSnapshotFromOwner(), untransformRelOptions(), update_frameheadpos(), update_frametailpos(), update_mergeclause_eclasses(), update_proconfig_value(), UpdateActiveSnapshotCommandId(), UpdateXmaxHintBits(), UtilityContainsQuery(), vac_open_indexes(), vac_truncate_clog(), vac_update_datfrozenxid(), vacuum(), vacuum_set_xid_limits(), vacuumLeafPage(), vacuumLeafRoot(), vacuumRedirectAndPlaceholder(), validArcLabel(), validate_index_heapscan(), ValidXLogPageHeader(), ValuesNext(), varbit_transform(), varchar_transform(), VirtualXactLock(), VirtualXactLockTableCleanup(), VirtualXactLockTableInsert(), visibilitymap_set(), WaitForCommands(), WaitForTerminatingWorkers(), WaitForWALToBecomeAvailable(), WaitLatchOrSocket(), walkStatEntryTree(), WalRcvDie(), WalRcvWaitForStartPosition(), WalReceiverMain(), WalSndKill(), WalSndSetState(), window_cume_dist(), window_percent_rank(), WinGetCurrentPosition(), WinGetFuncArgCurrent(), WinGetFuncArgInFrame(), WinGetFuncArgInPartition(), WinGetPartitionLocalMemory(), WinGetPartitionRowCount(), WinRowsArePeers(), WinSetMarkPosition(), WorkTableScanNext(), write_pipe_chunks(), WriteDataChunks(), writeListPage(), writeTimeLineHistory(), writetup_datum(), xact_redo(), xactGetCommittedInvalidationMessages(), XactLockTableWait(), XidCacheRemoveRunningXids(), XidIsConcurrent(), xlog_redo(), XLogFileClose(), XLogInsert(), XLogPageRead(), XLogReadBufferExtended(), XLogReadRecord(), XLogSaveBufferForHint(), XLogSend(), XLOGShmemInit(), XLOGShmemSize(), xlogVacuumPage(), XLogWalRcvSendHSFeedback(), XLogWrite(), and xmldata_root_element_start().

#define AssertArg (   condition  ) 
#define AssertMacro (   condition  )     ((void)true)

Definition at line 573 of file c.h.

#define AssertState (   condition  ) 
#define AssertVariableIsOfType (   varname,
  typename 
)
Value:
StaticAssertStmt(sizeof(varname) == sizeof(typename), \
    CppAsString(varname) " does not have type " CppAsString(typename))

Definition at line 671 of file c.h.

#define AssertVariableIsOfTypeMacro (   varname,
  typename 
)
Value:
((void) StaticAssertExpr(sizeof(varname) == sizeof(typename),       \
     CppAsString(varname) " does not have type " CppAsString(typename)))

Definition at line 674 of file c.h.

#define BoolIsValid (   boolean  )     ((boolean) == false || (boolean) == true)

Definition at line 475 of file c.h.

Referenced by init_params().

#define BUFFERALIGN (   LEN  )     TYPEALIGN(ALIGNOF_BUFFER, (LEN))

Definition at line 542 of file c.h.

Referenced by ShmemAlloc(), SimpleLruInit(), and SimpleLruShmemSize().

#define CppAsString (   identifier  )     "identifier"

Definition at line 142 of file c.h.

#define CppAsString2 (   x  )     CppAsString(x)

Definition at line 898 of file c.h.

#define CppConcat (   x,
  y 
)    _priv_CppIdentity(x)y

Definition at line 153 of file c.h.

#define dgettext (   d,
  x 
)    (x)

Definition at line 104 of file c.h.

Referenced by PLy_elog(), PLy_exception_set(), and PLy_output().

#define dngettext (   d,
  s,
  p,
  n 
)    ((n) == 1 ? (s) : (p))

Definition at line 106 of file c.h.

Referenced by PLy_exception_set_plural().

#define DOUBLEALIGN (   LEN  )     TYPEALIGN(ALIGNOF_DOUBLE, (LEN))

Definition at line 539 of file c.h.

#define DOUBLEALIGN_DOWN (   LEN  )     TYPEALIGN_DOWN(ALIGNOF_DOUBLE, (LEN))

Definition at line 550 of file c.h.

#define dummyret   char

Definition at line 163 of file c.h.

#define endof (   array  )     (&(array)[lengthof(array)])

Definition at line 520 of file c.h.

#define ESCAPE_STRING_SYNTAX   'E'

Definition at line 465 of file c.h.

Referenced by appendStringLiteralConn(), deparseStringLiteral(), and serialize_deflist().

#define false   ((bool) 0)

Definition at line 194 of file c.h.

#define FALSE   0

Definition at line 205 of file c.h.

Referenced by _ltree_compress(), addItemPointersToLeafTuple(), addtype(), array_to_datum_internal(), ATExecDropNotNull(), BaseBackup(), BeginStrongLockAcquire(), box_in(), buildFreshLeafTuple(), collectMatchesForHeapRow(), cube_contains_v0(), cube_is_point(), cube_overlap_v0(), DecodeTimeOnly(), entryGetItem(), exec_simple_check_node(), ExecEvalDistinct(), findDontCares(), g_cube_decompress(), g_int_compress(), g_int_decompress(), g_intbig_compress(), gbt_bit_consistent(), gbt_inet_compress(), gbt_intv_compress(), gbt_intv_decompress(), gbt_num_compress(), gbt_timetz_compress(), gbt_tstz_compress(), gbt_var_compress(), gbt_var_decompress(), ghstore_compress(), ginCombineData(), ginEntryInsert(), ginFindLeafPage(), ginInsertValue(), ginRedoInsert(), ginTraverseLock(), ginVacuumPostingTree(), gist_box_consistent(), gist_circle_compress(), gist_circle_consistent(), gist_point_compress(), gist_poly_compress(), gist_poly_consistent(), gistchoose(), gistDeCompressAtt(), gistFormTuple(), gistindex_keytest(), gistMakeUnionItVec(), gistMakeUnionKey(), gistpenalty(), gistSplitByKey(), gtrgm_compress(), gtsquery_compress(), gtsvector_compress(), gtsvector_decompress(), InitLatch(), InitSharedLatch(), inleap(), inzone(), keyGetItem(), lseg_out(), ltree_compress(), ltree_decompress(), NUM_numpart_from_char(), NUM_numpart_to_char(), NUM_processor(), outzone(), path_decode(), path_encode(), pg_dlclose(), pg_load_tz(), pg_signal_thread(), pg_timer_thread(), pg_tzset(), pg_usleep(), PGSemaphoreLock(), PGSharedMemoryIsInUse(), pgwin32_select(), pgwin32_signal_initialize(), pgwin32_waitforsinglesocket(), pipe_read_line(), placeOne(), plperl_func_handler(), plperl_trusted_init(), plperl_untrusted_init(), poly_in(), PQfireResultCreateEvents(), pqFunctionCall2(), pqFunctionCall3(), pqGetCopyData2(), pqGetCopyData3(), pqGetline2(), pqGetline3(), PQgetResult(), pqParseInput2(), PQsetvalue(), removeDontCares(), rulesub(), scanGetItem(), select_perl_context(), set_ps_display(), setitimer(), stringzone(), supportSecondarySplit(), tzload(), tzparse(), wait_for_tests(), WaitLatchOrSocket(), and xlogVacuumPage().

#define FirstCommandId   ((CommandId) 0)
#define gettext (   x  )     (x)

Definition at line 103 of file c.h.

Referenced by err_gettext(), and exec_command().

#define gettext_noop (   x  )     (x)
#define HIGHBIT   (0x80)

Definition at line 859 of file c.h.

Referenced by heap_fill_tuple(), iso8859_1_to_utf8(), and mic2latin_with_table().

#define INT64CONST (   x  )     ((int64) x)
#define INTALIGN (   LEN  )     TYPEALIGN(ALIGNOF_INT, (LEN))

Definition at line 537 of file c.h.

Referenced by gbt_bit_xfrm(), gbt_var_key_copy(), gbt_var_key_readable(), and gbt_var_node_truncate().

#define INTALIGN_DOWN (   LEN  )     TYPEALIGN_DOWN(ALIGNOF_INT, (LEN))

Definition at line 548 of file c.h.

#define InvalidSubTransactionId   ((SubTransactionId) 0)
#define IS_HIGHBIT_SET (   ch  )     ((unsigned char)(ch) & HIGHBIT)
#define lengthof (   array  )     (sizeof (array) / sizeof ((array)[0]))
#define LONG_ALIGN_MASK   (sizeof(long) - 1)

Definition at line 733 of file c.h.

#define LONGALIGN (   LEN  )     TYPEALIGN(ALIGNOF_LONG, (LEN))

Definition at line 538 of file c.h.

#define LONGALIGN_DOWN (   LEN  )     TYPEALIGN_DOWN(ALIGNOF_LONG, (LEN))

Definition at line 549 of file c.h.

#define Max (   x,
  y 
)    ((x) > (y) ? (x) : (y))

Definition at line 688 of file c.h.

Referenced by _bt_readpage(), add_abs(), add_var(), allocate_recordbuf(), appendContextKeyword(), applyLockingClause(), array_set_slice(), ATRewriteTable(), autovac_balance_cost(), bitsubstring(), box_intersect(), box_penalty(), bytea_substring(), calc_hist_selectivity_scalar(), CheckArchiveTimeout(), CLOGShmemBuffers(), compute_array_stats(), compute_semi_anti_join_factors(), compute_tsvector_stats(), cost_recursive_union(), cube_cmp_v0(), cube_contains_v0(), cube_inter(), cube_overlap_v0(), cube_union_v0(), cube_ur_coord(), distance_1D(), div_var(), div_var_fast(), dopr(), entry_dealloc(), errstart(), fmtint(), fsm_rebuild_page(), fsm_set_avail(), FuncnameGetCandidates(), gbt_date_penalty(), gbt_time_penalty(), gbt_var_picksplit(), get_position(), get_sock_dir(), GetLocalBufferStorage(), GinFormTuple(), ginNewScanKey(), gist_box_picksplit(), gtsvectorout(), heap_page_prune_opt(), helpSQL(), index_pages_fetched(), inetand(), inetor(), inter_sb(), lazy_space_alloc(), log_var(), ltree_penalty(), numeric_exp(), numeric_ln(), numeric_round(), numeric_sqrt(), numeric_to_number(), numeric_trunc(), NumLWLocks(), path_inter(), pgstat_recv_tabstat(), pgstat_report_analyze(), power_var(), prefix_selectivity(), RE_compile_and_cache(), ReadPageInternal(), record_cmp(), record_eq(), rt_box_union(), s_lock(), save_state_data(), saveHistory(), select_div_scale(), SetConstraintStateAddItem(), show_trgm(), StartPrepare(), sub_abs(), sub_var(), tbm_create(), text_substring(), tsquery_opr_selec(), tuplesort_merge_order(), and update_frametailpos().

#define MAXALIGN (   LEN  )     TYPEALIGN(MAXIMUM_ALIGNOF, (LEN))

Definition at line 540 of file c.h.

Referenced by _bt_buildadd(), _bt_checkpage(), _bt_checksplitloc(), _bt_findinsertloc(), _bt_findsplitloc(), _bt_insertonpg(), _bt_restore_page(), _bt_saveitem(), _bt_split(), _hash_checkpage(), _hash_doinsert(), _hash_metapinit(), _hash_splitbucket(), _hash_squeezebucket(), AllocSetAlloc(), AllocSetContextCreate(), AllocSetRealloc(), AutoVacuumShmemInit(), AutoVacuumShmemSize(), btree_xlog_split(), choose_hashed_distinct(), choose_hashed_grouping(), choose_hashed_setop(), choose_nelem_alloc(), compact_palloc0(), count_agg_clauses_walker(), CreateCheckPoint(), CreateTemplateTupleDesc(), dataSplitPage(), doPickSplit(), element_alloc(), entryIsEnoughSpace(), entrySplitPage(), estimate_size(), ExecChooseHashTableSize(), FinishPreparedTransaction(), gbt_tstz_consistent(), gbt_tstz_distance(), GetMemoryChunkContext(), GetMemoryChunkSpace(), GinFormInteriorTuple(), GinFormTuple(), ginRedoSplit(), ginRedoVacuumPage(), GinShortenTuple(), gistcheckpage(), gistGetItupFromPage(), gistInitBuffering(), gistPlaceItupToPage(), gistPushItupToNodeBuffer(), gtrgm_consistent(), gtrgm_distance(), gtrgm_penalty(), hash_agg_entry_size(), hash_estimate_size(), heap_form_minimal_tuple(), heap_form_tuple(), heap_multi_insert(), heap_page_items(), heap_update(), index_form_tuple(), InitShmemAllocation(), lca_inner(), lquery_in(), ltree_in(), makeSublist(), MemoryContextContains(), moveLeafs(), needs_toast_table(), PageAddItem(), PageIndexMultiDelete(), PageIndexTupleDelete(), PageInit(), PageIsVerified(), PageRepairFragmentation(), pfree(), PGSharedMemoryCreate(), pgss_memsize(), pgstat_hash_page(), PrescanPreparedTransactions(), ProcessRecords(), range_serialize(), raw_heap_insert(), ReadTwoPhaseFile(), RecoverPreparedTransactions(), relation_byte_size(), RelationGetBufferForTuple(), repalloc(), save_state_data(), ShmemAlloc(), SimpleLruInit(), SimpleLruShmemSize(), SpGistGetTypeSize(), SpGistInitPage(), SpGistPageAddNewItem(), spgRedoMoveLeafs(), spgRedoPickSplit(), StandbyRecoverPreparedTransactions(), StrategyShmemSize(), subplan_is_hashable(), tbm_create(), toast_flatten_tuple_attribute(), toast_insert_or_update(), TwoPhaseShmemInit(), TwoPhaseShmemSize(), XLogInsert(), XLogReadRecord(), and xlogVacuumPage().

#define MAXALIGN_DOWN (   LEN  )     TYPEALIGN_DOWN(MAXIMUM_ALIGNOF, (LEN))

Definition at line 551 of file c.h.

#define MAXDIM   6
#define memmove (   d,
  s,
  c 
)    bcopy(s, d, c)
#define MemSet (   start,
  val,
  len 
)
Value:
do \
    { \
        /* must be void* because we don't know if it is integer aligned yet */ \
        void   *_vstart = (void *) (start); \
        int     _val = (val); \
        Size    _len = (len); \
\
        if ((((intptr_t) _vstart) & LONG_ALIGN_MASK) == 0 && \
            (_len & LONG_ALIGN_MASK) == 0 && \
            _val == 0 && \
            _len <= MEMSET_LOOP_LIMIT && \
            /* \
             *  If MEMSET_LOOP_LIMIT == 0, optimizer should find \
             *  the whole "if" false at compile time. \
             */ \
            MEMSET_LOOP_LIMIT != 0) \
        { \
            long *_start = (long *) _vstart; \
            long *_stop = (long *) ((char *) _start + _len); \
            while (_start < _stop) \
                *_start++ = 0; \
        } \
        else \
            memset(_vstart, _val, _len); \
    } while (0)

Definition at line 745 of file c.h.

Referenced by _hash_alloc_buckets(), _hash_freeovflpage(), _hash_initbitmap(), _hash_metapinit(), _ltree_compress(), _ltree_picksplit(), _ltree_union(), aclexplode(), addArcs(), addKey(), AddRoleMems(), AdvanceXLInsertBuffer(), AllocateAttribute(), AllocateVfd(), AlterDatabase(), AlterDomainDefault(), AlterRole(), array_set(), array_set_slice(), assign_record_type_typmod(), ATAddForeignKeyConstraint(), autovacuum_do_vac_analyze(), BaseBackup(), bitshiftleft(), bitshiftright(), btcostestimate(), build_join_rel_hash(), build_paths_for_OR(), BuildEventTriggerCache(), BuildTupleHashTable(), calc_rank_cd(), CheckpointerShmemInit(), CheckRADIUSAuth(), CompactCheckpointerRequestQueue(), compile_plperl_function(), compile_pltcl_function(), compute_array_stats(), compute_function_hashkey(), compute_tsvector_stats(), connectDBStart(), conninfo_init(), ConstructTupleDescriptor(), cost_agg(), create_index_paths(), CreateCast(), CreateCheckPoint(), createdb(), CreateRestartPoint(), CreateRole(), CreateSharedBackendStatus(), CreateTableSpace(), DefineAttr(), DelRoleMems(), dir_realloc(), disable_all_timeouts(), do_autovacuum(), dopr(), errstart(), 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(), expandRecordVariable(), extract_query_dependencies(), fetch_fp_info(), find_oper_cache_entry(), find_rendezvous_variable(), fmgr(), format_elog_string(), g_intbig_picksplit(), g_intbig_union(), generate_series_timestamp(), generate_series_timestamptz(), get_btree_test_op(), get_join_index_paths(), GetConnection(), getCopyStart(), getParamDescriptions(), getRowDescriptions(), GetSerializableTransactionSnapshotInt(), ghstore_picksplit(), ghstore_union(), ginContinueSplit(), gistcostestimate(), grouping_planner(), gtrgm_picksplit(), gtrgm_union(), gtsvector_picksplit(), gtsvector_union(), hash_create(), hashcostestimate(), hdefault(), heap_get_root_tuples(), heap_xlog_insert(), heap_xlog_multi_insert(), heap_xlog_update(), hstore_from_record(), hstore_populate_record(), init_timezone_hashtable(), init_ts_config_cache(), InitCatalogCache(), InitFileAccess(), initGinState(), InitializeAttoptCache(), InitializeTableSpaceCache(), InitLocalBuffers(), InitLocks(), InitPredicateLocks(), InitProcGlobal(), InitQueryHashTable(), InitResultRelInfo(), InsertRule(), internal_load_library(), inv_read(), inv_truncate(), inv_write(), json_populate_record(), json_populate_recordset(), lo_initialize(), load_categories_hash(), load_relcache_init_file(), lock_twophase_recover(), LockAcquireExtended(), LockHasWaiters(), LockRelease(), lookup_ts_config_cache(), lookup_ts_dictionary_cache(), lookup_ts_parser_cache(), lookup_type_cache(), LookupOpclassInfo(), LookupTupleHashEntry(), ltree_union(), make_oper_cache_key(), makeEmptyPGconn(), makesign(), MarkAsPreparing(), mdinit(), mdread(), MemoryContextCreate(), movedb(), MultiXactShmemInit(), newLOfd(), NextCopyFrom(), NUM_processor(), PageInit(), parse_basebackup_options(), parse_hba_auth_opt(), pg_cursor(), pg_event_trigger_dropped_objects(), pg_lock_status(), pg_malloc0(), pg_prepared_statement(), pg_prepared_xact(), pg_stat_get_activity(), pg_stat_get_wal_senders(), pg_timezone_abbrevs(), pg_timezone_names(), pgstat_bestart(), pgstat_init_function_usage(), pgstat_report_stat(), pgstat_send_bgwriter(), pgstat_send_funcstats(), plperl_call_handler(), plperl_inline_handler(), plpgsql_inline_handler(), plpgsql_validator(), plpython_inline_handler(), PLy_malloc0(), PLyObject_ToComposite(), PMSignalShmemInit(), pqBuildStartupPacket2(), ProcSignalInit(), ProcSignalShmemInit(), reached_end_position(), ReadArrayStr(), ReadBuffer_common(), ReceiveTarFile(), record_C_func(), record_cmp(), record_eq(), record_in(), record_out(), record_recv(), record_send(), recordDependencyOnSingleRelExpr(), RelationCacheInitialize(), RememberFsyncRequest(), reorder_function_arguments(), RestoreBackupBlockContents(), ScanKeyEntryInitialize(), schedule_alarm(), seg_alloc(), sendFile(), sendFileWithContent(), set_ps_display(), SetDefaultACL(), setitimer(), SetupLockInTable(), SimpleLruZeroLSNs(), SimpleLruZeroPage(), SlruPhysicalReadPage(), smgropen(), spgcostestimate(), sql_exec(), StartupMultiXact(), StartupXLOG(), StreamServerPort(), tbm_create_pagetable(), tbm_get_pageentry(), tbm_mark_page_lossy(), TopoSort(), transformGraph(), TrimCLOG(), TupleDescInitEntry(), UpdateIndexRelation(), validateForeignKeyConstraint(), variable_paramref_hook(), visibilitymap_truncate(), WalRcvShmemInit(), WalSndShmemInit(), XLogInsert(), and XLogReaderAllocate().

#define MemSetAligned (   start,
  val,
  len 
)
Value:
do \
    { \
        long   *_start = (long *) (start); \
        int     _val = (val); \
        Size    _len = (len); \
\
        if ((_len & LONG_ALIGN_MASK) == 0 && \
            _val == 0 && \
            _len <= MEMSET_LOOP_LIMIT && \
            MEMSET_LOOP_LIMIT != 0) \
        { \
            long *_stop = (long *) ((char *) _start + _len); \
            while (_start < _stop) \
                *_start++ = 0; \
        } \
        else \
            memset(_start, _val, _len); \
    } while (0)

Definition at line 775 of file c.h.

Referenced by AllocSetDelete(), AllocSetReset(), MemoryContextAllocZero(), and palloc0().

#define MemSetLoop (   start,
  val,
  len 
)
Value:
do \
    { \
        long * _start = (long *) (start); \
        long * _stop = (long *) ((char *) _start + (Size) (len)); \
    \
        while (_start < _stop) \
            *_start++ = 0; \
    } while (0)

Definition at line 810 of file c.h.

Referenced by MemoryContextAllocZeroAligned().

#define MemSetTest (   val,
  len 
)
Value:
( ((len) & LONG_ALIGN_MASK) == 0 && \
    (len) <= MEMSET_LOOP_LIMIT && \
    MEMSET_LOOP_LIMIT != 0 && \
    (val) == 0 )

Definition at line 804 of file c.h.

#define Min (   x,
  y 
)    ((x) < (y) ? (x) : (y))

Definition at line 694 of file c.h.

Referenced by _bt_readpage(), acquire_inherited_sample_rows(), afterTriggerAddEvent(), AppendJumble(), array_cmp(), array_set_slice(), AtSubCommit_childXids(), autovac_balance_cost(), AutoVacLauncherMain(), bit(), bit_cmp(), bitfromint4(), bitfromint8(), bitsubstring(), bms_del_members(), bms_difference(), bms_int_members(), bms_is_subset(), bms_nonempty_difference(), bms_overlap(), bms_subset_compare(), box_intersect(), box_penalty(), buildFreshLeafTuple(), buildSubPlanHash(), BuildTupleHashTable(), byteacmp(), byteage(), byteagt(), byteale(), bytealt(), check_agg_arguments(), CheckpointerMain(), cliplen(), CLOGShmemBuffers(), compute_array_stats(), compute_tsvector_stats(), convert_bytea_to_scalar(), cost_bitmap_or_node(), create_unique_plan(), cube_cmp_v0(), cube_contains_v0(), cube_inter(), cube_ll_coord(), cube_overlap_v0(), cube_union_v0(), distance_1D(), div_var_fast(), doPickSplit(), dostr(), entry_dealloc(), eqjoinsel_semi(), estimate_path_cost_size(), ExecChooseHashTableSize(), ExecHashIncreaseNumBatches(), find_my_exec(), g_box_consider_split(), gbt_var_node_cp_len(), gbt_var_node_truncate(), gen_db_file_maps(), generate_nonunion_plan(), generate_normalized_query(), generate_recursion_plan(), geqo_set_seed(), get_position(), GetAccessStrategy(), GetLocalBufferStorage(), gincostestimate(), GinFormTuple(), gist_box_picksplit(), gist_tqcmp(), grouping_planner(), heap_deform_tuple(), HeapSatisfiesHOTandKeyUpdate(), hstore_cmp(), InitializeGUCOptionsFromEnvironment(), inittapes(), inner_int_inter(), inter_sb(), internal_bpchar_pattern_compare(), internal_text_pattern_compare(), lazy_space_alloc(), lca_inner(), leftmostLoc(), levenshtein_internal(), log_var(), lseg_dt(), ltree_compare(), make_union_unique(), mcelem_array_contain_overlap_selec(), mcelem_array_contained_selec(), network_cmp_internal(), numeric_exp(), numeric_ln(), numeric_round(), numeric_sqrt(), numeric_trunc(), path_inter(), perform_base_backup(), pg_qsort(), pgstat_get_crashed_backend_activity(), power_var(), pqSendSome(), preprocess_limit(), pretty_format_node_dump(), qsort_arg(), range_gist_consider_split(), relation_needs_vacanalyze(), report_invalid_encoding(), report_untranslatable_char(), restore(), rt_box_union(), s_lock(), saveHistory(), select_div_scale(), sendFile(), set_max_safe_fds(), SIInsertDataEntries(), slot_getallattrs(), slot_getsomeattrs(), spg_text_inner_consistent(), spg_text_leaf_consistent(), spg_text_picksplit(), spgdoinsert(), SpGistGetBuffer(), string_hash(), tarCreateHeader(), tbm_create(), tbm_lossify(), text_substring(), toast_save_datum(), tsCompareString(), tsquery_opr_selec(), tuplestore_trim(), vacuum_set_xid_limits(), validate_pkattnums(), varbit_in(), varstr_cmp(), and XLogReadRecord().

#define NameStr (   name  )     ((name).data)

Definition at line 454 of file c.h.

Referenced by aclitemout(), AddEnumLabel(), AddRelationNewConstraints(), AlterDomainAddConstraint(), AlterDomainDefault(), AlterDomainDropConstraint(), AlterDomainNotNull(), AlterDomainValidateConstraint(), AlterEventTriggerOwner_internal(), AlterExtensionNamespace(), AlterForeignDataWrapperOwner_internal(), AlterForeignServerOwner_internal(), AlterObjectNamespace_internal(), AlterObjectOwner_internal(), AlterObjectRename_internal(), AlterRelationNamespaceInternal(), AlterSchemaOwner_internal(), AlterTypeNamespaceInternal(), assignOperTypes(), ATExecAddOf(), ATExecChangeOwner(), ATExecDropConstraint(), ATExecDropInherit(), ATExecValidateConstraint(), ATRewriteTable(), AttrDefaultFetch(), BeginCopy(), boot_openrel(), bpchar_name(), btnamecmp(), btnamefastcmp(), build_column_default(), build_datatype(), build_row_from_class(), BuildEventTriggerCache(), buildRelationAliases(), check_selective_binary_conversion(), check_TSCurrentConfig(), CheckAttributeNamesTypes(), CheckAttributeType(), CheckConstraintFetch(), checkInsertTargets(), CheckMyDatabase(), checkRuleResultList(), checkViewTupleDesc(), CollationIsVisible(), compile_plperl_function(), compile_pltcl_function(), composite_to_json(), compute_function_hashkey(), ComputeIndexAttrs(), ConstructTupleDescriptor(), conversion_error_callback(), ConversionIsVisible(), convert_string_datum(), convert_tuples_by_name(), CopyTo(), CreateFunction(), currtid_for_view(), DefineAttr(), DefineCollation(), DefineOpClass(), deparseAnalyzeSql(), deparseFuncExpr(), deparseOperatorName(), do_autovacuum(), do_compile(), EnableDisableTrigger(), enum_out(), enum_send(), equalTupleDescs(), errdatatype(), errtablecol(), EventTriggerSQLDropAddObject(), exec_object_restorecon(), ExecConstraints(), ExecGrant_Attribute(), ExecGrant_Database(), ExecGrant_Fdw(), ExecGrant_ForeignServer(), ExecGrant_Function(), ExecGrant_Language(), ExecGrant_Namespace(), ExecGrant_Relation(), ExecGrant_Tablespace(), ExecGrant_Type(), ExecuteDoStmt(), expand_targetlist(), ExpandRowReference(), expandTupleDesc(), fetch_fp_info(), find_composite_type_dependencies(), fmgr_sql_validator(), format_operator_internal(), format_procedure_internal(), format_type_internal(), FunctionIsVisible(), generate_collation_name(), generate_function_name(), generate_operator_name(), generate_relation_name(), generateClonedIndexStmt(), get_am_name(), get_attname(), get_collation(), get_collation_name(), get_constraint_name(), get_database_list(), get_database_name(), get_db_info(), get_domain_constraint_oid(), get_extension_name(), get_file_fdw_attribute_options(), get_func_name(), get_name_for_var_field(), get_namespace_name(), get_opclass(), get_opclass_name(), get_opname(), get_rel_name(), get_relation_constraint_oid(), get_rte_attribute_type(), get_sql_delete(), get_sql_insert(), get_sql_update(), get_tablespace_name(), get_target_list(), get_tuple_of_interest(), GetDomainConstraints(), GetFdwRoutineByRelId(), GetForeignDataWrapper(), GetForeignServer(), getObjectDescription(), getObjectIdentity(), getOpFamilyDescription(), getOpFamilyIdentity(), getRelationDescription(), getRelationIdentity(), gettype(), GetUserNameFromId(), 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(), hstore_from_record(), hstore_populate_record(), index_check_primary_key(), init_sql_fcache(), InitPostgres(), inline_function(), inline_set_returning_function(), internal_get_result_type(), intorel_startup(), json_populate_record(), length_in_encoding(), 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(), namecpy(), nameeq(), namege(), namegt(), nameicregexeq(), nameicregexne(), namein(), namele(), namelike(), namelt(), namene(), namenlike(), nameout(), nameregexeq(), nameregexne(), namesend(), namestrcmp(), namestrcpy(), NextCopyFrom(), OpClassCacheLookup(), OpclassIsVisible(), OperatorIsVisible(), OpFamilyCacheLookup(), OpfamilyIsVisible(), ParseComplexProjection(), PG_char_to_encoding(), pg_convert(), pg_database_size_name(), pg_extension_update_paths(), pg_get_constraintdef_worker(), pg_get_functiondef(), pg_get_indexdef_worker(), pg_get_serial_sequence(), 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_newlocale_from_collation(), pg_tablespace_size_name(), plperl_hash_from_tuple(), pltcl_build_tuple_argument(), pltcl_set_tuple_values(), pltcl_trigger_handler(), PLy_procedure_create(), PLy_result_colnames(), PLyDict_FromTuple(), PLyGenericObject_ToComposite(), PLyMapping_ToComposite(), populate_recordset_object_end(), prepare_sql_fn_parse_info(), printatt(), recomputeNamespacePath(), regclassout(), regconfigout(), regdictionaryout(), regoperout(), regprocout(), regtypeout(), relation_needs_vacanalyze(), RelationIsVisible(), renameatt_check(), resolve_polymorphic_tupdesc(), rewriteTargetListIU(), ri_add_cast_to(), RI_FKey_check(), ri_GenerateQual(), ri_GenerateQualCollation(), RI_Initial_Check(), ri_ReportViolation(), schema_to_xml(), schema_to_xml_and_xmlschema(), schema_to_xmlschema(), 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(), SPI_fname(), SPI_gettype(), stringTypeDatum(), swap_relation_files(), SystemAttributeByName(), text_name(), to_ascii_encname(), transformFkeyGetPrimaryKey(), transformIndexConstraint(), transformOfType(), transformTableLikeClause(), triggered_change_notification(), TSConfigIsVisible(), TSDictionaryIsVisible(), TSParserIsVisible(), TSTemplateIsVisible(), TupleDescInitEntry(), TypeIsVisible(), typeTypeName(), validateCheckConstraint(), validateDomainConstraint(), and verify_dictoptions().

#define ngettext (   s,
  p,
  n 
)    ((n) == 1 ? (s) : (p))
#define NON_EXEC_STATIC   static

Definition at line 1015 of file c.h.

#define NULL   ((void *) 0)

Definition at line 213 of file c.h.

Referenced by _allocAH(), _ArchiveEntry(), _bt_buildadd(), _bt_check_unique(), _bt_checkkeys(), _bt_doinsert(), _bt_first(), _bt_freestack(), _bt_getroot(), _bt_getrootheight(), _bt_insert_parent(), _bt_load(), _bt_pagedel(), _bt_preprocess_array_keys(), _bt_preprocess_keys(), _bt_readpage(), _bt_uppershutdown(), _check_database_version(), _Clone(), _CloseArchive(), _connectDB(), _equalList(), _fmt(), _h_indexbuild(), _hash_dropscan(), _hash_getinitbuf(), _hash_getnewbuf(), _hash_splitbucket(), _hash_step(), _LoadBlobs(), _lt_q_regex(), _ltq_regex(), _ltree_isparent(), _ltree_risparent(), _ltxtq_exec(), _make_compiler_happy(), _mdfd_getseg(), _metaphone(), _outNode(), _outPathInfo(), _outToken(), _PG_init(), _PrintExtraToc(), _printTocEntry(), _readBitmapset(), _ReadExtraToc(), _reconnectToDB(), _ReopenArchive(), _skipData(), _SPI_checktuples(), _SPI_execute_plan(), _SPI_make_plan_non_temp(), _SPI_pquery(), _SPI_prepare_plan(), _StartBlob(), _StartBlobs(), _StartData(), _tarGetHeader(), _tarPositionTo(), _tarWriteHeader(), _tocEntryRequired(), AbortOutOfAnyTransaction(), AbortStrongLockAcquire(), AbortTransaction(), abstime2tm(), abstime_date(), abstime_timestamp(), accumArrayResult(), aclequal(), aclitemsort(), aclmask(), aclmask_direct(), aclmembers(), aclmerge(), acquire_inherited_sample_rows(), AcquireExecutorLocks(), acquireLocksOnSubLinks(), AcquireRewriteLocks(), add_abs(), add_base_rels_to_query(), add_dummy_return(), add_guc_variable(), add_include_path(), add_parameter_name(), add_path(), add_placeholder_variable(), add_preprocessor_define(), add_stringlist_item(), add_to_flat_tlist(), add_vars_to_targetlist(), AddEnumLabel(), AddInvalidationMessage(), AddInvertedQual(), addItemPointersToLeafTuple(), additional_numeric_locale_len(), addLeafTuple(), AddNewRelationType(), addNorm(), AddQual(), addRangeTableEntry(), addRangeTableEntryForCTE(), addRangeTableEntryForFunction(), addRangeTableEntryForJoin(), addRangeTableEntryForRelation(), addRangeTableEntryForSubquery(), addRangeTableEntryForValues(), AddRelationNewConstraints(), addRTEtoQuery(), addTargetToGroupList(), addTargetToSortList(), AddToDataDirLockFile(), addToResult(), adjust_appendrel_attrs_mutator(), adjust_data_dir(), adjust_inherited_tlist(), adjust_rowcompare_for_index(), adjust_view_column_set(), advance_aggregates(), advance_transition_function(), advance_windowaggregate(), afterTriggerAddEvent(), AfterTriggerBeginQuery(), AfterTriggerBeginSubXact(), AfterTriggerBeginXact(), AfterTriggerEndQuery(), AfterTriggerEndSubXact(), AfterTriggerExecute(), AfterTriggerFireDeferred(), afterTriggerFreeEventList(), afterTriggerInvokeEvents(), afterTriggerMarkEvents(), AfterTriggerPendingOnRel(), afterTriggerRestoreEventList(), AfterTriggerSaveEvent(), AfterTriggerSetState(), agg_retrieve_direct(), agg_retrieve_hash_table(), AggregateCreate(), ahlog(), ahprintf(), alloc_var(), allocarc(), AllocateDir(), AllocateFile(), AllocateVfd(), AllocSetAlloc(), AllocSetContextCreate(), AllocSetDelete(), AllocSetFree(), AllocSetRealloc(), AllocSetReset(), AllocSetStats(), AlterDomainAddConstraint(), AlterDomainDefault(), AlterDomainDropConstraint(), AlterDomainNotNull(), AlterDomainValidateConstraint(), AlterEnum(), AlterForeignDataWrapper(), AlterForeignServer(), AlterFunction(), AlterObjectOwner_internal(), AlterOpFamilyAdd(), AlterRole(), AlterRoleSet(), AlterSequence(), AlterSetting(), AlterTableNamespace(), AlterTableNamespaceInternal(), AlterTableSpaceOptions(), AlterTypeNamespace(), AlterTypeOwner(), AlterUserMapping(), analyze(), analyze_rel(), analyze_requires_snapshot(), analyzeCTE(), and_clause(), appendBinaryStringInfo(), appendCSVLiteral(), AppendInvalidationMessageList(), appendStringInfoVA(), appendStringLiteralConn(), appendStringLiteralDQ(), applyLockingClause(), applyRemoteGucs(), ApplyRetrieveRule(), ArchiveEntry(), archprintf(), array_agg_finalfn(), array_agg_transfn(), array_cmp(), array_contain_compare(), array_eq(), array_fill(), array_fill_internal(), array_get_isnull(), array_in(), array_out(), array_push(), array_recv(), array_replace_internal(), array_send(), array_to_datum_internal(), array_to_text(), array_to_text_internal(), arrayexpr_next_fn(), ArrayGetIntegerTypmods(), assign_backendlist_entry(), assign_collations_walker(), assign_query_collations_walker(), assign_record_type_typmod(), assign_temp_tablespaces(), assign_to(), assignOperTypes(), assignProcTypes(), AssignTransactionId(), assignVariables(), associate(), AsyncExistsPendingNotify(), asyncQueueAddEntries(), AsyncShmemInit(), AtAbort_Memory(), AtAbort_Portals(), ATAddCheckConstraint(), ATAddForeignKeyConstraint(), AtCleanup_Memory(), AtCleanup_Portals(), ATColumnChangeRequiresRewrite(), AtCommit_Memory(), AtEOSubXact_Inval(), AtEOSubXact_LargeObject(), AtEOSubXact_on_commit_actions(), AtEOSubXact_PgStat(), AtEOSubXact_RelationCache(), AtEOXact_GUC(), AtEOXact_Inval(), AtEOXact_LargeObject(), AtEOXact_on_commit_actions(), AtEOXact_PgStat(), AtEOXact_RelationCache(), AtEOXact_SMgr(), AtEOXact_Snapshot(), ATExecAddColumn(), ATExecAddIndexConstraint(), ATExecAddInherit(), ATExecAddOf(), ATExecAlterColumnGenericOptions(), ATExecAlterColumnType(), ATExecCmd(), ATExecColumnDefault(), ATExecGenericOptions(), ATExecSetOptions(), ATExecSetRelOptions(), ATExecSetTableSpace(), ATExecValidateConstraint(), ATPrepAddOids(), ATPrepAlterColumnType(), AtPrepare_Locks(), AtPrepare_PgStat(), AtPrepare_PredicateLocks(), ATRewriteTable(), ATRewriteTables(), ATSimpleRecursion(), AtStart_Inval(), AtStart_Memory(), AtStart_ResourceOwner(), AtSubAbort_childXids(), AtSubAbort_Memory(), AtSubAbort_Portals(), AtSubCleanup_Memory(), AtSubCleanup_Portals(), AtSubCommit_childXids(), AtSubCommit_Memory(), AtSubCommit_Portals(), AtSubStart_Inval(), AtSubStart_Memory(), AtSubStart_ResourceOwner(), AttrDefaultFetch(), attribute_used_walker(), autoinc(), autovac_balance_cost(), AutoVacLauncherMain(), AutoVacWorkerMain(), AuxiliaryProcessMain(), BackendStartup(), BackgroundWorkerInitializeConnection(), BackgroundWriterMain(), BaseBackup(), BeginCopy(), BeginCopyFrom(), BeginCopyTo(), BeginStrongLockAcquire(), big5_to_utf8(), binary_decode(), binary_encode(), binary_upgrade_extension_member(), bitgetpage(), BitmapHeapNext(), bms_add_member(), bms_add_members(), bms_copy(), bms_del_member(), bms_del_members(), bms_difference(), bms_equal(), bms_first_member(), bms_hash_value(), bms_int_members(), bms_intersect(), bms_is_empty(), bms_is_member(), bms_is_subset(), bms_join(), bms_membership(), bms_nonempty_difference(), bms_num_members(), bms_overlap(), bms_singleton_member(), bms_subset_compare(), bms_union(), booltestsel(), boot_get_type_io_data(), boot_openrel(), BootstrapModeMain(), BootstrapToastTable(), BootStrapXLOG(), BSD44_derived_dlerror(), BSD44_derived_dlopen(), BSD44_derived_dlsym(), bt_metap(), bt_page_items(), bt_page_stats(), btbuildCallback(), btbulkdelete(), btcostestimate(), btendscan(), btgettuple(), btree_predicate_proof(), btree_xlog_cleanup(), BTreeShmemInit(), btrescan(), btvacuumcleanup(), btvacuumpage(), btvacuumscan(), BufferAlloc(), BufferSync(), build_column_default(), build_function_result_tupdesc_d(), build_function_result_tupdesc_t(), build_implied_join_equality(), build_index_pathkeys(), build_index_tlist(), build_minmax_path(), build_pgstattuple_type(), build_physical_tlist(), build_relation_tlist(), build_simple_rel(), build_startup_packet(), build_subplan(), BuildArchiveDependencies(), buildDefaultACLCommands(), BuildDescForRelation(), BuildEventTriggerCache(), buildFreshLeafTuple(), buildMatViewRefreshDependencies(), buildMergedJoinVar(), buildSubPlanHash(), BuildTupleFromCStrings(), bytea_string_agg_finalfn(), bytea_string_agg_transfn(), byword(), cache_locale_time(), cache_record_field_properties(), CachedPlanGetTargetList(), calc_arraycontsel(), calc_hist_selectivity(), calc_rangesel(), calculate_database_size(), calculate_tablespace_size(), calculateDigestFromBuffer(), caltdissect(), canonicalize_qual(), CatalogCacheIdInvalidate(), CatalogCacheInitializeCache(), CatalogIndexInsert(), CatCacheRemoveCList(), CatCacheRemoveCTup(), cbrdissect(), cclass(), ccondissect(), cdissect(), cfclose(), cfind(), cfindloop(), cfopen(), cfopen_read(), ChangeVarNodes_walker(), check_agg_arguments_walker(), check_authmethod_unspecified(), check_db_file_conflict(), check_ddl_tag(), check_exclusion_constraint(), check_for_isn_and_int8_passing_mismatch(), check_for_reg_data_type_usage(), check_foreign_key(), check_hostname(), check_ident_usermap(), check_index_is_clusterable(), check_loadable_libraries(), check_locale(), check_locale_messages(), check_locale_monetary(), check_locale_name(), check_locale_numeric(), check_locale_time(), check_network_callback(), check_object_ownership(), check_parameter_resolution_walker(), check_primary_key(), check_redundant_nullability_qual(), check_required_directory(), check_restricted_library_name(), check_session_authorization(), check_sql_fn_retval(), check_stack_depth(), check_timezone_abbreviations(), check_ungrouped_columns_walker(), check_usermap(), check_valid_extension_name(), check_valid_version_name(), CheckAffix(), CheckArchiveTimeout(), CheckAttributeNamesTypes(), CheckCompoundAffixes(), checkCond(), checkDataDir(), CheckDeadLock(), checkExprHasSubLink(), checkExprHasSubLink_walker(), CheckForSerializableConflictIn(), CheckForSerializableConflictOut(), CheckForStandbyTrigger(), CheckIndexCompatible(), CheckMyDatabase(), checkNameSpaceConflicts(), CheckpointerMain(), CheckProcSignal(), CheckRADIUSAuth(), CheckSelectLocking(), CheckTableForSerializableConflictIn(), CheckTargetForConflictsIn(), CheckValidResultRel(), checkWellFormedRecursionWalker(), choose_bitmap_and(), choose_custom_plan(), choose_hashed_distinct(), choose_hashed_setop(), ChooseIndexColumnNames(), ChooseIndexName(), ChoosePortalStrategy(), cidr_abbrev(), citerdissect(), clause_selectivity(), clauselist_selectivity(), clean_NOT_intree(), cleanst(), cleanup(), CleanupBackupHistory(), CleanUpLock(), CleanupPriorWALFiles(), CleanupTempFiles(), clearcvec(), ClearOldPredicateLocks(), cleartraverse(), ClientAuthentication(), clientDone(), CloneArchive(), cloneouts(), close_cur1(), close_lseg(), close_pl(), close_ps(), closePGconn(), closerel(), cluster(), cluster_all_databases(), cmpLexeme(), cmpLexemeInfo(), cmtreefree(), coerce_record_to_complex(), coerce_to_boolean(), coerce_to_specific_type(), coerce_type(), colNameToVar(), colorchain(), colorcomplement(), CommandEndInvalidationMessages(), CommentObject(), CommitTransaction(), CommitTransactionCommand(), compact(), compact_palloc0(), compare_path_costs_fuzzily(), compare_pathkeys(), compare_subnode(), compare_tlist_datatypes(), compare_values_of_enum(), comparetup_cluster(), compatible_oper(), compatible_oper_opid(), compile_plperl_function(), compile_pltcl_function(), compileTheLexeme(), compileTheSubstitute(), CompleteCachedPlan(), compute_array_stats(), compute_function_hashkey(), compute_index_stats(), compute_return_type(), compute_tsvector_stats(), ComputeIndexAttrs(), concat_internal(), connectby_text(), connectby_text_serial(), ConnectDatabase(), connectDatabase(), connectDBComplete(), connectDBStart(), connectFailureMessage(), connectOptions1(), connectOptions2(), connectToServer(), conninfo_add_defaults(), conninfo_array_parse(), conninfo_init(), conninfo_parse(), conninfo_storeval(), conninfo_uri_decode(), conninfo_uri_parse(), conninfo_uri_parse_options(), conninfo_uri_parse_params(), construct_array(), ConstructTupleDescriptor(), contain_agg_clause(), contain_agg_clause_walker(), contain_aggs_of_level_walker(), contain_leaky_functions(), contain_leaky_functions_walker(), contain_mutable_functions(), contain_mutable_functions_walker(), contain_nonstrict_functions(), contain_nonstrict_functions_walker(), contain_subplans(), contain_subplans_walker(), contain_var_clause(), contain_var_clause_walker(), contain_vars_of_level_walker(), contain_volatile_functions(), contain_volatile_functions_walker(), contain_windowfuncs(), contain_windowfuncs_walker(), ConversionCreate(), convert_ANY_sublink_to_join(), convert_EXISTS_sublink_to_join(), convert_EXISTS_to_ANY(), convert_prep_stmt_params(), convert_string_datum(), convert_testexpr_mutator(), convertOperatorReference(), ConvertTriggerToFK(), cookDefault(), copy_clog_xlog_xid(), copy_file(), copy_heap_data(), copy_subdir_files(), CopyAndAddInvertedQual(), copyAndUpdateFile(), copydir(), CopyFrom(), CopyFromInsertBatch(), CopyGetAttnums(), copyins(), copyObject(), copyouts(), copyParamList(), CopyReadAttributesText(), CopyReadBinaryAttribute(), CopyTo(), CopyTriggerDesc(), cost_agg(), cost_qual_eval_walker(), cost_seqscan(), cost_tidscan(), count_agg_clauses_walker(), count_rowexpr_columns(), CountUnconnectedWorkers(), crashDumpHandler(), create_append_plan(), create_ctescan_plan(), create_cursor(), create_data_directory(), create_empty_extension(), create_indexscan_plan(), create_lateral_join_info(), create_merge_append_plan(), create_mergejoin_plan(), create_new_objects(), create_or_index_quals(), create_result_plan(), create_s(), create_script_for_cluster_analyze(), create_script_for_old_cluster_deletion(), create_singleton_array(), create_unique_path(), create_unique_plan(), CreateCachedPlan(), CreateCast(), CreateCheckPoint(), CreateCommandTag(), CreateComments(), CreateConstraintEntry(), createdb(), CreateDestReceiver(), CreateEndOfRecoveryRecord(), CreateEventTrigger(), CreateExtension(), CreateFKCheckTrigger(), CreateForeignDataWrapper(), createForeignKeyTriggers(), CreateForeignServer(), CreateForeignTable(), CreateLockFile(), CreateNewPortal(), CreateOneShotCachedPlan(), CreateOptsFile(), createPaddedCopyWithLength(), createPQExpBuffer(), CreateProceduralLanguage(), CreateRestartPoint(), CreateSchemaCommand(), CreateSharedComments(), CreateTrigger(), CreateUserMapping(), createViewAsClause(), crevcondissect(), creviterdissect(), crlf_process(), crosstab(), crosstab_hash(), crypt(), cube_contains_v0(), cube_overlap_v0(), cursor_to_xml(), cursor_to_xmlschema(), CustomizableCleanupPriorWALFiles(), database_to_xml(), database_to_xml_internal(), DataChecksumsEnabled(), datetime_to_char_body(), datum_to_json(), datumCopy(), db_dir_size(), dblink_connect(), dblink_connstr_check(), dblink_error_message(), dblink_get_connections(), dblink_get_notify(), dblink_get_pkey(), DCH_from_char(), DeadLockCheck(), deallocate_one(), debugStartup(), deccall2(), deccall3(), deccvasc(), deccvdbl(), deccvint(), deccvlong(), DecodeDate(), DecodeDateTime(), DecodeInterval(), DecodeNumberField(), DecodeSpecial(), DecodeTextArrayToCString(), DecodeTimeOnly(), DecodeUnits(), decompile_column_index_array(), deconstruct_jointree(), deconstruct_recurse(), DecrementParentLocks(), DecrementSize(), decrypt_internal(), decrypt_key(), dectoasc(), dectodbl(), dectoint(), dectolong(), default_threadlock(), defaultNoticeReceiver(), defGetBoolean(), defGetInt64(), defGetNumeric(), defGetQualifiedName(), defGetString(), defGetTypeLength(), defGetTypeName(), define_custom_variable(), DefineAggregate(), DefineAttr(), DefineCompositeType(), DefineDomain(), DefineEnum(), DefineIndex(), DefineOpClass(), DefineOperator(), DefineQueryRewrite(), DefineRange(), DefineRelation(), DefineType(), DefineView(), DefineViewRules(), deflist_to_tuplestore(), DeleteAllExportedSnapshotFiles(), DeleteAttributeTuples(), DeleteChildTargetLocks(), DeleteComments(), DeleteSharedComments(), DeleteSystemAttributeTuples(), DeleteVariable(), deleteWhatDependsOn(), deltraverse(), deparse_context_for(), deparseColumnRef(), deparseExpr(), deparseFuncExpr(), deparseParam(), deparseRelation(), deparseStringLiteral(), deparseVar(), describeAggregates(), describeFunctions(), describeOneTableDetails(), describeOperators(), describeRoles(), describeTableDetails(), describeTablespaces(), descriptor_variable(), destroy_tablespace_directories(), DestroyMetaString(), destroystate(), determineRecursiveColTypes(), digest_finish(), digest_reset(), dir_realloc(), DirectFunctionCall1Coll(), DirectFunctionCall2Coll(), DirectFunctionCall3Coll(), DirectFunctionCall4Coll(), DirectFunctionCall5Coll(), DirectFunctionCall6Coll(), DirectFunctionCall7Coll(), DirectFunctionCall8Coll(), DirectFunctionCall9Coll(), directory_is_empty(), disable_all_timeouts(), disable_timeout(), disable_timeouts(), discard_stack_value(), dispell_lexize(), dist_ps_internal(), distribute_qual_to_rels(), DllRegisterServer(), DllUnregisterServer(), do_analyze_rel(), do_autovacuum(), do_compile(), do_connect(), do_copy(), do_edit(), do_init(), do_lo_import(), do_numeric_accum(), do_numeric_avg_accum(), do_pg_start_backup(), do_pg_stop_backup(), do_promote(), do_pset(), do_setval(), do_shell(), do_start(), do_start_bgworker(), do_start_worker(), do_status(), do_to_timestamp(), do_watch(), doabbr(), doConnect(), DoCopy(), doCustom(), does_not_exist_skipping(), dolink(), domain_check(), domain_check_input(), domain_in(), domain_recv(), domainAddConstraint(), doPickSplit(), dopr_outch(), dostr(), DropAllPredicateLocksFromTable(), DropAllPreparedStatements(), DropBlobIfExists(), dropdb(), DropPreparedStatement(), DropRelFileNodesAllBuffers(), dropstate(), dsimple_lexize(), dsynonym_init(), dsynonym_lexize(), dummy_object_relabel(), dump_block(), dump_dynexecute(), dump_dynfors(), dump_execsql(), dump_exit(), dump_fetch(), dump_forc(), dump_fors(), dump_open(), dump_return(), dump_return_next(), dump_sqlda(), dump_variables(), dumpACL(), dumpAgg(), dumpAttrDef(), dumpBaseType(), dumpBlob(), dumpBlobs(), dumpCast(), dumpCollation(), dumpComment(), dumpCompositeType(), dumpCompositeTypeColComments(), dumpConstraint(), dumpConversion(), dumpCreateDB(), dumpDatabase(), dumpDatabaseConfig(), dumpDefaultACL(), dumpDomain(), dumpDumpableObject(), dumpEncoding(), dumpEnumType(), dumpEventTrigger(), dumpExtension(), dumpForeignDataWrapper(), dumpForeignServer(), dumpFunc(), dumpIndex(), dumpNamespace(), dumpnfa(), dumpOpclass(), dumpOpfamily(), dumpOpr(), dumpProcLang(), dumpRangeType(), dumpRule(), dumpSecLabel(), dumpSequence(), dumpSequenceData(), dumpShellType(), dumpStdStrings(), dumpTable(), dumpTableComment(), dumpTableData(), dumpTableData_copy(), dumpTableSchema(), dumpTableSecLabel(), dumpTablespaces(), dumpTimestamp(), dumpTrigger(), dumpTSConfig(), dumpTSDictionary(), dumpTSParser(), dumpTSTemplate(), dumpType(), dumpUserConfig(), dumpUserMappings(), duptraverse(), dxsyn_lexize(), each_object_field_end(), each_worker(), ean2ISBN(), ean2ISMN(), ean2ISSN(), ean2string(), eat(), ec_member_matches_foreign(), echo_hidden_hook(), echo_hook(), eclass(), ecpg_alloc(), ecpg_auto_prepare(), ecpg_check_PQresult(), ecpg_clear_auto_mem(), ecpg_deallocate_all_conn(), ecpg_execute(), ecpg_filter(), ecpg_find_prepared_statement(), ecpg_finish(), ecpg_get_connection(), ecpg_get_connection_nr(), ecpg_get_data(), ecpg_init(), ecpg_is_type_an_array(), ecpg_log(), ecpg_prepared(), ecpg_raise_backend(), ecpg_realloc(), ecpg_result_by_descriptor(), ecpg_set_compat_sqlda(), ecpg_set_native_sqlda(), ecpg_store_input(), ecpg_store_result(), ecpg_strdup(), ecpg_type_infocache_push(), ECPGallocate_desc(), ECPGconnect(), ECPGdeallocate_desc(), ECPGdescribe(), ECPGdo(), ECPGdo_descriptor(), ECPGdump_a_simple(), ECPGdump_a_struct(), ECPGdump_a_type(), ECPGfree_auto_mem(), ECPGget_desc(), ECPGget_PGconn(), ECPGget_sqlca(), ECPGget_var(), ECPGnoticeReceiver(), ECPGset_desc(), ECPGset_desc_header(), ECPGstatus(), ECPGtransactionStatus(), editFile(), element(), elog_finish(), emptyreachable(), enable_timeout(), EnablePortalManager(), encrypt_init(), encrypt_internal(), end_heap_rewrite(), EndCopy(), EndCopyTo(), EndDBCopyMode(), EndPrepare(), EndTransactionBlock(), enlargePQExpBuffer(), enough_time_passed(), entry_dealloc(), entry_reset(), entryGetItem(), enum_cmp_internal(), eqjoinsel_inner(), eqjoinsel_semi(), equal(), equalRuleLocks(), equalTupleDescs(), errfinish(), error(), errorMissingRTE(), errstart(), estimate_hash_bucketsize(), estimate_path_cost_size(), estimate_size(), euc_cn_to_utf8(), euc_jp_to_utf8(), euc_kr_to_utf8(), euc_tw_to_utf8(), eval_const_expressions_mutator(), eval_windowfunction(), EvalPlanQual(), EvalPlanQualBegin(), EvalPlanQualEnd(), EvalPlanQualFetch(), EvalPlanQualFetchRowMarks(), EvalPlanQualSetTuple(), EvalPlanQualStart(), evaluate_expr(), EvaluateParams(), EventCacheLookup(), EventTriggerInvoke(), examine_attribute(), examine_parameter_list(), examine_simple_variable(), examine_variable(), exec_assign_c_string(), exec_assign_value(), exec_cast_value(), exec_command(), exec_describe_statement_message(), exec_dynquery_with_params(), exec_eval_cleanup(), exec_eval_datum(), exec_eval_expr(), exec_eval_simple_expr(), exec_execute_message(), exec_for_query(), exec_get_datum_type(), exec_get_datum_type_info(), exec_init_tuple_store(), exec_move_row(), exec_object_restorecon(), exec_parse_message(), exec_prepare_plan(), exec_prog(), exec_run_select(), exec_simple_check_node(), exec_simple_check_plan(), exec_simple_query(), exec_simple_recheck_plan(), exec_stmt_block(), exec_stmt_case(), exec_stmt_close(), exec_stmt_dynexecute(), exec_stmt_dynfors(), exec_stmt_execsql(), exec_stmt_exit(), exec_stmt_fetch(), exec_stmt_forc(), exec_stmt_foreach_a(), exec_stmt_fori(), exec_stmt_getdiag(), exec_stmt_loop(), exec_stmt_open(), exec_stmt_perform(), exec_stmt_raise(), exec_stmt_return(), exec_stmt_return_next(), exec_stmt_return_query(), exec_stmt_while(), ExecAlterDefaultPrivilegesStmt(), ExecAlterExtensionContentsStmt(), ExecAlterObjectSchemaStmt(), ExecAlterOwnerStmt(), ExecARDeleteTriggers(), ExecARInsertTriggers(), ExecARUpdateTriggers(), ExecASDeleteTriggers(), ExecASInsertTriggers(), ExecAssignScanProjectionInfo(), ExecASTruncateTriggers(), ExecASUpdateTriggers(), ExecBRDeleteTriggers(), ExecBRInsertTriggers(), ExecBRUpdateTriggers(), ExecBSDeleteTriggers(), ExecBSInsertTriggers(), ExecBSTruncateTriggers(), ExecBSUpdateTriggers(), ExecBuildProjectionInfo(), ExecCallTriggerFunc(), ExecClearTuple(), ExecCloseIndices(), ExecConstraints(), ExecContextForcesOids(), ExecCopySlotMinimalTuple(), ExecCopySlotTuple(), execCurrentOf(), ExecDelete(), ExecEndFunctionScan(), ExecEndMaterial(), ExecEndModifyTable(), ExecEndNode(), ExecEndSort(), ExecEvalAggref(), ExecEvalAnd(), ExecEvalArray(), ExecEvalArrayCoerceExpr(), ExecEvalArrayRef(), ExecEvalCase(), ExecEvalCoalesce(), ExecEvalCoerceToDomain(), ExecEvalConvertRowtype(), ExecEvalFieldStore(), ExecEvalMinMax(), ExecEvalNot(), ExecEvalOr(), ExecEvalParamExec(), ExecEvalRow(), ExecEvalRowCompare(), ExecEvalWholeRowFast(), ExecEvalWholeRowSlow(), ExecEvalWholeRowVar(), ExecEvalWindowFunc(), ExecEvalXml(), ExecFetchSlotMinimalTuple(), ExecFetchSlotTuple(), ExecGrant_Database(), ExecGrant_Fdw(), ExecGrant_ForeignServer(), ExecGrant_Function(), ExecGrant_Language(), ExecGrant_Largeobject(), ExecGrant_Namespace(), ExecGrant_Relation(), ExecGrant_Tablespace(), ExecGrant_Type(), ExecHashBuildSkewHash(), ExecHashGetHashValue(), ExecHashGetSkewBucket(), ExecHashIncreaseNumBatches(), ExecHashJoin(), ExecHashJoinNewBatch(), ExecHashJoinOuterGetTuple(), ExecHashJoinSaveTuple(), ExecHashRemoveNextSkewBucket(), ExecHashSubPlan(), ExecHashTableResetMatchFlags(), ExecIndexBuildScanKeys(), ExecIndexEvalArrayKeys(), ExecIndexEvalRuntimeKeys(), ExecInitAgg(), ExecInitBitmapHeapScan(), ExecInitBitmapIndexScan(), ExecInitCteScan(), ExecInitExpr(), ExecInitFunctionScan(), ExecInitGroup(), ExecInitHashJoin(), ExecInitIndexOnlyScan(), ExecInitIndexScan(), ExecInitMergeJoin(), ExecInitModifyTable(), ExecInitNestLoop(), ExecInitNode(), ExecInitRecursiveUnion(), ExecInitResult(), ExecInitSeqScan(), ExecInitSubPlan(), ExecInitSubqueryScan(), ExecInitValuesScan(), ExecInitWindowAgg(), ExecInitWorkTableScan(), ExecInsert(), ExecInsertIndexTuples(), ExecIRDeleteTriggers(), ExecIRInsertTriggers(), ExecIRUpdateTriggers(), ExecLockRows(), ExecMakeFunctionResult(), ExecMakeFunctionResultNoSets(), ExecMakeTableFunctionResult(), ExecMaterial(), ExecMaterializeSlot(), ExecModifyTable(), ExecPrepareExpr(), ExecPrepareTuplestoreResult(), ExecProcessReturning(), ExecProcNode(), ExecProject(), ExecQual(), ExecQueryUsingCursor(), ExecRefreshMatView(), ExecRelCheck(), ExecRenameStmt(), ExecReScan(), ExecReScanAgg(), ExecReScanAppend(), ExecReScanBitmapAnd(), ExecReScanBitmapHeapScan(), ExecReScanBitmapIndexScan(), ExecReScanBitmapOr(), ExecReScanCteScan(), ExecReScanFunctionScan(), ExecReScanGroup(), ExecReScanHash(), ExecReScanHashJoin(), ExecReScanLimit(), ExecReScanLockRows(), ExecReScanMaterial(), ExecReScanMergeAppend(), ExecReScanMergeJoin(), ExecReScanNestLoop(), ExecReScanRecursiveUnion(), ExecReScanResult(), ExecReScanSeqScan(), ExecReScanSetOp(), ExecReScanSort(), ExecReScanSubqueryScan(), ExecReScanUnique(), ExecReScanWindowAgg(), ExecResult(), ExecResultMarkPos(), ExecResultRestrPos(), ExecScanFetch(), ExecScanHashBucket(), ExecScanHashTableForUnmatched(), ExecScanReScan(), ExecScanSubPlan(), ExecSecLabelStmt(), ExecSetParamPlan(), ExecSetVariableStmt(), ExecStoreAllNullTuple(), ExecStoreMinimalTuple(), ExecStoreTuple(), ExecStoreVirtualTuple(), ExecSupportsBackwardScan(), ExecTargetList(), ExecUpdate(), execute_extension_script(), execute_sql_string(), ExecuteGrantStmt(), ExecuteInsertCommands(), ExecutePlan(), ExecuteQuery(), ExecuteSqlQueryForSingleRow(), ExecuteTruncate(), ExecutorRewind(), ExecWindowAgg(), ExecWorkTableScan(), existsTimeLineHistory(), exit_horribly(), expand_colnames_array_to(), expand_indexqual_opclause(), expand_inherited_rtentry(), expand_schema_name_patterns(), expand_table_name_patterns(), expand_targetlist(), expand_tilde(), ExpandAllTables(), ExpandColumnRefStar(), expandRecordVariable(), expandRelAttrs(), ExpandRowReference(), ExpandSingleTable(), explain_ExecutorStart(), explain_get_index_name(), ExplainExecuteQuery(), ExplainMemberNodes(), ExplainNode(), ExplainOnePlan(), ExplainOneUtility(), ExplainPrintPlan(), ExplainQuery(), ExplainTargetRel(), expression_planner(), expression_returns_set(), expression_returns_set_rows_walker(), expression_returns_set_walker(), expression_tree_mutator(), expression_tree_walker(), exprIsLengthCoercion(), exprLocation(), extract_autovac_opts(), extract_not_arg(), extract_query_dependencies_walker(), extract_strong_not_arg(), ExtractSetVariableArgs(), fallbackSplit(), FastPathGetRelationLockEntry(), fetch_cursor_param_value(), fetch_finfo_record(), fetch_fp_info(), fetch_more_data(), FetchPreparedStatement(), FetchStatementTargetList(), FigureColname(), FigureColnameInternal(), file_acquire_sample_rows(), file_exists(), file_fdw_validator(), fileGetForeignPaths(), fileGetOptions(), fileIterateForeignScan(), fill_seq_with_data(), fillRelOptions(), filter_event_trigger(), filter_lines_with_token(), finalize_aggregate(), finalize_plan(), finalize_primnode(), finalize_windowaggregate(), find(), find_expr_references_walker(), find_forced_null_var(), find_forced_null_vars(), find_funcstat_entry(), find_header(), find_in_dynamic_libpath(), find_inheritance_children(), find_join_input_rel(), find_join_rel(), find_jointree_node_for_rel(), find_lateral_references(), find_matching_ts_config(), find_minmax_aggs_walker(), find_my_exec(), find_nonnullable_rels_walker(), find_nonnullable_vars_walker(), find_oper_cache_entry(), find_placeholders_in_jointree(), find_placeholders_recurse(), find_provider(), find_rendezvous_variable(), find_simple(), find_str(), find_struct_member(), find_typed_table_dependencies(), find_unaggregated_cols(), find_unaggregated_cols_walker(), find_update_path(), find_variable(), find_window_functions_walker(), findarc(), findDependentObjects(), findDontCares(), FindEndOfXLOG(), findeq(), FindLockCycleRecurse(), findNamespace(), findParentsByOid(), findPartialMatch(), FindStreamingStart(), findTargetlistEntrySQL92(), findTargetlistEntrySQL99(), findTheLexeme(), FindTupleHashEntry(), findVariant(), FindWord(), FinishPreparedTransaction(), fireRIRonSubLink(), fireRIRrules(), fireRules(), fix_dependencies(), fix_indexqual_operand(), fix_join_expr_mutator(), fix_opfuncids(), fix_opfuncids_walker(), fix_scan_expr_mutator(), fix_scan_expr_walker(), fix_upper_expr_mutator(), fixempties(), flagInhAttrs(), flatten_join_alias_vars_mutator(), flatten_set_variable_args(), float4_accum(), float8_accum(), float8_regr_accum(), FlushBuffer(), FlushDatabaseBuffers(), fmgr_info_cxt_security(), fmgr_info_other_lang(), fmgr_internal_function(), fmgr_oldstyle(), fmgr_security_definer(), fmgr_sql(), fmgr_sql_validator(), fmtId(), footers_with_default(), foreign_expr_walker(), forget_invalid_pages(), forget_invalid_pages_db(), fork_process(), format_function_arguments_old(), format_type_internal(), FormIndexDatum(), free_parsestate(), free_statement(), free_stringlist(), free_struct_lconv(), free_variable(), FreeAccessStrategy(), freearc(), freecm(), freecolor(), freedfa(), freenfa(), FreeQueryDesc(), freeScanKeys(), freeScanStackEntry(), freesrnode(), freestate(), freesubre(), FreeTriggerDesc(), freev(), FreeVfd(), FreeWorkerInfo(), from_char_parse_int_len(), fsm_readbuf(), func_get_detail(), func_select_candidate(), FuncNameAsType(), FuncnameGetCandidates(), function_parse_error_transpose(), FunctionCall1Coll(), FunctionCall2Coll(), FunctionCall3Coll(), FunctionCall4Coll(), FunctionCall5Coll(), FunctionCall6Coll(), FunctionCall7Coll(), FunctionCall8Coll(), FunctionCall9Coll(), FunctionNext(), fuzzy_open_file(), g_cube_union(), g_int_picksplit(), gb18030_to_utf8(), gbk_to_utf8(), gbt_num_distance(), gbt_var_same(), gbtreekey_in(), gbtreekey_out(), generate_append_tlist(), generate_base_implied_equalities(), generate_base_implied_equalities_const(), generate_base_implied_equalities_no_const(), generate_function_name(), generate_join_implied_equalities_normal(), generate_mergeappend_paths(), generate_old_dump(), generate_operator_name(), generate_recursion_plan(), generate_setop_grouplist(), generate_setop_tlist(), generate_wildcard_trgm(), generateClonedIndexStmt(), GenerateRecoveryConf(), genericcostestimate(), geqo_eval(), get_actual_variable_range(), get_agg_expr(), get_array_element_end(), get_assignment_input(), get_attribute_options(), get_attstatsslot(), get_available_versions_for_extension(), get_base_rel_indexes(), get_basic_select_query(), get_bin_version(), get_btree_test_op(), get_cached_rowtype(), get_call_expr_arg_stable(), get_call_expr_argtype(), get_canonical_locale_name(), get_char_item(), get_cheapest_fractional_path_for_pathkeys(), get_cheapest_path_for_pathkeys(), get_control_data(), get_crosstab_tuplestore(), get_current_username(), get_database_list(), get_db_and_rel_infos(), get_delete_query_def(), get_eclass_for_sort_expr(), get_expr_result_type(), get_ext_ver_list(), get_from_clause(), get_from_clause_item(), get_func_arg_info(), get_func_expr(), get_func_input_arg_names(), get_func_result_name(), get_func_result_type(), get_hash_entry(), get_insert_query_def(), get_int_item(), get_last_attnums(), get_line_style(), get_loop_count(), get_major_server_version(), get_name_for_var_field(), get_nearest_unprocessed_vertex(), get_next_work_item(), get_object_address(), get_object_address_type(), get_object_field_end(), get_parameterized_baserel_size(), get_path_all(), get_pgpid(), get_pgstat_tabentry_relid(), get_progname(), get_prompt(), get_range_io_data(), get_raw_page_internal(), get_record1(), get_rel_data_width(), get_rel_oids(), get_relation_constraints(), get_relation_info(), get_relid_attribute_name(), get_relids_in_jointree(), get_rels_with_domain(), get_remote_estimate(), get_restricted_token(), get_restriction_variable(), get_rewrite_oid_without_relid(), get_rte_attribute_type(), get_rule_expr(), get_rule_windowclause(), get_select_query_def(), get_setop_query(), get_sock_dir(), get_sort_group_operators(), get_source_line(), get_sql_delete(), get_sql_insert(), get_sql_update(), get_str_from_var(), get_sublink_expr(), get_tables_to_cluster(), get_tablespace_page_costs(), get_tabstat_stack_level(), get_target_list(), get_tuple_of_interest(), get_update_query_def(), get_user_default_acl(), get_variable(), get_variable_numdistinct(), get_variable_range(), get_windowfunc_expr(), get_with_clause(), get_worker(), GetActiveSnapshot(), getaddrinfo(), getAggregates(), getAnotherTuple(), GetAttributeByName(), GetAttributeByNum(), getAttrName(), getbits(), getBlobs(), GetCachedPlan(), GetCatCacheHashValue(), GetComboCommandId(), GetComment(), GetConfigOption(), GetConfigOptionByName(), GetConfigOptionByNum(), GetConfigOptionResetString(), GetConflictingVirtualXIDs(), GetConnection(), getConnectionByName(), getConstraints(), GetCurrentAbsoluteTime(), GetCurrentDateTime(), GetCurrentIntegerTimestamp(), GetCurrentTimestamp(), GetCurrentTimeUsec(), getcvec(), GetDefaultTablespace(), getDependencies(), GetDomainConstraints(), getExtensionMembership(), GetFdwRoutine(), GetFdwRoutineForRelation(), getfields(), GetForeignServer(), getFuncs(), gethms(), getIndexes(), getInsertSelectQuery(), getInstallationPaths(), GetIntoRelEFlags(), GetLocalBufferStorage(), GetLockConflicts(), GetMemoryChunkContext(), GetMemoryChunkSpace(), getMessageFromWorker(), getnameinfo(), getNamespaces(), getNextGISTSearchItem(), getNextNearest(), getnum(), getObjectDescription(), getoffset(), getOpclasses(), getOperators(), getOpfamilies(), getOpFamilyDescription(), getopt_long(), GetPgClassDescriptor(), GetPgIndexDescriptor(), getPgPassFilename(), GetPlatformEncoding(), getRelationDescription(), getRelationsInNamespace(), GetReplicationApplyDelay(), GetRTEByRangeTablePosn(), getrule(), getRules(), GetRunningTransactionData(), getrusage(), gets_fromFile(), getSchemaData(), getsecs(), GetSerializableTransactionSnapshotInt(), GetSharedMemName(), GetSnapshotData(), GetStandbyFlushRecPtr(), getsubdfa(), GetSystemIdentifier(), getTableAttrs(), getTableDataFKConstraints(), getTables(), getTocEntryByDumpId(), gettoken(), gettoken_query(), GetTransactionSnapshot(), getTriggers(), getTSCurrentConfig(), GetTupleForTrigger(), gettype(), getTypes(), getv4(), getvacant(), getVariable(), getWeights(), gin_extract_hstore(), gin_extract_hstore_query(), ginAllocEntryAccumulator(), ginbuild(), ginBuildCallback(), ginbuildempty(), ginbulkdelete(), ginContinueSplit(), gincostestimate(), ginEntryInsert(), ginExtractEntries(), ginFillScanEntry(), ginFillScanKey(), ginGetBAEntry(), ginHeapTupleFastCollect(), ginHeapTupleFastInsert(), ginHeapTupleInsert(), ginInitBA(), ginInsertCleanup(), ginInsertValue(), ginint4_queryextract(), ginNewScanKey(), ginRedoSplit(), ginvacuumcleanup(), ginVacuumEntryPage(), gist_box_consistent(), gist_box_same(), gist_circle_compress(), gist_circle_consistent(), gist_poly_compress(), gist_poly_consistent(), gistbuildempty(), gistbulkdelete(), gistchoose(), gistformdownlink(), gistFormTuple(), gistgetadjusted(), gistgetbitmap(), gistgettuple(), gistinserttuples(), gistMakeUnionItVec(), gistRelocateBuildBuffersOnSplit(), gistrescan(), gistScanPage(), GISTSearchTreeItemCombiner(), gistSplitByKey(), gistvacuumcleanup(), gistValidateBufferingOption(), gmtload(), GrantLockLocal(), GrantRole(), grouping_planner(), gseg_union(), gtrgm_consistent(), gtrgm_distance(), gtrgm_penalty(), guc_malloc(), guc_realloc(), guc_strdup(), GUCArrayDelete(), GUCArrayReset(), GuessControlValues(), handle_sigint(), handleCopyIn(), HandleCopyStream(), HandleFunctionRequest(), HandleSlashCmds(), has_indexed_join_quals(), has_multiple_baserels(), has_unnamed_full_join_using(), hash_array(), hash_destroy(), hash_inner_and_outer(), hash_object_field_end(), hash_search_with_hash_value(), hash_seq_search(), hash_update_hash_key(), hashbuild(), hashbulkdelete(), hashvacuumcleanup(), hasnonemptyout(), HaveNFreeProcs(), heap_copytuple(), heap_copytuple_with_tuple(), heap_create_with_catalog(), heap_fill_tuple(), heap_form_minimal_tuple(), heap_form_tuple(), heap_page_items(), heap_reloptions(), heap_truncate_find_FKs(), heapgettup(), heapgettup_pagemode(), histcontrol_hook(), histogram_selectivity(), hlparsetext(), hstore_defined(), hstore_exists(), hstore_fetchval(), hstore_from_array(), hstore_from_record(), hstore_populate_record(), hstore_recv(), hstore_skeys(), hstore_slice_to_array(), hstore_slice_to_hstore(), hstore_svals(), hyphenate(), icatalloc(), icfree(), icpyalloc(), ident_inet(), identify_locking_dependencies(), identify_system_timezone(), ifree(), increase_size(), IncreaseBuffer(), IncrementSize(), IncrementVarSublevelsUp_walker(), index_build(), index_constraint_create(), index_create(), index_form_tuple(), index_getnext(), index_getprocid(), index_getprocinfo(), index_insert(), index_register(), index_reloptions(), IndexBuildHeapScan(), IndexCheckExclusion(), IndexNext(), IndexOnlyNext(), IndexScanEnd(), ineq_histogram_selectivity(), inet_abbrev(), inet_cidr_ntop(), inet_cidr_ntop_ipv4(), inet_cidr_ntop_ipv6(), inet_cidr_pton_ipv6(), inet_client_addr(), inet_client_port(), inet_net_ntop(), inet_net_ntop_ipv4(), inet_net_ntop_ipv6(), inet_server_addr(), inet_server_port(), infile(), inheritance_planner(), init(), init_execution_state(), init_fcache(), init_htab(), init_litdata_packet(), init_MultiFuncCall(), init_openssl_rand(), init_parallel_dump_utils(), init_params(), init_sequence(), init_sql_fcache(), init_work(), InitArchiveFmt_Directory(), InitArchiveFmt_Null(), InitArchiveFmt_Tar(), InitAuxiliaryProcess(), InitCatCache(), InitCatCachePhase2(), InitFileAccess(), initGinState(), initialize(), initialize_data_directory(), initialize_environment(), initialize_mergeclause_eclasses(), initialize_worker_spi(), InitializeGUCOptionsFromEnvironment(), initializeInput(), InitializeOneGUCOption(), InitLatch(), InitPgFdwOptions(), InitPostgres(), initPQExpBuffer(), InitPredicateLocks(), InitProcess(), InitProcessPhase2(), initscan(), InitScanRelation(), InitSharedLatch(), InitShmemAllocation(), initSuffixTree(), initValue(), InitWalSender(), InitWalSenderSlot(), inleap(), inline_function(), inline_set_returning_function(), InputFunctionCall(), insert_ordered_oid(), insert_ordered_unique_oid(), insert_username(), InsertExtensionTuple(), InsertOneNull(), InsertPgAttributeTuple(), InsertRule(), insertStatEntry(), InstallTimeZoneAbbrevs(), int2_avg_accum(), int2_sum(), int2vectorrecv(), int4_avg_accum(), int4_sum(), int8inc(), internal_get_result_type(), internal_load_library(), internal_read_key(), InternalIpcMemoryCreate(), interpretOidsOption(), interval_accum(), interval_avg(), intorel_startup(), inv_read(), inv_truncate(), inv_write(), InvalidateAttoptCacheCallback(), InvalidateConstraintCacheCallBack(), InvalidateOprCacheCallBack(), InvalidateOprProofCacheCallBack(), InvalidateTableSpaceCacheCallback(), InvalidateTSCacheCallBack(), inzone(), inzsub(), IpcMemoryDelete(), IpcMemoryDetach(), irealloc(), is_extension_control_filename(), is_extension_script_filename(), is_redundant_derived_clause(), is_safe_append_member(), is_simple_subquery(), is_simple_union_all(), is_simple_union_all_recurse(), is_valid_dblink_option(), isAffixInUse(), isAssignmentIndirectionExpr(), IsBackendPid(), IsCheckpointOnSchedule(), iso8859_to_utf8(), isQueryUsingTempRelation(), isQueryUsingTempRelation_walker(), issue_warnings(), IsWaitingForLock(), johab_to_utf8(), join_is_legal(), json_agg_finalfn(), json_array_element(), json_array_element_text(), json_array_elements(), json_lex_string(), json_object_field(), json_object_field_text(), json_populate_record(), json_populate_recordset(), JumbleExpr(), JumbleQuery(), KillExistingArchiveStatus(), KillExistingXLOG(), koi8r_to_utf8(), koi8u_to_utf8(), lacon(), lastcold(), lastval(), lazy_tid_reaped(), lazy_vacuum_page(), lc_collate_is_c(), lc_ctype_is_c(), left_oper(), leftmostvalue_numeric(), levenshtein_internal(), lex_accept(), lex_expect(), lexnest(), libpq_select(), libpqrcv_endstreaming(), libpqrcv_PQexec(), libpqrcv_receive(), like_fixed_prefix(), line_interpt(), linkAndUpdateFile(), list_delete_cell(), list_delete_first(), list_free_private(), list_next_fn(), listAllDbs(), listCollations(), listConversions(), listDbRoleSettings(), listDefaultACLs(), listDomains(), listEventTriggers(), listExtensionContents(), listExtensions(), listForeignDataWrappers(), listForeignServers(), listForeignTables(), listLanguages(), listSchemas(), listTables(), listTSConfigs(), listTSConfigsVerbose(), listTSDictionaries(), listTSParsers(), listTSParsersVerbose(), listTSTemplates(), listUserMappings(), lo_close(), lo_creat(), lo_create(), lo_initialize(), lo_lseek(), lo_lseek64(), lo_manage(), lo_open(), lo_read(), lo_tell(), lo_tell64(), lo_truncate(), lo_truncate64(), lo_truncate_internal(), lo_unlink(), lo_write(), load_critical_index(), load_enum_cache_data(), load_external_function(), load_hba(), load_ident(), load_libraries(), load_relcache_init_file(), LoadKernel32(), local_buffer_write_error_callback(), LocalBufferAlloc(), locale_date_order(), localGetCurrentTimestamp(), LocalPrefetchBuffer(), LocalToUtf(), locate_agg_of_level_walker(), locate_grouping_columns(), locate_var_of_level_walker(), locate_windowfunc_walker(), lock_twophase_recover(), LockAcquireExtended(), LockBufferForCleanup(), LockErrorCleanup(), LockReassignCurrentOwner(), LockRelease(), LockReleaseAll(), LockReleaseCurrentOwner(), LockReleaseSession(), log_invalid_page(), log_line_prefix(), logfile_getname(), logfile_open(), logfile_rotate(), LogicalTapeRewind(), LogicalTapeSetClose(), LogicalTapeWrite(), LogStreamerMain(), longest(), looks_like_temp_rel_name(), lookup_agg_function(), lookup_C_func(), lookup_collation_cache(), lookup_fdw_handler_func(), lookup_fdw_validator_func(), lookup_hash_entry(), lookup_rowtype_tupdesc_internal(), lookup_rowtype_tupdesc_noerror(), lookup_ts_config_cache(), lookup_ts_dictionary_cache(), lookup_ts_parser_cache(), lookup_type_cache(), LookupOpclassInfo(), LookupOperNameTypeNames(), LookupTupleHashEntry(), LookupTypeName(), LookupTypeNameOid(), lose_s(), LPLRemoveHead(), lseg_inside_poly(), lseg_intersect_internal(), ltq_regex(), ltree_picksplit(), ltsRecallNextBlockNum(), ltsRecallPrevBlockNum(), ltsRecordBlockNum(), ltsRewindFrozenIndirectBlock(), ltsRewindIndirectBlock(), LWLockAcquire(), LWLockAcquireOrWait(), LWLockRelease(), main(), MainLoop(), make_absolute_path(), make_and_qual(), make_ands_implicit(), make_inh_translation_list(), make_join_rel(), make_modifytable(), make_one_rel(), make_op(), make_oper_cache_entry(), make_pathkey_from_sortop(), make_postgres(), make_restrictinfo(), make_restrictinfo_from_bitmapqual(), make_restrictinfo_internal(), make_restrictinfos_from_actual_clauses(), make_row_distinct_op(), make_ruledef(), make_sort_from_pathkeys(), make_sub_restrictinfos(), make_subplanTargetList(), make_template0(), make_tuple_from_result_row(), make_union_unique(), make_viewdef(), make_windowInputTargetList(), makeAlterConfigCommand(), makeDependencyGraphWalker(), makeEmptyPGconn(), MakePerTupleExprContext(), makeRangeConstructors(), makeRangeVarFromNameList(), makesearch(), MakeSharedInvalidMessagesArray(), makeTableDataInfo(), map_sql_catalog_to_xmlschema_types(), map_sql_schema_to_xmlschema_types(), map_sql_value_to_xml_value(), map_variable_attnos_mutator(), MapArrayTypeName(), mark_dummy_rel(), mark_work_done(), MarkAsPreparing(), markcanreach(), markQueryForLocking(), markreachable(), markRTEForSelectPriv(), markst(), markTargetListOrigin(), match_clause_to_ordering_op(), match_index_to_operand(), match_special_index_operator(), match_unsorted_outer(), matchLocks(), MatchNamedCall(), materializeQueryResult(), materializeResult(), mcelem_array_contained_selec(), mcv_selectivity(), mdclose(), mdcreate(), mdexists(), mdimmedsync(), mdnblocks(), mdsync(), mdtruncate(), memcheck(), MemoryContextContains(), MemoryContextCreate(), MemoryContextDelete(), MemoryContextDeleteChildren(), MemoryContextInit(), MemoryContextIsEmpty(), MemoryContextReset(), MemoryContextResetChildren(), MemoryContextStatsInternal(), merge_clump(), MergeAttributes(), MetaphAdd(), MinimumActiveBackends(), miss(), MJEvalInnerValues(), MJEvalOuterValues(), MJExamineQuals(), mkdatadir(), mkdirs(), mm_alloc(), mm_strdup(), moddatetime(), moresubs(), movedb(), moveins(), moveouts(), mp_error_string(), mp_int_abs(), mp_int_add(), mp_int_alloc(), mp_int_clear(), mp_int_compare(), mp_int_compare_unsigned(), mp_int_compare_value(), mp_int_compare_zero(), mp_int_copy(), mp_int_count_bits(), mp_int_div(), mp_int_div_pow2(), mp_int_divisible_value(), mp_int_egcd(), mp_int_expt(), mp_int_expt_value(), mp_int_exptmod(), mp_int_free(), mp_int_gcd(), mp_int_init_copy(), mp_int_init_size(), mp_int_init_value(), mp_int_invmod(), mp_int_is_pow2(), mp_int_mod(), mp_int_mul(), mp_int_mul_pow2(), mp_int_neg(), mp_int_read_binary(), mp_int_read_cstring(), mp_int_read_string(), mp_int_read_unsigned(), mp_int_redux_const(), mp_int_set_value(), mp_int_sqr(), mp_int_sqrt(), mp_int_string_len(), mp_int_sub(), mp_int_to_binary(), mp_int_to_int(), mp_int_to_string(), mp_int_to_unsigned(), mp_int_zero(), mpi_to_bn(), MultiExecBitmapAnd(), MultiExecBitmapIndexScan(), MultiExecBitmapOr(), MultiExecProcNode(), mXactCachePut(), mxid_to_string(), myFunctionCall2Coll(), nameicregexeq(), nameicregexne(), nameregexeq(), nameregexne(), NamespaceCreate(), negate_clause(), network_out(), new_9_0_populate_pg_largeobject_metadata(), newabbr(), newarc(), newcolor(), newcvec(), newdfa(), newfstate(), newlacon(), newLOfd(), NewMetaString(), newnfa(), newstate(), next(), NextCopyFrom(), nextval_internal(), nfanode(), nfatree(), NIImportAffixes(), NIImportDictionary(), NIImportOOAffixes(), NINormalizeWord(), nodeRead(), nonemptyins(), nonemptyouts(), NormalizeSubWord(), not_clause(), notice_processor(), NUM_cache(), numeric_avg(), numeric_stddev_internal(), numericvar_to_double(), numst(), objectDescription(), objectNamesToOids(), objectsInSchemaToOids(), OffsetVarNodes_walker(), OidFunctionCall0Coll(), OidFunctionCall1Coll(), OidFunctionCall2Coll(), OidFunctionCall3Coll(), OidFunctionCall4Coll(), OidFunctionCall5Coll(), OidFunctionCall6Coll(), OidFunctionCall7Coll(), OidFunctionCall8Coll(), OidFunctionCall9Coll(), oidin(), oidparse(), oidvectorrecv(), okcolors(), old_8_3_check_for_name_data_type_usage(), old_8_3_check_for_tsquery_usage(), old_8_3_check_ltree_usage(), old_8_3_create_sequence_script(), old_8_3_invalidate_bpchar_pattern_ops_indexes(), old_8_3_invalidate_hash_gin_indexes(), old_8_3_rebuild_tsvector_tables(), on_error_rollback_hook(), on_exit_nicely(), open_csvlogfile(), open_cur1(), open_lo_relation(), openit(), OpenPipeStream(), oper(), OperatorCreate(), OperatorLookup(), OperatorShellMake(), OperatorUpd(), OpernameGetCandidates(), optimize_minmax_aggregates(), optionListToArray(), or_clause(), output_deallocate_prepare_statement(), output_get_descr(), output_prepare_statement(), output_set_descr(), output_statement(), outzone(), packGraph(), page_header(), PageIsPredicateLocked(), pair_count(), pair_decode(), parallel_exec_prog(), parallel_restore(), parallel_transfer_all_new_dbs(), ParallelBackupStart(), param_is_newly_set(), parse(), parse_analyze(), parse_analyze_varparams(), parse_array(), parse_array_element(), parse_basebackup_options(), parse_cipher_name(), parse_extension_control_file(), parse_fcall_arguments_20(), parse_format(), parse_hba_auth_opt(), parse_hba_line(), parse_object(), parse_object_field(), parse_one_reloption(), parse_psql_options(), parse_scalar(), parse_slash_copy(), parse_symenc_data(), parse_symenc_mdc_data(), parseAclItem(), parseArchiveFormat(), parseCheckAggregates(), parseCommandLine(), ParseComplexProjection(), ParseDateTime(), ParseFuncOrColumn(), parseOidArray(), parsePGArray(), parseqatom(), parseQuery(), parser_errposition(), parseRelOptions(), parserOpenTable(), parseServiceFile(), parseServiceInfo(), parsetext(), parseTypeString(), ParseTzFile(), ParseVariableBool(), PasswordFromFile(), path_contains_parent_reference(), PathNameOpenFile(), per_MultiFuncCall(), perform_base_backup(), perform_default_encoding_conversion(), PerformCursorOpen(), performDeletion(), performMultipleDeletions(), PerformPortalClose(), permissionsList(), PersistHoldablePortal(), pfree(), pg_analyze_and_rewrite_params(), pg_atoi(), pg_available_extension_versions(), pg_available_extensions(), pg_backup_start_time(), pg_bind_textdomain_codeset(), pg_char_to_encname_struct(), pg_check_dir(), pg_column_size(), pg_crypt(), pg_ctype_get_cache(), pg_cursor(), pg_decrypt(), pg_dlerror(), pg_dlsym(), pg_encrypt(), pg_event_trigger_dropped_objects(), pg_extension_config_dump(), pg_extension_update_paths(), pg_fe_sendauth(), pg_free(), pg_freeaddrinfo_all(), pg_get_constraintdef_worker(), pg_get_expr(), pg_get_expr_ext(), pg_get_functiondef(), pg_get_indexdef(), pg_get_indexdef_columns(), pg_get_indexdef_ext(), pg_get_indexdef_string(), pg_get_indexdef_worker(), pg_get_ruledef_worker(), pg_get_triggerdef_worker(), pg_get_viewdef_worker(), pg_getaddrinfo_all(), pg_identify_object(), pg_indexes_size(), pg_last_xlog_receive_location(), pg_last_xlog_replay_location(), pg_listening_channels(), pg_load_tz(), pg_log(), pg_mkdir_p(), pg_newlocale_from_collation(), pg_perm_setlocale(), pg_prepared_statement(), pg_prepared_xact(), pg_re_throw(), pg_realloc(), pg_reg_colorisbegin(), pg_reg_colorisend(), pg_reg_getcharacters(), pg_reg_getfinalstate(), pg_reg_getinitialstate(), pg_reg_getnumcharacters(), pg_reg_getnumcolors(), pg_reg_getnumoutarcs(), pg_reg_getnumstates(), pg_reg_getoutarcs(), pg_regcomp(), pg_regexec(), pg_regfree(), pg_regprefix(), pg_relation_is_scannable(), pg_relation_size(), pg_rusage_init(), pg_signal_backend(), pg_signal_dispatch_thread(), pg_signal_thread(), pg_sockaddr_cidr_mask(), pg_start_backup(), pg_stat_get_analyze_count(), pg_stat_get_autoanalyze_count(), pg_stat_get_autovacuum_count(), pg_stat_get_backend_activity(), pg_stat_get_backend_activity_start(), pg_stat_get_backend_client_addr(), pg_stat_get_backend_client_port(), pg_stat_get_backend_dbid(), pg_stat_get_backend_pid(), pg_stat_get_backend_start(), pg_stat_get_backend_userid(), pg_stat_get_backend_waiting(), pg_stat_get_backend_xact_start(), pg_stat_get_blocks_fetched(), pg_stat_get_blocks_hit(), pg_stat_get_db_blk_read_time(), pg_stat_get_db_blk_write_time(), pg_stat_get_db_blocks_fetched(), pg_stat_get_db_blocks_hit(), pg_stat_get_db_conflict_all(), pg_stat_get_db_conflict_bufferpin(), pg_stat_get_db_conflict_lock(), pg_stat_get_db_conflict_snapshot(), pg_stat_get_db_conflict_startup_deadlock(), pg_stat_get_db_conflict_tablespace(), pg_stat_get_db_deadlocks(), pg_stat_get_db_stat_reset_time(), pg_stat_get_db_temp_bytes(), pg_stat_get_db_temp_files(), pg_stat_get_db_tuples_deleted(), pg_stat_get_db_tuples_fetched(), pg_stat_get_db_tuples_inserted(), pg_stat_get_db_tuples_returned(), pg_stat_get_db_tuples_updated(), pg_stat_get_db_xact_commit(), pg_stat_get_db_xact_rollback(), pg_stat_get_dead_tuples(), pg_stat_get_function_calls(), pg_stat_get_function_self_time(), pg_stat_get_function_total_time(), pg_stat_get_last_analyze_time(), pg_stat_get_last_autoanalyze_time(), pg_stat_get_last_autovacuum_time(), pg_stat_get_last_vacuum_time(), pg_stat_get_live_tuples(), pg_stat_get_numscans(), pg_stat_get_tuples_deleted(), pg_stat_get_tuples_fetched(), pg_stat_get_tuples_hot_updated(), pg_stat_get_tuples_inserted(), pg_stat_get_tuples_returned(), pg_stat_get_tuples_updated(), pg_stat_get_vacuum_count(), pg_stat_get_wal_senders(), pg_stat_get_xact_blocks_fetched(), pg_stat_get_xact_blocks_hit(), pg_stat_get_xact_function_calls(), pg_stat_get_xact_function_self_time(), pg_stat_get_xact_function_total_time(), pg_stat_get_xact_numscans(), pg_stat_get_xact_tuples_deleted(), pg_stat_get_xact_tuples_fetched(), pg_stat_get_xact_tuples_hot_updated(), pg_stat_get_xact_tuples_inserted(), pg_stat_get_xact_tuples_returned(), pg_stat_get_xact_tuples_updated(), pg_stat_statements(), pg_stop_backup(), pg_strftime(), pg_table_size(), pg_tablespace_databases(), pg_timer_thread(), pg_total_relation_size(), pg_tzset(), pg_usleep(), pg_verify_mbstr_len(), pg_vfprintf(), pg_vsnprintf(), pg_vsprintf(), pg_wcsformat(), pgarch_MainLoop(), pgarch_readyXlog(), pgarch_start(), PgArchiverMain(), pgfdw_subxact_callback(), pgfdw_xact_callback(), pgfnames(), PGLC_localeconv(), pglz_compress(), pgp_armor_decode(), pgp_cfb_create(), pgp_create_pkt_writer(), pgp_get_cipher_block_size(), pgp_get_cipher_key_size(), pgp_get_cipher_name(), pgp_get_keyid(), pgp_key_free(), pgp_load_cipher(), pgp_load_digest(), pgp_mpi_free(), pgp_parse_pubenc_sesskey(), pgp_set_symkey(), pgp_sym_decrypt_bytea(), pgp_sym_decrypt_text(), pgp_write_pubenc_sesskey(), PGReserveSemaphores(), pgrowlocks(), PGSemaphoreCreate(), PGSemaphoreUnlock(), PGSharedMemoryAttach(), PGSharedMemoryCreate(), PGSharedMemoryDetach(), PGSharedMemoryIsInUse(), PGSharedMemoryReAttach(), pgss_ExecutorEnd(), pgss_ExecutorStart(), pgss_post_parse_analyze(), pgss_ProcessUtility(), pgss_shmem_shutdown(), pgss_shmem_startup(), pgss_store(), pgstat_collect_oids(), pgstat_count_heap_delete(), pgstat_count_heap_insert(), pgstat_count_heap_update(), pgstat_end_function_usage(), pgstat_fetch_stat_dbentry(), pgstat_fetch_stat_funcentry(), pgstat_fetch_stat_tabentry(), pgstat_get_crashed_backend_activity(), pgstat_heap(), pgstat_init(), pgstat_initstats(), pgstat_read_db_statsfile(), pgstat_read_db_statsfile_timestamp(), pgstat_read_statsfiles(), pgstat_recv_dropdb(), pgstat_recv_funcpurge(), pgstat_recv_inquiry(), pgstat_recv_resetcounter(), pgstat_recv_resetsinglecounter(), pgstat_recv_tabpurge(), pgstat_report_activity(), pgstat_report_analyze(), pgstat_report_stat(), pgstat_reset_remove_files(), pgstat_send_funcstats(), pgstat_start(), pgstat_update_heap_dead_tuples(), pgstat_vacuum_stat(), pgstat_write_db_statsfile(), pgstat_write_statsfiles(), PgstatCollectorMain(), pgstatginindex(), pgstatindex(), pgtypes_defmt_scan(), PGTYPESdate_defmt_asc(), PGTYPESdate_fmt_asc(), PGTYPESdecimal_new(), PGTYPESnumeric_copy(), PGTYPESnumeric_div(), PGTYPESnumeric_from_asc(), PGTYPESnumeric_from_double(), PGTYPESnumeric_mul(), PGTYPESnumeric_new(), PGTYPESnumeric_to_long(), PGTYPEStimestamp_add_interval(), PGTYPEStimestamp_current(), PGTYPEStimestamp_fmt_asc(), PGTYPEStimestamp_from_asc(), PGTYPEStimestamp_to_asc(), pguuid_complain(), pgwin32_accept(), pgwin32_connect(), pgwin32_create_signal_listener(), pgwin32_get_dynamic_tokeninfo(), pgwin32_putenv(), pgwin32_recv(), pgwin32_ReserveSharedMemoryRegion(), pgwin32_select(), pgwin32_send(), pgwin32_setlocale(), pgwin32_signal_initialize(), pgwin32_socket(), pgwin32_socket_strerror(), pgwin32_waitforsinglesocket(), pgxml_result_to_text(), pgxml_xpath(), pgxmlNodeSetToText(), pickss(), PinBuffer(), pipe_read_line(), placeOne(), plan_cluster_use_sort(), plan_set_operations(), plperl_array_to_datum(), plperl_build_tuple_result(), plperl_fini(), plperl_func_handler(), plperl_init_interp(), plperl_modify_tuple(), plperl_return_next(), plperl_spi_exec(), plperl_spi_exec_prepared(), plperl_spi_fetchrow(), plperl_spi_freeplan(), plperl_spi_prepare(), plperl_spi_query(), plperl_spi_query_prepared(), plperl_sv_to_datum(), plperl_sv_to_literal(), plperl_trigger_handler(), plperl_trusted_init(), plpgsql_add_initdatums(), plpgsql_compile_inline(), plpgsql_create_econtext(), plpgsql_destroy_econtext(), plpgsql_dumptree(), plpgsql_exec_error_callback(), plpgsql_exec_event_trigger(), plpgsql_exec_function(), plpgsql_exec_trigger(), plpgsql_HashTableDelete(), plpgsql_HashTableInit(), plpgsql_location_to_lineno(), plpgsql_ns_additem(), plpgsql_ns_lookup(), plpgsql_ns_lookup_label(), plpgsql_ns_pop(), plpgsql_ns_push(), plpgsql_param_ref(), plpgsql_parse_cwordtype(), plpgsql_parse_dblword(), plpgsql_parse_tripword(), plpgsql_parse_word(), plpgsql_parse_wordtype(), plpgsql_post_column_ref(), plpgsql_scanner_errposition(), plpgsql_subxact_cb(), plpgsql_xact_cb(), pltcl_argisnull(), pltcl_elog(), pltcl_func_handler(), pltcl_init_interp(), pltcl_init_load_unknown(), pltcl_process_SPI_result(), pltcl_returnnull(), pltcl_set_tuple_values(), pltcl_SPI_execute_plan(), pltcl_SPI_prepare(), pltcl_subtrans_begin(), pltcl_trigger_handler(), PLTemplateExists(), PLy_add_exceptions(), PLy_current_execution_context(), PLy_cursor_fetch(), PLy_cursor_plan(), PLy_cursor_query(), PLy_elog(), PLy_exec_function(), PLy_exec_trigger(), PLy_function_build_args(), PLy_generate_spi_exceptions(), PLy_get_spi_error_data(), PLy_get_spi_sqlerrcode(), PLy_init_interp(), PLy_init_plpy(), PLy_modify_tuple(), PLy_output(), PLy_plan_new(), PLy_pop_execution_context(), PLy_procedure_call(), PLy_procedure_compile(), PLy_procedure_create(), PLy_procedure_get(), PLy_procedure_name(), PLy_procedure_valid(), PLy_quote_nullable(), PLy_result_item(), PLy_result_new(), PLy_spi_execute_fetch_result(), PLy_spi_execute_plan(), PLy_spi_prepare(), PLy_spi_subtransaction_abort(), PLy_spi_subtransaction_begin(), PLy_subtransaction_enter(), PLy_subtransaction_exit(), PLy_subtransaction_new(), PLy_traceback(), PLy_trigger_build_args(), PLy_typeinfo_dealloc(), PLyDict_FromTuple(), PLyGenericObject_ToComposite(), PLyList_FromArray(), PLyMapping_ToComposite(), PLySequence_ToComposite(), PLyUnicode_Bytes(), popen_check(), PopTransaction(), populate_recordset_object_end(), populate_recordset_object_field_end(), PortalCreateHoldStore(), PortalDefineQuery(), PortalHashTableDeleteAll(), PortalRunMulti(), PortalSetResultFormat(), postgresAnalyzeForeignTable(), postgresEndForeignModify(), postgresEndForeignScan(), postgresExecForeignDelete(), postgresExecForeignInsert(), postgresExecForeignUpdate(), postgresGetForeignPaths(), postgresGetForeignRelSize(), PostgresMain(), postgresReScanForeignScan(), PostmasterMain(), PostmasterRandom(), PostPrepare_Locks(), PostPrepare_PgStat(), postprocess_setop_tlist(), postquel_end(), postquel_getnext(), postquel_start(), postquel_sub_params(), pq_close(), pq_getkeepalivescount(), pq_getkeepalivesidle(), pq_getkeepalivesinterval(), pq_putemptymessage(), pq_setkeepalivescount(), pq_setkeepalivesidle(), pq_setkeepalivesinterval(), pqAddTuple(), pqBuildStartupPacket3(), PQclear(), PQconndefaults(), PQconnectionNeedsPassword(), PQconnectPoll(), PQconnectStart(), PQconnectStartParams(), PQconninfo(), PQconninfoFree(), PQconninfoParse(), PQcopyResult(), PQdisplayTuples(), PQescapeBytea(), PQescapeByteaInternal(), PQescapeInternal(), PQescapeString(), PQexecFinish(), PQexecStart(), PQfn(), PQfnumber(), PQgetCancel(), pqGetCopyData2(), pqGetCopyData3(), pqGetErrorNotice2(), pqGetErrorNotice3(), pqGetHomeDirectory(), pqGethostbyname(), pqGetpwuid(), pqInternalNotice(), PQparameterStatus(), pqParseInput2(), pqParseInput3(), PQprint(), PQresultErrorField(), pqRowProcessor(), pqSaveErrorResult(), pqSaveParameterStatus(), pqsecure_open_client(), PQsendQueryPrepared(), PQsetClientEncoding(), PQsetdbLogin(), pqSetenvPoll(), PQsetNoticeProcessor(), PQsetNoticeReceiver(), PQsetvalue(), pqSocketPoll(), PQtrace(), PQunescapeBytea(), PQuntrace(), PreCommit_Notify(), PreCommit_Portals(), predicate_classify(), predicate_implied_by_recurse(), predicate_refuted_by_recurse(), predicatelock_twophase_recover(), PredicateLockExists(), PredicateLockTuple(), PredicateLockTwoPhaseFinish(), prepare_common(), prepare_foreign_modify(), prepare_new_cluster(), prepare_new_databases(), prepare_sort_from_pathkeys(), prepare_sql_fn_parse_info(), PrepareQuery(), PrepareSortSupportComparisonShim(), PrepareSortSupportFromOrderingOp(), PrepareTempTablespaces(), PrepareToInvalidateCacheTuple(), PrepareTransaction(), PrepareTransactionBlock(), preprocess_expression(), preprocess_groupclause(), preprocess_qual_conditions(), preprocess_targetlist(), prepTuplestoreResult(), PrescanPreparedTransactions(), print_addr(), print_aligned_text(), print_aligned_vertical(), print_expr(), print_function_arguments(), print_html_text(), print_html_vertical(), print_latex_longtable_text(), print_slot(), print_unaligned_text(), print_unaligned_vertical(), printatt(), printMixedStruct(), PrintQueryTuples(), printTableAddCell(), printTableAddFooter(), printTableSetFooter(), printtup_startup(), ProcedureCreate(), process_builtin(), process_commands(), process_equivalence(), process_file(), process_implied_equality(), process_matched_tle(), process_pipe_input(), process_postgres_switches(), process_psqlrc(), process_secret_key(), process_startup_options(), process_sublinks_mutator(), process_subquery_nestloop_params(), ProcessCopyOptions(), ProcessGUCArray(), processIndirection(), ProcessRecords(), ProcessRepliesIfAny(), processSQLNamePattern(), ProcessStartupPacket(), processTypesSpec(), ProcessUtility(), ProcessUtilitySlow(), ProcKill(), ProcSendSignal(), ProcSleep(), ProcWakeup(), prompt_for_password(), prune_element_hashtable(), prune_lexemes_hashtable(), pthread_join(), pull(), pull_up_sublinks(), pull_up_sublinks_jointree_recurse(), pull_up_sublinks_qual_recurse(), pull_up_subqueries(), pull_up_subqueries_recurse(), pull_var_clause_walker(), pull_varattnos_walker(), pull_varnos_walker(), pull_vars_walker(), pullback(), pullf_create(), pullf_create_mbuf_reader(), pullup_replace_vars_callback(), pullup_replace_vars_subquery(), push(), pushf_create(), pushf_create_mbuf_writer(), pushfwd(), putVariable(), pwdfMatchesString(), px_crypt(), px_crypt_des(), px_find_cipher(), px_find_combo(), px_find_digest(), px_gen_salt(), qual_is_pushdown_safe(), query_contains_extern_params(), query_contains_extern_params_walker(), query_is_distinct_for(), query_planner(), query_to_xml(), query_to_xml_and_xmlschema(), query_to_xmlschema(), query_tree_mutator(), query_tree_walker(), QueryRewrite(), quote_identifier(), quote_if_needed(), range_get_typcache(), rangeTableEntry_used_walker(), RangeVarGetAndCheckCreationNamespace(), raw_expression_tree_walker(), raw_heap_insert(), RE_compile_and_cache(), RE_wchar_execute(), reached_end_position(), read_binary_file(), read_dictionary(), read_extension_control_file(), read_post_opts(), ReadArrayBinary(), ReadArrayStr(), ReadBuffer(), ReadCheckpointRecord(), ReadDataFromArchive(), readDatum(), ReadDir(), readfile(), ReadRecord(), readRecoveryCommandFile(), readstoplist(), readTimeLineHistory(), reapply_stacked_values(), rebuild_database_list(), ReceiveAndUnpackTarFile(), ReceiveFunctionCall(), ReceiveTarFile(), ReceiveXlogStream(), recheck_cast_function_args(), recompute_limits(), record_C_func(), record_cmp(), record_eq(), record_in(), record_out(), record_recv(), record_send(), recordMultipleDependencies(), RecoverPreparedTransactions(), RecoveryRestartPoint(), recurse_push_qual(), recurse_pushdown_safe(), recurse_set_operations(), recurse_union_children(), recv_and_check_password_packet(), reduce_dependencies(), reduce_outer_joins(), reduce_outer_joins_pass1(), reduce_outer_joins_pass2(), refnameRangeTblEntry(), refresh_matview_datafill(), refreshMatViewData(), regex_fixed_prefix(), RegisterBackgroundWorker(), RegisterTimeout(), RegisterWaitForSingleObject(), regoperin(), regoperout(), regprocedurein(), regprocin(), regprocout(), regression_main(), reindex_index(), ReindexDatabase(), ReindexTable(), relation_is_updatable(), relation_needs_vacanalyze(), RelationBuildTupleDesc(), RelationCacheInitFileRemove(), RelationCacheInitFileRemoveInDir(), RelationCacheInitializePhase3(), RelationCacheInvalidate(), RelationClearRelation(), RelationGetExclusionInfo(), RelationGetIndexAttrBitmap(), RelationGetIndexExpressions(), RelationGetIndexPredicate(), RelationMapFinishBootstrap(), RelationReloadIndexInfo(), RelationSetNewRelfilenode(), ReleaseCatCache(), ReleaseLockIfHeld(), ReleaseOneSerializableXact(), ReleasePredicateLocks(), ReleaseResources_hash(), RememberFsyncRequest(), remove_dbtablespaces(), remove_rel_from_query(), remove_variables(), RemoveFromWaitQueue(), RemoveLocalLock(), RemoveOldXlogFiles(), RemovePgTempFiles(), RemovePgTempFilesInDir(), RemovePgTempRelationFiles(), RemovePgTempRelationFilesInDbspace(), RemoveProcFromArray(), RemoveTargetIfNoLongerUsed(), renameatt(), RenameConstraint(), RenameDatabase(), RenameRewriteRule(), renametrig(), RenameType(), reorder_function_arguments(), repairDependencyLoop(), repalloc(), replace_aggs_with_params_mutator(), replace_correlation_vars_mutator(), replace_nestloop_params_mutator(), replace_rte_variables_mutator(), replace_s(), replace_string(), replace_text_regexp(), replace_token(), replace_vars_in_jointree(), ReplaceVarsFromTargetList_callback(), report_parse_error(), report_triggers(), reportErrorPosition(), RequestXLogStreaming(), ResetCancelConn(), ResetCatalogCache(), ResetUnloggedRelations(), ResetUnloggedRelationsInDbspaceDir(), ResetUnloggedRelationsInTablespaceDir(), ResetUsage(), resolve_column_ref(), ResolveRecoveryConflictWithVirtualXIDs(), ResourceOwnerDelete(), ResourceOwnerEnlargeBuffers(), ResourceOwnerEnlargeCatCacheListRefs(), ResourceOwnerEnlargeCatCacheRefs(), ResourceOwnerEnlargeFiles(), ResourceOwnerEnlargePlanCacheRefs(), ResourceOwnerEnlargeRelationRefs(), ResourceOwnerEnlargeSnapshots(), ResourceOwnerEnlargeTupleDescs(), ResourceOwnerForgetBuffer(), ResourceOwnerReleaseInternal(), ResourceOwnerRememberBuffer(), restore(), restore_toc_entries_parallel(), restore_toc_entries_prefork(), restore_toc_entry(), RestoreArchive(), RestoreArchivedFile(), restriction_is_or_clause(), RevalidateCachedQuery(), rewrite_heap_dead_tuple(), rewrite_heap_tuple(), RewriteControlFile(), RewriteQuery(), rewriteRuleAction(), rewriteTargetListIU(), rewriteTargetListUD(), rewriteTargetView(), rfree(), ri_Check_Pk_Match(), ri_FetchPreparedPlan(), RI_FKey_cascade_del(), RI_FKey_cascade_upd(), RI_FKey_check(), RI_FKey_setdefault_del(), RI_FKey_setdefault_upd(), RI_FKey_setnull_del(), RI_FKey_setnull_upd(), ri_HashPreparedPlan(), RI_Initial_Check(), ri_PerformCheck(), ri_PlanCheck(), ri_ReportViolation(), ri_restrict_del(), ri_restrict_upd(), right_oper(), rmtree(), rowcomparesel(), RS_compile(), rt_cube_size(), rt_seg_size(), RTERangeTablePosn(), rulesub(), run_ifaddr_callback(), run_named_permutations(), run_permutation(), run_schedule(), run_single_test(), RunFunctionExecuteHook(), RunNamespaceSearchHook(), RunObjectDropHook(), RunObjectPostAlterHook(), RunObjectPostCreateHook(), runShellCommand(), s_alloc(), s_brmu(), s_pad(), s_realloc(), save_ps_display_args(), scalararraysel_containment(), scan_directory_ci(), scanNameSpaceForRelid(), ScanQueryWalker(), scanstr(), scheck(), schedule_alarm(), schema_to_xml(), schema_to_xml_internal(), score_timezone(), search_plan_tree(), SearchCatCache(), SearchCatCacheList(), searchRangeTableForCol(), searchRangeTableForRel(), select_common_type(), select_loop(), select_outer_pathkeys_for_merge(), select_perl_context(), selectColorTrigrams(), selectDumpableNamespace(), selectDumpableTable(), selectDumpableType(), selectSourceSchema(), send_message_to_server_log(), SendBackupHeader(), sendDir(), sendFile(), sendFileWithContent(), SendQuery(), sendTablespace(), sepgsql_avc_compute(), sepgsql_dml_privileges(), sepgsql_fmgr_hook(), sepgsql_get_client_label(), sepgsql_init_client_label(), sepgsql_needs_fmgr_hook(), sepgsql_set_client_label(), serialize_deflist(), ServerLoop(), set_append_rel_pathlist(), set_arg(), set_base_rel_pathlists(), set_base_rel_sizes(), set_baserel_size_estimates(), set_cheapest(), set_config_by_name(), set_config_option(), set_config_sourcefile(), set_cte_pathlist(), set_deparse_for_query(), set_dl_error(), set_dummy_rel_pathlist(), set_errdata_field(), set_int_item(), set_join_column_names(), set_next_rotation_time(), set_null_conf(), set_pglocale_pgservice(), set_plan_refs(), set_ps_display(), set_relation_column_names(), set_returning_clause_references(), set_using_names(), SetCancelConn(), setcolor(), SetDefaultACL(), SetEpochTimestamp(), setitimer(), setKeepalivesCount(), setKeepalivesIdle(), setKeepalivesInterval(), setlocales(), setop_fill_hash_table(), setop_retrieve_direct(), setop_retrieve_hash_table(), setRuleCheckAsUser_walker(), setSchemaName(), SetSecurityLabel(), SetSharedSecurityLabel(), setTargetTable(), SetTransactionSnapshot(), setup_auth(), setup_config(), setup_connection(), setup_depend(), setup_firstcall(), setup_formatted_log_time(), setup_param_list(), setup_privileges(), setup_text_search(), setupDumpWorker(), SetupLockInTable(), SetupWorker(), SHA224_Final(), SHA224_Init(), SHA256_Final(), SHA256_Init(), SHA384_Final(), SHA384_Init(), SHA512_Final(), SHA512_Init(), shared_buffer_write_error_callback(), SharedInvalBackendInit(), shdepChangeDep(), shdepDropOwned(), shdepLockAndCheckObject(), shdepReassignOwned(), ShmemAlloc(), ShmemInitStruct(), SHMQueueIsDetached(), shortest(), show_config_by_name(), show_foreignscan_info(), show_log_timezone(), show_modifytable_info(), show_sort_info(), show_timezone(), ShowAllGUCConfig(), ShowUsage(), shutdown_MultiFuncCall(), ShutdownExprContext(), SignalUnconnectedWorkers(), simple_prompt(), SimpleLruTruncate(), SimpleLruWritePage(), single_decode(), sjis_to_utf8(), slice_check(), slice_from_s(), slice_to(), slist_delete(), slot_attisnull(), slot_getallattrs(), slot_getattr(), slot_getsomeattrs(), SlruPhysicalWritePage(), SlruScanDirectory(), SlruSelectLRUPage(), smgrclose(), smgrcloseall(), smgrclosenode(), smgrcreate(), smgropen(), smgrsetowner(), SN_close_env(), SN_create_env(), SN_set_current(), SnapshotResetXmin(), sort(), SortTocFromFile(), spawn_process(), specialAttNum(), specialcolors(), spg_range_quad_picksplit(), spg_text_choose(), spg_text_inner_consistent(), spg_text_leaf_consistent(), spg_text_picksplit(), spgAddNodeAction(), spgAddPendingTID(), spgbulkdelete(), spgClearPendingList(), spgdoinsert(), spgGetCache(), SpGistUpdateMetaPage(), spgPageIndexMultiDelete(), spgprocesspending(), spgRedoPickSplit(), spgSplitNodeAction(), spgvacuumcleanup(), spgvacuumscan(), SPI_connect(), SPI_copytuple(), SPI_cursor_open_internal(), SPI_cursor_open_with_args(), spi_dest_startup(), SPI_execute(), SPI_execute_plan(), SPI_execute_plan_with_paramlist(), SPI_execute_snapshot(), SPI_execute_with_args(), SPI_fnumber(), SPI_freeplan(), SPI_freetuptable(), SPI_getargcount(), SPI_getargtypeid(), SPI_is_cursor_plan(), SPI_keepplan(), SPI_modifytuple(), SPI_plan_get_cached_plan(), SPI_prepare_cursor(), SPI_prepare_params(), spi_printtup(), SPI_returntuple(), SPI_saveplan(), SPI_sql_row_to_xmlelement(), split_path(), split_to_stringlist(), SplitDirectoriesString(), SplitIdentifierString(), SplitToVariants(), splitTzLine(), sql_check(), sql_conn(), sql_exec_error_callback(), sql_fn_post_column_ref(), sql_fn_resolve_param_name(), sqlda_common_total_size(), sqlda_compat_empty_size(), sqlda_native_empty_size(), SS_finalize_plan(), ss_search(), ssl_cipher(), ssl_client_cert_present(), ssl_client_serial(), ssl_is_used(), ssl_version(), standard_ExecutorEnd(), standard_ExecutorFinish(), standard_ExecutorRun(), standard_ExecutorStart(), standard_join_search(), standard_planner(), standard_ProcessUtility(), StandbyRecoverPreparedTransactions(), StandbyTransactionIdIsPrepared(), start_postmaster(), StartAutoVacLauncher(), StartAutoVacWorker(), StartLogStreamer(), startScanEntry(), StartTransactionCommand(), startup_hacks(), StartupXLOG(), std_typanalyze(), stop_postmaster(), store_match(), StoreRelCheck(), storeRow(), str2uint(), StrategyGetBuffer(), StreamLog(), string_agg_finalfn(), string_agg_transfn(), string_to_datum(), string_to_uuid(), stringToNode(), stringzone(), strip_implicit_coercions(), strip_quotes(), sub_abs(), subblock(), subquery_is_pushdown_safe(), subquery_push_qual(), subre(), substitute_actual_parameters_mutator(), substitute_actual_srf_parameters_mutator(), substitute_libpath_macro(), substitute_multiple_relids_walker(), supportSecondarySplit(), symencrypt_sesskey(), SyncOneBuffer(), SyncRepWaitForLSN(), SysLogger_Start(), SysLoggerMain(), systable_beginscan(), systable_beginscan_ordered(), system(), system_reseed(), t_readline(), table_recheck_autovac(), table_to_xml(), tarCreateHeader(), tarOpen(), tarPrintf(), tarRead(), tarWrite(), tbm_begin_iterate(), tbm_create_pagetable(), tbm_find_pageentry(), tbm_intersect(), tbm_intersect_page(), tbm_lossify(), tbm_mark_page_lossy(), tbm_page_is_lossy(), tbm_union(), test(), test_postmaster_connection(), text_concat(), text_concat_ws(), text_format(), text_to_array_internal(), texticregexeq(), texticregexne(), textregexeq(), textregexne(), ThereAreNoReadyPortals(), ThereIsAtLeastOneRole(), thesaurus_lexize(), thesaurusRead(), threadRun(), TidListCreate(), TidNext(), timeofday(), timestamp2timestamptz(), timestamp2tm(), timestamp_abstime(), timestamp_age(), timestamp_date(), timestamp_in(), timestamp_out(), timestamp_part(), timestamp_pl_interval(), timestamp_recv(), timestamp_time(), timestamp_to_char(), timestamp_trunc(), timestamp_zone(), timestamptz_abstime(), timestamptz_age(), timestamptz_date(), timestamptz_out(), timestamptz_part(), timestamptz_pl_interval(), timestamptz_recv(), timestamptz_time(), timestamptz_timestamp(), timestamptz_timetz(), timestamptz_to_char(), timestamptz_to_str(), timestamptz_trunc(), timestamptz_zone(), timesub(), timetravel(), timetz2tm(), timetz_zone(), tlist_matches_coltypelist(), tlist_matches_tupdesc(), tlist_same_collations(), tlist_same_datatypes(), tm2timestamp(), toast_compress_datum(), toast_delete_datum(), toast_fetch_datum(), toast_fetch_datum_slice(), toast_flatten_tuple_attribute(), toast_insert_or_update(), toast_save_datum(), toastrel_valueid_exists(), tokenize_inc_file(), TooManyStates(), TopoSort(), TouchSocketFiles(), TouchSocketLockFiles(), TParserCopyInit(), TParserGet(), TParserInit(), TransactionIdIsInProgress(), transfer_all_new_tablespaces(), transfer_relfile(), transfer_single_new_db(), TransferPredicateLocksToNewTarget(), transformAExprIn(), transformAggregateCall(), transformAlterTableStmt(), transformArrayExpr(), transformArraySubscripts(), transformAssignedExpr(), transformAssignmentIndirection(), transformAssignmentSubscripts(), transformCaseExpr(), transformCoalesceExpr(), transformColumnDefinition(), transformColumnRef(), transformColumnType(), transformCreateStmt(), transformCurrentOfExpr(), transformDeclareCursorStmt(), transformExprRecurse(), transformFrameOffset(), transformFromClauseItem(), transformGenericOptions(), transformIndexConstraint(), transformIndexConstraints(), transformIndexStmt(), transformIndirection(), transformInsertStmt(), transformJoinUsingClause(), transformLimitClause(), transformLockingClause(), transformMinMaxExpr(), transformOfType(), transformParamRef(), transformRangeSubselect(), transformRelOptions(), transformRuleStmt(), transformSelectStmt(), transformSetOperationStmt(), transformSetOperationTree(), transformSubLink(), transformTableLikeClause(), transformTargetEntry(), transformTargetList(), transformTopLevelStmt(), transformTypeCast(), transformUpdateStmt(), transformValuesClause(), transformWhereClause(), transformWindowDefinitions(), transformWindowFuncCall(), transformXmlSerialize(), translate_col_privs(), treat_as_join_clause(), triggered_change_notification(), TriggerEnabled(), TrimExtension(), try_complete_step(), try_unix_std(), ts_accum(), ts_lexize(), ts_process_call(), ts_rank_tt(), ts_rank_ttf(), ts_rankcd_tt(), ts_rankcd_ttf(), ts_setup_firstcall(), ts_stat1(), ts_stat_sql(), tsa_rewrite_accum(), tsa_rewrite_finish(), tsa_tsearch2(), tsearch_readline_begin(), tsquery_opr_selec(), tsquery_rewrite(), tsquery_rewrite_query(), tsqueryin(), tsquerysel(), tsvector_update_trigger(), tsvectorin(), ttdummy(), TupleDescInitEntry(), TupleHashTableHash(), TupleHashTableMatch(), tuplesort_begin_cluster(), tuplesort_end(), tuplesort_performsort(), TwoPhaseGetGXact(), txid_current_snapshot(), TypeCacheRelCallback(), TypeCreate(), TypeGetTupleDesc(), typeInheritsFrom(), typenameType(), typenameTypeId(), typesequiv(), TypeShellMake(), typeTypeId(), tzload(), tzparse(), uhc_to_utf8(), unaccent_dict(), uncolorchain(), UnregisterExprContextCallback(), UnregisterSnapshot(), UnregisterSnapshotFromOwner(), unsetenv(), UnsyncVariables(), untransformRelOptions(), update_mergeclause_eclasses(), UpdateActiveSnapshotCommandId(), UpdateIndexRelation(), UpdateRangeTableOfViewParse(), useful_strerror(), useKeepalives(), UserAbortTransactionBlock(), utf8_to_big5(), utf8_to_euc_cn(), utf8_to_euc_jp(), utf8_to_euc_kr(), utf8_to_euc_tw(), utf8_to_gb18030(), utf8_to_gbk(), utf8_to_iso8859(), utf8_to_johab(), utf8_to_koi8r(), utf8_to_koi8u(), utf8_to_sjis(), utf8_to_uhc(), utf8_to_win(), UtfToLocal(), uuid_generate_v1(), uuid_generate_v1mc(), uuid_generate_v4(), vac_close_indexes(), vac_truncate_clog(), vac_update_datfrozenxid(), vac_update_relstats(), vacuum(), vacuum_all_databases(), vacuum_set_xid_limits(), vacuumlo(), validate_index(), validate_index_heapscan(), validateCheckConstraint(), validateDomainConstraint(), validateForeignKeyConstraint(), ValidatePgVersion(), ValuesNext(), var_eq_const(), var_eq_non_const(), verbosity_hook(), verify_directory(), view_is_auto_updatable(), VirtualXactLock(), vm_readbuf(), WaitForCommands(), WaitForWALToBecomeAvailable(), WaitLatchOrSocket(), walkdir(), walkStatEntryTree(), WalRcvDie(), WalRcvRunning(), WalRcvStreaming(), WalReceiverMain(), WalSndKill(), WalWriterMain(), warn_or_exit_horribly(), widget_in(), widget_out(), win_to_utf8(), window_first_value(), window_last_value(), window_nth_value(), WinGetFuncArgCurrent(), WinGetFuncArgInFrame(), WinGetFuncArgInPartition(), WinGetPartitionLocalMemory(), wordchrs(), worker_spi_main(), wrap_process(), write_console(), write_csvlog(), write_relcache_init_file(), write_syslogger_file(), write_version_file(), WriteDataChunksForTocEntry(), writefile(), WriteRecoveryConf(), writeTarData(), WriteToc(), writezone(), xact_redo_commit_compact(), xact_redo_commit_internal(), xactGetCommittedInvalidationMessages(), xidin(), XLogArchiveForceDone(), XLogArchiveNotify(), XLogCheckInvalidPages(), XLogDumpDisplayRecord(), XLogFileCopy(), XLogHaveInvalidPages(), XLogInsert(), XLogReadBufferExtended(), XLogReaderAllocate(), XLogSend(), XLogWalRcvSendReply(), XLogWrite(), xml_encode_special_chars(), xml_is_well_formed(), xml_out_internal(), xml_recv(), xmlconcat(), xmlelement(), xmlexists(), xmlpi(), xmlroot(), xpath_bool(), xpath_exists(), xpath_list(), xpath_nodeset(), xpath_number(), xpath_string(), xpath_table(), xslt_process(), yearistype(), and zaptreesubs().

#define offsetof (   type,
  field 
)    ((long) &((type *)0)->field)

Definition at line 507 of file c.h.

Referenced by _bt_steppage(), AtPrepare_PredicateLocks(), attribute_reloptions(), binaryheap_allocate(), BootStrapXLOG(), box_poly(), BTreeShmemSize(), btrestrpos(), build_tlist_index(), build_tlist_index_other_vars(), check_temp_tablespaces(), CheckpointerShmemSize(), CheckRADIUSAuth(), CheckTableForSerializableConflictIn(), CheckTargetForConflictsIn(), circle_poly(), ClearOldPredicateLocks(), CreatePredXact(), CreateSharedInvalidationState(), CreateSharedProcArray(), CreateTableSpace(), cube_a_f8(), cube_a_f8_f8(), cube_c_f8(), cube_c_f8_f8(), cube_enlarge(), cube_f8(), cube_f8_f8(), cube_subset(), default_reloptions(), DeleteChildTargetLocks(), DeleteLockTarget(), DropAllPredicateLocksFromTable(), ExecBuildProjectionInfo(), FindLockCycleRecurse(), FirstPredXact(), FlagSxactUnsafe(), GetAccessStrategy(), GetLockConflicts(), ginoptions(), gistoptions(), gistPushItupToNodeBuffer(), heap_form_minimal_tuple(), heap_form_tuple(), heap_insert(), heap_multi_insert(), heap_tuple_from_minimal_tuple(), heap_xlog_insert(), heap_xlog_multi_insert(), heap_xlog_update(), load_enum_cache_data(), load_relmap_file(), load_tzoffsets(), LockReleaseAll(), log_heap_update(), LogAccessExclusiveLocks(), main(), mXactCachePut(), needs_toast_table(), NextPredXact(), OnConflict_CheckForSerializationFailure(), path_add(), path_in(), path_poly(), path_recv(), pgss_memsize(), pgss_shmem_shutdown(), pgss_shmem_startup(), pgstat_read_db_statsfile_timestamp(), pgstat_read_statsfiles(), pgstat_send_funcstats(), pgstat_send_tabstat(), pgstat_vacuum_stat(), pgstat_write_statsfiles(), PMSignalShmemSize(), poly_in(), poly_path(), poly_recv(), PostPrepare_Locks(), PreCommit_CheckForSerializationFailure(), PrintCatCacheLeakWarning(), ProcArrayShmemSize(), ReadControlFile(), ReleaseCatCache(), ReleaseOneSerializableXact(), ReleasePredicateLocks(), ReleasePredXact(), RewriteControlFile(), RWConflictExists(), SetPossibleUnsafeConflict(), SetRWConflict(), setup_param_list(), SInvalShmemSize(), SummarizeOldestCommittedSxact(), suppress_redundant_updates_trigger(), SyncRepQueueInsert(), SyncRepWakeQueue(), tablespace_reloptions(), toast_flatten_tuple_attribute(), toast_insert_or_update(), TransferPredicateLocksToNewTarget(), TwoPhaseShmemInit(), TwoPhaseShmemSize(), UpdateControlFile(), ValidXLogRecord(), WalSndShmemSize(), write_relmap_file(), WriteControlFile(), WriteEmptyXLOG(), and XLogInsert().

#define OidIsValid (   objectId  )     ((bool) ((objectId) != InvalidOid))

Definition at line 490 of file c.h.

Referenced by _bt_compare_scankey_args(), _bt_find_extreme_element(), activate_interpreter(), add_column_collation_dependency(), AddEnumLabel(), AddNewAttributeTuples(), addTargetToSortList(), adjust_appendrel_attrs_mutator(), adjust_inherited_tlist(), adjust_rowcompare_for_index(), AggregateCreate(), AlterForeignDataWrapper(), AlterObjectOwner_internal(), AlterObjectRename_internal(), AlterTableNamespace(), AlterTypeNamespace_oid(), AlterTypeNamespaceInternal(), AlterTypeOwner(), AlterTypeOwnerInternal(), AlterUserMapping(), analyzeCTETargetList(), ApplyExtensionUpdates(), array_cmp(), array_contain_compare(), array_eq(), array_fill(), array_fill_with_lower_bounds(), array_recv(), array_replace_internal(), array_send(), array_typanalyze(), assign_collations_walker(), assignOperTypes(), assignProcTypes(), AssignTypeArrayOid(), ATAddForeignKeyConstraint(), ATExecAddIndex(), ATExecAddIndexConstraint(), ATExecClusterOn(), ATExecDropOf(), ATExecSetRelOptions(), ATExecSetTableSpace(), ATPrepSetTableSpace(), ATRewriteTable(), ATRewriteTables(), AutoVacWorkerMain(), binary_oper_exact(), binary_upgrade_set_pg_class_oids(), binary_upgrade_set_type_oids_by_type_oid(), boot_get_type_io_data(), bounds_adjacent(), btcostestimate(), btree_predicate_proof(), build_aggregate_fnexprs(), build_coercion_expression(), build_datatype(), build_subplan(), cache_array_element_properties(), cache_record_field_properties(), calc_arraycontsel(), calculate_table_size(), check_default_tablespace(), check_generic_type_consistency(), check_of_type(), check_TSCurrentConfig(), CheckAttributeType(), ChooseRelationName(), cluster(), cluster_rel(), CollationCreate(), CollationGetCollid(), CommentObject(), CommuteOpExpr(), CommuteRowCompareExpr(), compile_pltcl_function(), compute_range_stats(), compute_return_type(), ComputeIndexAttrs(), concat_internal(), ConstructTupleDescriptor(), contain_mutable_functions_walker(), contain_volatile_functions_walker(), ConversionCreate(), ConversionGetConid(), convert_EXISTS_to_ANY(), convert_function_name(), convert_type_name(), cookDefault(), copy_heap_data(), copyParamList(), cost_qual_eval_walker(), count_agg_clauses_walker(), CountDBBackends(), create_proc_lang(), create_toast_table(), create_unique_path(), create_unique_plan(), CreateCast(), CreateConstraintEntry(), createdb(), CreateExtension(), CreateForeignDataWrapper(), CreateFunction(), CreateProceduralLanguage(), CreateRole(), CreateTableSpace(), CreateTrigger(), CreateUserMapping(), DefineCompositeType(), DefineDomain(), DefineEnum(), DefineIndex(), DefineOpClass(), DefineOperator(), DefineQueryRewrite(), DefineRange(), DefineRelation(), DefineTSConfiguration(), DefineTSDictionary(), DefineTSParser(), DefineTSTemplate(), DefineType(), DefineVirtualRelation(), deparseFuncExpr(), do_autovacuum(), do_compile(), dropOperators(), dropProcedures(), DropSetting(), dumpBaseType(), dumpCast(), dumpCompositeType(), dumpDomain(), dumpOpr(), dumpProcLang(), dumpRangeType(), dumpSequence(), dumpTableSchema(), dumpTrigger(), enforce_generic_type_consistency(), enum_first(), enum_last(), enum_range_internal(), eqjoinsel_semi(), errdetail_params(), eval_const_expressions_mutator(), examine_attribute(), examine_parameter_list(), exec_assign_value(), exec_stmt_foreach_a(), ExecAlterExtensionContentsStmt(), ExecEvalArrayCoerceExpr(), ExecEvalParamExtern(), ExecHashBuildSkewHash(), ExecHashTableCreate(), ExecInitAgg(), ExecInitExpr(), ExecuteDoStmt(), ExecuteTruncate(), exprSetCollation(), exprType(), extract_grouping_ops(), fetch_cursor_param_value(), fetch_fp_info(), finalize_aggregate(), finalize_windowaggregate(), find_coercion_pathway(), find_composite_type_dependencies(), find_expr_references_walker(), find_minmax_aggs_walker(), find_typmod_coercion_function(), FindDefaultConversionProc(), findRangeCanonicalFunction(), findRangeSubOpclass(), findRangeSubtypeDiffFunction(), findTypeAnalyzeFunction(), findTypeInputFunction(), findTypeOutputFunction(), findTypeReceiveFunction(), findTypeSendFunction(), findTypeTypmodinFunction(), findTypeTypmodoutFunction(), finish_heap_swap(), fix_expr_common(), 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(), generateClonedIndexStmt(), GenerateTypeDependencies(), Generic_Text_IC_like(), get_am_oid(), get_btree_test_op(), 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_language_oid(), get_namespace_oid(), get_object_address(), 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_position(), get_range_io_data(), get_rel_oids(), get_relation_constraint_oid(), get_relation_info(), get_rels_with_domain(), get_role_oid(), get_rte_attribute_is_dropped(), get_sort_function_for_ordering_op(), get_sort_group_operators(), get_tablespace_oid(), get_ts_config_oid(), get_ts_dict_oid(), get_ts_parser_oid(), get_ts_template_oid(), getCasts(), GetColumnDefCollation(), GetConflictingVirtualXIDs(), getConstraintTypeDescription(), GetFdwRoutineByRelId(), GetForeignDataWrapperByName(), GetForeignServerByName(), GetIndexOpClass(), GetNewOid(), getObjectDescription(), getObjectIdentity(), GetOuterUserId(), getOwnedSeqs(), GetSessionUserId(), GetTempToastNamespace(), getTokenTypes(), getTriggers(), GetTSConfigTuple(), getTSCurrentConfig(), getTypeBinaryInputInfo(), getTypeBinaryOutputInfo(), getTypeInputInfo(), getTypeIOParam(), getTypeOutputInfo(), GetUserId(), gincost_pattern(), gistrescan(), grouping_is_sortable(), hash_array(), hash_range(), heap_create(), heap_create_with_catalog(), heap_prepare_insert(), heap_sync(), heap_truncate_one_rel(), ImportSnapshot(), index_create(), index_update_stats(), IndexBuildHeapScan(), IndexSupportInitialize(), initGinState(), initGISTstate(), initialize_peragg(), InitializeSessionUserId(), InitializeSessionUserIdStandalone(), InitTempTableNamespace(), inline_function(), intorel_startup(), is_complex_array(), is_member(), IsBinaryCoercible(), isTempNamespace(), isTempOrToastNamespace(), isTempToastNamespace(), LargeObjectCreate(), launch_worker(), lazy_scan_heap(), lc_collate_is_c(), lc_ctype_is_c(), left_oper(), like_fixed_prefix(), load_rangetype_info(), load_typcache_tupdesc(), lookup_agg_function(), lookup_collation_cache(), lookup_ts_config_cache(), lookup_ts_dictionary_cache(), lookup_ts_parser_cache(), lookup_type_cache(), LookupAggNameTypeNames(), LookupCreationNamespace(), LookupExplicitNamespace(), LookupNamespaceNoError(), LookupOperName(), LookupTypeName(), 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(), makeOperatorDependencies(), makeParserDependencies(), makeTSTemplateDependencies(), makeWholeRowVar(), map_sql_table_to_xmlschema(), mark_index_clustered(), mergejoinscansel(), MJExamineQuals(), moveArrayTypeName(), NamespaceCreate(), OpClassCacheLookup(), OpclassnameGetOpcid(), OpenTemporaryFile(), oper(), OperatorCreate(), OperatorLookup(), OperatorUpd(), OpernameGetCandidates(), OpFamilyCacheLookup(), OpfamilynameGetOpfid(), ParseFuncOrColumn(), patternsel(), pg_describe_object(), pg_do_encoding_conversion(), pg_get_constraintdef_worker(), pg_get_expr(), pg_get_expr_ext(), pg_get_expr_worker(), pg_get_indexdef_worker(), pg_get_serial_sequence(), pg_get_triggerdef_worker(), pg_identify_object(), pg_newlocale_from_collation(), pg_relation_filenode(), pg_relation_filepath(), pg_set_regex_collation(), pgstat_beshutdown_hook(), pgstat_send_tabstat(), pgstat_vacuum_stat(), plperl_call_perl_func(), plperl_hash_from_tuple(), plperl_sv_to_literal(), plpgsql_parse_cwordtype(), plpgsql_parse_wordrowtype(), pltcl_build_tuple_argument(), pltcl_set_tuple_values(), PLy_input_tuple_funcs(), PLy_output_tuple_funcs(), PLy_procedure_argument_valid(), prepare_sort_from_pathkeys(), PrepareClientEncoding(), preprocess_groupclause(), preprocess_minmax_aggregates(), ProcedureCreate(), processIndirection(), ProcessUtilitySlow(), PushOverrideSearchPath(), QualifiedNameGetCreationNamespace(), query_is_distinct_for(), range_gist_double_sorting_split(), range_gist_penalty(), RangeCreate(), RangeVarCallbackForDropRelation(), RangeVarCallbackForLockTable(), RangeVarCallbackForReindexIndex(), RangeVarCallbackOwnsTable(), RangeVarGetAndCheckCreationNamespace(), RangeVarGetCreationNamespace(), RangeVarGetRelidExtended(), rebuild_database_list(), rebuild_relation(), recomputeNamespacePath(), reconsider_full_join_clause(), reconsider_outer_join_clause(), record_cmp(), record_eq(), recordDependencyOnCurrentExtension(), refnameRangeTblEntry(), regoperatorin(), reindex_relation(), relation_needs_vacanalyze(), relation_openrv_extended(), RelationBuildDesc(), RelationInitLockInfo(), RelationInitPhysicalAddr(), RelationIsVisible(), RelnameGetRelid(), RemoveConstraintById(), RemoveObjects(), RemoveRelations(), RemoveTempRelationsCallback(), RemoveUserMapping(), renameatt(), RenameConstraintById(), RenameDatabase(), RenameRelation(), RenameRelationInternal(), RenameSchema(), RenameType(), RenameTypeInternal(), report_namespace_conflict(), report_triggers(), ResetTempTableNamespace(), resolve_generic_type(), resolve_polymorphic_argtypes(), resolve_polymorphic_tupdesc(), ri_AttributesEqual(), ri_FetchConstraintInfo(), ri_GenerateQualCollation(), ri_HashCompareOp(), right_oper(), roles_has_privs_of(), roles_is_member_of(), scalararraysel(), scalararraysel_containment(), ScanPgRelation(), searchRangeTableForRel(), select_equality_operator(), selectDumpableType(), SetCurrentRoleId(), SetDefaultACL(), SetOuterUserId(), SetReindexProcessing(), SetSessionAuthorization(), SetSessionUserId(), shdepDropDependency(), show_role(), simplify_function(), sql_fn_make_param(), StandbyAcquireAccessExclusiveLock(), std_typanalyze(), StoreCatalogInheritance(), storeOperators(), storeProcedures(), str_initcap(), str_tolower(), str_toupper(), superuser_arg(), suppress_redundant_updates_trigger(), swap_relation_files(), TablespaceCreateDbspace(), text_format(), toast_save_datum(), transformAExprIn(), transformAggregateCall(), transformAlterTableStmt(), transformArrayExpr(), transformArraySubscripts(), transformCaseExpr(), transformColumnType(), transformCreateStmt(), transformExprRecurse(), transformFkeyGetPrimaryKey(), transformGenericOptions(), transformIndexConstraint(), transformRowExpr(), transformXmlExpr(), ts_headline_byid_opt(), tt_setup_firstcall(), type_is_collatable(), TypeCreate(), TypenameGetTypid(), TypeShellMake(), validate_index_heapscan(), varstr_cmp(), and verify_dictoptions().

#define PG_BINARY   0
#define PG_BINARY_A   "a"

Definition at line 930 of file c.h.

Referenced by dumpDatabases(), and SetOutput().

#define PG_BINARY_R   "r"
#define PG_BINARY_W   "w"
#define PG_TEXTDOMAIN (   domain  )     (domain "-" PG_MAJORVERSION)

Definition at line 903 of file c.h.

Referenced by errstart(), format_elog_string(), main(), regression_main(), and set_pglocale_pgservice().

#define pg_unreachable (  )     abort()

Definition at line 831 of file c.h.

#define PG_USED_FOR_ASSERTS_ONLY   __attribute__((unused))

Definition at line 877 of file c.h.

Referenced by setop_fill_hash_table(), slist_delete(), and XLogPageRead().

#define PGDLLEXPORT

Definition at line 960 of file c.h.

#define PGDLLIMPORT

Definition at line 957 of file c.h.

#define PointerIsAligned (   pointer,
  type 
)    (((intptr_t)(pointer) % (sizeof (type))) == 0)

Definition at line 487 of file c.h.

#define PointerIsValid (   pointer  )     ((const void*)(pointer) != NULL)
#define RegProcedureIsValid (   p  )     OidIsValid(p)
#define SHORTALIGN (   LEN  )     TYPEALIGN(ALIGNOF_SHORT, (LEN))
#define SHORTALIGN_DOWN (   LEN  )     TYPEALIGN_DOWN(ALIGNOF_SHORT, (LEN))

Definition at line 547 of file c.h.

#define sigjmp_buf   jmp_buf
#define siglongjmp   longjmp

Definition at line 984 of file c.h.

Referenced by handle_sigint(), and pg_re_throw().

#define SIGNAL_ARGS   int postgres_signal_arg

Definition at line 973 of file c.h.

#define sigsetjmp (   x,
  y 
)    setjmp(x)
#define SQL_STR_DOUBLE (   ch,
  escape_backslash 
)    ((ch) == '\'' || ((ch) == '\\' && (escape_backslash)))
#define STATIC_IF_INLINE

Definition at line 850 of file c.h.

#define StaticAssertExpr (   condition,
  errmessage 
)    StaticAssertStmt(condition, errmessage)

Definition at line 647 of file c.h.

#define StaticAssertStmt (   condition,
  errmessage 
)    ((void) sizeof(struct { int static_assert_failure : (condition) ? 1 : -1; }))

Definition at line 645 of file c.h.

Referenced by hstoreValidOldFormat().

#define STATUS_EOF   (-2)

Definition at line 864 of file c.h.

Referenced by auth_failed().

#define STATUS_ERROR   (-1)

Definition at line 863 of file c.h.

Referenced by ProcSleep().

#define STATUS_FOUND   (1)

Definition at line 865 of file c.h.

Referenced by LockAcquireExtended().

#define STATUS_OK   (0)
#define STATUS_WAITING   (2)

Definition at line 866 of file c.h.

Referenced by ProcSleep(), ProcWakeup(), and RemoveFromWaitQueue().

#define StrNCpy (   dst,
  src,
  len 
)
Value:
do \
    { \
        char * _dst = (dst); \
        Size _len = (len); \
\
        if (_len > 0) \
        { \
            strncpy(_dst, (src), _len); \
            _dst[_len-1] = '\0'; \
        } \
    } while (0)

Definition at line 718 of file c.h.

Referenced by abstime2tm(), ChooseConstraintName(), ChooseRelationName(), DCH_cache_getnew(), DefineRelation(), ExecuteRecoveryCommand(), find_my_exec(), namestrcpy(), NUM_cache_getnew(), pg_get_userbyid(), RestoreArchivedFile(), SimpleLruInit(), and StartPrepare().

#define TopSubTransactionId   ((SubTransactionId) 1)

Definition at line 361 of file c.h.

#define true   ((bool) 1)

Definition at line 190 of file c.h.

#define TRUE   1
#define TYPEALIGN (   ALIGNVAL,
  LEN 
)    (((intptr_t) (LEN) + ((ALIGNVAL) - 1)) & ~((intptr_t) ((ALIGNVAL) - 1)))

Definition at line 533 of file c.h.

Referenced by BootStrapXLOG(), prepare_buf(), and XLOGShmemInit().

#define TYPEALIGN_DOWN (   ALIGNVAL,
  LEN 
)    (((intptr_t) (LEN)) & ~((intptr_t) ((ALIGNVAL) - 1)))

Definition at line 544 of file c.h.

#define UINT64CONST (   x  )     ((uint64) x)

Definition at line 295 of file c.h.

Referenced by ean2isn(), ean2string(), and FindEndOfXLOG().

#define VARHDRSZ   ((int32) sizeof(int32))

Definition at line 400 of file c.h.

Referenced by add_block_entropy(), anychar_typmodin(), anychar_typmodout(), apply_typmod(), array_send(), binary_decode(), binary_encode(), bitsubstring(), bpchar(), bpchar_input(), bpcharoctetlen(), bytea_string_agg_finalfn(), byteaeq(), byteain(), byteane(), byteaoctetlen(), bytearecv(), byteatrim(), char_bpchar(), char_text(), chr(), CopyOneRowTo(), copytext(), create_mbuf_from_vardata(), cstring_to_text_with_len(), decrypt_internal(), ECPGget_desc(), encrypt_internal(), find_provider(), formTextDatum(), gbt_bit_xfrm(), gbt_var_key_copy(), gbt_var_key_readable(), gbt_var_node_truncate(), gbt_var_penalty(), get_raw_page_internal(), getbytealen(), ghstore_consistent(), gin_extract_hstore_query(), gin_extract_query_trgm(), gin_extract_value_trgm(), gtrgm_compress(), gtrgm_consistent(), gtrgm_distance(), heap_tuple_untoast_attr(), heap_tuple_untoast_attr_slice(), hstore_hash(), hstore_slice_to_array(), init_work(), interval_to_char(), inv_truncate(), inv_write(), json_recv(), loread(), lpad(), make_greater_string(), makeitem(), map_sql_type_to_xml_name(), map_sql_type_to_xmlschema_type(), myFormatType(), numeric(), numeric_maximum_size(), numeric_to_number(), numeric_transform(), numerictypmodin(), numerictypmodout(), optionListToArray(), pg_armor(), pg_convert(), pg_dearmor(), pg_decrypt(), pg_decrypt_iv(), pg_digest(), pg_encrypt(), pg_encrypt_iv(), pg_file_write(), pg_hmac(), pg_random_bytes(), pgp_key_id_w(), pq_endtypsend(), printtup(), printtup_internal_20(), quote_literal(), read_binary_file(), read_text_file(), record_send(), repeat(), rpad(), SendFunctionResult(), show_trgm(), similar_escape(), similarity(), sort(), spg_text_inner_consistent(), spg_text_leaf_consistent(), string_to_bytea_const(), text_char(), text_length(), text_reverse(), text_substring(), texteq(), textne(), textoctetlen(), timestamp_to_char(), timestamptz_to_char(), to_tsvector_byid(), toast_fetch_datum(), toast_fetch_datum_slice(), toast_save_datum(), transformRelOptions(), translate(), ts_headline_byid_opt(), ts_lexize(), ts_stat_sql(), tsquerytree(), tsvector_update_trigger(), type_maximum_size(), unaccent_dict(), xml_recv(), and xslt_process().


Typedef Documentation

typedef uint16 bits16

Definition at line 260 of file c.h.

typedef uint32 bits32

Definition at line 261 of file c.h.

typedef uint8 bits8

Definition at line 259 of file c.h.

typedef char bool

Definition at line 186 of file c.h.

typedef bool* BoolPtr

Definition at line 198 of file c.h.

typedef struct varlena BpChar

Definition at line 409 of file c.h.

typedef struct varlena bytea

Definition at line 407 of file c.h.

typedef uint32 CommandId

Definition at line 368 of file c.h.

typedef float float4

Definition at line 337 of file c.h.

typedef double float8

Definition at line 338 of file c.h.

typedef unsigned int Index

Definition at line 322 of file c.h.

typedef signed short int16

Definition at line 239 of file c.h.

typedef signed int int32

Definition at line 240 of file c.h.

typedef signed char int8

Definition at line 238 of file c.h.

Definition at line 356 of file c.h.

Definition at line 364 of file c.h.

Definition at line 366 of file c.h.

typedef NameData* Name

Definition at line 452 of file c.h.

typedef struct nameData NameData
typedef signed int Offset

Definition at line 332 of file c.h.

typedef char* Pointer

Definition at line 229 of file c.h.

typedef Oid regproc

Definition at line 351 of file c.h.

Definition at line 352 of file c.h.

typedef int sig_atomic_t

Definition at line 306 of file c.h.

typedef size_t Size

Definition at line 313 of file c.h.

Definition at line 358 of file c.h.

typedef struct varlena text

Definition at line 408 of file c.h.

Definition at line 354 of file c.h.

typedef unsigned short uint16

Definition at line 251 of file c.h.

typedef unsigned int uint32

Definition at line 252 of file c.h.

typedef unsigned char uint8

Definition at line 250 of file c.h.

typedef struct varlena VarChar

Definition at line 410 of file c.h.


Function Documentation

int snprintf ( char *  str,
size_t  count,
const char *  fmt,
  ... 
)

Referenced by _ArchiveEntry(), _discoverArchiveFormat(), _EndBlob(), _LoadBlobs(), _MasterStartParallelItem(), _ShowOption(), _StartBlob(), _tarAddFile(), _tarGetHeader(), _tarPositionTo(), _WorkerJobDumpDirectory(), _WorkerJobRestoreCustom(), _WorkerJobRestoreDirectory(), addRangeTableEntryForValues(), AddToDataDirLockFile(), adjust_data_dir(), AlterObjectOwner_internal(), anybit_typmodout(), anychar_typmodout(), anytime_typmodout(), anytimestamp_typmodout(), autovac_report_activity(), BackendInitialize(), BaseBackup(), begin_remote_xact(), bootstrap_template1(), BSD44_derived_dlopen(), BSD44_derived_dlsym(), bt_metap(), bt_page_items(), bt_page_stats(), build_function_result_tupdesc_d(), build_pgstattuple_type(), build_row_from_class(), calculate_database_size(), calculate_relation_size(), calculate_tablespace_size(), cfopen_read(), cfopen_write(), check_data_dir(), check_for_isn_and_int8_passing_mismatch(), check_for_reg_data_type_usage(), check_foreign_key(), check_hard_link(), check_loadable_libraries(), check_log_duration(), check_primary_key(), check_timezone(), checkDataDir(), CheckRADIUSAuth(), ChooseConstraintName(), ChooseRelationName(), cidout(), cleanup(), CleanupBackgroundWorker(), CleanupBackupHistory(), CleanupPriorWALFiles(), close_cursor(), close_walfile(), cluster_conn_opts(), compile_pltcl_function(), complex_out(), connectDBStart(), connection_warnings(), convert_sourcefiles_in(), convertTSFunction(), copy_subdir_files(), copydir(), crashDumpHandler(), create_new_objects(), create_script_for_cluster_analyze(), create_script_for_old_cluster_deletion(), create_toast_table(), CreateLockFile(), CreateSocketLockFile(), CreateTrigger(), CustomizableCleanupPriorWALFiles(), CustomizableInitialize(), db_dir_size(), defGetString(), DeleteAllExportedSnapshotFiles(), describeDumpableObject(), disable_old_cluster(), do_compile(), do_edit(), do_init(), do_lo_list(), do_promote(), do_setval(), do_start(), do_start_bgworker(), do_watch(), doCustom(), dumpSequence(), ean2isn(), ean2string(), ecpg_execute(), ecpg_log(), ecpg_raise(), ecpg_raise_backend(), ecpg_start_test(), ECPGget_desc(), ECPGset_desc(), ECPGset_var(), exec_command(), exec_prog(), ExecBuildAuxRowMark(), ExecCreateTableAs(), ExecGrant_Largeobject(), ExecQueryUsingCursor(), existsTimeLineHistoryFile(), exitArchiveRecovery(), ExplainPropertyFloat(), ExplainPropertyInteger(), ExplainPropertyLong(), fetch_more_data(), find_other_exec(), FindStreamingStart(), finish_heap_swap(), float4_to_char(), float4out(), float8_to_char(), float8out(), footers_with_default(), fork_process(), format_operator_internal(), format_procedure_internal(), fuzzy_open_file(), generate_old_dump(), get_alternative_expectfile(), get_bin_version(), get_control_data(), get_db_conn(), get_db_infos(), get_dbstat_filename(), get_extension_aux_control_filename(), get_extension_control_directory(), get_extension_control_filename(), get_extension_script_directory(), get_extension_script_filename(), get_home_path(), get_major_server_version(), get_prompt(), get_rel_infos(), get_set_pwd(), get_sock_dir(), get_str_from_var_sci(), get_tablespace_paths(), get_tsearch_config_filename(), GetConfigOption(), GetConfigOptionByNum(), GetConfigOptionResetString(), GetDatabasePath(), getnameinfo(), getPgPassFilename(), ident_inet(), identify_system_timezone(), IdentifySystem(), ImportSnapshot(), init(), init_params(), init_ps_display(), initializeInput(), InitTempTableNamespace(), int4_to_char(), int_to_roman(), intervaltypmodout(), isolation_start_test(), join_path_components(), KeepFileRestoredFromArchive(), KillExistingArchiveStatus(), KillExistingXLOG(), libpqrcv_connect(), libpqrcv_identify_system(), libpqrcv_readtimelinehistoryfile(), libpqrcv_startstreaming(), listOneExtensionContents(), load_plpgsql(), load_relcache_init_file(), load_relmap_file(), load_resultmap(), logfile_getname(), macaddr_out(), main(), make_new_heap(), make_postgres(), make_template0(), network_out(), network_show(), new_9_0_populate_pg_largeobject_metadata(), nextval_internal(), numerictypmodout(), oidout(), old_8_3_check_for_name_data_type_usage(), old_8_3_check_for_tsquery_usage(), old_8_3_check_ltree_usage(), old_8_3_create_sequence_script(), old_8_3_invalidate_bpchar_pattern_ops_indexes(), old_8_3_invalidate_hash_gin_indexes(), old_8_3_rebuild_tsvector_tables(), open_result_files(), open_walfile(), OpenTemporaryFileInTablespace(), output(), page_header(), parseServiceInfo(), ParseTzFile(), perform_base_backup(), perform_fsync(), PerformPortalFetch(), pg_create_restore_point(), pg_current_xlog_insert_location(), pg_current_xlog_location(), pg_last_xlog_receive_location(), pg_last_xlog_replay_location(), pg_lock_status(), pg_perm_setlocale(), pg_rusage_show(), pg_signal_thread(), pg_size_pretty(), pg_start_backup(), pg_stat_get_wal_senders(), pg_stop_backup(), pg_switch_xlog(), pg_tablespace_location(), pg_tzenumerate_next(), pgarch_archiveXlog(), pgarch_readyXlog(), pgfdw_subxact_callback(), pgrowlocks(), pgstat_reset_remove_files(), pgstatindex(), pgtypes_fmt_replace(), PGTYPESdate_fmt_asc(), pgwin32_create_signal_listener(), pgwin32_get_dynamic_tokeninfo(), pid_lock_file_exists(), plperl_spi_prepare(), plpgsql_param_ref(), pltcl_init_interp(), pltcl_init_load_unknown(), pltcl_process_SPI_result(), pltcl_set_tuple_values(), pltcl_SPI_lastoid(), pltcl_SPI_prepare(), PLy_procedure_compile(), PLy_procedure_create(), PLy_procedure_munge_source(), poly2path(), PortalRun(), postgresAcquireSampleRowsFunc(), postgresEndForeignModify(), postgresReScanForeignScan(), PostmasterMain(), pqGetHomeDirectory(), prepare_foreign_modify(), preprocess_targetlist(), PrintControlValues(), PrintQueryStatus(), proc_exit(), process_psqlrc(), ProcessQuery(), progress_report(), prompt_for_password(), psql_command(), psql_start_test(), ReceiveAndUnpackTarFile(), ReceiveTarFile(), ReceiveXlogStream(), RecoverPreparedTransactions(), regclassout(), regconfigout(), regdictionaryout(), regoperout(), regprocout(), regression_main(), regtypeout(), RelationCacheInitFilePreInvalidate(), RelationCacheInitFileRemove(), RelationCacheInitFileRemoveInDir(), relpathbackend(), RemoveAttributeById(), RemoveOldXlogFiles(), RemovePgTempFiles(), RemovePgTempFilesInDir(), RemovePgTempRelationFiles(), RemovePgTempRelationFilesInDbspace(), replace_variables(), report_fork_failure_to_client(), ResetUnloggedRelations(), ResetUnloggedRelationsInDbspaceDir(), ResetUnloggedRelationsInTablespaceDir(), RestoreArchivedFile(), results_differ(), RI_Initial_Check(), rmtree(), runShellCommand(), scan_available_timezones(), select_default_timezone(), send_message_to_frontend(), SendBaseBackup(), sendDir(), sendTablespace(), SendXlogRecPtrResult(), set_dl_error(), set_info_version(), set_pglocale_pgservice(), setup_auth(), setup_collation(), setup_config(), setup_conversion(), setup_depend(), setup_description(), setup_dictionary(), setup_privileges(), setup_schema(), setup_sysviews(), show_log_file_mode(), show_tcp_keepalives_count(), show_tcp_keepalives_idle(), show_tcp_keepalives_interval(), show_trgm(), show_unix_socket_permissions(), SlruScanDirCbDeleteAll(), SlruScanDirCbDeleteCutoff(), sql_exec_dumpalldbs(), sql_exec_dumpalltables(), sql_exec_dumpalltbspc(), sql_exec_searchtables(), standard_ProcessUtility(), start_postmaster(), StartChildProcess(), StartLogStreamer(), StartReplication(), StartupXLOG(), stop_postmaster(), StreamServerPort(), test_config_settings(), test_postmaster_connection(), threadRun(), tidout(), timeofday(), timetravel(), transfer_relfile(), transformRowExpr(), transformSetOperationTree(), typenameTypeMod(), useful_strerror(), vacuum_db(), vacuumlo(), validate_exec(), ValidatePgVersion(), ValidateXLOGDirectoryStructure(), ValidXLogPageHeader(), VXIDGetDatum(), wait_result_to_str(), walkdir(), WalRcvWaitForStartPosition(), widget_in(), write_relcache_init_file(), write_relmap_file(), writeTimeLineHistory(), writeTimeLineHistoryFile(), xidout(), XLogArchiveIsBusy(), XLogFileCopy(), XLogFileInit(), XLogFileRead(), XLogSend(), XLOGShmemSize(), XLogWalRcvFlush(), and yesno_prompt().

int int vsnprintf ( char *  str,
size_t  count,
const char *  fmt,
va_list  args 
)