name | setting | description |
---|---|---|
application_name | ssql | Sets the application name to be reported in statistics and logs. |
archive_cleanup_command | Sets 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_mode | off | Allows archiving of WAL files using archive_command. |
archive_timeout | 0 | Forces a switch to the next WAL file if a new file has not been started within N seconds. |
array_nulls | on | Enable input of NULL elements in arrays. |
authentication_timeout | 1min | Sets the maximum allowed time to complete client authentication. |
autovacuum | off | Starts the autovacuum subprocess. |
autovacuum_analyze_scale_factor | 0.1 | Number of tuple inserts, updates, or deletes prior to analyze as a fraction of reltuples. |
autovacuum_analyze_threshold | 50 | Minimum number of tuple inserts, updates, or deletes prior to analyze. |
autovacuum_freeze_max_age | 200000000 | Age at which to autovacuum a table to prevent transaction ID wraparound. |
autovacuum_max_workers | 3 | Sets the maximum number of simultaneously running autovacuum worker processes. |
autovacuum_multixact_freeze_max_age | 400000000 | Multixact age at which to autovacuum a table to prevent multixact wraparound. |
autovacuum_naptime | 1min | Time to sleep between autovacuum runs. |
autovacuum_vacuum_cost_delay | 2ms | Vacuum cost delay in milliseconds, for autovacuum. |
autovacuum_vacuum_cost_limit | -1 | Vacuum cost amount available before napping, for autovacuum. |
autovacuum_vacuum_scale_factor | 0.2 | Number of tuple updates or deletes prior to vacuum as a fraction of reltuples. |
autovacuum_vacuum_threshold | 50 | Minimum number of tuple updates or deletes prior to vacuum. |
autovacuum_work_mem | -1 | Sets the maximum memory to be used by each autovacuum worker process. |
backend_flush_after | 0 | Number of pages after which previously performed writes are flushed to disk. |
backslash_quote | safe_encoding | Sets whether “'” is allowed in string literals. |
bgwriter_delay | 200ms | Background writer sleep time between rounds. |
bgwriter_flush_after | 2MB | Number of pages after which previously performed writes are flushed to disk. |
bgwriter_lru_maxpages | 100 | Background writer maximum number of LRU pages to flush per round. |
bgwriter_lru_multiplier | 2 | Multiple of the average buffer usage to free per round. |
block_size | 32768 | Shows the size of a disk block. |
bonjour | off | Enables advertising the server via Bonjour. |
bonjour_name | Sets the Bonjour service name. | |
bytea_output | hex | Sets the output format for bytea. |
check_function_bodies | on | Check function bodies during CREATE FUNCTION. |
checkpoint_completion_target | 0.5 | Time spent flushing dirty buffers during checkpoint, as fraction of checkpoint interval. |
checkpoint_flush_after | 1MB | Number of pages after which previously performed writes are flushed to disk. |
checkpoint_timeout | 5min | Sets the maximum time between automatic WAL checkpoints. |
checkpoint_warning | 30s | Enables warnings if checkpoint segments are filled more frequently than this. |
client_encoding | UTF8 | Sets the client’s character set encoding. |
client_min_messages | notice | Sets the message levels that are sent to the client. |
cluster_name | Sets the name of the cluster, which is included in the process title. | |
commit_delay | 0 | Sets the delay in microseconds between transaction commit and flushing WAL to disk. |
commit_siblings | 5 | Sets the minimum concurrent open transactions before performing commit_delay. |
config_file | /home/seabox/ seabox-data-directory/ coordinatordd/0/ seaboxsql.conf |
Sets the server’s main configuration file. |
constraint_exclusion | partition | Enables the planner to use constraints to optimize queries. |
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 | 0.1 | Sets the planner’s estimate of the fraction of a cursor’s rows that will be retrieved. |
cursor_tuple_fraction | 0.1 | Sets the planner’s estimate of the fraction of a cursor’s rows that will be retrieved. |
data_checksums | on | Shows whether data checksums are turned on for this cluster. |
data_directory | /home/seabox/ seabox-data-directory/ coordinatordd/0 |
Sets the server’s data directory. |
data_directory_mode | 0700 | Mode of the data directory. |
data_encryption | off | Shows whether data encryption is turned on for this cluster. |
data_sync_retry | off | Whether to continue running after a failure to sync data files. |
DateStyle | ISO, MDY | Sets the display format for date and time values. |
db_user_namespace | off | Enables per-database user names. |
deadlock_timeout | 1s | Sets the time to wait on a lock before checking for deadlock. |
debug_assertions | off | Shows whether the running server has assertion checks enabled. |
debug_deadlocks | off | Dumps information about all current locks when a deadlock timeout occurs. |
debug_disable_vecengine | disable some oprators of batch execution. | |
debug_pretty_print | on | Indents parse and plan tree displays. |
debug_print_parse | off | Logs each query’s parse tree. |
debug_print_plan | off | Logs each query’s execution plan. |
debug_print_prelim_plan | off | Prints the preliminary execution plan to server log. |
debug_print_rewritten | off | Logs each query’s rewritten parse tree. |
debug_print_slice_table | off | Prints the slice table to server log. |
debug_ve_buffer_data_size | 512MB | ve block buffer data size |
debug_ve_buffer_queue_size | 128 | ve block buffer queue size |
debug_ve_function | hybrid | The options of function debug. |
debug_vecengine | vecengine debug option. | |
default_decimal_precision | 18 | Default decimal precision. |
default_decimal_scale | 2 | Default decimal precision. |
default_statistics_target | 100 | Sets the default statistics target. |
default_table_access_method | heap | Sets the default table access method for new tables. |
default_tablespace | Sets the default tablespace to create tables and indexes in. | |
default_text_search_config | pg_catalog.simple | Sets default text search configuration. |
default_transaction_deferrable | off | Sets the default deferrable status of new transactions. |
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. |
dynamic_shared_memory_type | posix | Selects the dynamic shared memory implementation used. |
effective_cache_size | 16GB | Sets the planner’s assumption about the total size of the data caches. |
effective_io_concurrency | 1 | Number of simultaneous requests that can be handled efficiently by the disk subsystem. |
enable_bitmapscan | on | Enables the planner’s use of bitmap-scan plans. |
enable_dump_io_statistics | off | Enable dump io performance counters. |
enable_gathermerge | on | Enables the planner’s use of gather merge plans. |
enable_groupagg | on | Enables the planner’s use of grouping aggregation plans. |
enable_groupingsets_hash_disk | off | Enables the planner’s use of hashed aggregation plans for groupingsets when the total size of the hash tables is expected to exceed work_mem. |
enable_hashagg | on | Enables the planner’s use of hashed aggregation plans. |
enable_hashagg_disk | on | Enables the planner’s use of hashed aggregation plans that are expected to exceed work_mem. |
enable_hashjoin | on | Enables the planner’s use of hash join plans. |
enable_indexonlyscan | on | Enables the planner’s use of index-only-scan plans. |
enable_indexscan | on | Enables the planner’s use of index-scan plans. |
enable_material | on | Enables the planner’s use of materialization. |
enable_mergejoin | on | Enables the planner’s use of merge join plans. |
enable_minimize_tlist | on | Enable prune target list. |
enable_nestloop | on | Enables the planner’s use of nested-loop join plans. |
enable_parallel_append | on | Enables the planner’s use of parallel append plans. |
enable_parallel_hash | on | Enables the planner’s use of parallel hash plans. |
enable_partition_pruning | on | Enables plan-time and run-time partition pruning. |
enable_partitionwise_aggregate | off | Enables partitionwise aggregation and grouping. |
enable_partitionwise_join | off | Enables partitionwise join. |
enable_runtime_filter | on | Enable runtime filter. |
enable_seqscan | on | Enables the planner’s use of sequential-scan plans. |
enable_sort | on | Enables the planner’s use of explicit sort steps. |
enable_table_flashback | off | Enable drop table use flashback. |
enable_tidscan | on | Enables the planner’s use of TID scan plans. |
enable_vecengine | off | Enable vector engine. |
escape_string_warning | on | Warn about backslash escapes in ordinary string literals. |
event_source | SeaboxSQL | Sets the application name used to identify SeaboxSQL messages in the event log. |
exit_on_error | off | Terminate session on any error. |
explain_memory_verbosity | suppress | Experimental feature: show memory account usage in EXPLAIN ANALYZE. |
external_pid_file | Writes the seaboxmaster PID to the specified file. | |
extra_float_digits | 1 | Sets the number of digits displayed for floating-point values. |
force_parallel_mode | off | Forces use of parallel query facilities. |
from_collapse_limit | 8 | Sets the FROM-list size beyond which subqueries are not collapsed. |
fsync | on | Forces synchronization of updates to disk. |
full_page_writes | on | Writes full pages to WAL when first modified after a checkpoint. |
function_hybrid | on | Set hybrid function for vector engine. |
geqo | on | Enables genetic query optimization. |
geqo_effort | 5 | GEQO: effort is used to set the default for other GEQO parameters. |
geqo_generations | 0 | GEQO: number of iterations of the algorithm. |
geqo_pool_size | 0 | GEQO: number of individuals in the population. |
geqo_seed | 0 | GEQO: seed for random path selection. |
geqo_selection_bias | 2 | GEQO: selective pressure within the population. |
geqo_threshold | 12 | Sets the threshold of FROM items beyond which GEQO is used. |
gin_fuzzy_search_limit | 0 | Sets the maximum allowed result for exact search by GIN. |
gin_pending_list_limit | 4MB | Sets the maximum size of the pending list for GIN index. |
hba_file | /home/seabox/ seabox-data-directory/ coordinatordd/0/sd_hba.conf |
Sets the server’s “hba” configuration file. |
hot_standby | on | Allows connections and queries during recovery. |
hot_standby_feedback | off | Allows feedback from a hot standby to the primary that will avoid query conflicts. |
huge_pages | try | Use of huge pages on Linux or Windows. |
ident_file | /home/seabox/ seabox-data-directory/ coordinatordd/0/sd_ident.conf |
Sets the server’s “ident” configuration file. |
idle_in_transaction_session_timeout | 0 | Sets the maximum allowed duration of any idling transaction. |
ignore_checksum_failure | off | Continues processing after a checksum failure. |
ignore_system_indexes | off | Disables reading from system indexes. |
integer_datetimes | on | Datetimes are integer based. |
IntervalStyle | postgres | Sets the display format for interval values. |
jit | off | Allow JIT compilation. |
jit_above_cost | 100000 | Perform JIT compilation if query is more expensive. |
jit_debugging_support | off | Register JIT compiled function with debugger. |
jit_dump_bitcode | off | Write out LLVM bitcode to facilitate JIT debugging. |
jit_expressions | on | Allow JIT compilation of expressions. |
jit_inline_above_cost | 500000 | Perform JIT inlining if query is more expensive. |
jit_optimize_above_cost | 500000 | Optimize JITed functions if query is more expensive. |
jit_profiling_support | off | Register JIT compiled function with perf profiler. |
jit_provider | llvmjit | JIT provider to use. |
jit_tuple_deforming | on | Allow JIT compilation of tuple deforming. |
join_collapse_limit | 8 | Sets the FROM-list size beyond which JOIN constructs are not flattened. |
krb_caseins_users | off | Sets whether Kerberos and GSSAPI user names should be treated as case-insensitive. |
krb_server_keyfile | Sets the location of the Kerberos server key file. | |
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. |
lo_compat_privileges | off | Enables backward compatibility mode for privilege checks on large objects. |
local_preload_libraries | Lists unprivileged shared libraries to preload into each backend. | |
lock_timeout | 0 | Sets the maximum allowed duration of any wait for a lock. |
log_autovacuum_min_duration | -1 | Sets the minimum execution time above which autovacuum actions will be logged. |
log_checkpoints | off | Logs each checkpoint. |
log_connections | off | Logs each successful connection. |
log_destination | csvlog | Sets the destination for server log output. |
log_directory | log | Sets the destination directory for log files. |
log_disconnections | off | Logs end of a session, including duration. |
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_file_mode | 0600 | Sets the file permissions for log files. |
log_filename | seaboxsql-%Y-%m-%d_%H%M%S.log | Sets the file name pattern for log files. |
log_hostname | off | Logs the host name in the connection logs. |
log_line_prefix | %m [%p] | Controls information prefixed to each log line. |
log_lock_waits | off | Logs long lock waits. |
log_min_duration_statement | -1 | Sets the minimum execution time 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_replication_commands | off | Logs each replication command. |
log_rotation_age | 1d | Automatic log file rotation will occur after N minutes. |
log_rotation_size | 10MB | Automatic log file rotation will occur after N kilobytes. |
log_statement | none | Sets the type of statements logged. |
log_statement_stats | off | Writes cumulative performance statistics to the server log. |
log_temp_files | -1 | Log the use of temporary files larger than this number of kilobytes. |
log_timezone | Asia/Shanghai | Sets the time zone to use in log messages. |
log_transaction_sample_rate | 0 | Set the fraction of transactions to log for new transactions. |
log_truncate_on_rotation | off | Truncate existing log files of same name during log rotation. |
logging_collector | on | Start a subprocess to capture stderr output and/or csvlogs into log files. |
maintenance_work_mem | 64MB | Sets the maximum memory to be used for maintenance operations. |
max_connections | 250 | 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_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 | 64 | Sets the maximum number of locks per transaction. |
max_logical_replication_workers | 4 | Maximum number of logical replication worker processes. |
max_parallel_maintenance_workers | 2 | Sets the maximum number of parallel processes per maintenance operation. |
max_parallel_workers | 8 | Sets the maximum number of parallel workers that can be active at one time. |
max_parallel_workers_per_gather | 0 | Sets the maximum number of parallel processes per executor node. |
max_pred_locks_per_page | 2 | Sets the maximum number of predicate-locked tuples per page. |
max_pred_locks_per_relation | -2 | Sets the maximum number of predicate-locked pages and tuples per relation. |
max_pred_locks_per_transaction | 64 | Sets the maximum number of predicate locks per transaction. |
max_prepared_transactions | 50 | Sets the maximum number of simultaneously prepared transactions. |
max_replication_slots | 10 | Sets the maximum number of simultaneously defined replication slots. |
max_resource_portals_per_transaction | 64 | Maximum number of resource queues. |
max_resource_queues | 9 | Maximum number of resource queues. |
max_stack_depth | 2MB | Sets the maximum stack depth, in kilobytes. |
max_standby_archive_delay | 30s | Sets the maximum delay before canceling queries when a hot standby server is processing archived WAL data. |
max_standby_streaming_delay | 30s | Sets the maximum delay before canceling queries when a hot standby server is processing streamed WAL data. |
max_sync_workers_per_subscription | 2 | Maximum number of table synchronization workers per subscription. |
max_wal_senders | 10 | Sets the maximum number of simultaneously running WAL sender processes. |
max_wal_size | 1GB | Sets the WAL size that triggers a checkpoint. |
max_worker_processes | 8 | Maximum number of concurrent worker processes. |
memory_spill_ratio | 20 | Sets the memory_spill_ratio for resource group. |
min_parallel_index_scan_size | 512kB | Sets the minimum amount of index data for a parallel scan. |
min_parallel_table_scan_size | 8MB | Sets the minimum amount of table data for a parallel scan. |
min_wal_size | 80MB | Sets the minimum size to shrink the WAL to. |
old_snapshot_threshold | -1 | Time before a snapshot is too old to read pages changed after the snapshot was taken. |
operator_precedence_warning | off | Emit a warning for constructs that changed meaning since SeaboxSQL 9.4. |
optimizer | off | Enable SDORCA. |
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 n-ary-join have without disabling commutativity and associativity transform |
optimizer_join_order | exhaustive | Set optimizer join heuristic model. |
optimizer_join_order_threshold | 10 | Maximum number of join children to use dynamic programming based join ordering algorithm. |
optimizer_mdcache_size | 16MB | Sets the size of MDCache. |
optimizer_metadata_caching | on | This guc enables the optimizer to cache and reuse metadata. |
optimizer_minidump | onerror | Generate optimizer minidump. |
optimizer_parallel_union | off | Enable parallel execution for UNION/UNION ALL queries. |
parallel_leader_participation | on | Controls whether Gather and Gather Merge also run subplans. |
parallel_setup_cost | 1000 | Sets the planner’s estimate of the cost of starting up worker processes for parallel query. |
parallel_tuple_cost | 0.1 | Sets the planner’s estimate of the cost of passing each tuple (row) from worker to master backend. |
password_encryption | md5 | Chooses the algorithm for encrypting passwords. |
pgxc_node_name | coord1 | The Coordinator or Datanode name. |
plan_cache_mode | auto | Controls the planner’s selection of custom or generic plan. |
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 back |
pljava_statement_cache_size | 0 | Size of the prepared statement MRU cache |
pljava_vmoptions | Options sent to the JVM when it is created | |
port | 3000 | Sets the TCP port the server listens on. |
post_auth_delay | 0 | Waits N seconds on connection startup after authentication. |
pre_auth_delay | 0 | Waits N seconds on connection startup before authentication. |
primary_conninfo | Sets the connection string to be used to connect to the sending server. | |
primary_slot_name | Sets the name of the replication slot to use on the sending server. | |
promote_trigger_file | Specifies a file name whose presence ends recovery in the standby. | |
quote_all_identifiers | off | When generating SQL fragments, quote all identifiers. |
random_page_cost | 4 | Sets the planner’s estimate of the cost of a nonsequentially fetched disk page. |
readable_external_table_timeout | 1min | Cancel the query if no data read within N seconds. |
recovery_end_command | Sets the shell command that will be executed once at the end of recovery. | |
recovery_min_apply_delay | 0 | Sets the minimum delay for applying changes during recovery. |
recovery_skip_sync_data_dir | on | Skip the data directory synchronization of column tables while recoverying. |
recovery_target | Set to “immediate” to end recovery as soon as a consistent state is reached. | |
recovery_target_action | pause | Sets the action to perform upon reaching the recovery target. |
recovery_target_inclusive | on | Sets whether to include or exclude transaction with recovery target. |
recovery_target_lsn | Sets the LSN of the write-ahead log location up to which recovery will proceed. | |
recovery_target_name | Sets the named restore point up to which recovery will proceed. | |
recovery_target_time | Sets the time stamp up to which recovery will proceed. | |
recovery_target_timeline | latest | Specifies the timeline to recover into. |
recovery_target_xid | Sets the transaction ID up to which recovery will proceed. | |
resource_cleanup_gangs_on_wait | on | Enable idle gang cleanup before resource lockwait. |
resource_scheduler | on | Enable resource scheduling. |
resource_select_only | off | Enable resource locking of SELECT only. |
restart_after_crash | on | Reinitialize server after backend crash. |
restore_command | Sets the shell command that will retrieve an archived WAL file. | |
row_security | on | Enable row security. |
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. |
sc_active_backend_resqueue_length_cv | 0 | set to true to use new sc_active_backend_resqueue implemented with cv. |
sc_adjust_selectivity_for_outerjoins | on | Adjust selectivity of null tests over outer joins. |
sc_autostats_mode | none | Sets the autostats mode. |
sc_autostats_mode_in_functions | none | Sets the autostats mode for statements in procedural language functions. |
sc_cached_segworkers_threshold | 5 | Sets the maximum number of executor workers to cache between statements. |
sc_command_count | 1 | Shows the number of commands received from the client in this session. |
sc_contentid | -1 | The contentid used by this server. |
sc_create_table_random_default_distribution | off | Set the default distribution of a table to RANDOM. |
sc_dbid | 1 | The dbid used by this server. |
sc_dcs_conn_str | 172.16.3.76:2379 | The scdcs connection string used by this server. |
sc_dcs_top_path | /seabox | The scdcs top path for this cluster. |
sc_debug_linger | 0 | Number of seconds for QD/QE process to linger upon fatal internal error. |
sc_default_storage_options | blocksize=1048576, compresstype=auto, charsemantics=byte, compresslevel=1, checksum=true, blockrownum=32768, cache=false |
default options for scolumn storage. |
sc_dtx_recovery_interval | 1min | A complete checking in dtx recovery process starts each time a timer with this period expires. |
sc_dtx_recovery_prepared_period | 2min | Gather prepared transactions before the time (in seconds) to find potential orphaned ones. |
sc_dynamic_partition_pruning | on | This guc enables plans that can dynamically eliminate scanning of partitions. |
sc_enable_agg_distinct | on | Enable 2-phase aggregation to compute a single distinct-qualified aggregate. |
sc_enable_agg_distinct_pruning | on | Enable 3-phase aggregation and join to compute distinct-qualified aggregates. |
sc_enable_direct_dispatch | on | Enable dispatch for single-row-insert targetted mirror-pairs. |
sc_enable_explain_memory_account | off | Enable memory account in EXPLAIN ANALYZE. |
sc_enable_fast_sri | on | Enable single-slice single-row inserts. |
sc_enable_global_deadlock_detector | on | Enables the Global Deadlock Detector. |
sc_enable_minmax_optimization | on | Enables the planner’s use of index scans with limit to implement MIN/MAX. |
sc_enable_multiphase_agg | on | Enables the planner’s use of two- or three-stage parallel aggregation plans. |
sc_enable_opt_no_mergejoin | off | This guc force mergejoin path not to be generated. |
sc_enable_predicate_propagation | on | When two expressions are equivalent (such as with equijoined keys) then the planner applies predicates on one expression to the other expression. |
sc_enable_preunique | on | Enable 2-phase duplicate removal. |
sc_enable_query_metrics | off | Enable all query metrics collection. |
sc_enable_relsize_collection | off | This guc enables relsize collection when stats are not present. If disabled and stats are not present a default value is used. |
sc_enable_sort_distinct | on | Enable duplicate removal to be performed while sorting. |
sc_enable_sort_limit | on | Enable LIMIT operation to be performed while sorting. |
sc_executors_for_planner | 0 | If >0, number of executor dbs for the planner to assume in its cost and size estimates. |
sc_external_enable_exec | on | Enable selecting from an external table with an EXECUTE clause. |
sc_external_enable_filter_pushdown | on | Enable passing of query constraints to external table providers |
sc_external_max_execs | 64 | Maximum number of executors that connect to a single scfs URL. |
sc_external_table_default_size | 819200s | Default value for external table size. |
sc_fts_mark_mirror_down_grace_period | 30s | Time (in seconds) allowed to mirror after disconnection, to reconnect before being marked as down in configuration by FTS. |
sc_fts_probe_interval | 10s | A complete probe of all executors starts each time a timer with this period expires. |
sc_fts_probe_retries | 5 | Number of retries for FTS to complete probing a executor. |
sc_fts_probe_timeout | 20 | Maximum time (in seconds) allowed for FTS to complete probing a executor. |
sc_global_deadlock_detector_period | 30s | Sets the executing period of global deadlock detector backend. |
sc_hashjoin_tuples_per_bucket | 1 | Target density of hashtable used by Hashjoin during execution |
sc_instrument_shmem_size | 5MB | Sets the size of shmem allocated for instrumentation. |
sc_interconnect_cache_future_packets | on | Control whether future packets are cached. |
sc_interconnect_debug_retry_interval | 10 | Sets the interval by retry times to record a debug message for retry. |
sc_interconnect_default_rtt | 20ms | Sets the default rtt (in ms) for UDP interconnect |
sc_interconnect_fc_method | loss | Sets the flow control method used for UDP interconnect. |
sc_interconnect_min_retries_before_timeout | 100 | Sets the min retries before reporting a transmit timeout in the interconnect. |
sc_interconnect_min_rto | 20ms | Sets the min rto (in ms) for UDP interconnect |
sc_interconnect_queue_depth | 4 | Sets the maximum size of the receive queue for each connection in the UDP interconnect |
sc_interconnect_setup_timeout | 2h | Timeout (in seconds) on interconnect setup that occurs at query start |
sc_interconnect_snd_queue_depth | 2 | Sets the maximum size of the send queue for each connection in the UDP interconnect |
sc_interconnect_tcp_listener_backlog | 128 | Size of the listening queue for each TCP interconnect socket |
sc_interconnect_timer_checking_period | 20ms | Sets the timer checking period (in ms) for UDP interconnect |
sc_interconnect_timer_period | 5ms | Sets the timer period (in ms) for UDP interconnect |
sc_interconnect_transmit_timeout | 1h | Timeout (in seconds) on interconnect to transmit a packet |
sc_interconnect_type | udpifc | Sets the protocol used for inter-node communication. |
sc_max_local_distributed_cache | 1024 | Sets the number of local-distributed transactions to cache for optimizing visibility processing by backends. |
sc_max_packet_size | 32768 | Sets the max packet size for the Interconnect. |
sc_max_partition_level | 0 | Sets the maximum number of levels allowed when creating a partitioned table. |
sc_max_plan_size | 0 | Sets the maximum size of a plan to be dispatched. |
sc_max_slices | 0 | Maximum slices for a single query |
sc_module_register_time | 10 | Define how often module must register to scdcs. Unit: second |
sc_motion_cost_per_row | 0 | Sets the planner’s estimate of the cost of moving a row between worker processes. |
sc_node_connect_timeout | 3min | Maximum time (in seconds) allowed for a new worker process to start or a mirror to respond. |
sc_numa_policy | none | Sets the type of numa. |
sc_reject_percent_threshold | 300 | Reject limit in percent starts calculating after this number of rows processed |
sc_resgroup_memory_policy | eager_free | Sets the policy for memory allocation of queries. |
sc_resource_group_bypass | off | If the value is true, the query in this session will not be limited by resource group. |
sc_resource_group_cgroup_memory | 0 | Set value of total memory in resource group mode. |
sc_resource_group_cpu_limit | 0.9 | Maximum percentage of CPU resources assigned to a cluster. |
sc_resource_group_cpu_priority | 10 | Sets the cpu priority for seaboxsql processes when resource group is enabled. |
sc_resource_group_memory_limit | 0.7 | Maximum percentage of memory resources assigned to a cluster. |
sc_resource_group_queuing_timeout | 0 | A transaction gives up on queuing on a resource group after this timeout (in ms). |
sc_resource_manager | none | Sets the type of resource manager. |
sc_resqueue_memory_policy | eager_free | Sets the policy for memory allocation of queries. |
sc_resqueue_priority | on | Enables priority scheduling. |
sc_resqueue_priority_cpucores_per_executor | 1 | Number of processing units associated with a executor. |
sc_resqueue_priority_sweeper_interval | 1000 | Frequency (in ms) at which sweeper process re-evaluates CPU shares. |
sc_scolumn_compaction_threshold | 10 | Threshold of the ratio of dirty data in a executor file over which the file will be compacted during lazy vacuum. |
sc_session_id | 268435471 | Global ID used to uniquely identify a particular session in an Seabox Database array |
sc_subtrans_warn_limit | 16777216 | Sets the warning limit on number of subtransactions in a transaction. |
sc_temptable_buffer_skip_flush | on | temptable shared buffer skip flush if relfile not exists. |
sc_udp_bufsize_k | 0 | Sets recv buf size of UDP interconnect, for testing. |
sc_ve_hash_mem | 10GB | The hash table memory size in kB |
sc_ve_mem_limit | 0 | The memory limit of vecengine in kB |
sc_ve_two_level_hash_mem | 100MB | Min kB to use 2-level hash |
sc_vmem_idle_resource_timeout | 18s | Sets the time a session can be idle (in milliseconds) before we release gangs on the executor DBs to free resources. |
sc_vmem_protect_limit | 102400 | Virtual memory limit (in MB) of Seabox database memory protection. |
sc_vmem_protect_segworker_cache_limit | 500 | Max virtual memory limit (in MB) for a segworker to be cachable. |
sc_workfile_compression | off | Enables compression of temporary files. |
sc_workfile_limit_files_per_query | 100000 | Maximum number of workfiles allowed per query per executor. |
sc_workfile_limit_per_executor | 0 | Maximum disk space (in KB) used for workfiles per executor. |
sc_workfile_limit_per_query | 0 | Maximum disk space (in KB) used for workfiles per query per executor. |
sc_workfile_limit_per_query | 0 | Maximum disk space (in KB) used for workfiles per query per executor. |
sc_workfile_max_entries | 8192 | Sets the maximum number of entries that can be stored in the workfile directory. |
scolumn_delete_option | hash | The options of update/delete on scolumn when has join. |
scolumn_heap_cache_option | off | The options of scolumn cache table’s usage. |
scolumn_row_to_block_threshold | 32768 | Shows the threshold of rows of data in heap cache table convert to column. |
scolumn_sample_method | vitter2 | Sample method for scolumn. |
scolumn_sparse_index | on | Enable scolumn table use sparse index. |
scolumn_stats_level | 1 | level of calculating stats of column. |
scolumn_store_sort | on | SColumn store data partitial sorted. |
scolumn_update_one_to_multi | off | Enable scolumn table to update one row to multi-records. |
scolumn_wal_block_size | 64kB | Shows the block size that scolumn storage write in the write ahead log. |
scolumn_wal_check_level | 0 | The check leve of scolumn wal between primary and mirror. |
sd_enable_crash_log | on | Do not write stack information to log file. |
sd_enable_mac | off | Support Mandatory Access Control(mac). |
sd_role | dispatch | Sets the role for the session. |
search_path | “$user”, public | Sets the schema search order for names that are not schema-qualified. |
segment_size | 1GB | Shows the number of pages per disk file. |
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 | 12.3 | Shows the server version. |
server_version_num | 120003 | Shows the server version as an integer. |
session_preload_libraries | Lists shared libraries to preload into each backend. | |
session_replication_role | origin | Sets the session’s behavior for triggers and rewrite rules. |
shared_buffers | 128MB | Sets the number of shared memory buffers used by the server. |
shared_memory_type | mmap | Selects the shared memory implementation used for the main shared memory region. |
shared_preload_libraries | Lists shared libraries to preload into server. | |
ssl | off | Enables SSL connections. |
ssl_ca_file | Location of the SSL certificate authority file. | |
ssl_cert_file | server.crt | Location of the SSL server certificate file. |
ssl_ciphers | HIGH:MEDIUM:+3DES:!aNULL | Sets the list of allowed SSL ciphers. |
ssl_crl_file | Location of the SSL certificate revocation list file. | |
ssl_dh_params_file | Location of the SSL DH parameters file. | |
ssl_ecdh_curve | prime256v1 | Sets the curve to use for ECDH. |
ssl_key_file | server.key | Location of the SSL server private key file. |
ssl_library | OpenSSL | Name of the SSL library. |
ssl_max_protocol_version | Sets the maximum SSL/TLS protocol version to use. | |
ssl_min_protocol_version | TLSv1 | Sets the minimum SSL/TLS protocol version to use. |
ssl_passphrase_command | Command to obtain passphrases for SSL. | |
ssl_passphrase_command_supports_reload | off | Also use ssl_passphrase_command during server reload. |
ssl_prefer_server_ciphers | on | Give priority to server ciphersuite order. |
standard_conforming_strings | on | Causes ‘…’ strings to treat backslashes literally. |
statement_mem | 125MB | Sets the memory to be reserved for a statement. |
statement_timeout | 0 | Sets the maximum allowed duration of any statement. |
stats_queue_level | off | Collects resource queue-level statistics on database activity. |
stats_temp_directory | sd_stat_tmp | Writes temporary statistics files to the specified directory. |
superuser_reserved_connections | 3 | Sets the number of connection slots reserved for superusers. |
synchronize_seqscans | on | Enable synchronized sequential scans. |
synchronous_commit | on | Sets the current transaction’s synchronization level. |
synchronous_standby_names | Number of synchronous standbys and list of names of potential synchronous ones. | |
syslog_facility | local0 | Sets the syslog “facility” to be used when syslog enabled. |
syslog_ident | seaboxsql | Sets the program name used to identify SeaboxSQL messages in syslog. |
syslog_sequence_numbers | on | Add sequence number to syslog messages to avoid duplicate suppression. |
syslog_split_messages | on | Split messages sent to syslog by lines and to fit into 1024 bytes. |
tcp_keepalives_count | 0 | Maximum number of TCP keepalive retransmits. |
tcp_keepalives_idle | 0 | Time between issuing TCP keepalives. |
tcp_keepalives_interval | 0 | Time between TCP keepalive retransmits. |
tcp_user_timeout | 0 | TCP user timeout. |
temp_buffers | 32MB | Sets the maximum number of temporary buffers used by each session. |
temp_file_limit | -1 | Limits the total size of all temporary files used by each process. |
temp_tablespaces | Sets the tablespace(s) to use for temporary tables and sort files. | |
TimeZone | Asia/Shanghai | Sets the time zone for displaying and interpreting time stamps. |
timezone_abbreviations | Default | Selects a file of time zone abbreviations. |
trace_lock_oidmin | 16384 | Sets the minimum OID of tables for tracking locks. |
trace_lock_table | 0 | Sets the OID of the table with unconditionally lock tracing. |
trace_locks | off | Emits information about lock usage. |
trace_lwlocks | off | Emits information about lightweight lock usage. |
trace_notify | off | Generates debugging output for LISTEN and NOTIFY. |
trace_recovery_messages | log | Enables logging of recovery-related debugging information. |
trace_sort | off | Emit information about resource usage in sorting. |
trace_userlocks | off | Emits information about user lock usage. |
traceme_flags | debug option to enable extra trace_me flags. | |
track_activities | on | Collects information about executing commands. |
track_activity_query_size | 1kB | Sets the size reserved for pg_stat_activity.query, in bytes. |
track_commit_timestamp | off | Collects transaction commit time. |
track_counts | on | Collects statistics on database activity. |
track_functions | none | Collects function-level statistics on database activity. |
track_io_timing | off | Collects timing statistics for database I/O activity. |
transaction_deferrable | off | Whether to defer a read-only serializable transaction until it can be executed with no possible serialization failures. |
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_directories | /tmp | Sets the directories where Unix-domain sockets will be created. |
unix_socket_group | Sets the owning group of the Unix-domain socket. | |
unix_socket_permissions | 0777 | Sets the access permissions of the Unix-domain socket. |
update_process_title | on | Updates the process title to show the active SQL command. |
vacuum_cleanup_index_scale_factor | 0.1 | Number of tuple inserts prior to index cleanup as a fraction of reltuples. |
vacuum_cost_delay | 0 | Vacuum cost delay in milliseconds. |
vacuum_cost_limit | 200 | Vacuum cost amount available before napping. |
vacuum_cost_page_dirty | 20 | 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 | 10 | Vacuum cost for a page not found in the buffer cache. |
vacuum_defer_cleanup_age | 0 | Number of transactions by which VACUUM and HOT cleanup should be deferred, if any. |
vacuum_freeze_min_age | 50000000 | Minimum age at which VACUUM should freeze a table row. |
vacuum_freeze_table_age | 150000000 | Age at which VACUUM should scan whole table to freeze tuples. |
vacuum_multixact_freeze_min_age | 5000000 | Minimum age at which VACUUM should freeze a MultiXactId in a table row. |
vacuum_multixact_freeze_table_age | 150000000 | Multixact age at which VACUUM should scan whole table to freeze tuples. |
ve_aggr_always_nullable | on | Whether VE should make aggregate functions return nullable result. |
ve_copy_strict_mode | on | Whether VE should use strict check for end-of-line in CSV-mode, it means that no end-of-line is allowed in quote. |
vecengine_block_row_num | 32768 | Set block row number for vector engine. |
vecengine_parallel_degree | 1 | Set parallel degree for vector engine. |
vecengine_write_degree | 0 | Set write degree for vector engine. |
version | 21.0.3.460 | Shows the SeaboxSQL version. |
wait_for_replication_threshold | 200MB | Maximum amount of WAL written by a transaction prior to waiting for replication. |
wal_block_size | 8192 | Shows the block size in the write ahead log. |
wal_buffers | 1MB | Sets the number of disk-page buffers in shared memory for WAL. |
wal_compression | off | Compresses full-page writes written in WAL file. |
wal_consistency_checking | Sets the WAL resource managers for which WAL consistency checks are done. | |
wal_init_zero | on | Writes zeroes to new WAL files before first use. |
wal_keep_segments | 5 | Sets the number of WAL files held for standby servers. |
wal_level | replica | Set the level of information written to the WAL. |
wal_log_hints | off | Writes full pages to WAL when first modified after a checkpoint, even for a non-critical modifications. |
wal_receiver_status_interval | 10s | Sets the maximum interval between WAL receiver status reports to the sending server. |
wal_receiver_timeout | 1min | Sets the maximum wait time to receive data from the sending server. |
wal_recycle | on | Recycles WAL files by renaming them. |
wal_retrieve_retry_interval | 5s | Sets the time to wait before retrying to retrieve WAL after a failed attempt. |
wal_segment_size | 16MB | Shows the size of write ahead log segments. |
wal_sender_timeout | 1min | Sets the maximum time to wait for WAL replication. |
wal_sync_method | fdatasync | Selects the method used for forcing WAL updates to disk. |
wal_writer_delay | 200ms | Time between WAL flushes performed in the WAL writer. |
wal_writer_flush_after | 1MB | Amount of WAL written out by WAL writer that triggers a flush. |
work_mem | 32MB | Sets the maximum memory to be used for query workspaces. |
writable_external_table_bufsize | 64kB | Buffer size in kilobytes for writable external table before writing data to scfs. |
xmlbinary | base64 | Sets how binary values are to be encoded in XML. |
xmloption | content | Sets whether XML data in implicit parsing and serialization operations is to be considered as documents or content fragments. |
zero_damaged_pages | off | Continues processing past damaged page headers. |