GreenPlum 配置参数设置


-------------------------------------------------MASTER SHOW ALL------------------------------------------------------

=# show all;
                         name                         |                                     setting                                      |                                                                                   description    
                                                                                
------------------------------------------------------+----------------------------------------------------------------------------------+--------------------------------------------------------------------------------------------------
--------------------------------------------------------------------------------
 add_missing_from                                     | off                                                                              | Automatically adds missing table references to FROM clauses.
 application_name                                     | psql                                                                             | Sets the application name to be reported in statistics and logs.
 array_nulls                                          | on                                                                               | Enable input of NULL elements in arrays.
 authentication_timeout                               | 1min                                                                             | Sets the maximum time in seconds to complete client authentication.
 backslash_quote                                      | safe_encoding                                                                    | Sets whether "\'" is allowed in string literals.
 block_size                                           | 32768                                                                            | Shows size of a disk block
 bonjour_name                                         |                                                                                  | Sets the Bonjour broadcast service name.
 check_function_bodies                                | on                                                                               | Check function bodies during CREATE FUNCTION.
 client_encoding                                      | UTF8                                                                             | Sets the client's character set encoding.
 client_min_messages                                  | notice                                                                           | Sets the message levels that are sent to the client.
 cpu_index_tuple_cost                                 | 0.005                                                                            | Sets the planner's estimate of the cost of processing each index entry during an index scan.
 cpu_operator_cost                                    | 0.0025                                                                           | Sets the planner's estimate of the cost of processing each operator or function call.
 cpu_tuple_cost                                       | 0.01                                                                             | Sets the planner's estimate of the cost of processing each tuple (row).
 cursor_tuple_fraction                                | 1                                                                                | Sets the planner's estimate of the fraction of a cursor's rows that will be retrieved.
 custom_variable_classes                              |                                                                                  | Sets the list of known custom variable classes.
 DateStyle                                            | ISO, MDY                                                                         | Sets the display format for date and time values.
 db_user_namespace                                    | off                                                                              | Enables per-database user names.
 deadlock_timeout                                     | 1s                                                                               | The time in milliseconds to wait on lock before checking for deadlock.
 debug_assertions                                     | off                                                                              | Turns on various assertion checks.
 debug_pretty_print                                   | off                                                                              | Indents parse and plan tree displays.
 debug_print_parse                                    | off                                                                              | Prints the parse tree to the server log.
 debug_print_plan                                     | off                                                                              | Prints the execution plan to server log.
 debug_print_prelim_plan                              | off                                                                              | Prints the preliminary execution plan to server log.
 debug_print_resource_queue_id                        | off                                                                              | Enables resource queue debug logging to the server log
 debug_print_rewritten                                | off                                                                              | Prints the parse tree after rewriting to server log.
 debug_print_slice_table                              | off                                                                              | Prints the slice table to server log.
 default_statistics_target                            | 25                                                                               | Sets the default statistics target.
 default_tablespace                                   |                                                                                  | Sets the default tablespace to create tables and indexes in.
 default_transaction_isolation                        | read committed                                                                   | Sets the transaction isolation level of each new transaction.
 default_transaction_read_only                        | off                                                                              | Sets the default read-only status of new transactions.
 dynamic_library_path                                 | $libdir                                                                          | Sets the path for dynamically loadable modules.
 effective_cache_size                                 | 512MB                                                                            | Sets the planner's assumption about size of the disk cache.
 enable_bitmapscan                                    | on                                                                               | Enables the planner's use of bitmap-scan plans.
 enable_groupagg                                      | on                                                                               | Enables the planner's use of grouping aggregation plans.
 enable_hashagg                                       | on                                                                               | Enables the planner's use of hashed aggregation plans.
 enable_hashjoin                                      | on                                                                               | Enables the planner's use of hash join plans.
 enable_indexscan                                     | on                                                                               | Enables the planner's use of index-scan plans.
 enable_mergejoin                                     | off                                                                              | Enables the planner's use of merge join plans.
 enable_nestloop                                      | off                                                                              | Enables the planner's use of nested-loop join plans.
 enable_seqscan                                       | off                                                                              | Enables the planner's use of sequential-scan plans.
 enable_sort                                          | on                                                                               | Enables the planner's use of explicit sort steps.
 enable_tidscan                                       | on                                                                               | Enables the planner's use of TID scan plans.
 escape_string_warning                                | on                                                                               | Warn about backslash escapes in ordinary string literals.
 explain_memory_verbosity                             | suppress                                                                         | Experimental feature: show memory account usage in EXPLAIN ANALYZE.
 explain_pretty_print                                 | on                                                                               | Uses the indented output format for EXPLAIN VERBOSE.
 extra_float_digits                                   | 0                                                                                | Sets the number of digits displayed for floating-point values.
 from_collapse_limit                                  | 20                                                                               | Sets the FROM-list size beyond which subqueries are not collapsed.
 gp_adjust_selectivity_for_outerjoins                 | on                                                                               | Adjust selectivity of null tests over outer joins.
 gp_analyze_relative_error                            | 0.25                                                                             | target relative error fraction for row sampling during analyze
 gp_appendonly_compaction_threshold                   | 10                                                                               | Threshold of the ratio of dirty data in a segment file over which the file will be compacted duri
