scylladb / scylla-api-client

Scylla CLI Python module and command line utility
GNU Affero General Public License v3.0
4 stars 8 forks source link

Interface for /v2/config/{name} REST endpoint #47

Open GeoffMontee opened 4 days ago

GeoffMontee commented 4 days ago

The REST API provides an /v2/config/{name} endpoint to view configuration parameters. For example:

$ curl -XGET "http://localhost:10000/v2/config/stream_io_throughput_mb_per_sec"
0

The scylla-api-client utility does not provide an interface for this REST endpoint.

Steps to reproduce

$ scylla-api-client -lm | grep "config"

Expected results

A config module should be available that provides access to the /v2/config/{name} endpoint.

Actual results

There is no interface for the /v2/config/{name} endpoint.

bhalevy commented 3 days ago

Can you please try https://github.com/bhalevy/scylla-api-client/tree/v2-api ?

GeoffMontee commented 3 days ago

Hi @bhalevy ,

I built the branch by doing the following:

git clone https://github.com/bhalevy/scylla-api-client.git
cd scylla-api-client
git checkout v2-api
pip install --break-system-packages ./

This installed scylla-api-client to /usr/local/bin/, so I did the following:

root@f1cecb40536c:~/scylla-api-client# /usr/local/bin/scylla-api-client -lm
Available modules:

system
error_injection
storage_proxy
storage_service
endpoint_snitch_info
task_manager
messaging_service
gossiper
failure_detector
raft
compaction_manager
column_family
stream_manager
tasks
cache_service
authorization_cache
hinted_handoff
lsa
commitlog
collectd
v2

And the following:

root@f1cecb40536c:~/scylla-api-client# /usr/local/bin/scylla-api-client -lmc v2
v2 metrics-config:
  GET: Return the metrics layer configuration
  POST: Set the metrics layer relabel configuration
v2 config/background_writer_scheduling_quota:
  GET: max cpu usage ratio (between 0 and 1) for compaction process. Not intended for setting in normal operations. Setting it to 1 or higher will disable it, recommended operational setting is 0.5.
v2 config/auto_adjust_flush_quota:
  GET: true: auto-adjust memtable shares for flush processes
v2 config/memtable_flush_static_shares:
  GET: If set to higher than 0, ignore the controller's output and set the memtable shares statically. Do not set this unless you know what you are doing and suspect a problem in the controller. This option will be retired when the controller reaches more maturity.
v2 config/compaction_static_shares:
  GET: If set to higher than 0, ignore the controller's output and set the compaction shares statically. Do not set this unless you know what you are doing and suspect a problem in the controller. This option will be retired when the controller reaches more maturity.
v2 config/compaction_enforce_min_threshold:
  GET: If set to true, enforce the min_threshold option for compactions strictly. If false (default), Scylla may decide to compact even if below min_threshold.
v2 config/compaction_flush_all_tables_before_major_seconds:
  GET: Set the minimum interval in seconds between flushing all tables before each major compaction (default is 86400).This option is useful for maximizing tombstone garbage collection by releasing all active commitlog segments.Set to 0 to disable automatic flushing all tables before major compaction.
v2 config/cluster_name:
  GET: The name of the cluster; used to prevent machines in one logical cluster from joining another. All nodes participating in a cluster must have the same value.
v2 config/listen_address:
  GET: The IP address or hostname that Scylla binds to for connecting to other Scylla nodes. You must change the default setting for multiple nodes to communicate. Do not set to 0.0.0.0, unless you have set broadcast_address to an address that other nodes can use to reach this node.
v2 config/listen_interface:
  GET: The interface that Scylla binds to for connecting to other Scylla nodes. Interfaces must correspond to a single address, IP aliasing is not supported. See listen_address.
v2 config/listen_interface_prefer_ipv6:
  GET: If you choose to specify the interface by name and the interface has an ipv4 and an ipv6 addressyou can specify which should be chosen using listen_interface_prefer_ipv6. If false the first ipv4address will be used. If true the first ipv6 address will be used. Defaults to false preferringipv4. If there is only one address it will be selected regardless of ipv4/ipv6.
v2 config/workdir,W:
  GET: The directory in which Scylla will put all its subdirectories. The location of individual subdirs can be overridden by the respective ``*_directory`` options.
v2 config/commitlog_directory:
  GET: The directory where the commit log is stored. For optimal write performance, it is recommended the commit log be on a separate disk partition (ideally, a separate physical device) from the data file directories.
v2 config/schema_commitlog_directory:
  GET: The directory where the schema commit log is stored. This is a special commitlog instance used for schema and system tables. For optimal write performance, it is recommended the commit log be on a separate disk partition (ideally, a separate physical device) from the data file directories.
v2 config/data_file_directories:
  GET: The directory location where table data (SSTables) is stored.
v2 config/hints_directory:
  GET: The directory where hints files are stored if hinted handoff is enabled.
v2 config/view_hints_directory:
  GET: The directory where materialized-view updates are stored while a view replica is unreachable.
v2 config/saved_caches_directory:
  GET: The directory location where table key and row caches are stored.
v2 config/commit_failure_policy:
  GET: Policy for commit disk failures:
* die          Shut down gossip, so the node can be replaced.
* stop         Shut down gossip, leaving the node effectively dead, but can be inspected using the RESTful APIs.
* stop_commit  Shut down the commit log, letting writes collect but continuing to service reads (as in pre-2.0.5 Cassandra).
* ignore       Ignore fatal errors and let the batches fail.
v2 config/disk_failure_policy:
  GET: Sets how Scylla responds to disk failure. Recommend settings are stop or best_effort.
* die              Shut down gossip for any file system errors or single SSTable errors, so the node can be replaced.
* stop_paranoid    Shut down gossip even for single SSTable errors.
* stop             Shut down gossip, leaving the node effectively dead, but available for inspection using the RESTful APIs.
* best_effort      Stop using the failed disk and respond to requests based on the remaining available SSTables. This means you will see obsolete data at consistency level of ONE.
* ignore           Ignores fatal errors and lets the requests fail; all file system errors are logged but otherwise ignored. Scylla acts as in versions prior to Cassandra 1.2.
Related information: Handling Disk Failures In Cassandra 1.2 blog and Recovering from a single disk failure using JBOD.

v2 config/endpoint_snitch:
  GET: Set to a class that implements the IEndpointSnitch. Scylla uses snitches for locating nodes and routing requests.
* SimpleSnitch: Use for single-data center deployments or single-zone in public clouds. Does not recognize data center or rack information. It treats strategy order as proximity, which can improve cache locality when disabling read repair.
* GossipingPropertyFileSnitch: Recommended for production. The rack and data center for the local node are defined in the cassandra-rackdc.properties file and propagated to other nodes via gossip. To allow migration from the PropertyFileSnitch, it uses the cassandra-topology.properties file if it is present.
* Ec2Snitch: For EC2 deployments in a single region. Loads region and availability zone information from the EC2 API. The region is treated as the data center and the availability zone as the rack. Uses only private IPs. Subsequently it does not work across multiple regions.
* Ec2MultiRegionSnitch: Uses public IPs as the broadcast_address to allow cross-region connectivity. This means you must also set seed addresses to the public IP and open the storage_port or ssl_storage_port on the public IP firewall. For intra-region traffic, Scylla switches to the private IP after establishing a connection.
* GoogleCloudSnitch: For deployments on Google Cloud Platform across one or more regions. The region is treated as a datacenter and the availability zone is treated as a rack within the datacenter. The communication should occur over private IPs within the same logical network.
* RackInferringSnitch: Proximity is determined by rack and data center, which are assumed to correspond to the 3rd and 2nd octet of each node's IP address, respectively. This snitch is best used as an example for writing a custom snitch class (unless this happens to match your deployment conventions).

Related information: Snitches

v2 config/rpc_address:
  GET: The listen address for client connections (native transport).Valid values are:
* unset: Resolves the address using the hostname configuration of the node. If left unset, the hostname must resolve to the IP address of this node using /etc/hostname, /etc/hosts, or DNS.
* 0.0.0.0: Listens on all configured interfaces, but you must set the broadcast_rpc_address to a value other than 0.0.0.0.
* IP address
* hostname

