Sunday, July 17, 2022

PostgreSQL Parameters (pg_settings)

 

How many configuration parameters in PostgreSQL 15 (beta2)?


With rollup function, there are total 353 parameter settings.

postgres=# select context,count(*) from pg_settings
postgres-# group by rollup(context)
postgres-# order by context nulls last;
      context      | count
-------------------+-------
 backend           |     2
 internal          |    20
 postmaster        |    55
 sighup            |    92
 superuser         |    44
 superuser-backend |     4
 user              |   136
                   |   353
(8 rows)

Configuration parameter for "context=backend"

You can check the setting without restarting the PostgreSQL instance, it only take effects for new sessions after parameter change, instead of existing sessions.

select name,setting,short_desc from pg_settings
where context='backend' order by name;

select '|'||name||'|'||setting||'|'||short_desc||'|' from pg_settings
where context='backend' order by name;
namesettingsetting
ignore_system_indexesoffDisables reading from system indexes.
post_auth_delay0Sets the amount of time to wait after authentication on connection startup.

Configuration parameter for "context=internal"

These settings for information only, not for change directly. Some of them can be changed by "rebuilding" the PostgreSQL binary or passing options to initial initdb process.

select name,setting,short_desc from pg_settings
where context='internal' order by name;

select '|'||name||'|'||setting||'|'||short_desc||'|' from pg_settings
where context='internal' order by name;
namesettingsetting
block_size8192Shows the size of a disk block.
data_checksumsoffShows whether data checksums are turned on for this cluster.
data_directory_mode0700Shows the mode of the data directory.
debug_assertionsonShows whether the running server has assertion checks enabled.
in_hot_standbyoffShows whether hot standby is currently active.
integer_datetimesonShows whether datetimes are integer based.
lc_collateen_US.UTF-8Shows the collation order locale.
lc_ctypeen_US.UTF-8Shows the character classification and case conversion locale.
max_function_args100Shows the maximum number of function arguments.
max_identifier_length63Shows the maximum identifier length.
max_index_keys32Shows the maximum number of index keys.
segment_size131072Shows the number of pages per disk file.
server_encodingUTF8Shows the server (database) character set encoding.
server_version15beta2Shows the server version.
server_version_num150000Shows the server version as an integer.
shared_memory_size143Shows the size of the server's main shared memory area (rounded up to the nearest MB).
shared_memory_size_in_huge_pages72Shows the number of huge pages needed for the main shared memory area.
ssl_libraryOpenSSLShows the name of the SSL library.
wal_block_size8192Shows the block size in the write ahead log.
wal_segment_size16777216Shows the size of write ahead log segments.

Configuration parameter for "context=postmaster"

These settings can only be applied during server startup, so any changes requires server restart (Downtime!!!).

select name,setting,short_desc from pg_settings
where context='postmaster' order by name;

