Skip to content

Latest commit

 

History

History
521 lines (497 loc) · 38.9 KB

prometheus-postgres.md

File metadata and controls

521 lines (497 loc) · 38.9 KB

prometheus/postgres

This monitor scrapes Prmoetheus PostgreSQL Server Exporter metrics and sends them to SignalFx. It is a wrapper around the prometheus-exporter monitor that provides a restricted but expandable set of metrics.

Monitor Type: prometheus/postgres

Monitor Source Code

Accepts Endpoints: Yes

Multiple Instances Allowed: Yes

Configuration

Config option Required Type Description
host yes string Host of the exporter
port yes integer Port of the exporter
useHTTPS no bool If true, the agent will connect to the exporter using HTTPS instead of plain HTTP. (default: false)
skipVerify no bool If useHTTPS is true and this option is also true, the exporter's TLS cert will not be verified. (default: false)
metricPath no string Path to the metrics endpoint on the exporter server, usually /metrics (the default). (default: /metrics)
sendAllMetrics no bool Send all the metrics that come out of the Prometheus exporter without any filtering. This option has no effect when using the prometheus exporter monitor directly since there is no built-in filtering, only when embedding it in other monitors. (default: false)

Metrics

The following table lists the metrics available for this monitor. Metrics that are marked as Included are standard metrics and are monitored by default.

