|
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_BACKEND , B_DEAD_END_BACKEND , B_AUTOVAC_LAUNCHER , B_AUTOVAC_WORKER , B_BG_WORKER , B_WAL_SENDER , B_SLOTSYNC_WORKER , B_STANDALONE_BACKEND , B_ARCHIVER , B_BG_WRITER , B_CHECKPOINTER , B_IO_WORKER , B_STARTUP , B_WAL_RECEIVER , B_WAL_SUMMARIZER , B_WAL_WRITER , B_LOGGER } |
| enum | ProcessingMode { BootstrapProcessing , InitProcessing , NormalProcessing } |
| #define AmArchiverProcess | ( | ) | (MyBackendType == B_ARCHIVER) |
Definition at line 387 of file miscadmin.h.
| #define AmAutoVacuumLauncherProcess | ( | ) | (MyBackendType == B_AUTOVAC_LAUNCHER) |
Definition at line 382 of file miscadmin.h.
| #define AmAutoVacuumWorkerProcess | ( | ) | (MyBackendType == B_AUTOVAC_WORKER) |
Definition at line 383 of file miscadmin.h.
| #define AmBackgroundWorkerProcess | ( | ) | (MyBackendType == B_BG_WORKER) |
Definition at line 384 of file miscadmin.h.
| #define AmBackgroundWriterProcess | ( | ) | (MyBackendType == B_BG_WRITER) |
Definition at line 388 of file miscadmin.h.
| #define AmCheckpointerProcess | ( | ) | (MyBackendType == B_CHECKPOINTER) |
Definition at line 389 of file miscadmin.h.
| #define AmIoWorkerProcess | ( | ) | (MyBackendType == B_IO_WORKER) |
Definition at line 394 of file miscadmin.h.
| #define AmLogicalSlotSyncWorkerProcess | ( | ) | (MyBackendType == B_SLOTSYNC_WORKER) |
Definition at line 386 of file miscadmin.h.
| #define AmRegularBackendProcess | ( | ) | (MyBackendType == B_BACKEND) |
Definition at line 381 of file miscadmin.h.
| #define AmSpecialWorkerProcess | ( | ) |
Definition at line 396 of file miscadmin.h.
| #define AmStartupProcess | ( | ) | (MyBackendType == B_STARTUP) |
Definition at line 390 of file miscadmin.h.
| #define AmWalReceiverProcess | ( | ) | (MyBackendType == B_WAL_RECEIVER) |
Definition at line 391 of file miscadmin.h.
| #define AmWalSenderProcess | ( | ) | (MyBackendType == B_WAL_SENDER) |
Definition at line 385 of file miscadmin.h.
| #define AmWalSummarizerProcess | ( | ) | (MyBackendType == B_WAL_SUMMARIZER) |
Definition at line 392 of file miscadmin.h.
| #define AmWalWriterProcess | ( | ) | (MyBackendType == B_WAL_WRITER) |
Definition at line 393 of file miscadmin.h.
Definition at line 377 of file miscadmin.h.
| #define CHECK_FOR_INTERRUPTS | ( | ) |
Definition at line 123 of file miscadmin.h.
| #define DATEORDER_DMY 1 |
Definition at line 244 of file miscadmin.h.
| #define DATEORDER_MDY 2 |
Definition at line 245 of file miscadmin.h.
| #define DATEORDER_YMD 0 |
Definition at line 243 of file miscadmin.h.
| #define END_CRIT_SECTION | ( | ) |
Definition at line 152 of file miscadmin.h.
Definition at line 481 of file miscadmin.h.
| #define HOLD_CANCEL_INTERRUPTS | ( | ) | (QueryCancelHoldoffCount++) |
Definition at line 142 of file miscadmin.h.
| #define HOLD_INTERRUPTS | ( | ) | (InterruptHoldoffCount++) |
Definition at line 134 of file miscadmin.h.
| #define INIT_PG_LOAD_SESSION_LIBS 0x0001 |
Definition at line 499 of file miscadmin.h.
| #define INIT_PG_OVERRIDE_ALLOW_CONNS 0x0002 |
Definition at line 500 of file miscadmin.h.
| #define INIT_PG_OVERRIDE_ROLE_LOGIN 0x0004 |
Definition at line 501 of file miscadmin.h.
| #define INTERRUPTS_CAN_BE_PROCESSED | ( | ) |
Definition at line 130 of file miscadmin.h.
| #define INTERRUPTS_PENDING_CONDITION | ( | ) | (unlikely(InterruptPending)) |
Definition at line 113 of file miscadmin.h.
| #define INTSTYLE_ISO_8601 3 |
Definition at line 260 of file miscadmin.h.
| #define INTSTYLE_POSTGRES 0 |
Definition at line 257 of file miscadmin.h.
| #define INTSTYLE_POSTGRES_VERBOSE 1 |
Definition at line 258 of file miscadmin.h.
| #define INTSTYLE_SQL_STANDARD 2 |
Definition at line 259 of file miscadmin.h.
| #define InvalidPid (-1) |
Definition at line 32 of file miscadmin.h.
| #define IsBootstrapProcessingMode | ( | ) | (Mode == BootstrapProcessing) |
Definition at line 477 of file miscadmin.h.
| #define IsExternalConnectionBackend | ( | backend_type | ) | (backend_type == B_BACKEND || backend_type == B_WAL_SENDER) |
Definition at line 405 of file miscadmin.h.
| #define IsInitProcessingMode | ( | ) | (Mode == InitProcessing) |
Definition at line 478 of file miscadmin.h.
| #define IsNormalProcessingMode | ( | ) | (Mode == NormalProcessing) |
Definition at line 479 of file miscadmin.h.
| #define MAX_BAS_VAC_RING_SIZE_KB (16 * 1024 * 1024) |
Definition at line 279 of file miscadmin.h.
Definition at line 264 of file miscadmin.h.
| #define MIN_BAS_VAC_RING_SIZE_KB 128 |
Definition at line 278 of file miscadmin.h.
| #define RESUME_CANCEL_INTERRUPTS | ( | ) |
Definition at line 144 of file miscadmin.h.
| #define RESUME_INTERRUPTS | ( | ) |
Definition at line 136 of file miscadmin.h.
| #define SECURITY_LOCAL_USERID_CHANGE 0x0001 |
Definition at line 318 of file miscadmin.h.
| #define SECURITY_NOFORCE_RLS 0x0004 |
Definition at line 320 of file miscadmin.h.
| #define SECURITY_RESTRICTED_OPERATION 0x0002 |
Definition at line 319 of file miscadmin.h.
Definition at line 483 of file miscadmin.h.
| #define STACK_DEPTH_SLOP (512 * 1024) |
Definition at line 297 of file miscadmin.h.
| #define START_CRIT_SECTION | ( | ) | (CritSectionCount++) |
Definition at line 150 of file miscadmin.h.
| #define USE_GERMAN_DATES 3 |
Definition at line 239 of file miscadmin.h.
| #define USE_ISO_DATES 1 |
Definition at line 237 of file miscadmin.h.
| #define USE_POSTGRES_DATES 0 |
Definition at line 236 of file miscadmin.h.
| #define USE_SQL_DATES 2 |
Definition at line 238 of file miscadmin.h.
| #define USE_XSD_DATES 4 |
Definition at line 240 of file miscadmin.h.
Definition at line 299 of file miscadmin.h.
Definition at line 533 of file miscadmin.h.
Definition at line 337 of file miscadmin.h.
| Enumerator | |
|---|---|
| BootstrapProcessing | |
| InitProcessing | |
| NormalProcessing | |
Definition at line 468 of file miscadmin.h.
Definition at line 1519 of file miscinit.c.
References close, DIRECTORY_LOCK_FILE, ereport, errcode_for_file_access(), errmsg(), fb(), fd(), len, LOG, PG_BINARY, pg_fsync(), pg_pwrite, pgstat_report_wait_end(), pgstat_report_wait_start(), read, snprintf, and str.
Referenced by InternalIpcMemoryCreate(), PostmasterMain(), process_pm_child_exit(), process_pm_pmsignal(), and process_pm_shutdown_request().
Definition at line 607 of file postinit.c.
References Assert, DebugFileOpen(), fb(), InitBufferManagerAccess(), InitFileAccess(), InitializeProcessXLogLogicalInfo(), InitLockManagerAccess(), InitSync(), InitTemporaryFileAccess(), InitXLogInsert(), MyProc, pgaio_init_backend(), pgstat_initialize(), ReplicationSlotInitialize(), and smgrinit().
Referenced by AutoVacLauncherMain(), AutoVacWorkerMain(), AuxiliaryProcessMainCommon(), BackgroundWorkerMain(), BootstrapModeMain(), PostgresMain(), and ReplSlotSyncWorkerMain().
Definition at line 409 of file miscinit.c.
References Assert, DataDir, ereport, errcode_for_file_access(), errmsg(), FATAL, and fb().
Referenced by BootstrapModeMain(), PostgresSingleUserMain(), and PostmasterMain().
Definition at line 95 of file stack_depth.c.
References ereport, errcode(), errhint(), errmsg(), ERROR, fb(), max_stack_depth, and stack_is_too_deep().
Referenced by _jumbleNode(), AlterTypeRecurse(), apply_scanjoin_target_to_paths(), ATAddCheckNNConstraint(), ATExecAddColumn(), ATExecAlterConstrDeferrability(), ATExecAlterConstrEnforceability(), ATExecDropColumn(), ATExecSetNotNull(), CheckAttributeType(), 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(), dropconstraint_internal(), emit_jsp_gin_entries(), equal(), eval_const_expressions_mutator(), EventTriggerInvoke(), ExecEndNode(), ExecEvalSubPlan(), ExecInitExprRec(), ExecInitNode(), ExecMakeFunctionResultSet(), ExecProcNodeFirst(), ExecShutdownNode_walker(), execute(), executeAnyItem(), executeBoolItem(), executeItemOptUnwrapTarget(), expand_partitioned_rtentry(), expr_is_nonnullable(), expression_tree_mutator_impl(), expression_tree_walker_impl(), extract_jsp_bool_expr(), fillQT(), find_composite_type_dependencies(), find_matching_subplans_recurse(), findDependentObjects(), findoprnd(), 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(), infix(), infix(), inline_function_in_from(), int_query_opr_selec(), is_simple_union_all_recurse(), JsonbDeepContains(), lseg_inside_poly(), ltree_execute(), makepol(), makepol(), 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().
Definition at line 296 of file miscinit.c.
References Assert, data_directory_mode, DataDir, ereport, errcode(), errcode_for_file_access(), errdetail(), errhint(), errmsg(), FATAL, fb(), pg_dir_create_mode, pg_mode_mask, PG_MODE_MASK_GROUP, S_ISDIR, SetDataDirectoryCreatePerm(), stat, and ValidatePgVersion().
Referenced by BootstrapModeMain(), PostgresSingleUserMain(), and PostmasterMain().
Definition at line 1463 of file miscinit.c.
References CreateLockFile(), DataDir, DIRECTORY_LOCK_FILE, and fb().
Referenced by BootstrapModeMain(), PostgresSingleUserMain(), and PostmasterMain().
|
extern |
Definition at line 1472 of file miscinit.c.
References CreateLockFile(), fb(), MAXPGPATH, and snprintf.
Referenced by Lock_AF_UNIX().
Definition at line 1035 of file miscinit.c.
References add_size(), ClientConnectionInfo::authn_id, fb(), and MyClientConnectionInfo.
Referenced by InitializeParallelDSM().
Definition at line 3621 of file nodeHash.c.
References fb(), hash_mem_multiplier, Min, and work_mem.
Referenced by consider_groupingsets_paths(), cost_memoize_rescan(), create_setop_path(), ExecChooseHashTableSize(), ExecInitMemoize(), ExecParallelHashIncreaseNumBatches(), final_cost_hashjoin(), hash_agg_set_limits(), hash_choose_num_partitions(), subpath_is_hashable(), and subplan_is_hashable().
Definition at line 176 of file stack_depth.c.
Referenced by check_max_stack_depth(), and InitializeGUCOptionsFromEnvironment().
Definition at line 545 of file miscinit.c.
References Assert, AuthenticatedUserId, and OidIsValid.
Referenced by check_session_authorization(), and InitializeParallelDSM().
|
extern |
Definition at line 263 of file miscinit.c.
References fb(), and gettext_noop.
Referenced by BackendInitialize(), BackendStartup(), CleanupBackend(), CountChildren(), get_backend_type_for_log(), init_ps_display(), pg_stat_get_activity(), pg_stat_io_build_tuples(), and signal_child().
Definition at line 935 of file miscinit.c.
References InvalidOid, OuterUserId, and SetRoleIsActive.
Referenced by check_role(), InitializeParallelDSM(), and show_role().
Definition at line 480 of file miscinit.c.
References Assert, OidIsValid, and OuterUserId.
Referenced by DropRole(), and RenameRole().
Definition at line 508 of file miscinit.c.
References Assert, OidIsValid, and SessionUserId.
Referenced by check_role(), check_session_authorization(), DropRole(), get_rolespec_oid(), get_rolespec_tuple(), InitializeParallelDSM(), InitPostgres(), pgstat_bestart_final(), RenameRole(), and session_user().
Definition at line 515 of file miscinit.c.
References Assert, OidIsValid, SessionUserId, and SessionUserIsSuperuser.
Referenced by check_session_authorization(), and InitializeParallelDSM().
Definition at line 469 of file miscinit.c.
References Assert, CurrentUserId, and OidIsValid.
Referenced by AfterTriggerSaveEvent(), AggregateCreate(), all_rows_selectable(), 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(), ATExecChangeOwner(), ATPrepAlterColumnType(), ATPrepSetTableSpace(), ATSimplePermissions(), bbsink_server_new(), be_lo_unlink(), binary_upgrade_create_empty_extension(), binary_upgrade_logical_slot_has_caught_up(), brin_desummarize_range(), BuildCachedPlan(), BuildDescForRelation(), BuildIndexValueDescription(), calculate_database_size(), calculate_tablespace_size(), call_pltcl_start_proc(), check_enable_rls(), check_search_path(), 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(), copy_sequence(), 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(), DoCopy(), dropdb(), DropOwnedObjects(), DropRole(), DropSubscription(), DropTableSpace(), emit_audit_message(), EnableDisableRule(), ExecAlterDefaultPrivilegesStmt(), ExecAlterExtensionContentsStmt(), ExecAlterExtensionStmt(), ExecAlterObjectDependsStmt(), ExecBuildGroupingEqual(), ExecBuildParamSetEqual(), ExecBuildSlotPartitionKeyDescription(), ExecBuildSlotValueDescription(), ExecCheckOneRelPerms(), ExecCheckpoint(), 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(), fmgr_security_definer(), get_connect_string(), get_other_operator(), 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_largeobject_privilege_id(), 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_function_in_from(), 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_get_multixact_stats(), pg_get_sequence_data(), 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(), RangeVarCallbackForDblink(), RangeVarCallbackForDropRelation(), RangeVarCallbackForLockTable(), RangeVarCallbackForPolicy(), RangeVarCallbackForReindexIndex(), RangeVarCallbackForRenameRule(), RangeVarCallbackForRenameTrigger(), RangeVarCallbackForStats(), RangeVarCallbackMaintainsTable(), RangeVarCallbackOwnsRelation(), 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(), SetSequence(), shell_check_detail(), superuser(), TargetPrivilegesCheck(), TerminateOtherDBBackends(), transformTableLikeClause(), truncate_check_perms(), user_mapping_ddl_aclcheck(), vacuum_is_permitted_for_relation(), validate_option_array_item(), ValidateJoinEstimator(), ValidateOperatorReference(), and ValidateRestrictionEstimator().
Definition at line 661 of file miscinit.c.
References CurrentUserId, fb(), and InLocalUserIdChange().
Definition at line 612 of file miscinit.c.
References CurrentUserId, and SecurityRestrictionContext.
Referenced by AfterTriggerExecute(), amcheck_lock_relation_and_check(), ATExecMergePartitions(), ATExecSplitPartition(), brin_summarize_range(), cluster_rel(), ComputeIndexAttrs(), CreateSchemaCommand(), DefineIndex(), do_analyze_rel(), execute_extension_script(), fmgr_security_definer(), index_build(), index_concurrently_build(), InitializeParallelDSM(), PushTransaction(), RefreshMatViewByOid(), reindex_index(), ReindexRelationConcurrently(), ri_PerformCheck(), ri_PlanCheck(), StartTransaction(), SwitchToUntrustedUser(), vacuum_rel(), and validate_index().
Definition at line 988 of file miscinit.c.
References ereport, errcode(), errmsg(), ERROR, fb(), 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 688 of file miscinit.c.
References fb(), GETSTRUCT(), HeapTupleIsValid, ObjectIdGetDatum(), ReleaseSysCache(), rolreplication, SearchSysCache1(), and superuser_arg().
Referenced by AlterRole(), binary_upgrade_logical_slot_has_caught_up(), CheckSlotPermissions(), CreateRole(), and InitPostgres().
Definition at line 575 of file postinit.c.
References Assert, FastPathLockGroupsPerBackend, FP_LOCK_GROUPS_PER_BACKEND_MAX, FP_LOCK_SLOTS_PER_GROUP, Max, max_locks_per_xact, Min, and pg_nextpower2_32().
Referenced by BootstrapModeMain(), PostgresSingleUserMain(), and PostmasterMain().
Definition at line 550 of file postinit.c.
References Assert, autovacuum_worker_slots, ereport, errcode(), errdetail(), errmsg(), ERROR, fb(), MAX_BACKENDS, max_wal_senders, max_worker_processes, MaxBackends, MaxConnections, and NUM_SPECIAL_WORKER_PROCS.
Referenced by BootstrapModeMain(), PostgresSingleUserMain(), and PostmasterMain().
Definition at line 710 of file miscinit.c.
References AcceptInvalidationMessages(), AmRegularBackendProcess, Assert, CountUserBackends(), ereport, errcode(), errmsg(), FATAL, fb(), GETSTRUCT(), HeapTupleIsValid, InitializingParallelWorker, is_superuser(), IsBootstrapProcessingMode, IsUnderPostmaster, NameStr, ObjectIdGetDatum(), PGC_BACKEND, PGC_S_OVERRIDE, PointerGetDatum(), ReleaseSysCache(), SearchSysCache1(), SetAuthenticatedUserId(), and SetConfigOption().
Referenced by InitPostgres().
Definition at line 840 of file miscinit.c.
References AmAutoVacuumWorkerProcess, AmBackgroundWorkerProcess, AmLogicalSlotSyncWorkerProcess, Assert, AuthenticatedUserId, fb(), InvalidOid, IsUnderPostmaster, OidIsValid, SetCurrentRoleId(), and SetSessionAuthorization().
Referenced by InitPostgres().
Definition at line 874 of file miscinit.c.
References Assert, authn_id, fb(), MemoryContextStrdup(), pfree(), psprintf(), system_user(), SystemUser, and TopMemoryContext.
Referenced by InitPostgres(), and ParallelWorkerMain().
|
extern |
Definition at line 710 of file postinit.c.
References am_db_walsender, am_walsender, AmAutoVacuumLauncherProcess, AmAutoVacuumWorkerProcess, AmBackgroundWorkerProcess, AmLogicalSlotSyncWorkerProcess, AmRegularBackendProcess, 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, fb(), GetDatabasePath(), GetDatabaseTuple(), GetDatabaseTupleByOid(), GetSessionUserId(), GETSTRUCT(), 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(), INIT_PG_LOAD_SESSION_LIBS, INIT_PG_OVERRIDE_ALLOW_CONNS, INIT_PG_OVERRIDE_ROLE_LOGIN, InitCatalogCache(), initialize_acl(), InitializeClientEncoding(), InitializeSearchPath(), InitializeSession(), InitializeSessionUserId(), InitializeSessionUserIdStandalone(), InitializeSystemUser(), InitPlanCache(), InitProcessPhase2(), INJECTION_POINT, InvalidateCatalogSnapshot(), IsBinaryUpgrade, IsBootstrapProcessingMode, IsUnderPostmaster, LOCK_TIMEOUT, LockSharedObject(), LockTimeoutHandler(), MyCancelKey, MyCancelKeyLength, MyClientConnectionInfo, MyDatabaseHasLoginEventTriggers, MyDatabaseId, MyDatabaseTableSpace, MyProc, MyProcPort, NAMEDATALEN, NameStr, namestrcmp(), OidIsValid, PerformAuthentication(), pfree(), pg_usleep(), pgstat_before_server_shutdown(), pgstat_beinit(), pgstat_bestart_final(), pgstat_bestart_initial(), pgstat_bestart_security(), 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(), TRANSACTION_TIMEOUT, TransactionTimeoutHandler(), username, ValidatePgVersion(), WARNING, XACT_READ_COMMITTED, and XactIsoLevel.
Referenced by AutoVacLauncherMain(), AutoVacWorkerMain(), BackgroundWorkerInitializeConnection(), BackgroundWorkerInitializeConnectionByOid(), BootstrapModeMain(), PostgresMain(), and ReplSlotSyncWorkerMain().
Definition at line 96 of file miscinit.c.
References BlockSig, elog, ereport, errcode_for_socket_access(), errmsg_internal(), FATAL, fb(), InitializeLatchWaitSet(), InitializeWaitEventSupport(), InitProcessGlobals(), InitProcessLocalLatch(), IsUnderPostmaster, on_exit_reset(), pgwin32_signal_initialize(), postmaster_alive_fds, POSTMASTER_FD_WATCH, PostmasterDeathSignalInit(), pqinitmask(), pqsignal, SignalHandlerForCrashExit(), and SIGQUIT.
Referenced by postmaster_child_launch().
Definition at line 235 of file miscinit.c.
References InitLatch(), LocalLatchData, and MyLatch.
Referenced by InitPostmasterChild(), InitStandaloneProcess(), and PostmasterMain().
Definition at line 175 of file miscinit.c.
References argv0, Assert, B_STANDALONE_BACKEND, BlockSig, elog, FATAL, fb(), find_my_exec(), get_pkglib_path(), InitializeLatchWaitSet(), InitializeWaitEventSupport(), InitProcessGlobals(), InitProcessLocalLatch(), IsPostmasterEnvironment, my_exec_path, MyBackendType, pgwin32_signal_initialize(), pkglib_path, and pqinitmask().
Referenced by BootstrapModeMain(), and PostgresSingleUserMain().
Definition at line 630 of file miscinit.c.
References SECURITY_LOCAL_USERID_CHANGE, and SecurityRestrictionContext.
Referenced by GetUserIdAndContext(), and set_config_with_handle().
Definition at line 648 of file miscinit.c.
References SECURITY_NOFORCE_RLS, and SecurityRestrictionContext.
Referenced by check_enable_rls().
Definition at line 639 of file miscinit.c.
References SECURITY_RESTRICTED_OPERATION, and SecurityRestrictionContext.
Referenced by afterTriggerMarkEvents(), CheckRestrictedOperation(), DefineRelation(), PerformCursorOpen(), set_config_with_handle(), and SetUserIdAndContext().
Definition at line 1888 of file miscinit.c.
References fb(), get_locale_path(), MAXPGPATH, and my_exec_path.
Referenced by _PG_init(), and test_translation().
Definition at line 492 of file postinit.c.
References appendStringInfoChar(), StringInfoData::data, fb(), initStringInfo(), pfree(), pstrdup(), and resetStringInfo().
Referenced by process_startup_options().
Definition at line 443 of file utility.c.
References ereport, errcode(), errmsg(), ERROR, fb(), and RecoveryInProgress().
Referenced by pg_current_xact_id(), pg_notify(), and standard_ProcessUtility().
Definition at line 424 of file utility.c.
References ereport, errcode(), errmsg(), ERROR, fb(), and IsInParallelMode().
Referenced by ExecCheckXactReadOnly(), nextval_internal(), SetSequence(), and standard_ProcessUtility().
Definition at line 406 of file utility.c.
References ereport, errcode(), errmsg(), ERROR, fb(), 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(), DoCopy(), ExecCheckXactReadOnly(), lo_import_internal(), nextval_internal(), SetSequence(), and standard_ProcessUtility().
Definition at line 1865 of file miscinit.c.
References load_libraries(), local_preload_libraries_string, and session_preload_libraries_string.
Referenced by InitPostgres().
Definition at line 1851 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().
Definition at line 1879 of file miscinit.c.
References process_shmem_requests_in_progress, and shmem_request_hook.
Referenced by PostgresSingleUserMain(), and PostmasterMain().
Definition at line 3304 of file postgres.c.
References AmAutoVacuumWorkerProcess, AmBackgroundWorkerProcess, AmIoWorkerProcess, AmWalReceiverProcess, 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, fb(), get_timeout_finish_time(), get_timeout_indicator(), IdleInTransactionSessionTimeout, IdleInTransactionSessionTimeoutPending, IdleSessionTimeout, IdleSessionTimeoutPending, IdleStatsUpdateTimeoutPending, INJECTION_POINT, InterruptHoldoffCount, InterruptPending, IsLogicalLauncher(), IsLogicalWorker(), IsTransactionOrTransactionBlock(), LOCK_TIMEOUT, LockErrorCleanup(), LogMemoryContextPending, MyBgworkerEntry, ParallelApplyMessagePending, ParallelMessagePending, pgstat_report_stat(), pq_check_connection(), proc_exit(), ProcDiePending, ProcessLogMemoryContextInterrupt(), ProcessParallelApplyMessages(), ProcessParallelMessages(), ProcessProcSignalBarrier(), ProcessRecoveryConflictInterrupts(), ProcSignalBarrierPending, QueryCancelHoldoffCount, QueryCancelPending, RecoveryConflictPending, STATEMENT_TIMEOUT, TransactionTimeout, TransactionTimeoutPending, and whereToSendOutput.
Referenced by die().
Definition at line 1646 of file miscinit.c.
References close, DIRECTORY_LOCK_FILE, ereport, errcode_for_file_access(), errmsg(), fb(), fd(), len, LOG, PG_BINARY, pgstat_report_wait_end(), pgstat_report_wait_start(), and read.
Referenced by ServerLoop().
|
extern |
Definition at line 77 of file stack_depth.c.
References stack_base_ptr.
Definition at line 1084 of file miscinit.c.
References ClientConnectionInfo::auth_method, ClientConnectionInfo::authn_id, authn_id, fb(), MemoryContextStrdup(), MyClientConnectionInfo, and TopMemoryContext.
Referenced by ParallelWorkerMain().
Definition at line 1051 of file miscinit.c.
References Assert, ClientConnectionInfo::auth_method, ClientConnectionInfo::authn_id, SerializedClientConnectionInfo::authn_id_len, fb(), and MyClientConnectionInfo.
Referenced by InitializeParallelDSM().
|
extern |
Definition at line 44 of file stack_depth.c.
References fb(), and stack_base_ptr.
Referenced by main().
Definition at line 552 of file miscinit.c.
References Assert, AuthenticatedUserId, MyProc, OidIsValid, and PGPROC::roleId.
Referenced by InitializeSessionUserId(), and ParallelWorkerMain().
Definition at line 956 of file miscinit.c.
References is_superuser(), OidIsValid, SessionUserId, SessionUserIsSuperuser, SetOuterUserId(), and SetRoleIsActive.
Referenced by assign_role(), InitializeSessionUserIdStandalone(), and ParallelWorkerMain().
Definition at line 283 of file miscinit.c.
References Assert, DatabasePath, MemoryContextStrdup(), and TopMemoryContext.
Referenced by InitPostgres().
Definition at line 389 of file miscinit.c.
References Assert, DataDir, free, and make_absolute_path().
Referenced by SelectConfigFiles().
Definition at line 920 of file miscinit.c.
References is_superuser(), SetOuterUserId(), SetRoleIsActive, and SetSessionUserId().
Referenced by assign_session_authorization(), InitializeSessionUserIdStandalone(), and ParallelWorkerMain().
Definition at line 668 of file miscinit.c.
References CurrentUserId, ereport, errcode(), errmsg(), ERROR, fb(), InSecurityRestrictedOperation(), SECURITY_LOCAL_USERID_CHANGE, and SecurityRestrictionContext.
Definition at line 619 of file miscinit.c.
References CurrentUserId, and SecurityRestrictionContext.
Referenced by AbortSubTransaction(), AbortTransaction(), AfterTriggerExecute(), amcheck_lock_relation_and_check(), ATExecMergePartitions(), ATExecSplitPartition(), brin_summarize_range(), cluster_rel(), ComputeIndexAttrs(), CreateSchemaCommand(), DefineIndex(), do_analyze_rel(), execute_extension_script(), fmgr_security_definer(), index_build(), index_concurrently_build(), ParallelWorkerMain(), refresh_by_match_merge(), RefreshMatViewByOid(), reindex_index(), ReindexRelationConcurrently(), RestoreUserContext(), ri_PerformCheck(), ri_PlanCheck(), SwitchToUntrustedUser(), vacuum_rel(), and validate_index().
Definition at line 109 of file stack_depth.c.
References fb(), max_stack_depth_bytes, and stack_base_ptr.
Referenced by check_stack_depth(), IsSquashableConstant(), MemoryContextStatsInternal(), rstacktoodeep(), and ShowTransactionStateRec().
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_extension_location(), 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_buffercache_superuser_check(), pg_import_system_collations(), pg_nextoid(), pg_relpages(), pg_relpagesbyid(), 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(), 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 CacheRegisterSyscacheCallback(), fb(), 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(), check_conn_params(), check_object_ownership(), check_role_grantor(), check_role_membership_authorization(), check_session_authorization(), CreateRole(), CreateSubscription(), DropSubscription(), emit_audit_message(), GetSubscription(), has_bypassrls_privilege(), has_createrole_privilege(), has_privs_of_role(), has_rolreplication(), is_admin_of_role(), is_member_of_role(), LockGXact(), member_can_set_role(), object_aclmask_ext(), object_ownercheck(), pg_class_aclmask_ext(), pg_largeobject_aclmask_snapshot(), pg_namespace_aclmask_ext(), pg_parameter_acl_aclmask(), pg_parameter_aclmask(), pg_signal_backend(), pg_type_aclmask_ext(), pgfdw_security_check(), REGRESS_exec_check_perms(), REGRESS_object_access_hook(), REGRESS_object_access_hook_str(), REGRESS_utility_command(), select_best_grantor(), superuser(), and TerminateOtherDBBackends().
Definition at line 242 of file miscinit.c.
References Assert, fb(), FeBeWaitSet, FeBeWaitSetLatchPos, LocalLatchData, ModifyWaitEvent(), MyLatch, MyProc, PGPROC::procLatch, SetLatch(), and WL_LATCH_SET.
Referenced by AuxiliaryProcKill(), and ProcKill().
Definition at line 215 of file miscinit.c.
References Assert, fb(), FeBeWaitSet, FeBeWaitSetLatchPos, LocalLatchData, ModifyWaitEvent(), MyLatch, MyProc, PGPROC::procLatch, SetLatch(), and WL_LATCH_SET.
Referenced by InitAuxiliaryProcess(), and InitProcess().
Definition at line 1490 of file miscinit.c.
References DIRECTORY_LOCK_FILE, fb(), lfirst, and lock_files.
Referenced by ServerLoop().
Definition at line 1718 of file miscinit.c.
References AllocateFile(), ereport, errcode(), errcode_for_file_access(), errdetail(), errhint(), errmsg(), FATAL, fb(), FreeFile(), MAXPGPATH, and snprintf.
Referenced by checkDataDir(), and InitPostgres().
|
extern |
Definition at line 130 of file globals.c.
Referenced by ATAddForeignKeyConstraint(), ATExecAddIndexConstraint(), ATSimplePermissions(), createdb(), createPartitionTable(), 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 35 of file globals.c.
Referenced by ClientCheckTimeoutHandler(), and ProcessInterrupts().
|
extern |
Definition at line 36 of file globals.c.
Referenced by internal_flush_buffer(), and ProcessInterrupts().
|
extern |
Definition at line 161 of file globals.c.
Referenced by CommitTsShmemBuffers(), and CommitTsShmemInit().
|
extern |
Definition at line 45 of file globals.c.
Referenced by AtInplace_Inval(), CompactCheckpointerRequestQueue(), errfinish(), errstart(), heap_page_would_be_all_visible(), HeapTupleHeaderGetCmax(), log_newpage_buffer(), MemoryContextCreate(), pgaio_io_process_completion(), pgstat_prepare_report_checksum_failure(), PreInplace_Inval(), proc_exit_prepare(), ProcessClientWriteInterrupt(), ProcessInterrupts(), visibilitymap_set_vmbits(), XactLogAbortRecord(), XactLogCommitRecord(), XLogEnsureRecordSpace(), and XLogWrite().
|
extern |
Definition at line 77 of file globals.c.
Referenced by checkDataDir(), RetrieveDataDirCreatePerm(), and show_data_directory_mode().
|
extern |
Definition at line 104 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 71 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 126 of file globals.c.
Referenced by assign_datestyle(), check_datestyle(), DecodeNumber(), EncodeDateOnly(), and EncodeDateTime().
|
extern |
Definition at line 125 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 129 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(), ScheduleBufferTagForWriteback(), SyncDataDirectory(), and XLogFlush().
|
extern |
Definition at line 123 of file globals.c.
Referenced by asyncQueueReadAllNotifications(), BeginInternalSubTransaction(), CheckpointerMain(), and errstart().
|
extern |
Definition at line 132 of file globals.c.
Referenced by get_hash_memory_limit().
|
extern |
Definition at line 37 of file globals.c.
Referenced by IdleInTransactionSessionTimeoutHandler(), and ProcessInterrupts().
|
extern |
Definition at line 39 of file globals.c.
Referenced by IdleSessionTimeoutHandler(), and ProcessInterrupts().
|
extern |
Definition at line 42 of file globals.c.
Referenced by IdleStatsUpdateTimeoutHandler(), and ProcessInterrupts().
|
extern |
Definition at line 81 of file miscinit.c.
Referenced by AuxiliaryProcessMainCommon(), BootstrapModeMain(), get_relation_info(), systable_beginscan(), and systable_beginscan_ordered().
|
extern |
Definition at line 43 of file globals.c.
Referenced by errfinish(), proc_exit_prepare(), ProcessClientWriteInterrupt(), ProcessInterrupts(), ProcessRecoveryConflictInterrupts(), and SyncRepWaitForLSN().
|
extern |
Definition at line 32 of file globals.c.
Referenced by ClientCheckTimeoutHandler(), die(), HandleLogMemoryContextInterrupt(), HandleParallelApplyMessageInterrupt(), HandleParallelMessageInterrupt(), HandleProcSignalBarrierInterrupt(), HandleRecoveryConflictInterrupt(), IdleInTransactionSessionTimeoutHandler(), IdleSessionTimeoutHandler(), IdleStatsUpdateTimeoutHandler(), internal_flush_buffer(), proc_exit_prepare(), ProcessInterrupts(), ProcessRecoveryConflictInterrupt(), ResetProcSignalBarrierBits(), StatementCancelHandler(), TransactionTimeoutHandler(), and vacuum_delay_point().
|
extern |
Definition at line 127 of file globals.c.
Referenced by DecodeInterval(), DecodeInterval(), interval_out(), PGTYPESinterval_to_asc(), and set_transmission_modes().
|
extern |
Definition at line 121 of file globals.c.
Referenced by AddEnumLabel(), ApplyLauncherRegister(), AssignTypeArrayOid(), AssignTypeMultirangeArrayOid(), AssignTypeMultirangeOid(), create_toast_table(), CreateDatabaseUsingFileCopy(), createdb(), CreateRole(), CreateTableSpace(), DefineCollation(), DefineOpClass(), GetNewOidWithIndex(), GetNewRelFileNumber(), heap_create_with_catalog(), icu_validate_locale(), index_create(), index_update_stats(), InitPostgres(), InvalidateObsoleteReplicationSlots(), KeepLogSeg(), LaunchMissingBackgroundProcesses(), mdunlinkfork(), PostmasterMain(), process_postgres_switches(), RelationSetNewRelfilenumber(), ReplicationSlotCreate(), truncate_check_rel(), TypeCreate(), and TypeShellMake().
|
extern |
Definition at line 119 of file globals.c.
Referenced by dsm_create(), get_slru_entry(), GetNewObjectId(), HotStandbyActiveInReplay(), InitStandaloneProcess(), MarkAsPreparingGuts(), pgstat_fetch_entry(), pgstat_read_statsfile(), pgstat_shutdown_hook(), pgstat_wal_flush_cb(), postmaster_child_launch(), PostmasterMain(), RegisterBackgroundWorker(), RequestCheckpoint(), SetNextObjectId(), ShutdownXLOG(), StartupXLOG(), and UnlinkLockFiles().
|
extern |
Definition at line 120 of file globals.c.
Referenced by _PG_init(), AdvanceNextFullTransactionIdPastXid(), AutoVacuumShmemInit(), AuxiliaryProcessMainCommon(), BackgroundWorkerShmemInit(), bootstrap_signals(), BootstrapModeMain(), BTreeShmemInit(), CheckMyDatabase(), CheckRecoveryConsistency(), CommitTsShmemInit(), createdb(), CreateLWLocks(), CreateOrAttachShmemStructs(), 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(), EventTriggerOnLogin(), EventTriggerSQLDrop(), EventTriggerTableRewrite(), ForwardSyncRequest(), get_slru_entry(), GetNewMultiXactId(), GetNewTransactionId(), GetQuitSignalReason(), init_ps_display(), InitAuxiliaryProcess(), InitializeLatchWaitSet(), InitializeSessionUserId(), InitializeSessionUserIdStandalone(), InitializeWaitEventSupport(), InitPostgres(), InitPostmasterChild(), InitProcess(), InitSync(), InjectionPointShmemInit(), LockBufferInternal(), LWLockAcquire(), MaintainLatestCompletedXidRecovery(), MultiXactShmemInit(), parallel_vacuum_compute_workers(), PerformRecoveryXLogAction(), PerformWalRecovery(), pg_get_shmem_pagesize(), pgaio_io_wait(), pgaio_worker_needs_synchronous_execution(), PGSemaphoreCreate(), PGSharedMemoryNoReAttach(), PGSharedMemoryReAttach(), pgss_shmem_startup(), pgstat_fetch_entry(), pgstat_read_statsfile(), pgstat_report_autovac(), pgstat_report_recovery_conflict(), pgstat_shutdown_hook(), pgstat_wal_flush_cb(), pgstat_write_statsfile(), plan_create_index_workers(), PostgresMain(), PostgresSingleUserMain(), postmaster_child_launch(), PredicateLockShmemInit(), process_postgres_switches(), process_settings(), ProcessConfigFile(), ProcessConfigFileInternal(), ProcessStartupProcInterrupts(), ReadRecord(), readRecoverySignalFile(), RegisterBackgroundWorker(), RegisterDynamicBackgroundWorker(), ReplicationSlotAcquire(), SendPostmasterSignal(), SerialInit(), set_config_sourcefile(), set_config_with_handle(), SetMultiXactIdLimit(), SetTransactionIdLimit(), ShmemInitStruct(), SimpleLruInit(), standard_planner(), start_xact_command(), StatsShmemInit(), superuser_arg(), SyncScanShmemInit(), test_slru_shmem_startup(), TwoPhaseShmemInit(), UpdateLogicalDecodingStatusEndOfRecovery(), vacuum_delay_point(), VarsupShmemInit(), verify_dictoptions(), WaitLatch(), WaitLatchOrSocket(), XLogArchiveNotify(), XLogPageRead(), XLogPrefetchIncrement(), XLogRecGetFullXid(), XLogShutdownWalRcv(), and XLogWrite().
|
extern |
Definition at line 1783 of file miscinit.c.
Referenced by process_session_preload_libraries().
|
extern |
Definition at line 41 of file globals.c.
Referenced by HandleLogMemoryContextInterrupt(), ProcessAutoVacLauncherInterrupts(), ProcessCheckpointerInterrupts(), ProcessInterrupts(), ProcessLogMemoryContextInterrupt(), ProcessMainLoopInterrupts(), ProcessPgArchInterrupts(), ProcessStartupProcInterrupts(), and ProcessWalSummarizerInterrupts().
|
extern |
Definition at line 133 of file globals.c.
Referenced by _brin_leader_participate_as_worker(), _brin_parallel_build_main(), _bt_leader_participate_as_worker(), _bt_parallel_build_main(), _bt_spools_heapscan(), _gin_leader_participate_as_worker(), _gin_parallel_build_main(), _h_spoolinit(), brinbuild(), bt_check_every_level(), dead_items_alloc(), ginbuild(), 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 134 of file globals.c.
Referenced by parallel_vacuum_compute_workers(), and plan_create_index_workers().
|
extern |
Definition at line 145 of file globals.c.
Referenced by RegisterDynamicBackgroundWorker().
|
extern |
Definition at line 26 of file stack_depth.c.
Referenced by check_stack_depth().
|
extern |
Definition at line 144 of file globals.c.
Referenced by BackgroundWorkerShmemInit(), BackgroundWorkerShmemSize(), BackgroundWorkerStateChange(), CheckRequiredParameterValues(), ForgetBackgroundWorker(), ForgetUnstartedBackgroundWorkers(), GetBackgroundWorkerPid(), InitControlFile(), InitializeMaxBackends(), InitPostmasterChildSlots(), InitProcGlobal(), RegisterBackgroundWorker(), ReportBackgroundWorkerExit(), ReportBackgroundWorkerPID(), TerminateBackgroundWorker(), and XLogReportParameters().
|
extern |
Definition at line 146 of file globals.c.
Referenced by AioChooseMaxConcurrency(), AioProcs(), AsyncShmemInit(), AsyncShmemSize(), BTreeShmemInit(), BTreeShmemSize(), DeadLockCheckRecurse(), dsm_postmaster_startup(), ExpandConstraints(), FastPathLockShmemSize(), FindLockCycleRecurse(), FindLockCycleRecurseMember(), GetBlockerStatusData(), GetLockConflicts(), GetLockStatusData(), GetSerializableTransactionSnapshotInt(), GetSingleProcBlockerStatusData(), InitBufferManagerAccess(), InitDeadLockChecking(), InitializeMaxBackends(), InitProcGlobal(), pg_safe_snapshot_blocking_pids(), PGProcShmemSize(), pgstat_get_backend_current_activity(), pgstat_get_crashed_backend_activity(), PreCommit_Notify(), predicatelock_twophase_recover(), PredicateLockShmemInit(), PredicateLockShmemSize(), ProcGlobalSemas(), TestConfiguration(), WaitForLSN(), WaitLSNShmemInit(), and WaitLSNShmemSize().
|
extern |
Definition at line 143 of file globals.c.
Referenced by CheckRequiredParameterValues(), InitControlFile(), InitializeMaxBackends(), InitPostmasterChildSlots(), InitProcGlobal(), ListenServerPort(), PostmasterMain(), and XLogReportParameters().
|
extern |
Definition at line 62 of file miscinit.c.
|
extern |
Definition at line 162 of file globals.c.
Referenced by MultiXactShmemInit(), and MultiXactShmemSize().
|
extern |
Definition at line 163 of file globals.c.
Referenced by MultiXactShmemInit(), and MultiXactShmemSize().
|
extern |
Definition at line 81 of file globals.c.
Referenced by adjust_data_dir(), get_configdata(), get_doc_path(), get_etc_path(), get_extension_control_directories(), 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(), main(), make_relative_path(), ParseTzFile(), pg_bindtextdomain(), pg_config(), pg_TZDIR(), PostmasterMain(), process_psqlrc(), and set_pglocale_pgservice().
|
extern |
Definition at line 64 of file miscinit.c.
Referenced by AutoVacLauncherMain(), AutoVacWorkerMain(), BackgroundWorkerMain(), BackgroundWriterMain(), CheckpointerMain(), CreateRestartPoint(), get_backend_type_for_log(), init_ps_display(), InitStandaloneProcess(), InvalidatePossiblyObsoleteSlot(), IoWorkerMain(), pgaio_init_backend(), pgaio_worker_error_callback(), PgArchiverMain(), pgstat_bestart_final(), pgstat_bestart_initial(), pgstat_count_backend_io_op(), pgstat_count_backend_io_op_time(), pgstat_count_io_op(), pgstat_flush_backend(), pgstat_io_flush_cb(), pgstat_should_report_connstat(), pgstat_write_statsfile(), PostgresMain(), ProcessStartupPacket(), ReplSlotSyncWorkerMain(), send_message_to_server_log(), standard_ProcessUtility(), StartupProcessMain(), SysLoggerMain(), WalReceiverMain(), WalSummarizerMain(), WalWriterMain(), write_csvlog(), and write_jsonlog().
|
extern |
Definition at line 52 of file globals.c.
Referenced by InitPostgres(), and PostgresMain().
|
extern |
Definition at line 53 of file globals.c.
Referenced by InitPostgres(), and PostgresMain().
|
extern |
Definition at line 98 of file globals.c.
Referenced by EventTriggerOnLogin(), and InitPostgres().
|
extern |
Definition at line 94 of file globals.c.
Referenced by AfterTriggerSetState(), AlterDatabase(), AlterObjectRename_internal(), AlterPublicationOwner_internal(), AlterSchemaOwner_internal(), AlterSubscription(), AlterSubscriptionOwner(), AlterSubscriptionOwner_internal(), ApplyPendingListenActions(), asyncQueueNotificationToEntry(), asyncQueueProcessPageEntries(), ATExecDetachPartition(), AutoVacuumRequestWork(), BecomeRegisteredListener(), CacheInvalidateCatalog(), CacheInvalidateHeapTupleCommon(), CacheInvalidateRelcache(), CacheInvalidateRelcacheByTuple(), CacheInvalidateRelSync(), check_default_table_access_method(), check_default_tablespace(), check_default_text_search_config(), check_temp_tablespaces(), CheckLogicalDecodingRequirements(), CheckMyDatabase(), checkSharedDependencies(), checkTempNamespaceStatus(), classIdGetDbId(), CleanupListenersOnExit(), ComputeXidHorizons(), ConditionalLockDatabaseObject(), create_pg_locale_builtin(), create_pg_locale_icu(), create_pg_locale_libc(), CreateDecodingContext(), CreateInitDecodingContext(), CreatePublication(), CreateSchemaCommand(), CreateSubscription(), current_database(), database_to_xml_internal(), DeconstructQualifiedName(), do_analyze_rel(), do_autovacuum(), dropdb(), DropSubscription(), EventTriggerOnLogin(), exec_object_restorecon(), exec_replication_command(), ExecuteTruncateGuts(), ExpandColumnRefStar(), ExportSnapshot(), extension_is_trusted(), find_funcstat_entry(), find_tabstat_entry(), get_subscription_oid(), GetCurrentVirtualXIDs(), GetNewRelFileNumber(), GetOldestActiveTransactionId(), GetRunningTransactionData(), heap_inplace_update_and_unlock(), heap_vacuum_rel(), IdentifySystem(), ImportSnapshot(), init_database_collation(), initialize_acl(), InitializeParallelDSM(), InitPostgres(), InitTempTableNamespace(), InitWalSender(), 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_ext(), pg_relation_filepath(), pg_stat_reset_single_function_counters(), pg_stat_reset_single_table_counters(), pgss_store(), pgstat_bestart_final(), 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_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(), pgstat_update_parallel_workers_stats(), PostgresMain(), PrepareTableEntriesForListen(), PrepareToInvalidateCacheTuple(), PrepareTransaction(), ProcArrayInstallImportedXmin(), ProcArrayInstallRestoredXmin(), RangeVarCallbackForStats(), RangeVarGetAndCheckCreationNamespace(), RangeVarGetCreationNamespace(), RangeVarGetRelidExtended(), read_stream_begin_impl(), ReindexMultipleTables(), RelationInitLockInfo(), RelationInitPhysicalAddr(), RelationMapFinishBootstrap(), RenameDatabase(), RenameSchema(), ReplicationSlotCreate(), roles_is_member_of(), ScanPgRelation(), SearchSysCacheLocked1(), sepgsql_schema_post_create(), SetDatabaseHasLoginEventTriggers(), SetLocktagRelationOid(), shdepDropOwned(), shdepReassignOwned(), SignalBackends(), transformColumnRef(), TwoPhaseGetOldestXidInCommit(), UnlockApplyTransactionForSession(), UnlockDatabaseObject(), UpdateLogicalMappings(), vac_truncate_clog(), vac_update_datfrozenxid(), vacuum_is_permitted_for_relation(), XactLogAbortRecord(), and XactLogCommitRecord().
|
extern |
Definition at line 96 of file globals.c.
Referenced by AlterTableMoveAll(), ATPrepSetTableSpace(), calculate_tablespace_size(), check_temp_tablespaces(), CheckRelationTableSpaceMove(), DefineIndex(), DefineRelation(), ExecReindex(), FileSetInit(), get_tablespace(), get_tablespace_location(), GetDefaultTablespace(), GetNewRelFileNumber(), heap_create(), heap_inplace_update_and_unlock(), InitPostgres(), LogStandbyInvalidations(), OpenTemporaryFile(), perform_relmap_update(), pg_relation_filepath(), PrepareTempTablespaces(), ReindexMultipleInternal(), RelationInitPhysicalAddr(), RelationMapFinishBootstrap(), RelidByRelfilenumber(), SetRelationTableSpace(), XactLogAbortRecord(), and XactLogCommitRecord().
|
extern |
Definition at line 63 of file globals.c.
Referenced by ApplyLauncherMain(), autoprewarm_main(), AutoVacLauncherMain(), avl_sigusr2_handler(), BackgroundWriterMain(), CheckDeadLockAlert(), CheckpointerMain(), CheckpointWriteDelay(), ClientCheckTimeoutHandler(), ConditionVariableTimedSleep(), ConfigurePostmasterWaitSet(), copy_read_data(), die(), do_pg_backup_stop(), ExecAppendAsyncEventWait(), 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(), IoWorkerMain(), lazy_truncate_heap(), libpqsrv_cancel(), libpqsrv_connect_internal(), libpqsrv_get_result(), LogicalParallelApplyLoop(), logicalrep_worker_stop_internal(), LogicalRepApplyLoop(), mq_putmessage(), pa_send_data(), pa_wait_for_xact_state(), pg_promote(), pg_sleep(), pg_wait_until_termination(), pgaio_worker_die(), pgaio_worker_register(), pgarch_MainLoop(), pgarch_waken_stop(), pgfdw_get_cleanup_result(), pq_check_connection(), pq_init(), ProcessClientReadInterrupt(), ProcessClientWriteInterrupt(), ProcessPendingWrites(), procsignal_sigusr1_handler(), ProcSleep(), ProcWaitForSignal(), ReqShutdownXLOG(), secure_read(), secure_write(), ServerLoop(), shm_mq_receive_bytes(), shm_mq_send_bytes(), shm_mq_wait_internal(), ShutDownSlotSync(), SignalHandlerForConfigReload(), SignalHandlerForShutdownRequest(), sigUsr1Handler(), StatementCancelHandler(), summarizer_wait_for_wal(), SwitchBackToLocalLatch(), SwitchToSharedLatch(), SyncRepWaitForLSN(), SysLoggerMain(), test_shm_mq_pipelined(), throttle(), TransactionTimeoutHandler(), wait_for_slot_activity(), wait_for_table_state_change(), wait_for_worker_state_change(), wait_for_workers_to_become_ready(), WaitForBackgroundWorkerShutdown(), WaitForBackgroundWorkerStartup(), WaitForLSN(), WaitForParallelWorkersToAttach(), WaitForParallelWorkersToFinish(), WaitForReplicationWorkerAttach(), WalRcvWaitForStartPosition(), WalReceiverMain(), WalSndLastCycleHandler(), WalSndLoop(), WalSndWaitForWal(), WalWriterMain(), and worker_spi_main().
|
extern |
Definition at line 54 of file globals.c.
Referenced by MarkPostmasterChildInactive(), MarkPostmasterChildWalSender(), postmaster_child_launch(), and RegisterPostmasterChildActive().
|
extern |
Definition at line 47 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(), ATExecMergePartitions(), ATExecSplitPartition(), autoprewarm_main(), AutoVacLauncherMain(), basic_archive_file(), BecomeRegisteredListener(), CheckpointerMain(), CleanupListenersOnExit(), CleanupProcSignalState(), DisownLatch(), ExportSnapshot(), FileSetInit(), fork_process(), get_backend_type_for_log(), GetSerializableTransactionSnapshotInt(), HandleWalSndInitStopping(), InitAuxiliaryProcess(), initialize_prng(), InitializeParallelDSM(), InitializeWaitEventSupport(), InitLatch(), InitPostmasterDeathWatchHandle(), InitProcess(), InitProcessGlobals(), InitWalSenderSlot(), injection_point_allowed(), injection_points_attach(), InvalidatePossiblyObsoleteSlot(), IsLogicalLauncher(), LaunchParallelWorkers(), llvm_compile_module(), LockAcquireExtended(), LockTimeoutHandler(), log_status_format(), logicalrep_worker_launch(), main(), ModifyWaitEvent(), OpenTemporaryFileInTablespace(), OwnLatch(), pg_backend_pid(), pgstat_bestart_initial(), PostgresMain(), PostmasterMain(), proc_exit(), process_pgfdw_appname(), ProcessLogMemoryContextInterrupt(), ProcSignalInit(), ProcSleep(), ReplicationSlotAcquire(), ReplicationSlotCleanup(), ReplicationSlotCreate(), ReplicationSlotsDropDBSlots(), replorigin_session_reset(), replorigin_session_reset_internal(), replorigin_session_setup(), ReplSlotSyncWorkerMain(), ResetLatch(), ServerLoop(), SetLatch(), setup_background_workers(), SharedInvalBackendInit(), SignalBackends(), SnapBuildSerialize(), StatementTimeoutHandler(), SyncReplicationSlots(), WakeupMyProc(), WalRcvDie(), WalReceiverMain(), worker_spi_launch(), write_csvlog(), write_jsonlog(), write_pipe_chunks(), and write_relcache_init_file().
|
extern |
Definition at line 51 of file globals.c.
Referenced by appendSCRAMKeysInfo(), assign_tcp_keepalives_count(), assign_tcp_keepalives_idle(), assign_tcp_keepalives_interval(), assign_tcp_user_timeout(), BackendInitialize(), BackendMain(), check_conn_params(), connect_pg_server(), dblink_connstr_check(), dblink_connstr_has_required_scram_options(), dblink_security_check(), get_connect_string(), inet_client_addr(), inet_client_port(), inet_server_addr(), inet_server_port(), InitPostgres(), internal_flush_buffer(), log_disconnections(), log_status_format(), pgfdw_has_required_scram_options(), pgfdw_security_check(), pgstat_bestart_initial(), pgstat_bestart_security(), PostgresMain(), pq_getbyte_if_available(), pq_recvbuf(), process_pgfdw_appname(), scram_exchange(), 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(), validate_token(), write_csvlog(), and write_jsonlog().
|
extern |
Definition at line 48 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 49 of file globals.c.
Referenced by InitProcessGlobals(), log_disconnections(), pgstat_bestart_initial(), and pgstat_report_connect().
|
extern |
|
extern |
Definition at line 164 of file globals.c.
Referenced by AsyncShmemInit(), and AsyncShmemSize().
|
extern |
Definition at line 79 of file globals.c.
Referenced by BootstrapModeMain(), DebugFileOpen(), and process_postgres_switches().
|
extern |
Definition at line 82 of file globals.c.
Referenced by add_module_to_inline_search_path(), expand_dynamic_library_name(), getInstallationPaths(), InitStandaloneProcess(), llvm_create_types(), load_module(), and provider_init().
|
extern |
Definition at line 106 of file globals.c.
Referenced by get_backend_type_for_log(), InitPostmasterDeathWatchHandle(), pg_promote(), pg_reload_conf(), PostmasterMain(), SendPostmasterSignal(), and xlog_redo().
|
extern |
Definition at line 34 of file globals.c.
Referenced by die(), proc_exit_prepare(), ProcessClientReadInterrupt(), ProcessClientWriteInterrupt(), ProcessInterrupts(), and SyncRepWaitForLSN().
|
extern |
Definition at line 1787 of file miscinit.c.
Referenced by check_wal_consistency_checking(), InitializeWalConsistencyChecking(), and process_shared_preload_libraries().
|
extern |
Definition at line 1786 of file miscinit.c.
Referenced by _PG_init(), apw_start_leader_worker(), init_custom_variable(), pgstat_register_kind(), process_shared_preload_libraries(), RegisterBackgroundWorker(), and RegisterCustomRmgr().
|
extern |
Definition at line 1790 of file miscinit.c.
Referenced by process_shmem_requests(), RequestAddinShmemSpace(), and RequestNamedLWLockTranche().
|
extern |
Definition at line 40 of file globals.c.
Referenced by BufferSync(), CheckpointWriteDelay(), HandleProcSignalBarrierInterrupt(), ProcessAutoVacLauncherInterrupts(), ProcessCheckpointerInterrupts(), ProcessInterrupts(), ProcessMainLoopInterrupts(), ProcessPgArchInterrupts(), ProcessProcSignalBarrier(), ProcessStartupProcInterrupts(), ProcessWalSummarizerInterrupts(), and ResetProcSignalBarrierBits().
|
extern |
Definition at line 44 of file globals.c.
Referenced by errfinish(), ProcessInterrupts(), and ProcessRecoveryConflictInterrupt().
|
extern |
Definition at line 33 of file globals.c.
Referenced by AutoVacLauncherMain(), do_autovacuum(), perform_work_item(), PostgresMain(), proc_exit_prepare(), ProcessInterrupts(), StatementCancelHandler(), and SyncRepWaitForLSN().
|
extern |
Definition at line 165 of file globals.c.
Referenced by PredicateLockShmemSize(), and SerialInit().
|
extern |
Definition at line 1781 of file miscinit.c.
Referenced by process_session_preload_libraries().
|
extern |
Definition at line 1782 of file miscinit.c.
Referenced by process_shared_preload_libraries().
|
extern |
Definition at line 1789 of file miscinit.c.
Referenced by _PG_init(), and process_shmem_requests().
|
extern |
Definition at line 166 of file globals.c.
Referenced by SUBTRANSShmemBuffers(), and SUBTRANSShmemInit().
|
extern |
Definition at line 167 of file globals.c.
Referenced by CLOGShmemBuffers(), and CLOGShmemInit().
|
extern |
Definition at line 38 of file globals.c.
Referenced by ProcessInterrupts(), and TransactionTimeoutHandler().
|
extern |
Definition at line 149 of file globals.c.
Referenced by do_autovacuum(), and ExecVacuum().
|
extern |
Definition at line 158 of file globals.c.
Referenced by AsyncReadBuffers(), lazy_check_wraparound_failsafe(), MarkBufferDirty(), MarkBufferDirtyHint(), PinBufferForBlock(), vacuum(), vacuum_delay_point(), and VacuumUpdateCosts().
|
extern |
Definition at line 157 of file globals.c.
Referenced by AsyncReadBuffers(), compute_parallel_delay(), lazy_check_wraparound_failsafe(), MarkBufferDirty(), MarkBufferDirtyHint(), parallel_vacuum_main(), parallel_vacuum_process_all_indexes(), PinBufferForBlock(), vacuum(), vacuum_delay_point(), and VacuumUpdateCosts().
|
extern |
Definition at line 155 of file globals.c.
Referenced by VacuumUpdateCosts().
|
extern |
Definition at line 154 of file globals.c.
Referenced by AutoVacuumUpdateCostLimit(), and VacuumUpdateCosts().
|
extern |
Definition at line 153 of file globals.c.
Referenced by MarkBufferDirty(), and MarkBufferDirtyHint().
|
extern |
Definition at line 151 of file globals.c.
Referenced by AsyncReadBuffers(), and PinBufferForBlock().
|
extern |
Definition at line 152 of file globals.c.
Referenced by AsyncReadBuffers().
|
extern |
Definition at line 131 of file globals.c.
Referenced by _bt_parallel_scan_and_sort(), _bt_pendingfsm_init(), _bt_spools_heapscan(), adjust_foreign_grouping_path_cost(), array_sort_internal(), collectMatchBitmap(), compute_bitmap_pages(), connectby(), cost_append(), cost_material(), cost_rescan(), create_groupingsets_path(), create_incremental_sort_path(), create_merge_append_path(), create_sort_path(), CreateWorkExprContext(), crosstab(), exec_init_tuple_store(), ExecIncrementalSort(), ExecInitCteScan(), ExecInitRecursiveUnion(), ExecMakeTableFunctionResult(), ExecMaterial(), ExecSort(), final_cost_mergejoin(), get_crosstab_tuplestore(), get_hash_memory_limit(), GetCurrentFDWTuplestore(), ginInsertCleanup(), hash_create_memory(), initial_cost_mergejoin(), initialize_aggregate(), initialize_phase(), InitMaterializedSRF(), label_incrementalsort_with_costsize(), label_sort_with_costsize(), libpqrcv_processTuples(), MakeTransitionCaptureState(), materializeQueryResult(), materializeResult(), MultiExecBitmapIndexScan(), MultiExecBitmapOr(), ordered_set_startup(), plperl_return_next_internal(), pltcl_init_tuple_store(), populate_recordset_worker(), PortalCreateHoldStore(), postquel_start(), prepare_tuplestore(), roles_list_append(), storeRow(), switchToPresortedPrefixMode(), and tfuncFetchRows().