ng lazy vacuum.
 gp_autostats_mode                                    | ON_NO_STATS                                                                      | Sets the autostats mode.
 gp_autostats_mode_in_functions                       | NONE                                                                             | Sets the autostats mode for statements in procedural language functions.
 gp_autostats_on_change_threshold                     | 2147483647                                                                       | Threshold for number of tuples added to table by CTAS or Insert-to to trigger autostats in on_cha
nge mode. See gp_autostats_mode.
 gp_backup_directIO                                   | off                                                                              | Enable direct IO dump
 gp_backup_directIO_read_chunk_mb                     | 20                                                                               | Size of read Chunk buffer in directIO dump (in MB)
 gp_cached_segworkers_threshold                       | 5                                                                                | Sets the maximum number of segment workers to cache between statements.
 gp_command_count                                     | 1                                                                                | Shows the number of commands received from the client in this session.
 gp_connectemc_mode                                   | on                                                                               | control connectemc functionality
 gp_connection_send_timeout                           | 3600                                                                             | Timeout for sending data to unresponsive clients (seconds)
 gp_connections_per_thread                            | 64                                                                               | Sets the number of client connections handled in each thread.
 gp_contentid                                         | -1                                                                               | The contentid used by this server.
 gp_create_table_random_default_distribution          | off                                                                              | Set the default distribution of a table to RANDOM.
 gp_dbid                                              | 1                                                                                | The dbid used by this server.
 gp_debug_linger                                      | 0                                                                                | Number of seconds for QD/QE process to linger upon fatal internal error.
 gp_default_storage_options                           | appendonly=false,blocksize=32768,compresstype=none,checksum=true,orientation=row | Default options for appendonly storage.
 gp_dynamic_partition_pruning                         | on                                                                               | This guc enables plans that can dynamically eliminate scanning of partitions.
 gp_email_connect_avoid_duration                      | 7200                                                                             | Sets the amount of time (in secs) to avoid connecting to SMTP server
 gp_email_connect_failures                            | 5                                                                                | Sets the number of consecutive connect failures before declaring SMTP server as unavailable
 gp_email_connect_timeout                             | 15                                                                               | Sets the amount of time (in secs) after which SMTP sockets would timeout
 gp_email_from                                        |                                                                                  | Sets email address of the sender of email alerts (our e-mail id).
 gp_email_smtp_password                               |                                                                                  | Sets the password used for the SMTP server, if required.
 gp_email_smtp_server                                 | localhost:25                                                                     | Sets the SMTP server and port used to send e-mail alerts.
 gp_email_smtp_userid                                 |                                                                                  | Sets the userid used for the SMTP server, if required.
 gp_email_to                                          |                                                                                  | Sets email address(es) to send alerts to.  Maybe be multiple email addresses.
 gp_enable_adaptive_nestloop                          | on                                                                               | Enables the planner's use of the Adaptive Join Choice operator.
 gp_enable_agg_distinct                               | on                                                                               | Enable 2-phase aggregation to compute a single distinct-qualified aggregate.
 gp_enable_agg_distinct_pruning                       | on                                                                               | Enable 3-phase aggregation and join to compute distinct-qualified aggregates.
 gp_enable_direct_dispatch                            | on                                                                               | Enable dispatch for single-row-insert targetted mirror-pairs.
 gp_enable_exchange_default_partition                 | off                                                                              | Allow DDL that will exchange default partitions.
 gp_enable_fallback_plan                              | on                                                                               | Plan types which are not enabled may be used when a query would be infeasible without them.
 gp_enable_fast_sri                                   | on                                                                               | Enable single-slice single-row inserts.
 gp_enable_gpperfmon                                  | on                                                                               | Enable gpperfmon monitoring.
 gp_enable_groupext_distinct_gather                   | on                                                                               | Enable gathering data to a single node to compute distinct-qualified aggregates on grouping exten
