PostgreSQL Source Code
git master
|
#include "postgres.h"
#include <limits.h>
#include "access/htup_details.h"
#include "access/relation.h"
#include "access/reloptions.h"
#include "access/table.h"
#include "catalog/namespace.h"
#include "catalog/pg_foreign_data_wrapper.h"
#include "catalog/pg_foreign_server.h"
#include "catalog/pg_type.h"
#include "catalog/pg_user_mapping.h"
#include "executor/spi.h"
#include "foreign/foreign.h"
#include "funcapi.h"
#include "lib/stringinfo.h"
#include "libpq-fe.h"
#include "libpq/libpq-be.h"
#include "libpq/libpq-be-fe-helpers.h"
#include "mb/pg_wchar.h"
#include "miscadmin.h"
#include "parser/scansup.h"
#include "utils/acl.h"
#include "utils/builtins.h"
#include "utils/fmgroids.h"
#include "utils/guc.h"
#include "utils/lsyscache.h"
#include "utils/memutils.h"
#include "utils/rel.h"
#include "utils/varlena.h"
Go to the source code of this file.
Data Structures | |
struct | remoteConn |
struct | storeInfo |
struct | remoteConnHashEnt |
Macros | |
#define | NUMCONN 16 |
#define | DBLINK_NOTIFY_COLS 3 |
Typedefs | |
typedef struct remoteConn | remoteConn |
typedef struct storeInfo | storeInfo |
typedef struct remoteConnHashEnt | remoteConnHashEnt |
Variables | |
PG_MODULE_MAGIC | |
static remoteConn * | pconn = NULL |
static HTAB * | remoteConnHash = NULL |
static uint32 | dblink_we_connect = 0 |
static uint32 | dblink_we_get_conn = 0 |
static void PGresult * | res |
static void PGresult const char * | p2 |
typedef struct remoteConn remoteConn |
typedef struct remoteConnHashEnt remoteConnHashEnt |
|
static |
Definition at line 3032 of file dblink.c.
References Assert(), conn, GetConfigOption(), GUC_ACTION_SAVE, i, lengthof, NewGUCNestLevel(), PGC_S_SESSION, PGC_USERSET, PQparameterStatus(), and set_config_option().
Referenced by materializeResult(), and storeQueryResult().
|
static |
Definition at line 2540 of file dblink.c.
References HASHCTL::entrysize, hash_create(), HASH_ELEM, HASH_STRINGS, HASHCTL::keysize, NAMEDATALEN, and NUMCONN.
Referenced by createNewConnection(), deleteConnection(), and getConnectionByName().
|
static |
Definition at line 2552 of file dblink.c.
References remoteConn::conn, createConnHash(), ereport, errcode(), ERRCODE_DUPLICATE_OBJECT, errmsg(), ERROR, HASH_ENTER, hash_search(), sort-test::key, libpqsrv_disconnect(), remoteConnHashEnt::name, name, pfree(), pstrdup(), remoteConnHashEnt::rconn, remoteConnHash, strlcpy(), and truncate_identifier().
Referenced by dblink_connect().
Datum dblink_build_sql_delete | ( | PG_FUNCTION_ARGS | ) |
Definition at line 1710 of file dblink.c.
References AccessShareLock, ACL_SELECT, cstring_to_text(), ereport, errcode(), errmsg(), ERROR, get_rel_from_relname(), get_sql_delete(), get_text_array_contents(), PG_GETARG_ARRAYTYPE_P, PG_GETARG_INT32, PG_GETARG_POINTER, PG_GETARG_TEXT_PP, PG_RETURN_TEXT_P, relation_close(), and validate_pkattnums().
Datum dblink_build_sql_insert | ( | PG_FUNCTION_ARGS | ) |
Definition at line 1621 of file dblink.c.
References AccessShareLock, ACL_SELECT, cstring_to_text(), ereport, errcode(), errmsg(), ERROR, get_rel_from_relname(), get_sql_insert(), get_text_array_contents(), PG_GETARG_ARRAYTYPE_P, PG_GETARG_INT32, PG_GETARG_POINTER, PG_GETARG_TEXT_PP, PG_RETURN_TEXT_P, relation_close(), and validate_pkattnums().
Datum dblink_build_sql_update | ( | PG_FUNCTION_ARGS | ) |
Definition at line 1786 of file dblink.c.
References AccessShareLock, ACL_SELECT, cstring_to_text(), ereport, errcode(), errmsg(), ERROR, get_rel_from_relname(), get_sql_update(), get_text_array_contents(), PG_GETARG_ARRAYTYPE_P, PG_GETARG_INT32, PG_GETARG_POINTER, PG_GETARG_TEXT_PP, PG_RETURN_TEXT_P, relation_close(), and validate_pkattnums().
Datum dblink_cancel_query | ( | PG_FUNCTION_ARGS | ) |
Definition at line 1341 of file dblink.c.
References conn, cstring_to_text(), dblink_get_named_conn(), dblink_init(), PG_GETARG_TEXT_PP, PG_RETURN_TEXT_P, PQcancel(), PQfreeCancel(), PQgetCancel(), res, and text_to_cstring().
Datum dblink_close | ( | PG_FUNCTION_ARGS | ) |
Definition at line 481 of file dblink.c.
References appendStringInfo(), buf, remoteConn::conn, conn, cstring_to_text(), dblink_init(), dblink_res_error(), get_fn_expr_argtype(), getConnectionByName(), initStringInfo(), remoteConn::newXactForCursor, remoteConn::openCursorCount, pconn, PG_GETARG_BOOL, PG_GETARG_TEXT_PP, PG_NARGS, PG_RETURN_TEXT_P, PGRES_COMMAND_OK, PQclear(), PQexec(), PQresultStatus(), res, and text_to_cstring().
Datum dblink_connect | ( | PG_FUNCTION_ARGS | ) |
Definition at line 267 of file dblink.c.
References remoteConn::conn, conn, CONNECTION_BAD, connstr, createNewConnection(), cstring_to_text(), dblink_connstr_check(), dblink_init(), dblink_security_check(), dblink_we_connect, ereport, errcode(), errdetail_internal(), errmsg(), ERROR, get_connect_string(), GetDatabaseEncoding(), GetDatabaseEncodingName(), libpqsrv_connect(), libpqsrv_disconnect(), MemoryContextAlloc(), remoteConn::newXactForCursor, remoteConn::openCursorCount, pchomp(), pconn, pfree(), PG_GETARG_TEXT_PP, PG_NARGS, PG_RETURN_TEXT_P, PQclientEncoding(), PQerrorMessage(), PQsetClientEncoding(), PQstatus(), text_to_cstring(), TopMemoryContext, and WaitEventExtensionNew().
|
static |
Definition at line 2677 of file dblink.c.
References be_gssapi_get_delegation(), connstr, dblink_connstr_has_pw(), ereport, errcode(), errdetail(), errmsg(), ERROR, MyProcPort, and superuser().
Referenced by dblink_connect(), and dblink_get_conn().
|
static |
Definition at line 2642 of file dblink.c.
References connstr, options, PQconninfoFree(), PQconninfoParse(), and option::val.
Referenced by dblink_connstr_check(), and dblink_security_check().
Datum dblink_current_query | ( | PG_FUNCTION_ARGS | ) |
Datum dblink_disconnect | ( | PG_FUNCTION_ARGS | ) |
Definition at line 350 of file dblink.c.
References remoteConn::conn, conn, cstring_to_text(), dblink_init(), deleteConnection(), getConnectionByName(), libpqsrv_disconnect(), pconn, pfree(), PG_GETARG_TEXT_PP, PG_NARGS, PG_RETURN_TEXT_P, and text_to_cstring().
Datum dblink_error_message | ( | PG_FUNCTION_ARGS | ) |
Definition at line 1374 of file dblink.c.
References conn, cstring_to_text(), dblink_get_named_conn(), dblink_init(), pchomp(), PG_GETARG_TEXT_PP, PG_RETURN_TEXT_P, PQerrorMessage(), and text_to_cstring().
Datum dblink_exec | ( | PG_FUNCTION_ARGS | ) |
Definition at line 1394 of file dblink.c.
References remoteConn::conn, conn, cstring_to_text(), dblink_get_conn(), dblink_init(), dblink_res_error(), elog(), ereport, errcode(), errmsg(), ERROR, get_fn_expr_argtype(), libpqsrv_disconnect(), pconn, PG_END_TRY, PG_FINALLY, PG_GETARG_BOOL, PG_GETARG_TEXT_PP, PG_NARGS, PG_RETURN_TEXT_P, PG_TRY, PGRES_COMMAND_OK, PGRES_TUPLES_OK, PQclear(), PQcmdStatus(), PQexec(), PQresultStatus(), res, and text_to_cstring().
Datum dblink_fdw_validator | ( | PG_FUNCTION_ARGS | ) |
Definition at line 1936 of file dblink.c.
References DefElem::defname, ereport, errcode(), errdetail(), errhint(), errmsg(), ERROR, getClosestMatch(), initClosestMatch(), is_valid_dblink_option(), _PQconninfoOption::keyword, lfirst, match_state, PG_GETARG_DATUM, PG_GETARG_OID, PG_RETURN_VOID, PQconndefaults(), untransformRelOptions(), and updateClosestMatch().
Datum dblink_fetch | ( | PG_FUNCTION_ARGS | ) |
Definition at line 568 of file dblink.c.
References appendStringInfo(), buf, remoteConn::conn, conn, dblink_init(), dblink_res_error(), ereport, errcode(), errmsg(), ERROR, get_fn_expr_argtype(), getConnectionByName(), initStringInfo(), materializeResult(), pconn, PG_GETARG_BOOL, PG_GETARG_INT32, PG_GETARG_TEXT_PP, PG_NARGS, PGRES_COMMAND_OK, PGRES_TUPLES_OK, PQclear(), PQexec(), PQresultStatus(), prepTuplestoreResult(), res, and text_to_cstring().
|
static |
Definition at line 186 of file dblink.c.
References remoteConn::conn, conn, CONNECTION_BAD, connstr, dblink_connstr_check(), dblink_security_check(), dblink_we_get_conn, ereport, errcode(), errdetail_internal(), errmsg(), ERROR, get_connect_string(), getConnectionByName(), GetDatabaseEncoding(), GetDatabaseEncodingName(), libpqsrv_connect(), libpqsrv_disconnect(), pchomp(), PQclientEncoding(), PQerrorMessage(), PQsetClientEncoding(), PQstatus(), and WaitEventExtensionNew().
Referenced by dblink_exec(), and dblink_record_internal().
Datum dblink_get_connections | ( | PG_FUNCTION_ARGS | ) |
Definition at line 1282 of file dblink.c.
References accumArrayResult(), CStringGetTextDatum, CurrentMemoryContext, hash_seq_init(), hash_seq_search(), makeArrayResult(), remoteConnHashEnt::name, PG_RETURN_DATUM, PG_RETURN_NULL, and remoteConnHash.
|
static |
Definition at line 239 of file dblink.c.
References remoteConn::conn, and getConnectionByName().
Referenced by dblink_cancel_query(), dblink_error_message(), dblink_get_notify(), dblink_is_busy(), dblink_record_internal(), and dblink_send_query().
Datum dblink_get_notify | ( | PG_FUNCTION_ARGS | ) |
Definition at line 1883 of file dblink.c.
References pgNotify::be_pid, remoteConn::conn, conn, CStringGetTextDatum, dblink_get_named_conn(), dblink_init(), DBLINK_NOTIFY_COLS, pgNotify::extra, InitMaterializedSRF(), Int32GetDatum(), pconn, PG_GETARG_TEXT_PP, PG_NARGS, PQconsumeInput(), PQfreemem(), PQnotifies(), pgNotify::relname, ReturnSetInfo::setDesc, ReturnSetInfo::setResult, text_to_cstring(), tuplestore_putvalues(), and values.
Datum dblink_get_pkey | ( | PG_FUNCTION_ARGS | ) |
Definition at line 1497 of file dblink.c.
References AccessShareLock, ACL_SELECT, FuncCallContext::attinmeta, BuildTupleFromCStrings(), FuncCallContext::call_cntr, CreateTemplateTupleDesc(), get_pkey_attnames(), get_rel_from_relname(), HeapTupleGetDatum(), if(), FuncCallContext::max_calls, MemoryContextSwitchTo(), FuncCallContext::multi_call_memory_ctx, palloc_array, PG_GETARG_TEXT_PP, psprintf(), relation_close(), SRF_FIRSTCALL_INIT, SRF_IS_FIRSTCALL, SRF_PERCALL_SETUP, SRF_RETURN_DONE, SRF_RETURN_NEXT, TupleDescGetAttInMetadata(), TupleDescInitEntry(), FuncCallContext::user_fctx, and values.
Datum dblink_get_result | ( | PG_FUNCTION_ARGS | ) |
Definition at line 694 of file dblink.c.
References dblink_record_internal().
|
static |
Definition at line 251 of file dblink.c.
References remoteConn::conn, MemoryContextAlloc(), remoteConn::newXactForCursor, remoteConn::openCursorCount, pconn, and TopMemoryContext.
Referenced by dblink_cancel_query(), dblink_close(), dblink_connect(), dblink_disconnect(), dblink_error_message(), dblink_exec(), dblink_fetch(), dblink_get_notify(), dblink_is_busy(), dblink_open(), and dblink_record_internal().
Datum dblink_is_busy | ( | PG_FUNCTION_ARGS | ) |
Definition at line 1317 of file dblink.c.
References conn, dblink_get_named_conn(), dblink_init(), PG_GETARG_TEXT_PP, PG_RETURN_INT32, PQconsumeInput(), PQisBusy(), and text_to_cstring().
Datum dblink_open | ( | PG_FUNCTION_ARGS | ) |
Definition at line 388 of file dblink.c.
References appendStringInfo(), buf, remoteConn::conn, conn, cstring_to_text(), dblink_init(), dblink_res_error(), get_fn_expr_argtype(), getConnectionByName(), initStringInfo(), remoteConn::newXactForCursor, remoteConn::openCursorCount, pconn, PG_GETARG_BOOL, PG_GETARG_TEXT_PP, PG_NARGS, PG_RETURN_TEXT_P, PGRES_COMMAND_OK, PQclear(), PQexec(), PQresultStatus(), PQTRANS_IDLE, PQtransactionStatus(), res, and text_to_cstring().
Datum dblink_record | ( | PG_FUNCTION_ARGS | ) |
Definition at line 662 of file dblink.c.
References dblink_record_internal().
|
static |
Definition at line 700 of file dblink.c.
References remoteConn::conn, conn, dblink_get_conn(), dblink_get_named_conn(), dblink_init(), dblink_res_error(), elog(), ERROR, FunctionCallInfoBaseData::flinfo, get_fn_expr_argtype(), libpqsrv_disconnect(), materializeQueryResult(), materializeResult(), pconn, PG_END_TRY, PG_FINALLY, PG_GETARG_BOOL, PG_GETARG_TEXT_PP, PG_NARGS, PG_TRY, PGRES_COMMAND_OK, PGRES_TUPLES_OK, PQgetResult(), PQresultStatus(), prepTuplestoreResult(), res, and text_to_cstring().
Referenced by dblink_get_result(), and dblink_record().
|
static |
Definition at line 2705 of file dblink.c.
References conn, ereport, errcode(), errcontext, errdetail_internal(), errhint(), errmsg(), errmsg_internal(), ERROR, fmt, MAKE_SQLSTATE, NOTICE, pchomp(), PG_DIAG_CONTEXT, PG_DIAG_MESSAGE_DETAIL, PG_DIAG_MESSAGE_HINT, PG_DIAG_MESSAGE_PRIMARY, PG_DIAG_SQLSTATE, PQclear(), PQerrorMessage(), PQresultErrorField(), res, va_end(), va_start(), vsnprintf, and xpstrdup().
Referenced by dblink_close(), dblink_exec(), dblink_fetch(), dblink_open(), and dblink_record_internal().
|
static |
Definition at line 2607 of file dblink.c.
References be_gssapi_get_delegation(), conn, connstr, dblink_connstr_has_pw(), ereport, errcode(), errdetail(), errhint(), errmsg(), ERROR, libpqsrv_disconnect(), MyProcPort, pfree(), PQconnectionUsedGSSAPI(), PQconnectionUsedPassword(), and superuser().
Referenced by dblink_connect(), and dblink_get_conn().
Datum dblink_send_query | ( | PG_FUNCTION_ARGS | ) |
Definition at line 669 of file dblink.c.
References conn, dblink_get_named_conn(), elog(), ERROR, NOTICE, pchomp(), PG_GETARG_TEXT_PP, PG_NARGS, PG_RETURN_INT32, PQerrorMessage(), PQsendQuery(), and text_to_cstring().
|
static |
Definition at line 2581 of file dblink.c.
References createConnHash(), ereport, errcode(), errmsg(), ERROR, HASH_REMOVE, hash_search(), sort-test::key, name, pstrdup(), remoteConnHash, and truncate_identifier().
Referenced by dblink_disconnect().
Referenced by _bt_allequalimage(), _bt_allocbuf(), _bt_buildadd(), _bt_check_rowcompare(), _bt_check_third_page(), _bt_check_unique(), _bt_compare_scankey_args(), _bt_dedup_finish_pending(), _bt_dedup_pass(), _bt_delitems_delete(), _bt_delitems_vacuum(), _bt_endpoint(), _bt_find_extreme_element(), _bt_findsplitloc(), _bt_finish_split(), _bt_first(), _bt_get_endpoint(), _bt_getroot(), _bt_gettrueroot(), _bt_insert_parent(), _bt_insertonpg(), _bt_mark_page_halfdead(), _bt_mark_scankey_required(), _bt_moveright(), _bt_newlevel(), _bt_preprocess_array_keys(), _bt_preprocess_keys(), _bt_restore_page(), _bt_sort_array_elements(), _bt_sortaddtup(), _bt_split(), _bt_start_vacuum(), _bt_stepright(), _bt_swap_posting(), _bt_unlink_halfdead_page(), _bt_walk_left(), _copyA_Const(), _equalList(), _hash_datum2hashkey_type(), _hash_firstfreebit(), _hash_freeovflpage(), _hash_getbuf(), _hash_getbuf_with_condlock_cleanup(), _hash_getbuf_with_strategy(), _hash_getinitbuf(), _hash_getnewbuf(), _hash_init(), _hash_pgaddmultitup(), _hash_pgaddtup(), _jumbleA_Const(), _jumbleList(), _jumbleNode(), _jumbleRangeTblEntry(), _ltree_consistent(), _mdfd_getseg(), _metaphone(), _outA_Expr(), _outConstraint(), _outList(), _outRangeTblEntry(), _PG_init(), _readA_Const(), _readA_Expr(), _readBitmapset(), _readBoolExpr(), _readConstraint(), _readExtensibleNode(), _readRangeTblEntry(), _SPI_cursor_operation(), _SPI_pquery(), _tarWriteHeader(), AbortSubTransaction(), AbortTransaction(), aclcheck_error(), aclcheck_error_col(), acldefault(), acldefault_sql(), aclmask(), aclmask_direct(), AcquireRewriteLocks(), add_base_rels_to_query(), add_cast_to(), add_function_cost(), add_function_defaults(), add_nullingrels_if_needed(), add_row_identity_var(), add_vars_to_targetlist(), AddFileToBackupManifest(), addFkRecurseReferenced(), addLeafTuple(), addNode(), addOrReplaceTuple(), addRangeTableEntryForENR(), AddRelationNewConstraints(), AddRoleMems(), AddSubscriptionRelState(), addTargetToSortList(), AddWaitEventToSet(), adjust_appendrel_attrs_multilevel(), adjust_appendrel_attrs_mutator(), adjust_child_relids_multilevel(), adjust_inherited_attnums(), adjust_inherited_attnums_multilevel(), adjust_partition_colnos_using_map(), adjust_view_column_set(), AdjustIntervalForTypmod(), AdjustNotNullInheritance(), AdjustNotNullInheritance1(), advance_windowaggregate_base(), AdvanceXLInsertBuffer(), AfterTriggerExecute(), afterTriggerInvokeEvents(), AfterTriggerSaveEvent(), agg_args_support_sendreceive(), AggregateCreate(), AggRegisterCallback(), AlignedAllocFree(), allocacl(), allocate_reloption(), AllocateDir(), AllocateFile(), AllocateVfd(), AllocSetFree(), AllocSetRealloc(), AlterCollation(), AlterDatabaseRefreshColl(), AlterDomainAddConstraint(), AlterDomainDefault(), AlterDomainDropConstraint(), AlterDomainNotNull(), AlterDomainValidateConstraint(), AlterEnum(), AlterExtensionNamespace(), AlterFunction(), AlterObjectNamespace_internal(), AlterObjectOwner_internal(), AlterObjectRename_internal(), AlterOperator(), AlterOpFamilyAdd(), AlterOpFamilyDrop(), AlterRelationNamespaceInternal(), AlterRole(), AlterSchemaOwner_oid(), AlterSequence(), AlterStatistics(), AlterSubscription(), AlterSystemSetConfigFile(), AlterTableGetLockLevel(), AlterTSDictionary(), AlterTypeNamespaceInternal(), AlterTypeOwner_oid(), AlterTypeOwnerInternal(), AlterTypeRecurse(), AlterUserMapping(), amvalidate(), analyzeCTE(), AnonymousShmemDetach(), appendFunctionName(), appendOrderByClause(), appendOrderBySuffix(), AppendStringToManifest(), apply_handle_delete_internal(), apply_handle_stream_abort(), apply_handle_stream_commit(), apply_handle_stream_prepare(), apply_handle_stream_start(), apply_handle_stream_stop(), apply_handle_tuple_routing(), apply_handle_update_internal(), apply_map_update(), apply_pathtarget_labeling_to_tlist(), apply_spooled_messages(), ApplyExtensionUpdates(), ApplyRetrieveRule(), array_agg_array_combine(), array_agg_array_transfn(), array_agg_combine(), array_agg_deserialize(), array_agg_transfn(), array_create_iterator(), array_exec_setup(), array_fill(), array_fill_with_lower_bounds(), array_typanalyze(), ASN1_STRING_to_text(), assign_client_encoding(), assign_collations_walker(), assignOperTypes(), AssignPostmasterChildSlot(), assignProcTypes(), AssignTransactionId(), Async_Listen(), Async_Notify(), Async_Unlisten(), Async_UnlistenAll(), ATAddForeignKeyConstraint(), AtCleanup_Portals(), AtCommit_Notify(), ATDetachCheckNoForeignKeyRefs(), AtEOSubXact_cleanup(), AtEOSubXact_HashTables(), AtEOSubXact_Parallel(), AtEOXact_cleanup(), AtEOXact_HashTables(), AtEOXact_Parallel(), AtEOXact_Snapshot(), ATExecAddColumn(), ATExecAddConstraint(), ATExecAddIndexConstraint(), ATExecAddOf(), ATExecAlterColumnType(), ATExecChangeOwner(), ATExecCmd(), ATExecDetachPartition(), ATExecDropColumn(), ATExecDropExpression(), ATExecDropNotNull(), ATExecDropOf(), ATExecForceNoForceRowSecurity(), ATExecReplicaIdentity(), ATExecSetIdentity(), ATExecSetRelOptions(), ATExecSetRowSecurity(), ATParseTransformCmd(), ATPostAlterTypeCleanup(), ATPostAlterTypeParse(), ATPrepCmd(), ATRewriteTable(), ATSimplePermissions(), AtStart_GUC(), AtSubCleanup_Portals(), AttachSession(), attnumAttName(), attnumCollationId(), attnumTypeId(), AttrDefaultFetch(), autoinc(), AutoVacuumUpdateCostLimit(), AutoVacWorkerMain(), AuxiliaryProcessMain(), AuxiliaryProcKill(), BackgroundWorkerMain(), BackgroundWorkerStateChange(), basic_archive_file_internal(), be_gssapi_write(), be_lo_close(), be_lo_open(), be_tls_get_certificate_hash(), before_stmt_triggers_fired(), begin_remote_xact(), BeginInternalSubTransaction(), BeginTransactionBlock(), BgBufferSync(), binary_decode(), binary_encode(), binary_upgrade_create_empty_extension(), binary_upgrade_logical_slot_has_caught_up(), binaryheap_add(), binaryheap_add_unordered(), BipartiteMatch(), bitmap_subplan_mark_shared(), BitmapAdjustPrefetchIterator(), BitmapHeapNext(), bitposition(), blbuild(), blinsert(), bloom_init(), bloomBuildCallback(), blvalidate(), bms_add_member(), bms_add_range(), bms_del_member(), bms_is_member(), bms_make_singleton(), bms_overlap_list(), bms_singleton_member(), BogusFree(), BogusGetChunkContext(), BogusGetChunkSpace(), BogusRealloc(), bool_accum_inv(), booltestsel(), boot_get_type_io_data(), boot_openrel(), BootstrapModeMain(), BootstrapToastTable(), bqarr_in(), brin_bloom_consistent(), brin_doinsert(), brin_doupdate(), brin_inclusion_consistent(), brin_metapage_info(), brin_minmax_consistent(), brin_minmax_multi_consistent(), brin_page_items(), brin_redo(), brin_xlog_insert_update(), brin_xlog_samepage_update(), brinbuild(), brincostestimate(), brinvalidate(), bt_check_every_level(), bt_check_level_from_leftmost(), bt_downlink_missing_check(), bt_metap(), bt_multi_page_stats(), bt_page_items_bytea(), bt_page_items_internal(), bt_page_print_tuples(), bt_page_stats_internal(), bt_target_page_check(), btbuild(), btcostestimate(), btree_redo(), btree_xlog_dedup(), btree_xlog_insert(), btree_xlog_mark_page_halfdead(), btree_xlog_split(), btree_xlog_unlink_page(), btree_xlog_updates(), btvalidate(), BufFileAppend(), BufFileDeleteFileSet(), BufFileSeek(), BufTableDelete(), build_coercion_expression(), build_column_default(), build_concat_foutcache(), build_datatype(), build_EvalXFuncInt(), build_expression_pathkey(), build_function_result_tupdesc_d(), build_index_tlist(), build_joinrel_tlist(), build_mss(), build_pgstattuple_type(), build_physical_tlist(), build_regexp_split_result(), build_replindex_scan_key(), build_row_from_vars(), build_server_final_message(), build_simple_rel(), build_subplan(), BuildDummyIndexInfo(), BuildIndexInfo(), buildMergedJoinVar(), BuildRelationExtStatistics(), BuildSpeculativeIndexInfo(), byteaout(), cache_locale_time(), cache_reduce_memory(), CachedPlanSetParentContext(), CacheInvalidateRelcacheByRelid(), CacheRegisterRelcacheCallback(), CacheRegisterSyscacheCallback(), calc_hist_selectivity(), calc_joinrel_size_estimate(), calc_multirangesel(), calc_rangesel(), call_pltcl_start_proc(), CallerFInfoFunctionCall1(), CallerFInfoFunctionCall2(), CallStmtResultDesc(), CallSyscacheCallbacks(), cancel_before_shmem_exit(), cannotCastJsonbValue(), CatalogCacheComputeHashValue(), CatalogCacheComputeTupleHashValue(), CatalogCacheInitializeCache(), check_amop_signature(), check_amproc_signature(), check_default_text_search_config(), check_domain_for_new_field(), check_encoding_conversion_args(), check_exclusion_or_unique_constraint(), check_float8_array(), check_foreign_key(), check_hash_func_signature(), check_hostname(), check_locale(), check_object_ownership(), check_on_shmem_exit_lists_are_empty(), check_primary_key(), check_role_grantor(), check_with_filler(), CheckArchiveTimeout(), CheckBufferIsPinnedOnce(), CheckConstraintFetch(), CheckDateTokenTable(), CheckForBufferLeaks(), CheckForLocalBufferLeaks(), CheckFunctionValidatorAccess(), CheckIndexCompatible(), CheckMyDatabase(), CheckPointLogicalRewriteHeap(), CheckPointReplicationSlots(), CheckPointSnapBuild(), CheckRecoveryConsistency(), CheckRelationLockedByMe(), CheckSASLAuth(), checkSplitConditions(), checkTargetlistEntrySQL92(), CheckValidResultRel(), CheckVarSlotCompatibility(), checkWellFormedRecursion(), checkWellFormedRecursionWalker(), checkWellFormedSelectStmt(), ChoosePortalStrategy(), ClassifyUtilityCommandAsReadOnly(), clause_selectivity_ext(), CleanupBackupHistory(), CleanUpLock(), CleanupProcSignalState(), CleanupSubTransaction(), CleanupTempFiles(), CleanupTransaction(), clear_subscription_skip_lsn(), clog_redo(), CloneFkReferenced(), CloneFkReferencing(), CloneRowTriggersToPartition(), ClosePipeStream(), closerel(), CloseTransientFile(), coerce_type(), CollationIsVisibleExt(), collectMatchesForHeapRow(), CommandCounterIncrement(), CommandIsReadOnly(), commit_ts_redo(), CommitSubTransaction(), CommitTransaction(), CommitTransactionCommand(), CommuteOpExpr(), compare_tlist_datatypes(), compare_values_of_enum(), compareDatetime(), CompareIndexInfo(), compareItems(), compareJsonbContainers(), compareJsonbScalarValue(), comparison_shim(), compile_plperl_function(), compile_pltcl_function(), compute_array_stats(), compute_function_attributes(), compute_new_xmax_infomask(), compute_tsvector_stats(), computeDelta(), computeDistance(), ComputeIndexAttrs(), computeLeafRecompressWALData(), config_enum_lookup_by_value(), connectby(), ConstraintSetParentConstraint(), construct_array_builtin(), ConstructTupleDescriptor(), ConversionCreate(), ConversionIsVisibleExt(), convert_aclright_to_string(), convert_subquery_pathkeys(), convert_testexpr_mutator(), convertJsonbScalar(), convertJsonbValue(), copy_plpgsql_datums(), copy_replication_slot(), copy_table_data(), CopyArrayEls(), CopyCachedPlan(), CopyConversionError(), copyObjectImpl(), CopyXLogRecordToWAL(), cost_bitmap_tree_node(), cost_qual_eval_walker(), count_usable_fds(), create_and_test_bloom(), create_append_plan(), create_bitmap_subplan(), create_ctescan_plan(), create_foreign_join_path(), create_foreign_modify(), create_gather_merge_plan(), create_hash_bounds(), create_indexscan_plan(), create_internal(), create_join_plan(), create_list_bounds(), create_merge_append_plan(), create_mergejoin_plan(), create_plan(), create_plan_recurse(), create_range_bounds(), create_scan_plan(), create_toast_table(), create_unique_plan(), create_worktablescan_plan(), CreateAnonymousSegment(), CreateCast(), CreateCheckPoint(), CreateCommandTag(), createdb(), CreateDecodingContext(), CreateEndOfRecoveryRecord(), CreateExtension(), createForeignKeyActionTriggers(), CreateInitDecodingContext(), CreateLockFile(), CreateOverwriteContrecordRecord(), CreatePartitionPruneState(), createPostingTree(), CreateRole(), CreateSchemaCommand(), CreateSharedMemoryAndSemaphores(), CreateSubscription(), CreateTableSpace(), CreateTransform(), CreateTriggerFiringOn(), CreateWaitEventSet(), crosstab(), cryptohash_internal(), currtid_for_view(), currtid_internal(), database_is_invalid_oid(), dataBeginPlaceToPageLeaf(), datum_image_eq(), datum_image_hash(), datum_to_jsonb_internal(), datum_write(), datumGetSize(), dbase_redo(), dblink_exec(), dblink_record_internal(), dblink_send_query(), DCH_cache_getnew(), DeadLockCheck(), DeadLockCheckRecurse(), DecodeDateTime(), DecodeTextArrayToBitmapset(), DecodingContextFindStartpoint(), decompile_conbin(), deconstruct_array_builtin(), deconstruct_distribute(), deconstruct_recurse(), DeconstructFkConstraintRow(), defGetString(), defGetStringList(), defGetTypeLength(), DefineAttr(), DefineCollation(), DefineDomain(), DefineIndex(), DefineOpClass(), DefineRelation(), DefineSavepoint(), DefineTSConfiguration(), DefineView(), Delete(), DeleteRelationTuple(), DeleteSequenceTuple(), DelRoleMems(), deparseAnalyzeSql(), deparseExpr(), deparseOpExpr(), deparseScalarArrayOpExpr(), dependency_degree(), deregister_seq_scan(), deserialize_deflist(), DetachPartitionFinalize(), detoast_attr_slice(), digest_block_size(), digest_finish(), digest_reset(), digest_result_size(), digest_update(), DirectFunctionCall1Coll(), DirectFunctionCall2Coll(), DirectFunctionCall3Coll(), DirectFunctionCall4Coll(), DirectFunctionCall5Coll(), DirectFunctionCall6Coll(), DirectFunctionCall7Coll(), DirectFunctionCall8Coll(), DirectFunctionCall9Coll(), DirectInputFunctionCallSafe(), DisableSubscription(), DiscardCommand(), disconnect_cached_connections(), distribute_qual_to_rels(), distribute_restrictinfo_to_rels(), do_analyze_rel(), do_autovacuum(), do_compile(), do_serialize(), do_serialize_binary(), do_setval(), doDeletion(), does_not_exist_skipping(), domain_check_input(), doPickSplit(), DoPortalRunFetch(), drain(), dropconstraint_internal(), dropdb(), DropObjectById(), DropRelationAllLocalBuffers(), DropRelationLocalBuffers(), DropRole(), dsa_allocate_extended(), dsa_pin(), dsa_unpin(), dsm_attach(), dsm_cleanup_for_mmap(), dsm_cleanup_using_control_segment(), dsm_impl_op(), dsm_impl_sysv(), dsm_pin_segment(), dsm_postmaster_shutdown(), dsm_postmaster_startup(), dsm_unpin_segment(), dump_stmt(), dumptuples(), edge_failure(), enable_timeouts(), EncodeSpecialDate(), EncodeSpecialInterval(), EncodeSpecialTimestamp(), encrypt_password(), EndTransactionBlock(), enlargeStringInfo(), ensure_active_superblock(), ensure_last_message(), EnsurePortalSnapshotExists(), entryExecPlaceToPage(), entryLoadMoreItems(), entrySplitPage(), eqjoinsel(), equal(), equalsJsonbScalarValue(), err_generic_string(), errdatatype(), errdetail_relkind_not_supported(), estimate_multivariate_ndistinct(), eval_const_expressions_mutator(), eval_windowaggregates(), EvalPlanQualFetchRowMark(), EventTriggerCommonSetup(), EventTriggerInvoke(), EventTriggerOnLogin(), examine_attribute(), examine_expression(), examine_simple_variable(), examine_variable(), exec_assign_value(), exec_check_assignable(), exec_dynquery_with_params(), exec_eval_datum(), Exec_ListenPreCommit(), exec_move_row_from_fields(), exec_object_restorecon(), exec_prepare_plan(), exec_replication_command(), exec_run_select(), exec_save_simple_expr(), exec_stmt_block(), exec_stmt_call(), exec_stmt_dynexecute(), exec_stmt_execsql(), exec_stmt_forc(), exec_stmt_getdiag(), exec_stmt_open(), exec_stmt_raise(), exec_stmt_return(), exec_stmt_return_next(), exec_stmt_return_query(), exec_stmts(), Exec_UnlistenAllCommit(), Exec_UnlistenCommit(), ExecAlterDefaultPrivilegesStmt(), ExecAlterExtensionContentsStmt(), ExecAlterExtensionStmt(), ExecAlterObjectSchemaStmt(), ExecAlterOwnerStmt(), ExecAsyncConfigureWait(), ExecAsyncNotify(), ExecAsyncRequest(), ExecAsyncResponse(), ExecBitmapAnd(), ExecBitmapIndexScan(), ExecBitmapOr(), ExecBuildAuxRowMark(), ExecBuildUpdateProjection(), ExecCheckIndexConstraints(), ExecCheckPermissionsModified(), ExecCheckTIDVisible(), ExecCreateTableAs(), ExecCrossPartitionUpdate(), execCurrentOf(), ExecDelete(), ExecEndNode(), ExecEvalFieldSelect(), ExecEvalFieldStoreDeForm(), ExecEvalJsonConstructor(), ExecEvalNextValueExpr(), ExecEvalSysVar(), ExecEvalXmlExpr(), ExecFindRowMark(), ExecGetAncestorResultRels(), ExecGetResultRelCheckAsUser(), ExecGrant_Attribute(), ExecGrant_common(), ExecGrant_Largeobject(), ExecGrant_Parameter(), ExecGrant_Relation(), ExecGrantStmt_oids(), ExecHash(), ExecHashJoinImpl(), ExecHashSubPlan(), ExecHashTableCreate(), ExecIndexBuildScanKeys(), ExecIndexMarkPos(), ExecIndexOnlyMarkPos(), ExecIndexOnlyRestrPos(), ExecIndexRestrPos(), ExecInitAgg(), ExecInitCoerceToDomain(), ExecInitExprRec(), ExecInitForeignScan(), ExecInitFunctionResultSet(), ExecInitFunctionScan(), ExecInitHashJoin(), ExecInitMemoize(), ExecInitMerge(), ExecInitMergeJoin(), ExecInitModifyTable(), ExecInitNamedTuplestoreScan(), ExecInitNestLoop(), ExecInitNode(), ExecInitParallelPlan(), ExecInitPartitionInfo(), ExecInitStoredGenerated(), ExecInitSubPlan(), ExecInitWindowAgg(), ExecLimit(), ExecLockRows(), ExecLookupResultRelByOid(), ExecMarkPos(), ExecMemoize(), ExecMergeJoin(), ExecMergeMatched(), ExecMergeNotMatched(), ExecModifyTable(), ExecOnConflictUpdate(), ExecParallelHashJoinNewBatch(), ExecParallelReportInstrumentation(), ExecParallelRetrieveInstrumentation(), ExecPushExprSetupSteps(), ExecRefreshMatView(), ExecReindex(), ExecRelCheck(), ExecRenameStmt(), ExecReScan(), ExecReScanModifyTable(), ExecReScanSetParamPlan(), ExecRestrPos(), ExecResultMarkPos(), ExecResultRestrPos(), ExecScanReScan(), ExecSetParamPlan(), ExecSetVariableStmt(), ExecStoreBufferHeapTuple(), ExecStoreHeapTuple(), ExecStoreMinimalTuple(), ExecStorePinnedBufferHeapTuple(), ExecSubPlan(), execTuplesHashPrepare(), ExecUpdate(), execute_extension_script(), execute_foreign_modify(), execute_jsp_gin_node(), executeBoolItem(), ExecuteCallStmt(), executeDateTimeMethod(), ExecuteDoStmt(), ExecuteGrantStmt(), executeItemOptUnwrapTarget(), executeItemUnwrapTargetArray(), ExecuteQuery(), ExecWindowAgg(), ExecWithCheckOptions(), expand_all_col_privileges(), expand_col_privileges(), expand_function_arguments(), expand_indexqual_rowcompare(), expand_insert_targetlist(), expand_partitioned_rtentry(), expand_vacuum_rel(), expanded_record_set_field_internal(), expandRecordVariable(), expandRTE(), expandTableLikeClause(), explain_get_index_name(), ExplainExecuteQuery(), ExplainOneUtility(), exprCollation(), expression_tree_mutator_impl(), expression_tree_walker_impl(), exprSetCollation(), exprType(), exprTypmod(), extension_config_remove(), extract_jsp_bool_expr(), extractNotNullColumn(), FastPathGetRelationLockEntry(), fetch_att(), fetch_finfo_record(), fetch_fp_info(), fetch_remote_table_info(), fetch_statentries_for_relation(), FileAccess(), FileClose(), FileFallocate(), fileGetOptions(), FilePrefetch(), FileRead(), FileSize(), FileSync(), FileTruncate(), FileWrite(), FileWriteback(), FileZero(), fill_seq_fork_with_data(), FillPortalStore(), fillRelOptions(), fillTypeDesc(), finalize_plan(), find_appinfos_by_relids(), find_base_rel(), find_base_rel_ignore_join(), find_coercion_pathway(), find_expr_references_walker(), find_in_dynamic_libpath(), find_indexpath_quals(), find_inheritance_children_extended(), find_join_domain(), find_join_input_rel(), find_jointree_node_for_rel(), find_nonnullable_rels_walker(), find_nonnullable_vars_walker(), find_or_make_matching_shared_tupledesc(), find_param_referent(), find_placeholder_info(), find_placeholders_recurse(), find_recursive_union(), find_window_functions_walker(), findDependentObjects(), findFkeyCast(), findoprnd(), findoprnd_recurse(), finish_heap_swap(), FinishSortSupportFunction(), fireASTriggers(), fireBSTriggers(), fix_indexqual_clause(), fix_indexqual_operand(), fix_join_expr_mutator(), fix_param_node(), fix_upper_expr_mutator(), fix_windowagg_condition_expr_mutator(), fixup_inherited_columns(), fixup_whole_row_references(), flatten_reloptions(), flatten_set_variable_args(), flattenJsonPathParseItem(), fmgr_c_validator(), fmgr_info_C_lang(), fmgr_info_cxt_security(), fmgr_info_other_lang(), fmgr_internal_validator(), fmgr_security_definer(), fmgr_sql(), fmgr_sql_validator(), fmgr_symbol(), foreign_join_ok(), forget_invalid_pages(), forget_invalid_pages_db(), ForgetManyTestResources(), ForgetPortalSnapshots(), format_operator_parts(), format_procedure_parts(), format_type_extended(), FormIndexDatum(), FormPartitionKeyDatum(), ForwardSyncRequest(), free_stmt(), FreeDesc(), FreeDir(), FreeFile(), FreePageManagerPutInternal(), FreeVfd(), fsm_search_avail(), fsm_space_needed_to_cat(), func_get_detail(), func_parallel(), func_strict(), func_volatile(), FuncnameGetCandidates(), function_inlinable(), function_selectivity(), FunctionCall0Coll(), FunctionCall1Coll(), FunctionCall2Coll(), FunctionCall3Coll(), FunctionCall4Coll(), FunctionCall5Coll(), FunctionCall6Coll(), FunctionCall7Coll(), FunctionCall8Coll(), FunctionCall9Coll(), FunctionIsVisibleExt(), g_cube_distance(), g_int_picksplit(), gbt_num_distance(), gc_qtexts(), gen_prune_steps_from_opexps(), generate_collation_name(), generate_function_name(), generate_nonunion_paths(), generate_operator_clause(), generate_operator_name(), generate_partition_qual(), generate_qualified_relation_name(), generate_qualified_type_name(), generate_recursion_path(), generate_relation_name(), generateClonedExtStatsStmt(), generateClonedIndexStmt(), GenerationFree(), GenerationRealloc(), GenericXLogRegisterBuffer(), geqo(), get_actual_variable_endpoint(), get_agg_combine_expr(), get_altertable_subcmdinfo(), get_am_type_string(), get_attgenerated(), get_attname(), get_attoptions(), get_attstatsslot(), get_attstattarget(), get_atttypetypmodcoll(), get_collation(), get_collation_isdeterministic(), get_columns_length(), get_config_unit_name(), get_controlfile(), get_crosstab_tuplestore(), get_database_list(), get_eclass_for_sort_expr(), get_explain_guc_options(), get_from_clause_item(), get_func_arg_info(), get_func_input_arg_names(), get_func_leakproof(), get_func_nargs(), get_func_prokind(), get_func_result_name(), get_func_retset(), get_func_rettype(), get_func_signature(), get_func_trftypes(), get_func_variadictype(), get_function_rows(), get_index_isclustered(), get_index_isvalid(), get_indexpath_pages(), get_insert_query_def(), get_join_variables(), get_jointype_name(), get_json_agg_constructor(), get_json_constructor(), get_language_name(), get_last_relevant_decnum(), get_matching_list_bounds(), get_matching_location(), get_matching_partitions(), get_matching_range_bounds(), get_merged_range_bounds(), get_multirange_io_data(), get_mxact_status_for_lock(), get_name_for_var_field(), get_object_address(), get_object_address_opcf(), get_object_address_opf_member(), get_object_address_relobject(), get_object_address_unqualified(), get_object_namespace(), get_op_opfamily_properties(), get_opclass(), get_opclass_family(), get_opclass_input_type(), get_opclass_method(), get_opclass_name(), get_partition_for_tuple(), get_partition_operator(), get_partition_parent(), get_perl_array_ref(), get_policies_for_relation(), get_primary_key_attnos(), get_publication_name(), get_qual_for_range(), get_query_def(), get_range_io_data(), get_range_key_properties(), get_range_nulltest(), get_rel_persistence(), get_relation_by_qualified_name(), get_relation_column_alias_ids(), get_relation_constraint_attnos(), get_relation_name(), get_relation_statistics(), get_relids_for_join(), get_relids_in_jointree(), get_remote_estimate(), get_ri_constraint_root(), get_rolespec_oid(), get_rolespec_tuple(), get_rte_attribute_is_dropped(), get_rte_attribute_name(), get_rule_expr(), get_segment_by_index(), get_select_query_def(), get_setop_query(), get_sortgroupref_clause(), get_sortgroupref_tle(), get_sublink_expr(), get_subscription_name(), get_sync_bit(), get_ts_parser_func(), get_ts_template_func(), get_tuple_of_interest(), get_typdefault(), get_type_category_preferred(), get_type_io_data(), get_typlenbyval(), get_typlenbyvalalign(), get_utility_query_def(), get_val(), get_variable(), get_view_query(), get_windowfunc_expr_helper(), GetAccessStrategy(), GetAttributeByName(), GetAttributeByNum(), getBaseTypeAndTypmod(), GetBTPageStatistics(), GetCachedPlan(), GetCCHashEqFuncs(), GetCommandLogLevel(), GetCompressionMethodName(), GetConnection(), getConstraintTypeDescription(), GetCTEForRTE(), GetEpochTime(), GetFdwRoutine(), GetFdwRoutineByServerId(), GetForeignColumnOptions(), GetForeignDataWrapperExtended(), GetForeignKeyActionTriggers(), GetForeignKeyCheckTriggers(), GetForeignServerExtended(), GetForeignServerIdByRelId(), GetForeignTable(), getIdentitySequence(), GetIndexAmRoutine(), GetIndexAmRoutineByAmId(), GetIndexInputType(), getInsertSelectQuery(), getIthJsonbValueFromContainer(), getJsonEncodingConst(), getJsonPathItem(), GetLatestSnapshot(), getlen(), GetLocalVictimBuffer(), GetLockConflicts(), GetNamedLWLockTranche(), GetNewMultiXactId(), GetNewObjectId(), GetNewRelFileNumber(), GetNewTransactionId(), getNextFlagFromString(), GetNSItemByRangeTablePosn(), getObjectClass(), getObjectDescription(), getObjectIdentityParts(), getOpFamilyDescription(), getOpFamilyIdentity(), getProcedureTypeDescription(), GetPublication(), getPublicationSchemaInfo(), getQuadrant(), getRelationDescription(), getRelationIdentity(), getRelationTypeDescription(), getRTEPermissionInfo(), GetSerializableTransactionSnapshotInt(), GetSharedMemName(), GetSubscription(), GetSysCacheHashValue(), GetTableAmRoutine(), gettoken_tsvector(), getTokenTypes(), GetTransactionSnapshot(), GetTSConfigTuple(), getTSCurrentConfig(), GetTsmRoutine(), GetTupleForTrigger(), gettype(), getTypeBinaryInputInfo(), getTypeBinaryOutputInfo(), getTypeInputInfo(), getTypeOutputInfo(), GetWaitEventExtensionIdentifier(), GetXLogBuffer(), ghstore_consistent(), gimme_gene(), gin_btree_compare_prefix(), gin_btree_extract_query(), gin_consistent_hstore(), gin_consistent_jsonb(), gin_consistent_jsonb_path(), gin_extract_hstore_query(), gin_extract_jsonb_path(), gin_extract_jsonb_query(), gin_extract_jsonb_query_path(), gin_extract_query_trgm(), gin_extract_trgm(), gin_extract_tsquery_5args(), gin_extract_tsvector_2args(), gin_leafpage_items(), gin_metapage_info(), gin_page_opaque_info(), gin_redo(), gin_trgm_consistent(), gin_trgm_triconsistent(), gin_triconsistent_jsonb(), gin_triconsistent_jsonb_path(), gin_tsquery_consistent_6args(), ginarrayconsistent(), ginarrayextract_2args(), ginarraytriconsistent(), ginbuild(), gincost_pattern(), gincostestimate(), ginEntryFillRoot(), ginFindParents(), ginFinishSplit(), ginHeapTupleFastCollect(), ginHeapTupleFastInsert(), ginint4_consistent(), ginint4_queryextract(), ginPlaceToPage(), ginqueryarrayextract(), ginReadTuple(), ginRedoInsertEntry(), ginRedoInsertListPage(), ginRedoRecompress(), ginRedoSplit(), ginRedoUpdateMetapage(), ginRedoVacuumPage(), ginStepRight(), ginVacuumEntryPage(), ginVacuumPostingTreeLeaf(), ginvalidate(), gist_bbox_distance(), gist_box_leaf_consistent(), gist_indexsortbuild_flush_ready_pages(), gist_indexsortbuild_levelstate_flush(), gist_page_items(), gist_page_items_bytea(), gist_page_opaque_info(), gist_point_consistent(), gist_point_consistent_internal(), gist_point_distance(), gist_redo(), gistBufferingFindCorrectParent(), gistbufferinginserttuples(), gistbuild(), gistEmptyAllBuffers(), gistfillbuffer(), gistFindPath(), gistGetParent(), gistgettuple(), gistindex_keytest(), gistInitBuffering(), gistplacetopage(), gistRedoPageUpdateRecord(), gistrescan(), gistvalidate(), grow_memtuples(), gtrgm_consistent(), gtrgm_distance(), handle_streamed_transaction(), HandleParallelApplyMessage(), HandleParallelMessage(), has_dangerous_join_using(), has_row_triggers(), has_subclass(), hash_bitmap_info(), hash_corrupted(), hash_create(), hash_freeze(), hash_metapage_info(), hash_ok_operator(), hash_page_items(), hash_page_stats(), hash_redo(), hash_search_with_hash_value(), hash_update_hash_key(), hash_xlog_insert(), hash_xlog_move_page_contents(), hash_xlog_split_page(), hash_xlog_squeeze_page(), hashbpchar(), hashbpcharextended(), hashbuild(), hashtext(), hashtextextended(), hashvalidate(), heap2_decode(), heap2_redo(), heap_abort_speculative(), heap_attisnull(), heap_create_with_catalog(), heap_decode(), heap_drop_with_catalog(), heap_fetch_toast_slice(), heap_finish_speculative(), heap_getnext(), heap_getsysattr(), heap_inplace_update(), heap_lock_tuple(), heap_lock_updated_tuple_rec(), heap_modify_tuple_by_cols(), heap_page_is_all_visible(), heap_page_items(), heap_prune_chain(), heap_redo(), heap_tuple_infomask_flags(), heap_xlog_confirm(), heap_xlog_delete(), heap_xlog_inplace(), heap_xlog_insert(), heap_xlog_lock(), heap_xlog_lock_updated(), heap_xlog_multi_insert(), heap_xlog_update(), heapam_index_build_range_scan(), heapam_relation_copy_for_cluster(), heapam_scan_analyze_next_tuple(), HeapCheckForSerializableConflictOut(), hexval(), hide_coercion_node(), HoldPinnedPortals(), hstoreUpgrade(), hypothetical_check_argtypes(), hypothetical_dense_rank_final(), hypothetical_rank_common(), identify_join_columns(), identify_opfamily_groups(), if(), ImportForeignSchema(), ImportSnapshot(), inclusion_get_strategy_procinfo(), IncrementVarSublevelsUp_walker(), index_build(), index_check_primary_key(), index_concurrently_create_copy(), index_concurrently_swap(), index_constraint_create(), index_create(), index_drop(), index_get_partition(), index_getprocinfo(), index_other_operands_eval_cost(), index_set_state_flags(), index_store_float8_orderby_distances(), index_strategy_get_limit(), index_update_stats(), IndexGetRelation(), IndexNextWithReorder(), IndexOnlyNext(), IndexOnlyRecheck(), IndexSetParentIndex(), IndexSupportInitialize(), IndexSupportsBackwardScan(), inet_gist_consistent(), inet_opr_codenum(), inet_to_cidr(), infix(), init_custom_variable(), init_locale(), init_MultiFuncCall(), init_params(), init_sql_fcache(), init_toast_snapshot(), InitAuxiliaryProcess(), initBloomState(), InitCatalogCache(), initGinState(), initGISTstate(), initHyperLogLog(), initial_cost_mergejoin(), initialize_peragg(), initialize_worker_spi(), InitializeBackupManifest(), InitializeLatchSupport(), InitializeMaxBackends(), InitializeOneGUCOption(), InitLatch(), InitLocalBuffers(), InitMaterializedSRF(), InitPlan(), InitPostgres(), InitPostmasterChild(), InitProcess(), InitSharedLatch(), InitStandaloneProcess(), inittapes(), inline_set_returning_function(), InputFunctionCall(), InputFunctionCallSafe(), Insert(), insert_timeout(), insert_username(), InsertOneNull(), InsertOneTuple(), InsertOneValue(), InstrEndLoop(), InstrStartNode(), InstrStopNode(), int2_accum_inv(), int2_avg_accum(), int2_avg_accum_inv(), int2int4_sum(), int4_accum_inv(), int4_avg_accum(), int4_avg_accum_inv(), int4_avg_combine(), int8_accum_inv(), int8_avg(), int8_avg_accum_inv(), int8_avg_combine(), int8_avg_deserialize(), int8_avg_serialize(), int_query_opr_selec(), internal_get_result_type(), InternalIpcMemoryCreate(), interpret_func_volatility(), interval_avg_accum_inv(), interval_avg_deserialize(), interval_avg_serialize(), interval_in(), intervaltypmodleastfield(), intervaltypmodout(), intset_add_member(), intset_update_upper(), inv_getsize(), inv_read(), inv_truncate(), inv_write(), InvalidateAttoptCacheCallback(), InvalidateBuffer(), InvalidateOprCacheCallBack(), InvalidateShippableCacheCallback(), InvalidateTableSpaceCacheCallback(), IOContextForStrategy(), IpcMemoryDelete(), IpcMemoryDetach(), IpcSemaphoreKill(), irbt_combine(), is_simple_subquery(), is_simple_union_all(), is_simple_union_all_recurse(), isCurrentGroup(), issue_xlog_fsync(), iteratorFromContainer(), join_search_one_level(), join_selectivity(), jointree_contains_lateral_outer_refs(), json_agg_transfn_worker(), json_errdetail(), json_errsave_error(), json_object_agg_transfn_worker(), json_typeof(), jsonb_agg_transfn_worker(), jsonb_get_element(), jsonb_hash(), jsonb_hash_extended(), jsonb_in_scalar(), jsonb_object_agg_transfn_worker(), jsonb_put_escaped_value(), jsonb_recv(), Jsonb_to_SV(), JsonbContainerTypeName(), JsonbDeepContains(), JsonbHashScalarValue(), JsonbHashScalarValueExtended(), JsonbIteratorNext(), JsonbToCStringWorker(), JsonbType(), JsonbTypeName(), JsonbValue_to_SV(), JsonbValueAsText(), JsonEncodeDateTime(), jsonpath_recv(), jspInitByBuffer(), jspOperationName(), KnownAssignedXidsAdd(), KnownAssignedXidsDisplay(), KnownAssignedXidsRemove(), KnownAssignedXidsRemovePreceding(), lazy_scan_heap(), lazy_scan_noprune(), lazy_scan_prune(), lc_collate_is_c(), leader_takeover_tapes(), llvm_build_inline_plan(), llvm_compile_module(), llvm_create_types(), llvm_execute_inline_plan(), llvm_get_function(), llvm_load_summary(), llvm_optimize_module(), llvm_pg_func(), llvm_pg_var_func_type(), llvm_pg_var_type(), llvm_recreate_llvm_context(), llvm_resolve_symbol(), llvm_session_initialize(), llvm_set_target(), llvm_shutdown(), lo_manage(), load_categories_hash(), load_critical_index(), load_domaintype_info(), load_module(), load_multirangetype_info(), load_rangetype_info(), load_relcache_init_file(), load_return_type(), load_typcache_tupdesc(), LoadOutputPlugin(), LocalBufferAlloc(), LocalExecuteInvalidationMessage(), LocalToUtf(), lock_twophase_postcommit(), lock_twophase_recover(), lock_twophase_standby_recover(), LockAcquireExtended(), LockBuffer(), LockBufferForCleanup(), LockCheckConflicts(), LockHasWaiters(), LockRefindAndRelease(), LockRelease(), LockReleaseAll(), LockReleaseSession(), LockWaiterCount(), log_invalid_page(), LogCurrentRunningXacts(), logical_heap_rewrite_flush_mappings(), LogicalConfirmReceivedLocation(), LogicalIncreaseRestartDecodingForSlot(), LogicalIncreaseXminForSlot(), logicalmsg_decode(), logicalmsg_redo(), LogicalOutputWrite(), LogicalParallelApplyLoop(), logicalrep_read_begin(), logicalrep_read_begin_prepare(), logicalrep_read_commit(), logicalrep_read_commit_prepared(), logicalrep_read_delete(), logicalrep_read_insert(), logicalrep_read_prepare_common(), logicalrep_read_rollback_prepared(), logicalrep_read_stream_commit(), logicalrep_read_tuple(), logicalrep_read_update(), logicalrep_rel_open(), logicalrep_worker_launch(), logicalrep_write_namespace(), logicalrep_write_tuple(), logicalrep_write_typ(), LogicalReplicationSlotHasPendingWal(), LogicalRepSyncTableStart(), LogicalTapeBackspace(), LogicalTapeCreate(), LogicalTapeSeek(), LogicalTapeWrite(), lookup_am_handler_func(), lookup_collation_cache(), lookup_ts_config_cache(), lookup_ts_dictionary_cache(), lookup_ts_parser_cache(), LookupBackgroundWorkerFunction(), LookupOpclassInfo(), LookupParallelWorkerFunction(), LookupTypeNameExtended(), lquery_recv(), LruDelete(), LruInsert(), ltree_consistent(), ltree_recv(), ltxtq_recv(), LWLockAcquire(), LWLockAcquireOrWait(), LWLockConditionalAcquire(), LWLockQueueSelf(), LWLockRelease(), lz4_compress_datum(), macaddr_abbrev_abort(), make_absolute_path(), make_callstmt_target(), make_canonical_pathkey(), make_const(), make_inh_translation_list(), make_inner_pathkeys_for_merge(), make_new_connection(), make_new_heap(), make_one_partition_rbound(), make_pathkey_from_sortinfo(), make_pathkey_from_sortop(), make_range(), make_rel_from_joinlist(), make_result_opt_error(), make_ruledef(), make_scalar_key(), make_sort_from_groupcols(), make_tsvector(), make_tuple_from_result_row(), make_unique_from_pathkeys(), makeBoolAggState(), makeIntervalAggState(), makeNumericAggState(), makepol(), makeStringAggState(), MakeTidOpExpr(), MakeTransitionCaptureState(), map_sql_table_to_xmlschema(), map_sql_type_to_xml_name(), map_variable_attnos_mutator(), mark_index_clustered(), MarkBufferDirty(), MarkBufferDirtyHint(), markQueryForLocking(), markRelsAsNulledBy(), markRTEForSelectPriv(), markTargetListOrigin(), mask_unused_space(), match_clause_to_partition_key(), match_index_to_operand(), match_network_subset(), match_unsorted_outer(), materializeResult(), max_parallel_hazard_test(), maybe_reread_subscription(), mbms_add_member(), mbms_is_member(), mcelem_array_selec(), mcv_get_match_bitmap(), mcv_match_expression(), mdnblocks(), MemoryContextAlloc(), MemoryContextAllocExtended(), MemoryContextAllocHuge(), MemoryContextAllocZero(), MemoryContextAllocZeroAligned(), MergeAttributes(), mergeruns(), MergeWithExistingConstraint(), minmax_get_strategy_procinfo(), minmax_multi_get_strategy_procinfo(), MJExamineQuals(), mock_scram_secret(), moddatetime(), ModifyWaitEvent(), movedb(), moveLeafs(), mq_putmessage_noblock(), MultiExecBitmapAnd(), MultiExecBitmapOr(), MultiExecProcNode(), multirange_agg_transfn(), multirange_cmp(), multirange_constructor0(), multirange_constructor1(), multirange_constructor2(), multirange_eq_internal(), multirange_get_typcache(), multirange_in(), multirange_intersect_agg_transfn(), multixact_redo(), MultiXactIdCreateFromMembers(), mxstatus_to_string(), NameListToString(), NamespaceCreate(), ndistinct_for_combination(), negate_clause(), network_abbrev_abort(), networkjoinsel(), nextval_internal(), nodeRead(), NotifyMyFrontEnd(), nulltestsel(), NUM_cache_getnew(), NUM_numpart_from_char(), NUM_numpart_to_char(), NUM_processor(), numeric_abbrev_abort(), numeric_accum_inv(), numeric_avg_combine(), numeric_avg_deserialize(), numeric_avg_serialize(), numeric_combine(), numeric_deserialize(), numeric_poly_combine(), numeric_poly_deserialize(), numeric_poly_serialize(), numeric_serialize(), objectNamesToOids(), ObjectsInPublicationToOids(), objectsInSchemaToOids(), oidparse(), op_input_types(), op_strict(), op_volatile(), OpClassCacheLookup(), OpclassIsVisibleExt(), OpenPipeStream(), OpenTemporaryFileInTablespace(), OpenTransientFilePerm(), operator_predicate_proof(), OperatorCreate(), OperatorIsVisibleExt(), OpFamilyCacheLookup(), OpfamilyIsVisibleExt(), ordered_set_startup(), outNode(), OutputPluginPrepareWrite(), OutputPluginWrite(), OwnLatch(), pa_allocate_worker(), pa_decr_and_wait_stream_block(), pa_free_worker(), pa_start_subtrans(), pa_stream_abort(), page_header(), PageAddItemExtended(), PageIndexMultiDelete(), PageIndexTupleDelete(), PageIndexTupleDeleteNoCompact(), PageIndexTupleOverwrite(), palloc(), palloc0(), palloc_extended(), parallel_vacuum_main(), parallel_vacuum_process_all_indexes(), parallel_vacuum_process_one_index(), parse_affentry(), parse_format(), parse_func_options(), parse_hstore(), parse_jsonb_index_flags(), parse_lquery(), parse_ltree(), parse_one_reloption(), parse_ooaffentry(), parse_output_parameters(), parse_policy_command(), parse_tsquery(), parseCreateReplSlotOptions(), ParseFuncOrColumn(), parseNodeString(), PartitionHasPendingDetach(), PathNameOpenFilePerm(), pattern_fixed_prefix(), patternsel(), percentile_cont_final_common(), percentile_cont_multi_final_common(), percentile_disc_final(), percentile_disc_multi_final(), perform_pruning_base_step(), perform_pruning_combine_step(), perform_work_item(), PerformCursorOpen(), PerformMembersTruncation(), PerformWalRecovery(), PersistHoldablePortal(), pg_aclmask(), pg_armor(), pg_backup_stop(), pg_buffercache_pages(), pg_buffercache_summary(), pg_column_compression(), pg_column_size(), pg_control_checkpoint(), pg_control_init(), pg_control_recovery(), pg_control_system(), pg_crc32c_armv8_available(), pg_create_logical_replication_slot(), pg_create_physical_replication_slot(), pg_current_logfile(), pg_current_snapshot(), pg_do_encoding_conversion(), pg_event_trigger_ddl_commands(), pg_extension_config_dump(), pg_get_catalog_foreign_keys(), pg_get_constraintdef_worker(), pg_get_functiondef(), pg_get_indexdef_worker(), pg_get_keywords(), pg_get_multixact_members(), pg_get_object_address(), pg_get_partkeydef_worker(), pg_get_ruledef_worker(), pg_get_statisticsobj_worker(), pg_get_triggerdef_worker(), pg_get_viewdef_worker(), pg_get_wal_record_info(), pg_GSS_error_int(), pg_identify_object(), pg_identify_object_as_address(), pg_import_system_collations(), pg_input_error_info(), pg_isolation_test_session_is_blocked(), pg_last_committed_xact(), pg_logical_replication_slot_advance(), pg_logical_slot_get_changes_guts(), pg_newlocale_from_collation(), pg_parse_query(), pg_partition_tree(), pg_perm_setlocale(), pg_plan_query(), pg_relation_filepath(), pg_replication_origin_create(), pg_replication_slot_advance(), pg_rewrite_query(), pg_sequence_parameters(), pg_split_walfile_name(), pg_stat_get_subscription(), pg_stat_get_wal_receiver(), pg_stat_statements_info(), pg_stat_statements_internal(), pg_timezone_abbrevs(), pg_tzset(), pg_visibility_map_summary(), pg_xact_commit_timestamp_origin(), pgfdw_inval_callback(), pgfdw_reset_xact_state(), pgfdw_subxact_callback(), pgfdw_xact_callback(), PGLC_localeconv(), pgoutput_change(), pgoutput_commit_txn(), pgoutput_row_filter(), pgoutput_row_filter_exec_expr(), pgp_armor_decode(), pgp_armor_encode(), pgp_armor_headers(), pgp_extract_armor_headers(), PGReserveSemaphores(), PGSemaphoreCreate(), PGSemaphoreLock(), PGSemaphoreReset(), PGSemaphoreTryLock(), PGSemaphoreUnlock(), PGSharedMemoryCreate(), PGSharedMemoryDetach(), PGSharedMemoryIsInUse(), PGSharedMemoryReAttach(), pgstat_discard_stats(), pgstat_drop_entry_internal(), pgstat_get_io_context_name(), pgstat_get_io_object_name(), pgstat_get_io_op_index(), pgstat_get_io_time_index(), pgstat_read_statsfile(), pgstat_release_entry_ref(), pgstat_replslot_to_serialized_name_cb(), pgstat_write_statsfile(), pgstatginindex_internal(), pgstathashindex(), pgstatindex_impl(), pgstattuple_approx_internal(), pgwin32_ReserveSharedMemoryRegion(), pgwin32_select(), pgxml_result_to_text(), PinPortal(), plperl_event_trigger_handler(), plperl_fini(), plperl_func_handler(), plperl_init_interp(), plperl_inline_handler(), plperl_return_next_internal(), plperl_spi_exec_prepared(), plperl_spi_freeplan(), plperl_spi_prepare(), plperl_spi_query(), plperl_spi_query_prepared(), plperl_trigger_handler(), plperl_util_elog(), plperl_validator(), plpgsql_build_datatype(), plpgsql_build_variable(), plpgsql_call_handler(), plpgsql_compile(), plpgsql_compile_inline(), plpgsql_exec_function(), plpgsql_exec_get_datum_type(), plpgsql_exec_get_datum_type_info(), plpgsql_exec_trigger(), plpgsql_free_function_memory(), plpgsql_fulfill_promise(), plpgsql_HashTableDelete(), plpgsql_HashTableInsert(), plpgsql_inline_handler(), plpgsql_parse_cwordtype(), plpgsql_parse_word(), plpgsql_validator(), plpython3_call_handler(), plpython3_inline_handler(), plpython3_validator(), plsample_func_handler(), plsample_trigger_handler(), pltcl_build_tuple_result(), pltcl_event_trigger_handler(), pltcl_func_handler(), pltcl_init_interp(), pltcl_returnnext(), pltcl_SPI_prepare(), pltcl_trigger_handler(), PLy_current_execution_context(), PLy_cursor_init_type(), PLy_cursor_plan(), PLy_cursor_query(), PLy_exception_set_with_details(), PLy_exec_function(), PLy_exec_trigger(), PLy_modify_tuple(), PLy_plan_init_type(), PLy_pop_execution_context(), PLy_procedure_compile(), PLy_procedure_create(), PLy_procedure_get(), PLy_procedure_munge_source(), PLy_result_init_type(), PLy_spi_exception_set(), PLy_spi_prepare(), PLy_subtransaction_init_type(), PLy_traceback(), PLy_trigger_build_args(), PLyObject_AsString(), PLyObject_FromJsonbContainer(), PLyObject_FromJsonbValue(), PopTransaction(), populate_joinrel_with_paths(), populate_record_field(), populate_scalar(), PortalRun(), PortalRunFetch(), PosixSemaphoreCreate(), PosixSemaphoreKill(), postgresAnalyzeForeignTable(), postgresBeginForeignInsert(), postgresGetAnalyzeInfoForForeignTable(), postgresGetForeignJoinPaths(), postgresGetForeignUpperPaths(), postgresPlanDirectModify(), postgresPlanForeignModify(), PostmasterDeathSignalInit(), PostmasterIsAliveInternal(), PostPrepare_Locks(), postprocess_setop_tlist(), pq_getmsgint(), pq_init(), pq_parse_errornotice(), pq_sendint(), PreCommit_Notify(), PreCommit_Portals(), predicate_implied_by_recurse(), predicate_refuted_by_recurse(), prepare_column_cache(), prepare_sort_from_pathkeys(), PrepareInvalidationState(), preparePresortedCols(), PrepareRedoAdd(), PrepareRedoRemove(), PrepareSortSupportFromGistIndexRel(), PrepareSortSupportFromIndexRel(), PrepareSortSupportFromOrderingOp(), PrepareTransaction(), preprocess_aggref(), preprocess_minmax_aggregates(), preprocess_qual_conditions(), preprocess_targetlist(), preprocessNamespacePath(), PreventInTransactionBlock(), print_function_arguments(), printJsonPathItem(), printsimple(), privilege_to_string(), proc_exit(), proc_exit_prepare(), ProcArrayApplyRecoveryInfo(), ProcArraySetReplicationSlotXmin(), ProcedureCreate(), process_equivalence(), process_matched_tle(), process_subquery_nestloop_params(), process_syncing_tables(), ProcessCatchupInterrupt(), ProcessCommittedInvalidationMessages(), ProcessIncomingNotify(), processIndirection(), ProcessRecoveryConflictInterrupt(), ProcessStandbyHSFeedbackMessage(), ProcessStandbyReplyMessage(), ProcessSyncRequests(), ProcessUtilitySlow(), ProcessWalSndrMessage(), ProcKill(), ProcSendSignal(), ProcSignalInit(), provider_init(), prs_setup_firstcall(), prune_element_hashtable(), prune_lexemes_hashtable(), pull_up_sublinks_jointree_recurse(), pull_up_subqueries_recurse(), pull_up_union_leaf_queries(), pull_var_clause_walker(), pullup_replace_vars_callback(), push_back_token(), pushJsonbValueScalar(), pushOpStack(), pvsnprintf(), QTNodeCompare(), query_planner(), query_to_oid_list(), query_to_xml_and_xmlschema(), query_to_xmlschema(), querytree(), radius_add_attribute(), random_init_pool(), range_adjacent_internal(), range_after_internal(), range_agg_finalfn(), range_agg_transfn(), range_before_internal(), range_cmp(), range_contains_internal(), range_eq_internal(), range_get_typcache(), range_gist_consistent_int_element(), range_gist_consistent_int_multirange(), range_gist_consistent_int_range(), range_gist_consistent_leaf_element(), range_gist_consistent_leaf_multirange(), range_gist_consistent_leaf_range(), range_gist_penalty(), range_intersect(), range_intersect_agg_transfn(), range_minus(), range_minus_internal(), range_overlaps_internal(), range_overleft_internal(), range_overright_internal(), range_union_internal(), RangeVarCallbackForAlterRelation(), RangeVarCallbackForTruncate(), RangeVarCallbackOwnsRelation(), raw_expression_tree_walker_impl(), raw_heap_insert(), rbt_begin_iterate(), rbt_populate(), read_client_final_message(), read_gucstate(), read_gucstate_binary(), read_seq_tuple(), readDatum(), ReadTempFileBlock(), ReceiveFunctionCall(), ReceiveSharedInvalidMessages(), recheck_cast_function_args(), record_image_cmp(), recordExtObjInitPriv(), RecordKnownAssignedTransactionIds(), RecordTransactionAbort(), RecordTransactionAbortPrepared(), RecordTransactionCommit(), recovery_create_dbdir(), recoveryApplyDelay(), RecoveryRestartPoint(), recurse_push_qual(), recurse_pushdown_safe(), recurse_set_operations(), recv_password_packet(), reduce_outer_joins(), reduce_outer_joins_pass1(), reduce_outer_joins_pass2(), refresh_by_match_merge(), refresh_matview_datafill(), regclassin(), regcollationin(), regconfigin(), regdictionaryin(), register_seq_scan(), RegisterBackgroundWorker(), RegisterExtensibleNodeEntry(), regnamespacein(), regoperatorin(), regoperin(), regprocedurein(), regprocin(), REGRESS_object_access_hook_str(), regress_setenv(), regrolein(), regtypein(), RehashCatCache(), reindex_index(), reindex_relation(), ReindexRelationConcurrently(), relation_mark_replica_identity(), relation_needs_vacanalyze(), relation_open(), RelationAddBlocks(), RelationBuildDesc(), RelationBuildLocalRelation(), RelationBuildPartitionDesc(), RelationBuildPartitionKey(), RelationBuildPublicationDesc(), RelationBuildRowSecurity(), RelationBuildTriggers(), RelationBuildTupleDesc(), RelationCacheInitializePhase3(), RelationClearMissing(), RelationClearRelation(), RelationCreateStorage(), RelationFindReplTupleByIndex(), RelationFindReplTupleSeq(), RelationForgetRelation(), RelationGetBufferForTuple(), RelationGetExclusionInfo(), RelationGetIdentityKeyBitmap(), RelationGetIndexAttrBitmap(), relationHasPrimaryKey(), RelationInitIndexAccessInfo(), RelationInitPhysicalAddr(), RelationInitTableAccessMethod(), RelationIsVisibleExt(), RelationMapRemoveMapping(), RelationMapUpdateMap(), RelationPutHeapTuple(), RelationReloadIndexInfo(), RelationSetNewRelfilenumber(), ReleaseBuffer(), ReleaseCurrentSubTransaction(), ReleaseLockIfHeld(), ReleaseLruFile(), ReleaseManyTestResource(), ReleaseSavepoint(), ReleaseString(), RelfilenumberMapInvalidateCallback(), RelidByRelfilenumber(), relmap_redo(), RememberClusterOnForRebuilding(), RememberManyTestResources(), RememberReplicaIdentityForRebuilding(), remove_rel_from_joinlist(), remove_self_joins_recurse(), remove_timeout_index(), remove_useless_joins(), remove_useless_results_recurse(), RemoveAttrDefault(), RemoveAttrDefaultById(), RemoveAttributeById(), RemoveConstraintById(), removeExtObjInitPriv(), RemoveFunctionById(), RemoveGXact(), RemoveInheritance(), RemoveLocalLock(), RemoveNonParentXlogFiles(), RemoveOldXlogFiles(), RemoveOperatorById(), RemovePartitionKeyByRelId(), RemovePolicyById(), RemovePublicationById(), RemovePublicationRelById(), RemovePublicationSchemaById(), RemoveReindexPending(), RemoveRelations(), RemoveRewriteRuleById(), RemoveRoleFromObjectACL(), RemoveRoleFromObjectPolicy(), RemoveStatisticsById(), RemoveTempXlogFiles(), RemoveTriggerById(), RemoveTSConfigurationById(), RemoveTypeById(), RemoveUserMapping(), rename_constraint_internal(), RenameConstraint(), RenameConstraintById(), RenameDatabase(), RenameRelationInternal(), RenameRole(), RenameTableSpace(), RenameType(), RenameTypeInternal(), reorder_function_arguments(), ReorderBufferAbortOld(), ReorderBufferIterTXNNext(), ReorderBufferProcessTXN(), ReorderBufferSerializeTXN(), ReorderBufferToastAppendChunk(), ReorderBufferToastReplace(), repalloc(), repalloc0(), repalloc_extended(), replace_rte_variables(), replace_vars_in_jointree(), ReplaceVarsFromTargetList_callback(), replorigin_drop_by_name(), replorigin_redo(), replorigin_session_setup(), report_invalid_page(), report_name_conflict(), report_namespace_conflict(), ReportSlotConnectionError(), RequestAddinShmemSpace(), RequestCheckpoint(), RequestNamedLWLockTranche(), ResetRelRewrite(), ResetSequence(), ResetUnloggedRelations(), ResetUnloggedRelationsInDbspaceDir(), resolve_anyarray_from_others(), resolve_anyelement_from_others(), resolve_anymultirange_from_others(), resolve_anyrange_from_others(), resolve_column_ref(), resolve_special_varno(), ResourceOwnerEnlarge(), ResourceOwnerForget(), ResourceOwnerForgetLock(), ResourceOwnerRelease(), ResourceOwnerReleaseAll(), ResourceOwnerReleaseAllOfKind(), ResourceOwnerRemember(), ResOwnerReleaseBufferPin(), RestoreComboCIDState(), RestoreRelationMap(), RestoreSlotFromDisk(), restrict_and_check_grant(), restriction_selectivity(), revmap_get_buffer(), RewriteQuery(), rewriteTargetListIU(), rewriteTargetView(), rewriteValuesRTE(), ri_Check_Pk_Match(), ri_FetchConstraintInfo(), RI_FKey_cascade_del(), RI_FKey_cascade_upd(), RI_FKey_check(), ri_GenerateQualCollation(), ri_HashCompareOp(), RI_Initial_Check(), ri_LoadConstraintInfo(), RI_PartitionRemove_Check(), ri_PerformCheck(), ri_PlanCheck(), ri_restrict(), ri_set(), roles_is_member_of(), RollbackAndReleaseCurrentSubTransaction(), RollbackToSavepoint(), RS_compile(), RS_execute(), RS_isRegis(), rtree_internal_consistent(), s_check_valid(), s_lock_free_sema(), s_lock_stuck(), SaveCachedPlan(), ScanPgRelation(), ScanSourceDatabasePgClassTuple(), schedule_alarm(), scram_build_secret(), scram_exchange(), scram_verify_plain_password(), search_indexed_tlist_for_phv(), search_indexed_tlist_for_var(), SearchSysCacheList(), seg_cmp(), select_rowmark_type(), send_feedback(), SendBackupManifest(), sendDir(), sendFile(), sendFileWithContent(), sepgsql_attribute_post_create(), sepgsql_database_post_create(), sepgsql_fmgr_hook(), sepgsql_object_access(), sepgsql_proc_post_create(), sepgsql_proc_setattr(), sepgsql_relation_post_create(), sepgsql_relation_setattr(), sepgsql_relation_setattr_extra(), sepgsql_schema_post_create(), seq_redo(), sequence_options(), SerializeComboCIDState(), set_attnotnull(), set_baserel_partition_key_exprs(), set_cheapest(), set_config_option_ext(), set_cte_pathlist(), set_join_references(), set_joinrel_partition_key_exprs(), set_max_safe_fds(), set_output_count(), set_plan_refs(), set_rel_pathlist(), set_rel_size(), set_using_names(), set_worktable_pathlist(), SetAttrMissing(), SetDatabaseEncoding(), SetDatatabaseHasLoginEventTriggers(), SetDefaultACL(), SetMatViewPopulatedState(), SetNextObjectId(), setPath(), SetReindexPending(), SetReindexProcessing(), SetRelationHasSubclass(), SetRelationNumChecks(), SetRelationRuleStatus(), SetRelationTableSpace(), Setup_AF_UNIX(), setup_firstcall(), setup_simple_rel_arrays(), SetupApplyOrSyncWorker(), SetupLockInTable(), SharedInvalBackendInit(), SharedRecordTypmodRegistryInit(), shdepChangeDep(), shdepDropOwned(), shdepLockAndCheckObject(), shdepReassignOwned(), shell_archive_file(), shell_archive_shutdown(), shm_toc_lookup(), shmem_exit(), should_apply_changes_for_rel(), show_grouping_set_keys(), show_sort_group_keys(), show_sortorder_options(), SICleanupQueue(), signal_child(), SignalBackends(), simple_heap_delete(), simple_heap_update(), simple_table_tuple_delete(), simple_table_tuple_update(), simplify_function(), SlabAlloc(), SlabContextCreate(), SlabFree(), SlabRealloc(), slot_compile_deform(), slot_getsomeattrs_int(), SlruReportIOError(), SlruScanDirectory(), smgr_redo(), smgrclose(), SnapBuildAddCommittedTxn(), SnapBuildClearExportedSnapshot(), SnapBuildCommitTxn(), SnapBuildDistributeNewCatalogSnapshot(), SnapBuildExportSnapshot(), SnapBuildFreeSnapshot(), SnapBuildInitialSnapshot(), SnapBuildProcessNewCid(), SnapBuildProcessRunningXacts(), SnapBuildPurgeOlderTxn(), SnapBuildSerialize(), SnapBuildSnapDecRefcount(), SnapBuildWaitSnapshot(), spg_box_quad_get_scankey_bbox(), spg_box_quad_inner_consistent(), spg_box_quad_leaf_consistent(), spg_kd_choose(), spg_kd_inner_consistent(), spg_quad_inner_consistent(), spg_quad_leaf_consistent(), spg_range_quad_inner_consistent(), spg_range_quad_leaf_consistent(), spg_redo(), spg_text_inner_consistent(), spg_text_leaf_consistent(), spgAddNodeAction(), spgbuild(), spgdoinsert(), spgExtractNodeLabels(), spgFormInnerTuple(), spgGetCache(), spggettuple(), spgInnerTest(), spgist_name_inner_consistent(), spgist_name_leaf_consistent(), SpGistGetBuffer(), SpGistPageAddNewItem(), spgMatchNodeAction(), spgPageIndexMultiDelete(), spgprocesspending(), spgRedoAddLeaf(), spgRedoAddNode(), spgRedoSplitTuple(), spgSplitNodeAction(), spgTestLeafTuple(), spgUpdateNodeLink(), spgvalidate(), spgWalk(), SPI_connect_ext(), SPI_cursor_close(), SPI_cursor_open_internal(), SPI_cursor_open_with_args(), SPI_cursor_parse_open(), SPI_datumTransfer(), spi_dest_startup(), SPI_freetuptable(), SPI_palloc(), spi_printtup(), ss_get_location(), SS_process_ctes(), ss_report_location(), ssl_extension_info(), standard_ExecutorRun(), standard_ExecutorStart(), standard_join_search(), standby_decode(), standby_redo(), StandbyAcquireAccessExclusiveLock(), StandbyReleaseAllLocks(), StandbyReleaseXidEntryLocks(), StartSubTransaction(), StartTransactionCommand(), StartupReplicationOrigin(), StartupReplicationSlots(), statapprox_heap(), statext_dependencies_deserialize(), statext_dependencies_load(), statext_expressions_load(), statext_is_kind_built(), statext_mcv_deserialize(), statext_mcv_load(), statext_ndistinct_deserialize(), statext_ndistinct_load(), StatisticsGetRelation(), StatisticsObjIsVisibleExt(), store_att_byval(), StoreAttrDefault(), StoreConstraints(), storeObjectDescription(), StorePartitionBound(), storeQueryResult(), storeRow(), StrategyGetBuffer(), stream_open_file(), StreamClose(), StreamServerPort(), string_agg_combine(), string_to_const(), stringify_adefprivs_objtype(), stringify_grant_objtype(), sts_initialize(), substitute_actual_parameters_mutator(), substitute_actual_srf_parameters_mutator(), SubTransGetTopmostTransaction(), summarize_range(), swap_relation_files(), SyncRepReleaseWaiters(), SysCacheGetAttr(), SysCacheGetAttrNotNull(), SysCacheInvalidate(), SysLoggerMain(), systable_beginscan(), systable_beginscan_ordered(), systable_getnext(), systable_getnext_ordered(), SystemAttributeDefinition(), table_index_fetch_tuple(), table_scan_bitmap_next_block(), table_scan_bitmap_next_tuple(), table_scan_getnextslot(), table_scan_sample_next_block(), table_scan_sample_next_tuple(), table_tuple_fetch_row_version(), table_tuple_get_latest_tid(), tblspc_redo(), tbm_add_tuples(), tbm_intersect(), test_atomic_uint32(), test_atomic_uint64(), test_bloomfilter(), test_dsa_basic(), test_empty(), test_enc_conversion(), test_fdw_handler(), test_huge_distances(), test_itemptr_pair(), test_lfind32(), test_lfind8_internal(), test_lfind8_le_internal(), test_pattern(), test_predtest(), test_rb_tree(), test_resowner_forget_between_phases(), test_resowner_many(), test_resowner_priorities(), test_resowner_remember_between_phases(), test_shm_mq_main(), test_single_value(), test_single_value_and_filler(), test_slru_page_delete(), test_slru_page_sync(), test_slru_scan_cb(), test_spinlock(), testcustomrmgrs_redo(), testdelete(), testfind(), testfindltgt(), testleftmost(), testleftright(), testrightleft(), text_format(), text_substring(), thesaurus_lexize(), thesaurusRead(), TidExprListCreate(), timestamp_in(), timestamptz_in(), tliOfPointInHistory(), toast_compress_datum(), toast_decompress_datum(), toast_decompress_datum_slice(), toast_fetch_datum(), toast_fetch_datum_slice(), toast_open_indexes(), TransactionBlockStatusCode(), TransactionIdDidAbort(), TransactionIdDidCommit(), transformAExprBetween(), transformAlterTableStmt(), transformBooleanTest(), transformBoolExpr(), transformCallStmt(), transformColumnDefinition(), transformConstraintAttrs(), transformCreateSchemaStmtElements(), transformCreateStmt(), transformDeclareCursorStmt(), transformExprRecurse(), transformFkeyCheckAttrs(), transformFkeyGetPrimaryKey(), transformFromClauseItem(), transformGenericOptions(), transformInsertStmt(), transformLockingClause(), transformMergeStmt(), transformMultiAssignRef(), transformPartitionBound(), transformPartitionBoundValue(), transformPartitionCmd(), transformPLAssignStmt(), transformRangeSubselect(), transformRuleStmt(), transformSubLink(), transformTableConstraint(), transformUpdateTargetList(), transformWindowDefinitions(), translate_col_privs_multilevel(), trigger_return_old(), triggered_change_notification(), TriggerSetParentTrigger(), TruncateMultiXact(), try_partitionwise_join(), try_relation_open(), tryAttachPartitionForeignKey(), TryReuseForeignKey(), TS_execute_locations_recurse(), TS_execute_recurse(), TS_phrase_execute(), ts_setup_firstcall(), ts_stat_sql(), TSConfigIsVisibleExt(), TSDictionaryIsVisibleExt(), TSParserIsVisibleExt(), tsquery_opr_selec(), tsquery_requires_match(), tsquery_rewrite_query(), tsqueryrecv(), tsquerysend(), TSTemplateIsVisibleExt(), tsvector_setweight(), tsvector_setweight_by_filter(), tsvector_unnest(), tsvector_update_trigger(), tsvectorin(), tsvectorrecv(), tt_setup_firstcall(), ttdummy(), tts_virtual_getsomeattrs(), TupleDescInitBuiltinEntry(), TupleDescInitEntry(), tuplesort_begin_batch(), tuplesort_begin_cluster(), tuplesort_begin_common(), tuplesort_begin_datum(), tuplesort_begin_heap(), tuplesort_begin_index_btree(), tuplesort_begin_index_gist(), tuplesort_begin_index_hash(), tuplesort_free(), tuplesort_gettuple_common(), tuplesort_markpos(), tuplesort_performsort(), tuplesort_puttuple_common(), tuplesort_rescan(), tuplesort_restorepos(), tuplesort_skiptuples(), tuplestore_alloc_read_pointer(), tuplestore_copy_read_pointer(), tuplestore_gettuple(), tuplestore_puttuple_common(), tuplestore_rescan(), tuplestore_select_read_pointer(), tuplestore_set_eflags(), TwoPhaseGetGXact(), TypeCreate(), TypeGetTupleDesc(), typeidType(), typeidTypeRelid(), typeIsOfTypedTable(), TypeIsVisibleExt(), typeOrDomainTypeRelid(), typeTypeId(), unify_hypothetical_args(), UnpinPortal(), update_default_partition_oid(), update_frameheadpos(), update_frametailpos(), update_relispartition(), UpdateActiveSnapshotCommandId(), UpdateDecodingStats(), UpdateLogicalMappings(), UpdateMinRecoveryPoint(), UpdateSharedMemoryConfig(), UpdateSubscriptionRelState(), UpdateTwoPhaseState(), UserAbortTransactionBlock(), UtfToLocal(), uuid_abbrev_abort(), uuid_generate_internal(), vac_truncate_clog(), vac_update_datfrozenxid(), vac_update_relstats(), vacuumLeafPage(), vacuumLeafRoot(), VacuumUpdateCosts(), validate_index(), validatePartitionedIndex(), varstr_abbrev_abort(), verify_client_proof(), verify_dictoptions(), verify_hash_page(), verifyBackupPageConsistency(), view_has_instead_trigger(), visibilitymap_clear(), visibilitymap_get_status(), visibilitymap_prepare_truncate(), visibilitymap_set(), wait_pid(), WaitEventExtensionNew(), WaitForProcSignalBarrier(), WaitForWALToBecomeAvailable(), WaitXLogInsertionsToFinish(), WalRcvWaitForStartPosition(), WalReceiverMain(), WalSndKeepalive(), window_gettupleslot(), WinGetFuncArgInFrame(), WinGetFuncArgInPartition(), WinRowsArePeers(), WinSetMarkPosition(), worker_spi_main(), write_item(), write_relcache_init_file(), write_relmap_file(), writeListPage(), WriteTempFileBlock(), X509_NAME_to_cstring(), xact_decode(), xact_redo(), XidCacheRemoveRunningXids(), xlog_decode(), xlog_redo(), XLogBackgroundFlush(), XLogBeginInsert(), XLogCheckInvalidPages(), XLogCompressBackupBlock(), XLogEnsureRecordSpace(), XLogFileCopy(), XLogFileInitInternal(), XLogFileRead(), XLogFileReadAnyTLI(), XLogFlush(), XLogInsert(), XLogInsertRecord(), XLogPrefetcherIsFiltered(), XLogPrefetcherNextBlock(), XLogReadBufferForRedoExtended(), XLogReadDetermineTimeline(), XLogRecGetBlockTag(), XLogRecordAssemble(), xlogrecovery_redo(), XLogRegisterBlock(), XLogRegisterBufData(), XLogRegisterBuffer(), XLogSendLogical(), XLogSendPhysical(), XLogWalRcvSendHSFeedback(), XLogWalRcvSendReply(), XLogWrite(), XmlTableGetValue(), and xpath_table().
|
static |
Definition at line 2877 of file dblink.c.
References appendStringInfoChar(), buf, initStringInfo(), and generate_unaccent_rules::str.
Referenced by get_connect_string().
|
static |
Definition at line 2502 of file dblink.c.
References get_namespace_name(), quote_qualified_identifier(), RelationData::rd_rel, RelationGetRelationName, RelationGetRelid, and RelationIsVisible().
Referenced by get_sql_delete(), get_sql_insert(), get_sql_update(), and get_tuple_of_interest().
|
static |
Definition at line 2349 of file dblink.c.
References i, and sort-test::key.
Referenced by get_sql_insert(), and get_sql_update().
|
static |
Definition at line 2787 of file dblink.c.
References ACL_USAGE, aclcheck_error(), ACLCHECK_OK, appendStringInfo(), DefElem::arg, buf, DefElem::defname, ereport, errcode(), errdetail(), errmsg(), ERROR, escape_param_str(), ForeignServer::fdwid, GetForeignDataWrapper(), GetForeignServerByName(), GetUserId(), GetUserMapping(), initStringInfo(), is_valid_dblink_option(), lfirst, object_aclcheck(), OBJECT_FOREIGN_SERVER, ForeignDataWrapper::options, ForeignServer::options, UserMapping::options, PQconndefaults(), pstrdup(), ForeignServer::serverid, ForeignServer::servername, strVal, and truncate_identifier().
Referenced by dblink_connect(), and dblink_get_conn().
Definition at line 2015 of file dblink.c.
References AccessShareLock, BTEqualStrategyNumber, GETSTRUCT, HeapTupleIsValid, i, ObjectIdGetDatum(), palloc_array, RelationData::rd_att, RelationGetRelid, ScanKeyInit(), SPI_fname(), systable_beginscan(), systable_endscan(), systable_getnext(), table_close(), and table_open().
Referenced by dblink_get_pkey().
|
static |
Definition at line 2477 of file dblink.c.
References aclcheck_error(), ACLCHECK_OK, get_relkind_objtype(), GetUserId(), makeRangeVarFromNameList(), pg_class_aclcheck(), RelationData::rd_rel, RelationGetRelationName, RelationGetRelid, table_openrv(), and textToQualifiedNameList().
Referenced by dblink_build_sql_delete(), dblink_build_sql_insert(), dblink_build_sql_update(), and dblink_get_pkey().
|
static |
Definition at line 2206 of file dblink.c.
References appendStringInfo(), appendStringInfoString(), buf, generate_relation_name(), i, initStringInfo(), NameStr, quote_ident_cstr(), quote_literal_cstr(), RelationData::rd_att, relname, and TupleDescAttr.
Referenced by dblink_build_sql_delete().
|
static |
Definition at line 2126 of file dblink.c.
References appendStringInfo(), appendStringInfoChar(), appendStringInfoString(), buf, ereport, errcode(), errmsg(), ERROR, generate_relation_name(), get_attnum_pk_pos(), get_tuple_of_interest(), i, initStringInfo(), sort-test::key, NameStr, TupleDescData::natts, pfree(), pstrdup(), quote_ident_cstr(), quote_literal_cstr(), RelationData::rd_att, relname, SPI_getvalue(), TupleDescAttr, and val.
Referenced by dblink_build_sql_insert().
|
static |
Definition at line 2243 of file dblink.c.
References appendStringInfo(), appendStringInfoString(), buf, ereport, errcode(), errmsg(), ERROR, generate_relation_name(), get_attnum_pk_pos(), get_tuple_of_interest(), i, initStringInfo(), sort-test::key, NameStr, TupleDescData::natts, pfree(), pstrdup(), quote_ident_cstr(), quote_literal_cstr(), RelationData::rd_att, relname, SPI_getvalue(), TupleDescAttr, and val.
Referenced by dblink_build_sql_update().
|
static |
Definition at line 2070 of file dblink.c.
References ARR_DATA_PTR, ARR_DIMS, ARR_ELEMTYPE, ARR_NDIM, ARR_NULLBITMAP, ArrayGetNItems(), Assert(), att_addlength_pointer, att_align_nominal, get_typlenbyvalalign(), i, nitems, palloc_array, PointerGetDatum(), TextDatumGetCString, typalign, and values.
Referenced by dblink_build_sql_delete(), dblink_build_sql_insert(), and dblink_build_sql_update().
|
static |
Definition at line 2364 of file dblink.c.
References appendStringInfo(), appendStringInfoString(), buf, elog(), ereport, errcode(), errmsg(), ERROR, generate_relation_name(), i, initStringInfo(), NameStr, TupleDescData::natts, pfree(), quote_ident_cstr(), quote_literal_cstr(), RelationData::rd_att, relname, SPI_connect(), SPI_copytuple(), SPI_exec(), SPI_finish(), SPI_OK_SELECT, SPI_processed, SPI_tuptable, TupleDescAttr, and SPITupleTable::vals.
Referenced by get_sql_insert(), and get_sql_update().
|
static |
Definition at line 2520 of file dblink.c.
References createConnHash(), HASH_FIND, hash_search(), sort-test::key, name, pstrdup(), remoteConnHashEnt::rconn, remoteConnHash, and truncate_identifier().
Referenced by dblink_close(), dblink_disconnect(), dblink_fetch(), dblink_get_conn(), dblink_get_named_conn(), and dblink_open().
|
static |
Definition at line 2981 of file dblink.c.
References _PQconninfoOption::dispchar, and _PQconninfoOption::keyword.
Referenced by dblink_fdw_validator(), and get_connect_string().
|
static |
Definition at line 987 of file dblink.c.
References res, and FunctionCallInfoBaseData::resultinfo.
Referenced by dblink_record_internal().
|
static |
Definition at line 848 of file dblink.c.
References applyRemoteGucs(), Assert(), BuildTupleFromCStrings(), conn, CreateTemplateTupleDesc(), CreateTupleDescCopy(), ReturnSetInfo::econtext, ExprContext::ecxt_per_query_memory, elog(), ereport, errcode(), errmsg(), ERROR, get_call_result_type(), i, MemoryContextSwitchTo(), TupleDescData::natts, palloc_array, PG_END_TRY, PG_FINALLY, PG_TRY, PGRES_COMMAND_OK, PGRES_TUPLES_OK, PQclear(), PQcmdStatus(), PQgetisnull(), PQgetvalue(), PQnfields(), PQntuples(), PQresultStatus(), res, restoreLocalGucs(), FunctionCallInfoBaseData::resultinfo, ReturnSetInfo::returnMode, ReturnSetInfo::setDesc, ReturnSetInfo::setResult, SFRM_Materialize, TupleDescGetAttInMetadata(), TupleDescInitEntry(), tuplestore_begin_heap(), tuplestore_puttuple(), TYPEFUNC_COMPOSITE, TYPEFUNC_RECORD, values, and work_mem.
Referenced by dblink_fetch(), and dblink_record_internal().
PG_FUNCTION_INFO_V1 | ( | dblink_build_sql_delete | ) |
PG_FUNCTION_INFO_V1 | ( | dblink_build_sql_insert | ) |
PG_FUNCTION_INFO_V1 | ( | dblink_build_sql_update | ) |
PG_FUNCTION_INFO_V1 | ( | dblink_cancel_query | ) |
PG_FUNCTION_INFO_V1 | ( | dblink_close | ) |
PG_FUNCTION_INFO_V1 | ( | dblink_connect | ) |
PG_FUNCTION_INFO_V1 | ( | dblink_current_query | ) |
PG_FUNCTION_INFO_V1 | ( | dblink_disconnect | ) |
PG_FUNCTION_INFO_V1 | ( | dblink_error_message | ) |
PG_FUNCTION_INFO_V1 | ( | dblink_exec | ) |
PG_FUNCTION_INFO_V1 | ( | dblink_fdw_validator | ) |
PG_FUNCTION_INFO_V1 | ( | dblink_fetch | ) |
PG_FUNCTION_INFO_V1 | ( | dblink_get_connections | ) |
PG_FUNCTION_INFO_V1 | ( | dblink_get_notify | ) |
PG_FUNCTION_INFO_V1 | ( | dblink_get_pkey | ) |
PG_FUNCTION_INFO_V1 | ( | dblink_get_result | ) |
PG_FUNCTION_INFO_V1 | ( | dblink_is_busy | ) |
PG_FUNCTION_INFO_V1 | ( | dblink_open | ) |
PG_FUNCTION_INFO_V1 | ( | dblink_record | ) |
PG_FUNCTION_INFO_V1 | ( | dblink_send_query | ) |
PQclear | ( | res | ) |
Referenced by _check_database_version(), _doSetSessionAuth(), _selectOutputSchema(), _selectTableAccessMethod(), _selectTablespace(), add_tablespace_footer(), addFooterToPublicationDesc(), advanceConnectionState(), append_depends_on_extension(), appendQualifiedRelation(), BaseBackup(), binary_upgrade_set_pg_class_oids(), binary_upgrade_set_type_oids_by_type_oid(), buildMatViewRefreshDependencies(), buildShSecLabels(), check_for_data_types_usage(), check_for_incompatible_polymorphics(), check_for_isn_and_int8_passing_mismatch(), check_for_pg_role_prefix(), check_for_prepared_transactions(), check_for_tables_with_oids(), check_for_user_defined_encoding_conversions(), check_for_user_defined_postfix_ops(), check_is_install_user(), check_loadable_libraries(), check_new_cluster_logical_replication_slots(), check_prepare_conn(), check_proper_datallowconn(), ClearOrSaveResult(), close_cursor(), cluster_all_databases(), collectComments(), collectRoleNames(), collectSecLabels(), compile_database_list(), compile_relation_list_one_db(), ConnectDatabase(), connectDatabase(), connectToServer(), convertTSFunction(), create_cursor(), create_logical_replication_slots(), CreateReplicationSlot(), createViewAsClause(), dblink_close(), dblink_exec(), dblink_fetch(), dblink_open(), dblink_res_error(), deallocate_one(), deallocate_query(), describeAccessMethods(), describeAggregates(), describeConfigurationParameters(), describeFunctions(), describeOneTableDetails(), describeOneTSConfig(), describeOneTSParser(), describeOperators(), describePublications(), DescribeQuery(), describeRoleGrants(), describeRoles(), describeSubscriptions(), describeTableDetails(), describeTablespaces(), describeTypes(), descriptor_free(), discardUntilSync(), do_lo_import(), do_sql_command_end(), dropDBs(), DropReplicationSlot(), dropRoles(), dropTablespaces(), dumpAgg(), dumpBaseType(), dumpCollation(), dumpCompositeType(), dumpConversion(), dumpDatabase(), dumpDatabaseConfig(), dumpDatabases(), dumpDomain(), dumpEnumType(), dumpForeignServer(), dumpFunc(), dumpLOs(), dumpOpclass(), dumpOpfamily(), dumpOpr(), dumpRangeType(), dumpRoleGUCPrivs(), dumpRoleMembership(), dumpRoles(), dumpRule(), dumpSearchPath(), dumpSequence(), dumpSequenceData(), dumpStatisticsExt(), dumpTable(), dumpTableAttach(), dumpTableData_copy(), dumpTableData_insert(), dumpTableSchema(), dumpTablespaces(), dumpTSConfig(), dumpTSDictionary(), dumpUserConfig(), dumpUserMappings(), ecpg_autostart_transaction(), ecpg_check_PQresult(), ecpg_process_output(), ECPGdescribe(), ECPGsetcommit(), ECPGtrans(), EndDBCopyMode(), exec_command_password(), ExecQueryUsingCursor(), execute_foreign_modify(), executeCommand(), executeMaintenanceCommand(), executeQueryOrDie(), ExecuteSqlCommand(), ExecuteSqlStatement(), executeStatement(), expand_dbname_patterns(), expand_extension_name_patterns(), expand_foreign_server_name_patterns(), expand_schema_name_patterns(), expand_table_name_patterns(), fail_lo_xact(), fetch_more_data(), finish_lo_xact(), get_create_object_cmd(), get_db_infos(), get_language_name(), get_loadable_libraries(), get_next_possible_free_pg_type_oid(), get_old_cluster_logical_slot_infos(), get_parallel_object_list(), get_rel_infos(), get_remote_estimate(), get_returning_data(), get_synchronized_snapshot(), get_tablespace_paths(), get_template0_info(), getAccessMethods(), getAdditionalACLs(), getAggregates(), getCasts(), getCollations(), GetConnection(), getConstraints(), getConversions(), getCopyStart(), getDefaultACLs(), getDependencies(), getDomainConstraints(), getEventTriggers(), getExtendedStatistics(), getExtensionMembership(), getExtensions(), getForeignDataWrappers(), getForeignServers(), getFormattedTypeName(), getFuncs(), getIndexes(), getInherits(), getLOs(), getNamespaces(), getOpclasses(), getOperators(), getOpfamilies(), getParamDescriptions(), getPartitioningInfo(), getPolicies(), getProcLangs(), getPublicationNamespaces(), getPublications(), getPublicationTables(), getRowDescriptions(), getRules(), GetSlotInformation(), getSubscriptions(), getTableAttrs(), GetTableInfo(), getTables(), getTransforms(), getTriggers(), getTSConfigurations(), getTSDictionaries(), getTSParsers(), getTSTemplates(), getTypes(), handleCopyIn(), HandleCopyResult(), HandleEndOfCopyStream(), init_libpq_conn(), initPopulateTable(), libpq_fetch_file(), libpq_traverse_files(), libpqrcv_connect(), libpqrcv_create_slot(), libpqrcv_endstreaming(), libpqrcv_exec(), libpqrcv_identify_system(), libpqrcv_PQexec(), libpqrcv_readtimelinehistoryfile(), libpqrcv_receive(), libpqrcv_startstreaming(), listAllDbs(), listCasts(), listCollations(), listConversions(), listDbRoleSettings(), listDefaultACLs(), listDomains(), listEventTriggers(), listExtendedStats(), listExtensionContents(), listExtensions(), listForeignDataWrappers(), listForeignServers(), listForeignTables(), listLanguages(), listLargeObjects(), listOneExtensionContents(), listOperatorClasses(), listOperatorFamilies(), listOpFamilyFunctions(), listOpFamilyOperators(), listPartitionedTables(), listPublications(), listSchemas(), listTables(), listTSConfigs(), listTSConfigsVerbose(), listTSDictionaries(), listTSParsers(), listTSParsersVerbose(), listTSTemplates(), listUserMappings(), lo_close(), lo_creat(), lo_create(), lo_initialize(), lo_lseek(), lo_lseek64(), lo_open(), lo_read(), lo_tell(), lo_tell64(), lo_truncate(), lo_truncate64(), lo_unlink(), lo_write(), lockTableForWorker(), lookup_object_oid(), main(), materializeResult(), objectDescription(), old_9_6_invalidate_hash_indexes(), permissionsList(), pgfdw_cancel_query_end(), pgfdw_exec_cleanup_query_end(), pgfdw_finish_pre_commit_cleanup(), pgfdw_get_cleanup_result(), pgfdw_get_result(), pgfdw_report_error(), pgfdw_xact_callback(), postgresAcquireSampleRowsFunc(), postgresAnalyzeForeignTable(), postgresEndDirectModify(), postgresGetAnalyzeInfoForForeignTable(), postgresImportForeignSchema(), postgresReScanForeignScan(), PQconnectPoll(), PQencryptPasswordConn(), pqEndcopy3(), pqGetErrorNotice3(), PQsetClientEncoding(), prepare_common(), prepare_foreign_modify(), prepareCommand(), process_queued_fetch_requests(), process_result(), processExtensionTables(), processQueryResult(), readCommandResponse(), ReceiveCopyData(), ReceiveXlogStream(), reindex_all_databases(), report_extension_updates(), RetrieveDataDirCreatePerm(), RetrieveWalSegSize(), run_permutation(), run_simple_command(), run_simple_query(), RunIdentifySystem(), SendQuery(), set_frozenxids(), set_locale_and_encoding(), setup_connection(), sql_conn(), sql_exec(), start_lo_xact(), store_returning_result(), storeQueryResult(), StreamLogicalLog(), TableCommandResultHandler(), test_multi_pipelines(), test_nosync(), test_pipeline_abort(), test_pipeline_idle(), test_pipelined_insert(), test_prepared(), test_simple_pipeline(), test_singlerowmode(), test_transaction(), try_complete_step(), tryExecuteStatement(), vacuum_all_databases(), vacuum_one_database(), and vacuumlo().
|
static |
Definition at line 820 of file dblink.c.
References ReturnSetInfo::allowedModes, ereport, errcode(), errmsg(), ERROR, if(), IsA, FunctionCallInfoBaseData::resultinfo, ReturnSetInfo::returnMode, ReturnSetInfo::setDesc, ReturnSetInfo::setResult, and SFRM_Materialize.
Referenced by dblink_fetch(), and dblink_record_internal().
|
static |
Definition at line 2334 of file dblink.c.
References cstring_to_text(), DatumGetTextPP, DirectFunctionCall1, PointerGetDatum(), quote_ident(), and text_to_cstring().
Referenced by get_sql_delete(), get_sql_insert(), get_sql_update(), and get_tuple_of_interest().
|
static |
Definition at line 3084 of file dblink.c.
References AtEOXact_GUC().
Referenced by materializeResult(), and storeQueryResult().
|
static |
Definition at line 1102 of file dblink.c.
References applyRemoteGucs(), CHECK_FOR_INTERRUPTS, conn, storeInfo::cur_res, elog(), ERROR, storeInfo::last_res, pchomp(), PGRES_SINGLE_TUPLE, PGRES_TUPLES_OK, PQclear(), PQerrorMessage(), PQgetResult(), PQresultStatus(), PQsendQuery(), PQsetSingleRowMode(), res, restoreLocalGucs(), and storeRow().
Definition at line 1170 of file dblink.c.
References Assert(), storeInfo::attinmeta, BuildTupleFromCStrings(), CreateTupleDescCopy(), storeInfo::cstrs, ReturnSetInfo::econtext, ExprContext::ecxt_per_query_memory, elog(), ereport, errcode(), errmsg(), ERROR, storeInfo::fcinfo, get_call_result_type(), i, if(), MemoryContextReset(), MemoryContextSwitchTo(), TupleDescData::natts, palloc_array, pfree(), PQgetisnull(), PQgetvalue(), PQnfields(), PQntuples(), res, FunctionCallInfoBaseData::resultinfo, ReturnSetInfo::setDesc, ReturnSetInfo::setResult, storeInfo::tmpcontext, TupleDescGetAttInMetadata(), storeInfo::tuplestore, tuplestore_begin_heap(), tuplestore_end(), tuplestore_puttuple(), TYPEFUNC_COMPOSITE, TYPEFUNC_RECORD, and work_mem.
Referenced by storeQueryResult().
|
static |
Definition at line 2910 of file dblink.c.
References int2vector::dim1, ereport, errcode(), errmsg(), ERROR, i, j, Min, TupleDescData::natts, palloc_array, RelationData::rd_att, TupleDescAttr, and int2vector::values.
Referenced by dblink_build_sql_delete(), dblink_build_sql_insert(), and dblink_build_sql_update().
|
static |
|
static |
Definition at line 134 of file dblink.c.
Referenced by dblink_connect().
|
static |
Definition at line 135 of file dblink.c.
Referenced by dblink_get_conn().
void PGresult const char* p2 |
Definition at line 163 of file dblink.c.
Referenced by bit_and(), bit_or(), bitxor(), byteapos(), colorTrgmInfoCmp(), colorTrgmInfoPenaltyCmp(), comp_ptrgm(), compare3(), compare4(), crlf_process(), DOTypeNameCompare(), ecpg_filter_stderr(), gbt_var_node_cp_len(), gist_bbox_zorder_cmp(), inter_lb(), interpt_pp(), library_name_compare(), list_cookedconstr_attnum_cmp(), list_int_cmp(), list_oid_cmp(), oid_cmp(), packArcInfoCmp(), packGraph(), parse_cipher_name(), passwordFromFile(), path_add(), path_distance(), path_inter(), path_n_eq(), path_n_ge(), path_n_gt(), path_n_le(), path_n_lt(), plist_same(), point_add(), point_div(), point_mul(), point_sub(), points_box(), rlocator_comparator(), selectColorTrigrams(), sort_order_cmp(), TocEntrySizeCompareBinaryheap(), TocEntrySizeCompareQsort(), and wchareq().
|
static |
Definition at line 130 of file dblink.c.
Referenced by dblink_close(), dblink_connect(), dblink_disconnect(), dblink_exec(), dblink_fetch(), dblink_get_notify(), dblink_init(), dblink_open(), and dblink_record_internal().
|
static |
Definition at line 131 of file dblink.c.
Referenced by createNewConnection(), dblink_get_connections(), deleteConnection(), and getConnectionByName().
void PGresult* res |
Definition at line 163 of file dblink.c.
Referenced by _bt_binsrch_posting(), _check_database_version(), _doSetSessionAuth(), _int_contains(), _intbig_alloc(), _lca(), _lt_q_regex(), _ltq_regex(), _ltree_consistent(), _ltree_isparent(), _ltree_risparent(), _ltxtq_exec(), _pgp_read_public_key(), _ReadByte(), _selectOutputSchema(), _selectTableAccessMethod(), _selectTablespace(), _SPI_execute_plan(), _SPI_pquery(), _tarAddFile(), _tarReadRaw(), _tocEntryRequired(), addFooterToPublicationDesc(), addItemPointersToLeafTuple(), advance_windowaggregate(), advance_windowaggregate_base(), advanceConnectionState(), analyze_row_processor(), anybit_typmodout(), anychar_typmodout(), append_depends_on_extension(), appendBoolResult(), appendQualifiedRelation(), appendReloptionsArrayAH(), BaseBackup(), bf_check_supported_key_len(), binary_decode(), binary_encode(), binary_upgrade_set_type_oids_by_type_oid(), blgetbitmap(), BloomFormTuple(), bn_to_mpi(), btgettuple(), btproperty(), buildFreshLeafTuple(), buildMatViewRefreshDependencies(), buildShSecLabels(), byteaSetBit(), byteaSetByte(), calc_key_id(), calc_rank(), calc_rank_and(), calc_rank_or(), cfb_process(), check_field_number(), check_for_data_types_usage(), check_for_incompatible_polymorphics(), check_for_isn_and_int8_passing_mismatch(), check_for_pg_role_prefix(), check_for_prepared_transactions(), check_for_tables_with_oids(), check_for_user_defined_encoding_conversions(), check_for_user_defined_postfix_ops(), check_is_install_user(), check_key_cksum(), check_key_sha1(), check_loadable_libraries(), check_locale(), check_locale_name(), check_new_cluster_logical_replication_slots(), check_param_number(), check_prepare_conn(), check_publications(), check_publications_origin(), check_tuple_field_number(), checkcondition_str(), CheckForBufferLeaks(), clean_NOT_intree(), clean_stopword_intree(), close_cursor(), cmp_list_len_contents_asc(), cmpEntries(), cmpTheLexeme(),