Name Type Included Description
pg_exporter_last_scrape_duration_seconds gauge Duration of the last scrape of metrics from PostgresSQL.
pg_exporter_last_scrape_error gauge Whether the last scrape of metrics from PostgreSQL resulted in an error (1 for error, 0 for success).
pg_exporter_scrapes_total cumulative Total number of times PostgresSQL was scraped for metrics.
pg_exporter_user_queries_load_error gauge Whether the user queries file was loaded and parsed successfully (1 for error, 0 for success).
pg_locks_count gauge Number of locks
pg_postmaster_start_time_seconds gauge Time at which postmaster started
pg_replication_is_replica gauge Indicates if this host is a slave
pg_replication_lag gauge Replication lag behind master in seconds
pg_settings_allow_system_table_mods gauge Allows modifications of the structure of system tables.
pg_settings_archive_timeout_seconds gauge Forces a switch to the next xlog file if a new file has not been started within N seconds. [Units converted to seconds.]
pg_settings_array_nulls gauge Enable input of NULL elements in arrays.
pg_settings_authentication_timeout_seconds gauge Sets the maximum allowed time to complete client authentication. [Units converted to seconds.]
pg_settings_autovacuum gauge Starts the autovacuum subprocess.
pg_settings_autovacuum_analyze_scale_factor gauge Number of tuple inserts, updates, or deletes prior to analyze as a fraction of reltuples.
pg_settings_autovacuum_analyze_threshold gauge Minimum number of tuple inserts, updates, or deletes prior to analyze.
pg_settings_autovacuum_freeze_max_age gauge Age at which to autovacuum a table to prevent transaction ID wraparound.
pg_settings_autovacuum_max_workers gauge Sets the maximum number of simultaneously running autovacuum worker processes.
pg_settings_autovacuum_multixact_freeze_max_age gauge Multixact age at which to autovacuum a table to prevent multixact wraparound.
pg_settings_autovacuum_naptime_seconds gauge Time to sleep between autovacuum runs. [Units converted to seconds.]
pg_settings_autovacuum_vacuum_cost_delay_seconds gauge Vacuum cost delay in milliseconds, for autovacuum. [Units converted to seconds.]
pg_settings_autovacuum_vacuum_cost_limit gauge Vacuum cost amount available before napping, for autovacuum.
pg_settings_autovacuum_vacuum_scale_factor gauge Number of tuple updates or deletes prior to vacuum as a fraction of reltuples.
pg_settings_autovacuum_vacuum_threshold gauge Minimum number of tuple updates or deletes prior to vacuum.
pg_settings_autovacuum_work_mem_bytes gauge Sets the maximum memory to be used by each autovacuum worker process. [Units converted to bytes.]
pg_settings_backend_flush_after_bytes gauge Number of pages after which previously performed writes are flushed to disk. [Units converted to bytes.]
pg_settings_bgwriter_delay_seconds gauge Background writer sleep time between rounds. [Units converted to seconds.]
pg_settings_bgwriter_flush_after_bytes gauge Number of pages after which previously performed writes are flushed to disk. [Units converted to bytes.]
pg_settings_bgwriter_lru_maxpages gauge Background writer maximum number of LRU pages to flush per round.
pg_settings_bgwriter_lru_multiplier gauge Multiple of the average buffer usage to free per round.
pg_settings_block_size gauge Shows the size of a disk block.
pg_settings_bonjour gauge Enables advertising the server via Bonjour.
pg_settings_check_function_bodies gauge Check function bodies during CREATE FUNCTION.
pg_settings_checkpoint_completion_target gauge Time spent flushing dirty buffers during checkpoint, as fraction of checkpoint interval.
pg_settings_checkpoint_flush_after_bytes gauge Number of pages after which previously performed writes are flushed to disk. [Units converted to bytes.]
pg_settings_checkpoint_timeout_seconds gauge Sets the maximum time between automatic WAL checkpoints. [Units converted to seconds.]
pg_settings_checkpoint_warning_seconds gauge Enables warnings if checkpoint segments are filled more frequently than this. [Units converted to seconds.]
pg_settings_commit_delay gauge Sets the delay in microseconds between transaction commit and flushing WAL to disk.
pg_settings_commit_siblings gauge Sets the minimum concurrent open transactions before performing commit_delay.
pg_settings_cpu_index_tuple_cost gauge Sets the planner's estimate of the cost of processing each index entry during an index scan.
pg_settings_cpu_operator_cost gauge Sets the planner's estimate of the cost of processing each operator or function call.
pg_settings_cpu_tuple_cost gauge Sets the planner's estimate of the cost of processing each tuple (row).
pg_settings_cursor_tuple_fraction gauge Sets the planner's estimate of the fraction of a cursor's rows that will be retrieved.
pg_settings_data_checksums gauge Shows whether data checksums are turned on for this cluster.
pg_settings_db_user_namespace gauge Enables per-database user names.
pg_settings_deadlock_timeout_seconds gauge Sets the time to wait on a lock before checking for deadlock. [Units converted to seconds.]
pg_settings_debug_assertions gauge Shows whether the running server has assertion checks enabled.
pg_settings_debug_pretty_print gauge Indents parse and plan tree displays.
pg_settings_debug_print_parse gauge Logs each query's parse tree.
pg_settings_debug_print_plan gauge Logs each query's execution plan.
pg_settings_debug_print_rewritten gauge Logs each query's rewritten parse tree.
pg_settings_default_statistics_target gauge Sets the default statistics target.
pg_settings_default_transaction_deferrable gauge Sets the default deferrable status of new transactions.
pg_settings_default_transaction_read_only gauge Sets the default read-only status of new transactions.
pg_settings_default_with_oids gauge Create new tables with OIDs by default.
pg_settings_effective_cache_size_bytes gauge Sets the planner's assumption about the size of the data cache. [Units converted to bytes.]
pg_settings_effective_io_concurrency gauge Number of simultaneous requests that can be handled efficiently by the disk subsystem.
pg_settings_enable_bitmapscan gauge Enables the planner's use of bitmap-scan plans.
pg_settings_enable_hashagg gauge Enables the planner's use of hashed aggregation plans.
pg_settings_enable_hashjoin gauge Enables the planner's use of hash join plans.
pg_settings_enable_indexonlyscan gauge Enables the planner's use of index-only-scan plans.
pg_settings_enable_indexscan gauge Enables the planner's use of index-scan plans.
pg_settings_enable_material gauge Enables the planner's use of materialization.
pg_settings_enable_mergejoin gauge Enables the planner's use of merge join plans.
pg_settings_enable_nestloop gauge Enables the planner's use of nested-loop join plans.
pg_settings_enable_seqscan gauge Enables the planner's use of sequential-scan plans.
pg_settings_enable_sort gauge Enables the planner's use of explicit sort steps.
pg_settings_enable_tidscan gauge Enables the planner's use of TID scan plans.
pg_settings_escape_string_warning gauge Warn about backslash escapes in ordinary string literals.
pg_settings_exit_on_error gauge Terminate session on any error.
pg_settings_extra_float_digits gauge Sets the number of digits displayed for floating-point values.
pg_settings_from_collapse_limit gauge Sets the FROM-list size beyond which subqueries are not collapsed.
pg_settings_fsync gauge Forces synchronization of updates to disk.
pg_settings_full_page_writes gauge Writes full pages to WAL when first modified after a checkpoint.
pg_settings_geqo gauge Enables genetic query optimization.
pg_settings_geqo_effort gauge GEQO: effort is used to set the default for other GEQO parameters.
pg_settings_geqo_generations gauge GEQO: number of iterations of the algorithm.
pg_settings_geqo_pool_size gauge GEQO: number of individuals in the population.
pg_settings_geqo_seed gauge GEQO: seed for random path selection.
pg_settings_geqo_selection_bias gauge GEQO: selective pressure within the population.
pg_settings_geqo_threshold gauge Sets the threshold of FROM items beyond which GEQO is used.
pg_settings_gin_fuzzy_search_limit gauge Sets the maximum allowed result for exact search by GIN.
pg_settings_gin_pending_list_limit_bytes gauge Sets the maximum size of the pending list for GIN index. [Units converted to bytes.]
pg_settings_hot_standby gauge Allows connections and queries during recovery.
pg_settings_hot_standby_feedback gauge Allows feedback from a hot standby to the primary that will avoid query conflicts.
pg_settings_idle_in_transaction_session_timeout_seconds gauge Sets the maximum allowed duration of any idling transaction. [Units converted to seconds.]
pg_settings_ignore_checksum_failure gauge Continues processing after a checksum failure.
pg_settings_ignore_system_indexes gauge Disables reading from system indexes.
pg_settings_integer_datetimes gauge Datetimes are integer based.
pg_settings_join_collapse_limit gauge Sets the FROM-list size beyond which JOIN constructs are not flattened.
pg_settings_krb_caseins_users gauge Sets whether Kerberos and GSSAPI user names should be treated as case-insensitive.
pg_settings_lo_compat_privileges gauge Enables backward compatibility mode for privilege checks on large objects.
pg_settings_lock_timeout_seconds gauge Sets the maximum allowed duration of any wait for a lock. [Units converted to seconds.]
pg_settings_log_autovacuum_min_duration_seconds gauge Sets the minimum execution time above which autovacuum actions will be logged. [Units converted to seconds.]
pg_settings_log_checkpoints gauge Logs each checkpoint.
pg_settings_log_connections gauge Logs each successful connection.
pg_settings_log_disconnections gauge Logs end of a session, including duration.
pg_settings_log_duration gauge Logs the duration of each completed SQL statement.
pg_settings_log_executor_stats gauge Writes executor performance statistics to the server log.
pg_settings_log_file_mode gauge Sets the file permissions for log files.
pg_settings_log_hostname gauge Logs the host name in the connection logs.
pg_settings_log_lock_waits gauge Logs long lock waits.
pg_settings_log_min_duration_statement_seconds gauge Sets the minimum execution time above which statements will be logged. [Units converted to seconds.]
pg_settings_log_parser_stats gauge Writes parser performance statistics to the server log.
pg_settings_log_planner_stats gauge Writes planner performance statistics to the server log.
pg_settings_log_replication_commands gauge Logs each replication command.
pg_settings_log_rotation_age_seconds gauge Automatic log file rotation will occur after N minutes. [Units converted to seconds.]
pg_settings_log_rotation_size_bytes gauge Automatic log file rotation will occur after N kilobytes. [Units converted to bytes.]
pg_settings_log_statement_stats gauge Writes cumulative performance statistics to the server log.
pg_settings_log_temp_files_bytes gauge Log the use of temporary files larger than this number of kilobytes. [Units converted to bytes.]
pg_settings_log_truncate_on_rotation gauge Truncate existing log files of same name during log rotation.
pg_settings_logging_collector gauge Start a subprocess to capture stderr output and/or csvlogs into log files.
pg_settings_maintenance_work_mem_bytes gauge Sets the maximum memory to be used for maintenance operations. [Units converted to bytes.]
pg_settings_max_connections gauge Sets the maximum number of concurrent connections.
pg_settings_max_files_per_process gauge Sets the maximum number of simultaneously open files for each server process.
pg_settings_max_function_args gauge Shows the maximum number of function arguments.
pg_settings_max_identifier_length gauge Shows the maximum identifier length.
pg_settings_max_index_keys gauge Shows the maximum number of index keys.
pg_settings_max_locks_per_transaction gauge Sets the maximum number of locks per transaction.
pg_settings_max_parallel_workers_per_gather gauge Sets the maximum number of parallel processes per executor node.
pg_settings_max_pred_locks_per_transaction gauge Sets the maximum number of predicate locks per transaction.
pg_settings_max_prepared_transactions gauge Sets the maximum number of simultaneously prepared transactions.
pg_settings_max_replication_slots gauge Sets the maximum number of simultaneously defined replication slots.
pg_settings_max_stack_depth_bytes gauge Sets the maximum stack depth, in kilobytes. [Units converted to bytes.]
pg_settings_max_standby_archive_delay_seconds gauge Sets the maximum delay before canceling queries when a hot standby server is processing archived WAL data. [Units converted to seconds.]
pg_settings_max_standby_streaming_delay_seconds gauge Sets the maximum delay before canceling queries when a hot standby server is processing streamed WAL data. [Units converted to seconds.]
pg_settings_max_wal_senders gauge Sets the maximum number of simultaneously running WAL sender processes.
pg_settings_max_wal_size_bytes gauge Sets the WAL size that triggers a checkpoint. [Units converted to bytes.]
pg_settings_max_worker_processes gauge Maximum number of concurrent worker processes.
pg_settings_min_parallel_relation_size_bytes gauge Sets the minimum size of relations to be considered for parallel scan. [Units converted to bytes.]
pg_settings_min_wal_size_bytes gauge Sets the minimum size to shrink the WAL to. [Units converted to bytes.]
pg_settings_old_snapshot_threshold_seconds gauge Time before a snapshot is too old to read pages changed after the snapshot was taken. [Units converted to seconds.]
pg_settings_operator_precedence_warning gauge Emit a warning for constructs that changed meaning since PostgreSQL 9.4.
pg_settings_parallel_setup_cost gauge Sets the planner's estimate of the cost of starting up worker processes for parallel query.
pg_settings_parallel_tuple_cost gauge Sets the planner's estimate of the cost of passing each tuple (row) from worker to master backend.
pg_settings_password_encryption gauge Encrypt passwords.
pg_settings_port gauge Sets the TCP port the server listens on.
pg_settings_post_auth_delay_seconds gauge Waits N seconds on connection startup after authentication. [Units converted to seconds.]
pg_settings_pre_auth_delay_seconds gauge Waits N seconds on connection startup before authentication. [Units converted to seconds.]
pg_settings_quote_all_identifiers gauge When generating SQL fragments, quote all identifiers.
pg_settings_random_page_cost gauge Sets the planner's estimate of the cost of a nonsequentially fetched disk page.
pg_settings_replacement_sort_tuples gauge Sets the maximum number of tuples to be sorted using replacement selection.
pg_settings_restart_after_crash gauge Reinitialize server after backend crash.
pg_settings_row_security gauge Enable row security.
pg_settings_segment_size_bytes gauge Shows the number of pages per disk file. [Units converted to bytes.]
pg_settings_seq_page_cost gauge Sets the planner's estimate of the cost of a sequentially fetched disk page.
pg_settings_server_version_num gauge Shows the server version as an integer.
pg_settings_shared_buffers_bytes gauge Sets the number of shared memory buffers used by the server. [Units converted to bytes.]
pg_settings_sql_inheritance gauge Causes subtables to be included by default in various commands.
pg_settings_ssl gauge Enables SSL connections.
pg_settings_ssl_prefer_server_ciphers gauge Give priority to server ciphersuite order.
pg_settings_standard_conforming_strings gauge Causes '...' strings to treat backslashes literally.
pg_settings_statement_timeout_seconds gauge Sets the maximum allowed duration of any statement. [Units converted to seconds.]
pg_settings_superuser_reserved_connections gauge Sets the number of connection slots reserved for superusers.
pg_settings_synchronize_seqscans gauge Enable synchronized sequential scans.
pg_settings_syslog_sequence_numbers gauge Add sequence number to syslog messages to avoid duplicate suppression.
pg_settings_syslog_split_messages gauge Split messages sent to syslog by lines and to fit into 1024 bytes.
pg_settings_tcp_keepalives_count gauge Maximum number of TCP keepalive retransmits.
pg_settings_tcp_keepalives_idle_seconds gauge Time between issuing TCP keepalives. [Units converted to seconds.]
pg_settings_tcp_keepalives_interval_seconds gauge Time between TCP keepalive retransmits. [Units converted to seconds.]
pg_settings_temp_buffers_bytes gauge Sets the maximum number of temporary buffers used by each session. [Units converted to bytes.]
pg_settings_temp_file_limit_bytes gauge Limits the total size of all temporary files used by each process. [Units converted to bytes.]
pg_settings_trace_notify gauge Generates debugging output for LISTEN and NOTIFY.
pg_settings_trace_sort gauge Emit information about resource usage in sorting.
pg_settings_track_activities gauge Collects information about executing commands.
pg_settings_track_activity_query_size gauge Sets the size reserved for pg_stat_activity.query, in bytes.
pg_settings_track_commit_timestamp gauge Collects transaction commit time.
pg_settings_track_counts gauge Collects statistics on database activity.
pg_settings_track_io_timing gauge Collects timing statistics for database I/O activity.
pg_settings_transaction_deferrable gauge Whether to defer a read-only serializable transaction until it can be executed with no possible serialization failures.
pg_settings_transaction_read_only gauge Sets the current transaction's read-only status.
pg_settings_transform_null_equals gauge Treats "expr=NULL" as "expr IS NULL".
pg_settings_unix_socket_permissions gauge Sets the access permissions of the Unix-domain socket.
pg_settings_update_process_title gauge Updates the process title to show the active SQL command.
pg_settings_vacuum_cost_delay_seconds gauge Vacuum cost delay in milliseconds. [Units converted to seconds.]
pg_settings_vacuum_cost_limit gauge Vacuum cost amount available before napping.
pg_settings_vacuum_cost_page_dirty gauge Vacuum cost for a page dirtied by vacuum.
pg_settings_vacuum_cost_page_hit gauge Vacuum cost for a page found in the buffer cache.
pg_settings_vacuum_cost_page_miss gauge Vacuum cost for a page not found in the buffer cache.
pg_settings_vacuum_defer_cleanup_age gauge Number of transactions by which VACUUM and HOT cleanup should be deferred, if any.
pg_settings_vacuum_freeze_min_age gauge Minimum age at which VACUUM should freeze a table row.
pg_settings_vacuum_freeze_table_age gauge Age at which VACUUM should scan whole table to freeze tuples.
pg_settings_vacuum_multixact_freeze_min_age gauge Minimum age at which VACUUM should freeze a MultiXactId in a table row.
pg_settings_vacuum_multixact_freeze_table_age gauge Multixact age at which VACUUM should scan whole table to freeze tuples.
pg_settings_wal_block_size gauge Shows the block size in the write ahead log.
pg_settings_wal_buffers_bytes gauge Sets the number of disk-page buffers in shared memory for WAL. [Units converted to bytes.]
pg_settings_wal_compression gauge Compresses full-page writes written in WAL file.
pg_settings_wal_keep_segments gauge Sets the number of WAL files held for standby servers.
pg_settings_wal_log_hints gauge Writes full pages to WAL when first modified after a checkpoint, even for a non-critical modifications.
pg_settings_wal_receiver_status_interval_seconds gauge Sets the maximum interval between WAL receiver status reports to the primary. [Units converted to seconds.]
pg_settings_wal_receiver_timeout_seconds gauge Sets the maximum wait time to receive data from the primary. [Units converted to seconds.]
pg_settings_wal_retrieve_retry_interval_seconds gauge Sets the time to wait before retrying to retrieve WAL after a failed attempt. [Units converted to seconds.]
pg_settings_wal_segment_size_bytes gauge Shows the number of pages per write ahead log segment. [Units converted to bytes.]
pg_settings_wal_sender_timeout_seconds gauge Sets the maximum time to wait for WAL replication. [Units converted to seconds.]
pg_settings_wal_writer_delay_seconds gauge Time between WAL flushes performed in the WAL writer. [Units converted to seconds.]
pg_settings_wal_writer_flush_after_bytes gauge Amount of WAL written out by WAL writer that triggers a flush. [Units converted to bytes.]
pg_settings_work_mem_bytes gauge Sets the maximum memory to be used for query workspaces. [Units converted to bytes.]
pg_settings_zero_damaged_pages gauge Continues processing past damaged page headers.
pg_slow_queries gauge Current number of slow queries
pg_stat_activity_count gauge Number of connections in this state
pg_stat_activity_max_tx_duration gauge Max duration in seconds any active transaction has been running
pg_stat_bgwriter_buffers_alloc cumulative Number of buffers allocated
pg_stat_bgwriter_buffers_backend cumulative Number of buffers written directly by a backend
pg_stat_bgwriter_buffers_backend_fsync cumulative 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)
pg_stat_bgwriter_buffers_checkpoint cumulative Number of buffers written during checkpoints
pg_stat_bgwriter_buffers_clean cumulative Number of buffers written by the background writer
pg_stat_bgwriter_checkpoint_sync_time cumulative Total amount of time that has been spent in the portion of checkpoint processing where files are synchronized to disk, in milliseconds
pg_stat_bgwriter_checkpoint_write_time cumulative Total amount of time that has been spent in the portion of checkpoint processing where files are written to disk, in milliseconds
pg_stat_bgwriter_checkpoints_req cumulative Number of requested checkpoints that have been performed
pg_stat_bgwriter_checkpoints_timed cumulative Number of scheduled checkpoints that have been performed
pg_stat_bgwriter_maxwritten_clean cumulative Number of times the background writer stopped a cleaning scan because it had written too many buffers
pg_stat_bgwriter_stats_reset cumulative Time at which these statistics were last reset
pg_stat_database_blk_read_time cumulative Time spent reading data file blocks by backends in this database, in milliseconds
pg_stat_database_blk_write_time cumulative Time spent writing data file blocks by backends in this database, in milliseconds
pg_stat_database_blks_hit cumulative 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)
pg_stat_database_blks_read cumulative Number of disk blocks read in this database
pg_stat_database_conflicts cumulative 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.)
pg_stat_database_conflicts_confl_bufferpin cumulative Number of queries in this database that have been canceled due to pinned buffers
pg_stat_database_conflicts_confl_deadlock cumulative Number of queries in this database that have been canceled due to deadlocks
pg_stat_database_conflicts_confl_lock cumulative Number of queries in this database that have been canceled due to lock timeouts
pg_stat_database_conflicts_confl_snapshot cumulative Number of queries in this database that have been canceled due to old snapshots
pg_stat_database_conflicts_confl_tablespace cumulative Number of queries in this database that have been canceled due to dropped tablespaces
pg_stat_database_deadlocks cumulative Number of deadlocks detected in this database
pg_stat_database_numbackends gauge 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.
pg_stat_database_stats_reset cumulative Time at which these statistics were last reset
pg_stat_database_temp_bytes cumulative 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.
pg_stat_database_temp_files cumulative 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.
pg_stat_database_tup_deleted cumulative Number of rows deleted by queries in this database
pg_stat_database_tup_fetched cumulative Number of rows fetched by queries in this database
pg_stat_database_tup_inserted cumulative Number of rows inserted by queries in this database
pg_stat_database_tup_returned cumulative Number of rows returned by queries in this database
pg_stat_database_tup_updated cumulative Number of rows updated by queries in this database
pg_stat_database_xact_commit cumulative Number of transactions in this database that have been committed
pg_stat_database_xact_rollback cumulative Number of transactions in this database that have been rolled back
pg_static gauge Version string as reported by postgres
pg_stuck_idle_in_transaction_queries gauge Current number of queries that are stuck being idle in transactions
pg_total_relation_size_bytes gauge Total disk space usage for the specified table and associated indexes
pg_up gauge Whether the last scrape of metrics from PostgreSQL was able to connect to the server (1 for yes, 0 for no).
pg_vacuum_age_in_seconds gauge The current maximum VACUUM query age in seconds
pg_vacuum_analyze_age_in_seconds gauge The current maximum VACUUM ANALYZE query age in seconds
pg_vacuum_analyze_queries gauge The current number of VACUUM ANALYZE queries
pg_vacuum_queries gauge The current number of VACUUM queries