tion queries.
 gp_enable_groupext_distinct_pruning                  | on                                                                               | Enable 3-phase aggregation and join to compute distinct-qualified aggregates on grouping extentio
n queries.
 gp_enable_multiphase_agg                             | on                                                                               | Enables the planner's use of two- or three-stage parallel aggregation plans.
 gp_enable_predicate_propagation                      | on                                                                               | When two expressions are equivalent (such as with equijoined keys) then the planner applies predi
cates on one expression to the other expression.
 gp_enable_preunique                                  | on                                                                               | Enable 2-phase duplicate removal.
 gp_enable_relsize_collection                         | off                                                                              | This guc enables relsize collection when stats are not present. If disabled and stats are not pre
sent a default value is used.
 gp_enable_sequential_window_plans                    | on                                                                               | Experimental feature: Enable non-parallel window plans.
 gp_enable_sort_distinct                              | on                                                                               | Enable duplicate removal to be performed while sorting.
 gp_enable_sort_limit                                 | on                                                                               | Enable LIMIT operation to be performed while sorting.
 gp_external_enable_exec                              | on                                                                               | Enable selecting from an external table with an EXECUTE clause.
 gp_external_grant_privileges                         | off                                                                              | Enable non superusers to create http or gpfdist external tables.
 gp_external_max_segs                                 | 64                                                                               | Maximum number of segments that connect to a single gpfdist URL.
 gp_filerep_ct_batch_size                             | 65536                                                                            | Maximum number of blocks from changetracking log that a filerep resync worker processes at one ti
me.
 gp_filerep_tcp_keepalives_count                      | 2                                                                                | Maximum number of TCP keepalive retransmits for FileRep connection.
 gp_filerep_tcp_keepalives_idle                       | 1min                                                                             | Seconds between issuing TCP keepalives for FileRep connection.
 gp_filerep_tcp_keepalives_interval                   | 30s                                                                              | Seconds between TCP keepalive retransmits for FileRep connection.
 gp_fts_probe_interval                                | 1min                                                                             | A complete probe of all segments starts each time a timer with this period expires.
 gp_fts_probe_threadcount                             | 16                                                                               | Use this number of threads for probing the segments.
 gp_fts_probe_timeout                                 | 20s                                                                              | Maximum time (in seconds) allowed for FTS to complete probing a segment.
 gp_gpperfmon_send_interval                           | 1                                                                                | Interval in seconds between sending messages to gpperfmon.
 gp_hadoop_home                                       |                                                                                  | The location where Hadoop is installed in each segment.
 gp_hadoop_target_version                             | gphd-1.1                                                                         | The distro/version of Hadoop that external table is connecting to.
 gp_hashjoin_tuples_per_bucket                        | 5                                                                                | Target density of hashtable used by Hashjoin during execution
 gp_idf_deduplicate                                   | auto                                                                             | Sets the mode to control inverse distribution function's de-duplicate strategy.
 gp_initial_bad_row_limit                             | 1000                                                                             | Stops processing when number of the first bad rows exceeding this value
 gp_inline_simple_cte                                 | on                                                                               | Inline simple CTEs that are referred only once.
 gp_interconnect_cache_future_packets                 | on                                                                               | Control whether future packets are cached.
 gp_interconnect_debug_retry_interval                 | 10                                                                               | Sets the interval by retry times to record a debug message for retry.
 gp_interconnect_default_rtt                          | 20ms                                                                             | Sets the default rtt (in ms) for UDP interconnect
 gp_interconnect_fc_method                            | LOSS                                                                             | Sets the flow control method used for UDP interconnect.
 gp_interconnect_hash_multiplier                      | 2                                                                                | Sets the number of hash buckets used by the UDP interconnect to track connections (the number of 
buckets is given by the product of the segment count and the hash multipliers).
 gp_interconnect_min_retries_before_timeout           | 100                                                                              | Sets the min retries before reporting a transmit timeout in the interconnect.
 gp_interconnect_min_rto                              | 20ms                                                                             | Sets the min rto (in ms) for UDP interconnect
 gp_interconnect_queue_depth                          | 4                                                                                | Sets the maximum size of the receive queue for each connection in the UDP interconnect
 gp_interconnect_setup_timeout                        | 2h                                                                               | Timeout (in seconds) on interconnect setup that occurs at query start
 gp_interconnect_snd_queue_depth                      | 2                                                                                | Sets the maximum size of the send queue for each connection in the UDP interconnect
 gp_interconnect_tcp_listener_backlog                 | 128                                                                              | Size of the listening queue for each TCP interconnect socket
 gp_interconnect_timer_checking_period                | 20ms                                                                             | Sets the timer checking period (in ms) for UDP interconnect
 gp_interconnect_timer_period                         | 5ms                                                                              | Sets the timer period (in ms) for UDP interconnect
 gp_interconnect_transmit_timeout                     | 1h                                                                               | Timeout (in seconds) on interconnect to transmit a packet
 gp_interconnect_type                                 | UDPIFC                                                                           | Sets the protocol used for inter-node communication.
 gp_log_format                                        | csv                                                                              | Sets the format for log files.
 gp_max_csv_line_length                               | 1048576                                                                          | Maximum allowed length of a csv input data row in bytes
 gp_max_databases                                     | 16                                                                               | Sets the maximum number of databases.
 gp_max_filespaces                                    | 8                                                                                | Sets the maximum number of filespaces.
 gp_max_local_distributed_cache                       | 1024                                                                             | Sets the number of local-distributed transactions to cache for optimizing visibility processing b
