PostgreSQL exporter 3316
9/29/2025
Exported Metrics 281281
| Name | Description | Labels |
|---|---|---|
| pg_exporter_last_scrape_duration_seconds | Duration of the last scrape of metrics from PostgresSQL. | |
| pg_exporter_last_scrape_error | Whether the last scrape of metrics from PostgreSQL resulted in an error (1 for error, 0 for success). | |
| pg_exporter_scrapes_total | Total number of times PostgresSQL was scraped for metrics. | |
| pg_locks_count | Number of locks | datname, mode, server |
| pg_settings_allow_system_table_mods | Allows modifications of the structure of system tables. | server |
| pg_settings_archive_timeout_seconds | Forces 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_nulls | Enable input of NULL elements in arrays. | server |
| pg_settings_authentication_timeout_seconds | Sets the maximum allowed time to complete client authentication. [Units converted to seconds.] | server |
| pg_settings_autovacuum | Starts the autovacuum subprocess. | server |
| pg_settings_autovacuum_analyze_scale_factor | Number of tuple inserts, updates, or deletes prior to analyze as a fraction of reltuples. | server |
| pg_settings_autovacuum_analyze_threshold | Minimum number of tuple inserts, updates, or deletes prior to analyze. | server |
| pg_settings_autovacuum_freeze_max_age | Age at which to autovacuum a table to prevent transaction ID wraparound. | server |
| pg_settings_autovacuum_max_workers | Sets the maximum number of simultaneously running autovacuum worker processes. | server |
| pg_settings_autovacuum_multixact_freeze_max_age | Multixact age at which to autovacuum a table to prevent multixact wraparound. | server |
| pg_settings_autovacuum_naptime_seconds | Time to sleep between autovacuum runs. [Units converted to seconds.] | server |
| pg_settings_autovacuum_vacuum_cost_delay_seconds | Vacuum cost delay in milliseconds, for autovacuum. [Units converted to seconds.] | server |
| pg_settings_autovacuum_vacuum_cost_limit | Vacuum cost amount available before napping, for autovacuum. | server |
| pg_settings_autovacuum_vacuum_insert_scale_factor | Number of tuple inserts prior to vacuum as a fraction of reltuples. | server |
| pg_settings_autovacuum_vacuum_insert_threshold | Minimum number of tuple inserts prior to vacuum, or -1 to disable insert vacuums. | server |
| pg_settings_autovacuum_vacuum_scale_factor | Number of tuple updates or deletes prior to vacuum as a fraction of reltuples. | server |
| pg_settings_autovacuum_vacuum_threshold | Minimum number of tuple updates or deletes prior to vacuum. | server |
| pg_settings_autovacuum_work_mem_bytes | Sets the maximum memory to be used by each autovacuum worker process. [Units converted to bytes.] | server |
| pg_settings_backend_flush_after_bytes | Number of pages after which previously performed writes are flushed to disk. [Units converted to bytes.] | server |
| pg_settings_bgwriter_delay_seconds | Background writer sleep time between rounds. [Units converted to seconds.] | server |
| pg_settings_bgwriter_flush_after_bytes | Number of pages after which previously performed writes are flushed to disk. [Units converted to bytes.] | server |
| pg_settings_bgwriter_lru_maxpages | Background writer maximum number of LRU pages to flush per round. | server |
| pg_settings_bgwriter_lru_multiplier | Multiple of the average buffer usage to free per round. | server |
| pg_settings_block_size | Shows the size of a disk block. | server |
| pg_settings_bonjour | Enables advertising the server via Bonjour. | server |
| pg_settings_check_function_bodies | Check function bodies during CREATE FUNCTION. | server |
| pg_settings_checkpoint_completion_target | Time spent flushing dirty buffers during checkpoint, as fraction of checkpoint interval. | server |
| pg_settings_checkpoint_flush_after_bytes | Number of pages after which previously performed writes are flushed to disk. [Units converted to bytes.] | server |
| pg_settings_checkpoint_timeout_seconds | Sets the maximum time between automatic WAL checkpoints. [Units converted to seconds.] | server |
| pg_settings_checkpoint_warning_seconds | Enables warnings if checkpoint segments are filled more frequently than this. [Units converted to seconds.] | server |
| pg_settings_commit_delay | Sets the delay in microseconds between transaction commit and flushing WAL to disk. | server |
| pg_settings_commit_siblings | Sets the minimum concurrent open transactions before performing commit_delay. | server |
| pg_settings_cpu_index_tuple_cost | Sets the planner's estimate of the cost of processing each index entry during an index scan. | server |
| pg_settings_cpu_operator_cost | Sets the planner's estimate of the cost of processing each operator or function call. | server |
| pg_settings_cpu_tuple_cost | Sets the planner's estimate of the cost of processing each tuple (row). | server |
| pg_settings_cursor_tuple_fraction | Sets the planner's estimate of the fraction of a cursor's rows that will be retrieved. | server |
| pg_settings_data_checksums | Shows whether data checksums are turned on for this cluster. | server |
| pg_settings_data_directory_mode | Mode of the data directory. | server |
| pg_settings_data_sync_retry | Whether to continue running after a failure to sync data files. | server |
| pg_settings_db_user_namespace | Enables per-database user names. | server |
| pg_settings_deadlock_timeout_seconds | Sets the time to wait on a lock before checking for deadlock. [Units converted to seconds.] | server |
| pg_settings_debug_assertions | Shows whether the running server has assertion checks enabled. | server |
| pg_settings_debug_pretty_print | Indents parse and plan tree displays. | server |
| pg_settings_debug_print_parse | Logs each query's parse tree. | server |
| pg_settings_debug_print_plan | Logs each query's execution plan. | server |
| pg_settings_debug_print_rewritten | Logs each query's rewritten parse tree. | server |
| pg_settings_default_statistics_target | Sets the default statistics target. | server |
| pg_settings_default_transaction_deferrable | Sets the default deferrable status of new transactions. | server |
| pg_settings_default_transaction_read_only | Sets the default read-only status of new transactions. | server |
| pg_settings_effective_cache_size_bytes | Sets the planner's assumption about the total size of the data caches. [Units converted to bytes.] | server |
| pg_settings_effective_io_concurrency | Number of simultaneous requests that can be handled efficiently by the disk subsystem. | server |
| pg_settings_enable_bitmapscan | Enables the planner's use of bitmap-scan plans. | server |
| pg_settings_enable_gathermerge | Enables the planner's use of gather merge plans. | server |
| pg_settings_enable_hashagg | Enables the planner's use of hashed aggregation plans. | server |
| pg_settings_enable_hashjoin | Enables the planner's use of hash join plans. | server |
| pg_settings_enable_incremental_sort | Enables the planner's use of incremental sort steps. | server |
| pg_settings_enable_indexonlyscan | Enables the planner's use of index-only-scan plans. | server |
| pg_settings_enable_indexscan | Enables the planner's use of index-scan plans. | server |
| pg_settings_enable_material | Enables the planner's use of materialization. | server |
| pg_settings_enable_mergejoin | Enables the planner's use of merge join plans. | server |
| pg_settings_enable_nestloop | Enables the planner's use of nested-loop join plans. | server |
| pg_settings_enable_parallel_append | Enables the planner's use of parallel append plans. | server |
| pg_settings_enable_parallel_hash | Enables the planner's use of parallel hash plans. | server |
| pg_settings_enable_partition_pruning | Enables plan-time and run-time partition pruning. | server |
| pg_settings_enable_partitionwise_aggregate | Enables partitionwise aggregation and grouping. | server |
| pg_settings_enable_partitionwise_join | Enables partitionwise join. | server |
| pg_settings_enable_seqscan | Enables the planner's use of sequential-scan plans. | server |
| pg_settings_enable_sort | Enables the planner's use of explicit sort steps. | server |
| pg_settings_enable_tidscan | Enables the planner's use of TID scan plans. | server |
| pg_settings_escape_string_warning | Warn about backslash escapes in ordinary string literals. | server |
| pg_settings_exit_on_error | Terminate session on any error. | server |
| pg_settings_extra_float_digits | Sets the number of digits displayed for floating-point values. | server |
| pg_settings_from_collapse_limit | Sets the FROM-list size beyond which subqueries are not collapsed. | server |
| pg_settings_fsync | Forces synchronization of updates to disk. | server |
| pg_settings_full_page_writes | Writes full pages to WAL when first modified after a checkpoint. | server |
| pg_settings_geqo | Enables genetic query optimization. | server |
| pg_settings_geqo_effort | GEQO: effort is used to set the default for other GEQO parameters. | server |
| pg_settings_geqo_generations | GEQO: number of iterations of the algorithm. | server |
| pg_settings_geqo_pool_size | GEQO: number of individuals in the population. | server |
| pg_settings_geqo_seed | GEQO: seed for random path selection. | server |
| pg_settings_geqo_selection_bias | GEQO: selective pressure within the population. | server |
| pg_settings_geqo_threshold | Sets the threshold of FROM items beyond which GEQO is used. | server |
| pg_settings_gin_fuzzy_search_limit | Sets the maximum allowed result for exact search by GIN. | server |
| pg_settings_gin_pending_list_limit_bytes | Sets the maximum size of the pending list for GIN index. [Units converted to bytes.] | server |
| pg_settings_hash_mem_multiplier | Multiple of work_mem to use for hash tables. | server |
| pg_settings_hot_standby | Allows connections and queries during recovery. | server |
| pg_settings_hot_standby_feedback | Allows feedback from a hot standby to the primary that will avoid query conflicts. | server |
| pg_settings_idle_in_transaction_session_timeout_seconds | Sets the maximum allowed duration of any idling transaction. [Units converted to seconds.] | server |
| pg_settings_ignore_checksum_failure | Continues processing after a checksum failure. | server |
| pg_settings_ignore_invalid_pages | Continues recovery after an invalid pages failure. | server |
| pg_settings_ignore_system_indexes | Disables reading from system indexes. | server |
| pg_settings_integer_datetimes | Datetimes are integer based. | server |
| pg_settings_jit | Allow JIT compilation. | server |
| pg_settings_jit_above_cost | Perform JIT compilation if query is more expensive. | server |
| pg_settings_jit_debugging_support | Register JIT compiled function with debugger. | server |
| pg_settings_jit_dump_bitcode | Write out LLVM bitcode to facilitate JIT debugging. | server |
| pg_settings_jit_expressions | Allow JIT compilation of expressions. | server |
| pg_settings_jit_inline_above_cost | Perform JIT inlining if query is more expensive. | server |
| pg_settings_jit_optimize_above_cost | Optimize JITed functions if query is more expensive. | server |
| pg_settings_jit_profiling_support | Register JIT compiled function with perf profiler. | server |
| pg_settings_jit_tuple_deforming | Allow JIT compilation of tuple deforming. | server |
| pg_settings_join_collapse_limit | Sets the FROM-list size beyond which JOIN constructs are not flattened. | server |
| pg_settings_krb_caseins_users | Sets whether Kerberos and GSSAPI user names should be treated as case-insensitive. | server |
| pg_settings_lo_compat_privileges | Enables backward compatibility mode for privilege checks on large objects. | server |
| pg_settings_lock_timeout_seconds | Sets the maximum allowed duration of any wait for a lock. [Units converted to seconds.] | server |
| pg_settings_log_autovacuum_min_duration_seconds | Sets the minimum execution time above which autovacuum actions will be logged. [Units converted to seconds.] | server |
| pg_settings_log_checkpoints | Logs each checkpoint. | server |
| pg_settings_log_connections | Logs each successful connection. | server |
| pg_settings_log_disconnections | Logs end of a session, including duration. | server |
| pg_settings_log_duration | Logs the duration of each completed SQL statement. | server |
| pg_settings_log_executor_stats | Writes executor performance statistics to the server log. | server |
| pg_settings_log_file_mode | Sets the file permissions for log files. | server |
| pg_settings_log_hostname | Logs the host name in the connection logs. | server |
| pg_settings_log_lock_waits | Logs long lock waits. | server |
| pg_settings_log_min_duration_sample_seconds | Sets 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_seconds | Sets the minimum execution time above which all statements will be logged. [Units converted to seconds.] | server |
| pg_settings_log_parameter_max_length_bytes | When logging statements, limit logged parameter values to first N bytes. [Units converted to bytes.] | server |
| pg_settings_log_parameter_max_length_on_error_bytes | When reporting an error, limit logged parameter values to first N bytes. [Units converted to bytes.] | server |
| pg_settings_log_parser_stats | Writes parser performance statistics to the server log. | server |
| pg_settings_log_planner_stats | Writes planner performance statistics to the server log. | server |
| pg_settings_log_replication_commands | Logs each replication command. | server |
| pg_settings_log_rotation_age_seconds | Automatic log file rotation will occur after N minutes. [Units converted to seconds.] | server |
| pg_settings_log_rotation_size_bytes | Automatic log file rotation will occur after N kilobytes. [Units converted to bytes.] | server |
| pg_settings_log_statement_sample_rate | Fraction of statements exceeding log_min_duration_sample to be logged. | server |
| pg_settings_log_statement_stats | Writes cumulative performance statistics to the server log. | server |
| pg_settings_log_temp_files_bytes | Log the use of temporary files larger than this number of kilobytes. [Units converted to bytes.] | server |
| pg_settings_log_transaction_sample_rate | Set the fraction of transactions to log for new transactions. | server |
| pg_settings_log_truncate_on_rotation | Truncate existing log files of same name during log rotation. | server |
| pg_settings_logging_collector | Start a subprocess to capture stderr output and/or csvlogs into log files. | server |
| pg_settings_logical_decoding_work_mem_bytes | Sets the maximum memory to be used for logical decoding. [Units converted to bytes.] | server |
| pg_settings_maintenance_io_concurrency | A variant of effective_io_concurrency that is used for maintenance work. | server |
| pg_settings_maintenance_work_mem_bytes | Sets the maximum memory to be used for maintenance operations. [Units converted to bytes.] | server |
| pg_settings_max_connections | Sets the maximum number of concurrent connections. | server |
| pg_settings_max_files_per_process | Sets the maximum number of simultaneously open files for each server process. | server |
| pg_settings_max_function_args | Shows the maximum number of function arguments. | server |
| pg_settings_max_identifier_length | Shows the maximum identifier length. | server |
| pg_settings_max_index_keys | Shows the maximum number of index keys. | server |
| pg_settings_max_locks_per_transaction | Sets the maximum number of locks per transaction. | server |
| pg_settings_max_logical_replication_workers | Maximum number of logical replication worker processes. | server |
| pg_settings_max_parallel_maintenance_workers | Sets the maximum number of parallel processes per maintenance operation. | server |
| pg_settings_max_parallel_workers | Sets the maximum number of parallel workers that can be active at one time. | server |
| pg_settings_max_parallel_workers_per_gather | Sets the maximum number of parallel processes per executor node. | server |
| pg_settings_max_pred_locks_per_page | Sets the maximum number of predicate-locked tuples per page. | server |
| pg_settings_max_pred_locks_per_relation | Sets the maximum number of predicate-locked pages and tuples per relation. | server |
| pg_settings_max_pred_locks_per_transaction | Sets the maximum number of predicate locks per transaction. | server |
| pg_settings_max_prepared_transactions | Sets the maximum number of simultaneously prepared transactions. | server |
| pg_settings_max_replication_slots | Sets the maximum number of simultaneously defined replication slots. | server |
| pg_settings_max_slot_wal_keep_size_bytes | Sets the maximum WAL size that can be reserved by replication slots. [Units converted to bytes.] | server |
| pg_settings_max_stack_depth_bytes | Sets the maximum stack depth, in kilobytes. [Units converted to bytes.] | server |
| pg_settings_max_standby_archive_delay_seconds | Sets 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_seconds | Sets 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_subscription | Maximum number of table synchronization workers per subscription. | server |
| pg_settings_max_wal_senders | Sets the maximum number of simultaneously running WAL sender processes. | server |
| pg_settings_max_wal_size_bytes | Sets the WAL size that triggers a checkpoint. [Units converted to bytes.] | server |
| pg_settings_max_worker_processes | Maximum number of concurrent worker processes. | server |
| pg_settings_min_parallel_index_scan_size_bytes | Sets the minimum amount of index data for a parallel scan. [Units converted to bytes.] | server |
| pg_settings_min_parallel_table_scan_size_bytes | Sets the minimum amount of table data for a parallel scan. [Units converted to bytes.] | server |
| pg_settings_min_wal_size_bytes | Sets the minimum size to shrink the WAL to. [Units converted to bytes.] | server |
| pg_settings_old_snapshot_threshold_seconds | Time before a snapshot is too old to read pages changed after the snapshot was taken. [Units converted to seconds.] | server |
| pg_settings_operator_precedence_warning | Emit a warning for constructs that changed meaning since PostgreSQL 9.4. | server |
| pg_settings_parallel_leader_participation | Controls whether Gather and Gather Merge also run subplans. | server |
| pg_settings_parallel_setup_cost | Sets the planner's estimate of the cost of starting up worker processes for parallel query. | server |
| pg_settings_parallel_tuple_cost | Sets the planner's estimate of the cost of passing each tuple (row) from worker to master backend. | server |
| pg_settings_port | Sets the TCP port the server listens on. | server |
| pg_settings_post_auth_delay_seconds | Waits N seconds on connection startup after authentication. [Units converted to seconds.] | server |
| pg_settings_pre_auth_delay_seconds | Waits N seconds on connection startup before authentication. [Units converted to seconds.] | server |
| pg_settings_quote_all_identifiers | When generating SQL fragments, quote all identifiers. | server |
| pg_settings_random_page_cost | Sets the planner's estimate of the cost of a nonsequentially fetched disk page. | server |
| pg_settings_recovery_min_apply_delay_seconds | Sets the minimum delay for applying changes during recovery. [Units converted to seconds.] | server |
| pg_settings_recovery_target_inclusive | Sets whether to include or exclude transaction with recovery target. | server |
| pg_settings_restart_after_crash | Reinitialize server after backend crash. | server |
| pg_settings_row_security | Enable row security. | server |
| pg_settings_segment_size_bytes | Shows the number of pages per disk file. [Units converted to bytes.] | server |
| pg_settings_seq_page_cost | Sets the planner's estimate of the cost of a sequentially fetched disk page. | server |
| pg_settings_server_version_num | Shows the server version as an integer. | server |
| pg_settings_shared_buffers_bytes | Sets the number of shared memory buffers used by the server. [Units converted to bytes.] | server |
| pg_settings_ssl | Enables SSL connections. | server |
| pg_settings_ssl_passphrase_command_supports_reload | Also use ssl_passphrase_command during server reload. | server |
| pg_settings_ssl_prefer_server_ciphers | Give priority to server ciphersuite order. | server |
| pg_settings_standard_conforming_strings | Causes '...' strings to treat backslashes literally. | server |
| pg_settings_statement_timeout_seconds | Sets the maximum allowed duration of any statement. [Units converted to seconds.] | server |
| pg_settings_superuser_reserved_connections | Sets the number of connection slots reserved for superusers. | server |
| pg_settings_synchronize_seqscans | Enable synchronized sequential scans. | server |
| pg_settings_syslog_sequence_numbers | Add sequence number to syslog messages to avoid duplicate suppression. | server |
| pg_settings_syslog_split_messages | Split messages sent to syslog by lines and to fit into 1024 bytes. | server |
| pg_settings_tcp_keepalives_count | Maximum number of TCP keepalive retransmits. | server |
| pg_settings_tcp_keepalives_idle_seconds | Time between issuing TCP keepalives. [Units converted to seconds.] | server |
| pg_settings_tcp_keepalives_interval_seconds | Time between TCP keepalive retransmits. [Units converted to seconds.] | server |
| pg_settings_tcp_user_timeout_seconds | TCP user timeout. [Units converted to seconds.] | server |
| pg_settings_temp_buffers_bytes | Sets the maximum number of temporary buffers used by each session. [Units converted to bytes.] | server |
| pg_settings_temp_file_limit_bytes | Limits the total size of all temporary files used by each process. [Units converted to bytes.] | server |
| pg_settings_trace_notify | Generates debugging output for LISTEN and NOTIFY. | server |
| pg_settings_trace_sort | Emit information about resource usage in sorting. | server |
| pg_settings_track_activities | Collects information about executing commands. | server |
| pg_settings_track_activity_query_size_bytes | Sets the size reserved for pg_stat_activity.query, in bytes. [Units converted to bytes.] | server |
| pg_settings_track_commit_timestamp | Collects transaction commit time. | server |
| pg_settings_track_counts | Collects statistics on database activity. | server |
| pg_settings_track_io_timing | Collects timing statistics for database I/O activity. | server |
| pg_settings_transaction_deferrable | Whether to defer a read-only serializable transaction until it can be executed with no possible serialization failures. | server |
| pg_settings_transaction_read_only | Sets the current transaction's read-only status. | server |
| pg_settings_transform_null_equals | Treats "expr=NULL" as "expr IS NULL". | server |
| pg_settings_unix_socket_permissions | Sets the access permissions of the Unix-domain socket. | server |
| pg_settings_update_process_title | Updates the process title to show the active SQL command. | server |
| pg_settings_vacuum_cleanup_index_scale_factor | Number of tuple inserts prior to index cleanup as a fraction of reltuples. | server |
| pg_settings_vacuum_cost_delay_seconds | Vacuum cost delay in milliseconds. [Units converted to seconds.] | server |
| pg_settings_vacuum_cost_limit | Vacuum cost amount available before napping. | server |
| pg_settings_vacuum_cost_page_dirty | Vacuum cost for a page dirtied by vacuum. | server |
| pg_settings_vacuum_cost_page_hit | Vacuum cost for a page found in the buffer cache. | server |
| pg_settings_vacuum_cost_page_miss | Vacuum cost for a page not found in the buffer cache. | server |
| pg_settings_vacuum_defer_cleanup_age | Number of transactions by which VACUUM and HOT cleanup should be deferred, if any. | server |
| pg_settings_vacuum_freeze_min_age | Minimum age at which VACUUM should freeze a table row. | server |
| pg_settings_vacuum_freeze_table_age | Age at which VACUUM should scan whole table to freeze tuples. | server |
| pg_settings_vacuum_multixact_freeze_min_age | Minimum age at which VACUUM should freeze a MultiXactId in a table row. | server |
| pg_settings_vacuum_multixact_freeze_table_age | Multixact age at which VACUUM should scan whole table to freeze tuples. | server |
| pg_settings_wal_block_size | Shows the block size in the write ahead log. | server |
| pg_settings_wal_buffers_bytes | Sets the number of disk-page buffers in shared memory for WAL. [Units converted to bytes.] | server |
| pg_settings_wal_compression | Compresses full-page writes written in WAL file. | server |
| pg_settings_wal_init_zero | Writes zeroes to new WAL files before first use. | server |
| pg_settings_wal_keep_size_bytes | Sets the size of WAL files held for standby servers. [Units converted to bytes.] | server |
| pg_settings_wal_log_hints | Writes full pages to WAL when first modified after a checkpoint, even for a non-critical modifications. | server |
| pg_settings_wal_receiver_create_temp_slot | Sets whether a WAL receiver should create a temporary replication slot if no permanent slot is configured. | server |
| pg_settings_wal_receiver_status_interval_seconds | Sets the maximum interval between WAL receiver status reports to the sending server. [Units converted to seconds.] | server |
| pg_settings_wal_receiver_timeout_seconds | Sets the maximum wait time to receive data from the sending server. [Units converted to seconds.] | server |
| pg_settings_wal_recycle | Recycles WAL files by renaming them. | server |
| pg_settings_wal_retrieve_retry_interval_seconds | Sets the time to wait before retrying to retrieve WAL after a failed attempt. [Units converted to seconds.] | server |
| pg_settings_wal_segment_size_bytes | Shows the size of write ahead log segments. [Units converted to bytes.] | server |
| pg_settings_wal_sender_timeout_seconds | Sets the maximum time to wait for WAL replication. [Units converted to seconds.] | server |
| pg_settings_wal_skip_threshold_bytes | Size of new file to fsync instead of writing WAL. [Units converted to bytes.] | server |
| pg_settings_wal_writer_delay_seconds | Time between WAL flushes performed in the WAL writer. [Units converted to seconds.] | server |
| pg_settings_wal_writer_flush_after_bytes | Amount of WAL written out by WAL writer that triggers a flush. [Units converted to bytes.] | server |
| pg_settings_work_mem_bytes | Sets the maximum memory to be used for query workspaces. [Units converted to bytes.] | server |
| pg_settings_zero_damaged_pages | Continues processing past damaged page headers. | server |
| pg_stat_activity_count | number of connections in this state | datname, server, state |
| pg_stat_activity_max_tx_duration | max duration in seconds any active transaction has been running | datname, server, state |
| pg_stat_archiver_archived_count | Number of WAL files that have been successfully archived | server |
| pg_stat_archiver_failed_count | Number of failed attempts for archiving WAL files | server |
| pg_stat_archiver_last_archive_age | Time in seconds since last WAL segment was successfully archived | server |
| pg_stat_bgwriter_buffers_alloc | Number of buffers allocated | server |
| pg_stat_bgwriter_buffers_backend | Number of buffers written directly by a backend | server |
| pg_stat_bgwriter_buffers_backend_fsync | Number 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_checkpoint | Number of buffers written during checkpoints | server |
| pg_stat_bgwriter_buffers_clean | Number of buffers written by the background writer | server |
| pg_stat_bgwriter_checkpoint_sync_time | Total amount of time that has been spent in the portion of checkpoint processing where files are synchronized to disk, in milliseconds | server |
| pg_stat_bgwriter_checkpoint_write_time | Total amount of time that has been spent in the portion of checkpoint processing where files are written to disk, in milliseconds | server |
| pg_stat_bgwriter_checkpoints_req | Number of requested checkpoints that have been performed | server |
| pg_stat_bgwriter_checkpoints_timed | Number of scheduled checkpoints that have been performed | server |
| pg_stat_bgwriter_maxwritten_clean | Number of times the background writer stopped a cleaning scan because it had written too many buffers | server |
| pg_stat_bgwriter_stats_reset | Time at which these statistics were last reset | server |
| pg_stat_database_blk_read_time | Time spent reading data file blocks by backends in this database, in milliseconds | datid, datname, server |
| pg_stat_database_blk_write_time | Time spent writing data file blocks by backends in this database, in milliseconds | datid, datname, server |
| pg_stat_database_blks_hit | Number 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_read | Number of disk blocks read in this database | datid, datname, server |
| pg_stat_database_checksum_failures | Unknown metric from pg_stat_database | datid, datname, server |
| pg_stat_database_checksum_last_failure | Unknown metric from pg_stat_database | datid, datname, server |
| pg_stat_database_conflicts | Number 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_bufferpin | Number of queries in this database that have been canceled due to pinned buffers | datid, datname, server |
| pg_stat_database_conflicts_confl_deadlock | Number of queries in this database that have been canceled due to deadlocks | datid, datname, server |
| pg_stat_database_conflicts_confl_lock | Number of queries in this database that have been canceled due to lock timeouts | datid, datname, server |
| pg_stat_database_conflicts_confl_snapshot | Number of queries in this database that have been canceled due to old snapshots | datid, datname, server |
| pg_stat_database_conflicts_confl_tablespace | Number of queries in this database that have been canceled due to dropped tablespaces | datid, datname, server |
| pg_stat_database_deadlocks | Number of deadlocks detected in this database | datid, datname, server |
| pg_stat_database_numbackends | Number 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_reset | Time at which these statistics were last reset | datid, datname, server |
| pg_stat_database_temp_bytes | Total 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_files | Number 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_deleted | Number of rows deleted by queries in this database | datid, datname, server |
| pg_stat_database_tup_fetched | Number of rows fetched by queries in this database | datid, datname, server |
| pg_stat_database_tup_inserted | Number of rows inserted by queries in this database | datid, datname, server |
| pg_stat_database_tup_returned | Number of rows returned by queries in this database | datid, datname, server |
| pg_stat_database_tup_updated | Number of rows updated by queries in this database | datid, datname, server |
| pg_stat_database_xact_commit | Number of transactions in this database that have been committed | datid, datname, server |
| pg_stat_database_xact_rollback | Number of transactions in this database that have been rolled back | datid, datname, server |
| pg_static | Version string as reported by postgres | server, short_version, version |
| pg_up | Whether the last scrape of metrics from PostgreSQL was able to connect to the server (1 for yes, 0 for no). | |
| postgres_exporter_build_info | A 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_flight | Current number of scrapes being served. | |
| promhttp_metric_handler_requests_total | Total number of scrapes by HTTP status code. | code |