public class Config
extends java.lang.Object
Modifier and Type | Class and Description |
---|---|
static class |
Config.CommitFailurePolicy |
static class |
Config.CommitLogSync |
static class |
Config.CorruptedTombstoneStrategy |
static class |
Config.DiskAccessMode |
static class |
Config.DiskFailurePolicy |
static class |
Config.DiskOptimizationStrategy |
static class |
Config.FlushCompression |
static class |
Config.InternodeCompression |
static class |
Config.MemtableAllocationType |
static class |
Config.MemtableOptions |
static class |
Config.PaxosOnLinearizabilityViolation
A safety mechanism for detecting incorrect paxos state, that may be down either to a bug or incorrect usage of LWTs
(most likely due to unsafe mixing of SERIAL and LOCAL_SERIAL operations), and rejecting
|
static class |
Config.PaxosStatePurging
Select the kind of paxos state purging to use.
|
static class |
Config.PaxosVariant
The variants of paxos implementation and semantics supported by Cassandra.
|
static class |
Config.RepairCommandPoolFullStrategy |
static class |
Config.UserFunctionTimeoutPolicy |
Constructor and Description |
---|
Config() |
Modifier and Type | Method and Description |
---|---|
static java.util.function.Supplier<Config> |
getOverrideLoadConfig() |
static boolean |
isClientMode()
Deprecated.
migrate to
DatabaseDescriptor.isClientInitialized() |
static void |
log(Config config) |
static void |
setClientMode(boolean clientMode)
Deprecated.
|
static void |
setOverrideLoadConfig(java.util.function.Supplier<Config> loadConfig) |
static java.util.Set<java.lang.String> |
splitCommaDelimited(java.lang.String src) |
public static final java.lang.String PROPERTY_PREFIX
public java.lang.String cluster_name
public java.lang.String authenticator
public java.lang.String authorizer
public java.lang.String role_manager
public java.lang.String network_authorizer
public volatile DurationSpec.IntMillisecondsBound permissions_validity
public volatile int permissions_cache_max_entries
public volatile DurationSpec.IntMillisecondsBound permissions_update_interval
public volatile boolean permissions_cache_active_update
public volatile DurationSpec.IntMillisecondsBound roles_validity
public volatile int roles_cache_max_entries
public volatile DurationSpec.IntMillisecondsBound roles_update_interval
public volatile boolean roles_cache_active_update
public volatile DurationSpec.IntMillisecondsBound credentials_validity
public volatile int credentials_cache_max_entries
public volatile DurationSpec.IntMillisecondsBound credentials_update_interval
public volatile boolean credentials_cache_active_update
public java.lang.String partitioner
public boolean auto_bootstrap
public volatile boolean hinted_handoff_enabled
public java.util.Set<java.lang.String> hinted_handoff_disabled_datacenters
public volatile DurationSpec.IntMillisecondsBound max_hint_window
public java.lang.String hints_directory
public boolean hint_window_persistent_enabled
public volatile boolean force_new_prepared_statement_behaviour
public ParameterizedClass seed_provider
public Config.DiskAccessMode disk_access_mode
public Config.DiskFailurePolicy disk_failure_policy
public Config.CommitFailurePolicy commit_failure_policy
public volatile boolean use_deterministic_table_id
public java.lang.String initial_token
public java.lang.Integer num_tokens
public java.lang.String allocate_tokens_for_keyspace
public java.lang.Integer allocate_tokens_for_local_replication_factor
public DurationSpec.LongMillisecondsBound native_transport_idle_timeout
public volatile DurationSpec.LongMillisecondsBound request_timeout
public volatile DurationSpec.LongMillisecondsBound read_request_timeout
public volatile DurationSpec.LongMillisecondsBound range_request_timeout
public volatile DurationSpec.LongMillisecondsBound write_request_timeout
public volatile DurationSpec.LongMillisecondsBound counter_write_request_timeout
public volatile DurationSpec.LongMillisecondsBound cas_contention_timeout
public volatile DurationSpec.LongMillisecondsBound truncate_request_timeout
public volatile DurationSpec.LongMillisecondsBound repair_request_timeout
public java.lang.Integer streaming_connections_per_host
public DurationSpec.IntSecondsBound streaming_keep_alive_period
public boolean internode_timeout
public volatile DurationSpec.LongMillisecondsBound slow_query_log_timeout
public volatile double phi_convict_threshold
public int concurrent_reads
public int concurrent_writes
public int concurrent_counter_writes
public int concurrent_materialized_view_writes
public int available_processors
@Deprecated public java.lang.Integer concurrent_replicates
public int memtable_flush_writers
public DataStorageSpec.IntMebibytesBound memtable_heap_space
public DataStorageSpec.IntMebibytesBound memtable_offheap_space
public java.lang.Float memtable_cleanup_threshold
public Config.MemtableOptions memtable
@Deprecated public volatile java.lang.Integer repair_session_max_tree_depth
public volatile DataStorageSpec.IntMebibytesBound repair_session_space
public volatile boolean use_offheap_merkle_trees
public int storage_port
public int ssl_storage_port
public java.lang.String listen_address
public java.lang.String listen_interface
public boolean listen_interface_prefer_ipv6
public java.lang.String broadcast_address
public boolean listen_on_broadcast_address
public java.lang.String internode_authenticator
public boolean traverse_auth_from_root
public java.lang.String rpc_address
public java.lang.String rpc_interface
public boolean rpc_interface_prefer_ipv6
public java.lang.String broadcast_rpc_address
public boolean rpc_keepalive
public DataStorageSpec.IntBytesBound internode_max_message_size
public DataStorageSpec.IntBytesBound internode_socket_send_buffer_size
public DataStorageSpec.IntBytesBound internode_socket_receive_buffer_size
public DataStorageSpec.IntBytesBound internode_application_send_queue_capacity
public DataStorageSpec.IntBytesBound internode_application_send_queue_reserve_endpoint_capacity
public DataStorageSpec.IntBytesBound internode_application_send_queue_reserve_global_capacity
public DataStorageSpec.IntBytesBound internode_application_receive_queue_capacity
public DataStorageSpec.IntBytesBound internode_application_receive_queue_reserve_endpoint_capacity
public DataStorageSpec.IntBytesBound internode_application_receive_queue_reserve_global_capacity
public volatile DurationSpec.IntMillisecondsBound internode_tcp_connect_timeout
public volatile DurationSpec.IntMillisecondsBound internode_tcp_user_timeout
public volatile DurationSpec.IntMillisecondsBound internode_streaming_tcp_user_timeout
public boolean start_native_transport
public int native_transport_port
public java.lang.Integer native_transport_port_ssl
public int native_transport_max_threads
public DataStorageSpec.IntMebibytesBound native_transport_max_frame_size
public volatile long native_transport_max_concurrent_connections
public volatile long native_transport_max_concurrent_connections_per_ip
public boolean native_transport_flush_in_batches_legacy
public volatile boolean native_transport_allow_older_protocols
public volatile DataStorageSpec.LongBytesBound native_transport_max_request_data_in_flight_per_ip
public volatile DataStorageSpec.LongBytesBound native_transport_max_request_data_in_flight
public volatile boolean native_transport_rate_limiting_enabled
public volatile int native_transport_max_requests_per_second
public DataStorageSpec.IntBytesBound native_transport_receive_queue_capacity
@Deprecated public java.lang.Integer native_transport_max_negotiable_protocol_version
public DataStorageSpec.IntMebibytesBound max_value_size
public boolean snapshot_before_compaction
public boolean auto_snapshot
public java.lang.String auto_snapshot_ttl
public volatile long snapshot_links_per_second
public volatile DataStorageSpec.IntKibibytesBound column_index_size
public volatile DataStorageSpec.IntKibibytesBound column_index_cache_size
public volatile DataStorageSpec.IntKibibytesBound batch_size_warn_threshold
public volatile DataStorageSpec.IntKibibytesBound batch_size_fail_threshold
public java.lang.Integer unlogged_batch_across_partitions_warn_threshold
public volatile java.lang.Integer concurrent_compactors
public volatile DataRateSpec.LongBytesPerSecondBound compaction_throughput
public volatile DataStorageSpec.IntMebibytesBound compaction_large_partition_warning_threshold
public DataStorageSpec.IntMebibytesBound min_free_space_per_drive
public volatile java.lang.Integer compaction_tombstone_warning_threshold
public volatile int concurrent_materialized_view_builders
public volatile int reject_repair_compaction_threshold
@Deprecated public int max_streaming_retries
public volatile DataRateSpec.LongBytesPerSecondBound stream_throughput_outbound
public volatile DataRateSpec.LongBytesPerSecondBound inter_dc_stream_throughput_outbound
public volatile DataRateSpec.LongBytesPerSecondBound entire_sstable_stream_throughput_outbound
public volatile DataRateSpec.LongBytesPerSecondBound entire_sstable_inter_dc_stream_throughput_outbound
public java.lang.String[] data_file_directories
public java.lang.String local_system_data_file_directory
public java.lang.String saved_caches_directory
public java.lang.String commitlog_directory
public DataStorageSpec.IntMebibytesBound commitlog_total_space
public Config.CommitLogSync commitlog_sync
public double commitlog_sync_batch_window_in_ms
public DurationSpec.IntMillisecondsBound commitlog_sync_group_window
public DurationSpec.IntMillisecondsBound commitlog_sync_period
public DataStorageSpec.IntMebibytesBound commitlog_segment_size
public ParameterizedClass commitlog_compression
public Config.FlushCompression flush_compression
public int commitlog_max_compression_buffers_in_pool
public DurationSpec.IntMillisecondsBound periodic_commitlog_sync_lag_block
public TransparentDataEncryptionOptions transparent_data_encryption_options
public DataStorageSpec.IntKibibytesBound max_mutation_size
public boolean cdc_enabled
public volatile boolean cdc_block_writes
public java.lang.String cdc_raw_directory
public DataStorageSpec.IntMebibytesBound cdc_total_space
public DurationSpec.IntMillisecondsBound cdc_free_space_check_interval
@Deprecated public int commitlog_periodic_queue_size
public java.lang.String endpoint_snitch
public boolean dynamic_snitch
public DurationSpec.IntMillisecondsBound dynamic_snitch_update_interval
public DurationSpec.IntMillisecondsBound dynamic_snitch_reset_interval
public double dynamic_snitch_badness_threshold
public java.lang.String failure_detector
public EncryptionOptions.ServerEncryptionOptions server_encryption_options
public EncryptionOptions client_encryption_options
public Config.InternodeCompression internode_compression
public DataStorageSpec.IntKibibytesBound hinted_handoff_throttle
public DataStorageSpec.IntKibibytesBound batchlog_replay_throttle
public int max_hints_delivery_threads
public DurationSpec.IntMillisecondsBound hints_flush_period
public DataStorageSpec.IntMebibytesBound max_hints_file_size
public volatile DataStorageSpec.LongBytesBound max_hints_size_per_host
public ParameterizedClass hints_compression
public volatile boolean auto_hints_cleanup_enabled
public volatile boolean incremental_backups
public boolean trickle_fsync
public DataStorageSpec.IntKibibytesBound trickle_fsync_interval
@Nullable public volatile DataStorageSpec.IntMebibytesBound sstable_preemptive_open_interval
public volatile boolean key_cache_migrate_during_compaction
public volatile int key_cache_keys_to_save
public DataStorageSpec.LongMebibytesBound key_cache_size
public volatile DurationSpec.IntSecondsBound key_cache_save_period
public java.lang.String row_cache_class_name
public DataStorageSpec.LongMebibytesBound row_cache_size
public volatile DurationSpec.IntSecondsBound row_cache_save_period
public volatile int row_cache_keys_to_save
public DataStorageSpec.LongMebibytesBound counter_cache_size
public volatile DurationSpec.IntSecondsBound counter_cache_save_period
public volatile int counter_cache_keys_to_save
public DataStorageSpec.LongMebibytesBound paxos_cache_size
public DurationSpec.IntSecondsBound cache_load_timeout
public DataStorageSpec.IntMebibytesBound networking_cache_size
public DataStorageSpec.IntMebibytesBound file_cache_size
public boolean file_cache_enabled
public java.lang.Boolean file_cache_round_up
BufferPool
slab sizes of 64 KiB, we
store in the file cache buffers that divide 64 KiB, so we need to round the buffer sizes to powers of two.
This boolean controls weather they are rounded up or down. Set it to true to round up to the
next power of two, set it to false to round down to the previous power of two. Note that buffer sizes are
already rounded to 4 KiB and capped between 4 KiB minimum and 64 kb maximum by the Config.DiskOptimizationStrategy
.
By default, this boolean is set to round down when disk_optimization_strategy
is ssd
,
and to round up when it is spinning
.@Deprecated public boolean buffer_pool_use_heap_if_exhausted
public Config.DiskOptimizationStrategy disk_optimization_strategy
public double disk_optimization_estimate_percentile
public double disk_optimization_page_cross_chance
public boolean inter_dc_tcp_nodelay
public Config.MemtableAllocationType memtable_allocation_type
public volatile boolean read_thresholds_enabled
public volatile DataStorageSpec.LongBytesBound coordinator_read_size_warn_threshold
public volatile DataStorageSpec.LongBytesBound coordinator_read_size_fail_threshold
public volatile DataStorageSpec.LongBytesBound local_read_size_warn_threshold
public volatile DataStorageSpec.LongBytesBound local_read_size_fail_threshold
public volatile DataStorageSpec.LongBytesBound row_index_read_size_warn_threshold
public volatile DataStorageSpec.LongBytesBound row_index_read_size_fail_threshold
public volatile int tombstone_warn_threshold
public volatile int tombstone_failure_threshold
public final ReplicaFilteringProtectionOptions replica_filtering_protection
public volatile DataStorageSpec.LongMebibytesBound index_summary_capacity
@Nullable public volatile DurationSpec.IntMinutesBound index_summary_resize_interval
public volatile DurationSpec.IntMillisecondsBound gc_log_threshold
public volatile DurationSpec.IntMillisecondsBound gc_warn_threshold
public DurationSpec.IntSecondsBound trace_type_query_ttl
public DurationSpec.IntSecondsBound trace_type_repair_ttl
public volatile ConsistencyLevel ideal_consistency_level
@Deprecated public int windows_timer_interval
@Deprecated public java.lang.String otc_coalescing_strategy
@Deprecated public static final int otc_coalescing_window_us_default
@Deprecated public int otc_coalescing_window_us
@Deprecated public int otc_coalescing_enough_coalesced_messages
@Deprecated public static final int otc_backlog_expiration_interval_ms_default
@Deprecated public volatile int otc_backlog_expiration_interval_ms
public DataStorageSpec.LongMebibytesBound prepared_statements_cache_size
public boolean user_defined_functions_enabled
public boolean scripted_user_defined_functions_enabled
public boolean materialized_views_enabled
public boolean transient_replication_enabled
public boolean sasi_indexes_enabled
public volatile boolean drop_compact_storage_enabled
public volatile boolean use_statements_enabled
public boolean user_defined_functions_threads_enabled
public boolean allow_insecure_udfs
public boolean allow_extra_insecure_udfs
public DurationSpec.LongMillisecondsBound user_defined_functions_warn_timeout
public DurationSpec.LongMillisecondsBound user_defined_functions_fail_timeout
public Config.UserFunctionTimeoutPolicy user_function_timeout_policy
@Deprecated public volatile boolean back_pressure_enabled
@Deprecated public volatile ParameterizedClass back_pressure_strategy
public volatile int concurrent_validations
public Config.RepairCommandPoolFullStrategy repair_command_pool_full_strategy
public int repair_command_pool_size
public int block_for_peers_timeout_in_secs
public boolean block_for_peers_in_remote_dcs
public volatile boolean automatic_sstable_upgrade
public volatile int max_concurrent_automatic_sstable_upgrades
public boolean stream_entire_sstables
public volatile AuditLogOptions audit_logging_options
public volatile FullQueryLoggerOptions full_query_logging_options
public Config.CorruptedTombstoneStrategy corrupted_tombstone_strategy
public volatile boolean diagnostic_events_enabled
public volatile int default_keyspace_rf
public volatile boolean repaired_data_tracking_for_range_reads_enabled
public volatile boolean repaired_data_tracking_for_partition_reads_enabled
public volatile boolean report_unconfirmed_repaired_data_mismatches
public volatile boolean snapshot_on_repaired_data_mismatch
public volatile DurationSpec.IntSecondsBound validation_preview_purge_head_start
public boolean auth_cache_warming_enabled
public volatile java.lang.String auth_read_consistency_level
public volatile java.lang.String auth_write_consistency_level
public volatile boolean partition_denylist_enabled
public volatile boolean denylist_writes_enabled
public volatile boolean denylist_reads_enabled
public volatile boolean denylist_range_reads_enabled
public DurationSpec.IntSecondsBound denylist_refresh
public DurationSpec.IntSecondsBound denylist_initial_load_retry
public volatile int denylist_max_keys_per_table
public volatile int denylist_max_keys_total
public ConsistencyLevel denylist_consistency_level
public volatile int initial_range_tombstone_list_allocation_size
public volatile double range_tombstone_list_growth_factor
public volatile boolean snapshot_on_duplicate_row_detection
public volatile boolean check_for_duplicate_rows_during_reads
public volatile boolean check_for_duplicate_rows_during_compaction
public boolean autocompaction_on_startup_enabled
public volatile boolean auto_optimise_inc_repair_streams
public volatile boolean auto_optimise_full_repair_streams
public volatile boolean auto_optimise_preview_repair_streams
public boolean uuid_sstable_identifiers_enabled
@Deprecated public volatile int table_count_warn_threshold
@Deprecated public volatile int keyspace_count_warn_threshold
public volatile int consecutive_message_errors_threshold
public volatile SubnetGroups client_error_reporting_exclusions
public volatile SubnetGroups internode_error_reporting_exclusions
public volatile int keyspaces_warn_threshold
public volatile int keyspaces_fail_threshold
public volatile int tables_warn_threshold
public volatile int tables_fail_threshold
public volatile int columns_per_table_warn_threshold
public volatile int columns_per_table_fail_threshold
public volatile int secondary_indexes_per_table_warn_threshold
public volatile int secondary_indexes_per_table_fail_threshold
public volatile int materialized_views_per_table_warn_threshold
public volatile int materialized_views_per_table_fail_threshold
public volatile int page_size_warn_threshold
public volatile int page_size_fail_threshold
public volatile int partition_keys_in_select_warn_threshold
public volatile int partition_keys_in_select_fail_threshold
public volatile int in_select_cartesian_product_warn_threshold
public volatile int in_select_cartesian_product_fail_threshold
public volatile java.util.Set<java.lang.String> table_properties_warned
public volatile java.util.Set<java.lang.String> table_properties_ignored
public volatile java.util.Set<java.lang.String> table_properties_disallowed
public volatile java.util.Set<ConsistencyLevel> read_consistency_levels_warned
public volatile java.util.Set<ConsistencyLevel> read_consistency_levels_disallowed
public volatile java.util.Set<ConsistencyLevel> write_consistency_levels_warned
public volatile java.util.Set<ConsistencyLevel> write_consistency_levels_disallowed
public volatile boolean user_timestamps_enabled
public volatile boolean group_by_enabled
public volatile boolean drop_truncate_table_enabled
public volatile boolean secondary_indexes_enabled
public volatile boolean uncompressed_tables_enabled
public volatile boolean compact_tables_enabled
public volatile boolean read_before_write_list_operations_enabled
public volatile boolean allow_filtering_enabled
public volatile DataStorageSpec.LongBytesBound collection_size_warn_threshold
public volatile DataStorageSpec.LongBytesBound collection_size_fail_threshold
public volatile int items_per_collection_warn_threshold
public volatile int items_per_collection_fail_threshold
public volatile int fields_per_udt_warn_threshold
public volatile int fields_per_udt_fail_threshold
public volatile int data_disk_usage_percentage_warn_threshold
public volatile int data_disk_usage_percentage_fail_threshold
public volatile DataStorageSpec.LongBytesBound data_disk_usage_max_disk_size
public volatile int minimum_replication_factor_warn_threshold
public volatile int minimum_replication_factor_fail_threshold
public volatile DurationSpec.LongNanosecondsBound streaming_state_expires
public volatile DataStorageSpec.LongBytesBound streaming_state_size
public volatile boolean streaming_stats_enabled
public volatile DurationSpec.IntSecondsBound streaming_slow_events_log_timeout
public volatile java.util.Map<StartupChecks.StartupCheckType,java.util.Map<java.lang.String,java.lang.Object>> startup_checks
public volatile DurationSpec.LongNanosecondsBound repair_state_expires
public volatile int repair_state_size
public volatile Config.PaxosVariant paxos_variant
Config.PaxosVariant
. Defaults to v1, recommend upgrading to v2 at earliest opportunity.public volatile boolean skip_paxos_repair_on_topology_change
public volatile DurationSpec.LongSecondsBound paxos_purge_grace_period
public volatile Config.PaxosOnLinearizabilityViolation paxos_on_linearizability_violations
Config.PaxosOnLinearizabilityViolation
.
Default is to ignore, as applications may readily mix SERIAL and LOCAL_SERIAL and this is the most likely source
of linearizability violations. this facility should be activated only for debugging Cassandra or by power users
who are investigating their own application behaviour.public volatile Config.PaxosStatePurging paxos_state_purging
Config.PaxosStatePurging
default is legacy.public volatile boolean paxos_repair_enabled
public boolean paxos_topology_repair_no_dc_checks
public boolean paxos_topology_repair_strict_each_quorum
public volatile java.util.Set<java.lang.String> skip_paxos_repair_on_topology_change_keyspaces
public java.lang.String paxos_contention_wait_randomizer
public java.lang.String paxos_contention_min_wait
public java.lang.String paxos_contention_max_wait
public java.lang.String paxos_contention_min_delta
public volatile int paxos_repair_parallelism
public volatile int max_top_size_partition_count
public volatile int max_top_tombstone_partition_count
public volatile DataStorageSpec.LongBytesBound min_tracked_partition_size
public volatile long min_tracked_partition_tombstone_count
public volatile boolean top_partitions_enabled
public static java.util.Set<java.lang.String> splitCommaDelimited(java.lang.String src)
@Deprecated public static boolean isClientMode()
DatabaseDescriptor.isClientInitialized()
@Deprecated public static void setClientMode(boolean clientMode)
DatabaseDescriptor.clientInitialization(boolean)
public static java.util.function.Supplier<Config> getOverrideLoadConfig()
public static void setOverrideLoadConfig(java.util.function.Supplier<Config> loadConfig)
public static void log(Config config)
Copyright © 2009- The Apache Software Foundation