首页 > 数据库 >PostgreSQL数据库所有的等待事件

PostgreSQL数据库所有的等待事件

时间:2022-11-28 14:34:40浏览次数:42  
标签:WAL PostgreSQL read data 数据库 write Waiting file 等待

Wait Event TypeWait Event NameDescription
LWLock ShmemIndexLock Waiting to find or allocate space in shared memory.
OidGenLock Waiting to allocate or assign an OID.
XidGenLock Waiting to allocate or assign a transaction id.
ProcArrayLock Waiting to get a snapshot or clearing a transaction id at transaction end.
SInvalReadLock Waiting to retrieve or remove messages from shared invalidation queue.
SInvalWriteLock Waiting to add a message in shared invalidation queue.
WALBufMappingLock Waiting to replace a page in WAL buffers.
WALWriteLock Waiting for WAL buffers to be written to disk.
ControlFileLock Waiting to read or update the control file or creation of a new WAL file.
CheckpointLock Waiting to perform checkpoint.
CLogControlLock Waiting to read or update transaction status.
SubtransControlLock Waiting to read or update sub-transaction information.
MultiXactGenLock Waiting to read or update shared multixact state.
MultiXactOffsetControlLock Waiting to read or update multixact offset mappings.
MultiXactMemberControlLock Waiting to read or update multixact member mappings.
RelCacheInitLock Waiting to read or write relation cache initialization file.
CheckpointerCommLock Waiting to manage fsync requests.
TwoPhaseStateLock Waiting to read or update the state of prepared transactions.
TablespaceCreateLock Waiting to create or drop the tablespace.
BtreeVacuumLock Waiting to read or update vacuum-related information for a B-tree index.
AddinShmemInitLock Waiting to manage space allocation in shared memory.
AutovacuumLock Autovacuum worker or launcher waiting to update or read the current state of autovacuum workers.
AutovacuumScheduleLock Waiting to ensure that the table it has selected for a vacuum still needs vacuuming.
SyncScanLock Waiting to get the start location of a scan on a table for synchronized scans.
RelationMappingLock Waiting to update the relation map file used to store catalog to filenode mapping.
AsyncCtlLock Waiting to read or update shared notification state.
AsyncQueueLock Waiting to read or update notification messages.
SerializableXactHashLock Waiting to retrieve or store information about serializable transactions.
SerializableFinishedListLock Waiting to access the list of finished serializable transactions.
SerializablePredicateLockListLock Waiting to perform an operation on a list of locks held by serializable transactions.
OldSerXidLock Waiting to read or record conflicting serializable transactions.
SyncRepLock Waiting to read or update information about synchronous replicas.
BackgroundWorkerLock Waiting to read or update background worker state.
DynamicSharedMemoryControlLock Waiting to read or update dynamic shared memory state.
AutoFileLock Waiting to update the postgresql.auto.conf file.
ReplicationSlotAllocationLock Waiting to allocate or free a replication slot.
ReplicationSlotControlLock Waiting to read or update replication slot state.
CommitTsControlLock Waiting to read or update transaction commit timestamps.
CommitTsLock Waiting to read or update the last value set for the transaction timestamp.
ReplicationOriginLock Waiting to setup, drop or use replication origin.
MultiXactTruncationLock Waiting to read or truncate multixact information.
OldSnapshotTimeMapLock Waiting to read or update old snapshot control information.
BackendRandomLock Waiting to generate a random number.
LogicalRepWorkerLock Waiting for action on logical replication worker to finish.
CLogTruncationLock Waiting to truncate the write-ahead log or waiting for write-ahead log truncation to finish.
clog Waiting for I/O on a clog (transaction status) buffer.
commit_timestamp Waiting for I/O on commit timestamp buffer.
subtrans Waiting for I/O a subtransaction buffer.
multixact_offset Waiting for I/O on a multixact offset buffer.
multixact_member Waiting for I/O on a multixact_member buffer.
async Waiting for I/O on an async (notify) buffer.
oldserxid Waiting to I/O on an oldserxid buffer.
wal_insert Waiting to insert WAL into a memory buffer.
buffer_content Waiting to read or write a data page in memory.
buffer_io Waiting for I/O on a data page.
replication_origin Waiting to read or update the replication progress.
replication_slot_io Waiting for I/O on a replication slot.
proc Waiting to read or update the fast-path lock information.
buffer_mapping Waiting to associate a data block with a buffer in the buffer pool.
lock_manager Waiting to add or examine locks for backends, or waiting to join or exit a locking group (used by parallel query).
predicate_lock_manager Waiting to add or examine predicate lock information.
parallel_query_dsa Waiting for parallel query dynamic shared memory allocation lock.
tbm Waiting for TBM shared iterator lock.
Lock relation Waiting to acquire a lock on a relation.
extend Waiting to extend a relation.
page Waiting to acquire a lock on page of a relation.
tuple Waiting to acquire a lock on a tuple.
transactionid Waiting for a transaction to finish.
virtualxid Waiting to acquire a virtual xid lock.
speculative token Waiting to acquire a speculative insertion lock.
object Waiting to acquire a lock on a non-relation database object.
userlock Waiting to acquire a user lock.
advisory Waiting to acquire an advisory user lock.
BufferPin BufferPin Waiting to acquire a pin on a buffer.
Activity ArchiverMain Waiting in main loop of the archiver process.
AutoVacuumMain Waiting in main loop of autovacuum launcher process.
BgWriterHibernate Waiting in background writer process, hibernating.
BgWriterMain Waiting in main loop of background writer process background worker.
CheckpointerMain Waiting in main loop of checkpointer process.
LogicalLauncherMain Waiting in main loop of logical launcher process.
LogicalApplyMain Waiting in main loop of logical apply process.
PgStatMain Waiting in main loop of the statistics collector process.
RecoveryWalAll Waiting for WAL from any kind of source (local, archive or stream) at recovery.
RecoveryWalStream Waiting for WAL from a stream at recovery.
SysLoggerMain Waiting in main loop of syslogger process.
WalReceiverMain Waiting in main loop of WAL receiver process.
WalSenderMain Waiting in main loop of WAL sender process.
WalWriterMain Waiting in main loop of WAL writer process.
Client ClientRead Waiting to read data from the client.
ClientWrite Waiting to write data from the client.
LibPQWalReceiverConnect Waiting in WAL receiver to establish connection to remote server.
LibPQWalReceiverReceive Waiting in WAL receiver to receive data from remote server.
SSLOpenServer Waiting for SSL while attempting connection.
WalReceiverWaitStart Waiting for startup process to send initial data for streaming replication.
WalSenderWaitForWAL Waiting for WAL to be flushed in WAL sender process.
WalSenderWriteData Waiting for any activity when processing replies from WAL receiver in WAL sender process.
Extension Extension Waiting in an extension.
IPC BgWorkerShutdown Waiting for background worker to shut down.
BgWorkerStartup Waiting for background worker to start up.
BtreePage Waiting for the page number needed to continue a parallel B-tree scan to become available.
ExecuteGather Waiting for activity from child process when executing Gather node.
LogicalSyncData Waiting for logical replication remote server to send data for initial table synchronization.
LogicalSyncStateChange Waiting for logical replication remote server to change state.
MessageQueueInternal Waiting for other process to be attached in shared message queue.
MessageQueuePutMessage Waiting to write a protocol message to a shared message queue.
MessageQueueReceive Waiting to receive bytes from a shared message queue.
MessageQueueSend Waiting to send bytes to a shared message queue.
ParallelFinish Waiting for parallel workers to finish computing.
ParallelBitmapScan Waiting for parallel bitmap scan to become initialized.
ProcArrayGroupUpdate Waiting for group leader to clear transaction id at transaction end.
ReplicationOriginDrop Waiting for a replication origin to become inactive to be dropped.
ReplicationSlotDrop Waiting for a replication slot to become inactive to be dropped.
SafeSnapshot Waiting for a snapshot for a READ ONLY DEFERRABLE transaction.
SyncRep Waiting for confirmation from remote server during synchronous replication.
Timeout BaseBackupThrottle Waiting during base backup when throttling activity.
PgSleep Waiting in process that called pg_sleep.
RecoveryApplyDelay Waiting to apply WAL at recovery because it is delayed.
IO BufFileRead Waiting for a read from a buffered file.
BufFileWrite Waiting for a write to a buffered file.
ControlFileRead Waiting for a read from the control file.
ControlFileSync Waiting for the control file to reach stable storage.
ControlFileSyncUpdate Waiting for an update to the control file to reach stable storage.
ControlFileWrite Waiting for a write to the control file.
ControlFileWriteUpdate Waiting for a write to update the control file.
CopyFileRead Waiting for a read during a file copy operation.
CopyFileWrite Waiting for a write during a file copy operation.
DataFileExtend Waiting for a relation data file to be extended.
DataFileFlush Waiting for a relation data file to reach stable storage.
DataFileImmediateSync Waiting for an immediate synchronization of a relation data file to stable storage.
DataFilePrefetch Waiting for an asynchronous prefetch from a relation data file.
DataFileRead Waiting for a read from a relation data file.
DataFileSync Waiting for changes to a relation data file to reach stable storage.
DataFileTruncate Waiting for a relation data file to be truncated.
DataFileWrite Waiting for a write to a relation data file.
DSMFillZeroWrite Waiting to write zero bytes to a dynamic shared memory backing file.
LockFileAddToDataDirRead Waiting for a read while adding a line to the data directory lock file.
LockFileAddToDataDirSync Waiting for data to reach stable storage while adding a line to the data directory lock file.
LockFileAddToDataDirWrite Waiting for a write while adding a line to the data directory lock file.
LockFileCreateRead Waiting to read while creating the data directory lock file.
LockFileCreateSync Waiting for data to reach stable storage while creating the data directory lock file.
LockFileCreateWrite Waiting for a write while creating the data directory lock file.
LockFileReCheckDataDirRead Waiting for a read during recheck of the data directory lock file.
LogicalRewriteCheckpointSync Waiting for logical rewrite mappings to reach stable storage during a checkpoint.
LogicalRewriteMappingSync Waiting for mapping data to reach stable storage during a logical rewrite.
LogicalRewriteMappingWrite Waiting for a write of mapping data during a logical rewrite.
LogicalRewriteSync Waiting for logical rewrite mappings to reach stable storage.
LogicalRewriteWrite Waiting for a write of logical rewrite mappings.
RelationMapRead Waiting for a read of the relation map file.
RelationMapSync Waiting for the relation map file to reach stable storage.
RelationMapWrite Waiting for a write to the relation map file.
ReorderBufferRead Waiting for a read during reorder buffer management.
ReorderBufferWrite Waiting for a write during reorder buffer management.
ReorderLogicalMappingRead Waiting for a read of a logical mapping during reorder buffer management.
ReplicationSlotRead Waiting for a read from a replication slot control file.
ReplicationSlotRestoreSync Waiting for a replication slot control file to reach stable storage while restoring it to memory.
ReplicationSlotSync Waiting for a replication slot control file to reach stable storage.
ReplicationSlotWrite Waiting for a write to a replication slot control file.
SLRUFlushSync Waiting for SLRU data to reach stable storage during a checkpoint or database shutdown.
SLRURead Waiting for a read of an SLRU page.
SLRUSync Waiting for SLRU data to reach stable storage following a page write.
SLRUWrite Waiting for a write of an SLRU page.
SnapbuildRead Waiting for a read of a serialized historical catalog snapshot.
SnapbuildSync Waiting for a serialized historical catalog snapshot to reach stable storage.
SnapbuildWrite Waiting for a write of a serialized historical catalog snapshot.
TimelineHistoryFileSync Waiting for a timeline history file received via streaming replication to reach stable storage.
TimelineHistoryFileWrite Waiting for a write of a timeline history file received via streaming replication.
TimelineHistoryRead Waiting for a read of a timeline history file.
TimelineHistorySync Waiting for a newly created timeline history file to reach stable storage.
TimelineHistoryWrite Waiting for a write of a newly created timeline history file.
TwophaseFileRead Waiting for a read of a two phase state file.
TwophaseFileSync Waiting for a two phase state file to reach stable storage.
TwophaseFileWrite Waiting for a write of a two phase state file.
WALBootstrapSync Waiting for WAL to reach stable storage during bootstrapping.
WALBootstrapWrite Waiting for a write of a WAL page during bootstrapping.
WALCopyRead Waiting for a read when creating a new WAL segment by copying an existing one.
WALCopySync Waiting a new WAL segment created by copying an existing one to reach stable storage.
WALCopyWrite Waiting for a write when creating a new WAL segment by copying an existing one.
WALInitSync Waiting for a newly initialized WAL file to reach stable storage.
WALInitWrite Waiting for a write while initializing a new WAL file.
WALRead Waiting for a read from a WAL file.
WALSenderTimelineHistoryRead Waiting for a read from a timeline history file during walsender timeline command.
WALSyncMethodAssign Waiting for data to reach stable storage while assigning WAL sync method.
WALWrite Waiting for a write to a WAL file.