Related information: Network

v2 config/rpc_interface:
  GET: The listen address for client connections. Interfaces must correspond to a single address, IP aliasing is not supported. See rpc_address.
v2 config/rpc_interface_prefer_ipv6:
  GET: If you choose to specify the interface by name and the interface has an ipv4 and an ipv6 addressyou can specify which should be chosen using rpc_interface_prefer_ipv6. If false the first ipv4address will be used. If true the first ipv6 address will be used. Defaults to false preferringipv4. If there is only one address it will be selected regardless of ipv4/ipv6.
v2 config/seed_provider:
  GET: The addresses of hosts deemed contact points. Scylla nodes use the -seeds list to find each other and learn the topology of the ring.

 * class_name (Default: org.apache.cassandra.locator.SimpleSeedProvider): The class within Scylla that handles the seed logic. It can be customized, but this is typically not required.
 * seeds (Default: 127.0.0.1): A comma-delimited list of IP addresses used by gossip for bootstrapping new nodes joining a cluster. When running multiple nodes, you must change the list from the default value. In multiple data-center clusters, the seed list should include at least one node from each data center (replication group). More than a single seed node per data center is recommended for fault tolerance. Otherwise, gossip has to communicate with another data center when bootstrapping a node. Making every node a seed node is not recommended because of increased maintenance and reduced gossip performance. Gossip optimization is not critical, but it is recommended to use a small seed list (approximately three nodes per data center).

Related information: Initializing a multiple node cluster (single data center) and Initializing a multiple node cluster (multiple data centers).
v2 config/compaction_throughput_mb_per_sec:
  GET: Throttles compaction to the specified total throughput across the entire system. The faster you insert data, the faster you need to compact in order to keep the SSTable count down. The recommended Value is 16 to 32 times the rate of write throughput (in MBs/second). Setting the value to 0 disables compaction throttling.

Related information: Configuring compaction
v2 config/compaction_large_partition_warning_threshold_mb:
  GET: Log a warning when writing partitions larger than this value.
v2 config/compaction_large_row_warning_threshold_mb:
  GET: Log a warning when writing rows larger than this value.
v2 config/compaction_large_cell_warning_threshold_mb:
  GET: Log a warning when writing cells larger than this value.
v2 config/compaction_rows_count_warning_threshold:
  GET: Log a warning when writing a number of rows larger than this value.
v2 config/compaction_collection_elements_count_warning_threshold:
  GET: Log a warning when writing a collection containing more elements than this value.
v2 config/memtable_total_space_in_mb:
  GET: Specifies the total memory used for all memtables on a node. This replaces the per-table storage settings memtable_operations_in_millions and memtable_throughput_in_mb.
v2 config/concurrent_reads:
  GET: For workloads with more data than can fit in memory, the bottleneck is reads fetching data from disk. Setting to (16 × number_of_drives) allows operations to queue low enough in the stack so that the OS and drives can reorder them.
v2 config/concurrent_writes:
  GET: Writes in Cassandra are rarely I/O bound, so the ideal number of concurrent writes depends on the number of CPU cores in your system. The recommended value is (8 x number_of_cpu_cores).
v2 config/concurrent_counter_writes:
  GET: Counter writes read the current values before incrementing and writing them back. The recommended value is (16 × number_of_drives) .
v2 config/incremental_backups:
  GET: Backs up data updated since the last snapshot was taken. When enabled, Scylla creates a hard link to each SSTable flushed or streamed locally in a backups/ subdirectory of the keyspace data. Removing these links is the operator's responsibility.

Related information: Enabling incremental backups
v2 config/snapshot_before_compaction:
  GET: Enable or disable taking a snapshot before each compaction. This option is useful to back up data when there is a data format change. Be careful using this option because Cassandra does not clean up older snapshots automatically.

Related information: Configuring compaction
v2 config/phi_convict_threshold:
  GET: Adjusts the sensitivity of the failure detector on an exponential scale. Generally this setting never needs adjusting.

Related information: Failure detection and recovery
v2 config/failure_detector_timeout_in_ms:
  GET: Maximum time between two successful echo message before gossip mark a node down in milliseconds.

v2 config/direct_failure_detector_ping_timeout_in_ms:
  GET: Duration after which the direct failure detector aborts a ping message, so the next ping can start.
Note: this failure detector is used by Raft, and is different from gossiper's failure detector (configured by `failure_detector_timeout_in_ms`).

v2 config/commitlog_sync:
  GET: The method that Scylla uses to acknowledge writes in milliseconds:
* periodic: Used with commitlog_sync_period_in_ms (Default: 10000 - 10 seconds ) to control how often the commit log is synchronized to disk. Periodic syncs are acknowledged immediately.
* batch: Used with commitlog_sync_batch_window_in_ms (Default: disabled ``**``) to control how long Scylla waits for other writes before performing a sync. When using this method, writes are not acknowledged until fsynced to disk.

Related information: Durability
v2 config/commitlog_segment_size_in_mb:
  GET: Sets the size of the individual commitlog file segments. A commitlog segment may be archived, deleted, or recycled after all its data has been flushed to SSTables. This amount of data can potentially include commitlog segments from every table in the system. The default size is usually suitable for most commitlog archiving, but if you want a finer granularity, 8 or 16 MB is reasonable. See Commit log archive configuration.

Related information: Commit log archive configuration
v2 config/schema_commitlog_segment_size_in_mb:
  GET: Sets the size of the individual schema commitlog file segments. The default size is larger than the default size of the data commitlog because the segment size puts a limit on the mutation size that can be written at once, and some schema mutation writes are much larger than average.

Related information: Commit log archive configuration
v2 config/commitlog_sync_period_in_ms:
  GET: Controls how long the system waits for other writes before performing a sync in ``periodic`` mode.
v2 config/commitlog_sync_batch_window_in_ms:
  GET: Controls how long the system waits for other writes before performing a sync in ``batch`` mode.
v2 config/commitlog_max_data_lifetime_in_seconds:
  GET: Controls how long data remains in commit log before the system tries to evict it to sstable, regardless of usage pressure. (0 disables)
v2 config/commitlog_total_space_in_mb:
  GET: Total space used for commitlogs. If the used space goes above this value, Scylla rounds up to the next nearest segment multiple and flushes memtables to disk for the oldest commitlog segments, removing those log segments. This reduces the amount of data to replay on startup, and prevents infrequently-updated tables from indefinitely keeping commitlog segments. A small total commitlog space tends to cause more flush activity on less-active tables.

Related information: Configuring memtable throughput
v2 config/commitlog_reuse_segments:
  GET: Whether or not to reuse commitlog segments when finished instead of deleting them. Can improve commitlog latency on some file systems.

v2 config/commitlog_flush_threshold_in_mb:
  GET: Threshold for commitlog disk usage. When used disk space goes above this value, Scylla initiates flushes of memtables to disk for the oldest commitlog segments, removing those log segments. Adjusting this affects disk usage vs. write latency. Default is (approximately) commitlog_total_space_in_mb - <num shards>*commitlog_segment_size_in_mb.
v2 config/commitlog_use_o_dsync:
  GET: Whether or not to use O_DSYNC mode for commitlog segments IO. Can improve commitlog latency on some file systems.

v2 config/commitlog_use_hard_size_limit:
  GET: Whether or not to use a hard size limit for commitlog disk usage. Default is true. Enabling this can cause latency spikes, whereas the default can lead to occasional disk usage peaks.

v2 config/commitlog_use_fragmented_entries:
  GET: Whether or not to allow commitlog entries to fragment across segments, allowing for larger entry sizes.

v2 config/compaction_preheat_key_cache:
  GET: When set to true , cached row keys are tracked during compaction, and re-cached to their new positions in the compacted SSTable. If you have extremely large key caches for tables, set the value to false ; see Global row and key caches properties.
