|
PostgreSQL Source Code git master
|
#include "postgres.h"#include "common/file_perm.h"#include "libpq/libpq-be.h"#include "libpq/pqcomm.h"#include "miscadmin.h"#include "postmaster/postmaster.h"#include "storage/procnumber.h"#include "storage/procsignal.h"
Go to the source code of this file.
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().
| volatile sig_atomic_t CheckClientConnectionPending = false |
Definition at line 35 of file globals.c.
Referenced by ClientCheckTimeoutHandler(), and ProcessInterrupts().
| volatile sig_atomic_t ClientConnectionLost = false |
Definition at line 36 of file globals.c.
Referenced by internal_flush_buffer(), and ProcessInterrupts().
| int commit_timestamp_buffers = 0 |
Definition at line 161 of file globals.c.
Referenced by CommitTsShmemBuffers(), and CommitTsShmemInit().
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().
| int data_directory_mode = PG_DIR_MODE_OWNER |
Definition at line 77 of file globals.c.
Referenced by checkDataDir(), RetrieveDataDirCreatePerm(), and show_data_directory_mode().
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().
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().
| int DateOrder = DATEORDER_MDY |
Definition at line 126 of file globals.c.
Referenced by assign_datestyle(), check_datestyle(), DecodeNumber(), EncodeDateOnly(), and EncodeDateTime().
| int DateStyle = USE_ISO_DATES |
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().
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().
Definition at line 123 of file globals.c.
Referenced by asyncQueueReadAllNotifications(), BeginInternalSubTransaction(), CheckpointerMain(), and errstart().
| ProtocolVersion FrontendProtocol |
Definition at line 30 of file globals.c.
Referenced by BackendInitialize(), pq_redirect_to_shm_mq(), process_postgres_switches(), ProcessStartupPacket(), send_message_to_frontend(), and SendNegotiateProtocolVersion().
| double hash_mem_multiplier = 2.0 |
Definition at line 132 of file globals.c.
Referenced by get_hash_memory_limit().
| volatile sig_atomic_t IdleInTransactionSessionTimeoutPending = false |
Definition at line 37 of file globals.c.
Referenced by IdleInTransactionSessionTimeoutHandler(), and ProcessInterrupts().
| volatile sig_atomic_t IdleSessionTimeoutPending = false |
Definition at line 39 of file globals.c.
Referenced by IdleSessionTimeoutHandler(), and ProcessInterrupts().
| volatile sig_atomic_t IdleStatsUpdateTimeoutPending = false |
Definition at line 42 of file globals.c.
Referenced by IdleStatsUpdateTimeoutHandler(), and ProcessInterrupts().
Definition at line 43 of file globals.c.
Referenced by errfinish(), proc_exit_prepare(), ProcessClientWriteInterrupt(), ProcessInterrupts(), ProcessRecoveryConflictInterrupts(), and SyncRepWaitForLSN().
| volatile sig_atomic_t InterruptPending = false |
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().
| int IntervalStyle = INTSTYLE_POSTGRES |
Definition at line 127 of file globals.c.
Referenced by DecodeInterval(), DecodeInterval(), interval_out(), PGTYPESinterval_to_asc(), and set_transmission_modes().
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().
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().
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().
| volatile sig_atomic_t LogMemoryContextPending = false |
Definition at line 41 of file globals.c.
Referenced by HandleLogMemoryContextInterrupt(), ProcessAutoVacLauncherInterrupts(), ProcessCheckpointerInterrupts(), ProcessInterrupts(), ProcessLogMemoryContextInterrupt(), ProcessMainLoopInterrupts(), ProcessPgArchInterrupts(), ProcessStartupProcInterrupts(), and ProcessWalSummarizerInterrupts().
| int maintenance_work_mem = 65536 |
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().
| int max_parallel_maintenance_workers = 2 |
Definition at line 134 of file globals.c.
Referenced by parallel_vacuum_compute_workers(), and plan_create_index_workers().
| int max_parallel_workers = 8 |
Definition at line 145 of file globals.c.
Referenced by RegisterDynamicBackgroundWorker().
| int max_worker_processes = 8 |
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().
| int MaxBackends = 0 |
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().
| int MaxConnections = 100 |
Definition at line 143 of file globals.c.
Referenced by CheckRequiredParameterValues(), InitControlFile(), InitializeMaxBackends(), InitPostmasterChildSlots(), InitProcGlobal(), ListenServerPort(), PostmasterMain(), and XLogReportParameters().
| int multixact_member_buffers = 32 |
Definition at line 162 of file globals.c.
Referenced by MultiXactShmemInit(), and MultiXactShmemSize().
| int multixact_offset_buffers = 16 |
Definition at line 163 of file globals.c.
Referenced by MultiXactShmemInit(), and MultiXactShmemSize().
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().
| uint8 MyCancelKey[MAX_CANCEL_KEY_LENGTH] |
Definition at line 52 of file globals.c.
Referenced by InitPostgres(), and PostgresMain().
| int MyCancelKeyLength = 0 |
Definition at line 53 of file globals.c.
Referenced by InitPostgres(), and PostgresMain().
| struct ClientSocket* MyClientSocket |
Definition at line 50 of file globals.c.
Referenced by BackendMain(), and postmaster_child_launch().
Definition at line 98 of file globals.c.
Referenced by EventTriggerOnLogin(), and InitPostgres().
| Oid MyDatabaseId = InvalidOid |
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().
| Oid MyDatabaseTableSpace = InvalidOid |
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().
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().
| int MyPMChildSlot |
Definition at line 54 of file globals.c.
Referenced by MarkPostmasterChildInactive(), MarkPostmasterChildWalSender(), postmaster_child_launch(), and RegisterPostmasterChildActive().
| ProcNumber MyProcNumber = INVALID_PROC_NUMBER |
Definition at line 90 of file globals.c.
Referenced by addLSNWaiter(), ApplyPendingListenActions(), asyncQueueReadAllNotifications(), asyncQueueUnregister(), AtEOXact_MultiXact(), AtPrepare_MultiXact(), AuxiliaryProcKill(), BackgroundWriterMain(), BecomeRegisteredListener(), buffer_readv_complete(), buffer_readv_complete_one(), buffer_readv_report(), BufferLockDequeueSelf(), BufferLockQueueSelf(), CheckpointerMain(), CleanupInvalidationState(), CleanupListenersOnExit(), ConditionVariableBroadcast(), ConditionVariableCancelSleep(), ConditionVariablePrepareToSleep(), ConditionVariableTimedSleep(), DebugPrintBufferRefcount(), deleteLSNWaiter(), DropRelationBuffers(), DropRelationsAllBuffers(), FlushLocalBuffer(), GetMultiXactIdMembers(), GetSerializableTransactionSnapshotInt(), InitAuxiliaryProcess(), InitializeParallelDSM(), InitProcess(), InitRecoveryTransactionEnvironment(), InitTempTableNamespace(), InvalidateLocalBuffer(), local_buffer_write_error_callback(), LockBufferForCleanup(), LockGXact(), LWLockDequeueSelf(), LWLockQueueSelf(), MarkAsPreparingGuts(), md_readv_report(), MultiXactIdCreate(), MultiXactIdExpand(), MultiXactIdSetOldestMember(), MultiXactIdSetOldestVisible(), pgaio_init_backend(), pgaio_io_acquire_nb(), pgaio_io_process_completion(), pgaio_io_reclaim(), pgaio_io_wait(), pgaio_worker_error_callback(), pgaio_wref_check_done(), PgArchiverMain(), pgstat_beinit(), pgstat_bestart_final(), pgstat_create_backend(), pgstat_flush_backend(), pgstat_shutdown_hook(), PostPrepare_MultiXact(), PrepareTableEntriesForListen(), ProcKill(), ProcSignalInit(), SharedInvalBackendInit(), SIGetDataEntries(), smgr_aio_describe_identity(), StartTransaction(), TransactionGroupUpdateXidStatus(), UnlockBuffers(), VirtualXactLockTableCleanup(), visibilitymap_set_vmbits(), WaitForLSN(), WaitLSNCleanup(), WALInsertLockAcquire(), WalReceiverMain(), WalSummarizerMain(), and WalWriterMain().
| int MyProcPid |
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().
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().
| pg_time_t MyStartTime |
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().
| TimestampTz MyStartTimestamp |
Definition at line 49 of file globals.c.
Referenced by InitProcessGlobals(), log_disconnections(), pgstat_bestart_initial(), and pgstat_report_connect().
| int NBuffers = 16384 |
Definition at line 142 of file globals.c.
Referenced by AioChooseMaxConcurrency(), apw_dump_now(), apw_load_buffers(), BgBufferSync(), BufferIsValid(), BufferManagerShmemInit(), BufferManagerShmemSize(), BufferSync(), CheckpointerShmemInit(), CheckpointerShmemSize(), ClockSweepTick(), CreateCheckPoint(), DropDatabaseBuffers(), DropRelationBuffers(), DropRelationsAllBuffers(), EvictAllUnpinnedBuffers(), EvictRelUnpinnedBuffers(), FlushDatabaseBuffers(), FlushRelationBuffers(), FlushRelationsAllBuffers(), GetAccessStrategyPinLimit(), GetAccessStrategyWithSize(), hashbuild(), InitBufferManagerAccess(), initscan(), LogCheckpointEnd(), MarkDirtyAllUnpinnedBuffers(), MarkDirtyRelUnpinnedBuffers(), pg_buffercache_evict(), pg_buffercache_mark_dirty(), pg_buffercache_os_pages_internal(), pg_buffercache_pages(), pg_buffercache_summary(), pg_buffercache_usage_counts(), SimpleLruAutotuneBuffers(), StrategyGetBuffer(), StrategyInitialize(), StrategyShmemSize(), StrategySyncStart(), table_block_parallelscan_initialize(), and XLOGChooseNumBuffers().
| int notify_buffers = 16 |
Definition at line 164 of file globals.c.
Referenced by AsyncShmemInit(), and AsyncShmemSize().
Definition at line 79 of file globals.c.
Referenced by BootstrapModeMain(), DebugFileOpen(), and process_postgres_switches().
| ProcNumber ParallelLeaderProcNumber = INVALID_PROC_NUMBER |
Definition at line 92 of file globals.c.
Referenced by ParallelWorkerMain(), and ParallelWorkerShutdown().
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().
| pid_t PostmasterPid = 0 |
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().
| volatile sig_atomic_t ProcDiePending = false |
Definition at line 34 of file globals.c.
Referenced by die(), proc_exit_prepare(), ProcessClientReadInterrupt(), ProcessClientWriteInterrupt(), ProcessInterrupts(), and SyncRepWaitForLSN().
| volatile sig_atomic_t ProcSignalBarrierPending = false |
Definition at line 40 of file globals.c.
Referenced by BufferSync(), CheckpointWriteDelay(), HandleProcSignalBarrierInterrupt(), ProcessAutoVacLauncherInterrupts(), ProcessCheckpointerInterrupts(), ProcessInterrupts(), ProcessMainLoopInterrupts(), ProcessPgArchInterrupts(), ProcessProcSignalBarrier(), ProcessStartupProcInterrupts(), ProcessWalSummarizerInterrupts(), and ResetProcSignalBarrierBits().
Definition at line 44 of file globals.c.
Referenced by errfinish(), ProcessInterrupts(), and ProcessRecoveryConflictInterrupt().
| volatile sig_atomic_t QueryCancelPending = false |
Definition at line 33 of file globals.c.
Referenced by AutoVacLauncherMain(), do_autovacuum(), perform_work_item(), PostgresMain(), proc_exit_prepare(), ProcessInterrupts(), StatementCancelHandler(), and SyncRepWaitForLSN().
| int serializable_buffers = 32 |
Definition at line 165 of file globals.c.
Referenced by PredicateLockShmemSize(), and SerialInit().
| int subtransaction_buffers = 0 |
Definition at line 166 of file globals.c.
Referenced by SUBTRANSShmemBuffers(), and SUBTRANSShmemInit().
| int transaction_buffers = 0 |
Definition at line 167 of file globals.c.
Referenced by CLOGShmemBuffers(), and CLOGShmemInit().
| volatile sig_atomic_t TransactionTimeoutPending = false |
Definition at line 38 of file globals.c.
Referenced by ProcessInterrupts(), and TransactionTimeoutHandler().
| int VacuumBufferUsageLimit = 2048 |
Definition at line 149 of file globals.c.
Referenced by do_autovacuum(), and ExecVacuum().
Definition at line 158 of file globals.c.
Referenced by AsyncReadBuffers(), lazy_check_wraparound_failsafe(), MarkBufferDirty(), MarkBufferDirtyHint(), PinBufferForBlock(), vacuum(), vacuum_delay_point(), and VacuumUpdateCosts().
| int VacuumCostBalance = 0 |
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().
| double VacuumCostDelay = 0 |
Definition at line 155 of file globals.c.
Referenced by VacuumUpdateCosts().
| int VacuumCostLimit = 200 |
Definition at line 154 of file globals.c.
Referenced by AutoVacuumUpdateCostLimit(), and VacuumUpdateCosts().
| int VacuumCostPageDirty = 20 |
Definition at line 153 of file globals.c.
Referenced by MarkBufferDirty(), and MarkBufferDirtyHint().
| int VacuumCostPageHit = 1 |
Definition at line 151 of file globals.c.
Referenced by AsyncReadBuffers(), and PinBufferForBlock().
| int VacuumCostPageMiss = 2 |
Definition at line 152 of file globals.c.
Referenced by AsyncReadBuffers().
| int work_mem = 4096 |
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().