标签:WAL,PostgreSQL,read,data,数据库,write,Waiting,file,等待
From: https://www.cnblogs.com/zhenren001/p/16932100.html

相关文章

  • 使用SQL Server Management Studio 2008 将数据库里的数据导成脚本
    之前很羡慕MySQL有这样的工具可以把数据库里的数据导成脚本,SQLServer2005的时候大牛PinalDave写了个​​DatabasePublishingWizard​​​,具体用法参考他写的文章​​......
  • 部署主从数据库
    Mysql主从配置:   大型网站为了软解大量的并发访问,除了在网站实现分布式负载均衡,远远不够。到了数据业务层、数据访问层,如果还是传统的数据结构,或者只是单单靠一台服务......
  • 时序数据库 influxdb 教程
    十年河东,十年河西,莫欺少年穷学无止境,精益求精时序数据库influxdb适用于物联网、等大数据行业,支持亿级数据中文参考文档​​https://jasper-zhang1.gitbooks.io/influxdb/c......
  • 数据库
    目录约束数据库设计多表查询事务约束概念&分类非空约束唯一约束主键约束默认约束检查约束外键约束约束的概念和分类约束概念约束是作用于表中上的规......
  • Mysql 直接拷贝数据库文件导致表不显示的问题
    前言:最近有一个需求,需要迁移数据库中的其中一个库,需要迁移的那个数据库占用了700多G的空间,所以采用直接拷贝数据库文件的方式,拷贝到另一台服务器后发现表不显示,记录本次问......
  • 数据库索引
    介绍利用关键字,就是记录的部分数据(某个字段,某些字段,某个字段的一部分),建立与记录位置的对应关系,就是索引。索引的作用:是用于快速定位实际数据位置的一种机制。例如:字典......
  • mysql 数据库管理
    一、常用的数据类型二、数据库管理2.1创建数据库和表-create2.2删除数据库和表-drop  一、常用的数据类型类型解释举例int整型......
  • 【转载】Oracle - 数据库打补丁最佳实践
    一、概述本文将介绍如何给oracle数据库打最新补丁,数据库版本为11.2.0.4单实例,操作系统为redhat6.5 二、下载相关升级包1.登录MOS,查阅(ID2118136.2),下载最新补丁包......
  • 数据库中的锁
    在很多文章中都能见到不少“锁”,下面整理下常见的“锁”1、按照并发策略分类数据库中的并发控制主要分为三种,一是乐观锁,二是悲观锁,三是时间戳乐观锁持有的是一种乐观的......
  • 网络编程及数据库MySQL总结
    目录网络编程并发知识网络编程知识网络编程软件开发架构计算机网络的相关专业名词OSI七层协议物理连接层数据链路层网络层传输层应用层socket模块黏包现象struct模块并发编......