All YB-TServer flags

List of all YB-TServer process flags for configuring YugabyteDB using yb-tserver

Use the yb-tserver binary and its flags to configure the YB-TServer server. The yb-tserver executable file is located in the bin directory of YugabyteDB home. For more detailed information about flags commonly used for production deployments and instructions on using yb-tserver, refer to the yb-tserver documentation.

For a list of all YB-Master flags, see All YB-Master flags.

2.21.1.0

NAME ATTRIBUTES
abort_active_txns_during_xrepl_bootstrap DEFAULT: true
TAGS: advanced,runtime
DESCRIPTION: Abort active transactions during xcluster and cdc bootstrapping. Inconsistent replicated data may be produced if this is disabled.
aborted_intent_cleanup_max_batch_size DEFAULT: 256
TAGS: N/A
DESCRIPTION: Number of transactions to collect for possible cleanup.
aborted_intent_cleanup_ms DEFAULT: 60000
TAGS: runtime
DESCRIPTION: Duration in ms after which to check if a transaction is aborted.
aggressive_compaction_for_read_amp DEFAULT: false
TAGS: N/A
DESCRIPTION: Determines if we should compact aggressively to reduce read amplification based on number of files alone, without regards to relative sizes of the SSTable files.
allow_encryption_at_rest DEFAULT: true
TAGS: N/A
DESCRIPTION: Whether or not to allow encryption at rest to be enabled. Toggling this flag does not turn on or off encryption at rest, but rather allows or disallows a user from enabling it on in the future.
allow_insecure_connections DEFAULT: true
TAGS: N/A
DESCRIPTION: Whether we should allow insecure connections.
allow_preempting_compactions DEFAULT: true
TAGS: N/A
DESCRIPTION: Whether a compaction may be preempted in favor of another compaction with higher priority
allow_sensitive_data_in_logs DEFAULT: false
TAGS: runtime
DESCRIPTION: Allows potentially-sensitive debug data to be written unencrypted into logs.
allowed_preview_flags_csv DEFAULT:
TAGS: N/A
DESCRIPTION: CSV formatted list of Preview flag names. Flags that are tagged Preview cannot be modified unless they have been added to this list. By adding flags to this list, you acknowledge any risks associated with modifying them.
apply_changes_max_send_rate_mbps DEFAULT: 100
TAGS: runtime
DESCRIPTION: Server-wide max apply rate for xcluster traffic.
apply_intents_task_injected_delay_ms DEFAULT: 0
TAGS: N/A
DESCRIPTION: Inject such delay before applying intents for large transactions. Could be used to throttle the apply speed.
async_replication_idle_delay_ms DEFAULT: 100
TAGS: runtime
DESCRIPTION: How long to delay between polling when we expect no data at the destination.
async_replication_max_idle_wait DEFAULT: 3
TAGS: runtime
DESCRIPTION: Maximum number of consecutive empty GetChanges until the poller backs off to the idle interval, rather than immediately retrying.
async_replication_polling_delay_ms DEFAULT: 0
TAGS: runtime
DESCRIPTION: How long to delay in ms between applying and polling.
auto_compact_check_interval_sec DEFAULT: 60
TAGS: N/A
DESCRIPTION: The interval at which the full compaction task checks for tablets eligible for compaction, in seconds. 0 indicates that the background task is fully disabled.
auto_compact_memory_cleanup_interval_sec DEFAULT: 3600
TAGS: runtime
DESCRIPTION: The frequency with which we should check whether cleanup is needed in the full compaction manager. -1 indicates we should disable clean up.
auto_compact_min_obsolete_keys_found DEFAULT: 10000
TAGS: runtime
DESCRIPTION: Minimum number of keys read in the window for an automatic full compaction to be triggered.
auto_compact_min_wait_between_seconds DEFAULT: 0
TAGS: runtime
DESCRIPTION: Minimum wait time between automatic full compactions. Also applies to scheduled full compactions.
auto_compact_percent_obsolete DEFAULT: 99
TAGS: runtime
DESCRIPTION: Percentage of obsolete keys (over total keys) read over a window of time that trigger an automatic full compaction on a tablet. Only keys that are past their history retention (and thus can be garbage collected) are considered.
auto_compact_stat_window_seconds DEFAULT: 300
TAGS: runtime
DESCRIPTION: Window of time (seconds) over which DocDB read statistics are analyzed for the purposes of triggering full compactions automatically to improve read performance. Will always be rounded up to be a multiple of auto_compact_check_interval_sec.
auto_flags_apply_delay_ms DEFAULT: 10000
TAGS: advanced,stable,runtime
DESCRIPTION: Number of milliseconds after which a new AutoFlag config is applied. yb-tservers that have not heartbeated to yb-master within this duration cannot replicate data to XCluster targets. The value must be at least twice the heartbeat_interval_ms.
auto_flags_load_from_master_backoff_increment_ms DEFAULT: 100
TAGS: advanced,stable
DESCRIPTION: Number of milliseconds added to the delay between reties of fetching AutoFlags config from master leader. This delay is applied after the RPC reties have been exhausted.
auto_flags_load_from_master_max_backoff_sec DEFAULT: 3
TAGS: advanced,stable
DESCRIPTION: Maximum number of seconds to delay between reties of fetching AutoFlags config from master leader. This delay is applied after the RPC reties have been exhausted.
auto_promote_nonlocal_transactions_to_global DEFAULT: true
TAGS: runtime
DESCRIPTION: Automatically promote transactions touching data outside of region to global.
automatic_compaction_extra_priority DEFAULT: 50
TAGS: N/A
DESCRIPTION: Assigns automatic compactions extra priority when automatic tablet splits are enabled. This deprioritizes manual compactions including those induced by the tserver (e.g. post-split compactions). Suggested value between 0 and 50.
avoid_abort_after_sealing_ms DEFAULT: 20
TAGS: N/A
DESCRIPTION: If transaction was only sealed, we will try to abort it not earlier than this period in milliseconds.
backfill_index_client_rpc_timeout_ms DEFAULT: 86400000
TAGS: advanced
DESCRIPTION: Timeout for BackfillIndex RPCs from client to master.
backfill_index_rate_rows_per_sec DEFAULT: 0
TAGS: advanced,runtime
DESCRIPTION: Rate of at which the indexed table's entries are populated into the index table during index backfill. This is a per-tablet flag, i.e. a tserver responsible for multiple tablets could be processing more than this.
backfill_index_timeout_grace_margin_ms DEFAULT: -1
TAGS: advanced,runtime
DESCRIPTION: The time we give the backfill process to wrap up the current set of writes and return successfully the RPC with the information about how far we have processed the rows.
backfill_index_write_batch_size DEFAULT: 128
TAGS: advanced,runtime
DESCRIPTION: The batch size for backfilling the index.
backpressure_recovery_period_ms DEFAULT: 600000
TAGS: advanced,runtime
DESCRIPTION: Once we hit a backpressure/service-overflow we will consider dropping stale requests for this duration (in ms)
batch_tablet_metrics_update DEFAULT: true
TAGS: runtime
DESCRIPTION: Batch update of rocksdb and tablet metrics to once per request rather than updating immediately.
bg_superblock_flush_interval_secs DEFAULT: 60
TAGS: runtime
DESCRIPTION: The interval at which tablet superblocks are flushed to disk (if dirty) by a background thread. Applicable only when lazily_flush_superblock is enabled. 0 indicates that the background task is fully disabled.
binary_call_parser_reject_on_mem_tracker_hard_limit DEFAULT: true
TAGS: N/A
DESCRIPTION: Whether to reject/ignore calls on hitting mem tracker hard limit.
block_restart_interval DEFAULT: 16
TAGS: N/A
DESCRIPTION: Controls the number of keys to look at for computing the diff encoding.
bytes_durable_wal_write_mb DEFAULT: 1
TAGS: stable
DESCRIPTION: Amount of data in MB after which the Log/WAL should explicitly call fsync(). If 0 fsysnc() is not called.
bytes_remote_bootstrap_durable_write_mb DEFAULT: 1024
TAGS: N/A
DESCRIPTION: Explicitly call fsync after downloading the specified amount of data in MB during a remote bootstrap session. If 0 fsync() is not called.
cache_overflow_single_touch DEFAULT: true
TAGS: N/A
DESCRIPTION: Whether to enable overflow of single touch cache into the multi touch cache allocation
cache_single_touch_ratio DEFAULT: 0.20000000000000001
TAGS: N/A
DESCRIPTION: Fraction of the cache dedicated to single-touch items
callhome_collection_level DEFAULT: medium
TAGS: N/A
DESCRIPTION: Level of details sent by callhome
callhome_enabled DEFAULT: true
TAGS: runtime
DESCRIPTION: Enables callhome feature that sends analytics data to yugabyte
callhome_interval_secs DEFAULT: 3600
TAGS: runtime
DESCRIPTION: How often to run callhome
callhome_tag DEFAULT:
TAGS: N/A
DESCRIPTION: Tag to be inserted in the json sent to FLAGS_callhome_url. This tag is used by itest to specify that the data generated by callhome should be discarded by the receiver.
callhome_url DEFAULT: http://diagnostics.yugabyte.com
TAGS: N/A
DESCRIPTION: URL of callhome server
callsite_profile_stack_trace_threshold_usec DEFAULT: 0
TAGS: runtime
DESCRIPTION: Threshold, in microseconds, for printing stack traces for profiled call sites that take longer than this amount of time. Regardless of this setting, stack traces at any given call site will not be printed more than once a second. Set to 0 to disable stack traces.
cdc_checkpoint_opid_interval_ms DEFAULT: 60000
TAGS: N/A
DESCRIPTION: Interval up to which CDC consumer's checkpoint is considered for retaining log cache.If we haven't received an updated checkpoint from CDC consumer within the interval specified by cdc_checkpoint_opid_interval, then log cache does not consider that consumer while determining which op IDs to evict.
cdc_consumer_handler_thread_pool_size DEFAULT: 0
TAGS: advanced
DESCRIPTION: Override the max thread pool size for XClusterConsumerHandler, which is used by XClusterPoller. If set to 0, then the thread pool will use the default size (number of cpus on the system).
cdc_consumer_use_proxy_forwarding DEFAULT: false
TAGS: runtime
DESCRIPTION: When enabled, read requests from the XClusterConsumer that go to the wrong node are forwarded to the correct node by the Producer.
cdc_enable_consistent_records DEFAULT: true
TAGS: N/A
DESCRIPTION: If 'true' we will ensure that the records are order by the commit_time.
cdc_enable_replicate_intents DEFAULT: false
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
cdc_force_remote_tserver DEFAULT: false
TAGS: runtime
DESCRIPTION: Avoid local tserver apply optimization for xCluster and force remote RPCs.
cdc_get_changes_free_rpc_ratio DEFAULT: 0.10000000000000001
TAGS: N/A
DESCRIPTION: When the TServer only has this percentage of RPCs remaining because the rest are GetChanges, reject additional requests to throttle/backoff and prevent deadlocks.
cdc_immediate_transaction_cleanup DEFAULT: false
TAGS: runtime
DESCRIPTION: Clean up transactions from memory after apply, even if its changes have not yet been streamed by CDC.
cdc_intent_retention_ms DEFAULT: 14400000
TAGS: advanced,runtime
DESCRIPTION: Interval up to which CDC consumer's checkpoint is considered for retaining intents.If we haven't received an updated checkpoint from CDC consumer within the interval specified by cdc_checkpoint_opid_interval, then CDC does not consider that consumer while determining which op IDs to delete from the intent.
cdc_max_apply_batch_num_records DEFAULT: 0
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
cdc_max_apply_batch_size_bytes DEFAULT: 0
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
cdc_max_stream_intent_records DEFAULT: 1680
TAGS: N/A
DESCRIPTION: Max number of intent records allowed in single cdc batch.
cdc_min_replicated_index_considered_stale_secs DEFAULT: 900
TAGS: N/A
DESCRIPTION: If cdc_min_replicated_index hasn't been replicated in this amount of time, we reset itsvalue to max int64 to avoid retaining any logs
cdc_populate_end_markers_transactions DEFAULT: true
TAGS: runtime
DESCRIPTION: If 'true', we will also send 'BEGIN' and 'COMMIT' records for both single shard and multi shard transactions
cdc_populate_safepoint_record DEFAULT: true
TAGS: runtime
DESCRIPTION: If 'true' we will also send a 'SAFEPOINT' record at the end of each GetChanges call.
cdc_read_rpc_timeout_ms DEFAULT: 30000
TAGS: advanced
DESCRIPTION: Timeout used for CDC read rpc calls. Reads normally occur cross-cluster.
cdc_read_safe_deadline_ratio DEFAULT: 0.10000000000000001
TAGS: runtime
DESCRIPTION: When the heartbeat deadline has this percentage of time remaining, the master should halt tablet report processing so it can respond in time.
cdc_resolve_intent_lag_threshold_ms DEFAULT: 300000
TAGS: N/A
DESCRIPTION: The lag threshold in milli seconds between the hybrid time returned by GetMinStartTimeAmongAllRunningTransactions and LeaderSafeTime, when we decide the ConsistentStreamSafeTime for CDCSDK by resolving all committed intetns
cdc_snapshot_batch_size DEFAULT: 250
TAGS: runtime
DESCRIPTION: Batch size for the snapshot operation in CDC
cdc_state_checkpoint_update_interval_ms DEFAULT: 15000
TAGS: runtime
DESCRIPTION: Rate at which CDC state's checkpoint is updated.
cdc_state_table_num_tablets DEFAULT: 0
TAGS: runtime
DESCRIPTION: Number of tablets to use when creating the CDC state table. 0 to use the same default num tablets as for regular tables.
cdc_stream_records_threshold_size_bytes DEFAULT: 4194304
TAGS: runtime
DESCRIPTION: The threshold for the size of the response of a GetChanges call. The actual size may be a little higher than this value.
cdc_transaction_timeout_ms DEFAULT: 0
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
cdc_write_post_apply_metadata DEFAULT: false
TAGS: runtime
DESCRIPTION: Write post-apply transaction metadata to intentsdb for transaction that have been applied but have not yet been streamed by CDC.
cdc_write_rpc_timeout_ms DEFAULT: 30000
TAGS: advanced
DESCRIPTION: Timeout used for CDC write rpc calls. Writes normally occur intra-cluster.
cdc_ybclient_reactor_threads DEFAULT: 0
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
cdcsdk_max_consistent_records DEFAULT: 500
TAGS: runtime
DESCRIPTION: Controls the maximum number of records sent in GetConsistentChanges response
cdcsdk_publication_list_refresh_interval_secs DEFAULT: 3600
TAGS: runtime
DESCRIPTION: Interval in seconds at which the table list in the publication will be refreshed
cdcsdk_retention_barrier_no_revision_interval_secs DEFAULT: 120
TAGS: runtime
DESCRIPTION: Duration for which CDCSDK retention barriers cannot be revised from the cdcsdk_block_barrier_revision_start_time
cdcsdk_tablet_not_of_interest_timeout_secs DEFAULT: 14400
TAGS: runtime
DESCRIPTION: Timeout after which it can be inferred that tablet is not of interest for the stream
cert_file_pattern DEFAULT: node.$0.crt
TAGS: N/A
DESCRIPTION: Pattern used for certificate file
cert_node_filename DEFAULT:
TAGS: N/A
DESCRIPTION: The file name that will be used in the names of the node certificates and keys. These files will be named : 'node.{cert_node_filename}.{key|crt}'. If this flag is not set, then --server_broadcast_addresses will be used if it is set, and if not, --rpc_bind_addresses will be used.
certs_dir DEFAULT:
TAGS: N/A
DESCRIPTION: Directory that contains certificate authority, private key and certificates for this server. By default 'certs' subdir in data folder is used.
certs_for_cdc_dir DEFAULT:
TAGS: N/A
DESCRIPTION: The parent directory of where all certificates for xCluster producer universes will be stored, for when the producer and consumer clusters use different certificates. Place the certificates for each producer cluster in <certs_for_cdc_dir>/<producer_cluster_id>/*.
certs_for_client_dir DEFAULT:
TAGS: N/A
DESCRIPTION: Directory that contains certificate authority, private key and certificates for this server that should be used for client to server communications. When empty, the same dir as for server to server communications is used.
change_metadata_backoff_init_exponent DEFAULT: 1
TAGS: runtime
DESCRIPTION: Initial exponent of 2 in the exponential backoff loop that checks if a change metadata operation is finished. Only used for colocated table creation for now.
change_metadata_backoff_max_jitter_ms DEFAULT: 0
TAGS: runtime
DESCRIPTION: Max jitter (in ms) in the exponential backoff loop that checks if a change metadata operation is finished. Only used for colocated table creation for now.
check_pg_object_id_allocators_interval_secs DEFAULT: 10800
TAGS: advanced,runtime
DESCRIPTION: Interval at which pg object id allocators are checked for dropped databases.
cipher_list DEFAULT:
TAGS: N/A
DESCRIPTION: Define the list of available ciphers (TLSv1.2 and below).
ciphersuites DEFAULT:
TAGS: N/A
DESCRIPTION: Define the available TLSv1.3 ciphersuites.
cleanup_intents_sst_files DEFAULT: true
TAGS: N/A
DESCRIPTION: Cleanup intents files that are no more relevant to any running transaction.
cleanup_metrics_interval_sec DEFAULT: 60
TAGS: N/A
DESCRIPTION: The tick interval time for the metrics cleanup background task. If set to 0, it disables the background task.
cleanup_split_tablets_interval_sec DEFAULT: 60
TAGS: N/A
DESCRIPTION: Interval at which tablet manager tries to cleanup split tablets which are no longer needed. Setting this to 0 disables cleanup of split tablets.
client_read_write_timeout_ms DEFAULT: 60000
TAGS: N/A
DESCRIPTION: Timeout for client read and write operations.
clock_skew_force_crash_bound_usec DEFAULT: 60000000
TAGS: N/A
DESCRIPTION: If the clock skew larger than this amount (microseconds) is observed, we will force a crash regardless of the value of fail_on_out_of_range_clock_skew. This is useful for avoiding really large hybrid clock jumps. Set to 0 to disable the check. Note that this check is only preformed for clock skew greater than max_clock_skew_usec.
collect_end_to_end_traces DEFAULT: false
TAGS: advanced,runtime
DESCRIPTION: If true, collected traces includes information for sub-components potentially running on a different server.
collect_update_consensus_traces DEFAULT: false
TAGS: advanced,runtime
DESCRIPTION: If true, collected traces from followers for UpdateConsensus running on a different server.
colorlogtostderr DEFAULT: false
TAGS: runtime,stable
DESCRIPTION: color messages logged to stderr (if supported by terminal)
compaction_priority_start_bound DEFAULT: 10
TAGS: N/A
DESCRIPTION: Compaction task of DB that has number of SST files less than specified will have priority 0.
compaction_priority_step_size DEFAULT: 5
TAGS: N/A
DESCRIPTION: Compaction task of DB that has number of SST files greater that compaction_priority_start_bound will get 1 extra priority per every compaction_priority_step_size files.
compression_type DEFAULT: Snappy
TAGS: N/A
DESCRIPTION: On-disk compression type to use in RocksDB.By default, Snappy is used if supported.
consensus_force_recover_from_stuck_peer_call DEFAULT: false
TAGS: advanced,runtime
DESCRIPTION: Set this flag to true in addition to consensus_stuck_peer_call_threshold_ms to automatically recover from stuck RPC call.
consensus_lagging_follower_threshold DEFAULT: 10
TAGS: advanced,runtime
DESCRIPTION: Number of retransmissions at tablet leader to mark a follower as lagging. -1 disables the feature.
consensus_log_scoped_watch_delay_append_threshold_ms DEFAULT: 1000
TAGS: advanced,runtime
DESCRIPTION: If consensus log append takes longer than this, the kernel watchdog will print out a stack trace.
consensus_log_scoped_watch_delay_callback_threshold_ms DEFAULT: 1000
TAGS: advanced,runtime
DESCRIPTION: If calling consensus log callback(s) take longer than this, the kernel watchdog will print out a stack trace.
consensus_max_batch_size_bytes DEFAULT: 4194304
TAGS: advanced,runtime
DESCRIPTION: The maximum per-tablet RPC batch size when updating peers. The sum of consensus_max_batch_size_bytes and 1KB should be less than rpc_max_message_size
consensus_rpc_timeout_ms DEFAULT: 3000
TAGS: advanced
DESCRIPTION: Timeout used for all consensus internal RPC communications.
consensus_stuck_peer_call_threshold_ms DEFAULT: 10000
TAGS: advanced,runtime
DESCRIPTION: Time to wait after timeout before considering an RPC call as stuck.
consistent_restore DEFAULT: true
TAGS: N/A
DESCRIPTION: Whether to enable consistent restoration of snapshots
cql_allow_static_column_index DEFAULT: false
TAGS: N/A
DESCRIPTION: Raise unsupported error when creating an index on static columns
cql_always_return_metadata_in_execute_response DEFAULT: false
TAGS: N/A
DESCRIPTION: Force returning the table metadata in the EXECUTE request response
cql_check_table_schema_in_paging_state DEFAULT: true
TAGS: N/A
DESCRIPTION: Return error for prepared SELECT statement execution if the table was altered during the prepared statement execution.
cql_dump_statement_metrics_limit DEFAULT: 5000
TAGS: runtime
DESCRIPTION: Limit the number of statements that are dumped at the /statements endpoint.
cql_limit_nodelist_refresh_to_subscribed_conns DEFAULT: true
TAGS: advanced,runtime
DESCRIPTION: When enabled, the node list refresh events will only be sent to the connections which have subscribed to receiving the topology change events.
cql_nodelist_refresh_interval_secs DEFAULT: 300
TAGS: advanced,runtime
DESCRIPTION: Interval after which a node list refresh event should be sent to all CQL clients.
cql_prepare_child_threshold_ms DEFAULT: 2000
TAGS: N/A
DESCRIPTION: Timeout if preparing for child transaction takes longerthan the prescribed threshold.
cql_processors_limit DEFAULT: -4000
TAGS: N/A
DESCRIPTION: Limit number of CQL processors. Positive means absolute limit. Negative means number of processors per 1GB of root mem tracker memory limit. 0 - unlimited.
cql_proxy_bind_address DEFAULT:
TAGS: N/A
DESCRIPTION: Address to bind the CQL proxy to
cql_proxy_broadcast_rpc_address DEFAULT:
TAGS: N/A
DESCRIPTION: RPC address to broadcast to other nodes. This is the broadcast_address used in the system.local table
cql_proxy_webserver_port DEFAULT: 12000
TAGS: N/A
DESCRIPTION: Webserver port for CQL proxy
cql_raise_index_where_clause_error DEFAULT: false
TAGS: N/A
DESCRIPTION: Raise unsupported error if where clause is specified for create index
cql_rpc_keepalive_time_ms DEFAULT: 120000
TAGS: advanced
DESCRIPTION: If an RPC connection from a client is idle for this amount of time, the server will disconnect the client. Setting flag to 0 disables this clean up.
cql_rpc_memory_limit DEFAULT: 0
TAGS: N/A
DESCRIPTION: CQL RPC memory limit
cql_server_always_send_events DEFAULT: false
TAGS: N/A
DESCRIPTION: All CQL connections automatically subscribed for all CQL events.
cql_service_max_prepared_statement_size_bytes DEFAULT: 134217728
TAGS: N/A
DESCRIPTION: The maximum amount of memory the CQL proxy should use to maintain prepared statements. 0 or negative means unlimited.
cql_service_queue_length DEFAULT: 10000
TAGS: advanced
DESCRIPTION: RPC queue length for CQL service
cql_system_query_cache_empty_responses DEFAULT: true
TAGS: N/A
DESCRIPTION: Whether to cache empty responses from the master.
cql_system_query_cache_stale_msecs DEFAULT: 60000
TAGS: N/A
DESCRIPTION: Maximum permitted staleness for the system query cache. <= 0 permits infinite staleness.
cql_system_query_cache_tables DEFAULT:
TAGS: N/A
DESCRIPTION: Tables to cache connection data for. Entries are semicolon-delimited, in the format <keyspace>.<table>.
cql_table_is_transactional_by_default DEFAULT: false
TAGS: advanced
DESCRIPTION: When the 'transactions' property is not specified at CREATE TABLE time for a YCQL table, this flag determines the default setting for whether the table is transactional or not.
cql_unprepared_stmts_entries_limit DEFAULT: 500
TAGS: runtime
DESCRIPTION: Limit the number of unprepared statements that are being tracked.
cql_update_system_query_cache_msecs DEFAULT: 0
TAGS: N/A
DESCRIPTION: How often the system query cache should be updated. <= 0 disables caching.
cql_use_metadata_cache_for_schema_version_check DEFAULT: true
TAGS: advanced,runtime
DESCRIPTION: Use the internal Table Metadata Cache in TS to check the Table Schema Version when processing the YCQL PREPARE query.If disabled - the Table Schema Version is requested from the Master.
cql_ybclient_reactor_threads DEFAULT: 24
TAGS: N/A
DESCRIPTION: The number of reactor threads to be used for processing ybclient requests originating in the cql layer
db_block_cache_num_shard_bits DEFAULT: -1
TAGS: advanced,runtime
DESCRIPTION: -1 indicates a dynamic scheme that evaluates to 4 if number of cores is less than or equal to 16, 5 for 17-32 cores, 6 for 33-64 cores and so on. If the value is overridden, that value would be used in favor of the dynamic scheme. The maximum permissible value is 19.
db_block_cache_size_bytes DEFAULT: -1
TAGS: N/A
DESCRIPTION: Size of the shared RocksDB block cache (in bytes). A value of -1 specifies to instead use a percentage of this daemon's hard memory limit; see --db_block_cache_size_percentage for the percentage used. A value of -2 disables the block cache.
db_block_cache_size_percentage DEFAULT: -1000
TAGS: N/A
DESCRIPTION: Percentage of our hard memory limit to use for the shared RocksDB block cache, if --db_block_cache_size_bytes is -1. The special value -1000 means to instead use a recommended percentage determined in part by the amount of RAM available. The special value -3 means to use a older default that does not take the amount of RAM into account. The percentage used due to the special values may depend on whether this is a TServer or master daemon.
db_block_size_bytes DEFAULT: 32768
TAGS: N/A
DESCRIPTION: Size of RocksDB data block (in bytes).
db_filter_block_size_bytes DEFAULT: 65536
TAGS: N/A
DESCRIPTION: Size of RocksDB filter block (in bytes).
db_index_block_size_bytes DEFAULT: 32768
TAGS: N/A
DESCRIPTION: Size of RocksDB index block (in bytes).
db_min_keys_per_index_block DEFAULT: 100
TAGS: N/A
DESCRIPTION: Minimum number of keys per index block.
db_write_buffer_size DEFAULT: -1
TAGS: N/A
DESCRIPTION: Size of RocksDB write buffer (in bytes). -1 to use default.
ddl_verification_timeout_multiplier DEFAULT: 5
TAGS: runtime
DESCRIPTION: Multiplier for the timeout used for DDL verification. DDL verification may involve waiting for DDL operations to finish at the yb-master. This is a multiplier for default_admin_operation_timeout which is the timeout used for a single DDL operation
default_memory_limit_to_ram_ratio DEFAULT: -1000
TAGS: N/A
DESCRIPTION: The percentage of available RAM to use if --memory_limit_hard_bytes is 0. The special value -1000 means to instead use a recommended percentage determined in part by the amount of RAM available.
delete_intents_sst_files DEFAULT: true
TAGS: N/A
DESCRIPTION: Delete whole intents .SST files when possible.
detect_duplicates_for_retryable_requests DEFAULT: true
TAGS: N/A
DESCRIPTION: Enable tracking of write requests that prevents the same write from being applied twice.
disable_alter_vs_write_mutual_exclusion DEFAULT: false
TAGS: advanced,runtime
DESCRIPTION: A safety switch to disable the changes from D8710 which makes a schema operation take an exclusive lock making all write operations wait for it.
disable_auto_flags_management DEFAULT: false
TAGS: unsafe,advanced
DESCRIPTION: Disables AutoFlags management. A safety switch to turn off automatic promotion of AutoFlags. More information about AutoFlags can be found in https://github.com/yugabyte/yugabyte-db/blob/master/architecture/design/auto_flags.md. Use at your own risk!
disable_clock_sync_error DEFAULT: true
TAGS: advanced
DESCRIPTION: Whether or not we should keep running if we detect a clock synchronization issue.
disable_heartbeat_send_involved_tablets DEFAULT: false
TAGS: runtime
DESCRIPTION: If disabled, do not send involved tablets on heartbeats for pending transactions. This behavior is needed to support fetching old transactions and their involved tablets in order to support yb_lock_status/pg_locks.
disable_hybrid_scan DEFAULT: false
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
display_bind_params_in_cql_details DEFAULT: true
TAGS: N/A
DESCRIPTION: Whether to show bind params for CQL calls details in the RPCZ dump.
dns_cache_expiration_ms DEFAULT: 60000
TAGS: N/A
DESCRIPTION: Time to store DNS resolution results in cache.
docdb_ht_filter_conflict_with_committed DEFAULT: true
TAGS: runtime
DESCRIPTION: Use hybrid time SST filter when checking for conflicts with committed transactions.
drop_log_memory DEFAULT: true
TAGS: runtime,advanced
DESCRIPTION: Drop in-memory buffers of log contents. Logs can grow very quickly and they are rarely read before they need to be evicted from memory. Instead, drop them from memory as soon as they are flushed to disk.
dump_certificate_entries DEFAULT: false
TAGS: N/A
DESCRIPTION: Whether we should dump certificate entries.
dump_dbimpl_info DEFAULT: false
TAGS: N/A
DESCRIPTION: Dump RocksDB info during constructor.
dump_flags_xml DEFAULT: false
TAGS: advanced,stable
DESCRIPTION: Dump a XLM document describing all of gFlags used in this binary. Differs from helpxml by displaying the current runtime value as the default instead of the hard coded values from the flag definitions.
dump_lock_keys DEFAULT: true
TAGS: N/A
DESCRIPTION: Whether to add keys to error message when lock batch timed out
dump_metrics_to_trace DEFAULT: false
TAGS: runtime
DESCRIPTION: Whether to dump changed metrics in tracing.
dump_transactions DEFAULT: false
TAGS: runtime
DESCRIPTION: Dump transactions data in debug binary format.
dump_transactions_chunk_size DEFAULT: 10737418240
TAGS: runtime
DESCRIPTION: Start new transaction dump when current one reaches specified limit.
dump_transactions_gzip DEFAULT: 1
TAGS: runtime
DESCRIPTION: Whether transaction dump should be compressed in GZip format.
durable_wal_write DEFAULT: false
TAGS: stable
DESCRIPTION: Whether the Log/WAL should explicitly call fsync() after each write.
emulate_redis_responses DEFAULT: true
TAGS: N/A
DESCRIPTION: If emulate_redis_responses is false, we hope to get slightly better performance by just returning OK for commands that might require us to read additional records viz. SADD, HSET, and HDEL. If emulate_redis_responses is true, we read the required records to compute the response as specified by the official Redis API documentation. https://redis.io/commands
enable_automatic_tablet_splitting DEFAULT: true
TAGS: stable,auto,runtime
DESCRIPTION: If false, disables automatic tablet splitting driven from the yb-master side.
enable_block_based_table_cache_gc DEFAULT: false
TAGS: runtime
DESCRIPTION: Set to true to enable block based table garbage collector.
enable_callsite_profile DEFAULT: false
TAGS: runtime
DESCRIPTION: Enable counting and timing of function calls enclosed in the YB_PROFILE macro. The results are shown in the /pprof/callsite_profile web UI page.
enable_callsite_profile_timing DEFAULT: false
TAGS: runtime
DESCRIPTION: In addition to CPU cycle counts, also measure the actual time in microseconds in profiled call sites.
enable_cdc_client_tablet_caching DEFAULT: false
TAGS: runtime
DESCRIPTION: Enable caching the tablets found by client.
enable_cdc_state_table_caching DEFAULT: true
TAGS: runtime
DESCRIPTION: Enable caching the cdc_state table schema.
enable_cdcsdk_lag_collection DEFAULT: false
TAGS: runtime
DESCRIPTION: When enabled, vlog containing the lag for the getchanges call as well as last commit record in response will be printed.
enable_check_retryable_request_timeout DEFAULT: true
TAGS: N/A
DESCRIPTION: Whether to check if retryable request exceeds the timeout.
enable_collect_cdc_metrics DEFAULT: true
TAGS: runtime
DESCRIPTION: Enable collecting cdc and xcluster metrics.
enable_consensus_exponential_backoff DEFAULT: true
TAGS: advanced,runtime
DESCRIPTION: Whether exponential backoff based on number of retransmissions at tablet leader for number of entries to replicate to lagging follower is enabled.
enable_copy_retryable_requests_from_parent DEFAULT: true
TAGS: runtime
DESCRIPTION: Whether to copy retryable requests from parent tablet when openingthe child tablet
enable_data_block_fsync DEFAULT: true
TAGS: unsafe
DESCRIPTION: Whether to enable fsync() of data blocks, metadata, and their parent directories. Disabling this flag may cause data loss in the event of a system crash.
enable_deadlock_detection DEFAULT: false
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
enable_direct_local_tablet_server_call DEFAULT: true
TAGS: advanced
DESCRIPTION: Enable direct call to local tablet server
enable_flush_retryable_requests DEFAULT: true
TAGS: stable,auto,runtime
DESCRIPTION: If enabled, will flush retryable requests structure to the disk when roll the log segment, which helps speedup bootstrap process
enable_history_cutoff_propagation DEFAULT: false
TAGS: N/A
DESCRIPTION: Should we use history cutoff propagation (true) or calculate it locally (false).
enable_intentsdb_page DEFAULT: false
TAGS: N/A
DESCRIPTION: Enable displaying the contents of intentsdb page.
enable_leader_failure_detection DEFAULT: true
TAGS: unsafe
DESCRIPTION: Whether to enable failure detection of tablet leaders. If enabled, attempts will be made to elect a follower as a new leader when the leader is detected to have failed.
enable_lease_revocation DEFAULT: true
TAGS: N/A
DESCRIPTION: Enables lease revocation mechanism
enable_log_cache_gc DEFAULT: true
TAGS: N/A
DESCRIPTION: Set to true to enable log cache garbage collector.
enable_log_retention_by_op_idx DEFAULT: true
TAGS: runtime
DESCRIPTION: If true, logs will be retained based on an op id passed by the cdc service
enable_maintenance_manager DEFAULT: true
TAGS: unsafe
DESCRIPTION: Enable the maintenance manager, runs compaction and tablet cleaning tasks.
enable_multi_raft_heartbeat_batcher DEFAULT: false
TAGS: N/A
DESCRIPTION: If true, enables multi-Raft batching of raft heartbeats.
enable_ondisk_compression DEFAULT: true
TAGS: N/A
DESCRIPTION: Determines whether SSTable compression is enabled or not.
enable_pg_savepoints DEFAULT: false
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
enable_process_lifetime_heap_profiling DEFAULT: false
TAGS: advanced,stable
DESCRIPTION: WARNING: This flag will cause tcmalloc to sample every allocation. This can significantly impact performance. For a lighter approach, use sampling (profiler_sample_freq_bytes). This option is only supported with gperftools tcmalloc. Enables heap profiling for the lifetime of the process. Profile output will be stored in the directory specified by -heap_profile_path, and enabling this option will disable the on-demand profiling in /pprof/heap.
enable_process_lifetime_heap_sampling DEFAULT: false
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
enable_redis_auth DEFAULT: true
TAGS: N/A
DESCRIPTION: Enable AUTH for the Redis service
enable_restart_transaction_status_tablets_first DEFAULT: true
TAGS: N/A
DESCRIPTION: Set to true to prioritize bootstrapping transaction status tablets first.
enable_rpc_keepalive DEFAULT: true
TAGS: N/A
DESCRIPTION: Whether to enable RPC keepalive mechanism
enable_schema_packing_gc DEFAULT: true
TAGS: N/A
DESCRIPTION: Whether schema packing GC is enabled.
enable_single_record_update DEFAULT: true
TAGS: runtime
DESCRIPTION: Enable packing updates corresponding to a row in single CDC record
enable_stream_compression DEFAULT: true
TAGS: N/A
DESCRIPTION: Whether it is allowed to use stream compression.
enable_tablet_orphaned_block_deletion DEFAULT: false
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
enable_tracing DEFAULT: false
TAGS: advanced,runtime
DESCRIPTION: Flag to enable/disable tracing across the code.
enable_transaction_sealing DEFAULT: false
TAGS: N/A
DESCRIPTION: Whether transaction sealing is enabled.
enable_uncovered_index_select DEFAULT: true
TAGS: advanced
DESCRIPTION: Enable executing select statements using uncovered index
enable_update_local_peer_min_index DEFAULT: true
TAGS: runtime
DESCRIPTION: Enable each local peer to update its own log checkpoint instead of the leader updating all peers.
enable_wait_queues DEFAULT: true
TAGS: advanced
DESCRIPTION: If true, enable wait queues that help provide Wait-on-Conflict behavior during conflict resolution whenever required. Enabling this flag enables deadlock detection as well.
enable_xcluster_auto_flag_validation DEFAULT: true
TAGS: stable,auto,runtime
DESCRIPTION: Enables validation of AutoFlags between the xcluster universes
enable_xcluster_stat_collection DEFAULT: true
TAGS: runtime
DESCRIPTION: When enabled, stats are collected from xcluster streams for reporting purposes.
enable_ysql DEFAULT: true
TAGS: N/A
DESCRIPTION: Enable YSQL on the cluster. This will cause yb-master to initialize sys catalog tablet from an initial snapshot (in case --initial_sys_catalog_snapshot_path is specified or can be auto-detected). Also each tablet server will start a PostgreSQL server as a child process.
enable_ysql_conn_mgr DEFAULT: false
TAGS: preview
DESCRIPTION: Enable Ysql Connection Manager for the cluster. Tablet Server will start a Ysql Connection Manager process as a child process. NOTE: This flag protects a feature that is currently in preview. In order for it to be modified, 'enable_ysql_conn_mgr' must be set in --allowed_preview_flags_csv.
enable_ysql_conn_mgr_stats DEFAULT: true
TAGS: N/A
DESCRIPTION: Enable stats collection from Ysql Connection Manager. These stats will be displayed at the endpoint '<ip_address_of_cluster>:13000/connections'
entries_per_index_block DEFAULT: 10000
TAGS: advanced
DESCRIPTION: Number of entries per index block stored in WAL segment file
estimated_replicate_msg_size_percentage DEFAULT: 0.94999999999999996
TAGS: N/A
DESCRIPTION: The estimated percentage of replicate message size in a log entry batch.
evict_failed_followers DEFAULT: true
TAGS: advanced
DESCRIPTION: Whether to evict followers from the Raft config that have fallen too far behind the leader's log to catch up normally or have been unreachable by the leader for longer than follower_unavailable_considered_failed_sec
export_help_and_type_in_prometheus_metrics DEFAULT: true
TAGS: runtime
DESCRIPTION: Include #TYPE and #HELP in Prometheus metrics output by default
export_intentdb_metrics DEFAULT: true
TAGS: N/A
DESCRIPTION: Dump intentsdb statistics to prometheus metrics
expose_metric_histogram_percentiles DEFAULT: true
TAGS: N/A
DESCRIPTION: Should we expose the percentiles information for metrics histograms.
external_intent_cleanup_secs DEFAULT: 86400
TAGS: N/A
DESCRIPTION: Duration in secs after which to cleanup external intents.
fail_on_out_of_range_clock_skew DEFAULT: true
TAGS: N/A
DESCRIPTION: In case transactional tables are present, crash the process if clock skew greater than the configured maximum.
fatal_details_path_prefix DEFAULT:
TAGS: N/A
DESCRIPTION: A prefix to use for the path of a file to save fatal failure stack trace and other details to.
fault_crash_after_rocksdb_flush DEFAULT: 0
TAGS: N/A
DESCRIPTION: Fraction of time to crash right after a successful RocksDB flush in tests.
file_expiration_ignore_value_ttl DEFAULT: false
TAGS: unsafe,runtime
DESCRIPTION: When deciding whether a file has expired, assume that it is safe to ignore value-level TTL and expire based on table TTL only. CAUTION - Shoule only be used for expiration of older SST files without value-level TTL metadata, or for expiring files with incorrect value-level expiration. Misuse can result in the deletion of live data!
file_expiration_value_ttl_overrides_table_ttl DEFAULT: false
TAGS: unsafe,runtime
DESCRIPTION: When deciding whether a file has expired, assume that any file with value-level TTL metadata can be expired solely on that metadata. Useful for the expiration of files earlier than the table-level TTL that is set. CAUTION - Should only be used in workloads where the user is certain all data is written with a value-level TTL. Misuse can result in the deletion of live data!
flagfile DEFAULT:
TAGS: stable
DESCRIPTION: load flags from file
flush_retryable_requests_pool_max_threads DEFAULT: -1
TAGS: N/A
DESCRIPTION: The maximum number of threads used to flush retryable requests
flush_rocksdb_on_shutdown DEFAULT: true
TAGS: N/A
DESCRIPTION: Safely flush RocksDB when instance is destroyed, disabled for crash tests.
follower_unavailable_considered_failed_sec DEFAULT: 900
TAGS: advanced
DESCRIPTION: Seconds that a leader is unable to successfully heartbeat to a follower after which the follower is considered to be failed and evicted from the config.
force_global_transactions DEFAULT: false
TAGS: runtime
DESCRIPTION: Force all transactions to be global transactions
force_lookup_cache_refresh_secs DEFAULT: 0
TAGS: N/A
DESCRIPTION: When non-zero, specifies how often we send a GetTabletLocations request to the master leader to update the tablet replicas cache. This request is only sent if we are processing a ConsistentPrefix read.
force_single_shard_waiter_retry_ms DEFAULT: 30000
TAGS: N/A
DESCRIPTION: The amount of time to wait before sending the client of a single shard transaction a retryable error. Such clients are periodically sent a retryable error to ensure we don't maintain waiters in the wait queue for unresponsive or disconnected clients. This is not required for multi-tablet transactions which have a transaction ID and are rolled back if the transaction coordinator does not receive a heartbeat, since for these we will eventually discover that the transaction has been rolled back and remove the waiter. If set to zero, this will default to 30s.
forward_redis_requests DEFAULT: true
TAGS: N/A
DESCRIPTION: If false, the redis op will not be served if it's not a local request. The op response will be set to the redis error '-MOVED partition_key 0.0.0.0:0'. This works with jedis which only looks at the MOVED part of the reply and ignores the rest. For now, if this flag is true, we will only attempt to read from leaders, so redis_allow_reads_from_followers will be ignored.
fromenv DEFAULT:
TAGS: advanced,stable
DESCRIPTION: set flags from the environment [use 'export FLAGS_flag1=value']
fs_data_dirs DEFAULT:
TAGS: stable
DESCRIPTION: Comma-separated list of data directories. This argument must be specified.
fs_wal_dirs DEFAULT:
TAGS: stable
DESCRIPTION: Comma-separated list of directories for write-ahead logs. This is an optional argument. If this is not specified, fs_data_dirs is used for write-ahead logs also and that's a reasonable default for most use cases.
full_compaction_pool_max_queue_size DEFAULT: 500
TAGS: N/A
DESCRIPTION: The maximum number of tasks that can be held in the pool for full_compaction_pool_. This pool is used to run full compactions on tablets on a scheduled basis or after they have been split and still contain irrelevant data from the tablet they were sourced from.
full_compaction_pool_max_threads DEFAULT: 1
TAGS: N/A
DESCRIPTION: The maximum number of threads allowed for full_compaction_pool_. This pool is used to run full compactions on tablets, either on a shceduled basis or after they have been split and still contain irrelevant data from the tablet they were sourced from.
generic_svc_num_threads DEFAULT: 10
TAGS: advanced
DESCRIPTION: Number of RPC worker threads to run for the generic service
generic_svc_queue_length DEFAULT: 50
TAGS: advanced
DESCRIPTION: RPC Queue length for the generic service
get_changes_honor_deadline DEFAULT: true
TAGS: N/A
DESCRIPTION: Toggle whether to honor the deadline passed to log reader
get_locks_status_max_retry_attempts DEFAULT: 2
TAGS: runtime
DESCRIPTION: Maximum number of retries that will be performed for GetLockStatus requests that fail in the validation phase due to unseen responses from some of the involved tablets.
get_universe_key_registry_backoff_increment_ms DEFAULT: 100
TAGS: advanced,stable
DESCRIPTION: Number of milliseconds added to the delay between retries of fetching the full universe key registry from master leader. This delay is applied after the RPC reties have been exhausted.
get_universe_key_registry_max_backoff_sec DEFAULT: 3
TAGS: advanced,stable
DESCRIPTION: Maximum number of seconds to delay between retries of fetching the full universe key registry from master leader. This delay is applied after the RPC reties have been exhausted.
global_log_cache_size_limit_mb DEFAULT: 1024
TAGS: advanced
DESCRIPTION: Server-wide version of 'log_cache_size_limit_mb'. The total memory used for caching log entries across all tablets is kept under this threshold.
global_log_cache_size_limit_percentage DEFAULT: 5
TAGS: advanced
DESCRIPTION: The maximum percentage of root process memory that can be used for caching log entries across all tablets. Default is 5.
global_memstore_size_mb_max DEFAULT: 2048
TAGS: N/A
DESCRIPTION: Global memstore size is determined as a percentage of the available memory. However, this flag limits it in absolute size. Value of 0 means no limit on the value obtained by the percentage. Default is 2048.
global_memstore_size_percentage DEFAULT: 10
TAGS: N/A
DESCRIPTION: Percentage of total available memory to use for the global memstore. Default is 10. See also memstore_size_mb and global_memstore_size_mb_max.
gzip_stream_compression_level DEFAULT: 1
TAGS: runtime
DESCRIPTION: Compression level used by gzip stream compression. 0 - no compression, 1 - best speed, 9 - best compression.
heap_profile_path DEFAULT:
TAGS: advanced,stable
DESCRIPTION: Output path to store heap profiles. If not set, profiles are stored in the directory specified by the tmp_dir flag as $FLAGS_tmp_dir/<process-name>.<pid>.<n>.heap.
heartbeat_interval_ms DEFAULT: 1000
TAGS: advanced,runtime
DESCRIPTION: Interval at which the TS heartbeats to the master.
heartbeat_max_failures_before_backoff DEFAULT: 3
TAGS: advanced
DESCRIPTION: Maximum number of consecutive heartbeat failures until the Tablet Server backs off to the normal heartbeat interval, rather than retrying.
heartbeat_rpc_timeout_ms DEFAULT: 15000
TAGS: advanced,runtime
DESCRIPTION: Timeout used for the TS->Master heartbeat RPCs.
help DEFAULT: false
TAGS: stable
DESCRIPTION: show help on all flags [tip: all flags can have two dashes]
help_auto_flag_json DEFAULT: false
TAGS: advanced,stable
DESCRIPTION: Dump a JSON document describing all of the AutoFlags available in this binary.
helpmatch DEFAULT:
TAGS: advanced,stable
DESCRIPTION: show help on modules whose name contains the specified substr
helpon DEFAULT:
TAGS: advanced,stable
DESCRIPTION: show help on the modules named by this flag value
helppackage DEFAULT: false
TAGS: advanced,stable
DESCRIPTION: show help on all modules in the main package
helpshort DEFAULT: false
TAGS: advanced,stable
DESCRIPTION: show help on only the main module for this program
helpxml DEFAULT: false
TAGS: advanced,stable
DESCRIPTION: produce an xml version of help
history_cutoff_propagation_interval_ms DEFAULT: 180000
TAGS: N/A
DESCRIPTION: History cutoff propagation interval in milliseconds.
ht_lease_duration_ms DEFAULT: 2000
TAGS: N/A
DESCRIPTION: Hybrid time leader lease duration. A leader keeps establishing a new lease or extending the existing one with every UpdateConsensus. A new server is not allowed to add entries to RAFT log until a lease of the old leader is expired. 0 to disable.
inbound_rpc_memory_limit DEFAULT: 0
TAGS: N/A
DESCRIPTION: Inbound RPC memory limit
index_backfill_additional_delay_before_backfilling_ms DEFAULT: 0
TAGS: evolving,runtime
DESCRIPTION: Operations that are received by the tserver, and have decided how the indexes need to be updated (based on the IndexPermission), will not be added to the list of current transactions until they are replicated/applied. This delay allows for the GetSafeTime method to wait for such operations to be replicated/applied. Ideally, this value should be set to be something larger than the raft-heartbeat-interval but can be as high as the client_rpc_timeout if we want to be more conservative.
index_backfill_upperbound_for_user_enforced_txn_duration_ms DEFAULT: 65000
TAGS: evolving,runtime
DESCRIPTION: For Non-Txn tables, it is impossible to know at the tservers whether or not an 'old transaction' is still active. To avoid having such old transactions, we assume a bound on the duration of such transactions (during the backfill process) and wait it out. This flag denotes a conservative upper bound on the duration of such user enforced transactions.
index_backfill_wait_for_old_txns_ms DEFAULT: 0
TAGS: evolving,runtime
DESCRIPTION: Index backfill needs to wait for transactions that started before the WRITE_AND_DELETE phase to commit or abort before choosing a time for backfilling the index. This is the max time that the GetSafeTime call will wait for, before it resorts to attempt aborting old transactions. This is necessary to guard against the pathological active transaction that never commits from blocking the index backfill forever.
index_block_restart_interval DEFAULT: 1
TAGS: N/A
DESCRIPTION: Controls the number of data blocks to be indexed inside an index block.
initial_log_segment_size_bytes DEFAULT: 1048576
TAGS: N/A
DESCRIPTION: The maximum segment size we want for a new WAL segment, in bytes. This value keeps doubling (for each subsequent WAL segment) till it gets to the maximum configured segment size (log_segment_size_bytes or log_segment_size_mb).
initial_seqno DEFAULT: 1125899906842624
TAGS: N/A
DESCRIPTION: Initial seqno for new RocksDB instances.
instance_uuid_override DEFAULT:
TAGS: N/A
DESCRIPTION: When creating local instance metadata (for master or tserver) in an empty data directory, use this UUID instead of randomly-generated one. Can be used to replace a node that had its disk wiped in some scenarios.
intents_compaction_filter_max_errors_to_log DEFAULT: 100
TAGS: N/A
DESCRIPTION: Maximum number of errors to log for life cycle of the intents compcation filter.
intents_flush_max_delay_ms DEFAULT: 2000
TAGS: N/A
DESCRIPTION: Max time to wait for regular db to flush during flush of intents. After this time flush of regular db will be forced.
interval_durable_wal_write_ms DEFAULT: 1000
TAGS: stable
DESCRIPTION: Interval in ms after which the Log/WAL should explicitly call fsync(). If 0 fsysnc() is not called.
io_thread_pool_size DEFAULT: 4
TAGS: N/A
DESCRIPTION: Size of allocated IO Thread Pool.
key_file_pattern DEFAULT: node.$0.key
TAGS: N/A
DESCRIPTION: Pattern used for key file
lazily_flush_superblock DEFAULT: true
TAGS: N/A
DESCRIPTION: Flushes the superblock lazily on metadata update. Only used for colocated table creation currently.
leader_failure_exp_backoff_max_delta_ms DEFAULT: 20000
TAGS: experimental
DESCRIPTION: Maximum time to sleep in between leader election retries, in addition to the regular timeout. When leader election fails the interval in between retries increases exponentially, up to this value.
leader_failure_max_missed_heartbeat_periods DEFAULT: 6
TAGS: advanced
DESCRIPTION: Maximum heartbeat periods that the leader can fail to heartbeat in before we consider the leader to be failed. The total failure timeout in milliseconds is raft_heartbeat_interval_ms times leader_failure_max_missed_heartbeat_periods. The value passed to this flag may be fractional.
leader_lease_duration_ms DEFAULT: 2000
TAGS: N/A
DESCRIPTION: Leader lease duration. A leader keeps establishing a new lease or extending the existing one with every UpdateConsensus. A new server is not allowed to serve as a leader (i.e. serve up-to-date read requests or acknowledge write requests) until a lease of this duration has definitely expired on the old leader's side.
linear_backoff_ms DEFAULT: 1
TAGS: N/A
DESCRIPTION: Number of milliseconds added to delay while using linear backoff strategy.
local_ip_for_outbound_sockets DEFAULT:
TAGS: experimental
DESCRIPTION: IP to bind to when making outgoing socket connections. This must be an IP address of the form A.B.C.D, not a hostname. Advanced parameter, subject to change.
log_async_preallocate_segments DEFAULT: true
TAGS: advanced
DESCRIPTION: Whether the WAL segments preallocation should happen asynchronously
log_background_sync_data_fraction DEFAULT: 0.5
TAGS: N/A
DESCRIPTION: When log_enable_background_sync is enabled and periodic_sync_unsynced_bytes_ reaches bytes_durable_wal_write_mb_*log_background_sync_data_fraction, the fsync task is pushed to the log-sync queue.
log_background_sync_interval_fraction DEFAULT: 0.59999999999999998
TAGS: N/A
DESCRIPTION: When log_enable_background_sync is enabled and time passed since insertion of log entry exceeds interval_durable_wal_write_ms*log_background_sync_interval_fraction the fsync task is pushed to the log-sync queue.
log_backtrace_at DEFAULT:
TAGS: advanced
DESCRIPTION: Emit a backtrace when logging at file:linenum.
log_cache_gc_evict_only_over_allocated DEFAULT: true
TAGS: N/A
DESCRIPTION: If set to true, log cache garbage collection would evict only memory that was allocated over limit for log cache. Otherwise it will try to evict requested number of bytes.
log_cache_size_limit_mb DEFAULT: 128
TAGS: advanced
DESCRIPTION: The total per-tablet size of consensus entries which may be kept in memory. The log cache attempts to keep all entries which have not yet been replicated to all followers in memory, but if the total size of those entries exceeds this limit within an individual tablet, the oldest will be evicted.
log_dir DEFAULT:
TAGS: stable
DESCRIPTION: If specified, logfiles are written into this directory instead of the default logging directory.
log_enable_background_sync DEFAULT: true
TAGS: N/A
DESCRIPTION: If true, log fsync operations in the aggresively performed in the background.
log_failed_txn_metadata DEFAULT: false
TAGS: advanced,runtime
DESCRIPTION: Log metadata about failed transactions.
log_filename DEFAULT:
TAGS: stable
DESCRIPTION: Prefix of log filename - full path is <log_dir>/<log_filename>.[INFO|WARN|ERROR|FATAL]
log_inject_append_latency_ms_max DEFAULT: 0
TAGS: N/A
DESCRIPTION: The maximum latency to inject before the log append operation.
log_inject_latency DEFAULT: false
TAGS: unsafe
DESCRIPTION: If true, injects artificial latency in log sync operations. Advanced option. Use at your own risk -- has a negative effect on performance for obvious reasons!
log_inject_latency_ms_mean DEFAULT: 100
TAGS: unsafe
DESCRIPTION: The number of milliseconds of latency to inject, on average. Only takes effect if --log_inject_latency is true
log_inject_latency_ms_stddev DEFAULT: 100
TAGS: unsafe
DESCRIPTION: The standard deviation of latency to inject in before log sync operations. Only takes effect if --log_inject_latency is true
log_link DEFAULT:
TAGS: advanced,stable
DESCRIPTION: Put additional links to the log files in this directory
log_max_seconds_to_retain DEFAULT: 86400
TAGS: N/A
DESCRIPTION: Log files that are older will be deleted even if they contain cdc unreplicated entries. If 0, this flag will be ignored. This flag is ignored if a log segment contains entries that haven't beenflushed to RocksDB.
log_min_seconds_to_retain DEFAULT: 900
TAGS: advanced,runtime
DESCRIPTION: The minimum number of seconds for which to keep log segments to keep at all times, regardless of what is required for durability. Logs may be still retained for a longer amount of time if they are necessary for correct restart. This should be set long enough such that a tablet server which has temporarily failed can be restarted within the given time period. If a server is down for longer than this amount of time, it is possible that its tablets will be re-replicated on other machines.
log_min_segments_to_retain DEFAULT: 2
TAGS: advanced,runtime
DESCRIPTION: The minimum number of past log segments to keep at all times, regardless of what is required for durability. Must be at least 1.
log_preallocate_segments DEFAULT: true
TAGS: advanced
DESCRIPTION: Whether the WAL should preallocate the entire segment before writing to it
log_prefix DEFAULT: true
TAGS: runtime,advanced,stable
DESCRIPTION: Prepend the log prefix to the start of each log line
log_prefix_include_pid DEFAULT: false
TAGS: N/A
DESCRIPTION: Include PID into the log prefix
log_segment_size_bytes DEFAULT: 0
TAGS: N/A
DESCRIPTION: The default segment size for log roll-overs, in bytes. If 0 then log_segment_size_mb is used.
log_segment_size_mb DEFAULT: 64
TAGS: advanced
DESCRIPTION: The default segment size for log roll-overs, in MB
log_stop_retaining_min_disk_mb DEFAULT: 102400
TAGS: N/A
DESCRIPTION: Stop retaining logs if the space available for the logs falls below this limit. This flag is ignored if a log segment contains unflushed entries.
log_version_edits DEFAULT: false
TAGS: runtime
DESCRIPTION: Log RocksDB version edits as they are being written
logbuflevel DEFAULT: 1
TAGS: runtime,advanced
DESCRIPTION: Buffer log messages logged at this level or lower (-1 means don't buffer; 0 means buffer INFO only; ...)
logbufsecs DEFAULT: 30
TAGS: runtime,advanced
DESCRIPTION: Buffer log messages for at most this many seconds
logfile_mode DEFAULT: 436
TAGS: N/A
DESCRIPTION: Log file mode/permissions.
logtostderr DEFAULT: false
TAGS: runtime,stable
DESCRIPTION: log messages go to stderr instead of logfiles
lookup_cache_refresh_secs DEFAULT: 60
TAGS: N/A
DESCRIPTION: When non-zero, specifies how often we send a GetTabletLocations request to the master leader to update the tablet replicas cache. This request is only sent if we are processing a ConsistentPrefix read and the RPC layer has determined that its view of the replicas is inconsistent with what the master has reported
maintenance_manager_num_threads DEFAULT: 1
TAGS: stable
DESCRIPTION: Size of the maintenance manager thread pool. Beyond a value of '1', one thread is reserved for emergency flushes. For spinning disks, the number of threads should not be above the number of devices.
max_clock_skew_usec DEFAULT: 500000
TAGS: N/A
DESCRIPTION: Transaction read clock skew in usec. This is the maximum allowed time delta between servers of a single cluster.
max_clock_sync_error_usec DEFAULT: 10000000
TAGS: advanced,runtime
DESCRIPTION: Maximum allowed clock synchronization error as reported by NTP before the server will abort.
max_concurrent_master_lookups DEFAULT: 500
TAGS: N/A
DESCRIPTION: Maximum number of concurrent tablet location lookups from YB client to master
max_group_replicate_batch_size DEFAULT: 16
TAGS: N/A
DESCRIPTION: Maximum number of operations to submit to consensus for replication in a batch.
max_log_size DEFAULT: 1800
TAGS: runtime,stable
DESCRIPTION: approx. maximum log file size (in MB). A value of 0 will be silently overridden to 1.
max_message_length DEFAULT: 266338304
TAGS: N/A
DESCRIPTION: The maximum message length of the cql message.
max_next_calls_while_skipping_future_records DEFAULT: 3
TAGS: runtime
DESCRIPTION: After number of next calls is reached this limit, use seek to find non future record.
max_nexts_to_avoid_seek DEFAULT: 2
TAGS: runtime
DESCRIPTION: The number of next calls to try before doing resorting to do a rocksdb seek.
max_num_tablets_for_table DEFAULT: 5000
TAGS: N/A
DESCRIPTION: Max number of tablets that can be specified in a CREATE TABLE statement
max_prometheus_metric_entries DEFAULT: 4294967295
TAGS: runtime
DESCRIPTION: The maximum number of Prometheus metric entries returned in each scrape. Note that if adding a metric with all its entities would exceed the limit, then we will drop them all.Thus, the actual number of metric entries returned might be smaller than the limit.
max_rejection_delay_ms DEFAULT: 5000
TAGS: runtime
DESCRIPTION: Maximal delay for rejected write to be retried in milliseconds.
max_remote_bootstrap_attempts_from_non_leader DEFAULT: 5
TAGS: runtime
DESCRIPTION: When FLAGS_remote_bootstrap_from_leader_only is enabled, the flag represents the maximum number of times we attempt to remote bootstrap a new peer from a closest non-leader peer that result in a failure. We fallback to bootstrapping from the leader peer post this.
max_stale_read_bound_time_ms DEFAULT: 60000
TAGS: evolving,runtime
DESCRIPTION: If we are allowed to read from followers, specify the maximum time a follower can be behind by using the last message received from the leader. If set to zero, a read can be served by a follower regardless of when was the last time it received a message from the leader or how far behind this follower is.
max_tables_metrics_breakdowns DEFAULT: 0
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
max_time_in_queue_ms DEFAULT: 6000
TAGS: advanced,runtime
DESCRIPTION: Fail calls that get stuck in the queue longer than the specified amount of time (in ms)
max_transactions_in_status_request DEFAULT: 128
TAGS: N/A
DESCRIPTION: Request status for at most specified number of transactions at once. 0 disables load time transaction status resolution.
max_wait_for_aborting_transactions_during_restore_ms DEFAULT: 200
TAGS: advanced,runtime
DESCRIPTION: How much time in milliseconds to wait for tablet transactions to abort while applying the raft restore operation to a tablet.
max_wait_for_processresponse_before_closing_ms DEFAULT: 5000
TAGS: advanced
DESCRIPTION: Maximum amount of time we will wait in Peer::Close() for Peer::ProcessResponse() to finish before returning proceding to close the Peer and return
max_wait_for_safe_time_ms DEFAULT: 5000
TAGS: N/A
DESCRIPTION: Maximum time in milliseconds to wait for the safe time to advance when trying to scan at the given hybrid_time.
mem_tracker_include_pageheap_free_in_root_consumption DEFAULT: false
TAGS: advanced,runtime
DESCRIPTION: Whether to include tcmalloc.pageheap_free_bytes from the consumption of the root memtracker. tcmalloc.pageheap_free_bytes tracks memory mapped by tcmalloc but not currently used. If we do include this in consumption, it is possible that we reject requests due to soft memory limits being hit when we actually have available memory in the pageheap. So we exclude it by default.
mem_tracker_log_stack_trace DEFAULT: false
TAGS: N/A
DESCRIPTION: Enable logging of stack traces on memory tracker consume/release operations. Only takes effect if mem_tracker_logging is also enabled.
mem_tracker_logging DEFAULT: false
TAGS: N/A
DESCRIPTION: Enable logging of memory tracker consume/release operations
mem_tracker_tcmalloc_gc_release_bytes DEFAULT: -1
TAGS: runtime
DESCRIPTION: When the total amount of memory from calls to Release() since the last GC exceeds this flag, a new tcmalloc GC will be triggered. This GC will clear the tcmalloc page heap freelist. A higher value implies less aggressive GC, i.e. higher memory overhead, but more efficient in terms of runtime.
mem_tracker_update_consumption_interval_us DEFAULT: 2000000
TAGS: N/A
DESCRIPTION: Interval that is used to update memory consumption from external source. For instance from tcmalloc statistics.
memory_limit_hard_bytes DEFAULT: 0
TAGS: stable
DESCRIPTION: Maximum amount of memory this daemon should use in bytes. A value of 0 specifies to instead use a percentage of the total system memory; see --default_memory_limit_to_ram_ratio for the percentage used. A value of -1 disables all memory limiting.
memory_limit_soft_percentage DEFAULT: 85
TAGS: advanced
DESCRIPTION: Percentage of the hard memory limit that this daemon may consume before memory throttling of writes begins. The greater the excess, the higher the chance of throttling. In general, a lower soft limit leads to smoother write latencies but decreased throughput, and vice versa for a higher soft limit.
memory_limit_termination_threshold_pct DEFAULT: 200
TAGS: N/A
DESCRIPTION: If the RSS (resident set size) of the program reaches this percentage of the root memory tracker limit, the program will exit. RSS is measured using operating system means, not the memory allocator. Set to 0 to disable this behavior.
memory_limit_warn_threshold_percentage DEFAULT: 98
TAGS: advanced,runtime
DESCRIPTION: Percentage of the hard memory limit that this daemon may consume before WARNING level messages are periodically logged.
memstore_arena_size_kb DEFAULT: 64
TAGS: N/A
DESCRIPTION: Size of each arena allocation for the memstore
memstore_size_mb DEFAULT: 128
TAGS: N/A
DESCRIPTION: Max size (in mb) of the memstore, before needing to flush.
meta_cache_lookup_throttling_max_delay_ms DEFAULT: 1000
TAGS: N/A
DESCRIPTION: Max delay between calls during lookup throttling.
meta_cache_lookup_throttling_step_ms DEFAULT: 5
TAGS: N/A
DESCRIPTION: Step to increment delay between calls during lookup throttling.
metric_node_name DEFAULT: alma8-gcp-jenkins-builder-y9so5c:9000
TAGS: N/A
DESCRIPTION: Value to use as node name for metrics reporting
metrics_log_interval_ms DEFAULT: 0
TAGS: advanced
DESCRIPTION: Interval (in milliseconds) at which the server will dump its metrics to a local log file. The log files are located in the same directory as specified by the -log_dir flag. If this is not a positive value, then metrics logging will be disabled.
metrics_retirement_age_ms DEFAULT: 120000
TAGS: advanced,runtime
DESCRIPTION: The minimum number of milliseconds a metric will be kept for after it is no longer active. (Advanced option)
metrics_snapshotter_interval_ms DEFAULT: 30000
TAGS: advanced
DESCRIPTION: Interval at which the metrics are snapshotted.
metrics_snapshotter_table_metrics_whitelist DEFAULT: rocksdb_sst_read_micros_sum,rocksdb_sst_read_micros_count
TAGS: advanced
DESCRIPTION: Table metrics to record in native metrics storage.
metrics_snapshotter_tserver_metrics_whitelist DEFAULT: handler_latency_yb_client_read_local_sum,handler_latency_yb_client_read_local_count
TAGS: advanced
DESCRIPTION: Tserver metrics to record in native metrics storage.
metrics_snapshotter_ttl_ms DEFAULT: 604800000
TAGS: advanced
DESCRIPTION: Ttl for snapshotted metrics.
min_leader_stepdown_retry_interval_ms DEFAULT: 20000
TAGS: N/A
DESCRIPTION: Minimum amount of time between successive attempts to perform the leader stepdown for the same combination of tablet and intended (target) leader. This is needed to avoid infinite leader stepdown loops when the current leader never has a chance to update the intended leader with its latest records.
min_rejection_delay_ms DEFAULT: 100
TAGS: runtime
DESCRIPTION: Minimal delay for rejected write to be retried in milliseconds.
min_segment_size_bytes_to_rollover_at_flush DEFAULT: 0
TAGS: runtime
DESCRIPTION: Only rotate wals at least of this size (in bytes) at tablet flush.-1 to disable WAL rollover at flush. 0 to always rollover WAL at flush.
min_sidecar_buffer_size DEFAULT: 16384
TAGS: N/A
DESCRIPTION: Minimal buffer to allocate for sidecar
minicluster_daemon_id DEFAULT:
TAGS: N/A
DESCRIPTION: A human-readable 'daemon id', e.g. 'm-1' or 'ts-2', used in tests.
minloglevel DEFAULT: 0
TAGS: runtime,advanced,stable
DESCRIPTION: Messages logged at a lower level than this don't actually get logged anywhere
multi_raft_batch_size DEFAULT: 0
TAGS: advanced
DESCRIPTION: Maximum batch size for a multi-Raft consensus payload. Ignored if set to zero.
multi_raft_heartbeat_interval_ms DEFAULT: 50
TAGS: advanced
DESCRIPTION: The heartbeat interval for batch Raft replication.
net_address_filter DEFAULT: ipv4_external,ipv4_all,ipv6_external,ipv6_non_link_local,ipv6_all
TAGS: N/A
DESCRIPTION: Order in which to select ip addresses returned by the resolverCan be set to something like "ipv4_all,ipv6_all" to prefer IPv4 over IPv6 addresses.Can be set to something like "ipv4_external,ipv4_all,ipv6_all" to prefer external IPv4 addresses first. Other options include ipv6_external,ipv6_non_link_local
never_fsync DEFAULT: false
TAGS: unsafe,advanced
DESCRIPTION: Never fsync() anything to disk. This is used by tests to speed up runtime and improve stability. This is very unsafe to use in production.
node_to_node_encryption_required_uid DEFAULT:
TAGS: N/A
DESCRIPTION: Allow only certificates with specified uid. Empty to allow any.
node_to_node_encryption_use_client_certificates DEFAULT: false
TAGS: N/A
DESCRIPTION: Should client certificates be sent and verified for encrypted node to node communication.
non_graph_characters_percentage_to_use_hexadecimal_rendering DEFAULT: 10
TAGS: N/A
DESCRIPTION: Non graph charaters percentage to use hexadecimal rendering
num_concurrent_backfills_allowed DEFAULT: -1
TAGS: runtime
DESCRIPTION: Maximum number of concurrent backfill jobs that is allowed to run.
num_connections_to_server DEFAULT: 8
TAGS: N/A
DESCRIPTION: Number of underlying connections to each server
num_cpus DEFAULT: 0
TAGS: N/A
DESCRIPTION: Number of CPU cores used in calculations
num_open_tablets_metadata_simultaneously DEFAULT: 0
TAGS: advanced
DESCRIPTION: Number of threads available to open tablets' metadata during startup. If this is set to 0 (the default), then the number of open metadata threads will be set based on the number of CPUs
num_raft_ops_to_force_idle_intents_db_to_flush DEFAULT: 1000
TAGS: N/A
DESCRIPTION: When writes to intents RocksDB are stopped and the number of Raft operations after the last write to the intents RocksDB is greater than this value, the intents RocksDB would be requested to flush.
num_reactor_threads DEFAULT: -1
TAGS: advanced
DESCRIPTION: Number of libev reactor threads to start. If -1, the value is automatically set.
num_reserved_small_compaction_threads DEFAULT: -1
TAGS: N/A
DESCRIPTION: Number of reserved small compaction threads. It allows splitting small vs. large compactions.
num_tablets_to_open_simultaneously DEFAULT: 0
TAGS: advanced
DESCRIPTION: Number of threads available to open tablets during startup. If this is set to 0 (the default), then the number of bootstrap threads will be set based on the number of data directories. If the data directories are on some very fast storage device such as SSD or a RAID array, it may make sense to manually tune this.
o_direct_block_alignment_bytes DEFAULT: 4096
TAGS: advanced
DESCRIPTION: Alignment (in bytes) for blocks used for O_DIRECT operations.
o_direct_block_size_bytes DEFAULT: 4096
TAGS: advanced
DESCRIPTION: Size of the block to use when flag durable_wal_write is set.
openssl_require_fips DEFAULT: false
TAGS: N/A
DESCRIPTION: Use OpenSSL FIPS Provider.
outbound_rpc_memory_limit DEFAULT: 0
TAGS: N/A
DESCRIPTION: Outbound RPC memory limit
parallelize_bootstrap_producer DEFAULT: false
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
parallelize_read_ops DEFAULT: true
TAGS: advanced,runtime
DESCRIPTION: Controls whether multiple (Redis) read ops that are present in a operation should be executed in parallel.
password_hash_cache_size DEFAULT: 64
TAGS: N/A
DESCRIPTION: Number of password hashes to cache. 0 or negative disables caching.
pg_cache_response_renew_soft_lifetime_limit_ms DEFAULT: 180000
TAGS: N/A
DESCRIPTION: Lifetime limit for response cache soft renewing process
pg_client_extra_timeout_ms DEFAULT: 2000
TAGS: N/A
DESCRIPTION: Adding this value to RPC call timeout, so postgres could detect timeout by it's own mechanism and report it.
pg_client_heartbeat_interval_ms DEFAULT: 10000
TAGS: N/A
DESCRIPTION: Pg client heartbeat interval in ms.
pg_client_session_expiration_ms DEFAULT: 60000
TAGS: N/A
DESCRIPTION: Pg client session expiration time in milliseconds.
pg_client_svc_queue_length DEFAULT: 5000
TAGS: advanced
DESCRIPTION: RPC queue length for the Pg Client service.
pg_client_use_shared_memory DEFAULT: false
TAGS: runtime
DESCRIPTION: Use shared memory for executing read and write pg client queries
pg_mem_tracker_tcmalloc_gc_release_bytes DEFAULT: 5242880
TAGS: N/A
DESCRIPTION: Overriding the gflag mem_tracker_tcmalloc_gc_release_bytes defined in mem_tracker.cc. The overriding value is specifically set for Postgres backends
pg_mem_tracker_update_consumption_interval_us DEFAULT: 50000
TAGS: N/A
DESCRIPTION: Interval that is used to update memory consumption from external source. For instance from tcmalloc statistics. This interval is for Postgres backends only
pg_proxy_bind_address DEFAULT:
TAGS: N/A
DESCRIPTION: Address for the PostgreSQL proxy to bind to
pg_response_cache_capacity DEFAULT: 1024
TAGS: N/A
DESCRIPTION: PgClientService response cache capacity.
pg_response_cache_num_key_group_bucket DEFAULT: 512
TAGS: N/A
DESCRIPTION: Number of buckets for key group values which are used as part of response cache key. Response cache can be disabled for particular key group, but actually it will be disabled for all key groups in same bucket
pg_response_cache_size_bytes DEFAULT: 0
TAGS: N/A
DESCRIPTION: Size in bytes of the PgClientService response cache. 0 value (default) means that cache size is not limited by this flag.
pg_response_cache_size_percentage DEFAULT: 5
TAGS: N/A
DESCRIPTION: Percentage of total available memory to use by the PgClientService response cache. Default value is 5, max is 100, min is 0 means that cache size is not limited by this flag.
pg_verbose_error_log DEFAULT: false
TAGS: N/A
DESCRIPTION: True to enable verbose logging of errors in PostgreSQL server
pg_yb_session_timeout_ms DEFAULT: 60000
TAGS: N/A
DESCRIPTION: Timeout for operations between PostgreSQL server and YugaByte DocDB services
pggate_master_addresses DEFAULT:
TAGS: N/A
DESCRIPTION: Addresses of the master servers to which the PostgreSQL proxy server connects.
pggate_num_connections_to_server DEFAULT: 1
TAGS: N/A
DESCRIPTION: Number of underlying connections to each server from a PostgreSQL backend process. This overrides the value of --num_connections_to_server.
pggate_rpc_timeout_secs DEFAULT: 60
TAGS: N/A
DESCRIPTION: Timeout for RPCs from pggate to YB cluster
pggate_tserver_shm_fd DEFAULT: -1
TAGS: N/A
DESCRIPTION: File descriptor of the local tablet server's shared memory.
pggate_ybclient_reactor_threads DEFAULT: 2
TAGS: N/A
DESCRIPTION: The number of reactor threads to be used for processing ybclient requests originating in the PostgreSQL proxy server
pgsql_consistent_transactional_paging DEFAULT: true
TAGS: N/A
DESCRIPTION: Whether to enforce consistency of data returned for second page and beyond for YSQL queries on transactional tables. If true, read restart errors could be returned to prevent inconsistency. If false, no read restart errors are returned but the data may be stale. The latter is preferable for long scans. The data returned for the first page of results is never stale regardless of this flag.
pgsql_proxy_bind_address DEFAULT:
TAGS: N/A
DESCRIPTION: Address to bind the PostgreSQL proxy to
pgsql_proxy_webserver_port DEFAULT: 13000
TAGS: N/A
DESCRIPTION: Webserver port for PGSQL
pgsql_rpc_keepalive_time_ms DEFAULT: 0
TAGS: advanced
DESCRIPTION: If an RPC connection from a client is idle for this amount of time, the server will disconnect the client. Setting flag to 0 disables this clean up.
placement_cloud DEFAULT: cloud1
TAGS: N/A
DESCRIPTION: The cloud in which this instance is started.
placement_region DEFAULT: datacenter1
TAGS: N/A
DESCRIPTION: The cloud region in which this instance is started.
placement_uuid DEFAULT:
TAGS: N/A
DESCRIPTION: The uuid of the tservers cluster/placement.
placement_zone DEFAULT: rack1
TAGS: N/A
DESCRIPTION: The cloud availability zone in which this instance is started.
post_split_compaction_input_size_threshold_bytes DEFAULT: 268435456
TAGS: runtime
DESCRIPTION: Max size of a files to be compacted within one iteration. Set to 0 to compact all files at once during post split compaction.
post_split_trigger_compaction_pool_max_queue_size DEFAULT: 16
TAGS: N/A
DESCRIPTION: DEPRECATED. Use full_compaction_pool_max_queue_size.
post_split_trigger_compaction_pool_max_threads DEFAULT: 1
TAGS: N/A
DESCRIPTION: DEPRECATED. Use full_compaction_pool_max_threads.
postmaster_cgroup DEFAULT:
TAGS: N/A
DESCRIPTION: cgroup to add postmaster process to
print_nesting_levels DEFAULT: 5
TAGS: advanced,runtime
DESCRIPTION: controls the depth of the child traces to be printed.
print_trace_every DEFAULT: 0
TAGS: advanced,runtime
DESCRIPTION: Controls the rate at which traces are printed. Setting this to 0 disables printing the collected traces.
prioritize_tasks_by_disk DEFAULT: false
TAGS: N/A
DESCRIPTION: Consider disk load when considering compaction and flush priorities.
priority_thread_pool_size DEFAULT: -1
TAGS: N/A
DESCRIPTION: Max running workers in compaction thread pool. If -1 and max_background_compactions is specified - use max_background_compactions. If -1 and max_background_compactions is not specified - use sqrt(num_cpus).
profiler_sample_freq_bytes DEFAULT: 1048576
TAGS: N/A
DESCRIPTION: The frequency at which TCMalloc should sample allocations. Sampling is disabled if this is set to <= 0.
propagate_safe_time DEFAULT: true
TAGS: N/A
DESCRIPTION: Propagate safe time to read from leader to followers
protege_synchronization_timeout_ms DEFAULT: 1000
TAGS: N/A
DESCRIPTION: Timeout to synchronize protege before performing step down. 0 to disable synchronization.
proxy_resolve_cache_ms DEFAULT: 5000
TAGS: N/A
DESCRIPTION: Time in milliseconds to cache resolution result in Proxy
raft_heartbeat_interval_ms DEFAULT: 500
TAGS: advanced
DESCRIPTION: The heartbeat interval for Raft replication. The leader produces heartbeats to followers at this interval. The followers expect a heartbeat at this interval and consider a leader to have failed if it misses several in a row.
rate_limiter_min_rate DEFAULT: 1000
TAGS: N/A
DESCRIPTION: Minimum transmission rate in bytes/sec
rate_limiter_min_size DEFAULT: 32768
TAGS: N/A
DESCRIPTION: Minimum size for each transmission request
rbs_init_max_number_of_retries DEFAULT: 5
TAGS: runtime
DESCRIPTION: Max number of retries during remote bootstrap session initialisation, when metadata before and after checkpoint does not match. 0 - to disable retry logic.
reactor_based_outbound_call_expiration_delay_ms DEFAULT: 1000
TAGS: advanced,runtime
DESCRIPTION: Expire OutboundCalls using Reactor-level logic with this delay after the timeout, as an additional layer of protection against stuck outbound calls. This safety mechanism is disabled if this flag is set to 0.
reactor_check_current_thread DEFAULT: true
TAGS: runtime
DESCRIPTION: Enforce the requirement that operations that require running on a reactor thread are always running on the correct reactor thread.
read_buffer_memory_limit DEFAULT: -5
TAGS: N/A
DESCRIPTION: Overall limit for read buffers. Positive value - limit in bytes. Negative value - percent of root process memory. Zero - unlimited.
read_pool_max_queue_size DEFAULT: 128
TAGS: N/A
DESCRIPTION: The maximum number of tasks that can be held in the queue for read_pool_. This pool is used to run multiple read operations, that are part of the same tablet rpc, in parallel.
read_pool_max_threads DEFAULT: 128
TAGS: N/A
DESCRIPTION: The maximum number of threads allowed for read_pool_. This pool is used to run multiple read operations, that are part of the same tablet rpc, in parallel.
redis_allow_reads_from_followers DEFAULT: false
TAGS: evolving,runtime
DESCRIPTION: If true, the read will be served from the closest replica in the same AZ, which can be a follower.
redis_callbacks_threadpool_size DEFAULT: 64
TAGS: N/A
DESCRIPTION: The maximum size for the threadpool which handles callbacks from the ybclient layer
redis_connection_soft_limit_grace_period_sec DEFAULT: 60
TAGS: N/A
DESCRIPTION: The duration for which the outbound data needs to exceeed the softlimit before the connection gets closed down.
redis_keys_threshold DEFAULT: 10000
TAGS: N/A
DESCRIPTION: Maximum number of keys allowed to be in the db before the KEYS operation errors out
redis_max_batch DEFAULT: 500
TAGS: N/A
DESCRIPTION: Max number of redis commands that forms batch
redis_max_command_size DEFAULT: 265289728
TAGS: N/A
DESCRIPTION: Maximum size of the command in redis
redis_max_concurrent_commands DEFAULT: 1
TAGS: N/A
DESCRIPTION: Max number of redis commands received from single connection, that could be processed concurrently
redis_max_queued_bytes DEFAULT: 134217728
TAGS: N/A
DESCRIPTION: Max number of bytes in queued redis commands.
redis_max_read_buffer_size DEFAULT: 134217728
TAGS: N/A
DESCRIPTION: Max read buffer size for Redis connections.
redis_max_value_size DEFAULT: 67108864
TAGS: N/A
DESCRIPTION: Maximum size of the value in redis
redis_password_caching_duration_ms DEFAULT: 5000
TAGS: N/A
DESCRIPTION: The duration for which we will cache the redis passwords. 0 to disable.
redis_passwords_separator DEFAULT: ,
TAGS: N/A
DESCRIPTION: The character used to separate multiple passwords.
redis_proxy_bind_address DEFAULT:
TAGS: N/A
DESCRIPTION: Address to bind the redis proxy to
redis_proxy_webserver_port DEFAULT: 11000
TAGS: N/A
DESCRIPTION: Webserver port for redis proxy
redis_rpc_block_size DEFAULT: 1048576
TAGS: N/A
DESCRIPTION: Redis RPC block size
redis_rpc_keepalive_time_ms DEFAULT: 0
TAGS: advanced
DESCRIPTION: If an RPC connection from a client is idle for this amount of time, the server will disconnect the client. Setting flag to 0 disables this clean up.
redis_rpc_memory_limit DEFAULT: 0
TAGS: N/A
DESCRIPTION: Redis RPC memory limit
redis_safe_batch DEFAULT: true
TAGS: N/A
DESCRIPTION: Use safe batching with Redis service
redis_service_yb_client_timeout_millis DEFAULT: 3000
TAGS: N/A
DESCRIPTION: Timeout in milliseconds for RPC calls from Redis service to master/tserver
redis_svc_queue_length DEFAULT: 5000
TAGS: advanced
DESCRIPTION: RPC queue length for redis service
ref_counted_debug_type_name_regex DEFAULT:
TAGS: N/A
DESCRIPTION: Regex for type names for debugging RefCounted / scoped_refptr based classes. An empty string disables RefCounted debug logging.
regular_tablets_data_block_key_value_encoding DEFAULT: three_shared_parts
TAGS: stable,auto
DESCRIPTION: Key-value encoding to use for regular data blocks in RocksDB. Possible options: shared_prefix, three_shared_parts
remote_boostrap_rate_limit_bytes_per_sec DEFAULT: 0
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
remote_bootstrap_change_role_timeout_ms DEFAULT: 15000
TAGS: N/A
DESCRIPTION: Timeout for change role operation during remote bootstrap.
remote_bootstrap_from_leader_only DEFAULT: false
TAGS: stable,auto,runtime
DESCRIPTION: Whether to instruct the peer to attempt bootstrap from the closest peer instead of the leader. The leader too could be the closest peer depending on the new peer's geographic placement. Setting the flag to false will enable remote bootstrap from the closest peer. On addition of a new node, it follows that most bootstrap sources would now be from a single node and could result in increased load on the node. If bootstrap of a new node is slow, it might be worth setting the flag to true and enable bootstrapping from leader only.
remote_bootstrap_max_chunk_size DEFAULT: 67108864
TAGS: N/A
DESCRIPTION: Maximum chunk size to be transferred at a time during remote bootstrap.
remote_bootstrap_rate_limit_bytes_per_sec DEFAULT: 268435456
TAGS: N/A
DESCRIPTION: Maximum transmission rate during a remote bootstrap. This is across all the remote bootstrap sessions for which this process is acting as a sender or receiver. So the total limit will be 2 * remote_bootstrap_rate_limit_bytes_per_sec because a tserver or master can act both as a sender and receiver at the same time.
replication_failure_delay_exponent DEFAULT: 16
TAGS: runtime
DESCRIPTION: Max number of failures (N) to use when calculating exponential backoff (2^N-1).
report_ysql_ddl_txn_status_to_master DEFAULT: true
TAGS: runtime
DESCRIPTION: If set, at the end of DDL operation, the TServer will notify the YB-Master whether the DDL operation was committed or aborted
require_durable_wal_write DEFAULT: false
TAGS: stable
DESCRIPTION: Whether durable WAL write is required.In case you cannot write using O_DIRECT in WAL and data directories and this flag is set truethe system will deliberately crash with the appropriate error. If this flag is set false, the system will soft downgrade the durable_wal_write flag.
reset_master_leader_timeout_ms DEFAULT: 15000
TAGS: N/A
DESCRIPTION: Timeout to reset master leader in milliseconds.
retry_failed_replica_ms DEFAULT: 3600000
TAGS: N/A
DESCRIPTION: Time in milliseconds to wait for before retrying a failed replica
retryable_request_range_time_limit_secs DEFAULT: 30
TAGS: N/A
DESCRIPTION: Max delta in time for single op id range.
retryable_request_timeout_secs DEFAULT: 660
TAGS: runtime
DESCRIPTION: Maximum amount of time to keep write request in index, to prevent duplicate writes.If the client timeout is less than this value, then use the client timeout instead.
reuse_unclosed_segment_threshold_bytes DEFAULT: 9223372036854775807
TAGS: runtime
DESCRIPTION: If the last left in-progress segment size is smaller or equal to this threshold, Log will reuse this last segment as writable active_segment at tablet bootstrap. Otherwise, Log will create a new segment.
rlimit_as DEFAULT: -1
TAGS: N/A
DESCRIPTION: Memory size limit: bytes.
rlimit_cpu DEFAULT: -1
TAGS: N/A
DESCRIPTION: CPU time limit: seconds.
rlimit_data DEFAULT: -1
TAGS: N/A
DESCRIPTION: Data file size limit: bytes.
rlimit_fsize DEFAULT: -1
TAGS: N/A
DESCRIPTION: File size limit: blocks.
rlimit_memlock DEFAULT: 65536
TAGS: N/A
DESCRIPTION: Locked memory limit: bytes.
rlimit_nofile DEFAULT: 1048576
TAGS: N/A
DESCRIPTION: Open files limit.
rlimit_nproc DEFAULT: 12000
TAGS: N/A
DESCRIPTION: User process limit.
rlimit_stack DEFAULT: 8388608
TAGS: N/A
DESCRIPTION: Stack size limit: bytes.
rocksdb_base_background_compactions DEFAULT: -1
TAGS: N/A
DESCRIPTION: Number threads to do background compactions.
rocksdb_check_sst_file_tail_for_zeros DEFAULT: 0
TAGS: advanced,runtime
DESCRIPTION: Size of just written SST data file tail to be checked for being zeros. Check is not performed if flag value is zero.
rocksdb_compact_flush_rate_limit_bytes_per_sec DEFAULT: 1073741824
TAGS: N/A
DESCRIPTION: Use to control write rate of flush and compaction.
rocksdb_compact_flush_rate_limit_sharing_mode DEFAULT: tserver
TAGS: N/A
DESCRIPTION: map[#text:Allows to control rate limit sharing/calculation across RocksDB instances br:[ ]]
rocksdb_compaction_measure_io_stats DEFAULT: false
TAGS: N/A
DESCRIPTION: Measure stats for rocksdb compactions.
rocksdb_compaction_size_threshold_bytes DEFAULT: 2147483648
TAGS: N/A
DESCRIPTION: Threshold beyond which compaction is considered large.
rocksdb_disable_compactions DEFAULT: false
TAGS: N/A
DESCRIPTION: Disable rocksdb compactions.
rocksdb_file_starting_buffer_size DEFAULT: 8192
TAGS: N/A
DESCRIPTION: Starting buffer size for writable files, grows by 2x every new allocation.
rocksdb_level0_file_num_compaction_trigger DEFAULT: 5
TAGS: N/A
DESCRIPTION: Number of files to trigger level-0 compaction. -1 if compaction should not be triggered by number of files at all.
rocksdb_level0_slowdown_writes_trigger DEFAULT: -1
TAGS: N/A
DESCRIPTION: The number of files above which writes are slowed down.
rocksdb_level0_stop_writes_trigger DEFAULT: -1
TAGS: N/A
DESCRIPTION: The number of files above which compactions are stopped.
rocksdb_max_background_compactions DEFAULT: -1
TAGS: N/A
DESCRIPTION: Increased number of threads to do background compactions (used when compactions need to catch up.) Unless rocksdb_disable_compactions=true, this cannot be set to zero.
rocksdb_max_background_flushes DEFAULT: -1
TAGS: N/A
DESCRIPTION: Number threads to do background flushes.
rocksdb_max_file_size_for_compaction DEFAULT: 0
TAGS: N/A
DESCRIPTION: Maximal allowed file size to participate in RocksDB compaction. 0 - unlimited.
rocksdb_max_sst_write_retries DEFAULT: 0
TAGS: advanced,runtime
DESCRIPTION: Maximum allowed number of retries to write SST file in case of detected corruption after write.
rocksdb_max_write_buffer_number DEFAULT: 2
TAGS: N/A
DESCRIPTION: Maximum number of write buffers that are built up in memory.
rocksdb_nothing_in_memtable_to_flush_sleep_ms DEFAULT: 10
TAGS: N/A
DESCRIPTION: Used for a temporary workaround for http://bit.ly/ybissue437. How long to wait (ms) in case we could not flush any memtables, usually due to filters preventing us from doing so.
rocksdb_release_mutex_during_wait_for_memtables_to_flush DEFAULT: true
TAGS: N/A
DESCRIPTION: When a flush is scheduled, but there isn't a memtable eligible yet, release the mutex before going to sleep and reacquire it post sleep.
rocksdb_universal_compaction_always_include_size_threshold DEFAULT: 67108864
TAGS: N/A
DESCRIPTION: Always include files of smaller or equal size in a compaction.
rocksdb_universal_compaction_min_merge_width DEFAULT: 4
TAGS: N/A
DESCRIPTION: The minimum number of files in a single compaction run.
rocksdb_universal_compaction_size_ratio DEFAULT: 20
TAGS: N/A
DESCRIPTION: The percentage upto which files that are larger are include in a compaction.
rocksdb_use_logging_iterator DEFAULT: false
TAGS: N/A
DESCRIPTION: Wrap newly created RocksDB iterators in a logging wrapper
rpc_acceptor_listen_backlog DEFAULT: 128
TAGS: advanced
DESCRIPTION: Socket backlog parameter used when listening for RPC connections. This defines the maximum length to which the queue of pending TCP connections inbound to the RPC server may grow. If a connection request arrives when the queue is full, the client may receive an error. Higher values may help the server ride over bursts of new inbound connection requests.
rpc_bind_addresses DEFAULT: 0.0.0.0:9100
TAGS: stable
DESCRIPTION: Comma-separated list of addresses to bind to for RPC connections. Currently, ephemeral ports (i.e. port 0) are not allowed.
rpc_callback_max_cycles DEFAULT: 100000000
TAGS: advanced,runtime
DESCRIPTION: The maximum number of cycles for which an RPC callback should be allowed to run without emitting a warning. (Advanced debugging option)
rpc_connection_timeout_ms DEFAULT: 15000
TAGS: N/A
DESCRIPTION: Timeout for RPC connection operations
rpc_default_keepalive_time_ms DEFAULT: 65000
TAGS: advanced
DESCRIPTION: If an RPC connection from a client is idle for this amount of time, the server will disconnect the client. Setting flag to 0 disables this clean up.
rpc_dump_all_traces DEFAULT: false
TAGS: advanced,runtime
DESCRIPTION: If true, dump all RPC traces at INFO level
rpc_max_message_size DEFAULT: 267386880
TAGS: N/A
DESCRIPTION: The maximum size of a message of any RPC that the server will accept. The sum of consensus_max_batch_size_bytes and 1KB should be less than rpc_max_message_size
rpc_queue_limit DEFAULT: 0
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
rpc_read_buffer_size DEFAULT: 0
TAGS: N/A
DESCRIPTION: RPC connection read buffer size. 0 to auto detect.
rpc_server_allow_ephemeral_ports DEFAULT: false
TAGS: unsafe
DESCRIPTION: Allow binding to ephemeral ports. This can cause problems, so currently only allowed in tests.
rpc_slow_query_threshold_ms DEFAULT: 10000
TAGS: advanced,runtime
DESCRIPTION: Traces for calls that take longer than this threshold (in ms) are logged
rpc_throttle_threshold_bytes DEFAULT: 1048576
TAGS: N/A
DESCRIPTION: Throttle inbound RPC calls larger than specified size on hitting mem tracker soft limit. Throttling is disabled if negative value is specified. The value must be at least 16 and less than the strictly enforced consensus_max_batch_size_bytes.
rpc_workers_limit DEFAULT: 1024
TAGS: N/A
DESCRIPTION: Workers limit for rpc server
rpcs_shutdown_extra_delay_ms DEFAULT: 5000
TAGS: N/A
DESCRIPTION: Extra allowed time for a single RPC command to complete after its deadline.
rpcs_shutdown_timeout_ms DEFAULT: 15000
TAGS: N/A
DESCRIPTION: Timeout for a batch of multiple RPCs invoked in parallel to shutdown.
rpcz_max_cql_batch_dump_count DEFAULT: 4096
TAGS: N/A
DESCRIPTION: The maximum number of CQL batch elements in the RPCZ dump.
rpcz_max_cql_query_dump_size DEFAULT: 4096
TAGS: N/A
DESCRIPTION: The maximum size of the CQL query string in the RPCZ dump.
rpcz_max_redis_query_dump_size DEFAULT: 4096
TAGS: N/A
DESCRIPTION: The maximum size of the Redis query string in the RPCZ dump.
sampled_trace_1_in_n DEFAULT: 1000
TAGS: advanced,runtime
DESCRIPTION: Flag to enable/disable sampled tracing. 0 disables.
scanner_batch_size_rows DEFAULT: 0
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
scanner_default_batch_size_bytes DEFAULT: 0
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
scanner_max_batch_size_bytes DEFAULT: 0
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
scheduled_full_compaction_check_interval_min DEFAULT: 15
TAGS: N/A
DESCRIPTION: DEPRECATED. Use auto_compact_check_interval_sec.
scheduled_full_compaction_frequency_hours DEFAULT: 0
TAGS: runtime
DESCRIPTION: Frequency with which full compactions should be scheduled on tablets. 0 indicates the feature is disabled.
scheduled_full_compaction_jitter_factor_percentage DEFAULT: 33
TAGS: runtime
DESCRIPTION: Percentage of scheduled_full_compaction_frequency_hours to be used as jitter when determining full compaction schedule per tablet. Jitter will be deterministically computed when scheduling a compaction, between 0 and (frequency * jitter factor) hours.
send_wait_for_report_interval_ms DEFAULT: 60000
TAGS: N/A
DESCRIPTION: The tick interval time to trigger updating all transaction coordinators with wait-for relationships.
server_broadcast_addresses DEFAULT:
TAGS: N/A
DESCRIPTION: Broadcast addresses for this server.
server_tcmalloc_max_total_thread_cache_bytes DEFAULT: -1
TAGS: N/A
DESCRIPTION: Total number of bytes to use for the thread cache for tcmalloc across all threads in the tserver/master. If this is negative, it has no effect.
skip_flushed_entries DEFAULT: true
TAGS: N/A
DESCRIPTION: Only replay WAL entries that are not flushed to RocksDB or necessary to bootstrap retryable requests (unflushed and within retryable request timeout).
skip_flushed_entries_in_first_replayed_segment DEFAULT: true
TAGS: runtime
DESCRIPTION: If applicable, only replay entries that are not flushed to RocksDB or necessary to bootstrap retryable requests in the first replayed wal segment.
skip_tablet_data_verification DEFAULT: false
TAGS: N/A
DESCRIPTION: Skip checking tablet data for corruption.
skip_wal_rewrite DEFAULT: true
TAGS: experimental,runtime
DESCRIPTION: Skip rewriting WAL files during bootstrap.
small_compaction_extra_priority DEFAULT: 1
TAGS: N/A
DESCRIPTION: Small compaction will get small_compaction_extra_priority extra priority.
socket_receive_buffer_size DEFAULT: 0
TAGS: N/A
DESCRIPTION: Socket receive buffer size, 0 to use default
ssl_protocols DEFAULT:
TAGS: N/A
DESCRIPTION: List of allowed SSL protocols (ssl2, ssl3, tls10, tls11, tls12). Empty to allow TLS only.
sst_files_hard_limit DEFAULT: 48
TAGS: runtime
DESCRIPTION: When majority SST files number is greater that this limit, we will reject all write requests.
sst_files_soft_limit DEFAULT: 24
TAGS: runtime
DESCRIPTION: When majority SST files number is greater that this limit, we will start rejecting part of write requests. The higher the number of SST files, the higher probability of rejection.
start_cql_proxy DEFAULT: true
TAGS: N/A
DESCRIPTION: Starts a CQL proxy along with the tablet server
start_pgsql_proxy DEFAULT: false
TAGS: N/A
DESCRIPTION: Whether to run a PostgreSQL server as a child process of the tablet server
start_redis_proxy DEFAULT: true
TAGS: N/A
DESCRIPTION: Starts a redis proxy along with the tablet server
stateful_service_operation_timeout_sec DEFAULT: 120
TAGS: runtime
DESCRIPTION: The number of seconds after which stateful service operations should timeout.
stateful_service_periodic_task_interval_ms DEFAULT: 10000
TAGS: runtime
DESCRIPTION: Frequency of the stateful service periodic task. 0 indicates that the task should not run.
stderrthreshold DEFAULT: 3
TAGS: runtime,advanced,stable
DESCRIPTION: log messages at or above this level are copied to stderr in addition to logfiles. This flag obsoletes --alsologtostderr.
stepdown_disable_graceful_transition DEFAULT: false
TAGS: N/A
DESCRIPTION: During a leader stepdown, disable graceful leadership transfer to an up to date peer
stop_logging_if_full_disk DEFAULT: false
TAGS: runtime,advanced,stable
DESCRIPTION: Stop attempting to log to disk if the disk is full.
stop_on_parent_termination DEFAULT: false
TAGS: N/A
DESCRIPTION: When specified, this process will terminate when parent process terminates.Linux-only.
stream_compression_algo DEFAULT: 0
TAGS: N/A
DESCRIPTION: Algorithm used for stream compression. 0 - no compression, 1 - gzip, 2 - snappy, 3 - lz4.
stream_truncate_record DEFAULT: false
TAGS: runtime
DESCRIPTION: Enable streaming of TRUNCATE record
stuck_outbound_call_check_interval_sec DEFAULT: 30
TAGS: advanced,runtime
DESCRIPTION: Check and report each stuck outbound call at most once per this number of seconds.
stuck_outbound_call_default_timeout_sec DEFAULT: 120
TAGS: advanced,runtime
DESCRIPTION: Default timeout for reporting purposes for the Reactor-based stuck OutboundCall tracking and expiration mechanism. That mechanism itself is controlled by the reactor_based_outbound_call_expiration_delay_ms flag. Note that this flag does not force a call to be timed out, it just specifies the interval after which the call is logged.
suicide_on_eio DEFAULT: true
TAGS: advanced
DESCRIPTION: Kill the process if an I/O operation results in EIO
svc_queue_length_default DEFAULT: 0
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
symbolize_stacktrace DEFAULT: true
TAGS: advanced,runtime,stable
DESCRIPTION: Symbolize the stack trace in the tombstone
tablet_bloom_block_size DEFAULT: 0
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
tablet_bloom_target_fp_rate DEFAULT: 0
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
tablet_do_compaction_cleanup_for_intents DEFAULT: true
TAGS: N/A
DESCRIPTION: Whether to clean up intents for aborted transactions in compaction.
tablet_do_dup_key_checks DEFAULT: true
TAGS: unsafe
DESCRIPTION: Whether to check primary keys for duplicate on insertion. Use at your own risk!
tablet_enable_ttl_file_filter DEFAULT: false
TAGS: N/A
DESCRIPTION: Enables compaction to directly delete files that have expired based on TTL, rather than removing them via the normal compaction process.
tablet_exclusive_full_compaction DEFAULT: false
TAGS: runtime
DESCRIPTION: Enables exclusive mode for any non-post-split full compaction for a tablet: all scheduled and unscheduled compactions are run before the full compaction and no other compactions will get scheduled during a full compaction.
tablet_exclusive_post_split_compaction DEFAULT: false
TAGS: runtime
DESCRIPTION: Enables exclusive mode for post-split compaction for a tablet: all scheduled and unscheduled compactions are run before post-split compaction and no other compaction will get scheduled during post-split compaction.
tablet_operation_memory_limit_mb DEFAULT: 1024
TAGS: advanced
DESCRIPTION: Maximum amount of memory that may be consumed by all in-flight operations belonging to a particular tablet. When this limit is reached, new operations will be rejected and clients will be forced to retry them. If -1, operation memory tracking is disabled.
tablet_overhead_size_percentage DEFAULT: -1000
TAGS: N/A
DESCRIPTION: Percentage of total available memory to use for tablet-related overheads. A value of 0 means no limit. Must be between 0 and 100 inclusive. Exception: -1000 specifies to instead use a recommended value determined in part by the amount of RAM available.
tablet_replicas_per_core_limit DEFAULT: 0
TAGS: advanced,runtime
DESCRIPTION: The maximum number of tablets the cluster can support per vCPU being used by TServers. 0 means no limit.
tablet_replicas_per_gib_limit DEFAULT: 1462
TAGS: advanced,runtime
DESCRIPTION: The maximum number of tablets the cluster can support per GiB of RAM reserved by TServers for tablet overheads. 0 means no limit.
tablet_rocksdb_ops_quiet_down_timeout_ms DEFAULT: 0
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
tablet_server_svc_num_threads DEFAULT: -1
TAGS: advanced
DESCRIPTION: Number of RPC worker threads for the TS service. If -1, it is auto configured.
tablet_server_svc_queue_length DEFAULT: 5000
TAGS: advanced
DESCRIPTION: RPC queue length for the TS service.
tablet_validator_retain_delete_markers_validation_period_sec DEFAULT: 60
TAGS: advanced,runtime
DESCRIPTION: The time period in seconds for validation of retain delete markers property for index tables. The value is not updated immediately, it is posponed till the nearest run of the periodic validation task. The value of 0 is used to disable verification. In this case, the validation task wakes up every minute to get a new flag value.
taskstream_queue_max_size DEFAULT: 100000
TAGS: N/A
DESCRIPTION: Maximum number of operations waiting in the taskstream queue.
taskstream_queue_max_wait_ms DEFAULT: 1000
TAGS: N/A
DESCRIPTION: Maximum time in ms to wait for items in the taskstream queue to arrive.
tcmalloc_max_free_bytes_percentage DEFAULT: 10
TAGS: advanced,runtime
DESCRIPTION: Maximum percentage of the RSS that tcmalloc is allowed to use for reserved but unallocated memory.
tcmalloc_max_per_cpu_cache_bytes DEFAULT: -1
TAGS: N/A
DESCRIPTION: Sets the maximum cache size per CPU cache if Google TCMalloc is being used. If this is zero or less, it has no effect.
tcmalloc_trace_enabled DEFAULT: false
TAGS: advanced
DESCRIPTION: Enable tracing of malloc/free calls for tcmalloc.
tcmalloc_trace_frequency DEFAULT: 0
TAGS: advanced,runtime
DESCRIPTION: Frequency at which malloc/free calls should be traced.
tcmalloc_trace_max_threshold DEFAULT: 0
TAGS: advanced
DESCRIPTION: Maximum (exclusive) threshold for tracing malloc/free calls. If 0, no maximum threshold is used.
tcmalloc_trace_min_threshold DEFAULT: 0
TAGS: advanced
DESCRIPTION: Minimum (inclusive) threshold for tracing malloc/free calls.
temporary_disable_preelections_timeout_ms DEFAULT: 600000
TAGS: N/A
DESCRIPTION: If some of nodes does not support preelections, then we disable them for this amount of time.
TEST_check_broadcast_address DEFAULT: true
TAGS: N/A
DESCRIPTION: Break connectivity in test mini cluster to check broadcast address.
TEST_export_ash_uuids_as_hex_strings DEFAULT: false
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
TEST_transaction_allow_rerequest_status DEFAULT: true
TAGS: N/A
DESCRIPTION: Allow rerequest transaction status when TryAgain is received.
throttle_cql_calls_on_soft_memory_limit DEFAULT: true
TAGS: N/A
DESCRIPTION: Whether to reject CQL calls when soft memory limit is reached.
throttle_cql_calls_policy DEFAULT: 0
TAGS: N/A
DESCRIPTION: Policy for throttling CQL calls. 1 - drop throttled calls. 0 - respond with OVERLOADED error.
time_based_wal_gc_clock_delta_usec DEFAULT: 0
TAGS: N/A
DESCRIPTION: A delta in microseconds to add to the clock value used to determine if a WAL segment is safe to be garbage collected. This is needed for clusters running with a skewed hybrid clock, because the clock used for time-based WAL GC is the wall clock, not hybrid clock.
timestamp_history_retention_interval_sec DEFAULT: 900
TAGS: N/A
DESCRIPTION: The time interval in seconds to retain DocDB history for. Point-in-time reads at a hybrid time further than this in the past might not be allowed after a compaction. Set this to be higher than the expected maximum duration of any single transaction in your application.
timestamp_syscatalog_history_retention_interval_sec DEFAULT: 14400
TAGS: N/A
DESCRIPTION: The time interval in seconds to retain syscatalog history for CDC to read specific schema version. Point-in-time reads at a hybrid time further than this in the past might not be allowed after a compaction. Set this to be higher than the expected maximum duration of any single transaction in your application.
tmp_dir DEFAULT: /tmp
TAGS: N/A
DESCRIPTION: Directory to store temporary files. By default, the value of '/tmp' is used.
total_mem_watcher_interval_millis DEFAULT: 1000
TAGS: runtime
DESCRIPTION: Interval in milliseconds between checking the total memory usage of the current process as seen by the operating system, and deciding whether to terminate in case of excessive memory consumption.
trace_max_dump_size DEFAULT: 30000
TAGS: advanced,runtime
DESCRIPTION: The max size of a trace dumped to the logs in Trace::DumpToLogInfo. 0 means unbounded.
trace_to_console DEFAULT:
TAGS: experimental
DESCRIPTION: Trace pattern specifying which trace events should be dumped directly to the console
tracing_level DEFAULT: 0
TAGS: advanced,runtime
DESCRIPTION: verbosity levels (like --v) up to which tracing is enabled.
transaction_abort_check_interval_ms DEFAULT: 5000
TAGS: runtime
DESCRIPTION: Interval to check whether running transaction was aborted.
transaction_abort_check_timeout_ms DEFAULT: 30000
TAGS: runtime
DESCRIPTION: Timeout used when checking for aborted transactions.
transaction_check_interval_usec DEFAULT: 500000
TAGS: N/A
DESCRIPTION: Transaction check interval in usec.
transaction_deadlock_detection_interval_usec DEFAULT: 60000000
TAGS: advanced
DESCRIPTION: Deadlock detection interval in usec.
transaction_disable_heartbeat_in_tests DEFAULT: false
TAGS: N/A
DESCRIPTION: Disable heartbeat during test.
transaction_heartbeat_usec DEFAULT: 500000
TAGS: N/A
DESCRIPTION: Interval of transaction heartbeat in usec.
transaction_manager_queue_limit DEFAULT: 500
TAGS: N/A
DESCRIPTION: Max number of tasks used by transaction manager
transaction_manager_workers_limit DEFAULT: 50
TAGS: N/A
DESCRIPTION: Max number of workers used by transaction manager
transaction_max_missed_heartbeat_periods DEFAULT: 10
TAGS: N/A
DESCRIPTION: Maximum heartbeat periods that a pending transaction can miss before the transaction coordinator expires the transaction. The total expiration time in microseconds is transaction_heartbeat_usec times transaction_max_missed_heartbeat_periods. The value passed to this flag may be fractional.
transaction_min_running_check_delay_ms DEFAULT: 50
TAGS: N/A
DESCRIPTION: When transaction with minimal start hybrid time is updated at transaction participant, we wait at least this number of milliseconds before checking its status at transaction coordinator. Used for the optimization that deletes provisional records RocksDB SSTable files.
transaction_min_running_check_interval_ms DEFAULT: 250
TAGS: N/A
DESCRIPTION: While transaction with minimal start hybrid time remains the same, we will try to check its status at transaction coordinator at regular intervals this long (ms). Used for the optimization that deletes provisional records RocksDB SSTable files.
transaction_pool_cleanup_interval_ms DEFAULT: 5000
TAGS: N/A
DESCRIPTION: How frequently we should cleanup transaction pool
transaction_pool_reserve_factor DEFAULT: 2
TAGS: N/A
DESCRIPTION: During cleanup we will preserve number of transactions in pool that equals to average number or take requests during prepration multiplied by this factor
transaction_resend_applying_interval_usec DEFAULT: 5000000
TAGS: N/A
DESCRIPTION: Transaction resend applying interval in usec.
transaction_rpc_timeout_ms DEFAULT: 5000
TAGS: runtime
DESCRIPTION: Timeout used by transaction related RPCs in milliseconds.
transaction_status_tablet_log_segment_size_bytes DEFAULT: 4194304
TAGS: N/A
DESCRIPTION: The segment size for transaction status tablet log roll-overs, in bytes.
transactions_cleanup_cache_size DEFAULT: 256
TAGS: N/A
DESCRIPTION: Transactions cleanup cache size.
transactions_poll_check_aborted DEFAULT: true
TAGS: N/A
DESCRIPTION: Check aborted transactions during poll.
transactions_status_poll_interval_ms DEFAULT: 500
TAGS: N/A
DESCRIPTION: Transactions poll interval.
tryfromenv DEFAULT:
TAGS: advanced,stable
DESCRIPTION: set flags from the environment if present
ts_admin_svc_num_threads DEFAULT: 10
TAGS: advanced
DESCRIPTION: Number of RPC worker threads for the TS admin service
ts_admin_svc_queue_length DEFAULT: 50
TAGS: advanced
DESCRIPTION: RPC queue length for the TS admin service
ts_backup_svc_num_threads DEFAULT: 4
TAGS: advanced
DESCRIPTION: Number of RPC worker threads for the TS backup service
ts_backup_svc_queue_length DEFAULT: 50
TAGS: advanced
DESCRIPTION: RPC queue length for the TS backup service
ts_consensus_svc_num_threads DEFAULT: -1
TAGS: advanced
DESCRIPTION: Number of RPC worker threads for the TS consensus service. If -1, it is auto configured.
ts_consensus_svc_queue_length DEFAULT: 5000
TAGS: advanced
DESCRIPTION: RPC queue length for the TS consensus service.
ts_remote_bootstrap_svc_num_threads DEFAULT: 10
TAGS: advanced
DESCRIPTION: Number of RPC worker threads for the TS remote bootstrap service
ts_remote_bootstrap_svc_queue_length DEFAULT: 50
TAGS: advanced
DESCRIPTION: RPC queue length for the TS remote bootstrap service
tserver_enable_metrics_snapshotter DEFAULT: false
TAGS: N/A
DESCRIPTION: Should metrics snapshotter be enabled
tserver_heartbeat_metrics_add_drive_data DEFAULT: true
TAGS: N/A
DESCRIPTION: Add drive data to metrics which tserver sends to master
tserver_heartbeat_metrics_add_leader_info DEFAULT: true
TAGS: N/A
DESCRIPTION: Add leader info to metrics tserver sends to master
tserver_heartbeat_metrics_add_replication_status DEFAULT: true
TAGS: N/A
DESCRIPTION: Add replication status to metrics tserver sends to master
tserver_heartbeat_metrics_interval_ms DEFAULT: 5000
TAGS: N/A
DESCRIPTION: Interval (in milliseconds) at which tserver sends its metrics in a heartbeat to master.
tserver_master_addrs DEFAULT: 127.0.0.1:7100
TAGS: stable
DESCRIPTION: Comma separated addresses of the masters which the tablet server should connect to. The CQL proxy reads this flag as well to determine the new set of masters
tserver_master_replication_factor DEFAULT: 0
TAGS: N/A
DESCRIPTION: Number of master replicas. By default it is detected based on tserver_master_addrs option, but could be specified explicitly together with passing one or more master service domain name and port through tserver_master_addrs for masters auto-discovery when running on Kubernetes.
tserver_metrics_snapshotter_yb_client_default_timeout_ms DEFAULT: 5000
TAGS: advanced
DESCRIPTION: Default timeout for the YBClient embedded into the tablet server that is used by metrics snapshotter.
tserver_tcmalloc_max_total_thread_cache_bytes DEFAULT: 0
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
tserver_yb_client_default_timeout_ms DEFAULT: 60000
TAGS: N/A
DESCRIPTION: Default timeout for the YBClient embedded into the tablet server that is used for distributed transactions.
txn_max_apply_batch_records DEFAULT: 100000
TAGS: N/A
DESCRIPTION: Max number of apply records allowed in single RocksDB batch. When a transaction's data in one tablet does not fit into specified number of records, it will be applied using multiple RocksDB write batches.
txn_print_trace_every_n DEFAULT: 0
TAGS: advanced,runtime
DESCRIPTION: Controls the rate at which txn traces are printed. Setting this to 0 disables printing the collected traces.
txn_print_trace_on_error DEFAULT: false
TAGS: advanced,runtime
DESCRIPTION: Controls whether to always print txn traces on error.
txn_slow_op_threshold_ms DEFAULT: 0
TAGS: advanced,runtime
DESCRIPTION: Controls the rate at which txn traces are printed. Setting this to 0 disables printing the collected traces.
undefok DEFAULT:
TAGS: advanced,stable
DESCRIPTION: comma-separated list of flag names that it is okay to specify on the command line even if the program does not define a flag with that name. IMPORTANT: flags in this list that have arguments MUST use the flag=value format
universe_key_client_max_delay_ms DEFAULT: 2000
TAGS: runtime
DESCRIPTION: Maximum Time in microseconds that an instance of Backoff_waiter waits before retrying to get the Universe key registry.
update_all_tablets_upon_network_failure DEFAULT: true
TAGS: runtime
DESCRIPTION: If this is enabled, then pon receiving a network error, we mark the remote server as being unreachable for all tablets in metacache, instead of the single tablet which issued the rpc.
update_metrics_interval_ms DEFAULT: 15000
TAGS: runtime
DESCRIPTION: How often to update xDC cluster metrics.
update_min_cdc_indices_interval_secs DEFAULT: 60
TAGS: runtime
DESCRIPTION: How often to read cdc_state table to get the minimum applied index for each tablet across all streams. This information is used to correctly keep log files that contain unapplied entries. This is also the rate at which a tablet's minimum replicated index across all streams is sent to the other peers in the configuration. If flag enable_log_retention_by_op_idx is disabled, this flag has no effect.
update_permissions_cache_msecs DEFAULT: 2000
TAGS: N/A
DESCRIPTION: How often the roles' permissions cache should be updated. 0 means never update it
use_cassandra_authentication DEFAULT: false
TAGS: N/A
DESCRIPTION: If to require authentication on startup.
use_client_to_server_encryption DEFAULT: false
TAGS: N/A
DESCRIPTION: Use client to server encryption
use_docdb_aware_bloom_filter DEFAULT: true
TAGS: N/A
DESCRIPTION: Whether to use the DocDbAwareFilterPolicy for both bloom storage and seeks.
use_fast_next_for_iteration DEFAULT: true
TAGS: runtime
DESCRIPTION: Whether intent aware iterator should use fast next feature.
use_hashed_redis_password DEFAULT: true
TAGS: N/A
DESCRIPTION: Store the hash of the redis passwords instead.
use_icu_timezones DEFAULT: true
TAGS: N/A
DESCRIPTION: Use the new ICU library for timezones instead of boost
use_libbacktrace DEFAULT: false
TAGS: N/A
DESCRIPTION: Whether to use the libbacktrace library for symbolizing stack traces
use_memory_defaults_optimized_for_ysql DEFAULT: false
TAGS: N/A
DESCRIPTION: If true, the recommended defaults for the memory usage settings take into account the amount of RAM and cores available and are optimized for using YSQL. If false, the recommended defaults will be the old defaults, which are more suitable for YCQL but do not take into account the amount of RAM and cores available.
use_monotime_for_traces DEFAULT: false
TAGS: advanced,runtime
DESCRIPTION: Flag to enable use of MonoTime::Now() instead of CoarseMonoClock::Now(). CoarseMonoClock is much cheaper so it is better to use it. However if we need more accurate sub-millisecond level breakdown, we could use MonoTime.
use_multi_level_index DEFAULT: true
TAGS: N/A
DESCRIPTION: Whether to use multi-level data index.
use_node_hostname_for_local_tserver DEFAULT: false
TAGS: N/A
DESCRIPTION: Connect to local t-server by using host name instead of local IP
use_node_to_node_encryption DEFAULT: false
TAGS: N/A
DESCRIPTION: Use node to node encryption.
use_offset_based_key_decoding DEFAULT: false
TAGS: runtime
DESCRIPTION: Use Offset based key decoding for reader.
use_preelection DEFAULT: true
TAGS: N/A
DESCRIPTION: Whether to use pre election, before doing actual election.
use_priority_thread_pool_for_compactions DEFAULT: true
TAGS: runtime
DESCRIPTION: When true priority thread pool will be used for compactions, otherwise Env thread pool with Priority::LOW will be used.
use_priority_thread_pool_for_flushes DEFAULT: false
TAGS: runtime
DESCRIPTION: When true priority thread pool will be used for flushes, otherwise Env thread pool with Priority::HIGH will be used.
use_private_ip DEFAULT: never
TAGS: N/A
DESCRIPTION: When to use private IP for connection. cloud - would use private IP if destination node is located in the same cloud. region - would use private IP if destination node is located in the same cloud and region. zone - would use private IP if destination node is located in the same cloud, region and zone.never - would never use private IP if broadcast address is specified.
v DEFAULT: 0
TAGS: runtime,advanced,stable
DESCRIPTION: Show all VLOG(m) messages for m <= this. Overridable by --vmodule.
verify_client_endpoint DEFAULT: false
TAGS: N/A
DESCRIPTION: Whether client endpoint should be verified.
verify_encrypted_meta_block_checksums DEFAULT: true
TAGS: N/A
DESCRIPTION: Whether to verify checksums for meta blocks of encrypted SSTables.
verify_index_rate_rows_per_sec DEFAULT: 0
TAGS: advanced,runtime
DESCRIPTION: Rate of at which the indexed table's entries are read during index consistency checks.This is a per-tablet flag, i.e. a tserver responsible for multiple tablets could be processing more than this.
verify_index_read_batch_size DEFAULT: 128
TAGS: advanced,runtime
DESCRIPTION: The batch size for reading the index.
verify_server_endpoint DEFAULT: true
TAGS: N/A
DESCRIPTION: Whether server endpoint should be verified.
verify_tablet_data_interval_sec DEFAULT: 0
TAGS: N/A
DESCRIPTION: The tick interval time for the tablet data integrity verification background task. This defaults to 0, which means disable the background task.
version DEFAULT: false
TAGS: stable
DESCRIPTION: show version and build info and exit
version_file_json_path DEFAULT:
TAGS: N/A
DESCRIPTION: Path to directory containing JSON file with version info.
vmodule DEFAULT:
TAGS: advanced,stable
DESCRIPTION: per-module verbose level. Argument is a comma-separated list of <module name>=<log level>. <module name> is a glob pattern, matched against the filename base (that is, name ignoring .cc/.h./-inl.h). <log level> overrides any value given by --v.
wait_for_safe_op_id_to_apply_default_timeout_ms DEFAULT: 15000
TAGS: N/A
DESCRIPTION: Timeout used by WaitForSafeOpIdToApply when it was not specified by caller.
wait_for_ysql_backends_catalog_version_client_master_rpc_margin_ms DEFAULT: 5000
TAGS: advanced,runtime
DESCRIPTION: For a WaitForYsqlBackendsCatalogVersion client-to-master RPC, the amount of time to reserve out of the RPC timeout to respond back to client. If margin is zero, client will determine timeout without receiving response from master. Margin should be set high enough to cover processing and RPC time for the response. It should be lower than wait_for_ysql_backends_catalog_version_client_master_rpc_timeout_ms.
wait_for_ysql_backends_catalog_version_client_master_rpc_timeout_ms DEFAULT: 20000
TAGS: advanced
DESCRIPTION: WaitForYsqlBackendsCatalogVersion client-to-master RPC timeout. Specifically, both the postgres-to-tserver and tserver-to-master RPC timeout.
wait_hybrid_time_sleep_interval_us DEFAULT: 10000
TAGS: N/A
DESCRIPTION: Sleep interval in microseconds that will be used while waiting for specific hybrid time.
wait_queue_poll_interval_ms DEFAULT: 100
TAGS: N/A
DESCRIPTION: The interval duration between wait queue polls to fetch transaction statuses of active blockers.
wait_replication_drain_tserver_max_retry DEFAULT: 3
TAGS: runtime
DESCRIPTION: Maximum number of retry that a tserver will poll its tablets until the tabletsare all caught-up in the replication, before responding to the caller.
wait_replication_drain_tserver_retry_interval_ms DEFAULT: 100
TAGS: runtime
DESCRIPTION: Time in microseconds that a tserver will sleep between each iteration of polling its tablets until the tablets are all caught-up in the replication.
web_log_bytes DEFAULT: 1048576
TAGS: advanced,runtime
DESCRIPTION: The maximum number of bytes to display on the debug webserver's log page
webserver_authentication_domain DEFAULT:
TAGS: N/A
DESCRIPTION: Domain used for debug webserver authentication
webserver_ca_certificate_file DEFAULT:
TAGS: N/A
DESCRIPTION: The location of the certificate of the certificate authority of the debug webserver's SSL certificate file, in .pem format. If empty, system-wide CA certificates are used.
webserver_certificate_file DEFAULT:
TAGS: N/A
DESCRIPTION: The location of the debug webserver's SSL certificate file, in .pem format. If empty, webserver SSL support is not enabled
webserver_compression_threshold_kb DEFAULT: 4
TAGS: advanced,runtime
DESCRIPTION: The threshold of response size above which compression is performed.Default value is 4KB
webserver_doc_root DEFAULT:
TAGS: advanced
DESCRIPTION: Files under <webserver_doc_root> are accessible via the debug webserver. Defaults to $YB_HOME/www, or if $YB_HOME is not set, disables the document root
webserver_enable_doc_root DEFAULT: true
TAGS: advanced
DESCRIPTION: If true, webserver may serve static files from the webserver_doc_root
webserver_interface DEFAULT:
TAGS: advanced
DESCRIPTION: Interface to start debug webserver on. If blank, webserver binds to first host IPpresent in the list of comma separated rpc_bind_addresses
webserver_max_post_length_bytes DEFAULT: 1048576
TAGS: advanced,runtime
DESCRIPTION: The maximum length of a POST request that will be accepted by the embedded web server.
webserver_num_worker_threads DEFAULT: 50
TAGS: advanced
DESCRIPTION: Maximum number of threads to start for handling web server requests
webserver_password_file DEFAULT:
TAGS: N/A
DESCRIPTION: (Optional) Location of .htpasswd file containing user names and hashed passwords for debug webserver authentication
webserver_port DEFAULT: 9000
TAGS: stable
DESCRIPTION: Port to bind to for the web server
webserver_private_key_file DEFAULT:
TAGS: N/A
DESCRIPTION: The location of the debug webserver's SSL private key file, in .pem format. If empty, the private key is assumed to be located in the same file as the certificate.
webserver_private_key_password DEFAULT:
TAGS: N/A
DESCRIPTION: The password for the debug webserver's SSL private key. If empty, no password is used.
webserver_redirect_http_to_https DEFAULT: false
TAGS: N/A
DESCRIPTION: Redirect HTTP requests to the embedded webserver to HTTPS if HTTPS is enabled.
webserver_strict_transport_security DEFAULT: false
TAGS: runtime
DESCRIPTION: Header is cached by the browser for the specified 'max-age' and forces it to redirect any http request to https to avoid man-in-the-middle attacks. The original http request is never sent.
webserver_zlib_compression_level DEFAULT: 1
TAGS: advanced,runtime
DESCRIPTION: The zlib compression level.Lower compression levels result in faster execution, but less compression
writable_file_use_fsync DEFAULT: false
TAGS: advanced
DESCRIPTION: Use fsync(2) instead of fdatasync(2) for synchronizing dirty data to disk.
xcluster_consistent_wal_safe_time_frequency_ms DEFAULT: 250
TAGS: runtime
DESCRIPTION: Frequency in milliseconds at which apply safe time is computed.
xcluster_enable_packed_rows_support DEFAULT: true
TAGS: advanced,runtime
DESCRIPTION: Enables rewriting of packed rows with xcluster consumer schema version
xcluster_enable_subtxn_abort_propagation DEFAULT: true
TAGS: stable,auto,runtime
DESCRIPTION: Enable including information about which subtransactions aborted in CDC changes
xcluster_get_changes_max_send_rate_mbps DEFAULT: 100
TAGS: runtime
DESCRIPTION: Server-wide max send rate in megabytes per second for GetChanges response traffic. Throttles xcluster but not cdc traffic.
xcluster_poller_task_delay_considered_stuck_secs DEFAULT: 3600
TAGS: runtime
DESCRIPTION: Maximum amount of time between tasks of a xcluster poller above which it is considered as stuck.
xcluster_safe_time_update_interval_secs DEFAULT: 1
TAGS: runtime
DESCRIPTION: The interval at which xcluster safe time is computed. This controls the staleness of the data seen when performing database level xcluster consistent reads. If there is any additional lag in the replication, then it will add to the overall staleness of the data.
xcluster_svc_queue_length DEFAULT: 5000
TAGS: advanced
DESCRIPTION: RPC queue length for the xCluster service
yb_backend_oom_score_adj DEFAULT: 900
TAGS: N/A
DESCRIPTION: oom_score_adj of postgres backends in linux environments
yb_client_admin_operation_timeout_sec DEFAULT: 120
TAGS: N/A
DESCRIPTION: The number of seconds after which an admin operation should timeout.
yb_client_num_reactors DEFAULT: 16
TAGS: N/A
DESCRIPTION: Number of reactor threads for the yb client to communicate with different tservers.
yb_enable_cdc_consistent_snapshot_streams DEFAULT: false
TAGS: preview,runtime
DESCRIPTION: Enable support for CDC Consistent Snapshot Streams NOTE: This flag protects a feature that is currently in preview. In order for it to be modified, 'yb_enable_cdc_consistent_snapshot_streams' must be set in --allowed_preview_flags_csv.
yb_enable_read_committed_isolation DEFAULT: false
TAGS: N/A
DESCRIPTION: Defines how READ COMMITTED (which is our default SQL-layer isolation) and READ UNCOMMITTED are mapped internally. If false (default), both map to the stricter REPEATABLE READ implementation. If true, both use the new READ COMMITTED implementation instead.
yb_enable_valgrind DEFAULT: false
TAGS: N/A
DESCRIPTION: True to run postgres under Valgrind. Must compile with --no-tcmalloc
yb_num_shards_per_tserver DEFAULT: -1
TAGS: runtime
DESCRIPTION: The default number of shards per table per tablet server when a table is created. If the value is -1, the system automatically determines an appropriate value based on the number of CPU cores; it is determined to 1 if enable_automatic_tablet_splitting is set to true.
yb_pg_terminate_child_backend DEFAULT: false
TAGS: N/A
DESCRIPTION: Terminate other active server processes when a backend is killed
yb_system_namespace_readonly DEFAULT: true
TAGS: runtime
DESCRIPTION: Set system keyspace read-only.
yb_test_name DEFAULT:
TAGS: N/A
DESCRIPTION: Specifies test name this daemon is running as part of.
yb_webserver_oom_score_adj DEFAULT: 900
TAGS: N/A
DESCRIPTION: oom_score_adj of YSQL webserver in linux environments
ybclient_print_trace_every_n DEFAULT: 0
TAGS: advanced,runtime
DESCRIPTION: Controls the rate at which traces from ybclient are printed. Setting this to 0 disables printing the collected traces.
ycql_allow_in_op_with_order_by DEFAULT: false
TAGS: advanced
DESCRIPTION: Allow IN to be used with ORDER BY clause
ycql_allow_local_calls_in_curr_thread DEFAULT: true
TAGS: runtime
DESCRIPTION: Whether or not to allow local calls on the RPC thread.
ycql_allow_non_authenticated_password_reset DEFAULT: false
TAGS: runtime
DESCRIPTION: If to allow non-authenticated user to reset the password.
ycql_audit_excluded_categories DEFAULT:
TAGS: N/A
DESCRIPTION: Comma separated list of categories to be excluded from the audit log
ycql_audit_excluded_keyspaces DEFAULT: system,system_schema,system_virtual_schema,system_auth
TAGS: N/A
DESCRIPTION: Comma separated list of keyspaces to be excluded from the audit log
ycql_audit_excluded_users DEFAULT:
TAGS: N/A
DESCRIPTION: Comma separated list of users to be excluded from the audit log
ycql_audit_included_categories DEFAULT:
TAGS: N/A
DESCRIPTION: Comma separated list of categories to be included in the audit log, if none - includes all (non-excluded) categories
ycql_audit_included_keyspaces DEFAULT:
TAGS: N/A
DESCRIPTION: Comma separated list of keyspaces to be included in the audit log, if none - includes all (non-excluded) keyspaces
ycql_audit_included_users DEFAULT:
TAGS: N/A
DESCRIPTION: Comma separated list of users to be included in the audit log, if none - includes all (non-excluded) users
ycql_audit_log_level DEFAULT: ERROR
TAGS: N/A
DESCRIPTION: Severity level at which an audit will be logged. Could be INFO, WARNING, or ERROR
ycql_bind_collection_assignment_using_column_name DEFAULT: false
TAGS: runtime
DESCRIPTION: Enable using column name for binding the value of subscripted collection column
ycql_cache_login_info DEFAULT: false
TAGS: N/A
DESCRIPTION: Use authentication information cached locally.
ycql_consistent_transactional_paging DEFAULT: false
TAGS: N/A
DESCRIPTION: Whether to enforce consistency of data returned for second page and beyond for YCQL queries on transactional tables. If true, read restart errors could be returned to prevent inconsistency. If false, no read restart errors are returned but the data may be stale. The latter is preferable for long scans. The data returned for the first page of results is never stale regardless of this flag.
ycql_disable_index_updating_optimization DEFAULT: false
TAGS: advanced
DESCRIPTION: If true all secondary indexes must be updated even if the update does not change the index data.
ycql_enable_alter_rename_column_with_index DEFAULT: false
TAGS: advanced,runtime
DESCRIPTION: Whether renaming a column which is used in an index is enabled.
ycql_enable_audit_log DEFAULT: false
TAGS: runtime
DESCRIPTION: Enable YCQL audit. Use ycql_audit_* flags for fine-grained configuration
ycql_enable_packed_row DEFAULT: false
TAGS: runtime
DESCRIPTION: Whether packed row is enabled for YCQL.
ycql_enable_stat_statements DEFAULT: true
TAGS: runtime
DESCRIPTION: If enabled, it will track queries and dump the metrics on http://localhost:12000/statements.
ycql_enable_tracing_flag DEFAULT: true
TAGS: runtime
DESCRIPTION: If enabled, setting TRACING ON in cqlsh will cause the server to enable tracing for the requested RPCs and print them. Use this as a safety flag to disable tracing if an errant application has TRACING enabled by mistake.
ycql_jsonb_use_member_cache DEFAULT: true
TAGS: runtime
DESCRIPTION: Whether we use member cache during jsonb processing in YCQL.
ycql_ldap_base_dn DEFAULT:
TAGS: N/A
DESCRIPTION: Specifies the base directory to begin the user name search
ycql_ldap_bind_dn DEFAULT:
TAGS: sensitive_info
DESCRIPTION: Specifies the username to perform the initial search when doing search + bind authentication
ycql_ldap_bind_passwd DEFAULT:
TAGS: sensitive_info
DESCRIPTION: Password for username being used to perform the initial search when doing search + bind authentication
ycql_ldap_search_attribute DEFAULT:
TAGS: N/A
DESCRIPTION: Attribute to match against the username in the search when doing search + bind authentication. If no attribute is specified, the uid attribute is used.
ycql_ldap_search_filter DEFAULT:
TAGS: N/A
DESCRIPTION: The search filter to use when doing search + bind authentication.
ycql_ldap_server DEFAULT:
TAGS: N/A
DESCRIPTION: LDAP server of the form <scheme>://<ip>:<port>
ycql_ldap_tls DEFAULT: false
TAGS: N/A
DESCRIPTION: Connect to LDAP server using TLS encryption.
ycql_ldap_user_prefix DEFAULT:
TAGS: N/A
DESCRIPTION: String used for prepending the user name when forming the DN for binding to the LDAP server
ycql_ldap_user_suffix DEFAULT:
TAGS: N/A
DESCRIPTION: String used for appending the user name when forming the DN for binding to the LDAP Server.
ycql_ldap_users_to_skip_csv DEFAULT:
TAGS: sensitive_info
DESCRIPTION: Users that are authenticated via the local password check instead of LDAP (if ycql_use_ldap=true). This is a comma separated list
ycql_num_tablets DEFAULT: -1
TAGS: runtime
DESCRIPTION: The number of tablets per YCQL table. Default value is -1. Colocated tables are not affected. If its value is not set then (1) the value of yb_num_shards_per_tserver is used in conjunction with the number of tservers to determine the tablet count, (2) in case of low number of CPU cores (<4) and enable_automatic_tablet_splitting is set to true, neither the number of tservers nor yb_num_shards_per_tserver are taken into account to determine the tablet count, the value is determined on base the number of CPU cores only.If the user explicitly specifies a value of the tablet count in the Create Table DDL statement (with tablets = x syntax) then it takes precedence over the value of this flag. Needs to be set at tserver.
ycql_packed_row_size_limit DEFAULT: 0
TAGS: N/A
DESCRIPTION: Packed row size limit for YCQL in bytes. 0 to make this equal to SSTable block size.
ycql_require_drop_privs_for_truncate DEFAULT: false
TAGS: N/A
DESCRIPTION: Require DROP TABLE permission in order to truncate table
ycql_serial_operation_in_transaction_block DEFAULT: true
TAGS: N/A
DESCRIPTION: If true, operations within a transaction block must be executed in order, at least semantically speaking.
ycql_suppress_group_by_error DEFAULT: false
TAGS: stable,auto,runtime
DESCRIPTION: Enable to suppress the error raised when using GROUP BY clause
ycql_use_ldap DEFAULT: false
TAGS: N/A
DESCRIPTION: Use LDAP for user logins
ycql_use_local_transaction_tables DEFAULT: false
TAGS: runtime
DESCRIPTION: Whether or not to use local transaction tables when possible for YCQL transactions.
yedis_enable_flush DEFAULT: true
TAGS: N/A
DESCRIPTION: Enables FLUSHDB and FLUSHALL commands in yedis.
yql_allow_compatible_schema_versions DEFAULT: true
TAGS: advanced,runtime
DESCRIPTION: Allow YCQL requests to be accepted even if they originate from a client who is ahead of the server's schema, but is determined to be compatible with the current version.
yql_max_value_size DEFAULT: 67108864
TAGS: N/A
DESCRIPTION: Maximum size of a value in the Yugabyte Query Layer
ysql_analyze_dump_intentsdb_metrics DEFAULT: false
TAGS: runtime
DESCRIPTION: Whether to return changed intentsdb metrics for YSQL queries in RPC response.
ysql_analyze_dump_metrics DEFAULT: true
TAGS: runtime
DESCRIPTION: Whether to return changed metrics for YSQL queries in RPC response.
ysql_backward_prefetch_scale_factor DEFAULT: 0
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
ysql_beta_features DEFAULT: false
TAGS: N/A
DESCRIPTION: Whether to enable all ysql beta features
ysql_catalog_preload_additional_table_list DEFAULT:
TAGS: N/A
DESCRIPTION: A list of catalog tables that YSQL preloads additionally upon connection start-up and cache refreshes. Catalog table names must start with pg_.Invalid catalog names are ignored. Comma separated. Example: pg_range,pg_proc.If both ysql_catalog_preload_additional_tables and ysql_catalog_preload_additional_table_list are set, we take a union of both the default list and the user-specified list.
ysql_catalog_preload_additional_tables DEFAULT: false
TAGS: N/A
DESCRIPTION: If true, YB catalog preloads a default set of tables upon connection creation and cache refresh: pg_am,pg_amproc,pg_cast,pg_cast,pg_inherits,pg_policy,pg_proc,pg_tablespace,pg_trigger.
ysql_cdc_active_replication_slot_window_ms DEFAULT: 60000
TAGS: advanced,runtime
DESCRIPTION: Determines the window in milliseconds in which if a client has consumed the changes of a ReplicationSlot across any tablet, then it is considered to be actively used. ReplicationSlots which haven't been used in this interval areconsidered to be inactive.
ysql_client_read_write_timeout_ms DEFAULT: -1
TAGS: N/A
DESCRIPTION: Timeout for YSQL's yb-client read/write operations. Falls back on max(client_read_write_timeout_ms, 600s) if set to -1.
ysql_cluster_level_mutation_persist_interval_ms DEFAULT: 10000
TAGS: runtime
DESCRIPTION: Interval at which the reported node level table mutation counts are persisted to the underlying YCQL table by the central auto analyze service
ysql_cluster_level_mutation_persist_rpc_timeout_ms DEFAULT: 10000
TAGS: runtime
DESCRIPTION: Timeout for rpcs involved in persisting mutations in the auto-analyze table.
ysql_colocate_database_by_default DEFAULT: false
TAGS: N/A
DESCRIPTION: Enable colocation by default on each database.
ysql_conn_mgr_dowarmup DEFAULT: false
TAGS: N/A
DESCRIPTION: Enable precreation of server connections in Ysql Connection Manager. If set false, the server connections are created lazily (on-demand) in Ysql Connection Manager.
ysql_conn_mgr_idle_time DEFAULT: 60
TAGS: N/A
DESCRIPTION: Specifies the maximum idle (secs) time allowed for database connections created by the Ysql Connection Manager. If a database connection remains idle without serving a client connection for a duration equal to or exceeding the value provided, it will be automatically closed by the Ysql Connection Manager.
ysql_conn_mgr_internal_conn_db DEFAULT: yugabyte
TAGS: N/A
DESCRIPTION: Database to which Ysql Connection Manager will make connections to inorder to execute internal queries.
ysql_conn_mgr_max_client_connections DEFAULT: 10000
TAGS: N/A
DESCRIPTION: Total number of concurrent client connections that the Ysql Connection Manager allows.
ysql_conn_mgr_max_conns_per_db DEFAULT: 0
TAGS: N/A
DESCRIPTION: Maximum number of concurrent database connections Ysql Connection Manager can create per pool.
ysql_conn_mgr_min_conns_per_db DEFAULT: 1
TAGS: N/A
DESCRIPTION: Minimum number of physical connections, that will be present in pool. This limit is not considered while closing a broken physical connection.
ysql_conn_mgr_num_workers DEFAULT: 0
TAGS: N/A
DESCRIPTION: Number of worker threads used by Ysql Connection Manager. If set as 0 (default value), the number of worker threads will be half of the number of CPU cores.
ysql_conn_mgr_password DEFAULT: yugabyte
TAGS: N/A
DESCRIPTION: Password to be used by Ysql Connection Manager while creating database connections.
ysql_conn_mgr_port DEFAULT: 5433
TAGS: N/A
DESCRIPTION: Ysql Connection Manager port to which clients will connect. This must be different from the postgres port set via pgsql_proxy_bind_address. Default is 5433.
ysql_conn_mgr_stats_interval DEFAULT: 10
TAGS: N/A
DESCRIPTION: Interval (in secs) at which the stats for Ysql Connection Manager will be updated.
ysql_conn_mgr_use_unix_conn DEFAULT: true
TAGS: N/A
DESCRIPTION: Enable unix socket connections between Ysql Connection Manager and pg_backend. For pg_backend to accept unix socket connection by Ysql Connection Manager add 'local all yugabyte trust' in hba.conf (set ysql_hba_conf_csv as 'local all yugabyte trust').
ysql_conn_mgr_username DEFAULT: yugabyte
TAGS: N/A
DESCRIPTION: Username to be used by Ysql Connection Manager while creating database connections.
ysql_conn_mgr_warmup_db DEFAULT: yugabyte
TAGS: N/A
DESCRIPTION: Database for which warmup needs to be done.
ysql_datestyle DEFAULT: ISO, MDY
TAGS: pg
DESCRIPTION: The ysql display format for date and time values
ysql_ddl_transaction_wait_for_ddl_verification DEFAULT: true
TAGS: runtime
DESCRIPTION: If set, DDL transactions will wait for DDL verification to complete before returning to the client.
ysql_default_transaction_isolation DEFAULT: read committed
TAGS: pg
DESCRIPTION: The ysql transaction isolation level
ysql_disable_global_impact_ddl_statements DEFAULT: false
TAGS: N/A
DESCRIPTION: If true, disable global impact ddl statements in per database catalog version mode.
ysql_disable_per_tuple_memory_context_in_update_relattrs DEFAULT: false
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
ysql_disable_portal_run_context DEFAULT: false
TAGS: N/A
DESCRIPTION: Whether to use portal ybRunContext.
ysql_disable_server_file_access DEFAULT: false
TAGS: N/A
DESCRIPTION: If true, disables read, write, and execute of local server files. File access can be re-enabled if set to false.
ysql_enable_auth DEFAULT: false
TAGS: N/A
DESCRIPTION: True to enforce password authentication for all connections
ysql_enable_create_database_oid_collision_retry DEFAULT: true
TAGS: advanced
DESCRIPTION: Whether to retry YSQL CREATE DATABASE statement if oid collision happens.
ysql_enable_pack_full_row_update DEFAULT: false
TAGS: runtime
DESCRIPTION: Whether to enable packed row for full row update.
ysql_enable_packed_row DEFAULT: true
TAGS: stable,auto,runtime
DESCRIPTION: Whether packed row is enabled for YSQL.
ysql_enable_packed_row_for_colocated_table DEFAULT: false
TAGS: runtime
DESCRIPTION: Whether to enable packed row for colocated tables.
ysql_enable_profile DEFAULT: false
TAGS: N/A
DESCRIPTION: Enable PROFILE feature.
ysql_enable_read_request_caching DEFAULT: true
TAGS: N/A
DESCRIPTION: Enable read request caching
ysql_enable_table_mutation_counter DEFAULT: false
TAGS: experimental
DESCRIPTION: Enable counting of mutations on a per-table basis. These mutations are used to automatically trigger ANALYZE as soon as the mutations of a table cross a certain threshold (decided based on ysql_auto_analyze_tuples_threshold and ysql_auto_analyze_scale_factor).
ysql_enable_update_batching DEFAULT: false
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
ysql_follower_reads_avoid_waiting_for_safe_time DEFAULT: true
TAGS: advanced,runtime
DESCRIPTION: Controls whether ysql follower reads that specify a not-yet-safe read time should be rejected. This will force them to go to the leader, which will likely be faster than waiting for safe time to catch up.
ysql_forward_rpcs_to_local_tserver DEFAULT: false
TAGS: N/A
DESCRIPTION: DEPRECATED. Feature has been removed
ysql_hba_conf DEFAULT:
TAGS: sensitive_info
DESCRIPTION: Deprecated, use `ysql_hba_conf_csv` flag instead. Comma separated list of postgres hba rules (in order)
ysql_hba_conf_csv DEFAULT:
TAGS: sensitive_info
DESCRIPTION: CSV formatted line represented list of postgres hba rules (in order)
ysql_ident_conf_csv DEFAULT:
TAGS: N/A
DESCRIPTION: CSV formatted line represented list of postgres ident map rules (in order)
ysql_log_failed_docdb_requests DEFAULT: false
TAGS: N/A
DESCRIPTION: Log failed docdb requests.
ysql_log_min_duration_statement DEFAULT: -1
TAGS: pg,runtime
DESCRIPTION: Sets the duration of each completed ysql statement to be logged if the statement ran for at least the specified number of milliseconds. Zero prints all queries. -1 turns this feature off.
ysql_log_min_messages DEFAULT: warning
TAGS: pg
DESCRIPTION: Sets the lowest ysql message level to log
ysql_log_statement DEFAULT: none
TAGS: pg
DESCRIPTION: Sets which types of ysql statements should be logged
ysql_max_connections DEFAULT: 0
TAGS: pg
DESCRIPTION: Overrides the maximum number of concurrent ysql connections. If set to 0, Postgres will dynamically determine a platform-specific value
ysql_max_read_restart_attempts DEFAULT: 0
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
ysql_max_write_restart_attempts DEFAULT: 0
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
ysql_min_new_version_ignored_count DEFAULT: 10
TAGS: runtime
DESCRIPTION: Minimum consecutive number of times that a tserver is allowed to ignore an older catalog version that is retrieved from a tserver-master heartbeat response.
ysql_minimal_catalog_caches_preload DEFAULT: false
TAGS: N/A
DESCRIPTION: Fill postgres' caches with system items only
ysql_node_level_mutation_reporting_interval_ms DEFAULT: 5000
TAGS: runtime
DESCRIPTION: Interval at which the node level table mutation counts are sent to the auto analyze service which tracks table mutation counters at the cluster level.
ysql_node_level_mutation_reporting_timeout_ms DEFAULT: 5000
TAGS: runtime
DESCRIPTION: Timeout for mutation reporting rpc to auto-analyze service.
ysql_non_txn_copy DEFAULT: false
TAGS: N/A
DESCRIPTION: Execute COPY inserts non-transactionally.
ysql_num_shards_per_tserver DEFAULT: -1
TAGS: runtime
DESCRIPTION: The default number of shards per YSQL table per tablet server when a table is created. If the value is -1, the system automatically determines an appropriate value based on the number of CPU cores; it is determined to 1 if enable_automatic_tablet_splitting is set to true.
ysql_num_tablets DEFAULT: -1
TAGS: runtime
DESCRIPTION: The number of tablets per YSQL table. Default value is -1. If its value is not set then (1) the value of ysql_num_shards_per_tserver is used in conjunction with the number of tservers to determine the tablet count, (2) in case of low number of CPU cores (<4) and enable_automatic_tablet_splitting is set to true, neither the number of tservers nor ysql_num_shards_per_tserver are taken into account to determine the tablet count, the value is determined on base the number of CPU cores only.If the user explicitly specifies a value of the tablet count in the Create Table DDL statement (split into x tablets syntax) then it takes precedence over the value of this flag. Needs to be set at tserver.
ysql_output_buffer_size DEFAULT: 262144
TAGS: N/A
DESCRIPTION: Size of postgres-level output buffer, in bytes. While fetched data resides within this buffer and hasn't been flushed to client yet, we're free to transparently restart operation in case of restart read error.
ysql_pack_inserted_value DEFAULT: false
TAGS: preview,runtime
DESCRIPTION: Enabled packing inserted columns into a single packed value in postgres layer. NOTE: This flag protects a feature that is currently in preview. In order for it to be modified, 'ysql_pack_inserted_value' must be set in --allowed_preview_flags_csv.
ysql_packed_row_size_limit DEFAULT: 0
TAGS: N/A
DESCRIPTION: Packed row size limit for YSQL in bytes. 0 to make this equal to SSTable block size.
ysql_pg_conf DEFAULT:
TAGS: N/A
DESCRIPTION: Deprecated, use the `ysql_pg_conf_csv` flag instead. Comma separated list of postgres setting assignments
ysql_pg_conf_csv DEFAULT:
TAGS: N/A
DESCRIPTION: CSV formatted line represented list of postgres setting assignments
ysql_prefetch_limit DEFAULT: 0
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
ysql_rc_force_pick_read_time_on_pg_client DEFAULT: false
TAGS: advanced
DESCRIPTION: When resetting read time for a statement in Read Commited isolation level, pick read time on the PgClientService instead of allowing the tserver to pick one.
ysql_request_limit DEFAULT: 1024
TAGS: N/A
DESCRIPTION: Maximum number of requests to be sent at once
ysql_scan_deadline_margin_ms DEFAULT: 1000
TAGS: N/A
DESCRIPTION: Scan deadline is calculated by adding client timeout to the time when the request was received. It defines the moment in time when client has definitely timed out and if the request is yet in processing after the deadline, it can be canceled. Therefore to prevent client timeout, the request handler should return partial result and paging information some time before the deadline. That's what the ysql_scan_deadline_margin_ms is for. It should account for network and processing delays.
ysql_scan_timeout_multiplier DEFAULT: 0
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
ysql_select_parallelism DEFAULT: -1
TAGS: N/A
DESCRIPTION: Number of read requests to issue in parallel to tablets of a table for SELECT.
ysql_sequence_cache_method DEFAULT: connection
TAGS: N/A
DESCRIPTION: Where sequence values are cached for both existing and new sequences. Valid values are "connection" and "server"
ysql_sequence_cache_minval DEFAULT: 100
TAGS: N/A
DESCRIPTION: Set how many sequence numbers to be preallocated in cache.
ysql_serializable_isolation_for_ddl_txn DEFAULT: false
TAGS: N/A
DESCRIPTION: Whether to use serializable isolation for separate DDL-only transactions. By default, repeatable read isolation is used. This flag should go away once full transactional DDL is implemented.
ysql_session_max_batch_size DEFAULT: 3072
TAGS: N/A
DESCRIPTION: Use session variable ysql_session_max_batch_size instead. Maximum batch size for buffered writes between PostgreSQL server and YugaByte DocDB services
ysql_skip_row_lock_for_update DEFAULT: false
TAGS: stable,auto,runtime
DESCRIPTION: By default DocDB operations for YSQL take row-level locks. If set to true, DocDB will instead take finer column-level locks instead of locking the whole row. This may cause issues with data integrity for operations with implicit dependencies between columns.
ysql_sleep_before_retry_on_txn_conflict DEFAULT: true
TAGS: N/A
DESCRIPTION: Whether to sleep before retrying the write on transaction conflicts.
ysql_suppress_unsafe_alter_notice DEFAULT: false
TAGS: N/A
DESCRIPTION: Suppress NOTICE on use of unsafe ALTER statements
ysql_suppress_unsupported_error DEFAULT: false
TAGS: N/A
DESCRIPTION: Suppress ERROR on use of unsupported SQL statement and use WARNING instead
ysql_timezone DEFAULT:
TAGS: pg
DESCRIPTION: Overrides the default ysql timezone for displaying and interpreting timestamps. If no value is provided, Postgres will determine one based on the environment
ysql_transaction_abort_timeout_ms DEFAULT: 900000
TAGS: N/A
DESCRIPTION: Max amount of time we can wait for active transactions to abort on a tablet after DDL (eg. DROP TABLE) is executed. This deadline is same as unresponsive_ts_rpc_timeout_ms
ysql_use_flat_doc_reader DEFAULT: true
TAGS: runtime
DESCRIPTION: Use DocDBTableReader optimization that relies on having at most 1 subkey for YSQL.
ysql_use_packed_row_v2 DEFAULT: false
TAGS: preview,runtime
DESCRIPTION: Whether to use packed row V2 when row packing is enabled. NOTE: This flag protects a feature that is currently in preview. In order for it to be modified, 'ysql_use_packed_row_v2' must be set in --allowed_preview_flags_csv.
ysql_use_relcache_file DEFAULT: true
TAGS: N/A
DESCRIPTION: Use relcache init file
ysql_wait_until_index_permissions_timeout_ms DEFAULT: 0
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
ysql_yb_ash_circular_buffer_size DEFAULT: 16384
TAGS: pg
DESCRIPTION: Size (in KiBs) of ASH circular buffer that stores the samples
ysql_yb_ash_enable_infra DEFAULT: false
TAGS: preview,pg
DESCRIPTION: Allocate shared memory for ASH, start the background worker, create instrumentation hooks and enable querying the yb_active_session_history view.
ysql_yb_ash_sample_size DEFAULT: 500
TAGS: pg,runtime
DESCRIPTION: Number of samples captured from each component per sampling event
ysql_yb_ash_sampling_interval DEFAULT: 0
TAGS: deprecated,runtime
DESCRIPTION: Deprecated
ysql_yb_ash_sampling_interval_ms DEFAULT: 1000
TAGS: pg,runtime
DESCRIPTION: Time (in milliseconds) between two consecutive sampling events
ysql_yb_bnl_batch_size DEFAULT: 1024
TAGS: pg,runtime
DESCRIPTION: Batch size of nested loop joins.
ysql_yb_bypass_cond_recheck DEFAULT: true
TAGS: pg,stable,auto,runtime
DESCRIPTION: Bypass index condition recheck at the YSQL layer if the condition was pushed down.
ysql_yb_ddl_rollback_enabled DEFAULT: true
TAGS: pg,runtime
DESCRIPTION: If true, upon failure of a YSQL DDL transaction that affects the DocDB syscatalog, the YB-Master will rollback the changes made to the DocDB syscatalog.
ysql_yb_disable_wait_for_backends_catalog_version DEFAULT: false
TAGS: pg,runtime
DESCRIPTION: Disable waiting for backends to have up-to-date pg_catalog. This could cause correctness issues, which could be mitigated by setting high ysql_yb_index_state_flags_update_delay. Although it is runtime-settable, the effects won't take place for any in-progress queries.
ysql_yb_enable_add_column_missing_default DEFAULT: true
TAGS: pg,stable,auto,runtime
DESCRIPTION: Enable using the default value for existing rows after an ADD COLUMN ... DEFAULT operation
ysql_yb_enable_alter_table_rewrite DEFAULT: true
TAGS: pg,stable,auto,runtime
DESCRIPTION: Enable ALTER TABLE rewrite operations
ysql_yb_enable_ash DEFAULT: false
TAGS: pg,preview,runtime
DESCRIPTION: Starts sampling and instrumenting YSQL and YCQL queries, and various background activities. This does nothing if ysql_yb_enable_ash_infra is disabled.
ysql_yb_enable_base_scans_cost_model DEFAULT: false
TAGS: pg,preview,runtime
DESCRIPTION: Enable cost model enhancements
ysql_yb_enable_ddl_atomicity_infra DEFAULT: true
TAGS: pg,stable,auto,runtime
DESCRIPTION: Enables YSQL DDL atomicity
ysql_yb_enable_expression_pushdown DEFAULT: true
TAGS: pg,stable,auto,runtime
DESCRIPTION: Push supported expressions from ysql down to DocDB for evaluation.
ysql_yb_enable_hash_batch_in DEFAULT: true
TAGS: pg,stable,auto,runtime
DESCRIPTION: Enable batching of hash in queries.
ysql_yb_enable_index_aggregate_pushdown DEFAULT: true
TAGS: pg,stable,auto,runtime
DESCRIPTION: Push supported aggregates from ysql down to DocDB for evaluation. Affects IndexScan only.
ysql_yb_enable_memory_tracking DEFAULT: true
TAGS: pg,runtime
DESCRIPTION: Enables tracking of memory consumption of the PostgreSQL process. This enhances garbage collection behaviour and memory usage observability.
ysql_yb_enable_optimizer_statistics DEFAULT: false
TAGS: pg,preview,runtime
DESCRIPTION: Enables use of the PostgreSQL selectivity estimation which utilizes table statistics collected with ANALYZE. When disabled, a simpler heuristics based selectivity estimation is used.
ysql_yb_enable_pg_locks DEFAULT: true
TAGS: pg,stable,auto,runtime
DESCRIPTION: Enable the pg_locks view. This view provides information about the locks held by active postgres sessions.
ysql_yb_enable_replica_identity DEFAULT: false
TAGS: pg,preview,runtime
DESCRIPTION: Enable replica identity command for Alter Table query
ysql_yb_enable_replication_commands DEFAULT: false
TAGS: pg,preview,runtime
DESCRIPTION: Enable logical replication commands for Publication and Replication Slots
ysql_yb_enable_saop_pushdown DEFAULT: true
TAGS: pg,stable,auto,runtime
DESCRIPTION: Push supported scalar array operations from ysql down to DocDB for evaluation.
ysql_yb_enable_sequence_pushdown DEFAULT: true
TAGS: pg,stable,auto,runtime
DESCRIPTION: Allow nextval() to fetch the value range and advance the sequence value in a single operation
ysql_yb_fetch_row_limit DEFAULT: 1024
TAGS: pg,runtime
DESCRIPTION: Maximum number of rows to fetch per scan.
ysql_yb_fetch_size_limit DEFAULT: 0
TAGS: pg,runtime
DESCRIPTION: Maximum size of a fetch response.
ysql_yb_index_state_flags_update_delay DEFAULT: 0
TAGS: pg,runtime
DESCRIPTION: Delay in milliseconds between stages of online index build. For testing purposes.
ysql_yb_locks_max_transactions DEFAULT: 16
TAGS: pg,runtime
DESCRIPTION: Sets the maximum number of transactions for which to return rows in pg_locks.
ysql_yb_locks_min_txn_age DEFAULT: 1000
TAGS: pg,runtime
DESCRIPTION: Sets the minimum transaction age for results from pg_locks.
ysql_yb_locks_txn_locks_per_tablet DEFAULT: 200
TAGS: pg,runtime
DESCRIPTION: Sets the maximum number of rows to return per transaction per tablet in pg_locks.
ysql_yb_parallel_range_rows DEFAULT: 0
TAGS: pg,preview,runtime
DESCRIPTION: The number of rows to plan per parallel worker, zero disables the feature
ysql_yb_pushdown_is_not_null DEFAULT: true
TAGS: pg,stable,auto,runtime
DESCRIPTION: Push down IS NOT NULL condition filters
ysql_yb_pushdown_strict_inequality DEFAULT: true
TAGS: pg,stable,auto,runtime
DESCRIPTION: Push down strict inequality filters
ysql_yb_test_block_index_phase DEFAULT:
TAGS: pg
DESCRIPTION: Block the given index phase from proceeding. Valid names are indisready, build, indisvalid and finish. For testing purposes.
ysql_yb_toast_catcache_threshold DEFAULT: -1
TAGS: pg,runtime
DESCRIPTION: Size threshold in bytes for a catcache tuple to be compressed.
ysql_yb_wait_for_backends_catalog_version_timeout DEFAULT: 300000
TAGS: pg,runtime
DESCRIPTION: Timeout in milliseconds to wait for backends to reach desired catalog versions. The actual time spent may be longer than that by as much as master flag wait_for_ysql_backends_catalog_version_client_master_rpc_timeout_ms. Setting to zero or less results in no timeout. Currently used by concurrent CREATE INDEX.
ysql_yb_walsender_poll_sleep_duration_empty_ms DEFAULT: 1000
TAGS: pg,runtime
DESCRIPTION: Time in milliseconds for which Walsender waits before fetching the next batch of changes from the CDC service in case the last received response was empty. The response can be empty in case there are no DMLs happening in the system.
ysql_yb_walsender_poll_sleep_duration_nonempty_ms DEFAULT: 1
TAGS: pg,runtime
DESCRIPTION: Time in milliseconds for which Walsender waits before fetching the next batch of changes from the CDC service in case the last received response was non-empty.
ysql_yb_xcluster_consistency_level DEFAULT: database
TAGS: pg
DESCRIPTION: Controls the consistency level of xCluster replicated databases. Valid values are "database" and "tablet".