select '|'||name||'|'||setting||'|'||short_desc||'|' from pg_settings
where context='postmaster' order by name;
namesettingsetting
archive_modeoffAllows archiving of WAL files using archive_command.
autovacuum_freeze_max_age200000000Age at which to autovacuum a table to prevent transaction ID wraparound.
autovacuum_max_workers3Sets the maximum number of simultaneously running autovacuum worker processes.
autovacuum_multixact_freeze_max_age400000000Multixact age at which to autovacuum a table to prevent multixact wraparound.
bonjouroffEnables advertising the server via Bonjour.
bonjour_nameSets the Bonjour service name.
cluster_nameSets the name of the cluster, which is included in the process title.
config_file/var/lib/pgsql/15/data/postgresql.confSets the server's main configuration file.
data_directory/var/lib/pgsql/15/dataSets the server's data directory.
data_sync_retryoffWhether to continue running after a failure to sync data files.
dynamic_shared_memory_typeposixSelects the dynamic shared memory implementation used.
event_sourcePostgreSQLSets the application name used to identify PostgreSQL messages in the event log.
external_pid_fileWrites the postmaster PID to the specified file.
hba_file/var/lib/pgsql/15/data/pg_hba.confSets the server's "hba" configuration file.
hot_standbyonAllows connections and queries during recovery.
huge_pagestryUse of huge pages on Linux or Windows.
huge_page_size0The size of huge page that should be requested.
ident_file/var/lib/pgsql/15/data/pg_ident.confSets the server's "ident" configuration file.
ignore_invalid_pagesoffContinues recovery after an invalid pages failure.
jit_providerllvmjitJIT provider to use.
listen_addresseslocalhostSets the host name or IP address(es) to listen to.
logging_collectoronStart a subprocess to capture stderr output and/or csvlogs into log files.
max_connections100Sets the maximum number of concurrent connections.
max_files_per_process1000Sets the maximum number of simultaneously open files for each server process.
max_locks_per_transaction64Sets the maximum number of locks per transaction.
max_logical_replication_workers4Maximum number of logical replication worker processes.
max_pred_locks_per_transaction64Sets the maximum number of predicate locks per transaction.
max_prepared_transactions0Sets the maximum number of simultaneously prepared transactions.
max_replication_slots10Sets the maximum number of simultaneously defined replication slots.
max_wal_senders10Sets the maximum number of simultaneously running WAL sender processes.
max_worker_processes8Maximum number of concurrent worker processes.
min_dynamic_shared_memory0Amount of dynamic shared memory reserved at startup.
old_snapshot_threshold-1Time before a snapshot is too old to read pages changed after the snapshot was taken.
port5432Sets the TCP port the server listens on.
recovery_targetSet to "immediate" to end recovery as soon as a consistent state is reached.
recovery_target_actionpauseSets the action to perform upon reaching the recovery target.
recovery_target_inclusiveonSets whether to include or exclude transaction with recovery target.
recovery_target_lsnSets the LSN of the write-ahead log location up to which recovery will proceed.
recovery_target_nameSets the named restore point up to which recovery will proceed.
recovery_target_timeSets the time stamp up to which recovery will proceed.
recovery_target_timelinelatestSpecifies the timeline to recover into.
recovery_target_xidSets the transaction ID up to which recovery will proceed.
shared_buffers16384Sets the number of shared memory buffers used by the server.
shared_memory_typemmapSelects the shared memory implementation used for the main shared memory region.
shared_preload_librariesLists shared libraries to preload into server.
superuser_reserved_connections3Sets the number of connection slots reserved for superusers.
track_activity_query_size1024Sets the size reserved for pg_stat_activity.query, in bytes.
track_commit_timestampoffCollects transaction commit time.
unix_socket_directories/var/run/postgresql, /tmpSets the directories where Unix-domain sockets will be created.
unix_socket_groupSets the owning group of the Unix-domain socket.
unix_socket_permissions0777Sets the access permissions of the Unix-domain socket.
wal_buffers512Sets the number of disk-page buffers in shared memory for WAL.
wal_decode_buffer_size524288Maximum buffer size for reading ahead in the WAL during recovery.
wal_levelreplicaSets the level of information written to the WAL.
wal_log_hintsoffWrites full pages to WAL when first modified after a checkpoint, even for a non-critical modification.

Configuration parameter for "context=sighup"

Changes to these settings can be made in postgresql.conf without restarting the server. Send a SIGHUP signal to the postmaster to cause it to re-read postgresql.conf and apply the changes. The postmaster will also forward the SIGHUP signal to its child processes so that they all pick up the new value.

select name,setting,short_desc from pg_settings
where context='sighup' order by name;