y backends.
 gp_max_packet_size                                   | 8192                                                                             | Sets the max packet size for the Interconnect.
 gp_max_partition_level                               | 0                                                                                | Sets the maximum number of levels allowed when creating a partitioned table.
 gp_max_plan_size                                     | 0                                                                                | Sets the maximum size of a plan to be dispatched.
 gp_max_slices                                        | 0                                                                                | Maximum slices for a single query
 gp_max_tablespaces                                   | 16                                                                               | Sets the maximum number of tablespaces.
 gp_motion_cost_per_row                               | 0                                                                                | Sets the planner's estimate of the cost of moving a row between worker processes.
 gp_num_contents_in_cluster                           | 48                                                                               | Sets the number of segments in the cluster.
 gp_reject_percent_threshold                          | 300                                                                              | Reject limit in percent starts calculating after this number of rows processed
 gp_reraise_signal                                    | on                                                                               | Do we attempt to dump core when a serious problem occurs.
 gp_resqueue_memory_policy                            | eager_free                                                                       | Sets the policy for memory allocation of queries.
 gp_resqueue_priority                                 | on                                                                               | Enables priority scheduling.
 gp_resqueue_priority_cpucores_per_segment            | 4                                                                                | Number of processing units associated with a segment.
 gp_resqueue_priority_sweeper_interval                | 1000                                                                             | Frequency (in ms) at which sweeper process re-evaluates CPU shares.
 gp_role                                              | dispatch                                                                         | Sets the role for the session.
 gp_safefswritesize                                   | 0                                                                                | Minimum FS safe write size.
 gp_segment_connect_timeout                           | 10min                                                                            | Maximum time (in seconds) allowed for a new worker process to start or a mirror to respond.
 gp_segments_for_planner                              | 0                                                                                | If >0, number of segment dbs for the planner to assume in its cost and size estimates.
 gp_session_id                                        | 286470                                                                           | Global ID used to uniquely identify a particular session in an Greenplum Database array
 gp_set_proc_affinity                                 | off                                                                              | On postmaster startup, attempt to bind postmaster to a processor
 gp_snmp_community                                    | public                                                                           | Sets SNMP community name to send alerts (inform or trap messages) to.
 gp_snmp_monitor_address                              |                                                                                  | Sets the network address to send SNMP alerts (inform or trap messages) to.
 gp_snmp_use_inform_or_trap                           | trap                                                                             | If 'inform', we send alerts as SNMP v2c inform messages, if 'trap', we use SNMP v2 trap messages.
.
 gp_standby_dbid                                      | 98                                                                               | Sets DBID of standby master.
 gp_statistics_pullup_from_child_partition            | on                                                                               | This guc enables the planner to utilize statistics from partitions in planning queries on the par