v2 config/concurrent_compactors:
  GET: Sets the number of concurrent compaction processes allowed to run simultaneously on a node, not including validation compactions for anti-entropy repair. Simultaneous compactions help preserve read performance in a mixed read-write workload by mitigating the tendency of small SSTables to accumulate during a single long-running compaction. If compactions run too slowly or too fast, change compaction_throughput_mb_per_sec first.
v2 config/in_memory_compaction_limit_in_mb:
  GET: Size limit for rows being compacted in memory. Larger rows spill to disk and use a slower two-pass compaction process. When this occurs, a message is logged specifying the row key. The recommended value is 5 to 10 percent of the available Java heap size.
v2 config/preheat_kernel_page_cache:
  GET: Enable or disable kernel page cache preheating from contents of the key cache after compaction. When enabled it preheats only first page (4KB) of each row to optimize for sequential access. It can be harmful for fat rows, see CASSANDRA-4937 for more details.
v2 config/sstable_preemptive_open_interval_in_mb:
  GET: When compacting, the replacement opens SSTables before they are completely written and uses in place of the prior SSTables for any range previously written. This setting helps to smoothly transfer reads between the SSTables by reducing page cache churn and keeps hot rows hot.
v2 config/defragment_memory_on_idle:
  GET: When set to true, will defragment memory when the cpu is idle.  This reduces the amount of work Scylla performs when processing client requests.
v2 config/memtable_allocation_type:
  GET: Specify the way Cassandra allocates and manages memtable memory. See Off-heap memtables in Cassandra 2.1. Options are:
* heap_buffers     On heap NIO (non-blocking I/O) buffers.
* offheap_buffers  Off heap (direct) NIO buffers.
* offheap_objects  Native memory, eliminating NIO buffer heap overhead.
v2 config/memtable_cleanup_threshold:
  GET: Ratio of occupied non-flushing memtable size to total permitted size for triggering a flush of the largest memtable. Larger values mean larger flushes and less compaction, but also less concurrent flush activity, which can make it difficult to keep your disks saturated under heavy write load.
v2 config/file_cache_size_in_mb:
  GET: Total memory to use for SSTable-reading buffers.
v2 config/memtable_flush_queue_size:
  GET: The number of full memtables to allow pending flush (memtables waiting for a write thread). At a minimum, set to the maximum number of indexes created on a single table.
Related information: Flushing data from the memtable
v2 config/memtable_flush_writers:
  GET: Sets the number of memtable flush writer threads. These threads are blocked by disk I/O, and each one holds a memtable in memory while blocked. If you have a large Java heap size and many data directories, you can increase the value for better flush performance.
v2 config/memtable_heap_space_in_mb:
  GET: Total permitted memory to use for memtables. Triggers a flush based on memtable_cleanup_threshold. Cassandra stops accepting writes when the limit is exceeded until a flush completes. If unset, sets to default.
v2 config/memtable_offheap_space_in_mb:
  GET: See memtable_heap_space_in_mb
v2 config/column_index_size_in_kb:
  GET: Granularity of the index of rows within a partition. For huge rows, decrease this setting to improve seek time. If you use key cache, be careful not to make this setting too large because key cache will be overwhelmed. If you're unsure of the size of the rows, it's best to use the default setting.
v2 config/column_index_auto_scale_threshold_in_kb:
  GET: Auto-reduce the promoted index granularity by half when reaching this threshold, to prevent promoted index bloating due to partitions with too many rows. Set to 0 to disable this feature.
v2 config/index_summary_capacity_in_mb:
  GET: Fixed memory pool size in MB for SSTable index summaries. If the memory usage of all index summaries exceeds this limit, any SSTables with low read rates shrink their index summaries to meet this limit. This is a best-effort process. In extreme conditions, Cassandra may need to use more than this amount of memory.
v2 config/index_summary_resize_interval_in_minutes:
  GET: How frequently index summaries should be re-sampled. This is done periodically to redistribute memory from the fixed-size pool to SSTables proportional their recent read rates. To disable, set to -1. This leaves existing index summaries at their current sampling level.
v2 config/reduce_cache_capacity_to:
  GET: Sets the size percentage to which maximum cache capacity is reduced when Java heap usage reaches the threshold defined by reduce_cache_sizes_at. Together with flush_largest_memtables_at, these properties constitute an emergency measure for preventing sudden out-of-memory (OOM) errors.
v2 config/reduce_cache_sizes_at:
  GET: When Java heap usage (after a full concurrent mark sweep (CMS) garbage collection) exceeds this percentage, Cassandra reduces the cache capacity to the fraction of the current size as specified by reduce_cache_capacity_to. To disable, set the value to 1.0.
v2 config/stream_throughput_outbound_megabits_per_sec:
  GET: Throttles all outbound streaming file transfers on a node to the specified throughput. Cassandra does mostly sequential I/O when streaming data during bootstrap or repair, which can lead to saturating the network connection and degrading client (RPC) performance.
v2 config/inter_dc_stream_throughput_outbound_megabits_per_sec:
  GET: Throttles all streaming file transfer between the data centers. This setting allows throttles streaming throughput betweens data centers in addition to throttling all network stream traffic as configured with stream_throughput_outbound_megabits_per_sec.
v2 config/stream_io_throughput_mb_per_sec:
  GET: Throttles streaming I/O to the specified total throughput (in MiBs/s) across the entire system. Streaming I/O includes the one performed by repair and both RBNO and legacy topology operations such as adding or removing a node. Setting the value to 0 disables stream throttling.
v2 config/stream_plan_ranges_fraction:
  GET: Specify the fraction of ranges to stream in a single stream plan. Value is between 0 and 1.
v2 config/trickle_fsync:
  GET: When doing sequential writing, enabling this option tells fsync to force the operating system to flush the dirty buffers at a set interval trickle_fsync_interval_in_kb. Enable this parameter to avoid sudden dirty buffer flushing from impacting read latencies. Recommended to use on SSDs, but not on HDDs.
v2 config/trickle_fsync_interval_in_kb:
  GET: Sets the size of the fsync in kilobytes.
v2 config/auto_bootstrap:
  GET: This setting has been removed from default configuration. It makes new (non-seed) nodes automatically migrate the right data to themselves. Do not set this to false unless you really know what you are doing.
Related information: Initializing a multiple node cluster (single data center) and Initializing a multiple node cluster (multiple data centers).
v2 config/batch_size_warn_threshold_in_kb:
  GET: Log WARN on any batch size exceeding this value in kilobytes. Caution should be taken on increasing the size of this threshold as it can lead to node instability.
v2 config/batch_size_fail_threshold_in_kb:
  GET: Fail any multiple-partition batch exceeding this value. 1 MiB (8x warn threshold) by default.
v2 config/broadcast_address:
  GET: The IP address a node tells other nodes in the cluster to contact it by. It allows public and private address to be different. For example, use the broadcast_address parameter in topologies where not all nodes have access to other nodes by their private IP addresses.
If your Scylla cluster is deployed across multiple Amazon EC2 regions and you use the EC2MultiRegionSnitch , set the broadcast_address to public IP address of the node and the listen_address to the private IP.
v2 config/listen_on_broadcast_address:
  GET: When using multiple physical network interfaces, set this to true to listen on broadcast_address in addition to the listen_address, allowing nodes to communicate in both interfaces.  Ignore this property if the network configuration automatically routes between the public and private networks such as EC2.
v2 config/initial_token:
  GET: Used in the single-node-per-token architecture, where a node owns exactly one contiguous range in the ring space. Setting this property overrides num_tokens.