select '|'||name||'|'||setting||'|'||short_desc||'|' from pg_settings
where context='sighup' order by name;
namesettingsetting
archive_cleanup_commandSets the shell command that will be executed at every restart point.
archive_command(disabled)Sets the shell command that will be called to archive a WAL file.
archive_librarySets the library that will be called to archive a WAL file.
archive_timeout0Sets the amount of time to wait before forcing a switch to the next WAL file.
authentication_timeout60Sets the maximum allowed time to complete client authentication.
autovacuumonStarts the autovacuum subprocess.
autovacuum_analyze_scale_factor0.1Number of tuple inserts, updates, or deletes prior to analyze as a fraction of reltuples.
autovacuum_analyze_threshold50Minimum number of tuple inserts, updates, or deletes prior to analyze.
autovacuum_naptime60Time to sleep between autovacuum runs.
autovacuum_vacuum_cost_delay2Vacuum cost delay in milliseconds, for autovacuum.
autovacuum_vacuum_cost_limit-1Vacuum cost amount available before napping, for autovacuum.
autovacuum_vacuum_insert_scale_factor0.2Number of tuple inserts prior to vacuum as a fraction of reltuples.
autovacuum_vacuum_insert_threshold1000Minimum number of tuple inserts prior to vacuum, or -1 to disable insert vacuums.
autovacuum_vacuum_scale_factor0.2Number of tuple updates or deletes prior to vacuum as a fraction of reltuples.
autovacuum_vacuum_threshold50Minimum number of tuple updates or deletes prior to vacuum.
autovacuum_work_mem-1Sets the maximum memory to be used by each autovacuum worker process.
bgwriter_delay200Background writer sleep time between rounds.
bgwriter_flush_after64Number of pages after which previously performed writes are flushed to disk.
bgwriter_lru_maxpages100Background writer maximum number of LRU pages to flush per round.
bgwriter_lru_multiplier2Multiple of the average buffer usage to free per round.
checkpoint_completion_target0.9Time spent flushing dirty buffers during checkpoint, as fraction of checkpoint interval.
checkpoint_flush_after32Number of pages after which previously performed writes are flushed to disk.
checkpoint_timeout300Sets the maximum time between automatic WAL checkpoints.
checkpoint_warning30Sets the maximum time before warning if checkpoints triggered by WAL volume happen too frequently.
db_user_namespaceoffEnables per-database user names.
fsynconForces synchronization of updates to disk.
full_page_writesonWrites full pages to WAL when first modified after a checkpoint.
hot_standby_feedbackoffAllows feedback from a hot standby to the primary that will avoid query conflicts.
krb_caseins_usersoffSets whether Kerberos and GSSAPI user names should be treated as case-insensitive.
krb_server_keyfileFILE:/etc/sysconfig/pgsql/krb5.keytabSets the location of the Kerberos server key file.
log_autovacuum_min_duration600000Sets the minimum execution time above which autovacuum actions will be logged.
log_checkpointsonLogs each checkpoint.
log_destinationstderrSets the destination for server log output.
log_directorylogSets the destination directory for log files.
log_file_mode0600Sets the file permissions for log files.
log_filenamepostgresql-%a.logSets the file name pattern for log files.
log_hostnameoffLogs the host name in the connection logs.
log_line_prefix%m [%p]Controls information prefixed to each log line.
log_recovery_conflict_waitsoffLogs standby recovery conflict waits.
log_rotation_age1440Sets the amount of time to wait before forcing log file rotation.
log_rotation_size0Sets the maximum size a log file can reach before being rotated.
log_startup_progress_interval10000Time between progress updates for long-running startup operations.
log_timezoneUTCSets the time zone to use in log messages.
log_truncate_on_rotationonTruncate existing log files of same name during log rotation.
max_pred_locks_per_page2Sets the maximum number of predicate-locked tuples per page.
max_pred_locks_per_relation-2Sets the maximum number of predicate-locked pages and tuples per relation.
max_slot_wal_keep_size-1Sets the maximum WAL size that can be reserved by replication slots.
max_standby_archive_delay30000Sets the maximum delay before canceling queries when a hot standby server is processing archived WAL data.
max_standby_streaming_delay30000Sets the maximum delay before canceling queries when a hot standby server is processing streamed WAL data.
max_sync_workers_per_subscription2Maximum number of table synchronization workers per subscription.
max_wal_size1024Sets the WAL size that triggers a checkpoint.
min_wal_size80Sets the minimum size to shrink the WAL to.
pre_auth_delay0Sets the amount of time to wait before authentication on connection startup.
primary_conninfoSets the connection string to be used to connect to the sending server.
primary_slot_nameSets the name of the replication slot to use on the sending server.
promote_trigger_fileSpecifies a file name whose presence ends recovery in the standby.
recovery_end_commandSets the shell command that will be executed once at the end of recovery.
recovery_init_sync_methodfsyncSets the method for synchronizing the data directory before crash recovery.
recovery_min_apply_delay0Sets the minimum delay for applying changes during recovery.
recovery_prefetchtryPrefetch referenced blocks during recovery
remove_temp_files_after_crashonRemove temporary files after backend crash.
restart_after_crashonReinitialize server after backend crash.
restore_commandSets the shell command that will be called to retrieve an archived WAL file.
ssloffEnables SSL connections.
ssl_ca_fileLocation of the SSL certificate authority file.
ssl_cert_fileserver.crtLocation of the SSL server certificate file.
ssl_ciphersHIGH:MEDIUM:+3DES:!aNULLSets the list of allowed SSL ciphers.
ssl_crl_dirLocation of the SSL certificate revocation list directory.
ssl_crl_fileLocation of the SSL certificate revocation list file.
ssl_dh_params_fileLocation of the SSL DH parameters file.
ssl_ecdh_curveprime256v1Sets the curve to use for ECDH.
ssl_key_fileserver.keyLocation of the SSL server private key file.
ssl_max_protocol_versionSets the maximum SSL/TLS protocol version to use.
ssl_min_protocol_versionTLSv1.2Sets the minimum SSL/TLS protocol version to use.
ssl_passphrase_commandCommand to obtain passphrases for SSL.
ssl_passphrase_command_supports_reloadoffControls whether ssl_passphrase_command is called during server reload.
ssl_prefer_server_ciphersonGive priority to server ciphersuite order.
synchronous_standby_namesNumber of synchronous standbys and list of names of potential synchronous ones.
syslog_facilitylocal0Sets the syslog "facility" to be used when syslog enabled.
syslog_identpostgresSets the program name used to identify PostgreSQL messages in syslog.
syslog_sequence_numbersonAdd sequence number to syslog messages to avoid duplicate suppression.
syslog_split_messagesonSplit messages sent to syslog by lines and to fit into 1024 bytes.
trace_recovery_messageslogEnables logging of recovery-related debugging information.
vacuum_defer_cleanup_age0Number of transactions by which VACUUM and HOT cleanup should be deferred, if any.
wal_keep_size0Sets the size of WAL files held for standby servers.
wal_receiver_create_temp_slotoffSets whether a WAL receiver should create a temporary replication slot if no permanent slot is configured.
wal_receiver_status_interval10Sets the maximum interval between WAL receiver status reports to the sending server.
wal_receiver_timeout60000Sets the maximum wait time to receive data from the sending server.
wal_retrieve_retry_interval5000Sets the time to wait before retrying to retrieve WAL after a failed attempt.
wal_sync_methodfdatasyncSelects the method used for forcing WAL updates to disk.
wal_writer_delay200Time between WAL flushes performed in the WAL writer.
wal_writer_flush_after128Amount of WAL written out by WAL writer that triggers a flush.

