PostgreSQL Source Code
git master
|
Go to the source code of this file.
Typedefs | |
typedef char * | pg_stack_base_t |
typedef enum BackendType | BackendType |
typedef enum ProcessingMode | ProcessingMode |
typedef void(* | shmem_request_hook_type) (void) |
Enumerations | |
enum | BackendType { B_INVALID = 0 , B_ARCHIVER , B_AUTOVAC_LAUNCHER , B_AUTOVAC_WORKER , B_BACKEND , B_BG_WORKER , B_BG_WRITER , B_CHECKPOINTER , B_LOGGER , B_STANDALONE_BACKEND , B_STARTUP , B_WAL_RECEIVER , B_WAL_SENDER , B_WAL_WRITER } |
enum | ProcessingMode { BootstrapProcessing , InitProcessing , NormalProcessing } |
enum | AuxProcType { NotAnAuxProcess = -1 , StartupProcess = 0 , BgWriterProcess , ArchiverProcess , CheckpointerProcess , WalWriterProcess , WalReceiverProcess , NUM_AUXPROCTYPES } |
#define AmArchiverProcess | ( | ) | (MyAuxProcType == ArchiverProcess) |
Definition at line 454 of file miscadmin.h.
#define AmBackgroundWriterProcess | ( | ) | (MyAuxProcType == BgWriterProcess) |
Definition at line 453 of file miscadmin.h.
#define AmCheckpointerProcess | ( | ) | (MyAuxProcType == CheckpointerProcess) |
Definition at line 455 of file miscadmin.h.
#define AmStartupProcess | ( | ) | (MyAuxProcType == StartupProcess) |
Definition at line 452 of file miscadmin.h.
#define AmWalReceiverProcess | ( | ) | (MyAuxProcType == WalReceiverProcess) |
Definition at line 457 of file miscadmin.h.
#define AmWalWriterProcess | ( | ) | (MyAuxProcType == WalWriterProcess) |
Definition at line 456 of file miscadmin.h.
#define BACKEND_NUM_TYPES (B_WAL_WRITER + 1) |
Definition at line 344 of file miscadmin.h.
#define CHECK_FOR_INTERRUPTS | ( | ) |
Definition at line 121 of file miscadmin.h.
#define DATEORDER_DMY 1 |
Definition at line 237 of file miscadmin.h.
#define DATEORDER_MDY 2 |
Definition at line 238 of file miscadmin.h.
#define DATEORDER_YMD 0 |
Definition at line 236 of file miscadmin.h.
#define END_CRIT_SECTION | ( | ) |
Definition at line 150 of file miscadmin.h.
#define GetProcessingMode | ( | ) | Mode |
Definition at line 418 of file miscadmin.h.
#define HOLD_CANCEL_INTERRUPTS | ( | ) | (QueryCancelHoldoffCount++) |
Definition at line 140 of file miscadmin.h.
#define HOLD_INTERRUPTS | ( | ) | (InterruptHoldoffCount++) |
Definition at line 132 of file miscadmin.h.
#define INTERRUPTS_CAN_BE_PROCESSED | ( | ) |
Definition at line 128 of file miscadmin.h.
#define INTERRUPTS_PENDING_CONDITION | ( | ) | (unlikely(InterruptPending)) |
Definition at line 112 of file miscadmin.h.
#define INTSTYLE_ISO_8601 3 |
Definition at line 253 of file miscadmin.h.
#define INTSTYLE_POSTGRES 0 |
Definition at line 250 of file miscadmin.h.
#define INTSTYLE_POSTGRES_VERBOSE 1 |
Definition at line 251 of file miscadmin.h.
#define INTSTYLE_SQL_STANDARD 2 |
Definition at line 252 of file miscadmin.h.
#define InvalidPid (-1) |
Definition at line 32 of file miscadmin.h.
#define IsBootstrapProcessingMode | ( | ) | (Mode == BootstrapProcessing) |
Definition at line 414 of file miscadmin.h.
#define IsInitProcessingMode | ( | ) | (Mode == InitProcessing) |
Definition at line 415 of file miscadmin.h.
#define IsNormalProcessingMode | ( | ) | (Mode == NormalProcessing) |
Definition at line 416 of file miscadmin.h.
#define MAX_BAS_VAC_RING_SIZE_KB (16 * 1024 * 1024) |
Definition at line 272 of file miscadmin.h.
Definition at line 257 of file miscadmin.h.
#define MIN_BAS_VAC_RING_SIZE_KB 128 |
Definition at line 271 of file miscadmin.h.
#define RESUME_CANCEL_INTERRUPTS | ( | ) |
Definition at line 142 of file miscadmin.h.
#define RESUME_INTERRUPTS | ( | ) |
Definition at line 134 of file miscadmin.h.
#define SECURITY_LOCAL_USERID_CHANGE 0x0001 |
Definition at line 313 of file miscadmin.h.
#define SECURITY_NOFORCE_RLS 0x0004 |
Definition at line 315 of file miscadmin.h.
#define SECURITY_RESTRICTED_OPERATION 0x0002 |
Definition at line 314 of file miscadmin.h.
#define SetProcessingMode | ( | mode | ) |
Definition at line 420 of file miscadmin.h.
#define START_CRIT_SECTION | ( | ) | (CritSectionCount++) |
Definition at line 148 of file miscadmin.h.
#define USE_GERMAN_DATES 3 |
Definition at line 232 of file miscadmin.h.
#define USE_ISO_DATES 1 |
Definition at line 230 of file miscadmin.h.
#define USE_POSTGRES_DATES 0 |
Definition at line 229 of file miscadmin.h.
#define USE_SQL_DATES 2 |
Definition at line 231 of file miscadmin.h.
#define USE_XSD_DATES 4 |
Definition at line 233 of file miscadmin.h.
typedef enum BackendType BackendType |
typedef char* pg_stack_base_t |
Definition at line 291 of file miscadmin.h.
typedef enum ProcessingMode ProcessingMode |
typedef void(* shmem_request_hook_type) (void) |
Definition at line 497 of file miscadmin.h.
enum AuxProcType |
Enumerator | |
---|---|
NotAnAuxProcess | |
StartupProcess | |
BgWriterProcess | |
ArchiverProcess | |
CheckpointerProcess | |
WalWriterProcess | |
WalReceiverProcess | |
NUM_AUXPROCTYPES |
Definition at line 437 of file miscadmin.h.
enum BackendType |
Enumerator | |
---|---|
B_INVALID | |
B_ARCHIVER | |
B_AUTOVAC_LAUNCHER | |
B_AUTOVAC_WORKER | |
B_BACKEND | |
B_BG_WORKER | |
B_BG_WRITER | |
B_CHECKPOINTER | |
B_LOGGER | |
B_STANDALONE_BACKEND | |
B_STARTUP | |
B_WAL_RECEIVER | |
B_WAL_SENDER | |
B_WAL_WRITER |
Definition at line 326 of file miscadmin.h.
enum ProcessingMode |
Enumerator | |
---|---|
BootstrapProcessing | |
InitProcessing | |
NormalProcessing |
Definition at line 405 of file miscadmin.h.
void AddToDataDirLockFile | ( | int | target_line, |
const char * | str | ||
) |
Definition at line 1497 of file miscinit.c.
References close, DIRECTORY_LOCK_FILE, ereport, errcode_for_file_access(), errmsg(), fd(), len, LOG, PG_BINARY, pg_fsync(), pg_pwrite, pgstat_report_wait_end(), pgstat_report_wait_start(), read, snprintf, and generate_unaccent_rules::str.
Referenced by InternalIpcMemoryCreate(), PostmasterMain(), process_pm_child_exit(), process_pm_pmsignal(), and process_pm_shutdown_request().
void BaseInit | ( | void | ) |
Definition at line 629 of file postinit.c.
References Assert(), DebugFileOpen(), InitBufferPoolAccess(), InitFileAccess(), InitSync(), InitTemporaryFileAccess(), InitXLogInsert(), MyProc, pgstat_initialize(), ReplicationSlotInitialize(), and smgrinit().
Referenced by AutoVacLauncherMain(), AutoVacWorkerMain(), AuxiliaryProcessMain(), BootstrapModeMain(), PostgresMain(), and StartBackgroundWorker().
void ChangeToDataDir | ( | void | ) |
Definition at line 449 of file miscinit.c.
References Assert(), DataDir, ereport, errcode_for_file_access(), errmsg(), and FATAL.
Referenced by BootstrapModeMain(), PostgresSingleUserMain(), and PostmasterMain().
void check_stack_depth | ( | void | ) |
Definition at line 3523 of file postgres.c.
References ereport, errcode(), errhint(), errmsg(), ERROR, max_stack_depth, and stack_is_too_deep().
Referenced by _jumbleNode(), AlterTypeRecurse(), apply_scanjoin_target_to_paths(), checkCond(), clean_NOT_intree(), clean_stopword_intree(), cntsize(), contains_required_value(), convertJsonbValue(), copyObjectImpl(), Cover(), create_plan_recurse(), datum_to_json_internal(), datum_to_jsonb_internal(), dofindsubquery(), emit_jsp_gin_entries(), equal(), EventTriggerInvoke(), ExecEndNode(), ExecEvalSubPlan(), ExecInitExprRec(), ExecInitNode(), ExecMakeFunctionResultSet(), ExecProcNodeFirst(), ExecShutdownNode_walker(), execute(), executeAnyItem(), executeItemOptUnwrapTarget(), expand_partitioned_rtentry(), expression_tree_mutator_impl(), expression_tree_walker_impl(), extract_jsp_bool_expr(), fillQT(), find_composite_type_dependencies(), find_matching_subplans_recurse(), findoprnd(), findoprnd_recurse(), flatten_grouping_sets(), flattenJsonPathParseItem(), FreePageManagerDumpBtree(), freetree(), generate_partition_qual(), generate_partitionwise_join_paths(), get_query_def(), get_rels_with_domain(), get_rule_expr(), get_setop_query(), get_steps_using_prefix_recurse(), gistSplit(), hash_range(), hash_range_extended(), hash_record(), hash_record_extended(), hk_depth_search(), infix(), inline_set_returning_function(), int_query_opr_selec(), is_simple_union_all_recurse(), JsonbDeepContains(), lseg_inside_poly(), ltree_execute(), makepol(), maketree(), MatchText(), MultiExecProcNode(), outNode(), p_ishost(), p_isURLPath(), parse_array(), parse_object(), parseNodeString(), plainnode(), planstate_tree_walker_impl(), plperl_hash_from_tuple(), plperl_sv_to_datum(), PLy_input_setup_func(), PLy_output_setup_func(), populate_array_dim_jsonb(), populate_record_field(), printJsonPathItem(), pull_up_sublinks_jointree_recurse(), pull_up_subqueries_recurse(), QT2QTN(), QTNBinary(), QTNClearFlags(), QTNCopy(), QTNFree(), QTNodeCompare(), QTNSort(), QTNTernary(), range_cmp(), range_in(), range_out(), range_recv(), range_send(), raw_expression_tree_walker_impl(), record_cmp(), record_eq(), record_in(), record_out(), record_recv(), record_send(), recurse_set_operations(), regex_selectivity_sub(), relation_is_updatable(), resolve_special_varno(), set_append_rel_size(), setPath(), split_array(), SplitToVariants(), standard_ProcessUtility(), transformExprRecurse(), transformFromClauseItem(), transformSetOperationTree(), traverse_lacons(), try_partitionwise_join(), TS_execute_locations_recurse(), TS_execute_recurse(), TS_phrase_execute(), tsquery_opr_selec(), and tsquery_requires_match().
void checkDataDir | ( | void | ) |
Definition at line 336 of file miscinit.c.
References Assert(), data_directory_mode, DataDir, ereport, errcode(), errcode_for_file_access(), errdetail(), errhint(), errmsg(), FATAL, pg_dir_create_mode, pg_mode_mask, PG_MODE_MASK_GROUP, S_ISDIR, SetDataDirectoryCreatePerm(), stat::st_mode, stat::st_uid, stat, and ValidatePgVersion().
Referenced by BootstrapModeMain(), PostgresSingleUserMain(), and PostmasterMain().
void CreateDataDirLockFile | ( | bool | amPostmaster | ) |
Definition at line 1441 of file miscinit.c.
References CreateLockFile(), DataDir, and DIRECTORY_LOCK_FILE.
Referenced by BootstrapModeMain(), PostgresSingleUserMain(), and PostmasterMain().
void CreateSocketLockFile | ( | const char * | socketfile, |
bool | amPostmaster, | ||
const char * | socketDir | ||
) |
Definition at line 1450 of file miscinit.c.
References CreateLockFile(), MAXPGPATH, and snprintf.
Referenced by Lock_AF_UNIX().
Size EstimateClientConnectionInfoSpace | ( | void | ) |
Definition at line 1013 of file miscinit.c.
References add_size(), ClientConnectionInfo::authn_id, and MyClientConnectionInfo.
Referenced by InitializeParallelDSM().
size_t get_hash_memory_limit | ( | void | ) |
Definition at line 3587 of file nodeHash.c.
References hash_mem_multiplier, Min, and work_mem.
Referenced by BuildTupleHashTableExt(), choose_hashed_setop(), consider_groupingsets_paths(), cost_memoize_rescan(), create_unique_path(), ExecChooseHashTableSize(), ExecInitMemoize(), ExecParallelHashIncreaseNumBatches(), final_cost_hashjoin(), hash_agg_set_limits(), hash_choose_num_partitions(), subpath_is_hashable(), and subplan_is_hashable().
Oid GetAuthenticatedUserId | ( | void | ) |
Definition at line 578 of file miscinit.c.
References Assert(), AuthenticatedUserId, and OidIsValid.
Referenced by check_session_authorization(), and InitializeParallelDSM().
const char* GetBackendTypeDesc | ( | BackendType | backendType | ) |
Definition at line 264 of file miscinit.c.
References B_ARCHIVER, B_AUTOVAC_LAUNCHER, B_AUTOVAC_WORKER, B_BACKEND, B_BG_WORKER, B_BG_WRITER, B_CHECKPOINTER, B_INVALID, B_LOGGER, B_STANDALONE_BACKEND, B_STARTUP, B_WAL_RECEIVER, B_WAL_SENDER, and B_WAL_WRITER.
Referenced by BackendInitialize(), get_backend_type_for_log(), init_ps_display(), pg_stat_get_activity(), and pg_stat_get_io().
Oid GetCurrentRoleId | ( | void | ) |
Definition at line 910 of file miscinit.c.
References InvalidOid, OuterUserId, and SetRoleIsActive.
Referenced by InitializeParallelDSM(), and show_role().
Oid GetOuterUserId | ( | void | ) |
Definition at line 520 of file miscinit.c.
References Assert(), OidIsValid, and OuterUserId.
Referenced by DropRole(), and RenameRole().
Oid GetSessionUserId | ( | void | ) |
Definition at line 543 of file miscinit.c.
References Assert(), OidIsValid, and SessionUserId.
Referenced by check_role(), DropRole(), get_rolespec_oid(), get_rolespec_tuple(), InitPostgres(), pgstat_bestart(), RenameRole(), and session_user().
const char* GetSystemUser | ( | void | ) |
Oid GetUserId | ( | void | ) |
Definition at line 509 of file miscinit.c.
References Assert(), CurrentUserId, and OidIsValid.
Referenced by AggregateCreate(), AlterCollation(), AlterDatabase(), AlterDatabaseOwner(), AlterDatabaseRefreshColl(), AlterDatabaseSet(), AlterEventTrigger(), AlterEventTriggerOwner_internal(), AlterExtensionNamespace(), AlterForeignServer(), AlterForeignServerOwner_internal(), AlterFunction(), AlterObjectNamespace_internal(), AlterObjectOwner_internal(), AlterObjectRename_internal(), AlterOperator(), AlterOpFamilyAdd(), AlterPublication(), AlterPublicationOwner_internal(), AlterRole(), AlterRoleSet(), AlterSchemaOwner_internal(), AlterStatistics(), AlterSubscription(), AlterSubscriptionOwner_internal(), AlterSystemSetConfigFile(), AlterTableMoveAll(), AlterTableSpaceOptions(), AlterTSConfiguration(), AlterTSDictionary(), AlterType(), AlterTypeNamespace_oid(), AlterTypeOwner(), ATExecAddColumn(), ATExecChangeOwner(), ATPrepAlterColumnType(), ATPrepSetTableSpace(), ATSimplePermissions(), bbsink_server_new(), be_lo_put(), be_lo_unlink(), binary_upgrade_create_empty_extension(), brin_desummarize_range(), BuildCachedPlan(), BuildDescForRelation(), BuildIndexValueDescription(), calculate_database_size(), calculate_tablespace_size(), call_pltcl_start_proc(), check_enable_rls(), check_temp_tablespaces(), CheckCachedPlan(), checkDomainOwner(), checkEnumOwner(), checkFkeyPermissions(), CheckFunctionValidatorAccess(), CheckMyDatabase(), CheckSlotPermissions(), CommentObject(), compile_plperl_function(), compile_pltcl_function(), CompleteCachedPlan(), compute_return_type(), ConfigOptionIsVisible(), convert_and_check_filename(), CreateCast(), CreateConversionCommand(), createdb(), CreateEventTrigger(), CreateExtensionInternal(), CreateForeignDataWrapper(), CreateForeignServer(), CreateForeignTable(), CreateFunction(), CreateOpFamily(), CreateProceduralLanguage(), CreatePublication(), CreateRole(), CreateStatistics(), CreateSubscription(), CreateTableSpace(), CreateTransform(), CreateTriggerFiringOn(), current_user(), currtid_internal(), currval_oid(), DefineAggregate(), DefineCollation(), DefineDomain(), DefineEnum(), DefineIndex(), DefineOpClass(), DefineOperator(), DefineOpFamily(), DefineQueryRewrite(), DefineRange(), DefineRelation(), DefineTSConfiguration(), DefineTSDictionary(), DefineType(), do_setval(), DoCopy(), dropdb(), DropOwnedObjects(), DropRole(), DropSubscription(), DropTableSpace(), emit_audit_message(), EnableDisableRule(), examine_simple_variable(), examine_variable(), ExecAlterDefaultPrivilegesStmt(), ExecAlterExtensionContentsStmt(), ExecAlterExtensionStmt(), ExecAlterObjectDependsStmt(), ExecBuildGroupingEqual(), ExecBuildParamSetEqual(), ExecBuildSlotPartitionKeyDescription(), ExecBuildSlotValueDescription(), ExecCheckOneRelPerms(), ExecGetResultRelCheckAsUser(), ExecGrant_Attribute(), ExecGrant_common(), ExecGrant_Largeobject(), ExecGrant_Parameter(), ExecGrant_Relation(), ExecInitAgg(), ExecInitExprRec(), ExecInitFunc(), ExecInitWindowAgg(), ExecReindex(), ExecSecLabelStmt(), execute_extension_script(), ExecuteCallStmt(), ExecuteDoStmt(), ExecuteGrantStmt(), ExecuteTruncateGuts(), extension_is_trusted(), file_fdw_validator(), findRangeCanonicalFunction(), findRangeSubtypeDiffFunction(), FinishPreparedTransaction(), get_connect_string(), get_other_operator(), get_rel_from_relname(), get_rolespec_oid(), get_rolespec_tuple(), get_row_security_policies(), get_tables_to_cluster(), get_tables_to_cluster_partitioned(), GetConfigOptionValues(), gin_clean_pending_list(), GrantRole(), HandleFunctionRequest(), has_any_column_privilege_id(), has_any_column_privilege_name(), has_column_privilege_id_attnum(), has_column_privilege_id_name(), has_column_privilege_name_attnum(), has_column_privilege_name_name(), has_database_privilege_id(), has_database_privilege_name(), has_foreign_data_wrapper_privilege_id(), has_foreign_data_wrapper_privilege_name(), has_function_privilege_id(), has_function_privilege_name(), has_language_privilege_id(), has_language_privilege_name(), has_parameter_privilege_name(), has_schema_privilege_id(), has_schema_privilege_name(), has_sequence_privilege_id(), has_sequence_privilege_name(), has_server_privilege_id(), has_server_privilege_name(), has_table_privilege_id(), has_table_privilege_name(), has_tablespace_privilege_id(), has_tablespace_privilege_name(), has_type_privilege_id(), has_type_privilege_name(), have_createdb_privilege(), have_createrole_privilege(), heap_force_common(), ImportForeignSchema(), init_sexpr(), InitializeSearchPath(), InitPostgres(), InitTempTableNamespace(), inline_function(), inline_set_returning_function(), insert_username(), interpret_function_parameter_list(), inv_create(), inv_open(), LargeObjectCreate(), lastval(), LockViewRecurse(), LogicalRepSyncTableStart(), lookup_agg_function(), LookupCreationNamespace(), LookupExplicitNamespace(), MergeAttributes(), movedb(), nextval_internal(), OperatorCreate(), OperatorShellMake(), pg_has_role_id(), pg_has_role_name(), pg_import_system_collations(), pg_prewarm(), pg_sequence_last_value(), pg_sequence_parameters(), pg_signal_backend(), pg_stat_get_wal_receiver(), pg_stat_get_wal_senders(), pg_stat_statements_internal(), pgrowlocks(), pgss_store(), pgstat_get_backend_current_activity(), pltcl_fetch_interp(), postgresBeginDirectModify(), postgresBeginForeignScan(), postgresExecForeignTruncate(), postgresGetForeignRelSize(), postgresImportForeignSchema(), PrepareTempTablespaces(), PrepareTransaction(), PublicationAddTables(), RangeVarCallbackForAlterRelation(), RangeVarCallbackForDropRelation(), RangeVarCallbackForLockTable(), RangeVarCallbackForPolicy(), RangeVarCallbackForReindexIndex(), RangeVarCallbackForRenameRule(), RangeVarCallbackForRenameTrigger(), RangeVarCallbackOwnsRelation(), RangeVarCallbackOwnsTable(), RangeVarGetAndCheckCreationNamespace(), ReassignOwnedObjects(), recomputeNamespacePath(), REGRESS_exec_check_perms(), REGRESS_object_access_hook(), REGRESS_object_access_hook_str(), REGRESS_utility_command(), ReindexMultipleInternal(), ReindexMultipleTables(), RemoveObjects(), renameatt_check(), RenameDatabase(), RenameRole(), RenameSchema(), RenameTableSpace(), RenameType(), RevalidateCachedQuery(), RI_Initial_Check(), ri_ReportViolation(), select_perl_context(), set_config_option(), set_foreign_rel_properties(), shell_check_detail(), standard_ProcessUtility(), statext_is_compatible_clause(), superuser(), TargetPrivilegesCheck(), TerminateOtherDBBackends(), transformTableLikeClause(), truncate_check_perms(), user_mapping_ddl_aclcheck(), vacuum_is_relation_owner(), validate_option_array_item(), ValidateJoinEstimator(), and ValidateRestrictionEstimator().
void GetUserIdAndSecContext | ( | Oid * | userid, |
int * | sec_context | ||
) |
Definition at line 630 of file miscinit.c.
References CurrentUserId, and SecurityRestrictionContext.
Referenced by brin_summarize_range(), bt_index_check_internal(), cluster_rel(), ComputeIndexAttrs(), CreateSchemaCommand(), DefineIndex(), do_analyze_rel(), ExecCreateTableAs(), ExecRefreshMatView(), execute_extension_script(), fmgr_security_definer(), index_build(), index_concurrently_build(), InitializeParallelDSM(), PushTransaction(), reindex_index(), ReindexRelationConcurrently(), ri_PerformCheck(), ri_PlanCheck(), StartTransaction(), SwitchToUntrustedUser(), vacuum_rel(), and validate_index().
Definition at line 966 of file miscinit.c.
References AUTHOID, ereport, errcode(), errmsg(), ERROR, GETSTRUCT, HeapTupleIsValid, NameStr, ObjectIdGetDatum(), pstrdup(), ReleaseSysCache(), rolname, and SearchSysCache1().
Referenced by AddRoleMems(), check_can_set_role(), check_object_ownership(), check_role_grantor(), check_role_membership_authorization(), current_user(), DelRoleMems(), DropOwnedObjects(), execute_extension_script(), getObjectDescription(), getObjectIdentityParts(), insert_username(), LogicalRepSyncTableStart(), ReassignOwnedObjects(), regroleout(), session_user(), SwitchToUntrustedUser(), and TargetPrivilegesCheck().
Definition at line 706 of file miscinit.c.
References AUTHOID, GETSTRUCT, HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), rolreplication, SearchSysCache1(), and superuser_arg().
Referenced by AlterRole(), CheckSlotPermissions(), CreateRole(), and InitPostgres().
void InitializeMaxBackends | ( | void | ) |
Definition at line 559 of file postinit.c.
References Assert(), autovacuum_max_workers, elog(), ERROR, MAX_BACKENDS, max_wal_senders, max_worker_processes, MaxBackends, and MaxConnections.
Referenced by BootstrapModeMain(), PostgresSingleUserMain(), and PostmasterMain().
void InitializeSessionUserId | ( | const char * | rolename, |
Oid | roleid | ||
) |
Definition at line 728 of file miscinit.c.
References AcceptInvalidationMessages(), Assert(), AuthenticatedUserId, AUTHNAME, AUTHOID, CountUserBackends(), ereport, errcode(), errmsg(), FATAL, GETSTRUCT, HeapTupleIsValid, is_superuser(), IsBootstrapProcessingMode, IsUnderPostmaster, MyProc, NameStr, ObjectIdGetDatum(), OidIsValid, PGC_BACKEND, PGC_INTERNAL, PGC_S_DYNAMIC_DEFAULT, PGC_S_OVERRIDE, PointerGetDatum(), ReleaseSysCache(), PGPROC::roleId, SearchSysCache1(), SetConfigOption(), and SetSessionUserId().
Referenced by InitPostgres().
void InitializeSessionUserIdStandalone | ( | void | ) |
Definition at line 832 of file miscinit.c.
References Assert(), AuthenticatedUserId, IsAutoVacuumWorkerProcess(), IsBackgroundWorker, IsUnderPostmaster, OidIsValid, and SetSessionUserId().
Referenced by InitPostgres().
void InitializeSystemUser | ( | const char * | authn_id, |
const char * | auth_method | ||
) |
Definition at line 853 of file miscinit.c.
References Assert(), MemoryContextStrdup(), pfree(), psprintf(), system_user(), SystemUser, and TopMemoryContext.
Referenced by InitPostgres(), and ParallelWorkerMain().
void InitPostgres | ( | const char * | in_dbname, |
Oid | dboid, | ||
const char * | username, | ||
Oid | useroid, | ||
bool | load_session_libraries, | ||
bool | override_allow_connections, | ||
char * | out_dbname | ||
) |
Definition at line 718 of file postinit.c.
References am_db_walsender, am_walsender, Assert(), ClientConnectionInfo::auth_method, ClientConnectionInfo::authn_id, before_shmem_exit(), CheckDeadLockAlert(), CheckMyDatabase(), CLIENT_CONNECTION_CHECK_TIMEOUT, ClientCheckTimeoutHandler(), CommitTransactionCommand(), CreateAuxProcessResourceOwner(), CurrentResourceOwner, database_is_invalid_form(), PGPROC::databaseId, dbname, DEADLOCK_TIMEOUT, DEBUG3, elog(), EnablePortalManager(), ereport, errcode(), errcode_for_file_access(), errdetail(), errhint(), errmsg(), FATAL, GetDatabasePath(), GetDatabaseTuple(), GetDatabaseTupleByOid(), GetSessionUserId(), GETSTRUCT, GetTransactionSnapshot(), GetUserId(), has_privs_of_role(), has_rolreplication(), HaveNFreeProcs(), hba_authname(), HeapTupleIsValid, IDLE_IN_TRANSACTION_SESSION_TIMEOUT, IDLE_SESSION_TIMEOUT, IDLE_STATS_UPDATE_TIMEOUT, IdleInTransactionSessionTimeoutHandler(), IdleSessionTimeoutHandler(), IdleStatsUpdateTimeoutHandler(), InitCatalogCache(), initialize_acl(), InitializeClientEncoding(), InitializeSearchPath(), InitializeSession(), InitializeSessionUserId(), InitializeSessionUserIdStandalone(), InitializeSystemUser(), InitPlanCache(), InitProcessPhase2(), InvalidateCatalogSnapshot(), InvalidBackendId, IsAutoVacuumLauncherProcess(), IsAutoVacuumWorkerProcess(), IsBackgroundWorker, IsBinaryUpgrade, IsBootstrapProcessingMode, IsUnderPostmaster, LOCK_TIMEOUT, LockSharedObject(), LockTimeoutHandler(), MaxBackends, MyBackendId, MyClientConnectionInfo, MyDatabaseId, MyDatabaseTableSpace, MyProc, MyProcPort, NAMEDATALEN, NameStr, namestrcmp(), OidIsValid, PerformAuthentication(), pfree(), pg_usleep(), pgstat_before_server_shutdown(), pgstat_beinit(), pgstat_bestart(), PostAuthDelay, process_session_preload_libraries(), process_settings(), process_startup_options(), ProcSignalInit(), RegisterTimeout(), RelationCacheInitialize(), RelationCacheInitializePhase2(), RelationCacheInitializePhase3(), ReleaseAuxProcessResources(), ReservedConnections, RowExclusiveLock, SetCurrentStatementStartTimestamp(), SetDatabasePath(), SharedInvalBackendInit(), ShutdownPostgres(), ShutdownXLOG(), StartTransactionCommand(), StartupXLOG(), STATEMENT_TIMEOUT, StatementTimeoutHandler(), strlcpy(), superuser(), SuperuserReservedConnections, ThereIsAtLeastOneRole(), username, ValidatePgVersion(), WARNING, XACT_READ_COMMITTED, and XactIsoLevel.
Referenced by AutoVacLauncherMain(), AutoVacWorkerMain(), BackgroundWorkerInitializeConnection(), BackgroundWorkerInitializeConnectionByOid(), BootstrapModeMain(), and PostgresMain().
void InitPostmasterChild | ( | void | ) |
Definition at line 95 of file miscinit.c.
References BlockSig, elog(), ereport, errcode_for_socket_access(), errmsg_internal(), FATAL, InitializeLatchSupport(), InitializeLatchWaitSet(), InitProcessGlobals(), InitProcessLocalLatch(), IsUnderPostmaster, on_exit_reset(), pgwin32_signal_initialize(), postmaster_alive_fds, POSTMASTER_FD_WATCH, PostmasterDeathSignalInit(), pqinitmask(), pqsignal(), set_stack_base(), SignalHandlerForCrashExit(), and SIGQUIT.
Referenced by BackendStartup(), do_start_bgworker(), StartAutoVacWorker(), StartChildProcess(), and SysLogger_Start().
void InitProcessLocalLatch | ( | void | ) |
Definition at line 242 of file miscinit.c.
References InitLatch(), LocalLatchData, and MyLatch.
Referenced by InitPostmasterChild(), InitStandaloneProcess(), and PostmasterMain().
void InitStandaloneProcess | ( | const char * | argv0 | ) |
Definition at line 182 of file miscinit.c.
References argv0, Assert(), B_STANDALONE_BACKEND, BlockSig, elog(), FATAL, find_my_exec(), get_pkglib_path(), InitializeLatchSupport(), InitializeLatchWaitSet(), InitProcessGlobals(), InitProcessLocalLatch(), IsPostmasterEnvironment, my_exec_path, MyBackendType, pgwin32_signal_initialize(), pkglib_path, and pqinitmask().
Referenced by BootstrapModeMain(), and PostgresSingleUserMain().
bool InLocalUserIdChange | ( | void | ) |
Definition at line 648 of file miscinit.c.
References SECURITY_LOCAL_USERID_CHANGE, and SecurityRestrictionContext.
Referenced by GetUserIdAndContext(), and set_config_option_ext().
bool InNoForceRLSOperation | ( | void | ) |
Definition at line 666 of file miscinit.c.
References SECURITY_NOFORCE_RLS, and SecurityRestrictionContext.
Referenced by check_enable_rls().
bool InSecurityRestrictedOperation | ( | void | ) |
Definition at line 657 of file miscinit.c.
References SECURITY_RESTRICTED_OPERATION, and SecurityRestrictionContext.
Referenced by afterTriggerMarkEvents(), CheckRestrictedOperation(), DefineRelation(), PerformCursorOpen(), set_config_option_ext(), and SetUserIdAndContext().
void pg_bindtextdomain | ( | const char * | domain | ) |
Definition at line 1866 of file miscinit.c.
References get_locale_path(), MAXPGPATH, and my_exec_path.
Referenced by _PG_init().
void pg_split_opts | ( | char ** | argv, |
int * | argcp, | ||
const char * | optstr | ||
) |
Definition at line 501 of file postinit.c.
References appendStringInfoChar(), StringInfoData::data, initStringInfo(), pfree(), pstrdup(), and resetStringInfo().
Referenced by process_startup_options().
void PreventCommandDuringRecovery | ( | const char * | cmdname | ) |
Definition at line 448 of file utility.c.
References ereport, errcode(), errmsg(), ERROR, and RecoveryInProgress().
Referenced by pg_current_xact_id(), pg_notify(), and standard_ProcessUtility().
void PreventCommandIfParallelMode | ( | const char * | cmdname | ) |
Definition at line 429 of file utility.c.
References ereport, errcode(), errmsg(), ERROR, and IsInParallelMode().
Referenced by do_setval(), ExecCheckXactReadOnly(), nextval_internal(), and standard_ProcessUtility().
void PreventCommandIfReadOnly | ( | const char * | cmdname | ) |
Definition at line 411 of file utility.c.
References ereport, errcode(), errmsg(), ERROR, and XactReadOnly.
Referenced by be_lo_creat(), be_lo_create(), be_lo_from_bytea(), be_lo_open(), be_lo_put(), be_lo_truncate(), be_lo_truncate64(), be_lo_unlink(), be_lowrite(), do_setval(), DoCopy(), ExecCheckXactReadOnly(), lo_import_internal(), nextval_internal(), and standard_ProcessUtility().
void process_session_preload_libraries | ( | void | ) |
Definition at line 1843 of file miscinit.c.
References load_libraries(), local_preload_libraries_string, and session_preload_libraries_string.
Referenced by InitPostgres().
void process_shared_preload_libraries | ( | void | ) |
Definition at line 1829 of file miscinit.c.
References load_libraries(), process_shared_preload_libraries_done, process_shared_preload_libraries_in_progress, and shared_preload_libraries_string.
Referenced by PostgresSingleUserMain(), and PostmasterMain().
void process_shmem_requests | ( | void | ) |
Definition at line 1857 of file miscinit.c.
References process_shmem_requests_in_progress, and shmem_request_hook.
Referenced by PostgresSingleUserMain(), and PostmasterMain().
void ProcessInterrupts | ( | void | ) |
Definition at line 3254 of file postgres.c.
References BackgroundWorker::bgw_type, CheckClientConnectionPending, client_connection_check_interval, CLIENT_CONNECTION_CHECK_TIMEOUT, ClientAuthInProgress, ClientConnectionLost, CritSectionCount, DEBUG1, DestNone, DestRemote, DoingCommandRead, enable_timeout_after(), ereport, errcode(), errmsg(), errmsg_internal(), ERROR, FATAL, get_timeout_finish_time(), get_timeout_indicator(), HandleParallelApplyMessages(), HandleParallelMessages(), IdleInTransactionSessionTimeout, IdleInTransactionSessionTimeoutPending, IdleSessionTimeout, IdleSessionTimeoutPending, IdleStatsUpdateTimeoutPending, InterruptHoldoffCount, InterruptPending, IsAutoVacuumWorkerProcess(), IsBackgroundWorker, IsLogicalLauncher(), IsLogicalWorker(), IsTransactionOrTransactionBlock(), LOCK_TIMEOUT, LockErrorCleanup(), LogMemoryContextPending, MyBgworkerEntry, ParallelApplyMessagePending, ParallelMessagePending, pgstat_report_stat(), pq_check_connection(), proc_exit(), ProcDiePending, ProcessLogMemoryContextInterrupt(), ProcessProcSignalBarrier(), ProcessRecoveryConflictInterrupts(), ProcSignalBarrierPending, QueryCancelHoldoffCount, QueryCancelPending, RecoveryConflictPending, STATEMENT_TIMEOUT, and whereToSendOutput.
Referenced by die().
bool RecheckDataDirLockFile | ( | void | ) |
Definition at line 1624 of file miscinit.c.
References close, DIRECTORY_LOCK_FILE, ereport, errcode_for_file_access(), errmsg(), fd(), len, LOG, PG_BINARY, pgstat_report_wait_end(), pgstat_report_wait_start(), and read.
Referenced by ServerLoop().
void restore_stack_base | ( | pg_stack_base_t | base | ) |
void RestoreClientConnectionInfo | ( | char * | conninfo | ) |
Definition at line 1061 of file miscinit.c.
References SerializedClientConnectionInfo::auth_method, ClientConnectionInfo::auth_method, ClientConnectionInfo::authn_id, SerializedClientConnectionInfo::authn_id_len, MemoryContextStrdup(), MyClientConnectionInfo, and TopMemoryContext.
Referenced by ParallelWorkerMain().
void SerializeClientConnectionInfo | ( | Size | maxsize, |
char * | start_address | ||
) |
Definition at line 1029 of file miscinit.c.
References Assert(), SerializedClientConnectionInfo::auth_method, ClientConnectionInfo::auth_method, ClientConnectionInfo::authn_id, SerializedClientConnectionInfo::authn_id_len, and MyClientConnectionInfo.
Referenced by InitializeParallelDSM().
pg_stack_base_t set_stack_base | ( | void | ) |
Definition at line 3473 of file postgres.c.
References stack_base_ptr.
Referenced by InitPostmasterChild(), and PostmasterMain().
Definition at line 931 of file miscinit.c.
References is_superuser(), OidIsValid, PGC_INTERNAL, PGC_S_DYNAMIC_DEFAULT, SessionUserId, SessionUserIsSuperuser, SetConfigOption(), SetOuterUserId(), and SetRoleIsActive.
Referenced by assign_role(), and ParallelWorkerMain().
void SetDatabasePath | ( | const char * | path | ) |
Definition at line 323 of file miscinit.c.
References Assert(), DatabasePath, MemoryContextStrdup(), and TopMemoryContext.
Referenced by InitPostgres().
void SetDataDir | ( | const char * | dir | ) |
Definition at line 429 of file miscinit.c.
References Assert(), DataDir, free, and make_absolute_path().
Referenced by SelectConfigFiles().
Definition at line 894 of file miscinit.c.
References is_superuser(), PGC_INTERNAL, PGC_S_DYNAMIC_DEFAULT, SetConfigOption(), and SetSessionUserId().
Referenced by assign_session_authorization().
Definition at line 686 of file miscinit.c.
References CurrentUserId, ereport, errcode(), errmsg(), ERROR, InSecurityRestrictedOperation(), SECURITY_LOCAL_USERID_CHANGE, and SecurityRestrictionContext.
void SetUserIdAndSecContext | ( | Oid | userid, |
int | sec_context | ||
) |
Definition at line 637 of file miscinit.c.
References CurrentUserId, and SecurityRestrictionContext.
Referenced by AbortSubTransaction(), AbortTransaction(), brin_summarize_range(), bt_index_check_internal(), cluster_rel(), ComputeIndexAttrs(), CreateSchemaCommand(), DefineIndex(), do_analyze_rel(), ExecCreateTableAs(), ExecRefreshMatView(), execute_extension_script(), fmgr_security_definer(), index_build(), index_concurrently_build(), ParallelWorkerMain(), refresh_by_match_merge(), reindex_index(), ReindexRelationConcurrently(), RestoreUserContext(), ri_PerformCheck(), ri_PlanCheck(), SwitchToUntrustedUser(), vacuum_rel(), and validate_index().
bool stack_is_too_deep | ( | void | ) |
Definition at line 3537 of file postgres.c.
References max_stack_depth_bytes, and stack_base_ptr.
Referenced by check_stack_depth(), and rstacktoodeep().
bool superuser | ( | void | ) |
Definition at line 46 of file superuser.c.
References GetUserId(), and superuser_arg().
Referenced by AlterForeignDataWrapper(), AlterForeignDataWrapperOwner_internal(), AlterForeignServerOwner_internal(), AlterFunction(), AlterObjectNamespace_internal(), AlterObjectOwner_internal(), AlterObjectRename_internal(), AlterOpFamily(), AlterPublicationOwner_internal(), AlterRole(), AlterRoleSet(), AlterSubscription(), AlterSubscriptionOwner_internal(), AlterSystemSetConfigFile(), AlterType(), AlterTypeOwner(), ATExecChangeOwner(), brin_metapage_info(), brin_page_items(), brin_page_type(), brin_revmap_data(), bt_metap(), bt_multi_page_stats(), bt_page_items_bytea(), bt_page_items_internal(), bt_page_stats_internal(), check_encoding_locale_matches(), CheckAlterPublication(), CreateAccessMethod(), CreateCast(), CreateEventTrigger(), CreateForeignDataWrapper(), CreateFunction(), CreateProceduralLanguage(), CreatePublication(), CreateRole(), CreateSubscription(), CreateTableSpace(), dblink_connstr_check(), dblink_security_check(), DefineAggregate(), DefineOpClass(), DefineOpFamily(), DefineTSParser(), DefineTSTemplate(), DefineType(), DropRole(), dummy_object_relabel(), EnableDisableTrigger(), ExecSetVariableStmt(), execute_extension_script(), ExecuteDoStmt(), fmgr_security_definer(), fsm_page_contents(), get_raw_page_internal(), gin_leafpage_items(), gin_metapage_info(), gin_page_opaque_info(), gist_page_items(), gist_page_items_bytea(), gist_page_opaque_info(), GUCArrayReset(), hash_bitmap_info(), hash_metapage_info(), hash_page_items(), hash_page_stats(), hash_page_type(), have_createdb_privilege(), heap_page_items(), heap_tuple_infomask_flags(), InitPostgres(), interpret_func_support(), main(), page_checksum_internal(), page_header(), pg_import_system_collations(), pg_logdir_ls(), pg_nextoid(), pg_read_file(), pg_relpages(), pg_relpagesbyid(), pg_rotate_logfile(), pg_signal_backend(), pg_stop_making_pinned_objects(), pgstat_get_backend_current_activity(), pgstatginindex(), pgstatindex(), pgstatindexbyid(), pgstattuple(), pgstattuple_approx(), pgstattuplebyid(), postgres_fdw_validator(), ProcedureCreate(), regress_setenv(), RenameRole(), requireSuperuser(), sepgsql_restorecon(), set_config_by_name(), SetPGVariable(), standard_ProcessUtility(), TerminateOtherDBBackends(), tuple_data_split(), validate_option_array_item(), and wait_pid().
Definition at line 56 of file superuser.c.
References AUTHOID, CacheRegisterSyscacheCallback(), GETSTRUCT, HeapTupleIsValid, IsUnderPostmaster, last_roleid, last_roleid_is_super, ObjectIdGetDatum(), OidIsValid, ReleaseSysCache(), roleid_callback_registered, RoleidCallback(), rolsuper, and SearchSysCache1().
Referenced by AlterEventTriggerOwner_internal(), AlterForeignDataWrapperOwner_internal(), AlterPublicationOwner_internal(), AlterSubscription(), AlterSubscription_refresh(), check_conn_params(), check_object_ownership(), check_role_grantor(), check_role_membership_authorization(), check_session_authorization(), CreateRole(), CreateSubscription(), DropSubscription(), emit_audit_message(), has_bypassrls_privilege(), has_createrole_privilege(), has_privs_of_role(), has_rolreplication(), is_admin_of_role(), is_member_of_role(), LockGXact(), LogicalRepSyncTableStart(), member_can_set_role(), object_aclmask(), object_ownercheck(), pg_class_aclmask_ext(), pg_largeobject_aclmask_snapshot(), pg_namespace_aclmask(), pg_parameter_acl_aclmask(), pg_parameter_aclmask(), pg_signal_backend(), pg_type_aclmask(), pgfdw_security_check(), REGRESS_exec_check_perms(), REGRESS_object_access_hook(), REGRESS_object_access_hook_str(), REGRESS_utility_command(), run_apply_worker(), select_best_grantor(), superuser(), and TerminateOtherDBBackends().
void SwitchBackToLocalLatch | ( | void | ) |
Definition at line 249 of file miscinit.c.
References Assert(), FeBeWaitSet, FeBeWaitSetLatchPos, LocalLatchData, ModifyWaitEvent(), MyLatch, MyProc, PGPROC::procLatch, SetLatch(), and WL_LATCH_SET.
Referenced by AuxiliaryProcKill(), and ProcKill().
void SwitchToSharedLatch | ( | void | ) |
Definition at line 222 of file miscinit.c.
References Assert(), FeBeWaitSet, FeBeWaitSetLatchPos, LocalLatchData, ModifyWaitEvent(), MyLatch, MyProc, PGPROC::procLatch, SetLatch(), and WL_LATCH_SET.
Referenced by InitAuxiliaryProcess(), and InitProcess().
void TouchSocketLockFiles | ( | void | ) |
Definition at line 1468 of file miscinit.c.
References DIRECTORY_LOCK_FILE, lfirst, and lock_files.
Referenced by ServerLoop().
int trace_recovery | ( | int | trace_level | ) |
Definition at line 3752 of file elog.c.
References LOG, and trace_recovery_messages.
Referenced by KnownAssignedXidsRemove(), KnownAssignedXidsRemovePreceding(), LogCurrentRunningXacts(), ProcArrayApplyRecoveryInfo(), ProcessCommittedInvalidationMessages(), RecordKnownAssignedTransactionIds(), RecoveryRestartPoint(), StandbyAcquireAccessExclusiveLock(), StandbyReleaseAllLocks(), and StandbyReleaseXidEntryLocks().
void ValidatePgVersion | ( | const char * | path | ) |
Definition at line 1696 of file miscinit.c.
References AllocateFile(), ereport, errcode(), errcode_for_file_access(), errdetail(), errhint(), errmsg(), FATAL, FreeFile(), MAXPGPATH, and snprintf.
Referenced by checkDataDir(), and InitPostgres().
|
extern |
Definition at line 124 of file globals.c.
Referenced by ATAddForeignKeyConstraint(), ATExecAddIndexConstraint(), ATSimplePermissions(), createdb(), CreateSchemaCommand(), CreateStatistics(), CreateTableSpace(), CreateTriggerFiringOn(), DefineIndex(), DefineQueryRewrite(), DefineRelation(), perform_relmap_update(), RangeVarCallbackForAlterRelation(), RangeVarCallbackForDropRelation(), RangeVarCallbackForPolicy(), RangeVarCallbackForRenameRule(), RangeVarCallbackForRenameTrigger(), RangeVarCallbackOwnsRelation(), RemovePolicyById(), RemoveRewriteRuleById(), RemoveTriggerById(), renameatt_check(), RenameSchema(), RenameTableSpace(), and truncate_check_rel().
|
extern |
Definition at line 33 of file globals.c.
Referenced by ClientCheckTimeoutHandler(), and ProcessInterrupts().
|
extern |
Definition at line 34 of file globals.c.
Referenced by internal_flush(), and ProcessInterrupts().
|
extern |
Definition at line 42 of file globals.c.
Referenced by errfinish(), errstart(), HeapTupleHeaderGetCmax(), log_newpage_buffer(), MemoryContextCreate(), proc_exit_prepare(), ProcessClientWriteInterrupt(), ProcessInterrupts(), XactLogAbortRecord(), XactLogCommitRecord(), XLogEnsureRecordSpace(), and XLogWrite().
|
extern |
Definition at line 72 of file globals.c.
Referenced by checkDataDir(), RetrieveDataDirCreatePerm(), and show_data_directory_mode().
|
extern |
Definition at line 97 of file globals.c.
Referenced by load_relcache_init_file(), load_relmap_file(), perform_relmap_update(), ProcessCommittedInvalidationMessages(), RelationCacheInitFilePreInvalidate(), RelationMapFinishBootstrap(), SetDatabasePath(), and write_relcache_init_file().
|
extern |
Definition at line 66 of file globals.c.
Referenced by AbsoluteConfigLocation(), ChangeToDataDir(), checkControlFile(), checkDataDir(), convert_and_check_filename(), CreateDataDirLockFile(), CreateLockFile(), CreateTableSpace(), do_pg_backup_start(), get_controlfile(), GetSharedMemName(), InitWalRecovery(), main(), pg_control_checkpoint(), pg_control_init(), pg_control_recovery(), pg_control_system(), PGReserveSemaphores(), PGSharedMemoryAttach(), PGSharedMemoryCreate(), ProcessConfigFileInternal(), SelectConfigFiles(), SetDataDir(), update_controlfile(), and UpdateControlFile().
|
extern |
Definition at line 120 of file globals.c.
Referenced by assign_datestyle(), check_datestyle(), DecodeNumber(), EncodeDateOnly(), and EncodeDateTime().
|
extern |
Definition at line 119 of file globals.c.
Referenced by assign_datestyle(), check_datestyle(), date_out(), PGTYPESdate_to_asc(), PGTYPEStimestamp_to_asc(), set_transmission_modes(), time_out(), timestamp_out(), timestamptz_out(), and timetz_out().
|
extern |
Definition at line 123 of file globals.c.
Referenced by copydir(), get_sync_bit(), issue_xlog_fsync(), pg_fdatasync(), pg_flush_data(), pg_fsync_no_writethrough(), pg_fsync_writethrough(), ProcessSyncRequests(), SyncDataDirectory(), and XLogFlush().
|
extern |
Definition at line 117 of file globals.c.
Referenced by errstart(), and HandleCheckpointerInterrupts().
|
extern |
Definition at line 126 of file globals.c.
Referenced by get_hash_memory_limit().
|
extern |
Definition at line 35 of file globals.c.
Referenced by IdleInTransactionSessionTimeoutHandler(), and ProcessInterrupts().
|
extern |
Definition at line 36 of file globals.c.
Referenced by IdleSessionTimeoutHandler(), and ProcessInterrupts().
|
extern |
Definition at line 39 of file globals.c.
Referenced by IdleStatsUpdateTimeoutHandler(), and ProcessInterrupts().
|
extern |
Definition at line 80 of file miscinit.c.
Referenced by AuxiliaryProcessMain(), BootstrapModeMain(), get_relation_info(), systable_beginscan(), and systable_beginscan_ordered().
|
extern |
Definition at line 40 of file globals.c.
Referenced by errfinish(), proc_exit_prepare(), ProcessClientWriteInterrupt(), ProcessInterrupts(), ProcessRecoveryConflictInterrupts(), and SyncRepWaitForLSN().
|
extern |
Definition at line 30 of file globals.c.
Referenced by ClientCheckTimeoutHandler(), die(), HandleLogMemoryContextInterrupt(), HandleParallelApplyMessageInterrupt(), HandleParallelMessageInterrupt(), HandleProcSignalBarrierInterrupt(), HandleRecoveryConflictInterrupt(), IdleInTransactionSessionTimeoutHandler(), IdleSessionTimeoutHandler(), IdleStatsUpdateTimeoutHandler(), internal_flush(), proc_exit_prepare(), ProcessInterrupts(), ProcessRecoveryConflictInterrupt(), ResetProcSignalBarrierBits(), StatementCancelHandler(), and vacuum_delay_point().
|
extern |
Definition at line 121 of file globals.c.
Referenced by DecodeInterval(), interval_out(), PGTYPESinterval_to_asc(), and set_transmission_modes().
|
extern |
Definition at line 115 of file globals.c.
Referenced by InitAuxiliaryProcess(), InitializeSessionUserIdStandalone(), InitPostgres(), InitProcess(), ProcessInterrupts(), and StartBackgroundWorker().
|
extern |
Definition at line 114 of file globals.c.
Referenced by AddEnumLabel(), AssignTypeArrayOid(), AssignTypeMultirangeArrayOid(), AssignTypeMultirangeOid(), create_toast_table(), createdb(), CreateRole(), CreateTableSpace(), DefineCollation(), GetNewOidWithIndex(), GetNewRelFileNumber(), heap_create_with_catalog(), icu_validate_locale(), index_create(), InitPostgres(), mdunlinkfork(), MultiXactSetNextMXact(), PostmasterMain(), process_pm_child_exit(), process_postgres_switches(), RelationSetNewRelfilenumber(), ServerLoop(), truncate_check_rel(), TypeCreate(), and TypeShellMake().
|
extern |
Definition at line 112 of file globals.c.
Referenced by dsm_create(), get_slru_entry(), GetNewObjectId(), HotStandbyActiveInReplay(), InitStandaloneProcess(), MarkAsPreparingGuts(), pgstat_fetch_entry(), pgstat_flush_wal(), pgstat_read_statsfile(), pgstat_shutdown_hook(), PostmasterMain(), RequestCheckpoint(), SetNextObjectId(), ShutdownXLOG(), StartupXLOG(), and UnlinkLockFiles().
|
extern |
Definition at line 113 of file globals.c.
Referenced by _PG_init(), AdvanceNextFullTransactionIdPastXid(), AutoVacuumShmemInit(), AuxiliaryProcessMain(), BackgroundWorkerShmemInit(), bootstrap_signals(), BootstrapModeMain(), BTreeShmemInit(), CheckMyDatabase(), CheckRecoveryConsistency(), CommitTsShmemInit(), createdb(), CreateLWLocks(), CreateRestartPoint(), CreateSharedMemoryAndSemaphores(), DebugFileOpen(), dsm_attach(), dsm_backend_startup(), dsm_create(), dsm_impl_pin_segment(), dsm_impl_posix_resize(), dsm_impl_unpin_segment(), dsm_postmaster_startup(), EventTriggerDDLCommandEnd(), EventTriggerDDLCommandStart(), EventTriggerSQLDrop(), EventTriggerTableRewrite(), ForwardSyncRequest(), get_slru_entry(), GetNewMultiXactId(), GetNewTransactionId(), GetQuitSignalReason(), HandleStartupProcInterrupts(), init_ps_display(), InitializeLatchSupport(), InitializeLatchWaitSet(), InitializeSessionUserId(), InitializeSessionUserIdStandalone(), InitPostgres(), InitPostmasterChild(), InitPredicateLocks(), InitProcess(), InitSync(), LWLockAcquire(), MaintainLatestCompletedXidRecovery(), MultiXactShmemInit(), parallel_vacuum_compute_workers(), PerformRecoveryXLogAction(), PerformWalRecovery(), PGSemaphoreCreate(), PGSharedMemoryNoReAttach(), PGSharedMemoryReAttach(), pgss_shmem_startup(), pgstat_fetch_entry(), pgstat_flush_wal(), pgstat_read_statsfile(), pgstat_report_autovac(), pgstat_report_recovery_conflict(), pgstat_shutdown_hook(), plan_create_index_workers(), PostgresMain(), PostgresSingleUserMain(), process_postgres_switches(), process_settings(), ProcessConfigFileInternal(), ProcKill(), readRecoverySignalFile(), RegisterBackgroundWorker(), RegisterDynamicBackgroundWorker(), ReplicationSlotAcquire(), SendPostmasterSignal(), SerialInit(), set_config_option_ext(), set_config_sourcefile(), SetMultiXactIdLimit(), SetTransactionIdLimit(), ShmemInitStruct(), SimpleLruInit(), standard_planner(), start_xact_command(), StatsShmemInit(), superuser_arg(), SyncScanShmemInit(), TwoPhaseShmemInit(), vacuum_delay_point(), verify_dictoptions(), WaitLatch(), WaitLatchOrSocket(), XLogArchiveNotify(), XLogPageRead(), XLogPrefetchIncrement(), XLogRecGetFullXid(), and XLogWrite().
|
extern |
Definition at line 1761 of file miscinit.c.
Referenced by process_session_preload_libraries().
|
extern |
Definition at line 38 of file globals.c.
Referenced by HandleAutoVacLauncherInterrupts(), HandleCheckpointerInterrupts(), HandleLogMemoryContextInterrupt(), HandleMainLoopInterrupts(), HandlePgArchInterrupts(), HandleStartupProcInterrupts(), HandleWalWriterInterrupts(), ProcessInterrupts(), and ProcessLogMemoryContextInterrupt().
|
extern |
Definition at line 127 of file globals.c.
Referenced by _bt_leader_participate_as_worker(), _bt_parallel_build_main(), _bt_spools_heapscan(), _h_spoolinit(), bt_check_every_level(), dead_items_max_items(), ginBuildCallback(), ginInsertCleanup(), gistbuild(), gistInitBuffering(), hashbuild(), heapam_relation_copy_for_cluster(), parallel_vacuum_init(), parallel_vacuum_main(), plan_cluster_use_sort(), plan_create_index_workers(), RI_Initial_Check(), RI_PartitionRemove_Check(), and validate_index().
|
extern |
Definition at line 128 of file globals.c.
Referenced by parallel_vacuum_compute_workers(), and plan_create_index_workers().
|
extern |
Definition at line 139 of file globals.c.
Referenced by RegisterDynamicBackgroundWorker().
|
extern |
Definition at line 138 of file globals.c.
Referenced by BackgroundWorkerShmemInit(), BackgroundWorkerShmemSize(), BackgroundWorkerStateChange(), check_autovacuum_max_workers(), check_max_connections(), check_max_wal_senders(), CheckRequiredParameterValues(), ForgetBackgroundWorker(), ForgetUnstartedBackgroundWorkers(), GetBackgroundWorkerPid(), InitControlFile(), InitializeMaxBackends(), InitProcGlobal(), MaxLivePostmasterChildren(), RegisterBackgroundWorker(), ReportBackgroundWorkerExit(), ReportBackgroundWorkerPID(), TerminateBackgroundWorker(), and XLogReportParameters().
|
extern |
Definition at line 140 of file globals.c.
Referenced by AsyncShmemInit(), AsyncShmemSize(), AuxiliaryProcessMain(), BTreeShmemInit(), BTreeShmemSize(), CreateSharedInvalidationState(), DeadLockCheckRecurse(), dsm_postmaster_startup(), ExpandConstraints(), FindLockCycleRecurse(), FindLockCycleRecurseMember(), GetBlockerStatusData(), GetLockConflicts(), GetLockStatusData(), GetSerializableTransactionSnapshotInt(), GetSingleProcBlockerStatusData(), InitDeadLockChecking(), InitializeMaxBackends(), InitPostgres(), InitPredicateLocks(), InitProcGlobal(), LimitAdditionalPins(), pg_safe_snapshot_blocking_pids(), pgstat_beinit(), pgstat_get_backend_current_activity(), pgstat_get_crashed_backend_activity(), predicatelock_twophase_recover(), PredicateLockShmemSize(), ProcGlobalSemas(), ProcGlobalShmemSize(), SignalBackends(), SInvalShmemSize(), TestConfiguration(), and TwoPhaseShmemInit().
|
extern |
Definition at line 137 of file globals.c.
Referenced by check_autovacuum_max_workers(), check_max_wal_senders(), check_max_worker_processes(), CheckRequiredParameterValues(), InitControlFile(), InitializeMaxBackends(), InitProcGlobal(), MaxLivePostmasterChildren(), PostmasterMain(), StreamServerPort(), and XLogReportParameters().
|
extern |
Definition at line 61 of file miscinit.c.
|
extern |
Definition at line 76 of file globals.c.
Referenced by adjust_data_dir(), get_configdata(), get_doc_path(), get_etc_path(), get_extension_control_directory(), get_extension_control_filename(), get_extension_script_directory(), get_html_path(), get_include_path(), get_includeserver_path(), get_lib_path(), get_locale_path(), get_man_path(), get_pkginclude_path(), get_pkglib_path(), get_share_path(), get_tsearch_config_filename(), getInstallationPaths(), InitStandaloneProcess(), main(), make_relative_path(), ParseTzFile(), pg_bindtextdomain(), pg_config(), pg_TZDIR(), PostmasterMain(), process_psqlrc(), and set_pglocale_pgservice().
|
extern |
Definition at line 45 of file auxprocess.c.
Referenced by AuxiliaryProcessMain(), and pgstat_beinit().
|
extern |
Definition at line 63 of file miscinit.c.
Referenced by AutoVacLauncherMain(), AutoVacWorkerMain(), AuxiliaryProcessMain(), CreateRestartPoint(), get_backend_type_for_log(), init_ps_display(), InitStandaloneProcess(), InvalidatePossiblyObsoleteSlot(), pgstat_bestart(), pgstat_count_io_op_n(), pgstat_flush_io(), pgstat_should_report_connstat(), ProcessStartupPacket(), send_message_to_server_log(), standard_ProcessUtility(), StartBackgroundWorker(), SysLoggerMain(), write_csvlog(), and write_jsonlog().
|
extern |
Definition at line 48 of file globals.c.
Referenced by assign_backendlist_entry(), BackendStartup(), ParallelWorkerMain(), PostgresMain(), and StartAutovacuumWorker().
|
extern |
Definition at line 89 of file globals.c.
Referenced by AfterTriggerSetState(), AlterDatabase(), AlterObjectRename_internal(), AlterPublicationOwner_internal(), AlterSchemaOwner_internal(), AlterSubscription(), AlterSubscriptionOwner(), AlterSubscriptionOwner_internal(), asyncQueueNotificationToEntry(), asyncQueueProcessPageEntries(), ATExecDetachPartition(), AutoVacuumRequestWork(), CacheInvalidateCatalog(), CacheInvalidateHeapTuple(), CacheInvalidateRelcache(), CacheInvalidateRelcacheByTuple(), check_default_table_access_method(), check_default_tablespace(), check_default_text_search_config(), check_temp_tablespaces(), CheckLogicalDecodingRequirements(), CheckMyDatabase(), checkSharedDependencies(), checkTempNamespaceStatus(), classIdGetDbId(), ComputeXidHorizons(), CreateDecodingContext(), CreateInitDecodingContext(), CreatePublication(), CreateSchemaCommand(), CreateSubscription(), current_database(), database_to_xml_internal(), DeconstructQualifiedName(), do_analyze_rel(), do_autovacuum(), dropdb(), DropSubscription(), Exec_ListenPreCommit(), exec_object_restorecon(), exec_replication_command(), ExecuteTruncateGuts(), ExpandColumnRefStar(), ExportSnapshot(), extension_is_trusted(), find_funcstat_entry(), find_tabstat_entry(), get_subscription_oid(), get_tables_to_cluster_partitioned(), GetCurrentVirtualXIDs(), GetNewRelFileNumber(), heap_vacuum_rel(), IdentifySystem(), ImportSnapshot(), initialize_acl(), InitializeParallelDSM(), InitPostgres(), InitTempTableNamespace(), InitWalSenderSlot(), libpqrcv_exec(), LocalExecuteInvalidationMessage(), LockApplyTransactionForSession(), LockDatabaseFrozenIds(), LockDatabaseObject(), LockGXact(), logical_heap_rewrite_flush_mappings(), logical_rewrite_log_mapping(), LogLogicalMessage(), LogStandbyInvalidations(), map_sql_catalog_to_xmlschema_types(), map_sql_schema_to_xmlschema_types(), map_sql_table_to_xmlschema(), map_sql_type_to_xml_name(), match_db_entries(), movedb(), perform_relmap_update(), perform_work_item(), pg_collation_actual_version(), pg_namespace_aclmask(), pg_relation_filepath(), pg_stat_reset_single_function_counters(), pg_stat_reset_single_table_counters(), pgss_store(), pgstat_bestart(), pgstat_build_snapshot(), pgstat_copy_relation_stats(), pgstat_create_function(), pgstat_create_relation(), pgstat_drop_function(), pgstat_drop_relation(), pgstat_fetch_stat_funcentry(), pgstat_fetch_stat_tabentry_ext(), pgstat_init_function_usage(), pgstat_prep_database_pending(), pgstat_prep_relation_pending(), pgstat_report_analyze(), pgstat_report_checksum_failure(), pgstat_report_connect(), pgstat_report_deadlock(), pgstat_report_disconnect(), pgstat_report_recovery_conflict(), pgstat_report_tempfile(), pgstat_report_vacuum(), pgstat_reset_counters(), pgstat_reset_database_timestamp(), pgstat_shutdown_hook(), pgstat_update_dbstats(), PostgresMain(), PrepareToInvalidateCacheTuple(), PrepareTransaction(), ProcArrayInstallImportedXmin(), ProcArrayInstallRestoredXmin(), RangeVarGetAndCheckCreationNamespace(), RangeVarGetCreationNamespace(), RangeVarGetRelidExtended(), ReindexMultipleTables(), RelationInitLockInfo(), RelationInitPhysicalAddr(), RelationMapFinishBootstrap(), RenameDatabase(), RenameSchema(), ReplicationSlotCreate(), roles_is_member_of(), ScanPgRelation(), sepgsql_schema_post_create(), SetLocktagRelationOid(), shdepDropOwned(), shdepReassignOwned(), SignalBackends(), transformColumnRef(), UnlockApplyTransactionForSession(), UnlockDatabaseObject(), UpdateLogicalMappings(), vac_truncate_clog(), vac_update_datfrozenxid(), vacuum_is_relation_owner(), XactLogAbortRecord(), and XactLogCommitRecord().
|
extern |
Definition at line 91 of file globals.c.
Referenced by AlterTableMoveAll(), ATPrepSetTableSpace(), calculate_tablespace_size(), check_temp_tablespaces(), CheckRelationTableSpaceMove(), DefineIndex(), DefineRelation(), ExecReindex(), FileSetInit(), get_tablespace(), GetDefaultTablespace(), GetNewRelFileNumber(), heap_create(), InitPostgres(), LogStandbyInvalidations(), OpenTemporaryFile(), perform_relmap_update(), pg_relation_filepath(), pg_tablespace_location(), PrepareTempTablespaces(), ReindexMultipleInternal(), RelationInitPhysicalAddr(), RelationMapFinishBootstrap(), RelidByRelfilenumber(), SetRelationTableSpace(), XactLogAbortRecord(), and XactLogCommitRecord().
|
extern |
Definition at line 58 of file globals.c.
Referenced by ApplyLauncherMain(), autoprewarm_main(), AutoVacLauncherMain(), avl_sigusr2_handler(), BackgroundWriterMain(), be_tls_open_server(), CheckDeadLockAlert(), CheckpointerMain(), CheckpointWriteDelay(), ClientCheckTimeoutHandler(), ConditionVariableTimedSleep(), ConfigurePostmasterWaitSet(), copy_read_data(), die(), do_pg_backup_stop(), gather_readnext(), handle_pm_child_exit_signal(), handle_pm_pmsignal_signal(), handle_pm_reload_request_signal(), handle_pm_shutdown_request_signal(), handle_sig_alarm(), HandleCatchupInterrupt(), HandleNotifyInterrupt(), HandleParallelApplyMessageInterrupt(), HandleParallelMessageInterrupt(), IdleInTransactionSessionTimeoutHandler(), IdleSessionTimeoutHandler(), IdleStatsUpdateTimeoutHandler(), InitializeLatchWaitSet(), InitProcessLocalLatch(), lazy_truncate_heap(), libpqrcv_PQgetResult(), libpqsrv_connect_internal(), LogicalParallelApplyLoop(), logicalrep_worker_stop_internal(), LogicalRepApplyLoop(), mq_putmessage(), pa_send_data(), pa_wait_for_xact_state(), pg_promote(), pg_sleep(), pg_wait_until_termination(), pgarch_MainLoop(), pgarch_waken_stop(), pgfdw_get_cleanup_result(), pgfdw_get_result(), pq_check_connection(), pq_init(), ProcessClientReadInterrupt(), ProcessClientWriteInterrupt(), ProcessPendingWrites(), procsignal_sigusr1_handler(), ProcSleep(), ProcWaitForSignal(), read_or_wait(), ReqCheckpointHandler(), secure_open_gssapi(), secure_read(), secure_write(), ServerLoop(), shm_mq_receive_bytes(), shm_mq_send_bytes(), shm_mq_wait_internal(), SignalHandlerForConfigReload(), SignalHandlerForShutdownRequest(), sigUsr1Handler(), StatementCancelHandler(), SwitchBackToLocalLatch(), SwitchToSharedLatch(), SyncRepWaitForLSN(), SysLoggerMain(), test_shm_mq_pipelined(), throttle(), wait_for_relation_state_change(), wait_for_worker_state_change(), wait_for_workers_to_become_ready(), WaitForBackgroundWorkerShutdown(), WaitForBackgroundWorkerStartup(), WaitForParallelWorkersToAttach(), WaitForParallelWorkersToFinish(), WaitForReplicationWorkerAttach(), WalRcvWaitForStartPosition(), WalReceiverMain(), WalSndLastCycleHandler(), WalSndLoop(), WalSndWaitForWal(), WalWriterMain(), and worker_spi_main().
|
extern |
Definition at line 49 of file globals.c.
Referenced by assign_backendlist_entry(), BackendStartup(), MarkPostmasterChildActive(), MarkPostmasterChildInactive(), MarkPostmasterChildWalSender(), and StartAutovacuumWorker().
|
extern |
Definition at line 44 of file globals.c.
Referenced by AddWaitEventToSet(), ApplyLauncherMain(), apw_detach_shmem(), apw_dump_now(), apw_load_buffers(), apw_start_database_worker(), apw_start_leader_worker(), Async_Listen(), Async_Unlisten(), Async_UnlistenAll(), asyncQueueNotificationToEntry(), asyncQueueReadAllNotifications(), autoprewarm_main(), AutoVacLauncherMain(), basic_archive_file_internal(), CheckpointerMain(), CleanupProcSignalState(), DisownLatch(), Exec_ListenPreCommit(), Exec_UnlistenAllCommit(), Exec_UnlistenCommit(), ExportSnapshot(), FileSetInit(), get_backend_type_for_log(), GetSerializableTransactionSnapshotInt(), HandleWalSndInitStopping(), InitAuxiliaryProcess(), initialize_drandom_seed(), InitializeLatchSupport(), InitializeParallelDSM(), InitLatch(), InitPostmasterDeathWatchHandle(), InitProcess(), InitProcessGlobals(), InitWalSenderSlot(), InvalidatePossiblyObsoleteSlot(), IsLogicalLauncher(), LaunchParallelWorkers(), llvm_compile_module(), LockTimeoutHandler(), log_status_format(), logicalrep_worker_launch(), ModifyWaitEvent(), OpenTemporaryFileInTablespace(), OwnLatch(), ParallelWorkerMain(), pg_backend_pid(), pgstat_bestart(), PostgresMain(), PostmasterMain(), process_pgfdw_appname(), ProcessLogMemoryContextInterrupt(), ProcSignalInit(), ProcSleep(), ReplicationOriginExitCleanup(), ReplicationSlotAcquire(), ReplicationSlotCleanup(), ReplicationSlotCreate(), ReplicationSlotsDropDBSlots(), replorigin_session_setup(), ResetLatch(), ServerLoop(), SetLatch(), setup_background_workers(), SharedInvalBackendInit(), SignalBackends(), SnapBuildSerialize(), StatementTimeoutHandler(), WalRcvDie(), WalReceiverMain(), worker_spi_launch(), write_csvlog(), write_jsonlog(), write_pipe_chunks(), and write_relcache_init_file().
|
extern |
Definition at line 47 of file globals.c.
Referenced by assign_tcp_keepalives_count(), assign_tcp_keepalives_idle(), assign_tcp_keepalives_interval(), assign_tcp_user_timeout(), BackendInitialize(), check_conn_params(), dblink_connstr_check(), dblink_security_check(), inet_client_addr(), inet_client_port(), inet_server_addr(), inet_server_port(), InitPostgres(), internal_flush(), log_disconnections(), log_status_format(), pgfdw_security_check(), pgstat_bestart(), pq_getbyte_if_available(), pq_init(), pq_recvbuf(), process_pgfdw_appname(), show_tcp_keepalives_count(), show_tcp_keepalives_idle(), show_tcp_keepalives_interval(), show_tcp_user_timeout(), socket_close(), socket_set_nonblocking(), ssl_cipher(), ssl_client_cert_present(), ssl_client_dn(), ssl_client_dn_field(), ssl_client_serial(), ssl_extension_info(), ssl_is_used(), ssl_issuer_dn(), ssl_issuer_field(), ssl_version(), start_xact_command(), write_csvlog(), and write_jsonlog().
|
extern |
Definition at line 45 of file globals.c.
Referenced by CreateLockFile(), get_formatted_start_time(), InitProcessGlobals(), log_status_format(), process_pgfdw_appname(), SysLoggerMain(), write_csvlog(), and write_jsonlog().
|
extern |
Definition at line 46 of file globals.c.
Referenced by InitProcessGlobals(), log_disconnections(), pgstat_bestart(), and pgstat_report_connect().
|
extern |
|
extern |
Definition at line 74 of file globals.c.
Referenced by BootstrapModeMain(), DebugFileOpen(), and process_postgres_switches().
|
extern |
Definition at line 77 of file globals.c.
Referenced by add_module_to_inline_search_path(), getInstallationPaths(), InitStandaloneProcess(), llvm_create_types(), load_module(), provider_init(), and substitute_libpath_macro().
|
extern |
Definition at line 99 of file globals.c.
Referenced by get_backend_type_for_log(), InitPostmasterDeathWatchHandle(), pg_promote(), pg_reload_conf(), pg_spinlock_barrier(), PostmasterMain(), and SendPostmasterSignal().
|
extern |
Definition at line 32 of file globals.c.
Referenced by die(), proc_exit_prepare(), ProcessClientReadInterrupt(), ProcessClientWriteInterrupt(), ProcessInterrupts(), and SyncRepWaitForLSN().
|
extern |
Definition at line 1765 of file miscinit.c.
Referenced by check_wal_consistency_checking(), InitializeWalConsistencyChecking(), and process_shared_preload_libraries().
|
extern |
Definition at line 1764 of file miscinit.c.
Referenced by _PG_init(), apw_start_leader_worker(), init_custom_variable(), process_shared_preload_libraries(), RegisterBackgroundWorker(), and RegisterCustomRmgr().
|
extern |
Definition at line 1768 of file miscinit.c.
Referenced by process_shmem_requests(), RequestAddinShmemSpace(), and RequestNamedLWLockTranche().
|
extern |
Definition at line 37 of file globals.c.
Referenced by BufferSync(), CheckpointWriteDelay(), HandleAutoVacLauncherInterrupts(), HandleCheckpointerInterrupts(), HandleMainLoopInterrupts(), HandlePgArchInterrupts(), HandleProcSignalBarrierInterrupt(), HandleStartupProcInterrupts(), HandleWalWriterInterrupts(), ProcessInterrupts(), ProcessProcSignalBarrier(), and ResetProcSignalBarrierBits().
|
extern |
Definition at line 41 of file globals.c.
Referenced by errfinish(), ProcessInterrupts(), and ProcessRecoveryConflictInterrupt().
|
extern |
Definition at line 31 of file globals.c.
Referenced by AutoVacLauncherMain(), do_autovacuum(), perform_work_item(), PostgresMain(), proc_exit_prepare(), ProcessInterrupts(), StatementCancelHandler(), and SyncRepWaitForLSN().
|
extern |
Definition at line 1759 of file miscinit.c.
Referenced by process_session_preload_libraries().
|
extern |
Definition at line 1760 of file miscinit.c.
Referenced by process_shared_preload_libraries().
|
extern |
Definition at line 1767 of file miscinit.c.
Referenced by _PG_init(), and process_shmem_requests().
|
extern |
Definition at line 528 of file guc_tables.c.
Referenced by PerformWalRecovery(), and trace_recovery().
|
extern |
Definition at line 143 of file globals.c.
Referenced by do_autovacuum(), and ExecVacuum().
|
extern |
Definition at line 156 of file globals.c.
Referenced by lazy_check_wraparound_failsafe(), MarkBufferDirty(), MarkBufferDirtyHint(), ReadBuffer_common(), vacuum(), vacuum_delay_point(), and VacuumUpdateCosts().
|
extern |
Definition at line 155 of file globals.c.
Referenced by compute_parallel_delay(), lazy_check_wraparound_failsafe(), MarkBufferDirty(), MarkBufferDirtyHint(), parallel_vacuum_main(), parallel_vacuum_process_all_indexes(), ReadBuffer_common(), vacuum(), vacuum_delay_point(), and VacuumUpdateCosts().
|
extern |
Definition at line 149 of file globals.c.
Referenced by VacuumUpdateCosts().
|
extern |
Definition at line 148 of file globals.c.
Referenced by AutoVacuumUpdateCostLimit(), and VacuumUpdateCosts().
|
extern |
Definition at line 147 of file globals.c.
Referenced by MarkBufferDirty(), and MarkBufferDirtyHint().
|
extern |
Definition at line 145 of file globals.c.
Referenced by ReadBuffer_common().
|
extern |
Definition at line 146 of file globals.c.
Referenced by ReadBuffer_common().
|
extern |
Definition at line 153 of file globals.c.
Referenced by do_analyze_rel(), heap_vacuum_rel(), MarkBufferDirty(), MarkBufferDirtyHint(), parallel_vacuum_main(), and vacuum().
|
extern |
Definition at line 151 of file globals.c.
Referenced by do_analyze_rel(), heap_vacuum_rel(), parallel_vacuum_main(), ReadBuffer_common(), and vacuum().
|
extern |
Definition at line 152 of file globals.c.
Referenced by do_analyze_rel(), heap_vacuum_rel(), parallel_vacuum_main(), ReadBuffer_common(), and vacuum().
|
extern |
Definition at line 125 of file globals.c.
Referenced by _bt_parallel_scan_and_sort(), _bt_pendingfsm_init(), _bt_spools_heapscan(), adjust_foreign_grouping_path_cost(), begin_partition(), choose_hashed_setop(), collectMatchBitmap(), compute_bitmap_pages(), connectby(), cost_append(), cost_material(), cost_rescan(), create_gather_merge_path(), create_groupingsets_path(), create_incremental_sort_path(), create_merge_append_path(), create_sort_path(), create_unique_path(), CreateWorkExprContext(), crosstab(), exec_init_tuple_store(), ExecIncrementalSort(), ExecInitCteScan(), ExecInitRecursiveUnion(), ExecMakeTableFunctionResult(), ExecMaterial(), ExecRecursiveUnion(), ExecSort(), final_cost_mergejoin(), fmgr_sql(), get_crosstab_tuplestore(), get_hash_memory_limit(), GetCurrentFDWTuplestore(), ginInsertCleanup(), initial_cost_mergejoin(), initialize_aggregate(), initialize_phase(), InitMaterializedSRF(), label_sort_with_costsize(), libpqrcv_processTuples(), MakeTransitionCaptureState(), materializeResult(), MultiExecBitmapIndexScan(), MultiExecBitmapOr(), ordered_set_startup(), pg_logdir_ls_internal(), plperl_return_next_internal(), pltcl_init_tuple_store(), populate_recordset_worker(), PortalCreateHoldStore(), storeRow(), switchToPresortedPrefixMode(), and tfuncFetchRows().