PostgreSQL Source Code
git master
|
#include "access/rmgr.h"
#include "access/xlogdefs.h"
#include "access/xloginsert.h"
#include "access/xlogreader.h"
#include "datatype/timestamp.h"
#include "lib/stringinfo.h"
#include "nodes/pg_list.h"
#include "storage/fd.h"
Go to the source code of this file.
Data Structures | |
struct | CheckpointStatsData |
Typedefs | |
typedef enum ArchiveMode | ArchiveMode |
typedef enum WalLevel | WalLevel |
typedef enum RecoveryState | RecoveryState |
typedef struct CheckpointStatsData | CheckpointStatsData |
typedef enum WALAvailability | WALAvailability |
typedef enum SessionBackupState | SessionBackupState |
#define BACKUP_LABEL_FILE "backup_label" |
Definition at line 389 of file xlog.h.
Referenced by BackupInProgress(), CancelBackup(), do_pg_start_backup(), do_pg_stop_backup(), perform_base_backup(), pg_backup_start_time(), read_backup_label(), and StartupXLOG().
#define BACKUP_LABEL_OLD "backup_label.old" |
Definition at line 390 of file xlog.h.
Referenced by CancelBackup(), and StartupXLOG().
#define CHECKPOINT_CAUSE_TIME 0x0100 /* Elapsed time */ |
Definition at line 233 of file xlog.h.
Referenced by CheckpointerMain(), and LogCheckpointStart().
#define CHECKPOINT_CAUSE_XLOG 0x0080 /* XLOG consumption */ |
Definition at line 232 of file xlog.h.
Referenced by CheckpointerMain(), LogCheckpointStart(), XLogPageRead(), and XLogWrite().
#define CHECKPOINT_END_OF_RECOVERY |
Definition at line 222 of file xlog.h.
Referenced by BufferSync(), CheckpointerMain(), CreateCheckPoint(), LogCheckpointStart(), StartupXLOG(), and update_checkpoint_display().
#define CHECKPOINT_FLUSH_ALL |
Definition at line 226 of file xlog.h.
Referenced by BufferSync(), createdb(), LogCheckpointStart(), and movedb().
#define CHECKPOINT_FORCE 0x0008 /* Force even if no activity */ |
Definition at line 225 of file xlog.h.
Referenced by CreateCheckPoint(), createdb(), do_pg_start_backup(), dropdb(), DropTableSpace(), LogCheckpointStart(), movedb(), standard_ProcessUtility(), and StartupXLOG().
#define CHECKPOINT_IMMEDIATE 0x0004 /* Do it without delays */ |
Definition at line 224 of file xlog.h.
Referenced by CheckpointWriteDelay(), createdb(), do_pg_start_backup(), dropdb(), DropTableSpace(), ImmediateCheckpointRequested(), LogCheckpointStart(), movedb(), RequestCheckpoint(), ShutdownXLOG(), standard_ProcessUtility(), and StartupXLOG().
#define CHECKPOINT_IS_SHUTDOWN 0x0001 /* Checkpoint is for shutdown */ |
Definition at line 221 of file xlog.h.
Referenced by BufferSync(), CreateCheckPoint(), CreateRestartPoint(), LogCheckpointStart(), ShutdownXLOG(), and update_checkpoint_display().
#define CHECKPOINT_REQUESTED 0x0040 /* Checkpoint request has been made */ |
Definition at line 230 of file xlog.h.
Referenced by RequestCheckpoint().
#define CHECKPOINT_WAIT 0x0020 /* Wait for completion */ |
Definition at line 229 of file xlog.h.
Referenced by createdb(), do_pg_start_backup(), dropdb(), DropTableSpace(), LogCheckpointStart(), movedb(), RequestCheckpoint(), standard_ProcessUtility(), and StartupXLOG().
#define InHotStandby (standbyState >= STANDBY_SNAPSHOT_PENDING) |
Definition at line 74 of file xlog.h.
Referenced by btree_xlog_delete(), btree_xlog_reuse_page(), dbase_redo(), GetLockConflicts(), gistRedoDeleteRecord(), gistRedoPageReuse(), hash_xlog_vacuum_one_page(), heap_xlog_clean(), heap_xlog_cleanup_info(), heap_xlog_freeze_page(), heap_xlog_visible(), LockBufferForCleanup(), ProcSleep(), RecoverPreparedTransactions(), ResolveRecoveryConflictWithBufferPin(), ResolveRecoveryConflictWithLock(), and spgRedoVacuumRedirect().
#define PROMOTE_SIGNAL_FILE "promote" |
Definition at line 396 of file xlog.h.
Referenced by CheckPromoteSignal(), pg_promote(), and RemovePromoteSignalFiles().
#define RECOVERY_SIGNAL_FILE "recovery.signal" |
Definition at line 387 of file xlog.h.
Referenced by exitArchiveRecovery(), and readRecoverySignalFile().
#define STANDBY_SIGNAL_FILE "standby.signal" |
Definition at line 388 of file xlog.h.
Referenced by exitArchiveRecovery(), and readRecoverySignalFile().
#define SYNC_METHOD_FDATASYNC 1 |
Definition at line 26 of file xlog.h.
Referenced by get_sync_bit(), and issue_xlog_fsync().
#define SYNC_METHOD_FSYNC 0 |
Definition at line 25 of file xlog.h.
Referenced by get_sync_bit(), and issue_xlog_fsync().
#define SYNC_METHOD_FSYNC_WRITETHROUGH 3 |
Definition at line 28 of file xlog.h.
Referenced by get_sync_bit(), issue_xlog_fsync(), and pg_fsync().
#define SYNC_METHOD_OPEN 2 /* for O_SYNC */ |
Definition at line 27 of file xlog.h.
Referenced by get_sync_bit(), issue_xlog_fsync(), and XLogWrite().
#define SYNC_METHOD_OPEN_DSYNC 4 /* for O_DSYNC */ |
Definition at line 29 of file xlog.h.
Referenced by get_sync_bit(), issue_xlog_fsync(), and XLogWrite().
#define TABLESPACE_MAP "tablespace_map" |
Definition at line 392 of file xlog.h.
Referenced by CancelBackup(), do_pg_start_backup(), do_pg_stop_backup(), perform_base_backup(), read_tablespace_map(), and StartupXLOG().
#define TABLESPACE_MAP_OLD "tablespace_map.old" |
Definition at line 393 of file xlog.h.
Referenced by CancelBackup(), and StartupXLOG().
#define XLOG_INCLUDE_ORIGIN 0x01 /* include the replication origin */ |
Definition at line 238 of file xlog.h.
Referenced by EndPrepare(), ExecuteTruncateGuts(), heap_delete(), heap_finish_speculative(), heap_insert(), heap_multi_insert(), log_heap_update(), LogLogicalMessage(), XactLogAbortRecord(), XactLogCommitRecord(), and XLogRecordAssemble().
#define XLOG_INCLUDE_XID 0x04 /* include XID of top-level xact */ |
Definition at line 240 of file xlog.h.
Referenced by XLogRecordAssemble(), and XLogResetInsertion().
#define XLOG_MARK_UNIMPORTANT 0x02 /* record not important for durability */ |
Definition at line 239 of file xlog.h.
Referenced by gistXLogAssignLSN(), LogAccessExclusiveLocks(), LogCurrentRunningXacts(), RequestXLogSwitch(), and XLogInsertRecord().
#define XLogArchiveCommandSet | ( | ) | (XLogArchiveCommand[0] != '\0') |
Definition at line 185 of file xlog.h.
Referenced by pgarch_ArchiverCopyLoop(), and ShutdownXLOG().
#define XLogArchivingActive | ( | ) | (AssertMacro(XLogArchiveMode == ARCHIVE_MODE_OFF || wal_level >= WAL_LEVEL_REPLICA), XLogArchiveMode > ARCHIVE_MODE_OFF) |
Definition at line 180 of file xlog.h.
Referenced by do_pg_stop_backup(), pgarch_start(), show_archive_command(), ShutdownXLOG(), StartupXLOG(), writeTimeLineHistory(), XLogArchiveCheckDone(), and XLogWrite().
#define XLogArchivingAlways | ( | ) | (AssertMacro(XLogArchiveMode == ARCHIVE_MODE_OFF || wal_level >= WAL_LEVEL_REPLICA), XLogArchiveMode == ARCHIVE_MODE_ALWAYS) |
Definition at line 183 of file xlog.h.
Referenced by do_pg_stop_backup(), sigusr1_handler(), and XLogArchiveCheckDone().
#define XLogHintBitIsNeeded | ( | ) | (DataChecksumsEnabled() || wal_log_hints) |
Definition at line 202 of file xlog.h.
Referenced by BufferGetLSNAtomic(), FreeSpaceMapPrepareTruncateRel(), log_heap_visible(), MarkBufferDirtyHint(), visibilitymap_prepare_truncate(), and visibilitymap_set().
#define XLogIsNeeded | ( | ) | (wal_level >= WAL_LEVEL_REPLICA) |
Definition at line 191 of file xlog.h.
Referenced by do_pg_start_backup(), do_pg_stop_backup(), get_sync_bit(), pg_create_restore_point(), RelationCopyStorage(), RelationCreateStorage(), vacuum_log_cleanup_info(), XLogFileClose(), and XLogReportParameters().
#define XLogLogicalInfoActive | ( | ) | (wal_level >= WAL_LEVEL_LOGICAL) |
Definition at line 208 of file xlog.h.
Referenced by AssignTransactionId(), CommandEndInvalidationMessages(), ExecuteTruncateGuts(), IsSubTransactionAssignmentPending(), RecordTransactionCommit(), XactLogAbortRecord(), and XactLogCommitRecord().
#define XLogStandbyInfoActive | ( | ) | (wal_level >= WAL_LEVEL_REPLICA) |
Definition at line 205 of file xlog.h.
Referenced by _bt_delitems_delete_check(), _bt_getbuf(), AssignTransactionId(), BackgroundWriterMain(), CreateCheckPoint(), gistNewBuffer(), gistprunepage(), LockAcquireExtended(), LogStandbySnapshot(), RecordTransactionCommit(), and UpdateFullPageWrites().
typedef enum ArchiveMode ArchiveMode |
typedef struct CheckpointStatsData CheckpointStatsData |
typedef enum RecoveryState RecoveryState |
typedef enum SessionBackupState SessionBackupState |
typedef enum WALAvailability WALAvailability |
enum ArchiveMode |
Enumerator | |
---|---|
ARCHIVE_MODE_OFF | |
ARCHIVE_MODE_ON | |
ARCHIVE_MODE_ALWAYS |
enum HotStandbyState |
enum RecoveryState |
Enumerator | |
---|---|
RECOVERY_STATE_CRASH | |
RECOVERY_STATE_ARCHIVE | |
RECOVERY_STATE_DONE |
enum RecoveryTargetType |
Enumerator | |
---|---|
RECOVERY_TARGET_UNSET | |
RECOVERY_TARGET_XID | |
RECOVERY_TARGET_TIME | |
RECOVERY_TARGET_NAME | |
RECOVERY_TARGET_LSN | |
RECOVERY_TARGET_IMMEDIATE |
enum SessionBackupState |
Enumerator | |
---|---|
SESSION_BACKUP_NONE | |
SESSION_BACKUP_EXCLUSIVE | |
SESSION_BACKUP_NON_EXCLUSIVE |
enum WALAvailability |
Enumerator | |
---|---|
WALAVAIL_INVALID_LSN | |
WALAVAIL_RESERVED | |
WALAVAIL_EXTENDED | |
WALAVAIL_UNRESERVED | |
WALAVAIL_REMOVED |
Definition at line 271 of file xlog.h.
enum WalLevel |
Enumerator | |
---|---|
WAL_LEVEL_MINIMAL | |
WAL_LEVEL_REPLICA | |
WAL_LEVEL_LOGICAL |
void assign_checkpoint_completion_target | ( | double | newval, |
void * | extra | ||
) |
Definition at line 2343 of file xlog.c.
References CalculateCheckpointSegments(), CheckPointCompletionTarget, and newval.
void assign_max_wal_size | ( | int | newval, |
void * | extra | ||
) |
Definition at line 2336 of file xlog.c.
References CalculateCheckpointSegments(), max_wal_size_mb, and newval.
void BootStrapXLOG | ( | void | ) |
Definition at line 5224 of file xlog.c.
References AdvanceOldestClogXid(), Assert, BootStrapCLOG(), BootStrapCommitTs(), BootStrapMultiXact(), BootStrapSUBTRANS(), ControlFileData::checkPoint, ControlFileData::checkPointCopy, close, COMP_CRC32C, ereport, errcode_for_file_access(), errmsg(), FIN_CRC32C, FirstBootstrapObjectId, FirstMultiXactId, FirstNormalTransactionId, CheckPoint::fullPageWrites, fullPageWrites, FullTransactionIdFromEpochAndXid(), gettimeofday(), INIT_CRC32C, InitControlFile(), InvalidTransactionId, MultiXactSetNextMXact(), CheckPoint::newestCommitTsXid, CheckPoint::nextMulti, CheckPoint::nextMultiOffset, CheckPoint::nextOid, VariableCacheData::nextOid, CheckPoint::nextXid, VariableCacheData::nextXid, offsetof, VariableCacheData::oidCount, CheckPoint::oldestActiveXid, CheckPoint::oldestCommitTsXid, CheckPoint::oldestMulti, CheckPoint::oldestMultiDB, CheckPoint::oldestXid, CheckPoint::oldestXidDB, openLogFile, palloc(), PANIC, pfree(), pg_fsync(), pgstat_report_wait_end(), pgstat_report_wait_start(), CheckPoint::PrevTimeLineID, ReadControlFile(), CheckPoint::redo, SetCommitTsLimit(), SetMultiXactIdLimit(), SetTransactionIdLimit(), ShmemVariableCache, SizeOfXLogLongPHD, SizeOfXLogRecord, SizeOfXLogRecordDataHeaderShort, CheckPoint::ThisTimeLineID, ThisTimeLineID, CheckPoint::time, ControlFileData::time, TYPEALIGN, WAIT_EVENT_WAL_BOOTSTRAP_SYNC, WAIT_EVENT_WAL_BOOTSTRAP_WRITE, wal_segment_size, write, WriteControlFile(), XLogRecord::xl_info, XLogRecord::xl_prev, XLogRecord::xl_rmid, XLogRecord::xl_tot_len, XLogRecord::xl_xid, XLOG_CHECKPOINT_SHUTDOWN, XLOG_PAGE_MAGIC, XLogFileInit(), XLogPageHeaderData::xlp_info, XLP_LONG_HEADER, XLogPageHeaderData::xlp_magic, XLogPageHeaderData::xlp_pageaddr, XLogLongPageHeaderData::xlp_seg_size, XLogLongPageHeaderData::xlp_sysid, XLogPageHeaderData::xlp_tli, XLogLongPageHeaderData::xlp_xlog_blcksz, and XLR_BLOCK_ID_DATA_SHORT.
Referenced by AuxiliaryProcessMain().
XLogRecPtr CalculateMaxmumSafeLSN | ( | void | ) |
bool CheckPromoteSignal | ( | void | ) |
Definition at line 12798 of file xlog.c.
References PROMOTE_SIGNAL_FILE, and stat.
Referenced by CheckForStandbyTrigger(), and sigusr1_handler().
void CheckXLogRemoved | ( | XLogSegNo | segno, |
TimeLineID | tli | ||
) |
Definition at line 3956 of file xlog.c.
References ereport, errcode_for_file_access(), errmsg(), ERROR, filename, XLogCtlData::info_lck, XLogCtlData::lastRemovedSegNo, MAXFNAMELEN, SpinLockAcquire, SpinLockRelease, wal_segment_size, and XLogFileName.
Referenced by logical_read_xlog_page(), perform_base_backup(), and XLogSendPhysical().
void CreateCheckPoint | ( | int | flags | ) |
Definition at line 8830 of file xlog.c.
References ControlFileData::checkPoint, CHECKPOINT_END_OF_RECOVERY, CHECKPOINT_FORCE, CHECKPOINT_IS_SHUTDOWN, ControlFileData::checkPointCopy, CheckPointGuts(), CheckpointStatsData::ckpt_bufs_written, CheckpointStatsData::ckpt_segs_added, CheckpointStatsData::ckpt_segs_recycled, CheckpointStatsData::ckpt_segs_removed, CheckpointStatsData::ckpt_start_t, XLogCtlData::ckptFullXid, XLogCtlInsert::CurrBytePos, DB_SHUTDOWNED, DB_SHUTDOWNING, DEBUG1, elog, END_CRIT_SECTION, ereport, errmsg(), ERROR, CheckPoint::fullPageWrites, XLogCtlInsert::fullPageWrites, GetCurrentTimestamp(), GetLastImportantRecPtr(), GetOldestActiveTransactionId(), GetOldestTransactionIdConsideredRunning(), GetVirtualXIDsDelayingChkpt(), HaveVirtualXIDsDelayingChkpt(), XLogCtlData::info_lck, InitXLogInsert(), Insert(), XLogCtlData::Insert, INSERT_FREESPACE, InvalidateObsoleteReplicationSlots(), InvalidTransactionId, InvalidXLogRecPtr, KeepLogSeg(), LocalSetXLogInsertAllowed(), LocalXLogInsertAllowed, log_checkpoints, LogCheckpointEnd(), LogCheckpointStart(), LogStandbySnapshot(), LW_EXCLUSIVE, LW_SHARED, LWLockAcquire(), LWLockRelease(), MemSet, ControlFileData::minRecoveryPoint, ControlFileData::minRecoveryPointTLI, MultiXactGetCheckptMulti(), NBuffers, CheckPoint::newestCommitTsXid, VariableCacheData::newestCommitTsXid, CheckPoint::nextMulti, CheckPoint::nextMultiOffset, CheckPoint::nextOid, VariableCacheData::nextOid, CheckPoint::nextXid, VariableCacheData::nextXid, VariableCacheData::oidCount, CheckPoint::oldestActiveXid, CheckPoint::oldestCommitTsXid, VariableCacheData::oldestCommitTsXid, CheckPoint::oldestMulti, CheckPoint::oldestMultiDB, CheckPoint::oldestXid, VariableCacheData::oldestXid, CheckPoint::oldestXidDB, VariableCacheData::oldestXidDB, PANIC, pfree(), pg_usleep(), PreallocXlogFiles(), CheckPoint::PrevTimeLineID, XLogCtlData::PrevTimeLineID, ProcLastRecPtr, RecoveryInProgress(), CheckPoint::redo, RedoRecPtr, XLogCtlInsert::RedoRecPtr, XLogCtlData::RedoRecPtr, RemoveOldXlogFiles(), ShmemVariableCache, SizeOfXLogLongPHD, SizeOfXLogShortPHD, SpinLockAcquire, SpinLockRelease, START_CRIT_SECTION, ControlFileData::state, SyncPostCheckpoint(), SyncPreCheckpoint(), CheckPoint::ThisTimeLineID, ThisTimeLineID, CheckPoint::time, ControlFileData::time, TruncateSUBTRANS(), XLogCtlData::ulsn_lck, ControlFileData::unloggedLSN, XLogCtlData::unloggedLSN, update_checkpoint_display(), UpdateCheckPointDistanceEstimate(), UpdateControlFile(), wal_segment_size, WALInsertLockAcquireExclusive(), WALInsertLockRelease(), XLByteToSeg, XLOG_CHECKPOINT_ONLINE, XLOG_CHECKPOINT_SHUTDOWN, XLogBeginInsert(), XLogBytePosToRecPtr(), XLogFlush(), XLogInsert(), XLogRegisterData(), XLogSegmentOffset, and XLogStandbyInfoActive.
Referenced by CheckpointerMain(), RequestCheckpoint(), ShutdownXLOG(), and StartupXLOG().
bool CreateRestartPoint | ( | int | flags | ) |
Definition at line 9389 of file xlog.c.
References archiveCleanupCommand, ControlFileData::checkPoint, CHECKPOINT_IS_SHUTDOWN, ControlFileData::checkPointCopy, CheckPointGuts(), CheckpointStatsData::ckpt_start_t, DB_IN_ARCHIVE_RECOVERY, DB_SHUTDOWNED_IN_RECOVERY, DEBUG2, EnableHotStandby, ereport, errdetail(), errmsg(), ExecuteRecoveryCommand(), GetCurrentTimestamp(), GetLatestXTime(), GetOldestTransactionIdConsideredRunning(), GetWalRcvFlushRecPtr(), GetXLogReplayRecPtr(), XLogCtlData::info_lck, XLogCtlData::Insert, InvalidateObsoleteReplicationSlots(), InvalidXLogRecPtr, KeepLogSeg(), XLogCtlData::lastCheckPoint, XLogCtlData::lastCheckPointEndPtr, XLogCtlData::lastCheckPointRecPtr, LOG, log_checkpoints, LogCheckpointEnd(), LogCheckpointStart(), LW_EXCLUSIVE, LWLockAcquire(), LWLockRelease(), MemSet, ControlFileData::minRecoveryPoint, minRecoveryPoint, ControlFileData::minRecoveryPointTLI, minRecoveryPointTLI, PreallocXlogFiles(), RecoveryInProgress(), CheckPoint::redo, RedoRecPtr, XLogCtlInsert::RedoRecPtr, XLogCtlData::RedoRecPtr, RemoveOldXlogFiles(), SpinLockAcquire, SpinLockRelease, ControlFileData::state, CheckPoint::ThisTimeLineID, ThisTimeLineID, ControlFileData::time, timestamptz_to_str(), TruncateSUBTRANS(), update_checkpoint_display(), UpdateCheckPointDistanceEstimate(), UpdateControlFile(), UpdateMinRecoveryPoint(), wal_segment_size, WALInsertLockAcquireExclusive(), WALInsertLockRelease(), XLByteToSeg, and XLogRecPtrIsInvalid.
Referenced by CheckpointerMain(), and ShutdownXLOG().
bool DataChecksumsEnabled | ( | void | ) |
Definition at line 4961 of file xlog.c.
References Assert, and ControlFileData::data_checksum_version.
Referenced by PageIsVerifiedExtended(), PageSetChecksumCopy(), PageSetChecksumInplace(), pg_stat_get_db_checksum_failures(), pg_stat_get_db_checksum_last_failure(), ReadControlFile(), and sendFile().
void do_pg_abort_backup | ( | int | code, |
Datum | arg | ||
) |
Definition at line 11590 of file xlog.c.
References Assert, DatumGetBool, ereport, errmsg(), EXCLUSIVE_BACKUP_NONE, XLogCtlInsert::exclusiveBackupState, XLogCtlInsert::forcePageWrites, XLogCtlData::Insert, XLogCtlInsert::nonExclusiveBackups, SESSION_BACKUP_NON_EXCLUSIVE, sessionBackupState, WALInsertLockAcquireExclusive(), WALInsertLockRelease(), and WARNING.
Referenced by perform_base_backup(), and register_persistent_abort_backup_handler().
XLogRecPtr do_pg_start_backup | ( | const char * | backupidstr, |
bool | fast, | ||
TimeLineID * | starttli_p, | ||
StringInfo | labelfile, | ||
List ** | tablespaces, | ||
StringInfo | tblspcmapfile, | ||
bool | needtblspcmapfile | ||
) |
Definition at line 10659 of file xlog.c.
References AllocateDir(), AllocateFile(), appendStringInfo(), appendStringInfoChar(), BACKUP_LABEL_FILE, backup_started_in_recovery, BoolGetDatum, ControlFileData::checkPoint, CHECKPOINT_FORCE, CHECKPOINT_IMMEDIATE, CHECKPOINT_WAIT, ControlFileData::checkPointCopy, dirent::d_name, StringInfoData::data, DataDir, ereport, errcode(), errcode_for_file_access(), errhint(), errmsg(), ERROR, EXCLUSIVE_BACKUP_IN_PROGRESS, EXCLUSIVE_BACKUP_NONE, EXCLUSIVE_BACKUP_STARTING, XLogCtlInsert::exclusiveBackupState, XLogCtlInsert::forcePageWrites, FreeDir(), FreeFile(), CheckPoint::fullPageWrites, XLogCtlData::info_lck, initStringInfo(), XLogCtlData::Insert, IS_DIR_SEP, lappend(), XLogCtlInsert::lastBackupStart, XLogCtlData::lastFpwDisableRecPtr, StringInfoData::len, log_timezone, LW_SHARED, LWLockAcquire(), LWLockRelease(), makeStringInfo(), MAXFNAMELEN, MAXPGPATH, XLogCtlInsert::nonExclusiveBackups, tablespaceinfo::oid, palloc(), tablespaceinfo::path, pfree(), PG_END_ENSURE_ERROR_CLEANUP, PG_ENSURE_ERROR_CLEANUP, pg_fsync(), pg_localtime(), pg_start_backup_callback(), pg_strftime(), pstrdup(), ReadDir(), readlink, RecoveryInProgress(), CheckPoint::redo, relpath, RequestCheckpoint(), RequestXLogSwitch(), tablespaceinfo::rpath, SESSION_BACKUP_EXCLUSIVE, SESSION_BACKUP_NON_EXCLUSIVE, sessionBackupState, tablespaceinfo::size, snprintf, SpinLockAcquire, SpinLockRelease, stat, TABLESPACE_MAP, CheckPoint::ThisTimeLineID, wal_segment_size, WALInsertLockAcquireExclusive(), WALInsertLockRelease(), WARNING, XLByteToSeg, XLogFileName, and XLogIsNeeded.
Referenced by perform_base_backup(), and pg_start_backup().
XLogRecPtr do_pg_stop_backup | ( | char * | labelfile, |
bool | waitforarchive, | ||
TimeLineID * | stoptli_p | ||
) |
Definition at line 11177 of file xlog.c.
References AllocateFile(), Assert, BACKUP_LABEL_FILE, backup_started_in_recovery, BackupHistoryFileName, BackupHistoryFilePath, BoolGetDatum, CHECK_FOR_INTERRUPTS, CleanupBackupHistory(), DEBUG1, durable_unlink(), ereport, errcode(), errcode_for_file_access(), errhint(), errmsg(), ERROR, EXCLUSIVE_BACKUP_IN_PROGRESS, EXCLUSIVE_BACKUP_NONE, EXCLUSIVE_BACKUP_STOPPING, XLogCtlInsert::exclusiveBackupState, XLogCtlInsert::forcePageWrites, fprintf, FreeFile(), XLogCtlData::info_lck, XLogCtlData::Insert, XLogCtlData::lastFpwDisableRecPtr, log_timezone, LW_SHARED, LWLockAcquire(), LWLockRelease(), MAXFNAMELEN, MAXPGPATH, ControlFileData::minRecoveryPoint, ControlFileData::minRecoveryPointTLI, XLogCtlInsert::nonExclusiveBackups, NOTICE, palloc(), PG_END_ENSURE_ERROR_CLEANUP, PG_ENSURE_ERROR_CLEANUP, pg_localtime(), pg_stop_backup_callback(), pg_strftime(), pg_usleep(), pgstat_report_wait_end(), pgstat_report_wait_start(), RecoveryInProgress(), remaining, RequestXLogSwitch(), SESSION_BACKUP_NONE, sessionBackupState, SpinLockAcquire, SpinLockRelease, stat::st_size, stat, TABLESPACE_MAP, ThisTimeLineID, WAIT_EVENT_BACKUP_WAIT_WAL_ARCHIVE, wal_segment_size, WALInsertLockAcquireExclusive(), WALInsertLockRelease(), WARNING, XLByteToPrevSeg, XLByteToSeg, XLOG_BACKUP_END, XLogArchiveIsBusy(), XLogArchivingActive, XLogArchivingAlways, XLogBeginInsert(), XLogFileName, XLogInsert(), XLogIsNeeded, and XLogRegisterData().
Referenced by perform_base_backup(), pg_stop_backup(), and pg_stop_backup_v2().
SessionBackupState get_backup_status | ( | void | ) |
Definition at line 11156 of file xlog.c.
References sessionBackupState.
Referenced by pg_start_backup(), pg_stop_backup(), and pg_stop_backup_v2().
TimestampTz GetCurrentChunkReplayStartTime | ( | void | ) |
Definition at line 6228 of file xlog.c.
References XLogCtlData::currentChunkStartTime, XLogCtlData::info_lck, SpinLockAcquire, and SpinLockRelease.
Referenced by GetReplicationApplyDelay().
XLogRecPtr GetFakeLSNForUnloggedRel | ( | void | ) |
Definition at line 4977 of file xlog.c.
References SpinLockAcquire, SpinLockRelease, XLogCtlData::ulsn_lck, and XLogCtlData::unloggedLSN.
Referenced by gistGetFakeLSN().
XLogRecPtr GetFlushRecPtr | ( | void | ) |
Definition at line 8500 of file xlog.c.
References XLogwrtResult::Flush, XLogCtlData::info_lck, XLogCtlData::LogwrtResult, SpinLockAcquire, and SpinLockRelease.
Referenced by get_flush_position(), IdentifySystem(), pg_current_wal_flush_lsn(), pg_logical_slot_get_changes_guts(), pg_replication_slot_advance(), read_local_xlog_page(), StartReplication(), WalSndWaitForWal(), XLogSendLogical(), and XLogSendPhysical().
void GetFullPageWriteInfo | ( | XLogRecPtr * | RedoRecPtr_p, |
bool * | doPageWrites_p | ||
) |
Definition at line 8469 of file xlog.c.
References doPageWrites, and RedoRecPtr.
Referenced by XLogCheckBufferNeedsBackup(), and XLogInsert().
XLogRecPtr GetInsertRecPtr | ( | void | ) |
Definition at line 8484 of file xlog.c.
References XLogCtlData::info_lck, XLogCtlData::LogwrtRqst, SpinLockAcquire, SpinLockRelease, and XLogwrtRqst::Write.
Referenced by CheckpointerMain(), gistvacuumscan(), and IsCheckpointOnSchedule().
XLogRecPtr GetLastImportantRecPtr | ( | void | ) |
Definition at line 8518 of file xlog.c.
References i, InvalidXLogRecPtr, WALInsertLockPadded::l, WALInsertLock::lastImportantAt, LW_EXCLUSIVE, LWLockAcquire(), LWLockRelease(), and NUM_XLOGINSERT_LOCKS.
Referenced by BackgroundWriterMain(), CheckArchiveTimeout(), and CreateCheckPoint().
TimestampTz GetLatestXTime | ( | void | ) |
Definition at line 6198 of file xlog.c.
References XLogCtlData::info_lck, XLogCtlData::recoveryLastXTime, SpinLockAcquire, and SpinLockRelease.
Referenced by CreateRestartPoint(), pg_last_xact_replay_timestamp(), and StartupXLOG().
char* GetMockAuthenticationNonce | ( | void | ) |
Definition at line 4951 of file xlog.c.
References Assert, and ControlFileData::mock_authentication_nonce.
Referenced by scram_mock_salt().
RecoveryState GetRecoveryState | ( | void | ) |
Definition at line 8201 of file xlog.c.
References XLogCtlData::info_lck, XLogCtlData::SharedRecoveryState, SpinLockAcquire, and SpinLockRelease.
Referenced by XLogArchiveCheckDone().
XLogRecPtr GetRedoRecPtr | ( | void | ) |
Definition at line 8440 of file xlog.c.
References XLogCtlData::info_lck, RedoRecPtr, XLogCtlData::RedoRecPtr, SpinLockAcquire, and SpinLockRelease.
Referenced by CheckPointLogicalRewriteHeap(), CheckPointSnapBuild(), InitXLOGAccess(), nextval_internal(), ReplicationSlotReserveWal(), XLogPageRead(), XLogSaveBufferForHint(), and XLogWrite().
uint64 GetSystemIdentifier | ( | void | ) |
Definition at line 4941 of file xlog.c.
References Assert, and ControlFileData::system_identifier.
Referenced by IdentifySystem(), and WalReceiverMain().
WALAvailability GetWALAvailability | ( | XLogRecPtr | targetLSN | ) |
Definition at line 9660 of file xlog.c.
References ConvertToXSegs, GetXLogWriteRecPtr(), KeepLogSeg(), max_wal_size_mb, wal_segment_size, WALAVAIL_EXTENDED, WALAVAIL_INVALID_LSN, WALAVAIL_REMOVED, WALAVAIL_RESERVED, WALAVAIL_UNRESERVED, XLByteToSeg, XLogGetLastRemovedSegno(), and XLogRecPtrIsInvalid.
Referenced by pg_get_replication_slots().
XLogRecPtr GetXLogInsertRecPtr | ( | void | ) |
Definition at line 11657 of file xlog.c.
References XLogCtlInsert::CurrBytePos, Insert(), XLogCtlData::Insert, XLogCtlInsert::insertpos_lck, SpinLockAcquire, SpinLockRelease, and XLogBytePosToRecPtr().
Referenced by GetSnapshotDataInitOldSnapshot(), gistGetFakeLSN(), logical_begin_heap_rewrite(), pg_current_wal_insert_lsn(), and ReplicationSlotReserveWal().
void GetXLogReceiptTime | ( | TimestampTz * | rtime, |
bool * | fromStream | ||
) |
Definition at line 6244 of file xlog.c.
References Assert, InRecovery, XLOG_FROM_STREAM, XLogReceiptSource, and XLogReceiptTime.
Referenced by GetStandbyLimitTime().
XLogRecPtr GetXLogReplayRecPtr | ( | TimeLineID * | replayTLI | ) |
Definition at line 11638 of file xlog.c.
References XLogCtlData::info_lck, XLogCtlData::lastReplayedEndRecPtr, XLogCtlData::lastReplayedTLI, SpinLockAcquire, and SpinLockRelease.
Referenced by CheckpointerMain(), CreateRestartPoint(), GetReplicationApplyDelay(), GetStandbyFlushRecPtr(), IsCheckpointOnSchedule(), pg_last_wal_replay_lsn(), pg_logical_slot_get_changes_guts(), pg_replication_slot_advance(), read_local_xlog_page(), WalReceiverMain(), WalSndWaitForWal(), and XLogWalRcvSendReply().
XLogRecPtr GetXLogWriteRecPtr | ( | void | ) |
Definition at line 11673 of file xlog.c.
References XLogCtlData::info_lck, XLogCtlData::LogwrtResult, SpinLockAcquire, SpinLockRelease, and XLogwrtResult::Write.
Referenced by GetWALAvailability(), pg_attribute_noreturn(), pg_current_wal_lsn(), and pg_get_replication_slots().
bool HotStandbyActive | ( | void | ) |
Definition at line 8222 of file xlog.c.
References XLogCtlData::info_lck, LocalHotStandbyActive, XLogCtlData::SharedHotStandbyActive, SpinLockAcquire, and SpinLockRelease.
Referenced by XLogWalRcvSendHSFeedback().
bool HotStandbyActiveInReplay | ( | void | ) |
Definition at line 8247 of file xlog.c.
References AmStartupProcess, Assert, IsPostmasterEnvironment, and LocalHotStandbyActive.
void InitXLOGAccess | ( | void | ) |
Definition at line 8414 of file xlog.c.
References Assert, doPageWrites, XLogCtlInsert::forcePageWrites, XLogCtlInsert::fullPageWrites, GetRedoRecPtr(), InitXLogInsert(), Insert(), XLogCtlData::Insert, IsBootstrapProcessingMode, ThisTimeLineID, XLogCtlData::ThisTimeLineID, wal_segment_size, and ControlFileData::xlog_seg_size.
Referenced by AuxiliaryProcessMain(), LocalSetXLogInsertAllowed(), and RecoveryInProgress().
void issue_xlog_fsync | ( | int | fd, |
XLogSegNo | segno | ||
) |
Definition at line 10566 of file xlog.c.
References _, elog, ereport, errcode_for_file_access(), errmsg(), MAXFNAMELEN, PANIC, pg_fdatasync(), pg_fsync_no_writethrough(), pg_fsync_writethrough(), pgstat_report_wait_end(), pgstat_report_wait_start(), sync_method, SYNC_METHOD_FDATASYNC, SYNC_METHOD_FSYNC, SYNC_METHOD_FSYNC_WRITETHROUGH, SYNC_METHOD_OPEN, SYNC_METHOD_OPEN_DSYNC, ThisTimeLineID, WAIT_EVENT_WAL_SYNC, wal_segment_size, and XLogFileName.
Referenced by XLogWalRcvFlush(), and XLogWrite().
void LocalProcessControlFile | ( | bool | reset | ) |
Definition at line 5061 of file xlog.c.
References Assert, palloc(), and ReadControlFile().
Referenced by BackendRun(), PostgresMain(), PostmasterMain(), and PostmasterStateMachine().
bool PromoteIsTriggered | ( | void | ) |
Definition at line 12717 of file xlog.c.
References XLogCtlData::info_lck, LocalPromoteIsTriggered, XLogCtlData::SharedPromoteIsTriggered, SpinLockAcquire, and SpinLockRelease.
Referenced by pg_wal_replay_pause(), and pg_wal_replay_resume().
bool RecoveryInProgress | ( | void | ) |
Definition at line 8148 of file xlog.c.
References InitXLOGAccess(), LocalRecoveryInProgress, pg_memory_barrier, RECOVERY_STATE_DONE, XLogCtlData::SharedRecoveryState, and XLogCtl.
Referenced by BackgroundWriterMain(), BeginReportingGUCOptions(), brin_desummarize_range(), brin_summarize_range(), btree_index_mainfork_expected(), check_transaction_read_only(), check_XactIsoLevel(), CheckArchiveTimeout(), CheckLogicalDecodingRequirements(), CheckpointerMain(), ComputeXidHorizons(), CreateCheckPoint(), CreateEndOfRecoveryRecord(), CreateRestartPoint(), do_pg_start_backup(), do_pg_stop_backup(), error_commit_ts_disabled(), get_relation_info(), GetNewMultiXactId(), GetNewObjectId(), GetNewTransactionId(), GetOldestActiveTransactionId(), GetOldestSafeDecodingTransactionId(), GetRunningTransactionData(), GetSerializableTransactionSnapshot(), GetSerializableTransactionSnapshotInt(), GetSnapshotData(), gin_clean_pending_list(), GlobalVisTestFor(), heap_force_common(), heap_page_prune_opt(), IdentifySystem(), InitPostgres(), InitTempTableNamespace(), IsCheckpointOnSchedule(), LockAcquireExtended(), MaintainLatestCompletedXid(), MarkBufferDirtyHint(), perform_base_backup(), pg_create_restore_point(), pg_current_wal_flush_lsn(), pg_current_wal_insert_lsn(), pg_current_wal_lsn(), pg_is_in_recovery(), pg_is_wal_replay_paused(), pg_logical_slot_get_changes_guts(), pg_promote(), pg_replication_slot_advance(), pg_switch_wal(), pg_wal_replay_pause(), pg_wal_replay_resume(), pg_walfile_name(), pg_walfile_name_offset(), PrepareRedoAdd(), PrepareRedoRemove(), PreventCommandDuringRecovery(), ProcSendSignal(), ProcSleep(), read_local_xlog_page(), ReplicationSlotReserveWal(), replorigin_check_prerequisites(), ReportChangedGUCOptions(), sendDir(), SerialSetActiveSerXmin(), show_in_hot_standby(), ShutdownXLOG(), SnapBuildWaitSnapshot(), standard_ProcessUtility(), StartLogicalReplication(), StartTransaction(), TransactionIdIsInProgress(), TruncateMultiXact(), UpdateFullPageWrites(), WalReceiverMain(), WalSndWaitForWal(), XLogBackgroundFlush(), XLogInsertAllowed(), XLogNeedsFlush(), and XLogSendPhysical().
bool RecoveryIsPaused | ( | void | ) |
Definition at line 6068 of file xlog.c.
References XLogCtlData::info_lck, XLogCtlData::recoveryPause, SpinLockAcquire, and SpinLockRelease.
Referenced by pg_is_wal_replay_paused(), recoveryPausesHere(), and RecoveryRequiresIntParameter().
void register_persistent_abort_backup_handler | ( | void | ) |
Definition at line 11622 of file xlog.c.
References before_shmem_exit(), DatumGetBool, and do_pg_abort_backup().
Referenced by pg_start_backup().
void RemovePromoteSignalFiles | ( | void | ) |
Definition at line 12789 of file xlog.c.
References PROMOTE_SIGNAL_FILE.
Referenced by CheckForStandbyTrigger(), and PostmasterMain().
void SetRecoveryPause | ( | bool | recoveryPause | ) |
Definition at line 6080 of file xlog.c.
References XLogCtlData::info_lck, XLogCtlData::recoveryPause, SpinLockAcquire, and SpinLockRelease.
Referenced by pg_wal_replay_pause(), pg_wal_replay_resume(), RecoveryRequiresIntParameter(), and StartupXLOG().
void SetWalWriterSleeping | ( | bool | sleeping | ) |
Definition at line 12822 of file xlog.c.
References XLogCtlData::info_lck, SpinLockAcquire, SpinLockRelease, and XLogCtlData::WalWriterSleeping.
Referenced by WalWriterMain().
void ShutdownXLOG | ( | int | code, |
Datum | arg | ||
) |
Definition at line 8564 of file xlog.c.
References Assert, AuxProcessResourceOwner, CHECKPOINT_IMMEDIATE, CHECKPOINT_IS_SHUTDOWN, CreateCheckPoint(), CreateRestartPoint(), CurrentResourceOwner, ereport, errmsg(), IsPostmasterEnvironment, LOG, NOTICE, RecoveryInProgress(), RequestXLogSwitch(), WalSndInitStopping(), WalSndWaitStopping(), XLogArchiveCommandSet, and XLogArchivingActive.
Referenced by HandleCheckpointerInterrupts(), and InitPostgres().
void StartupRequestWalReceiverRestart | ( | void | ) |
Definition at line 12666 of file xlog.c.
References currentSource, ereport, errmsg(), LOG, pendingWalRcvRestart, WalRcvRunning(), and XLOG_FROM_STREAM.
Referenced by StartupRereadConfig().
void StartupXLOG | ( | void | ) |
Definition at line 6377 of file xlog.c.
References AdvanceNextFullTransactionIdPastXid(), AdvanceOldestClogXid(), AllowCascadeReplication, appendStringInfo(), appendStringInfoString(), ArchiveRecoveryRequested, ErrorContextCallback::arg, Assert, AuxProcessResourceOwner, BACKUP_LABEL_FILE, BACKUP_LABEL_OLD, ControlFileData::backupEndPoint, ControlFileData::backupEndRequired, ControlFileData::backupStartPoint, bgwriterLaunched, buf, ErrorContextCallback::callback, ControlFileData::checkPoint, CHECKPOINT_END_OF_RECOVERY, CHECKPOINT_FORCE, CHECKPOINT_IMMEDIATE, CHECKPOINT_WAIT, ControlFileData::checkPointCopy, CheckRecoveryConsistency(), CheckRequiredParameterValues(), checkTimeLineSwitch(), checkXLogConsistency(), XLogCtlData::ckptFullXid, close, CompleteCommitTsInitialization(), CreateCheckPoint(), CreateEndOfRecoveryRecord(), XLogCtlInsert::CurrBytePos, XLogCtlData::currentChunkStartTime, CurrentResourceOwner, StringInfoData::data, DataDir, DB_IN_ARCHIVE_RECOVERY, DB_IN_CRASH_RECOVERY, DB_IN_PRODUCTION, DB_SHUTDOWNED, DB_SHUTDOWNED_IN_RECOVERY, DB_SHUTDOWNING, DEBUG1, DEBUG2, DEBUG3, DeleteAllExportedSnapshotFiles(), DisownLatch(), doPageWrites, doRequestWalReceiverReply, durable_rename(), elog, EnableHotStandby, EnableSyncRequestForwarding(), EndRecPtr, ereport, errcode(), errcode_for_file_access(), errdetail(), errhint(), errmsg(), errmsg_internal(), ERROR, error_context_stack, ExecuteRecoveryCommand(), exitArchiveRecovery(), FATAL, findNewestTimeLine(), FirstNormalUnloggedLSN, XLogwrtRqst::Flush, XLogwrtResult::Flush, CheckPoint::fullPageWrites, XLogCtlInsert::fullPageWrites, FullTransactionIdRetreat(), GetCurrentTimestamp(), GetLatestXTime(), HandleStartupProcInterrupts(), InArchiveRecovery, XLogCtlData::info_lck, XLogCtlData::InitializedUpTo, InitRecoveryTransactionEnvironment(), initStringInfo(), InRecovery, InRedo, Insert(), XLogCtlData::Insert, InvalidXLogRecPtr, IsPostmasterEnvironment, IsUnderPostmaster, lastFullPageWrites, LastRec, XLogCtlData::lastReplayedEndRecPtr, XLogCtlData::lastReplayedTLI, XLogCtlData::lastSegSwitchLSN, XLogCtlData::lastSegSwitchTime, RunningTransactionsData::latestCompletedXid, VariableCacheData::latestCompletedXid, lfirst, LocalPromoteIsTriggered, LocalSetXLogInsertAllowed(), LocalXLogInsertAllowed, LOG, XLogCtlData::LogwrtResult, LogwrtResult, XLogCtlData::LogwrtRqst, LW_EXCLUSIVE, LWLockAcquire(), LWLockRelease(), MAXFNAMELEN, MAXPGPATH, MemSet, ControlFileData::minRecoveryPoint, minRecoveryPoint, ControlFileData::minRecoveryPointTLI, minRecoveryPointTLI, MultiXactSetNextMXact(), CheckPoint::newestCommitTsXid, CheckPoint::nextMulti, CheckPoint::nextMultiOffset, CheckPoint::nextOid, VariableCacheData::nextOid, CheckPoint::nextXid, RunningTransactionsData::nextXid, VariableCacheData::nextXid, NIL, NOTICE, tablespaceinfo::oid, VariableCacheData::oidCount, CheckPoint::oldestActiveXid, CheckPoint::oldestCommitTsXid, CheckPoint::oldestMulti, CheckPoint::oldestMultiDB, RunningTransactionsData::oldestRunningXid, CheckPoint::oldestXid, CheckPoint::oldestXidDB, OwnLatch(), XLogCtlData::pages, palloc(), PANIC, tablespaceinfo::path, pfree(), pg_rusage_init(), pg_rusage_show(), pg_usleep(), pgstat_reset_all(), PMSIGNAL_RECOVERY_STARTED, PreallocXlogFiles(), PrescanPreparedTransactions(), XLogCtlInsert::PrevBytePos, ErrorContextCallback::previous, CheckPoint::PrevTimeLineID, xl_end_of_recovery::PrevTimeLineID, XLogCtlData::PrevTimeLineID, primary_image_masked, proc_exit(), ProcArrayApplyRecoveryInfo(), ProcArrayInitRecovery(), psprintf(), PublishStartupProcessInformation(), reachedConsistency, read_backup_label(), read_tablespace_map(), XLogReaderState::readBuf, ReadCheckpointRecord(), readFile, readOff, ReadRecord(), readRecoverySignalFile(), ReadRecPtr, RecordKnownAssignedTransactionIds(), RecoverPreparedTransactions(), RECOVERY_STATE_ARCHIVE, RECOVERY_STATE_CRASH, RECOVERY_STATE_DONE, RECOVERY_TARGET_ACTION_PAUSE, RECOVERY_TARGET_ACTION_PROMOTE, RECOVERY_TARGET_ACTION_SHUTDOWN, RECOVERY_TARGET_IMMEDIATE, RECOVERY_TARGET_LSN, RECOVERY_TARGET_NAME, RECOVERY_TARGET_TIME, RECOVERY_TARGET_UNSET, RECOVERY_TARGET_XID, recoveryApplyDelay(), recoveryEndCommand, XLogCtlData::recoveryLastXTime, XLogCtlData::recoveryPause, recoveryPausesHere(), recoveryStopAfter, recoveryStopLSN, recoveryStopName, recoveryStopsAfter(), recoveryStopsBefore(), recoveryStopTime, recoveryStopXid, recoveryTarget, recoveryTargetAction, recoveryTargetLSN, recoveryTargetName, recoveryTargetTime, recoveryTargetTLI, recoveryTargetXid, XLogCtlData::recoveryWakeupLatch, CheckPoint::redo, RedoRecPtr, XLogCtlInsert::RedoRecPtr, XLogCtlData::RedoRecPtr, RedoStartLSN, RelationCacheInitFileRemove(), remove_tablespace_symlink(), RemoveNonParentXlogFiles(), RemoveTempXlogFiles(), replay_image_masked, XLogCtlData::replayEndRecPtr, XLogCtlData::replayEndTLI, RequestCheckpoint(), ResetUnloggedRelations(), restoreTimeLineHistoryFiles(), restoreTwoPhaseData(), RmgrData::rm_cleanup, RM_MAX_ID, RmgrData::rm_redo, rm_redo_error_callback(), RmgrData::rm_startup, RmgrTable, XLogReaderState::seg, SendPostmasterSignal(), SetCommitTsLimit(), SetMultiXactIdLimit(), SetRecoveryPause(), SetTransactionIdLimit(), XLogCtlData::SharedRecoveryState, ShmemVariableCache, ShutdownRecoveryTransactionEnvironment(), ShutdownWalRcv(), snprintf, SpinLockAcquire, SpinLockRelease, STANDBY_DISABLED, STANDBY_INITIALIZED, StandbyMode, StandbyModeRequested, StandbyRecoverPreparedTransactions(), standbyState, StartupCLOG(), StartupCommitTs(), StartupMultiXact(), StartupReorderBuffer(), StartupReplicationOrigin(), StartupReplicationSlots(), StartupSUBTRANS(), stat, ControlFileData::state, str_time(), RunningTransactionsData::subxcnt, RunningTransactionsData::subxid_overflow, symlink, SyncDataDirectory(), ControlFileData::system_identifier, XLogReaderState::system_identifier, TABLESPACE_MAP, TABLESPACE_MAP_OLD, CheckPoint::ThisTimeLineID, ThisTimeLineID, xl_end_of_recovery::ThisTimeLineID, XLogCtlData::ThisTimeLineID, CheckPoint::time, ControlFileData::time, timestamptz_to_str(), tliOfPointInHistory(), tliSwitchPoint(), trace_recovery_messages, ControlFileData::track_commit_timestamp, TransactionIdIsNormal, TransactionIdIsValid, TransactionIdRetreat, TrimCLOG(), TrimMultiXact(), U64FromFullTransactionId, UINT64_FORMAT, UNLOGGED_RELATION_CLEANUP, UNLOGGED_RELATION_INIT, ControlFileData::unloggedLSN, XLogCtlData::unloggedLSN, UpdateControlFile(), UpdateFullPageWrites(), validateRecoveryParameters(), ValidateXLOGDirectoryStructure(), wal_segment_close(), wal_segment_size, WalRcvForceReply(), WalRcvStreaming(), WalSndWakeup(), XLogwrtRqst::Write, XLogwrtResult::Write, writeTimeLineHistory(), WALOpenSegment::ws_tli, RunningTransactionsData::xcnt, XidFromFullTransactionId, RunningTransactionsData::xids, XLogRecord::xl_info, XLogRecord::xl_rmid, XL_ROUTINE, XLogRecord::xl_xid, XLogCtlData::xlblocks, XLByteToPrevSeg, XLOG_CHECKPOINT_SHUTDOWN, XLOG_END_OF_RECOVERY, xlog_outdesc(), XLogArchiveCleanup(), XLogArchiveIsReadyOrDone(), XLogArchiveNotify(), XLogArchivingActive, XLogBeginRead(), XLOGDIR, XLogFileName, XLogFilePath, XLogPageRead(), xlogreader, XLogReaderAllocate(), XLogReaderFree(), XLogReceiptTime, XLogRecGetData, XLogRecPtrIsInvalid, XLogRecPtrToBufIdx, XLogRecPtrToBytePos(), XLogReportParameters(), XLogSegmentOffset, XLR_CHECK_CONSISTENCY, XLR_INFO_MASK, and XRecOffIsValid.
Referenced by InitPostgres(), and StartupProcessMain().