Configuration parameter for "context=superuser"

These settings can be set from postgresql.conf, or within a session via the SET command; but only superusers can change them via SET.

select name,setting,short_desc from pg_settings
where context='superuser' order by name;

select '|'||name||'|'||setting||'|'||short_desc||'|' from pg_settings
where context='superuser' order by name;
namesettingsetting
allow_in_place_tablespacesoffAllows tablespaces directly inside pg_tblspc, for testing.
allow_system_table_modsoffAllows modifications of the structure of system tables.
backtrace_functionsLog backtrace for errors in these functions.
commit_delay0Sets the delay in microseconds between transaction commit and flushing WAL to disk.
compute_query_idautoEnables in-core computation of query identifiers.
deadlock_timeout1000Sets the time to wait on a lock before checking for deadlock.
debug_discard_caches0Aggressively flush system caches for debugging purposes.
dynamic_library_path$libdirSets the path for dynamically loadable modules.
ignore_checksum_failureoffContinues processing after a checksum failure.
jit_dump_bitcodeoffWrite out LLVM bitcode to facilitate JIT debugging.
lc_messagesen_US.UTF-8Sets the language in which messages are displayed.
lo_compat_privilegesoffEnables backward compatibility mode for privilege checks on large objects.
log_durationoffLogs the duration of each completed SQL statement.
log_error_verbositydefaultSets the verbosity of logged messages.
log_executor_statsoffWrites executor performance statistics to the server log.
log_lock_waitsoffLogs long lock waits.
log_min_duration_sample-1Sets the minimum execution time above which a sample of statements will be logged. Sampling is determined by log_statement_sample_rate.
log_min_duration_statement-1Sets the minimum execution time above which all statements will be logged.
log_min_error_statementerrorCauses all statements generating error at or above this level to be logged.
log_min_messageswarningSets the message levels that are logged.
log_parameter_max_length-1Sets the maximum length in bytes of data logged for bind parameter values when logging statements.
log_parser_statsoffWrites parser performance statistics to the server log.
log_planner_statsoffWrites planner performance statistics to the server log.
log_replication_commandsoffLogs each replication command.
log_statementnoneSets the type of statements logged.
log_statement_sample_rate1Fraction of statements exceeding log_min_duration_sample to be logged.
log_statement_statsoffWrites cumulative performance statistics to the server log.
log_temp_files-1Log the use of temporary files larger than this number of kilobytes.
log_transaction_sample_rate0Sets the fraction of transactions from which to log all statements.
max_stack_depth2048Sets the maximum stack depth, in kilobytes.
session_preload_librariesLists shared libraries to preload into each backend.
session_replication_roleoriginSets the session's behavior for triggers and rewrite rules.
temp_file_limit-1Limits the total size of all temporary files used by each process.
track_activitiesonCollects information about executing commands.
track_countsonCollects statistics on database activity.
track_functionsnoneCollects function-level statistics on database activity.
track_io_timingoffCollects timing statistics for database I/O activity.
track_wal_io_timingoffCollects timing statistics for WAL I/O activity.
update_process_titleonUpdates the process title to show the active SQL command.
wal_compressionoffCompresses full-page writes written in WAL file with specified method.
wal_consistency_checkingSets the WAL resource managers for which WAL consistency checks are done.
wal_init_zeroonWrites zeroes to new WAL files before first use.
wal_recycleonRecycles WAL files by renaming them.
zero_damaged_pagesoffContinues processing past damaged page headers.