If you not using vnodes or have num_tokens set it to 1 or unspecified (#num_tokens), you should always specify this parameter when setting up a production cluster for the first time and when adding capacity. For more information, see this parameter in the Cassandra 1.1 Node and Cluster Configuration documentation.
This parameter can be used with num_tokens (vnodes) in special cases such as Restoring from a snapshot.
v2 config/num_tokens:
  GET: Defines the number of tokens randomly assigned to this node on the ring when using virtual nodes (vnodes). The more tokens, relative to other nodes, the larger the proportion of data that the node stores. Generally all nodes should have the same number of tokens assuming equal hardware capability. The recommended value is 256. If unspecified (#num_tokens), Scylla uses 1 (equivalent to #num_tokens : 1) for legacy compatibility and uses the initial_token setting.
If not using vnodes, comment #num_tokens : 256 or set num_tokens : 1 and use initial_token. If you already have an existing cluster with one token per node and wish to migrate to vnodes, see Enabling virtual nodes on an existing production cluster.

.. note:: If using DataStax Enterprise, the default setting of this property depends on the type of node and type of install.
v2 config/partitioner:
  GET: Distributes rows (by partition key) across all nodes in the cluster. At the moment, only Murmur3Partitioner is supported. For new clusters use the default partitioner.

Related information: Partitioners
v2 config/storage_port:
  GET: The port for inter-node communication.
v2 config/auto_snapshot:
  GET: Enable or disable whether a snapshot is taken of the data before keyspace truncation or dropping of tables. To prevent data loss, using the default setting is strongly advised. If you set to false, you will lose data on truncation or drop.
v2 config/key_cache_keys_to_save:
  GET: Number of keys from the key cache to save. (0: all)
v2 config/key_cache_save_period:
  GET: Duration in seconds that keys are saved in cache. Caches are saved to saved_caches_directory. Saved caches greatly improve cold-start speeds and has relatively little effect on I/O.
v2 config/key_cache_size_in_mb:
  GET: A global cache setting for tables. It is the maximum size of the key cache in memory. To disable set to 0.
Related information: nodetool setcachecapacity.
v2 config/row_cache_keys_to_save:
  GET: Number of keys from the row cache to save.
v2 config/row_cache_size_in_mb:
  GET: Maximum size of the row cache in memory. Row cache can save more time than key_cache_size_in_mb, but is space-intensive because it contains the entire row. Use the row cache only for hot rows or static rows. If you reduce the size, you may not get you hottest keys loaded on start up.
v2 config/row_cache_save_period:
  GET: Duration in seconds that rows are saved in cache. Caches are saved to saved_caches_directory.
v2 config/memory_allocator:
  GET: The off-heap memory allocator. In addition to caches, this property affects storage engine meta data. Supported values:
* NativeAllocator
* JEMallocAllocator

Experiments show that jemalloc saves some memory compared to the native allocator because it is more fragmentation resistant. To use, install jemalloc as a library and modify cassandra-env.sh (instructions in file).
v2 config/counter_cache_size_in_mb:
  GET: When no value is specified a minimum of 2.5% of Heap or 50MB. If you perform counter deletes and rely on low gc_grace_seconds, you should disable the counter cache. To disable, set to 0
v2 config/counter_cache_save_period:
  GET: Duration after which Cassandra should save the counter cache (keys only). Caches are saved to saved_caches_directory.
v2 config/counter_cache_keys_to_save:
  GET: Number of keys from the counter cache to save. When disabled all keys are saved.
v2 config/tombstone_warn_threshold:
  GET: The maximum number of tombstones a query can scan before warning.
v2 config/tombstone_failure_threshold:
  GET: The maximum number of tombstones a query can scan before aborting.
v2 config/query_tombstone_page_limit:
  GET: The number of tombstones after which a query cuts a page, even if not full or even empty.
v2 config/query_page_size_in_bytes:
  GET: The size of pages in bytes, after a page accumulates this much data, the page is cut and sent to the client. Setting a too large value increases the risk of OOM.
v2 config/range_request_timeout_in_ms:
  GET: The time in milliseconds that the coordinator waits for sequential or index scans to complete.
v2 config/read_request_timeout_in_ms:
  GET: The time that the coordinator waits for read operations to complete
v2 config/counter_write_request_timeout_in_ms:
  GET: The time that the coordinator waits for counter writes to complete.
v2 config/cas_contention_timeout_in_ms:
  GET: The time that the coordinator continues to retry a CAS (compare and set) operation that contends with other proposals for the same row.
v2 config/truncate_request_timeout_in_ms:
  GET: The time that the coordinator waits for truncates (remove all data from a table) to complete. The long default value allows for a snapshot to be taken before removing the data. If auto_snapshot is disabled (not recommended), you can reduce this time.
v2 config/write_request_timeout_in_ms:
  GET: The time in milliseconds that the coordinator waits for write operations to complete.

Related information: About hinted handoff writes
v2 config/request_timeout_in_ms:
  GET: The default timeout for other, miscellaneous operations.

Related information: About hinted handoff writes
v2 config/cross_node_timeout:
  GET: Enable or disable operation timeout information exchange between nodes (to accurately measure request timeouts). If disabled Cassandra assumes the request was forwarded to the replica instantly by the coordinator.
CAUTION:
Before enabling this property make sure NTP (network time protocol) is installed and the times are synchronized between the nodes.
v2 config/internode_send_buff_size_in_bytes:
  GET: Sets the sending socket buffer size in bytes for inter-node calls.
When setting this parameter and internode_recv_buff_size_in_bytes, the buffer size is limited by net.core.wmem_max. When unset, buffer size is defined by net.ipv4.tcp_wmem. See man tcp and:
* /proc/sys/net/core/wmem_max
* /proc/sys/net/core/rmem_max
* /proc/sys/net/ipv4/tcp_wmem
* /proc/sys/net/ipv4/tcp_wmem

v2 config/internode_recv_buff_size_in_bytes:
  GET: Sets the receiving socket buffer size in bytes for inter-node calls.
v2 config/internode_compression:
  GET: Controls whether traffic between nodes is compressed. The valid values are:
* all: All traffic is compressed.
* dc: Traffic between data centers is compressed.
* none: No compression.
v2 config/inter_dc_tcp_nodelay:
  GET: Enable or disable tcp_nodelay for inter-data center communication. When disabled larger, but fewer, network packets are sent. This reduces overhead from the TCP protocol itself. However, if cross data-center responses are blocked, it will increase latency.
v2 config/streaming_socket_timeout_in_ms:
  GET: Enable or disable socket timeout for streaming operations. When a timeout occurs during streaming, streaming is retried from the start of the current file. Avoid setting this value too low, as it can result in a significant amount of data re-streaming.
v2 config/start_native_transport:
  GET: Enable or disable the native transport server. Uses the same address as the rpc_address, but the port is different from the rpc_port. See native_transport_port.
v2 config/native_transport_port:
  GET: Port on which the CQL native transport listens for clients.
v2 config/maintenance_socket:
  GET: The Unix Domain Socket the node uses for maintenance socket.
The possible options are:
 ignore         the node will not open the maintenance socket.
 workdir        the node will open the maintenance socket on the path <scylla's workdir>/cql.m,
                where <scylla's workdir> is a path defined by the workdir configuration option
 <socket path>  the node will open the maintenance socket on the path <socket path>
v2 config/maintenance_socket_group:
  GET: The group that the maintenance socket will be owned by. If not set, the group will be the same as the user running the scylla node.
v2 config/maintenance_mode:
  GET: If set to true, the node will not connect to other nodes. It will only serve requests to its local data.
v2 config/native_transport_port_ssl:
  GET: Port on which the CQL TLS native transport listens for clients.Enabling client encryption and keeping native_transport_port_ssl disabled will use encryptionfor native_transport_port. Setting native_transport_port_ssl to a different valuefrom native_transport_port will use encryption for native_transport_port_ssl whilekeeping native_transport_port unencrypted.
v2 config/native_shard_aware_transport_port:
  GET: Like native_transport_port, but clients-side port number (modulo smp) is used to route the connection to the specific shard.
v2 config/native_shard_aware_transport_port_ssl:
  GET: Like native_transport_port_ssl, but clients-side port number (modulo smp) is used to route the connection to the specific shard.
v2 config/native_transport_max_threads:
  GET: The maximum number of thread handling requests. The meaning is the same as rpc_max_threads.
Default is different (128 versus unlimited).
No corresponding native_transport_min_threads.
Idle threads are stopped after 30 seconds.

v2 config/native_transport_max_frame_size_in_mb:
  GET: The maximum size of allowed frame. Frame (requests) larger than this are rejected as invalid.
v2 config/broadcast_rpc_address:
  GET: RPC address to broadcast to drivers and other Scylla nodes. This cannot be set to 0.0.0.0. If blank, it is set to the value of the rpc_address or rpc_interface. If rpc_address or rpc_interfaceis set to 0.0.0.0, this property must be set.

v2 config/rpc_port:
  GET: Thrift port for client connections.
v2 config/start_rpc:
  GET: Starts the Thrift RPC server
v2 config/rpc_keepalive:
  GET: Enable or disable keepalive on client connections (CQL native, Redis and the maintenance socket).
v2 config/cache_hit_rate_read_balancing:
  GET: This boolean controls whether the replicas for read query will be chosen based on cache hit ratio.
v2 config/dynamic_snitch_badness_threshold:
  GET: Sets the performance threshold for dynamically routing requests away from a poorly performing node. A value of 0.2 means Cassandra continues to prefer the static snitch values until the node response time is 20% worse than the best performing node. Until the threshold is reached, incoming client requests are statically routed to the closest replica (as determined by the snitch). Having requests consistently routed to a given replica can help keep a working set of data hot when read repair is less than 1.
v2 config/dynamic_snitch_reset_interval_in_ms:
  GET: Time interval in milliseconds to reset all node scores, which allows a bad node to recover.
v2 config/dynamic_snitch_update_interval_in_ms:
  GET: The time interval for how often the snitch calculates node scores. Because score calculation is CPU intensive, be careful when reducing this interval.
v2 config/hinted_handoff_enabled:
  GET: Enable or disable hinted handoff. To enable per data center, add data center list. For example: hinted_handoff_enabled: DC1,DC2. A hint indicates that the write needs to be replayed to an unavailable node.
Related information: About hinted handoff writes
v2 config/max_hinted_handoff_concurrency:
  GET: Maximum concurrency allowed for sending hints. The concurrency is divided across shards and rounded up if not divisible by the number of shards. By default (or when set to 0), concurrency of 8*shard_count will be used.
v2 config/hinted_handoff_throttle_in_kb:
  GET: Maximum throttle per delivery thread in kilobytes per second. This rate reduces proportionally to the number of nodes in the cluster. For example, if there are two nodes in the cluster, each delivery thread will use the maximum rate. If there are three, each node will throttle to half of the maximum, since the two nodes are expected to deliver hints simultaneously.
v2 config/max_hint_window_in_ms:
  GET: Maximum amount of time that hints are generates hints for an unresponsive node. After this interval, new hints are no longer generated until the node is back up and responsive. If the node goes down again, a new interval begins. This setting can prevent a sudden demand for resources when a node is brought back online and the rest of the cluster attempts to replay a large volume of hinted writes.

Related information: Failure detection and recovery
v2 config/max_hints_delivery_threads:
  GET: Number of threads with which to deliver hints. In multiple data-center deployments, consider increasing this number because cross data-center handoff is generally slower.
v2 config/batchlog_replay_throttle_in_kb:
  GET: Total maximum throttle. Throttling is reduced proportionally to the number of nodes in the cluster.
v2 config/request_scheduler:
  GET: Defines a scheduler to handle incoming client requests according to a defined policy. This scheduler is useful for throttling client requests in single clusters containing multiple keyspaces. This parameter is specifically for requests from the client and does not affect inter-node communication. Valid values are:
* org.apache.cassandra.scheduler.NoScheduler   No scheduling takes place.
* org.apache.cassandra.scheduler.RoundRobinScheduler   Round robin of client requests to a node with a separate queue for each request_scheduler_id property.
* A Java class that implements the RequestScheduler interface.
v2 config/request_scheduler_id:
  GET: An identifier on which to perform request scheduling. Currently the only valid value is keyspace. See weights.
v2 config/request_scheduler_options:
  GET: Contains a list of properties that define configuration options for request_scheduler:
* throttle_limit: The number of in-flight requests per client. Requests beyond this limit are queued up until running requests complete. Recommended value is ((concurrent_reads + concurrent_writes) × 2)
* default_weight: (Default: 1 **)  How many requests are handled during each turn of the RoundRobin.
* weights: (Default: Keyspace: 1)  Takes a list of keyspaces. It sets how many requests are handled during each turn of the RoundRobin, based on the request_scheduler_id.
v2 config/authenticator:
  GET: The authentication backend, used to identify users. The available authenticators are:
* org.apache.cassandra.auth.AllowAllAuthenticator: Disables authentication; no checks are performed.
* org.apache.cassandra.auth.PasswordAuthenticator: Authenticates users with user names and hashed passwords stored in the system_auth.credentials table. If you use the default, 1, and the node with the lone replica goes down, you will not be able to log into the cluster because the system_auth keyspace was not replicated.
* com.scylladb.auth.CertificateAuthenticator: Authenticates users based on TLS certificate authentication subject. Roles and permissions still need to be defined as normal. Super user can be set using the 'auth_superuser_name' configuration value. Query to extract role name from subject string is set using 'auth_certificate_role_queries'.
* com.scylladb.auth.TransitionalAuthenticator: Wraps around the PasswordAuthenticator, logging them in if username/password pair provided is correct and treating them as anonymous users otherwise.

Related information: Internal authentication
v2 config/internode_authenticator:
  GET: Internode authentication backend. It implements org.apache.cassandra.auth.AllowAllInternodeAuthenticator to allows or disallow connections from peer nodes.
v2 config/authorizer:
  GET: The authorization backend. It implements IAuthenticator, which limits access and provides permissions. The available authorizers are:
* AllowAllAuthorizer: Disables authorization; allows any action to any user.
* CassandraAuthorizer: Stores permissions in system_auth.permissions table. If you use the default, 1, and the node with the lone replica goes down, you will not be able to log into the cluster because the system_auth keyspace was not replicated.
* com.scylladb.auth.TransitionalAuthorizer: Wraps around the CassandraAuthorizer, which is used to authorize permission management. Other actions are allowed for all users.

Related information: Object permissions
v2 config/role_manager:
  GET: The role-management backend, used to maintain grants and memberships between roles.The available role-managers are:
* CassandraRoleManager: Stores role data in the system_auth keyspace.
v2 config/permissions_validity_in_ms:
  GET: How long permissions in cache remain valid. Depending on the authorizer, such as CassandraAuthorizer, fetching permissions can be resource intensive. Permissions caching is disabled when this property is set to 0 or when AllowAllAuthorizer is used. The cached value is considered valid as long as both its value is not older than the permissions_validity_in_ms and the cached value has been read at least once during the permissions_validity_in_ms time frame. If any of these two conditions doesn't hold the cached value is going to be evicted from the cache.

Related information: Object permissions
v2 config/permissions_update_interval_in_ms:
  GET: Refresh interval for permissions cache (if enabled). After this interval, cache entries become eligible for refresh. An async reload is scheduled every permissions_update_interval_in_ms time period and the old value is returned until it completes. If permissions_validity_in_ms has a non-zero value, then this property must also have a non-zero value. It's recommended to set this value to be at least 3 times smaller than the permissions_validity_in_ms.
v2 config/permissions_cache_max_entries:
  GET: Maximum cached permission entries. Must have a non-zero value if permissions caching is enabled (see a permissions_validity_in_ms description).
v2 config/server_encryption_options:
  GET: Enable or disable inter-node encryption. You must also generate keys and provide the appropriate key and trust store locations and passwords. The available options are:
* internode_encryption: (Default: none) Enable or disable encryption of inter-node communication using the TLS_RSA_WITH_AES_128_CBC_SHA cipher suite for authentication, key exchange, and encryption of data transfers. The available inter-node options are:
   * all: Encrypt all inter-node communications.
   * none: No encryption.
   * dc: Encrypt the traffic between the data centers (server only).
   * rack: Encrypt the traffic between the racks(server only).
* certificate: (Default: conf/scylla.crt) The location of a PEM-encoded x509 certificate used to identify and encrypt the internode communication.
* keyfile: (Default: conf/scylla.key) PEM Key file associated with certificate.
* truststore: (Default: <not set, use system truststore> ) Location of the truststore containing the trusted certificate for authenticating remote servers.
* certficate_revocation_list: (Default: <not set>) PEM encoded certificate revocation list.

The advanced settings are:

* priority_string: (Default: not set, use default) GnuTLS priority string controlling TLS algorithms used/allowed.
* require_client_auth: (Default: false ) Enables or disables certificate authentication.

Related information: Node-to-node encryption
v2 config/client_encryption_options:
  GET: Enable or disable client-to-node encryption. You must also generate keys and provide the appropriate key and certificate. The available options are:
* enabled: (Default: false) To enable, set to true.
* certificate: (Default: conf/scylla.crt) The location of a PEM-encoded x509 certificate used to identify and encrypt the client/server communication.
* keyfile: (Default: conf/scylla.key) PEM Key file associated with certificate.
* truststore: (Default: <not set. use system truststore>) Location of the truststore containing the trusted certificate for authenticating remote servers.
* certficate_revocation_list: (Default: <not set> ) PEM encoded certificate revocation list.

The advanced settings are:

* priority_string: (Default: not set, use default) GnuTLS priority string controlling TLS algorithms used/allowed.
* require_client_auth: (Default: false) Enables or disables certificate authentication.

Related information: Client-to-node encryption
v2 config/alternator_encryption_options:
  GET: When Alternator via HTTPS is enabled with alternator_https_port, where to take the key and certificate. The available options are:
* certificate: (Default: conf/scylla.crt) The location of a PEM-encoded x509 certificate used to identify and encrypt the client/server communication.
* keyfile: (Default: conf/scylla.key) PEM Key file associated with certificate.

The advanced settings are:

* priority_string: GnuTLS priority string controlling TLS algorithms used/allowed.
v2 config/ssl_storage_port:
  GET: The SSL port for encrypted communication. Unused unless enabled in encryption_options.
v2 config/enable_in_memory_data_store:
  GET: Enable in memory mode (system tables are always persisted).
v2 config/enable_cache:
  GET: Enable cache.
v2 config/enable_commitlog:
  GET: Enable commitlog.
v2 config/volatile_system_keyspace_for_testing:
  GET: Don't persist system keyspace - testing only!
v2 config/api_port:
  GET: Http Rest API port.
v2 config/api_address:
  GET: Http Rest API address.
v2 config/api_ui_dir:
  GET: The directory location of the API GUI.
v2 config/api_doc_dir:
  GET: The API definition file directory.
v2 config/load_balance:
  GET: CQL request load balancing: 'none' or round-robin.'
v2 config/consistent_rangemovement:
  GET: When set to true, range movements will be consistent. It means: 1) it will refuse to bootstrap a new node if other bootstrapping/leaving/moving nodes detected. 2) data will be streamed to a new node only from the node which is no longer responsible for the token range. Same as -Dcassandra.consistent.rangemovement in cassandra.
