PostgreSQL GUC 参数级别介绍

本文涉及的产品
RDS MySQL Serverless 基础系列,0.5-2RCU 50GB
云原生数据库 PolarDB 分布式版,标准版 2核8GB
云数据库 RDS MySQL,集群版 2核4GB 100GB
推荐场景:
搭建个人博客
简介:

标签

PostgreSQL , 参数 , 参数级别


背景

在添加GUC参数时,需要注意你添加的参数属于什么类别的参数。

例如如果你想让普通用户能随时修改它,那么你需要将参数级别设置为PGC_USERSET。如果你想让超级用户能在线修改它,那么你需要将它设置为PGC_SUSET。如果你想让它能够在修改配置参数并通过信号生效,那么需要设置为PGC_SIGHUP。

GUC参数相关的代码如下

src/backend/utils/misc/guc.c

参数级别介绍

/*  
 * Displayable names for context types (enum GucContext)  
 *  
 * Note: these strings are deliberately not localized.  
 */  
const char *const GucContext_Names[] =  
{  
         /* PGC_INTERNAL */ "internal",      编译数据库集群时设置  
         /* PGC_POSTMASTER */ "postmaster",  只能启动是设置  
         /* PGC_SIGHUP */ "sighup",          允许通过修改配置文件,并通过SIGHUP信号更新参数。  
         /* PGC_SU_BACKEND */ "superuser-backend",     超级用户的backend级参数  
         /* PGC_BACKEND */ "backend",                  普通用户的backend级参数  
         /* PGC_SUSET */ "superuser",                  允许超级用户在线修改的参数  
         /* PGC_USERSET */ "user"                      允许普通用户在线修改的参数  
};  

如何查看所有参数级别

postgres=# select context,name,short_desc from pg_settings order by context,category,name;  
      context      |                name                 |                                                          short_desc                                                             
