PostgreSQL exporter
3316

Source Code prometheus-community/postgres_exporter
Last Relase
9/29/2025

Exported Metrics 281

NameDescriptionLabels
pg_exporter_last_scrape_duration_secondsDuration of the last scrape of metrics from PostgresSQL.
pg_exporter_last_scrape_errorWhether the last scrape of metrics from PostgreSQL resulted in an error (1 for error, 0 for success).
pg_exporter_scrapes_totalTotal number of times PostgresSQL was scraped for metrics.
pg_locks_countNumber of locksdatname, mode, server
pg_settings_allow_system_table_modsAllows modifications of the structure of system tables.server
pg_settings_archive_timeout_secondsForces a switch to the next WAL file if a new file has not been started within N seconds. [Units converted to seconds.]server
pg_settings_array_nullsEnable input of NULL elements in arrays.server
pg_settings_authentication_timeout_secondsSets the maximum allowed time to complete client authentication. [Units converted to seconds.]server
pg_settings_autovacuumStarts the autovacuum subprocess.server
pg_settings_autovacuum_analyze_scale_factorNumber of tuple inserts, updates, or deletes prior to analyze as a fraction of reltuples.server
pg_settings_autovacuum_analyze_thresholdMinimum number of tuple inserts, updates, or deletes prior to analyze.server
pg_settings_autovacuum_freeze_max_ageAge at which to autovacuum a table to prevent transaction ID wraparound.server
pg_settings_autovacuum_max_workersSets the maximum number of simultaneously running autovacuum worker processes.server
pg_settings_autovacuum_multixact_freeze_max_ageMultixact age at which to autovacuum a table to prevent multixact wraparound.server
pg_settings_autovacuum_naptime_secondsTime to sleep between autovacuum runs. [Units converted to seconds.]server
pg_settings_autovacuum_vacuum_cost_delay_secondsVacuum cost delay in milliseconds, for autovacuum. [Units converted to seconds.]server
pg_settings_autovacuum_vacuum_cost_limitVacuum cost amount available before napping, for autovacuum.server
pg_settings_autovacuum_vacuum_insert_scale_factorNumber of tuple inserts prior to vacuum as a fraction of reltuples.server
pg_settings_autovacuum_vacuum_insert_thresholdMinimum number of tuple inserts prior to vacuum, or -1 to disable insert vacuums.server
pg_settings_autovacuum_vacuum_scale_factorNumber of tuple updates or deletes prior to vacuum as a fraction of reltuples.server
pg_settings_autovacuum_vacuum_thresholdMinimum number of tuple updates or deletes prior to vacuum.server
pg_settings_autovacuum_work_mem_bytesSets the maximum memory to be used by each autovacuum worker process. [Units converted to bytes.]server
pg_settings_backend_flush_after_bytesNumber of pages after which previously performed writes are flushed to disk. [Units converted to bytes.]server
pg_settings_bgwriter_delay_secondsBackground writer sleep time between rounds. [Units converted to seconds.]server
pg_settings_bgwriter_flush_after_bytesNumber of pages after which previously performed writes are flushed to disk. [Units converted to bytes.]server
pg_settings_bgwriter_lru_maxpagesBackground writer maximum number of LRU pages to flush per round.server
pg_settings_bgwriter_lru_multiplierMultiple of the average buffer usage to free per round.server
pg_settings_block_sizeShows the size of a disk block.server
pg_settings_bonjourEnables advertising the server via Bonjour.server
pg_settings_check_function_bodiesCheck function bodies during CREATE FUNCTION.server
pg_settings_checkpoint_completion_targetTime spent flushing dirty buffers during checkpoint, as fraction of checkpoint interval.server
pg_settings_checkpoint_flush_after_bytesNumber of pages after which previously performed writes are flushed to disk. [Units converted to bytes.]server
pg_settings_checkpoint_timeout_secondsSets the maximum time between automatic WAL checkpoints. [Units converted to seconds.]server
pg_settings_checkpoint_warning_secondsEnables warnings if checkpoint segments are filled more frequently than this. [Units converted to seconds.]server
pg_settings_commit_delaySets the delay in microseconds between transaction commit and flushing WAL to disk.server
pg_settings_commit_siblingsSets the minimum concurrent open transactions before performing commit_delay.server
pg_settings_cpu_index_tuple_costSets the planner's estimate of the cost of processing each index entry during an index scan.server
pg_settings_cpu_operator_costSets the planner's estimate of the cost of processing each operator or function call.server
pg_settings_cpu_tuple_costSets the planner's estimate of the cost of processing each tuple (row).server
pg_settings_cursor_tuple_fractionSets the planner's estimate of the fraction of a cursor's rows that will be retrieved.server
pg_settings_data_checksumsShows whether data checksums are turned on for this cluster.server
pg_settings_data_directory_modeMode of the data directory.server
pg_settings_data_sync_retryWhether to continue running after a failure to sync data files.server
pg_settings_db_user_namespaceEnables per-database user names.server
pg_settings_deadlock_timeout_secondsSets the time to wait on a lock before checking for deadlock. [Units converted to seconds.]server
pg_settings_debug_assertionsShows whether the running server has assertion checks enabled.server
pg_settings_debug_pretty_printIndents parse and plan tree displays.server
pg_settings_debug_print_parseLogs each query's parse tree.server
pg_settings_debug_print_planLogs each query's execution plan.server
pg_settings_debug_print_rewrittenLogs each query's rewritten parse tree.server
pg_settings_default_statistics_targetSets the default statistics target.server
pg_settings_default_transaction_deferrableSets the default deferrable status of new transactions.server
pg_settings_default_transaction_read_onlySets the default read-only status of new transactions.server
pg_settings_effective_cache_size_bytesSets the planner's assumption about the total size of the data caches. [Units converted to bytes.]server
pg_settings_effective_io_concurrencyNumber of simultaneous requests that can be handled efficiently by the disk subsystem.server
pg_settings_enable_bitmapscanEnables the planner's use of bitmap-scan plans.server
pg_settings_enable_gathermergeEnables the planner's use of gather merge plans.server
pg_settings_enable_hashaggEnables the planner's use of hashed aggregation plans.server
pg_settings_enable_hashjoinEnables the planner's use of hash join plans.server
pg_settings_enable_incremental_sortEnables the planner's use of incremental sort steps.server
pg_settings_enable_indexonlyscanEnables the planner's use of index-only-scan plans.server
pg_settings_enable_indexscanEnables the planner's use of index-scan plans.server
pg_settings_enable_materialEnables the planner's use of materialization.server
pg_settings_enable_mergejoinEnables the planner's use of merge join plans.server
pg_settings_enable_nestloopEnables the planner's use of nested-loop join plans.server
pg_settings_enable_parallel_appendEnables the planner's use of parallel append plans.server
pg_settings_enable_parallel_hashEnables the planner's use of parallel hash plans.server
pg_settings_enable_partition_pruningEnables plan-time and run-time partition pruning.server
pg_settings_enable_partitionwise_aggregateEnables partitionwise aggregation and grouping.server
pg_settings_enable_partitionwise_joinEnables partitionwise join.server
pg_settings_enable_seqscanEnables the planner's use of sequential-scan plans.server
pg_settings_enable_sortEnables the planner's use of explicit sort steps.server
pg_settings_enable_tidscanEnables the planner's use of TID scan plans.server
pg_settings_escape_string_warningWarn about backslash escapes in ordinary string literals.server
pg_settings_exit_on_errorTerminate session on any error.server
pg_settings_extra_float_digitsSets the number of digits displayed for floating-point values.server
pg_settings_from_collapse_limitSets the FROM-list size beyond which subqueries are not collapsed.server
pg_settings_fsyncForces synchronization of updates to disk.server
pg_settings_full_page_writesWrites full pages to WAL when first modified after a checkpoint.server
pg_settings_geqoEnables genetic query optimization.server
pg_settings_geqo_effortGEQO: effort is used to set the default for other GEQO parameters.server
pg_settings_geqo_generationsGEQO: number of iterations of the algorithm.server
pg_settings_geqo_pool_sizeGEQO: number of individuals in the population.server
pg_settings_geqo_seedGEQO: seed for random path selection.server
pg_settings_geqo_selection_biasGEQO: selective pressure within the population.server
pg_settings_geqo_thresholdSets the threshold of FROM items beyond which GEQO is used.server
pg_settings_gin_fuzzy_search_limitSets the maximum allowed result for exact search by GIN.server
pg_settings_gin_pending_list_limit_bytesSets the maximum size of the pending list for GIN index. [Units converted to bytes.]server
pg_settings_hash_mem_multiplierMultiple of work_mem to use for hash tables.server
pg_settings_hot_standbyAllows connections and queries during recovery.server
pg_settings_hot_standby_feedbackAllows feedback from a hot standby to the primary that will avoid query conflicts.server
pg_settings_idle_in_transaction_session_timeout_secondsSets the maximum allowed duration of any idling transaction. [Units converted to seconds.]server
pg_settings_ignore_checksum_failureContinues processing after a checksum failure.server
pg_settings_ignore_invalid_pagesContinues recovery after an invalid pages failure.server
pg_settings_ignore_system_indexesDisables reading from system indexes.server
pg_settings_integer_datetimesDatetimes are integer based.server
pg_settings_jitAllow JIT compilation.server
pg_settings_jit_above_costPerform JIT compilation if query is more expensive.server
pg_settings_jit_debugging_supportRegister JIT compiled function with debugger.server
pg_settings_jit_dump_bitcodeWrite out LLVM bitcode to facilitate JIT debugging.server
pg_settings_jit_expressionsAllow JIT compilation of expressions.server
pg_settings_jit_inline_above_costPerform JIT inlining if query is more expensive.server
pg_settings_jit_optimize_above_costOptimize JITed functions if query is more expensive.server
pg_settings_jit_profiling_supportRegister JIT compiled function with perf profiler.server
pg_settings_jit_tuple_deformingAllow JIT compilation of tuple deforming.server
pg_settings_join_collapse_limitSets the FROM-list size beyond which JOIN constructs are not flattened.server
pg_settings_krb_caseins_usersSets whether Kerberos and GSSAPI user names should be treated as case-insensitive.server
pg_settings_lo_compat_privilegesEnables backward compatibility mode for privilege checks on large objects.server
pg_settings_lock_timeout_secondsSets the maximum allowed duration of any wait for a lock. [Units converted to seconds.]server
pg_settings_log_autovacuum_min_duration_secondsSets the minimum execution time above which autovacuum actions will be logged. [Units converted to seconds.]server
pg_settings_log_checkpointsLogs each checkpoint.server
pg_settings_log_connectionsLogs each successful connection.server
pg_settings_log_disconnectionsLogs end of a session, including duration.server
pg_settings_log_durationLogs the duration of each completed SQL statement.server
pg_settings_log_executor_statsWrites executor performance statistics to the server log.server
pg_settings_log_file_modeSets the file permissions for log files.server
pg_settings_log_hostnameLogs the host name in the connection logs.server
pg_settings_log_lock_waitsLogs long lock waits.server
pg_settings_log_min_duration_sample_secondsSets the minimum execution time above which a sample of statements will be logged. Sampling is determined by log_statement_sample_rate. [Units converted to seconds.]server
pg_settings_log_min_duration_statement_secondsSets the minimum execution time above which all statements will be logged. [Units converted to seconds.]server
pg_settings_log_parameter_max_length_bytesWhen logging statements, limit logged parameter values to first N bytes. [Units converted to bytes.]server
pg_settings_log_parameter_max_length_on_error_bytesWhen reporting an error, limit logged parameter values to first N bytes. [Units converted to bytes.]server
pg_settings_log_parser_statsWrites parser performance statistics to the server log.server
pg_settings_log_planner_statsWrites planner performance statistics to the server log.server
pg_settings_log_replication_commandsLogs each replication command.server
pg_settings_log_rotation_age_secondsAutomatic log file rotation will occur after N minutes. [Units converted to seconds.]server
pg_settings_log_rotation_size_bytesAutomatic log file rotation will occur after N kilobytes. [Units converted to bytes.]server
pg_settings_log_statement_sample_rateFraction of statements exceeding log_min_duration_sample to be logged.server
pg_settings_log_statement_statsWrites cumulative performance statistics to the server log.server
pg_settings_log_temp_files_bytesLog the use of temporary files larger than this number of kilobytes. [Units converted to bytes.]server
pg_settings_log_transaction_sample_rateSet the fraction of transactions to log for new transactions.server
pg_settings_log_truncate_on_rotationTruncate existing log files of same name during log rotation.server
pg_settings_logging_collectorStart a subprocess to capture stderr output and/or csvlogs into log files.server
pg_settings_logical_decoding_work_mem_bytesSets the maximum memory to be used for logical decoding. [Units converted to bytes.]server
pg_settings_maintenance_io_concurrencyA variant of effective_io_concurrency that is used for maintenance work.server
pg_settings_maintenance_work_mem_bytesSets the maximum memory to be used for maintenance operations. [Units converted to bytes.]server
pg_settings_max_connectionsSets the maximum number of concurrent connections.server
pg_settings_max_files_per_processSets the maximum number of simultaneously open files for each server process.server
pg_settings_max_function_argsShows the maximum number of function arguments.server
pg_settings_max_identifier_lengthShows the maximum identifier length.server
pg_settings_max_index_keysShows the maximum number of index keys.server
pg_settings_max_locks_per_transactionSets the maximum number of locks per transaction.server
pg_settings_max_logical_replication_workersMaximum number of logical replication worker processes.server
pg_settings_max_parallel_maintenance_workersSets the maximum number of parallel processes per maintenance operation.server
pg_settings_max_parallel_workersSets the maximum number of parallel workers that can be active at one time.server
pg_settings_max_parallel_workers_per_gatherSets the maximum number of parallel processes per executor node.server
pg_settings_max_pred_locks_per_pageSets the maximum number of predicate-locked tuples per page.server
pg_settings_max_pred_locks_per_relationSets the maximum number of predicate-locked pages and tuples per relation.server
pg_settings_max_pred_locks_per_transactionSets the maximum number of predicate locks per transaction.server
pg_settings_max_prepared_transactionsSets the maximum number of simultaneously prepared transactions.server
pg_settings_max_replication_slotsSets the maximum number of simultaneously defined replication slots.server
pg_settings_max_slot_wal_keep_size_bytesSets the maximum WAL size that can be reserved by replication slots. [Units converted to bytes.]server
pg_settings_max_stack_depth_bytesSets the maximum stack depth, in kilobytes. [Units converted to bytes.]server
pg_settings_max_standby_archive_delay_secondsSets the maximum delay before canceling queries when a hot standby server is processing archived WAL data. [Units converted to seconds.]server
pg_settings_max_standby_streaming_delay_secondsSets the maximum delay before canceling queries when a hot standby server is processing streamed WAL data. [Units converted to seconds.]server
pg_settings_max_sync_workers_per_subscriptionMaximum number of table synchronization workers per subscription.server
pg_settings_max_wal_sendersSets the maximum number of simultaneously running WAL sender processes.server
pg_settings_max_wal_size_bytesSets the WAL size that triggers a checkpoint. [Units converted to bytes.]server
pg_settings_max_worker_processesMaximum number of concurrent worker processes.server
pg_settings_min_parallel_index_scan_size_bytesSets the minimum amount of index data for a parallel scan. [Units converted to bytes.]server
pg_settings_min_parallel_table_scan_size_bytesSets the minimum amount of table data for a parallel scan. [Units converted to bytes.]server
pg_settings_min_wal_size_bytesSets the minimum size to shrink the WAL to. [Units converted to bytes.]server
pg_settings_old_snapshot_threshold_secondsTime before a snapshot is too old to read pages changed after the snapshot was taken. [Units converted to seconds.]server
pg_settings_operator_precedence_warningEmit a warning for constructs that changed meaning since PostgreSQL 9.4.server
pg_settings_parallel_leader_participationControls whether Gather and Gather Merge also run subplans.server
pg_settings_parallel_setup_costSets the planner's estimate of the cost of starting up worker processes for parallel query.server
pg_settings_parallel_tuple_costSets the planner's estimate of the cost of passing each tuple (row) from worker to master backend.server
pg_settings_portSets the TCP port the server listens on.server
pg_settings_post_auth_delay_secondsWaits N seconds on connection startup after authentication. [Units converted to seconds.]server
pg_settings_pre_auth_delay_secondsWaits N seconds on connection startup before authentication. [Units converted to seconds.]server
pg_settings_quote_all_identifiersWhen generating SQL fragments, quote all identifiers.server
pg_settings_random_page_costSets the planner's estimate of the cost of a nonsequentially fetched disk page.server
pg_settings_recovery_min_apply_delay_secondsSets the minimum delay for applying changes during recovery. [Units converted to seconds.]server
pg_settings_recovery_target_inclusiveSets whether to include or exclude transaction with recovery target.server
pg_settings_restart_after_crashReinitialize server after backend crash.server
pg_settings_row_securityEnable row security.server
pg_settings_segment_size_bytesShows the number of pages per disk file. [Units converted to bytes.]server
pg_settings_seq_page_costSets the planner's estimate of the cost of a sequentially fetched disk page.server
pg_settings_server_version_numShows the server version as an integer.server
pg_settings_shared_buffers_bytesSets the number of shared memory buffers used by the server. [Units converted to bytes.]server
pg_settings_sslEnables SSL connections.server
pg_settings_ssl_passphrase_command_supports_reloadAlso use ssl_passphrase_command during server reload.server
pg_settings_ssl_prefer_server_ciphersGive priority to server ciphersuite order.server
pg_settings_standard_conforming_stringsCauses '...' strings to treat backslashes literally.server
pg_settings_statement_timeout_secondsSets the maximum allowed duration of any statement. [Units converted to seconds.]server
pg_settings_superuser_reserved_connectionsSets the number of connection slots reserved for superusers.server
pg_settings_synchronize_seqscansEnable synchronized sequential scans.server
pg_settings_syslog_sequence_numbersAdd sequence number to syslog messages to avoid duplicate suppression.server
pg_settings_syslog_split_messagesSplit messages sent to syslog by lines and to fit into 1024 bytes.server
pg_settings_tcp_keepalives_countMaximum number of TCP keepalive retransmits.server
pg_settings_tcp_keepalives_idle_secondsTime between issuing TCP keepalives. [Units converted to seconds.]server
pg_settings_tcp_keepalives_interval_secondsTime between TCP keepalive retransmits. [Units converted to seconds.]server
pg_settings_tcp_user_timeout_secondsTCP user timeout. [Units converted to seconds.]server
pg_settings_temp_buffers_bytesSets the maximum number of temporary buffers used by each session. [Units converted to bytes.]server
pg_settings_temp_file_limit_bytesLimits the total size of all temporary files used by each process. [Units converted to bytes.]server
pg_settings_trace_notifyGenerates debugging output for LISTEN and NOTIFY.server
pg_settings_trace_sortEmit information about resource usage in sorting.server
pg_settings_track_activitiesCollects information about executing commands.server
pg_settings_track_activity_query_size_bytesSets the size reserved for pg_stat_activity.query, in bytes. [Units converted to bytes.]server
pg_settings_track_commit_timestampCollects transaction commit time.server
pg_settings_track_countsCollects statistics on database activity.server
pg_settings_track_io_timingCollects timing statistics for database I/O activity.server
pg_settings_transaction_deferrableWhether to defer a read-only serializable transaction until it can be executed with no possible serialization failures.server
pg_settings_transaction_read_onlySets the current transaction's read-only status.server
pg_settings_transform_null_equalsTreats "expr=NULL" as "expr IS NULL".server
pg_settings_unix_socket_permissionsSets the access permissions of the Unix-domain socket.server
pg_settings_update_process_titleUpdates the process title to show the active SQL command.server
pg_settings_vacuum_cleanup_index_scale_factorNumber of tuple inserts prior to index cleanup as a fraction of reltuples.server
pg_settings_vacuum_cost_delay_secondsVacuum cost delay in milliseconds. [Units converted to seconds.]server
pg_settings_vacuum_cost_limitVacuum cost amount available before napping.server
pg_settings_vacuum_cost_page_dirtyVacuum cost for a page dirtied by vacuum.server
pg_settings_vacuum_cost_page_hitVacuum cost for a page found in the buffer cache.server
pg_settings_vacuum_cost_page_missVacuum cost for a page not found in the buffer cache.server
pg_settings_vacuum_defer_cleanup_ageNumber of transactions by which VACUUM and HOT cleanup should be deferred, if any.server
pg_settings_vacuum_freeze_min_ageMinimum age at which VACUUM should freeze a table row.server
pg_settings_vacuum_freeze_table_ageAge at which VACUUM should scan whole table to freeze tuples.server
pg_settings_vacuum_multixact_freeze_min_ageMinimum age at which VACUUM should freeze a MultiXactId in a table row.server
pg_settings_vacuum_multixact_freeze_table_ageMultixact age at which VACUUM should scan whole table to freeze tuples.server
pg_settings_wal_block_sizeShows the block size in the write ahead log.server
pg_settings_wal_buffers_bytesSets the number of disk-page buffers in shared memory for WAL. [Units converted to bytes.]server
pg_settings_wal_compressionCompresses full-page writes written in WAL file.server
pg_settings_wal_init_zeroWrites zeroes to new WAL files before first use.server
pg_settings_wal_keep_size_bytesSets the size of WAL files held for standby servers. [Units converted to bytes.]server
pg_settings_wal_log_hintsWrites full pages to WAL when first modified after a checkpoint, even for a non-critical modifications.server
pg_settings_wal_receiver_create_temp_slotSets whether a WAL receiver should create a temporary replication slot if no permanent slot is configured.server
pg_settings_wal_receiver_status_interval_secondsSets the maximum interval between WAL receiver status reports to the sending server. [Units converted to seconds.]server
pg_settings_wal_receiver_timeout_secondsSets the maximum wait time to receive data from the sending server. [Units converted to seconds.]server
pg_settings_wal_recycleRecycles WAL files by renaming them.server
pg_settings_wal_retrieve_retry_interval_secondsSets the time to wait before retrying to retrieve WAL after a failed attempt. [Units converted to seconds.]server
pg_settings_wal_segment_size_bytesShows the size of write ahead log segments. [Units converted to bytes.]server
pg_settings_wal_sender_timeout_secondsSets the maximum time to wait for WAL replication. [Units converted to seconds.]server
pg_settings_wal_skip_threshold_bytesSize of new file to fsync instead of writing WAL. [Units converted to bytes.]server
pg_settings_wal_writer_delay_secondsTime between WAL flushes performed in the WAL writer. [Units converted to seconds.]server
pg_settings_wal_writer_flush_after_bytesAmount of WAL written out by WAL writer that triggers a flush. [Units converted to bytes.]server
pg_settings_work_mem_bytesSets the maximum memory to be used for query workspaces. [Units converted to bytes.]server
pg_settings_zero_damaged_pagesContinues processing past damaged page headers.server
pg_stat_activity_countnumber of connections in this statedatname, server, state
pg_stat_activity_max_tx_durationmax duration in seconds any active transaction has been runningdatname, server, state
pg_stat_archiver_archived_countNumber of WAL files that have been successfully archivedserver
pg_stat_archiver_failed_countNumber of failed attempts for archiving WAL filesserver
pg_stat_archiver_last_archive_ageTime in seconds since last WAL segment was successfully archivedserver
pg_stat_bgwriter_buffers_allocNumber of buffers allocatedserver
pg_stat_bgwriter_buffers_backendNumber of buffers written directly by a backendserver
pg_stat_bgwriter_buffers_backend_fsyncNumber of times a backend had to execute its own fsync call (normally the background writer handles those even when the backend does its own write)server
pg_stat_bgwriter_buffers_checkpointNumber of buffers written during checkpointsserver
pg_stat_bgwriter_buffers_cleanNumber of buffers written by the background writerserver
pg_stat_bgwriter_checkpoint_sync_timeTotal amount of time that has been spent in the portion of checkpoint processing where files are synchronized to disk, in millisecondsserver
pg_stat_bgwriter_checkpoint_write_timeTotal amount of time that has been spent in the portion of checkpoint processing where files are written to disk, in millisecondsserver
pg_stat_bgwriter_checkpoints_reqNumber of requested checkpoints that have been performedserver
pg_stat_bgwriter_checkpoints_timedNumber of scheduled checkpoints that have been performedserver
pg_stat_bgwriter_maxwritten_cleanNumber of times the background writer stopped a cleaning scan because it had written too many buffersserver
pg_stat_bgwriter_stats_resetTime at which these statistics were last resetserver
pg_stat_database_blk_read_timeTime spent reading data file blocks by backends in this database, in millisecondsdatid, datname, server
pg_stat_database_blk_write_timeTime spent writing data file blocks by backends in this database, in millisecondsdatid, datname, server
pg_stat_database_blks_hitNumber of times disk blocks were found already in the buffer cache, so that a read was not necessary (this only includes hits in the PostgreSQL buffer cache, not the operating system's file system cache)datid, datname, server
pg_stat_database_blks_readNumber of disk blocks read in this databasedatid, datname, server
pg_stat_database_checksum_failuresUnknown metric from pg_stat_databasedatid, datname, server
pg_stat_database_checksum_last_failureUnknown metric from pg_stat_databasedatid, datname, server
pg_stat_database_conflictsNumber of queries canceled due to conflicts with recovery in this database. (Conflicts occur only on standby servers; see pg_stat_database_conflicts for details.)datid, datname, server
pg_stat_database_conflicts_confl_bufferpinNumber of queries in this database that have been canceled due to pinned buffersdatid, datname, server
pg_stat_database_conflicts_confl_deadlockNumber of queries in this database that have been canceled due to deadlocksdatid, datname, server
pg_stat_database_conflicts_confl_lockNumber of queries in this database that have been canceled due to lock timeoutsdatid, datname, server
pg_stat_database_conflicts_confl_snapshotNumber of queries in this database that have been canceled due to old snapshotsdatid, datname, server
pg_stat_database_conflicts_confl_tablespaceNumber of queries in this database that have been canceled due to dropped tablespacesdatid, datname, server
pg_stat_database_deadlocksNumber of deadlocks detected in this databasedatid, datname, server
pg_stat_database_numbackendsNumber of backends currently connected to this database. This is the only column in this view that returns a value reflecting current state; all other columns return the accumulated values since the last reset.datid, datname, server
pg_stat_database_stats_resetTime at which these statistics were last resetdatid, datname, server
pg_stat_database_temp_bytesTotal amount of data written to temporary files by queries in this database. All temporary files are counted, regardless of why the temporary file was created, and regardless of the log_temp_files setting.datid, datname, server
pg_stat_database_temp_filesNumber of temporary files created by queries in this database. All temporary files are counted, regardless of why the temporary file was created (e.g., sorting or hashing), and regardless of the log_temp_files setting.datid, datname, server
pg_stat_database_tup_deletedNumber of rows deleted by queries in this databasedatid, datname, server
pg_stat_database_tup_fetchedNumber of rows fetched by queries in this databasedatid, datname, server
pg_stat_database_tup_insertedNumber of rows inserted by queries in this databasedatid, datname, server
pg_stat_database_tup_returnedNumber of rows returned by queries in this databasedatid, datname, server
pg_stat_database_tup_updatedNumber of rows updated by queries in this databasedatid, datname, server
pg_stat_database_xact_commitNumber of transactions in this database that have been committeddatid, datname, server
pg_stat_database_xact_rollbackNumber of transactions in this database that have been rolled backdatid, datname, server
pg_staticVersion string as reported by postgresserver, short_version, version
pg_upWhether the last scrape of metrics from PostgreSQL was able to connect to the server (1 for yes, 0 for no).
postgres_exporter_build_infoA metric with a constant '1' value labeled by version, revision, branch, and goversion from which postgres_exporter was built.branch, goversion, revision, version
promhttp_metric_handler_requests_in_flightCurrent number of scrapes being served.
promhttp_metric_handler_requests_totalTotal number of scrapes by HTTP status code.code
Exported metrics may not be complete and fully accurate.