v2 config/join_ring:
  GET: When set to true, a node will join the token ring. When set to false, a node will not join the token ring. This option cannot be changed after a node joins the cluster. If set to false, it overwrites the num_tokens and initial_token options. Setting to false is supported only if the cluster uses the raft-managed topology.
v2 config/load_ring_state:
  GET: When set to true, load tokens and host_ids previously saved. Same as -Dcassandra.load_ring_state in cassandra.
v2 config/replace_node_first_boot:
  GET: The Host ID of a dead node to replace. If the replacing node has already been bootstrapped successfully, this option will be ignored.
v2 config/replace_address:
  GET: [[deprecated]] The listen_address or broadcast_address of the dead node to replace. Same as -Dcassandra.replace_address.
v2 config/replace_address_first_boot:
  GET: [[deprecated]] Like replace_address option, but if the node has been bootstrapped successfully it will be ignored. Same as -Dcassandra.replace_address_first_boot.
v2 config/ignore_dead_nodes_for_replace:
  GET: List dead nodes to ignore for replace operation using a comma-separated list of host IDs. E.g., scylla --ignore-dead-nodes-for-replace 8d5ed9f4-7764-4dbd-bad8-43fddce94b7c,125ed9f4-7777-1dbn-mac8-43fddce9123e
v2 config/override_decommission:
  GET: Set true to force a decommissioned node to join the cluster (cannot be set if consistent-cluster-management is enabled).