Configuration parameter for "context=superuser-backend"

These values can be set without restarting PostgreSQL server, but only take effects on subsequently launched sessions.

select name,setting,short_desc from pg_settings
where context='superuser-backend' order by name;

select '|'||name||'|'||setting||'|'||short_desc||'|' from pg_settings
where context='superuser-backend' order by name;
namesettingsetting
jit_debugging_supportoffRegister JIT-compiled functions with debugger.
jit_profiling_supportoffRegister JIT-compiled functions with perf profiler.
log_connectionsoffLogs each successful connection.
log_disconnectionsoffLogs end of a session, including duration.

Configuration parameter for "context=user"

These settings can be set from postgresql.conf, or within a session via the SET command (higher precedence). Any user is allowed to change their session-local value.

select name,setting,short_desc from pg_settings
where context='user' order by name;

select '|'||name||'|'||setting||'|'||short_desc||'|' from pg_settings
where context='user' order by name;
namesettingsetting
application_namepsqlSets the application name to be reported in statistics and logs.
array_nullsonEnable input of NULL elements in arrays.
backend_flush_after0Number of pages after which previously performed writes are flushed to disk.
backslash_quotesafe_encodingSets whether "'" is allowed in string literals.
bytea_outputhexSets the output format for bytea.
check_function_bodiesonCheck routine bodies during CREATE FUNCTION and CREATE PROCEDURE.
client_connection_check_interval0Sets the time interval between checks for disconnection while running queries.
client_encodingUTF8Sets the client's character set encoding.
client_min_messagesnoticeSets the message levels that are sent to the client.
commit_siblings5Sets the minimum number of concurrent open transactions required before performing commit_delay.
constraint_exclusionpartitionEnables the planner to use constraints to optimize queries.
cpu_index_tuple_cost0.005Sets the planner's estimate of the cost of processing each index entry during an index scan.
cpu_operator_cost0.0025Sets the planner's estimate of the cost of processing each operator or function call.
cpu_tuple_cost0.01Sets the planner's estimate of the cost of processing each tuple (row).
cursor_tuple_fraction0.1Sets the planner's estimate of the fraction of a cursor's rows that will be retrieved.
DateStyleISO, MDYSets the display format for date and time values.
debug_pretty_printonIndents parse and plan tree displays.
debug_print_parseoffLogs each query's parse tree.
debug_print_planoffLogs each query's execution plan.
debug_print_rewrittenoffLogs each query's rewritten parse tree.
default_statistics_target100Sets the default statistics target.
default_table_access_methodheapSets the default table access method for new tables.
default_tablespaceSets the default tablespace to create tables and indexes in.
default_text_search_configpg_catalog.englishSets default text search configuration.
default_toast_compressionpglzSets the default compression method for compressible values.
default_transaction_deferrableoffSets the default deferrable status of new transactions.
default_transaction_isolationread committedSets the transaction isolation level of each new transaction.
default_transaction_read_onlyoffSets the default read-only status of new transactions.
effective_cache_size524288Sets the planner's assumption about the total size of the data caches.
effective_io_concurrency1Number of simultaneous requests that can be handled efficiently by the disk subsystem.
enable_async_appendonEnables the planner's use of async append plans.
enable_bitmapscanonEnables the planner's use of bitmap-scan plans.
enable_gathermergeonEnables the planner's use of gather merge plans.
enable_group_by_reorderingonenable reordering of GROUP BY key
enable_hashaggonEnables the planner's use of hashed aggregation plans.
enable_hashjoinonEnables the planner's use of hash join plans.
enable_incremental_sortonEnables the planner's use of incremental sort steps.
enable_indexonlyscanonEnables the planner's use of index-only-scan plans.
enable_indexscanonEnables the planner's use of index-scan plans.
enable_materialonEnables the planner's use of materialization.
enable_memoizeonEnables the planner's use of memoization.
enable_mergejoinonEnables the planner's use of merge join plans.
enable_nestlooponEnables the planner's use of nested-loop join plans.
enable_parallel_appendonEnables the planner's use of parallel append plans.
enable_parallel_hashonEnables the planner's use of parallel hash plans.
enable_partition_pruningonEnables plan-time and execution-time partition pruning.
enable_partitionwise_aggregateoffEnables partitionwise aggregation and grouping.
enable_partitionwise_joinoffEnables partitionwise join.
enable_seqscanonEnables the planner's use of sequential-scan plans.
enable_sortonEnables the planner's use of explicit sort steps.
enable_tidscanonEnables the planner's use of TID scan plans.
escape_string_warningonWarn about backslash escapes in ordinary string literals.
exit_on_erroroffTerminate session on any error.
extra_float_digits1Sets the number of digits displayed for floating-point values.
force_parallel_modeoffForces use of parallel query facilities.
from_collapse_limit8Sets the FROM-list size beyond which subqueries are not collapsed.
geqoonEnables genetic query optimization.
geqo_effort5GEQO: effort is used to set the default for other GEQO parameters.
geqo_generations0GEQO: number of iterations of the algorithm.
geqo_pool_size0GEQO: number of individuals in the population.
geqo_seed0GEQO: seed for random path selection.
geqo_selection_bias2GEQO: selective pressure within the population.
geqo_threshold12Sets the threshold of FROM items beyond which GEQO is used.
gin_fuzzy_search_limit0Sets the maximum allowed result for exact search by GIN.
gin_pending_list_limit4096Sets the maximum size of the pending list for GIN index.
hash_mem_multiplier2Multiple of work_mem to use for hash tables.
idle_in_transaction_session_timeout0Sets the maximum allowed idle time between queries, when in a transaction.
idle_session_timeout0Sets the maximum allowed idle time between queries, when not in a transaction.
IntervalStylepostgresSets the display format for interval values.
jitonAllow JIT compilation.
jit_above_cost100000Perform JIT compilation if query is more expensive.
jit_expressionsonAllow JIT compilation of expressions.
jit_inline_above_cost500000Perform JIT inlining if query is more expensive.
jit_optimize_above_cost500000Optimize JIT-compiled functions if query is more expensive.
jit_tuple_deformingonAllow JIT compilation of tuple deforming.
join_collapse_limit8Sets the FROM-list size beyond which JOIN constructs are not flattened.
lc_monetaryen_US.UTF-8Sets the locale for formatting monetary amounts.
lc_numericen_US.UTF-8Sets the locale for formatting numbers.
lc_timeen_US.UTF-8Sets the locale for formatting date and time values.
local_preload_librariesLists unprivileged shared libraries to preload into each backend.
lock_timeout0Sets the maximum allowed duration of any wait for a lock.
logical_decoding_work_mem65536Sets the maximum memory to be used for logical decoding.
log_parameter_max_length_on_error0Sets the maximum length in bytes of data logged for bind parameter values when logging statements, on error.
maintenance_io_concurrency10A variant of effective_io_concurrency that is used for maintenance work.
maintenance_work_mem65536Sets the maximum memory to be used for maintenance operations.
max_parallel_maintenance_workers2Sets the maximum number of parallel processes per maintenance operation.
max_parallel_workers8Sets the maximum number of parallel workers that can be active at one time.
max_parallel_workers_per_gather2Sets the maximum number of parallel processes per executor node.
min_parallel_index_scan_size64Sets the minimum amount of index data for a parallel scan.
min_parallel_table_scan_size1024Sets the minimum amount of table data for a parallel scan.
parallel_leader_participationonControls whether Gather and Gather Merge also run subplans.
parallel_setup_cost1000Sets the planner's estimate of the cost of starting up worker processes for parallel query.
parallel_tuple_cost0.1Sets the planner's estimate of the cost of passing each tuple (row) from worker to leader backend.
password_encryptionscram-sha-256Chooses the algorithm for encrypting passwords.
plan_cache_modeautoControls the planner's selection of custom or generic plan.
quote_all_identifiersoffWhen generating SQL fragments, quote all identifiers.
random_page_cost4Sets the planner's estimate of the cost of a nonsequentially fetched disk page.
recursive_worktable_factor10Sets the planner's estimate of the average size of a recursive query's working table.
row_securityonEnable row security.
search_path"$user", publicSets the schema search order for names that are not schema-qualified.
seq_page_cost1Sets the planner's estimate of the cost of a sequentially fetched disk page.
standard_conforming_stringsonCauses '...' strings to treat backslashes literally.
statement_timeout0Sets the maximum allowed duration of any statement.
stats_fetch_consistencycacheSets the consistency of accesses to statistics data
synchronize_seqscansonEnable synchronized sequential scans.
synchronous_commitonSets the current transaction's synchronization level.
tcp_keepalives_count0Maximum number of TCP keepalive retransmits.
tcp_keepalives_idle0Time between issuing TCP keepalives.
tcp_keepalives_interval0Time between TCP keepalive retransmits.
tcp_user_timeout0TCP user timeout.
temp_buffers1024Sets the maximum number of temporary buffers used by each session.
temp_tablespacesSets the tablespace(s) to use for temporary tables and sort files.
TimeZoneUTCSets the time zone for displaying and interpreting time stamps.
timezone_abbreviationsDefaultSelects a file of time zone abbreviations.
trace_notifyoffGenerates debugging output for LISTEN and NOTIFY.
trace_sortoffEmit information about resource usage in sorting.
transaction_deferrableoffWhether to defer a read-only serializable transaction until it can be executed with no possible serialization failures.
transaction_isolationread committedSets the current transaction's isolation level.
transaction_read_onlyoffSets the current transaction's read-only status.
transform_null_equalsoffTreats "expr=NULL" as "expr IS NULL".
vacuum_cost_delay0Vacuum cost delay in milliseconds.
vacuum_cost_limit200Vacuum cost amount available before napping.
vacuum_cost_page_dirty20Vacuum cost for a page dirtied by vacuum.
vacuum_cost_page_hit1Vacuum cost for a page found in the buffer cache.
vacuum_cost_page_miss2Vacuum cost for a page not found in the buffer cache.
vacuum_failsafe_age1600000000Age at which VACUUM should trigger failsafe to avoid a wraparound outage.
vacuum_freeze_min_age50000000Minimum age at which VACUUM should freeze a table row.
vacuum_freeze_table_age150000000Age at which VACUUM should scan whole table to freeze tuples.
vacuum_multixact_failsafe_age1600000000Multixact age at which VACUUM should trigger failsafe to avoid a wraparound outage.
vacuum_multixact_freeze_min_age5000000Minimum age at which VACUUM should freeze a MultiXactId in a table row.
vacuum_multixact_freeze_table_age150000000Multixact age at which VACUUM should scan whole table to freeze tuples.
wal_sender_timeout60000Sets the maximum time to wait for WAL replication.
wal_skip_threshold2048Minimum size of new file to fsync instead of writing WAL.
work_mem4096Sets the maximum memory to be used for query workspaces.
xmlbinarybase64Sets how binary values are to be encoded in XML.
xmloptioncontentSets whether XML data in implicit parsing and serialization operations is to be considered as documents or content fragments.

Reference:

No comments:

Post a Comment