-------------------+-------------------------------------+-------------------------------------------------------------------------------------------------------------------------------  
 backend           | ignore_system_indexes               | Disables reading from system indexes.  
 backend           | post_auth_delay                     | Waits N seconds on connection startup after authentication.  
 internal          | lc_collate                          | Shows the collation order locale.  
 internal          | lc_ctype                            | Shows the character classification and case conversion locale.  
 internal          | server_encoding                     | Sets the server (database) character set encoding.  
 internal          | block_size                          | Shows the size of a disk block.  
 internal          | data_checksums                      | Shows whether data checksums are turned on for this cluster.  
 internal          | debug_assertions                    | Shows whether the running server has assertion checks enabled.  
 internal          | integer_datetimes                   | Datetimes are integer based.  
 internal          | max_function_args                   | Shows the maximum number of function arguments.  
 internal          | max_identifier_length               | Shows the maximum identifier length.  
 internal          | max_index_keys                      | Shows the maximum number of index keys.  
 internal          | segment_size                        | Shows the number of pages per disk file.  
 internal          | server_version                      | Shows the server version.  
 internal          | server_version_num                  | Shows the server version as an integer.  
 internal          | wal_block_size                      | Shows the block size in the write ahead log.  
 internal          | wal_segment_size                    | Shows the number of pages per write ahead log segment.  
 postmaster        | autovacuum_freeze_max_age           | Age at which to autovacuum a table to prevent transaction ID wraparound.  
 postmaster        | autovacuum_max_workers              | Sets the maximum number of simultaneously running autovacuum worker processes.  
 postmaster        | autovacuum_multixact_freeze_max_age | Multixact age at which to autovacuum a table to prevent multixact wraparound.  
 postmaster        | shared_preload_libraries            | Lists shared libraries to preload into server.  
 postmaster        | bonjour                             | Enables advertising the server via Bonjour.  
 postmaster        | bonjour_name                        | Sets the Bonjour service name.  
 postmaster        | listen_addresses                    | Sets the host name or IP address(es) to listen to.  
 postmaster        | max_connections                     | Sets the maximum number of concurrent connections.  
 postmaster        | port                                | Sets the TCP port the server listens on.  
 postmaster        | superuser_reserved_connections      | Sets the number of connection slots reserved for superusers.  
 postmaster        | unix_socket_directories             | Sets the directories where Unix-domain sockets will be created.  
 postmaster        | unix_socket_group                   | Sets the owning group of the Unix-domain socket.  
 postmaster        | unix_socket_permissions             | Sets the access permissions of the Unix-domain socket.  
 postmaster        | allow_system_table_mods             | Allows modifications of the structure of system tables.  
 postmaster        | config_file                         | Sets the server's main configuration file.  
 postmaster        | data_directory                      | Sets the server's data directory.  
 postmaster        | external_pid_file                   | Writes the postmaster PID to the specified file.  
 postmaster        | hba_file                            | Sets the server's "hba" configuration file.  
 postmaster        | ident_file                          | Sets the server's "ident" configuration file.  
 postmaster        | max_locks_per_transaction           | Sets the maximum number of locks per transaction.  
 postmaster        | max_pred_locks_per_transaction      | Sets the maximum number of predicate locks per transaction.  
 postmaster        | cluster_name                        | Sets the name of the cluster, which is included in the process title.  
 postmaster        | track_commit_timestamp              | Collects transaction commit time.  
 postmaster        | max_replication_slots               | Sets the maximum number of simultaneously defined replication slots.  
 postmaster        | max_wal_senders                     | Sets the maximum number of simultaneously running WAL sender processes.  
 postmaster        | hot_standby                         | Allows connections and queries during recovery.  
 postmaster        | max_logical_replication_workers     | Maximum number of logical replication worker processes.  
 postmaster        | event_source                        | Sets the application name used to identify PostgreSQL messages in the event log.  
 postmaster        | logging_collector                   | Start a subprocess to capture stderr output and/or csvlogs into log files.  
 postmaster        | max_worker_processes                | Maximum number of concurrent worker processes.  
 postmaster        | old_snapshot_threshold              | Time before a snapshot is too old to read pages changed after the snapshot was taken.  
 postmaster        | max_files_per_process               | Sets the maximum number of simultaneously open files for each server process.  
 postmaster        | dynamic_shared_memory_type          | Selects the dynamic shared memory implementation used.  
 postmaster        | huge_pages                          | Use of huge pages on Linux.  
 postmaster        | max_prepared_transactions           | Sets the maximum number of simultaneously prepared transactions.  
 postmaster        | shared_buffers                      | Sets the number of shared memory buffers used by the server.  
 postmaster        | track_activity_query_size           | Sets the size reserved for pg_stat_activity.query, in bytes.  
 postmaster        | archive_mode                        | Allows archiving of WAL files using archive_command.  
 postmaster        | wal_buffers                         | Sets the number of disk-page buffers in shared memory for WAL.  
 postmaster        | wal_level                           | Set the level of information written to the WAL.  
 postmaster        | wal_log_hints                       | Writes full pages to WAL when first modified after a checkpoint, even for a non-critical modifications.  
 sighup            | autovacuum                          | Starts the autovacuum subprocess.  
 sighup            | autovacuum_analyze_scale_factor     | Number of tuple inserts, updates, or deletes prior to analyze as a fraction of reltuples.  
 sighup            | autovacuum_analyze_threshold        | Minimum number of tuple inserts, updates, or deletes prior to analyze.  
 sighup            | autovacuum_naptime                  | Time to sleep between autovacuum runs.  
 sighup            | autovacuum_vacuum_cost_delay        | Vacuum cost delay in milliseconds, for autovacuum.  
 sighup            | autovacuum_vacuum_cost_limit        | Vacuum cost amount available before napping, for autovacuum.  
 sighup            | autovacuum_vacuum_scale_factor      | Number of tuple updates or deletes prior to vacuum as a fraction of reltuples.  
 sighup            | autovacuum_vacuum_threshold         | Minimum number of tuple updates or deletes prior to vacuum.  
 sighup            | authentication_timeout              | Sets the maximum allowed time to complete client authentication.  
 sighup            | db_user_namespace                   | Enables per-database user names.  
 sighup            | krb_caseins_users                   | Sets whether Kerberos and GSSAPI user names should be treated as case-insensitive.  
 sighup            | krb_server_keyfile                  | Sets the location of the Kerberos server key file.  
 sighup            | ssl                                 | Enables SSL connections.  
 sighup            | ssl_ca_file                         | Location of the SSL certificate authority file.  
 sighup            | ssl_cert_file                       | Location of the SSL server certificate file.  
 sighup            | ssl_ciphers                         | Sets the list of allowed SSL ciphers.  
 sighup            | ssl_crl_file                        | Location of the SSL certificate revocation list file.  
 sighup            | ssl_dh_params_file                  | Location of the SSL DH params file.  
 sighup            | ssl_ecdh_curve                      | Sets the curve to use for ECDH.  
 sighup            | ssl_key_file                        | Location of the SSL server private key file.  
 sighup            | ssl_prefer_server_ciphers           | Give priority to server ciphersuite order.  
 sighup            | pre_auth_delay                      | Waits N seconds on connection startup before authentication.  
 sighup            | trace_recovery_messages             | Enables logging of recovery-related debugging information.  
 sighup            | restart_after_crash                 | Reinitialize server after backend crash.  
 sighup            | max_pred_locks_per_page             | Sets the maximum number of predicate-locked tuples per page.  
 sighup            | max_pred_locks_per_relation         | Sets the maximum number of predicate-locked pages and tuples per relation.  
 sighup            | synchronous_standby_names           | Number of synchronous standbys and list of names of potential synchronous ones.  
 sighup            | vacuum_defer_cleanup_age            | Number of transactions by which VACUUM and HOT cleanup should be deferred, if any.  
 sighup            | wal_keep_segments                   | Sets the number of WAL files held for standby servers.  
 sighup            | wal_sender_timeout                  | Sets the maximum time to wait for WAL replication.  
 sighup            | hot_standby_feedback                | Allows feedback from a hot standby to the primary that will avoid query conflicts.  
 sighup            | max_standby_archive_delay           | Sets the maximum delay before canceling queries when a hot standby server is processing archived WAL data.  
 sighup            | max_standby_streaming_delay         | Sets the maximum delay before canceling queries when a hot standby server is processing streamed WAL data.  
 sighup            | wal_receiver_status_interval        | Sets the maximum interval between WAL receiver status reports to the primary.  
 sighup            | wal_receiver_timeout                | Sets the maximum wait time to receive data from the primary.  
 sighup            | wal_retrieve_retry_interval         | Sets the time to wait before retrying to retrieve WAL after a failed attempt.  
 sighup            | max_sync_workers_per_subscription   | Maximum number of table synchronization workers per subscription.  
 sighup            | log_autovacuum_min_duration         | Sets the minimum execution time above which autovacuum actions will be logged.  
 sighup            | log_checkpoints                     | Logs each checkpoint.  
 sighup            | log_hostname                        | Logs the host name in the connection logs.  
 sighup            | log_line_prefix                     | Controls information prefixed to each log line.  
 sighup            | log_timezone                        | Sets the time zone to use in log messages.  
 sighup            | log_destination                     | Sets the destination for server log output.  
 sighup            | log_directory                       | Sets the destination directory for log files.  
 sighup            | log_file_mode                       | Sets the file permissions for log files.  
 sighup            | log_filename                        | Sets the file name pattern for log files.  
 sighup            | log_rotation_age                    | Automatic log file rotation will occur after N minutes.  
 sighup            | log_rotation_size                   | Automatic log file rotation will occur after N kilobytes.  
 sighup            | log_truncate_on_rotation            | Truncate existing log files of same name during log rotation.  
 sighup            | syslog_facility                     | Sets the syslog "facility" to be used when syslog enabled.  
 sighup            | syslog_ident                        | Sets the program name used to identify PostgreSQL messages in syslog.  
 sighup            | syslog_sequence_numbers             | Add sequence number to syslog messages to avoid duplicate suppression.  
 sighup            | syslog_split_messages               | Split messages sent to syslog by lines and to fit into 1024 bytes.  
 sighup            | bgwriter_delay                      | Background writer sleep time between rounds.  
 sighup            | bgwriter_flush_after                | Number of pages after which previously performed writes are flushed to disk.  
 sighup            | bgwriter_lru_maxpages               | Background writer maximum number of LRU pages to flush per round.  
 sighup            | bgwriter_lru_multiplier             | Multiple of the average buffer usage to free per round.  
 sighup            | autovacuum_work_mem                 | Sets the maximum memory to be used by each autovacuum worker process.  
 sighup            | stats_temp_directory                | Writes temporary statistics files to the specified directory.  
 sighup            | archive_command                     | Sets the shell command that will be called to archive a WAL file.  
 sighup            | archive_timeout                     | Forces a switch to the next WAL file if a new file has not been started within N seconds.  
 sighup            | checkpoint_completion_target        | Time spent flushing dirty buffers during checkpoint, as fraction of checkpoint interval.  
 sighup            | checkpoint_flush_after              | Number of pages after which previously performed writes are flushed to disk.  
 sighup            | checkpoint_timeout                  | Sets the maximum time between automatic WAL checkpoints.  
 sighup            | checkpoint_warning                  | Enables warnings if checkpoint segments are filled more frequently than this.  
 sighup            | max_wal_size                        | Sets the WAL size that triggers a checkpoint.  
 sighup            | min_wal_size                        | Sets the minimum size to shrink the WAL to.  
 sighup            | fsync                               | Forces synchronization of updates to disk.  
 sighup            | full_page_writes                    | Writes full pages to WAL when first modified after a checkpoint.  
 sighup            | wal_sync_method                     | Selects the method used for forcing WAL updates to disk.  
 sighup            | wal_writer_delay                    | Time between WAL flushes performed in the WAL writer.  
 sighup            | wal_writer_flush_after              | Amount of WAL written out by WAL writer that triggers a flush.  
 superuser         | lc_messages                         | Sets the language in which messages are displayed.  
 superuser         | dynamic_library_path                | Sets the path for dynamically loadable modules.  
 superuser         | session_preload_libraries           | Lists shared libraries to preload into each backend.  
 superuser         | session_replication_role            | Sets the session's behavior for triggers and rewrite rules.  
 superuser         | ignore_checksum_failure             | Continues processing after a checksum failure.  
 superuser         | wal_consistency_checking            | Sets the WAL resource managers for which WAL consistency checks are done.  
 superuser         | zero_damaged_pages                  | Continues processing past damaged page headers.  
 superuser         | deadlock_timeout                    | Sets the time to wait on a lock before checking for deadlock.  
 superuser         | update_process_title                | Updates the process title to show the active SQL command.  
 superuser         | log_duration                        | Logs the duration of each completed SQL statement.  
 superuser         | log_error_verbosity                 | Sets the verbosity of logged messages.  
 superuser         | log_lock_waits                      | Logs long lock waits.  
 superuser         | log_replication_commands            | Logs each replication command.  
 superuser         | log_statement                       | Sets the type of statements logged.  
 superuser         | log_temp_files                      | Log the use of temporary files larger than this number of kilobytes.  
 superuser         | log_min_duration_statement          | Sets the minimum execution time above which statements will be logged.  
 superuser         | log_min_error_statement             | Causes all statements generating error at or above this level to be logged.  
 superuser         | log_min_messages                    | Sets the message levels that are logged.  
 superuser         | temp_file_limit                     | Limits the total size of all temporary files used by each process.  
 superuser         | max_stack_depth                     | Sets the maximum stack depth, in kilobytes.  
 superuser         | log_executor_stats                  | Writes executor performance statistics to the server log.  
 superuser         | log_parser_stats                    | Writes parser performance statistics to the server log.  
 superuser         | log_planner_stats                   | Writes planner performance statistics to the server log.  
 superuser         | log_statement_stats                 | Writes cumulative performance statistics to the server log.  
 superuser         | track_activities                    | Collects information about executing commands.  
 superuser         | track_counts                        | Collects statistics on database activity.  
 superuser         | track_functions                     | Collects function-level statistics on database activity.  
 superuser         | track_io_timing                     | Collects timing statistics for database I/O activity.  
 superuser         | lo_compat_privileges                | Enables backward compatibility mode for privilege checks on large objects.  
 superuser         | commit_delay                        | Sets the delay in microseconds between transaction commit and flushing WAL to disk.  
 superuser         | wal_compression                     | Compresses full-page writes written in WAL file.  
 superuser-backend | log_connections                     | Logs each successful connection.  
 superuser-backend | log_disconnections                  | Logs end of a session, including duration.  
 user              | DateStyle                           | Sets the display format for date and time values.  
 user              | IntervalStyle                       | Sets the display format for interval values.  
 user              | TimeZone                            | Sets the time zone for displaying and interpreting time stamps.  
 user              | client_encoding                     | Sets the client's character set encoding.  
 user              | default_text_search_config          | Sets default text search configuration.  
 user              | extra_float_digits                  | Sets the number of digits displayed for floating-point values.  
 user              | lc_monetary                         | Sets the locale for formatting monetary amounts.  
 user              | lc_numeric                          | Sets the locale for formatting numbers.  
 user              | lc_time                             | Sets the locale for formatting date and time values.  
 user              | timezone_abbreviations              | Selects a file of time zone abbreviations.  
 user              | gin_fuzzy_search_limit              | Sets the maximum allowed result for exact search by GIN.  
 user              | tcp_keepalives_count                | Maximum number of TCP keepalive retransmits.  
 user              | tcp_keepalives_idle                 | Time between issuing TCP keepalives.  
 user              | tcp_keepalives_interval             | Time between TCP keepalive retransmits.  
 user              | local_preload_libraries             | Lists unprivileged shared libraries to preload into each backend.  
 user              | bytea_output                        | Sets the output format for bytea.  
 user              | check_function_bodies               | Check function bodies during CREATE FUNCTION.  
 user              | default_tablespace                  | Sets the default tablespace to create tables and indexes in.  
 user              | default_transaction_deferrable      | Sets the default deferrable status of new transactions.  
 user              | default_transaction_isolation       | Sets the transaction isolation level of each new transaction.  
 user              | default_transaction_read_only       | Sets the default read-only status of new transactions.  
 user              | gin_pending_list_limit              | Sets the maximum size of the pending list for GIN index.  
 user              | idle_in_transaction_session_timeout | Sets the maximum allowed duration of any idling transaction.  
 user              | lock_timeout                        | Sets the maximum allowed duration of any wait for a lock.  
 user              | search_path                         | Sets the schema search order for names that are not schema-qualified.  
 user              | statement_timeout                   | Sets the maximum allowed duration of any statement.  
 user              | temp_tablespaces                    | Sets the tablespace(s) to use for temporary tables and sort files.  
 user              | transaction_deferrable              | Whether to defer a read-only serializable transaction until it can be executed with no possible serialization failures.  
 user              | transaction_isolation               | Sets the current transaction's isolation level.  
 user              | transaction_read_only               | Sets the current transaction's read-only status.  
 user              | vacuum_freeze_min_age               | Minimum age at which VACUUM should freeze a table row.  
 user              | vacuum_freeze_table_age             | Age at which VACUUM should scan whole table to freeze tuples.  
 user              | vacuum_multixact_freeze_min_age     | Minimum age at which VACUUM should freeze a MultiXactId in a table row.  
 user              | vacuum_multixact_freeze_table_age   | Multixact age at which VACUUM should scan whole table to freeze tuples.  
 user              | xmlbinary                           | Sets how binary values are to be encoded in XML.  
 user              | xmloption                           | Sets whether XML data in implicit parsing and serialization operations is to be considered as documents or content fragments.  
 user              | password_encryption                 | Encrypt passwords.  
 user              | row_security                        | Enable row security.  
 user              | trace_notify                        | Generates debugging output for LISTEN and NOTIFY.  
 user              | trace_sort                          | Emit information about resource usage in sorting.  
 user              | exit_on_error                       | Terminate session on any error.  
 user              | geqo                                | Enables genetic query optimization.  
 user              | geqo_effort                         | GEQO: effort is used to set the default for other GEQO parameters.  
 user              | geqo_generations                    | GEQO: number of iterations of the algorithm.  
 user              | geqo_pool_size                      | GEQO: number of individuals in the population.  
 user              | geqo_seed                           | GEQO: seed for random path selection.  
 user              | geqo_selection_bias                 | GEQO: selective pressure within the population.  
 user              | geqo_threshold                      | Sets the threshold of FROM items beyond which GEQO is used.  
 user              | constraint_exclusion                | Enables the planner to use constraints to optimize queries.  
 user              | cursor_tuple_fraction               | Sets the planner's estimate of the fraction of a cursor's rows that will be retrieved.  
 user              | default_statistics_target           | Sets the default statistics target.  
 user              | force_parallel_mode                 | Forces use of parallel query facilities.  
 user              | from_collapse_limit                 | Sets the FROM-list size beyond which subqueries are not collapsed.  
 user              | join_collapse_limit                 | Sets the FROM-list size beyond which JOIN constructs are not flattened.  
 user              | cpu_index_tuple_cost                | Sets the planner's estimate of the cost of processing each index entry during an index scan.  
 user              | cpu_operator_cost                   | Sets the planner's estimate of the cost of processing each operator or function call.  
 user              | cpu_tuple_cost                      | Sets the planner's estimate of the cost of processing each tuple (row).  
 user              | effective_cache_size                | Sets the planner's assumption about the size of the disk cache.  
 user              | min_parallel_index_scan_size        | Sets the minimum amount of index data for a parallel scan.  
 user              | min_parallel_table_scan_size        | Sets the minimum amount of table data for a parallel scan.  
 user              | parallel_setup_cost                 | Sets the planner's estimate of the cost of starting up worker processes for parallel query.  
 user              | parallel_tuple_cost                 | Sets the planner's estimate of the cost of passing each tuple (row) from worker to master backend.  
 user              | random_page_cost                    | Sets the planner's estimate of the cost of a nonsequentially fetched disk page.  
 user              | seq_page_cost                       | Sets the planner's estimate of the cost of a sequentially fetched disk page.  
 user              | enable_bitmapscan                   | Enables the planner's use of bitmap-scan plans.  
 user              | enable_gathermerge                  | Enables the planner's use of gather merge plans.  
 user              | enable_hashagg                      | Enables the planner's use of hashed aggregation plans.  
 user              | enable_hashjoin                     | Enables the planner's use of hash join plans.  
 user              | enable_indexonlyscan                | Enables the planner's use of index-only-scan plans.  
 user              | enable_indexscan                    | Enables the planner's use of index-scan plans.  
 user              | enable_material                     | Enables the planner's use of materialization.  
 user              | enable_mergejoin                    | Enables the planner's use of merge join plans.  
 user              | enable_nestloop                     | Enables the planner's use of nested-loop join plans.  
 user              | enable_parallelappend               | Enables the planner's use of parallel append plans.  
 user              | enable_seqscan                      | Enables the planner's use of sequential-scan plans.  
 user              | enable_sort                         | Enables the planner's use of explicit sort steps.  
 user              | enable_tidscan                      | Enables the planner's use of TID scan plans.  
 user              | application_name                    | Sets the application name to be reported in statistics and logs.  
 user              | debug_pretty_print                  | Indents parse and plan tree displays.  
 user              | debug_print_parse                   | Logs each query's parse tree.  
 user              | debug_print_plan                    | Logs each query's execution plan.  
 user              | debug_print_rewritten               | Logs each query's rewritten parse tree.  
 user              | client_min_messages                 | Sets the message levels that are sent to the client.  
 user              | backend_flush_after                 | Number of pages after which previously performed writes are flushed to disk.  
 user              | effective_io_concurrency            | Number of simultaneous requests that can be handled efficiently by the disk subsystem.  
 user              | max_parallel_workers                | Sets the maximum number of parallel workers than can be active at one time.  
 user              | max_parallel_workers_per_gather     | Sets the maximum number of parallel processes per executor node.  
 user              | vacuum_cost_delay                   | Vacuum cost delay in milliseconds.  
 user              | vacuum_cost_limit                   | Vacuum cost amount available before napping.  
 user              | vacuum_cost_page_dirty              | Vacuum cost for a page dirtied by vacuum.  
 user              | vacuum_cost_page_hit                | Vacuum cost for a page found in the buffer cache.  
 user              | vacuum_cost_page_miss               | Vacuum cost for a page not found in the buffer cache.  
 user              | maintenance_work_mem                | Sets the maximum memory to be used for maintenance operations.  
 user              | replacement_sort_tuples             | Sets the maximum number of tuples to be sorted using replacement selection.  
 user              | temp_buffers                        | Sets the maximum number of temporary buffers used by each session.  
 user              | work_mem                            | Sets the maximum memory to be used for query workspaces.  
 user              | transform_null_equals               | Treats "expr=NULL" as "expr IS NULL".  
 user              | array_nulls                         | Enable input of NULL elements in arrays.  
 user              | backslash_quote                     | Sets whether "\'" is allowed in string literals.  
 user              | default_with_oids                   | Create new tables with OIDs by default.  
 user              | escape_string_warning               | Warn about backslash escapes in ordinary string literals.  
 user              | operator_precedence_warning         | Emit a warning for constructs that changed meaning since PostgreSQL 9.4.  
 user              | quote_all_identifiers               | When generating SQL fragments, quote all identifiers.  
 user              | standard_conforming_strings         | Causes '...' strings to treat backslashes literally.  
 user              | synchronize_seqscans                | Enable synchronized sequential scans.  
 user              | commit_siblings                     | Sets the minimum concurrent open transactions before performing commit_delay.  
 user              | synchronous_commit                  | Sets the current transaction's synchronization level.  