v2 config/enable_repair_based_node_ops:
  GET: Set true to use enable repair based node operations instead of streaming based.
v2 config/allowed_repair_based_node_ops:
  GET: A comma separated list of node operations which are allowed to enable repair based node operations. The operations can be bootstrap, replace, removenode, decommission and rebuild.
v2 config/enable_compacting_data_for_streaming_and_repair:
  GET: Enable the compacting reader, which compacts the data for streaming and repair (load'n'stream included) before sending it to, or synchronizing it with peers. Can reduce the amount of data to be processed by removing dead data, but adds CPU overhead.
v2 config/enable_tombstone_gc_for_streaming_and_repair:
  GET: If the compacting reader is enabled for streaming and repair (see enable_compacting_data_for_streaming_and_repair), allow it to garbage-collect tombstones. This can reduce the amount of data repair has to process.
v2 config/repair_partition_count_estimation_ratio:
  GET: Specify the fraction of partitions written by repair out of the total partitions. The value is currently only used for bloom filter estimation. Value is between 0 and 1.
v2 config/ring_delay_ms:
  GET: Time a node waits to hear from other nodes before joining the ring in milliseconds. Same as -Dcassandra.ring_delay_ms in cassandra.
v2 config/shadow_round_ms:
  GET: The maximum gossip shadow round time. Can be used to reduce the gossip feature check time during node boot up.
v2 config/fd_max_interval_ms:
  GET: The maximum failure_detector interval time in milliseconds. Interval larger than the maximum will be ignored. Larger cluster may need to increase the default.
v2 config/fd_initial_value_ms:
  GET: The initial failure_detector interval time in milliseconds.
v2 config/shutdown_announce_in_ms:
  GET: Time a node waits after sending gossip shutdown message in milliseconds. Same as -Dcassandra.shutdown_announce_in_ms in cassandra.
v2 config/developer_mode:
  GET: Relax environment checks. Setting to true can reduce performance and reliability significantly.
v2 config/skip_wait_for_gossip_to_settle:
  GET: An integer to configure the wait for gossip to settle. -1: wait normally, 0: do not wait at all, n: wait for at most n polls. Same as -Dcassandra.skip_wait_for_gossip_to_settle in cassandra.
v2 config/force_gossip_generation:
  GET: Force gossip to use the generation number provided by user.
v2 config/experimental_features:
  GET: Unlock experimental features provided as the option arguments (possible values: [''alternator-streams'', ''broadcast-tables'', ''keyspace-storage-options'', ''udf'']). Can be repeated.
v2 config/lsa_reclamation_step:
  GET: Minimum number of segments to reclaim in a single step.
v2 config/prometheus_port:
  GET: Prometheus port, set to zero to disable.
v2 config/prometheus_address:
  GET: Prometheus listening address, defaulting to listen_address if not explicitly set.
v2 config/prometheus_prefix:
  GET: Set the prefix of the exported Prometheus metrics. Changing this will break Scylla's dashboard compatibility, do not change unless you know what you are doing.
v2 config/prometheus_allow_protobuf:
  GET: If set allows the experimental Prometheus protobuf with native histogram
v2 config/abort_on_lsa_bad_alloc:
  GET: Abort when allocation in LSA region fails.
v2 config/murmur3_partitioner_ignore_msb_bits:
  GET: Number of most significant token bits to ignore in murmur3 partitioner; increase for very large clusters.
v2 config/unspooled_dirty_soft_limit:
  GET: Soft limit of unspooled dirty memory expressed as a portion of the hard limit.
v2 config/sstable_summary_ratio:
  GET: Enforces that 1 byte of summary is written for every N (2000 by default)bytes written to data file. Value must be between 0 and 1.