ent.
 gp_statistics_use_fkeys                              | on                                                                               | This guc enables the planner to utilize statistics derived from foreign key relationships.
 gp_subtrans_warn_limit                               | 16777216                                                                         | Sets the warning limit on number of subtransactions in a transaction.
 gp_udp_bufsize_k                                     | 0                                                                                | Sets recv buf size of UDP interconnect, for testing.
 gp_vmem_idle_resource_timeout                        | 18s                                                                              | Sets the time a session can be idle (in milliseconds) before we release gangs on the segment DBs 
to free resources.
 gp_vmem_protect_limit                                | 262144                                                                           | Virtual memory limit (in MB) of Greenplum memory protection.
 gp_vmem_protect_segworker_cache_limit                | 500                                                                              | Max virtual memory limit (in MB) for a segworker to be cachable.
 gp_workfile_checksumming                             | on                                                                               | Enable checksumming on the executor work files in order to catch possible faulty writes caused by
 your disk drivers.
 gp_workfile_compress_algorithm                       | none                                                                             | Specify the compression algorithm that work files in the query executor use.
 gp_workfile_limit_files_per_query                    | 100000                                                                           | Maximum number of workfiles allowed per query per segment.
 gp_workfile_limit_per_query                          | 0                                                                                | Maximum disk space (in KB) used for workfiles per query per segment.
 gp_workfile_limit_per_segment                        | 0                                                                                | Maximum disk space (in KB) used for workfiles per segment.
 gpperfmon_log_alert_level                            | warning                                                                          | Specify the log alert level used by gpperfmon.
 gpperfmon_port                                       | 8888                                                                             | Sets the port number of gpperfmon.
 integer_datetimes                                    | on                                                                               | Datetimes are integer based.
 IntervalStyle                                        | postgres                                                                         | Sets the display format for interval values.
 join_collapse_limit                                  | 20                                                                               | Sets the FROM-list size beyond which JOIN constructs are not flattened.
 krb_caseins_users                                    | off                                                                              | Sets whether Kerberos user names should be treated as case-insensitive.
 krb_server_keyfile                                   | FILE:/usr/local/greenplum-db-devel/etc/postgresql/krb5.keytab                    | Sets the location of the Kerberos server key file.
 krb_srvname                                          | postgres                                                                         | Sets the name of the Kerberos service.
 lc_collate                                           | en_US.utf8                                                                       | Shows the collation order locale.
 lc_ctype                                             | en_US.utf8                                                                       | Shows the character classification and case conversion locale.
 lc_messages                                          | en_US.utf8                                                                       | Sets the language in which messages are displayed.
 lc_monetary                                          | en_US.utf8                                                                       | Sets the locale for formatting monetary amounts.
 lc_numeric                                           | en_US.utf8                                                                       | Sets the locale for formatting numbers.
 lc_time                                              | en_US.utf8                                                                       | Sets the locale for formatting date and time values.
 listen_addresses                                     | *                                                                                | Sets the host name or IP address(es) to listen to.
 local_preload_libraries                              |                                                                                  | Lists shared libraries to preload into each backend.
 log_autostats                                        | off                                                                              | Logs details of auto-stats issued ANALYZEs.
 log_connections                                      | off                                                                              | Logs each successful connection.
 log_count_recovered_files_batch                      | 1000                                                                             | Logs the total number of files shipped to the mirror after every batch of size specified by this 
value
 log_disconnections                                   | off                                                                              | Logs end of a session, including duration.
 log_dispatch_stats                                   | off                                                                              | Writes dispatcher performance statistics to the server log.
 log_duration                                         | off                                                                              | Logs the duration of each completed SQL statement.
 log_error_verbosity                                  | default                                                                          | Sets the verbosity of logged messages.
 log_executor_stats                                   | off                                                                              | Writes executor performance statistics to the server log.
 log_hostname                                         | off                                                                              | Logs the host name in the connection logs.
 log_min_duration_statement                           | -1                                                                               | Sets the minimum execution time in milliseconds above which statements will be logged.
 log_min_error_statement                              | error                                                                            | Causes all statements generating error at or above this level to be logged.
 log_min_messages                                     | warning                                                                          | Sets the message levels that are logged.
 log_parser_stats                                     | off                                                                              | Writes parser performance statistics to the server log.
 log_planner_stats                                    | off                                                                              | Writes planner performance statistics to the server log.
 log_rotation_age                                     | 1d                                                                               | Automatic log file rotation will occur after N minutes
 log_rotation_size                                    | 0                                                                                | Automatic log file rotation will occur after N kilobytes
 log_statement                                        | all                                                                              | Sets the type of statements logged.
 log_statement_stats                                  | off                                                                              | Writes cumulative performance statistics to the server log.
 log_timezone                                         | PRC                                                                              | Sets the time zone to use in log messages.
 log_truncate_on_rotation                             | off                                                                              | Truncate existing log files of same name during log rotation.
 maintenance_work_mem                                 | 64MB                                                                             | Sets the maximum memory to be used for maintenance operations.
 max_appendonly_tables                                | 10000                                                                            | Maximum number of different (unrelated) append only tables that can participate in writing data c