To specify custom metrics you want to monitor, add a metricsToInclude filter to the agent configuration, as shown in the code snippet below. The snippet lists all available custom metrics. You can copy and paste the snippet into your configuration file, then delete any custom metrics that you do not want sent.

Note that some of the custom metrics require you to set a flag as well as add them to the list. Check the monitor configuration file to see if a flag is required for gathering additional metrics.

metricsToInclude:
  - metricNames:
    - pg_exporter_last_scrape_duration_seconds
    - pg_exporter_last_scrape_error
    - pg_exporter_scrapes_total
    - pg_exporter_user_queries_load_error
    - pg_locks_count
    - pg_postmaster_start_time_seconds
    - pg_replication_is_replica
    - pg_replication_lag
    - pg_settings_allow_system_table_mods
    - pg_settings_archive_timeout_seconds
    - pg_settings_array_nulls
    - pg_settings_authentication_timeout_seconds
    - pg_settings_autovacuum
    - pg_settings_autovacuum_analyze_scale_factor
    - pg_settings_autovacuum_analyze_threshold
    - pg_settings_autovacuum_freeze_max_age
    - pg_settings_autovacuum_max_workers
    - pg_settings_autovacuum_multixact_freeze_max_age
    - pg_settings_autovacuum_naptime_seconds
    - pg_settings_autovacuum_vacuum_cost_delay_seconds
    - pg_settings_autovacuum_vacuum_cost_limit
    - pg_settings_autovacuum_vacuum_scale_factor
    - pg_settings_autovacuum_vacuum_threshold
    - pg_settings_autovacuum_work_mem_bytes
    - pg_settings_backend_flush_after_bytes
    - pg_settings_bgwriter_delay_seconds
    - pg_settings_bgwriter_flush_after_bytes
    - pg_settings_bgwriter_lru_maxpages
    - pg_settings_bgwriter_lru_multiplier
    - pg_settings_block_size
    - pg_settings_bonjour
    - pg_settings_check_function_bodies
    - pg_settings_checkpoint_completion_target
    - pg_settings_checkpoint_flush_after_bytes
    - pg_settings_checkpoint_timeout_seconds
    - pg_settings_checkpoint_warning_seconds
    - pg_settings_commit_delay
    - pg_settings_commit_siblings
    - pg_settings_cpu_index_tuple_cost
    - pg_settings_cpu_operator_cost
    - pg_settings_cpu_tuple_cost
    - pg_settings_cursor_tuple_fraction
    - pg_settings_data_checksums
    - pg_settings_db_user_namespace
    - pg_settings_deadlock_timeout_seconds
    - pg_settings_debug_assertions
    - pg_settings_debug_pretty_print
    - pg_settings_debug_print_parse
    - pg_settings_debug_print_plan
    - pg_settings_debug_print_rewritten
    - pg_settings_default_statistics_target
    - pg_settings_default_transaction_deferrable
    - pg_settings_default_transaction_read_only
    - pg_settings_default_with_oids
    - pg_settings_effective_cache_size_bytes
    - pg_settings_effective_io_concurrency
    - pg_settings_enable_bitmapscan
    - pg_settings_enable_hashagg
    - pg_settings_enable_hashjoin
    - pg_settings_enable_indexonlyscan
    - pg_settings_enable_indexscan
    - pg_settings_enable_material
    - pg_settings_enable_mergejoin
    - pg_settings_enable_nestloop
    - pg_settings_enable_seqscan
    - pg_settings_enable_sort
    - pg_settings_enable_tidscan
    - pg_settings_escape_string_warning
    - pg_settings_exit_on_error
    - pg_settings_extra_float_digits
    - pg_settings_from_collapse_limit
    - pg_settings_fsync
    - pg_settings_full_page_writes
    - pg_settings_geqo
    - pg_settings_geqo_effort
    - pg_settings_geqo_generations
    - pg_settings_geqo_pool_size
    - pg_settings_geqo_seed
    - pg_settings_geqo_selection_bias
    - pg_settings_geqo_threshold
    - pg_settings_gin_fuzzy_search_limit
    - pg_settings_gin_pending_list_limit_bytes
    - pg_settings_hot_standby
    - pg_settings_hot_standby_feedback
    - pg_settings_idle_in_transaction_session_timeout_seconds
    - pg_settings_ignore_checksum_failure
    - pg_settings_ignore_system_indexes
    - pg_settings_integer_datetimes
    - pg_settings_join_collapse_limit
    - pg_settings_krb_caseins_users
    - pg_settings_lo_compat_privileges
    - pg_settings_lock_timeout_seconds
    - pg_settings_log_autovacuum_min_duration_seconds
    - pg_settings_log_checkpoints
    - pg_settings_log_connections
    - pg_settings_log_disconnections
    - pg_settings_log_duration
    - pg_settings_log_executor_stats
    - pg_settings_log_file_mode
    - pg_settings_log_hostname
    - pg_settings_log_lock_waits
    - pg_settings_log_min_duration_statement_seconds
    - pg_settings_log_parser_stats
    - pg_settings_log_planner_stats
    - pg_settings_log_replication_commands
    - pg_settings_log_rotation_age_seconds
    - pg_settings_log_rotation_size_bytes
    - pg_settings_log_statement_stats
    - pg_settings_log_temp_files_bytes
    - pg_settings_log_truncate_on_rotation
    - pg_settings_logging_collector
    - pg_settings_maintenance_work_mem_bytes
    - pg_settings_max_connections
    - pg_settings_max_files_per_process
    - pg_settings_max_function_args
    - pg_settings_max_identifier_length
    - pg_settings_max_index_keys
    - pg_settings_max_locks_per_transaction
    - pg_settings_max_parallel_workers_per_gather
    - pg_settings_max_pred_locks_per_transaction
    - pg_settings_max_prepared_transactions
    - pg_settings_max_replication_slots
    - pg_settings_max_stack_depth_bytes
    - pg_settings_max_standby_archive_delay_seconds
    - pg_settings_max_standby_streaming_delay_seconds
    - pg_settings_max_wal_senders
    - pg_settings_max_wal_size_bytes
    - pg_settings_max_worker_processes
    - pg_settings_min_parallel_relation_size_bytes
    - pg_settings_min_wal_size_bytes
    - pg_settings_old_snapshot_threshold_seconds
    - pg_settings_operator_precedence_warning
    - pg_settings_parallel_setup_cost
    - pg_settings_parallel_tuple_cost
    - pg_settings_password_encryption
    - pg_settings_port
    - pg_settings_post_auth_delay_seconds
    - pg_settings_pre_auth_delay_seconds
    - pg_settings_quote_all_identifiers
    - pg_settings_random_page_cost
    - pg_settings_replacement_sort_tuples
    - pg_settings_restart_after_crash
    - pg_settings_row_security
    - pg_settings_segment_size_bytes
    - pg_settings_seq_page_cost
    - pg_settings_server_version_num
    - pg_settings_shared_buffers_bytes
    - pg_settings_sql_inheritance
    - pg_settings_ssl
    - pg_settings_ssl_prefer_server_ciphers
    - pg_settings_standard_conforming_strings
    - pg_settings_statement_timeout_seconds
    - pg_settings_superuser_reserved_connections
    - pg_settings_synchronize_seqscans
    - pg_settings_syslog_sequence_numbers
    - pg_settings_syslog_split_messages
    - pg_settings_tcp_keepalives_count
    - pg_settings_tcp_keepalives_idle_seconds
    - pg_settings_tcp_keepalives_interval_seconds
    - pg_settings_temp_buffers_bytes
    - pg_settings_temp_file_limit_bytes
    - pg_settings_trace_notify
    - pg_settings_trace_sort
    - pg_settings_track_activities
    - pg_settings_track_activity_query_size
    - pg_settings_track_commit_timestamp
    - pg_settings_track_counts
    - pg_settings_track_io_timing
    - pg_settings_transaction_deferrable
    - pg_settings_transaction_read_only
    - pg_settings_transform_null_equals
    - pg_settings_unix_socket_permissions
    - pg_settings_update_process_title
    - pg_settings_vacuum_cost_delay_seconds
    - pg_settings_vacuum_cost_limit
    - pg_settings_vacuum_cost_page_dirty
    - pg_settings_vacuum_cost_page_hit
    - pg_settings_vacuum_cost_page_miss
    - pg_settings_vacuum_defer_cleanup_age
    - pg_settings_vacuum_freeze_min_age
    - pg_settings_vacuum_freeze_table_age
    - pg_settings_vacuum_multixact_freeze_min_age
    - pg_settings_vacuum_multixact_freeze_table_age
    - pg_settings_wal_block_size
    - pg_settings_wal_buffers_bytes
    - pg_settings_wal_compression
    - pg_settings_wal_keep_segments
    - pg_settings_wal_log_hints
    - pg_settings_wal_receiver_status_interval_seconds
    - pg_settings_wal_receiver_timeout_seconds
    - pg_settings_wal_retrieve_retry_interval_seconds
    - pg_settings_wal_segment_size_bytes
    - pg_settings_wal_sender_timeout_seconds
    - pg_settings_wal_writer_delay_seconds
    - pg_settings_wal_writer_flush_after_bytes
    - pg_settings_work_mem_bytes
    - pg_settings_zero_damaged_pages
    - pg_slow_queries
    - pg_stat_bgwriter_buffers_alloc
    - pg_stat_bgwriter_buffers_backend
    - pg_stat_bgwriter_buffers_backend_fsync
    - pg_stat_bgwriter_buffers_checkpoint
    - pg_stat_bgwriter_buffers_clean
    - pg_stat_bgwriter_checkpoint_sync_time
    - pg_stat_bgwriter_checkpoint_write_time
    - pg_stat_bgwriter_checkpoints_req
    - pg_stat_bgwriter_checkpoints_timed
    - pg_stat_bgwriter_maxwritten_clean
    - pg_stat_bgwriter_stats_reset
    - pg_stat_database_conflicts
    - pg_stat_database_deadlocks
    - pg_stat_database_stats_reset
    - pg_static
    - pg_stuck_idle_in_transaction_queries
    - pg_up
    - pg_vacuum_age_in_seconds
    - pg_vacuum_analyze_age_in_seconds
    - pg_vacuum_analyze_queries
    - pg_vacuum_queries
    monitorType: prometheus/postgres