v2 config/components_memory_reclaim_threshold:
  GET: Ratio of available memory for all in-memory components of SSTables in a shard beyond which the memory will be reclaimed from components until it falls back under the threshold. Currently, this limit is only enforced for bloom filters.
v2 config/large_memory_allocation_warning_threshold:
  GET: Warn about memory allocations above this size; set to zero to disable.
v2 config/enable_deprecated_partitioners:
  GET: Enable the byteordered and random partitioners. These partitioners are deprecated and will be removed in a future version.
v2 config/enable_keyspace_column_family_metrics:
  GET: Enable per keyspace and per column family metrics reporting.
v2 config/enable_node_aggregated_table_metrics:
  GET: Enable aggregated per node, per keyspace and per table metrics reporting, applicable if enable_keyspace_column_family_metrics is false.
v2 config/enable_sstable_data_integrity_check:
  GET: Enable interposer which checks for integrity of every sstable write. Performance is affected to some extent as a result. Useful to help debugging problems that may arise at another layers.
v2 config/enable_sstable_key_validation:
  GET: Enable validation of partition and clustering keys monotonicity Performance is affected to some extent as a result. Useful to help debugging problems that may arise at another layers.
v2 config/cpu_scheduler:
  GET: Enable cpu scheduling.
v2 config/view_building:
  GET: Enable view building; should only be set to false when the node is experience issues due to view building.
v2 config/enable_sstables_mc_format:
  GET: Enable SSTables 'mc' format to be used as the default file format.  Deprecated, please use ''sstable_format'' instead.
v2 config/enable_sstables_md_format:
  GET: Enable SSTables 'md' format to be used as the default file format.  Deprecated, please use ''sstable_format'' instead.
v2 config/sstable_format:
  GET: Default sstable file format
v2 config/uuid_sstable_identifiers_enabled:
  GET: If set to true, each newly created sstable will have a UUID based generation identifier, and such files are not readable by previous Scylla versions.
v2 config/table_digest_insensitive_to_expiry:
  GET: When enabled, per-table schema digest calculation ignores empty partitions.
v2 config/enable_dangerous_direct_import_of_cassandra_counters:
  GET: Only turn this option on if you want to import tables from Cassandra containing counters, and you are SURE that no counters in that table were created in a version earlier than Cassandra 2.1. It is not enough to have ever since upgraded to newer versions of Cassandra. If you EVER used a version earlier than 2.1 in the cluster where these SSTables come from, DO NOT TURN ON THIS OPTION! You will corrupt your data. You have been warned.
v2 config/enable_shard_aware_drivers:
  GET: Enable native transport drivers to use connection-per-shard for better performance.
v2 config/enable_ipv6_dns_lookup:
  GET: Use IPv6 address resolution
v2 config/abort_on_internal_error:
  GET: Abort the server instead of throwing exception when internal invariants are violated.
v2 config/max_partition_key_restrictions_per_query:
  GET: Maximum number of distinct partition keys restrictions per query. This limit places a bound on the size of IN tuples, especially when multiple partition key columns have IN restrictions. Increasing this value can result in server instability.
v2 config/max_clustering_key_restrictions_per_query:
  GET: Maximum number of distinct clustering key restrictions per query. This limit places a bound on the size of IN tuples, especially when multiple clustering key columns have IN restrictions. Increasing this value can result in server instability.
v2 config/max_memory_for_unlimited_query_soft_limit:
  GET: Maximum amount of memory a query, whose memory consumption is not naturally limited, is allowed to consume, e.g. non-paged and reverse queries. This is the soft limit, there will be a warning logged for queries violating this limit.
v2 config/max_memory_for_unlimited_query_hard_limit:
  GET: Maximum amount of memory a query, whose memory consumption is not naturally limited, is allowed to consume, e.g. non-paged and reverse queries. This is the hard limit, queries violating this limit will be aborted.
v2 config/reader_concurrency_semaphore_serialize_limit_multiplier:
  GET: Start serializing reads after their collective memory consumption goes above $normal_limit * $multiplier.
v2 config/reader_concurrency_semaphore_kill_limit_multiplier:
  GET: Start killing reads after their collective memory consumption goes above $normal_limit * $multiplier.
v2 config/reader_concurrency_semaphore_cpu_concurrency:
  GET: Admit new reads while there are less than this number of requests that need CPU.
v2 config/maintenance_reader_concurrency_semaphore_count_limit:
  GET: Allow up to this many maintenance (e.g. streaming and repair) reads per shard to progress at the same time.
v2 config/twcs_max_window_count:
  GET: The maximum number of compaction windows allowed when making use of TimeWindowCompactionStrategy. A setting of 0 effectively disables the restriction.
v2 config/initial_sstable_loading_concurrency:
  GET: Maximum amount of sstables to load in parallel during initialization. A higher number can lead to more memory consumption. You should not need to touch this.
v2 config/enable_3_1_0_compatibility_mode:
  GET: Set to true if the cluster was initially installed from 3.1.0. If it was upgraded from an earlier version, or installed from a later version, leave this set to false. This adjusts the communication protocol to work around a bug in Scylla 3.1.0.
v2 config/enable_user_defined_functions:
  GET: Enable user defined functions. You must also set ``experimental-features=udf``.
v2 config/user_defined_function_time_limit_ms:
  GET: The time limit for each UDF invocation.
v2 config/user_defined_function_allocation_limit_bytes:
  GET: How much memory each UDF invocation can allocate.
v2 config/user_defined_function_contiguous_allocation_limit_bytes:
  GET: How much memory each UDF invocation can allocate in one chunk.
v2 config/schema_registry_grace_period:
  GET: Time period in seconds after which unused schema versions will be evicted from the local schema registry cache. Default is 1 second.
v2 config/max_concurrent_requests_per_shard:
  GET: Maximum number of concurrent requests a single shard can handle before it starts shedding extra load. By default, no requests will be shed.
v2 config/cdc_dont_rewrite_streams:
  GET: Disable rewriting streams from cdc_streams_descriptions to cdc_streams_descriptions_v2. Should not be necessary, but the procedure is expensive and prone to failures; this config option is left as a backdoor in case some user requires manual intervention.
v2 config/strict_allow_filtering:
  GET: Match Cassandra in requiring ALLOW FILTERING on slow queries. Can be true, false, or warn. When false, Scylla accepts some slow queries even without ALLOW FILTERING that Cassandra rejects. Warn is same as false, but with warning.
v2 config/strict_is_not_null_in_views:
  GET: In materialized views, restrictions are allowed only on the view's primary key columns.
In old versions Scylla mistakenly allowed IS NOT NULL restrictions on columns which were not part of the view's primary key. These invalid restrictions were ignored.
This option controls the behavior when someone tries to create a view with such invalid IS NOT NULL restrictions.

Can be true, false, or warn:
 * `true`: IS NOT NULL is allowed only on the view's primary key columns, trying to use it on other columns will cause an error, as it should.
 * `false`: Scylla accepts IS NOT NULL restrictions on regular columns, but they're silently ignored. It's useful for backwards compatibility.
 * `warn`: The same as false, but there's a warning about invalid view restrictions.

To preserve backwards compatibility on old clusters, Scylla's default setting is `warn`. New clusters have this option set to `true` by scylla.yaml (which overrides the default `warn`), to make sure that trying to create an invalid view causes an error.
v2 config/enable_cql_config_updates:
  GET: Make the system.config table UPDATEable.
v2 config/enable_parallelized_aggregation:
  GET: Use on a new, parallel algorithm for performing aggregate queries.
v2 config/cql_duplicate_bind_variable_names_refer_to_same_variable:
  GET: A bind variable that appears twice in a CQL query refers to a single variable (if false, no name matching is performed).
v2 config/alternator_port:
  GET: Alternator API port.
v2 config/alternator_https_port:
  GET: Alternator API HTTPS port.
v2 config/alternator_address:
  GET: Alternator API listening address.
v2 config/alternator_enforce_authorization:
  GET: Enforce checking the authorization header for every request in Alternator.
v2 config/alternator_write_isolation:
  GET: Default write isolation policy for Alternator.