oncurrently.
 max_connections                                      | 700                                                                              | Sets the maximum number of concurrent connections.
 max_files_per_process                                | 1000                                                                             | Sets the maximum number of simultaneously open files for each server process.
 max_fsm_pages                                        | 960000                                                                           | Sets the maximum number of disk pages for which free space is tracked.
 max_fsm_relations                                    | 30000                                                                            | Sets the maximum number of tables and indexes for which free space is tracked.
 max_function_args                                    | 100                                                                              | Shows the maximum number of function arguments.
 max_identifier_length                                | 63                                                                               | Shows the maximum identifier length
 max_index_keys                                       | 32                                                                               | Shows the maximum number of index keys.
 max_locks_per_transaction                            | 256                                                                              | Sets the maximum number of locks per transaction.
 max_prepared_transactions                            | 600                                                                              | Sets the maximum number of simultaneously prepared transactions.
 max_resource_portals_per_transaction                 | 64                                                                               | Maximum number of resource queues.
 max_resource_queues                                  | 15                                                                               | Maximum number of resource queues.
 max_stack_depth                                      | 9MB                                                                              | Sets the maximum stack depth, in kilobytes.
 max_statement_mem                                    | 2000MB                                                                           | Sets the maximum value for statement_mem setting.
 max_work_mem                                         | 1000MB                                                                           | Sets the maximum value for work_mem setting.
 optimizer                                            | off                                                                              | Enable Pivotal Query Optimizer.
 optimizer_analyze_root_partition                     | on                                                                               | Enable statistics collection on root partitions during ANALYZE
 optimizer_control                                    | on                                                                               | Allow/disallow turning the optimizer on or off.
 optimizer_enable_associativity                       | off                                                                              | Enables Join Associativity in optimizer
 optimizer_join_arity_for_associativity_commutativity | 18                                                                               | Maximum number of children Nary-join can have without disabling commutativity and associativity t
ransform
 optimizer_join_order                                 | exhaustive                                                                       | Set optimizer join heuristic model.
 optimizer_minidump                                   | onerror                                                                          | Generate optimizer minidump.
 optimizer_parallel_union                             | on                                                                               | Enable parallel execution for UNION/UNION ALL queries.
 password_encryption                                  | on                                                                               | Encrypt passwords.
 password_hash_algorithm                              | MD5                                                                              | The cryptograph hash algorithm to apply to passwords before storing them.
 pgstat_track_activity_query_size                     | 1024                                                                             | Maximum length of the query to be displayed in pg_stat_activity
 pljava_classpath                                     |                                                                                  | classpath used by the the JVM
 pljava_classpath_insecure                            | off                                                                              | Allow pljava_classpath to be set by user per session
 pljava_release_lingering_savepoints                  | off                                                                              | If true, lingering savepoints will be released on function exit; if false, they will be rolled ba
ck
 pljava_statement_cache_size                          | 0                                                                                | Size of the prepared statement MRU cache
 pljava_vmoptions                                     |                                                                                  | Options sent to the JVM when it is created
 port                                                 | 5432                                                                             | Sets the TCP port the server listens on.
 random_page_cost                                     | 100                                                                              | Sets the planner's estimate of the cost of a nonsequentially fetched disk page.
 readable_external_table_timeout                      | 10min                                                                            | Cancel the query if no data read within N seconds.
 regex_flavor                                         | advanced                                                                         | Sets the regular expression "flavor".
 repl_catchup_within_range                            | 1                                                                                | Sets the maximum number of xlog segments allowed to lag when the backends can start blocking desp