(270 rows)  
相关实践学习
使用PolarDB和ECS搭建门户网站
本场景主要介绍基于PolarDB和ECS实现搭建门户网站。
阿里云数据库产品家族及特性
阿里云智能数据库产品团队一直致力于不断健全产品体系,提升产品性能,打磨产品功能,从而帮助客户实现更加极致的弹性能力、具备更强的扩展能力、并利用云设施进一步降低企业成本。以云原生+分布式为核心技术抓手,打造以自研的在线事务型(OLTP)数据库Polar DB和在线分析型(OLAP)数据库Analytic DB为代表的新一代企业级云原生数据库产品体系, 结合NoSQL数据库、数据库生态工具、云原生智能化数据库管控平台,为阿里巴巴经济体以及各个行业的企业客户和开发者提供从公共云到混合云再到私有云的完整解决方案,提供基于云基础设施进行数据从处理、到存储、再到计算与分析的一体化解决方案。本节课带你了解阿里云数据库产品家族及特性。
相关文章
|
1月前
|
DataWorks Java 关系型数据库
DataWorks常见问题之将预警信息发送至邮箱
DataWorks是阿里云提供的一站式大数据开发与管理平台,支持数据集成、数据开发、数据治理等功能;在本汇总中,我们梳理了DataWorks产品在使用过程中经常遇到的问题及解答,以助用户在数据处理和分析工作中提高效率,降低难度。
|
7月前
|
缓存 关系型数据库 数据库
PostgreSQL技术大讲堂 - 第32讲:数据库参数调整
从零开始学PostgreSQL技术大讲堂 - 第32讲:数据库参数调整
546 2
|
2天前
|
SQL 缓存 关系型数据库
PolarDB产品使用问题之已经修改了expire_logs_days参数并确认已生效,但在SQL查询中仍然显示为0,该怎么办
PolarDB产品使用合集涵盖了从创建与管理、数据管理、性能优化与诊断、安全与合规到生态与集成、运维与支持等全方位的功能和服务,旨在帮助企业轻松构建高可用、高性能且易于管理的数据库环境,满足不同业务场景的需求。用户可以通过阿里云控制台、API、SDK等方式便捷地使用这些功能,实现数据库的高效运维与持续优化。
|
2天前
|
存储 关系型数据库 分布式数据库
PolarDB产品使用问题之如何确定storageType是否通过配置文件参数定义
PolarDB产品使用合集涵盖了从创建与管理、数据管理、性能优化与诊断、安全与合规到生态与集成、运维与支持等全方位的功能和服务,旨在帮助企业轻松构建高可用、高性能且易于管理的数据库环境,满足不同业务场景的需求。用户可以通过阿里云控制台、API、SDK等方式便捷地使用这些功能,实现数据库的高效运维与持续优化。
|
1月前
|
SQL 关系型数据库 数据库
postgresql数据库修改参数的方式
在PostgreSQL数据库中,你可以通过多种方式修改数据库参数,以更改其行为。以下是一些常见的修改数据库参数的方式: 1. **通过配置文件修改(postgresql.conf):** PostgreSQL的配置文件是 `postgresql.conf`。你可以直接编辑该文件,找到要修改的参数,修改其值,然后重新启动PostgreSQL服务以使更改生效。 通常,`postgresql.conf` 文件位于 PostgreSQL 数据目录下。修改完毕后,确保重新启动 PostgreSQL 服务。 2. **使用 ALTER SYSTEM 命令:** PostgreSQL
151 1
|
1月前
|
运维 安全 关系型数据库
PolarDB产品使用合集之关于PolarDB DRDS的设置参数,主要有哪些
PolarDB产品使用合集涵盖了从创建与管理、数据管理、性能优化与诊断、安全与合规到生态与集成、运维与支持等全方位的功能和服务,旨在帮助企业轻松构建高可用、高性能且易于管理的数据库环境,满足不同业务场景的需求。用户可以通过阿里云控制台、API、SDK等方式便捷地使用这些功能,实现数据库的高效运维与持续优化。
|
1月前
|
关系型数据库 Java 分布式数据库
PolarDB for PostgreSQL参数问题之参数删除失败如何解决
PolarDB for PostgreSQL是基于PostgreSQL开发的一款云原生关系型数据库服务,它提供了高性能、高可用性和弹性扩展的特性;本合集将围绕PolarDB(pg)的部署、管理和优化提供指导,以及常见问题的排查和解决办法。
|
1月前
|
关系型数据库 PostgreSQL
PostgreSQL 的哪些参数不能通过ALTER SYSTEM SET 修改
在 PostgreSQL 中,有一些参数是不能通过 `ALTER SYSTEM SET` 语句进行动态修改的,这些参数通常需要在 PostgreSQL 的配置文件中进行手动修改。以下是一些不能通过 `ALTER SYSTEM SET` 修改的常见参数: 1. **track_activities** 2. **track_counts** 3. **track_io_timing** 4. **track_functions** 5. **track_activity_query_size** 6. **track_commit_timestamp** 7. **shared_preload
|
11月前
|
关系型数据库 Java 数据库连接
PostgreSQL 14中连接参数target_session_attrs增强
PostgreSQL 14中连接参数target_session_attrs增强
110 0
|
SQL 弹性计算 Kubernetes
实践教程之如何使用PolarDB-X参数模板
PolarDB-X 为了方便用户体验,提供了免费的实验环境,您可以在实验环境里体验 PolarDB-X 的安装部署和各种内核特性。除了免费的实验,PolarDB-X 也提供免费的视频课程,手把手教你玩转 PolarDB-X 分布式数据库。本期实验将指导您如何使用PolarDB-X参数模板。

相关产品

  • 云原生数据库 PolarDB