v2 config/alternator_streams_time_window_s:
  GET: CDC query confidence window for alternator streams.
v2 config/alternator_timeout_in_ms:
  GET: The server-side timeout for completing Alternator API requests.
v2 config/alternator_ttl_period_in_seconds:
  GET: The default period for Alternator's expiration scan. Alternator attempts to scan every table within that period.
v2 config/alternator_describe_endpoints:
  GET: Overrides the behavior of Alternator's DescribeEndpoints operation. An empty value (the default) means DescribeEndpoints will return the same endpoint used in the request. The string 'disabled' disables the DescribeEndpoints operation. Any other string is the fixed value that will be returned by DescribeEndpoints operations.
v2 config/abort_on_ebadf:
  GET: Abort the server on incorrect file descriptor access. Throws exception when disabled.
v2 config/redis_port:
  GET: Port on which the REDIS transport listens for clients.
v2 config/redis_ssl_port:
  GET: Port on which the REDIS TLS native transport listens for clients.
v2 config/redis_read_consistency_level:
  GET: Consistency level for read operations for redis.
v2 config/redis_write_consistency_level:
  GET: Consistency level for write operations for redis.
v2 config/redis_database_count:
  GET: Database count for the redis. You can use the default settings (16).
v2 config/redis_keyspace_replication_strategy:
  GET: Set the replication strategy for the redis keyspace. The setting is used by the first node in the boot phase when the keyspace is not exists to create keyspace for redis.
The replication strategy determines how many copies of the data are kept in a given data center. This setting impacts consistency, availability and request speed.
Two strategies are available: SimpleStrategy and NetworkTopologyStrategy.

* class: (Default: SimpleStrategy ). Set the replication strategy for redis keyspace.
* 'replication_factor': N, (Default: 'replication_factor':1) IFF the class is SimpleStrategy, assign the same replication factor to the entire cluster.
* 'datacenter_name': N [,...], (Default: 'dc1:1') IFF the class is NetworkTopologyStrategy, assign replication factors to each data center in a comma separated list.

Related information: About replication strategy.
v2 config/sanitizer_report_backtrace:
  GET: In debug mode, report log-structured allocator sanitizer violations with a backtrace. Slow.
v2 config/flush_schema_tables_after_modification:
  GET: Flush tables in the system_schema keyspace after schema modification. This is required for crash recovery, but slows down tests and can be disabled for them
v2 config/restrict_replication_simplestrategy:
  GET: Controls whether to disable SimpleStrategy replication. Can be true, false, or warn.
v2 config/restrict_dtcs:
  GET: Controls whether to prevent setting DateTieredCompactionStrategy. Can be true, false, or warn.
v2 config/restrict_twcs_without_default_ttl:
  GET: Controls whether to prevent creating TimeWindowCompactionStrategy tables without a default TTL. Can be true, false, or warn.
v2 config/restrict_future_timestamp:
  GET: Controls whether to detect and forbid unreasonable USING TIMESTAMP, more than 3 days into the future.
v2 config/unsafe_ignore_truncation_record:
  GET: Ignore truncation record stored in system tables as if tables were never truncated.
v2 config/force_schema_commit_log:
  GET: Use separate schema commit log unconditionally rater than after restart following discovery of cluster-wide support for it.
v2 config/task_ttl_in_seconds:
  GET: Time for which information about finished task stays in memory.
v2 config/nodeops_watchdog_timeout_seconds:
  GET: Time in seconds after which node operations abort when not hearing from the coordinator.
v2 config/nodeops_heartbeat_interval_seconds:
  GET: Period of heartbeat ticks in node operations.
v2 config/cache_index_pages:
  GET: Keep SSTable index pages in the global cache after a SSTable read. Expected to improve performance for workloads with big partitions, but may degrade performance for workloads with small partitions. The amount of memory usable by index cache is limited with ``index_cache_fraction``.
v2 config/index_cache_fraction:
  GET: The maximum fraction of cache memory permitted for use by index cache. Clamped to the [0.0; 1.0] range. Must be small enough to not deprive the row cache of memory, but should be big enough to fit a large fraction of the index. The default value 0.2 means that at least 80% of cache memory is reserved for the row cache, while at most 20% is usable by the index cache.
v2 config/consistent_cluster_management:
  GET: Use RAFT for cluster management and DDL.
v2 config/force_gossip_topology_changes:
  GET: Force gossip-based topology operations in a fresh cluster. Only the first node in the cluster must use it. The rest will fall back to gossip-based operations anyway. This option should be used only for testing.
v2 config/wasm_cache_memory_fraction:
  GET: Maximum total size of all WASM instances stored in the cache as fraction of total shard memory.
v2 config/wasm_cache_timeout_in_ms:
  GET: Time after which an instance is evicted from the cache.
v2 config/wasm_cache_instance_size_limit:
  GET: Instances with size above this limit will not be stored in the cache.
v2 config/wasm_udf_yield_fuel:
  GET: Wasmtime fuel a WASM UDF can consume before yielding.
v2 config/wasm_udf_total_fuel:
  GET: Wasmtime fuel a WASM UDF can consume before termination.
v2 config/wasm_udf_memory_limit:
  GET: How much memory each WASM UDF can allocate at most.
v2 config/relabel_config_file:
  GET: Optionally, read relabel config from file.
v2 config/object_storage_config_file:
  GET: Optionally, read object-storage endpoints config from file.
v2 config/live_updatable_config_params_changeable_via_cql:
  GET: If set to true, configuration parameters defined with LiveUpdate can be updated in runtime via CQL (by updating system.config virtual table), otherwise they can't.
v2 config/auth_superuser_name:
  GET: Initial authentication super username. Ignored if authentication tables already contain a super user.
v2 config/auth_superuser_salted_password:
  GET: Initial authentication super user salted password. Create using mkpassword or similar. The hashing algorithm used must be available on the node host. Ignored if authentication tables already contain a super user password.
v2 config/auth_certificate_role_queries:
  GET: Regular expression used by CertificateAuthenticator to extract role name from an accepted transport authentication certificate subject info.
v2 config/minimum_replication_factor_fail_threshold:
  GET:
v2 config/minimum_replication_factor_warn_threshold:
  GET:
v2 config/maximum_replication_factor_warn_threshold:
  GET:
v2 config/maximum_replication_factor_fail_threshold:
  GET:
v2 config/tablets_initial_scale_factor:
  GET: Calculated initial tablets are multiplied by this number
v2 config/target_tablet_size_in_bytes:
  GET: Allows target tablet size to be configured. Defaults to 5G (in bytes). Maintaining tablets at reasonable sizes is important to be able to redistribute load. A higher value means tablet migration throughput can be reduced. A lower value may cause number of tablets to increase significantly, potentially resulting in performance drawbacks.
v2 config/replication_strategy_warn_list:
  GET: Controls which replication strategies to warn about when creating/altering a keyspace. Doesn't affect the pre-existing keyspaces.
v2 config/replication_strategy_fail_list:
  GET: Controls which replication strategies are disallowed to be used when creating/altering a keyspace. Doesn't affect the pre-existing keyspaces.
v2 config/service_levels_interval_ms:
  GET: Controls how often service levels module polls configuration table
v2 config/error_injections_at_startup:
  GET: List of error injections that should be enabled on startup.
v2 config/topology_barrier_stall_detector_threshold_seconds:
  GET: Report sites blocking topology barrier if it takes longer than this.
v2 config/enable_tablets:
  GET: Enable tablets for newly created keyspaces
v2 config/default_log_level:
  GET: Default log level for log messages
v2 config/logger_log_level:
  GET: Map of logger name to log level. Valid log levels are 'error', 'warn', 'info', 'debug' and 'trace'
v2 config/log_to_stdout:
  GET: Send log output to stdout
v2 config/log_to_syslog:
  GET: Send log output to syslog
GeoffMontee commented 3 days ago

It seems to work:

root@f1cecb40536c:~/scylla-api-client# /usr/local/bin/scylla-api-client v2 config/stream_io_throughput_mb_per_sec GET
0