ite the WAL sender being in catchup phase. (Master Mirroring)
 replication_timeout                                  | 1min                                                                             | Sets the maximum time to wait for WAL replication (Master Mirroring)
 resource_cleanup_gangs_on_wait                       | on                                                                               | Enable idle gang cleanup before resource lockwait.
 resource_select_only                                 | off                                                                              | Enable resource locking of SELECT only.
 runaway_detector_activation_percent                  | 90                                                                               | The runaway detector activates if the used vmem exceeds this percentage of the vmem quota. Set to
 100 to disable runaway detection.
 search_path                                          | sor, eda, dm, ldf, public, pg_catalog                                            | Sets the schema search order for names that are not schema-qualified.
 seq_page_cost                                        | 1                                                                                | Sets the planner's estimate of the cost of a sequentially fetched disk page.
 server_encoding                                      | UTF8                                                                             | Sets the server (database) character set encoding.
 server_version                                       | 8.2.15                                                                           | Shows the server version.
 server_version_num                                   | 80215                                                                            | Shows the server version as an integer.
 shared_buffers                                       | 1GB                                                                              | Sets the number of shared memory buffers used by the server.
 shared_preload_libraries                             |                                                                                  | Lists shared libraries to preload into server.
 ssl                                                  | off                                                                              | Enables SSL connections.
 ssl_ciphers                                          | ALL:!ADH:!LOW:!EXP:!MD5:@STRENGTH                                                | Sets the list of allowed SSL ciphers.
 standard_conforming_strings                          | off                                                                              | '...' strings treat backslashes literally.
 statement_mem                                        | 125MB                                                                            | Sets the memory to be reserved for a statement.
 statement_timeout                                    | 0                                                                                | Sets the maximum allowed duration (in milliseconds) of any statement.
 stats_queue_level                                    | off                                                                              | Collects resource queue-level statistics on database activity.
 superuser_reserved_connections                       | 3                                                                                | Sets the number of connection slots reserved for superusers.
 tcp_keepalives_count                                 | 0                                                                                | Maximum number of TCP keepalive retransmits.
 tcp_keepalives_idle                                  | 0                                                                                | Seconds between issuing TCP keepalives.
 tcp_keepalives_interval                              | 0                                                                                | Seconds between TCP keepalive retransmits.
 temp_buffers                                         | 1024                                                                             | Sets the maximum number of temporary buffers used by each session.
 TimeZone                                             | PRC                                                                              | Sets the time zone for displaying and interpreting time stamps.
 timezone_abbreviations                               | Default                                                                          | Selects a file of time zone abbreviations.
 track_activities                                     | on                                                                               | Collects information about executing commands.
 track_counts                                         | off                                                                              | Collects statistics on database activity.
 transaction_isolation                                | read committed                                                                   | Sets the current transaction's isolation level.
 transaction_read_only                                | off                                                                              | Sets the current transaction's read-only status.
 transform_null_equals                                | off                                                                              | Treats "expr=NULL" as "expr IS NULL".
 unix_socket_directory                                |                                                                                  | Sets the directory where the Unix-domain socket will be created.
 unix_socket_group                                    |                                                                                  | Sets the owning group of the Unix-domain socket.
 unix_socket_permissions                              | 511                                                                              | Sets the access permissions of the Unix-domain socket.
 update_process_title                                 | on                                                                               | Updates the process title to show the active SQL command.
 vacuum_cost_delay                                    | 0                                                                                | Vacuum cost delay in milliseconds.
 vacuum_cost_limit                                    | 800                                                                              | Vacuum cost amount available before napping.
 vacuum_cost_page_dirty                               | 10                                                                               | Vacuum cost for a page dirtied by vacuum.
 vacuum_cost_page_hit                                 | 1                                                                                | Vacuum cost for a page found in the buffer cache.
 vacuum_cost_page_miss                                | 5                                                                                | Vacuum cost for a page not found in the buffer cache.
 vacuum_freeze_min_age                                | 100000000                                                                        | Minimum age at which VACUUM should freeze a table row.
 wal_buffers                                          | 256kB                                                                            | Sets the number of disk-page buffers in shared memory for WAL.
 wal_receiver_status_interval                         | 10s                                                                              | Sets the maximum interval between WAL receiver status reports to the primary. (Master Mirroring)
 work_mem                                             | 32MB                                                                             | Sets the maximum memory to be used for query workspaces.
 writable_external_table_bufsize                      | 64kB                                                                             | Buffer size in kilo bytes for writable external table before writing data to gpfdist.
(279 rows)
 

发布了150 篇原创文章 · 获赞 46 · 访问量 11万+

猜你喜欢

转载自blog.csdn.net/MyySophia/article/details/103873020