Class DatabaseDescriptor


  • public class DatabaseDescriptor
    extends java.lang.Object
    • Field Detail

      • allowUnlimitedConcurrentValidations

        public static volatile boolean allowUnlimitedConcurrentValidations
    • Constructor Detail

      • DatabaseDescriptor

        public DatabaseDescriptor()
    • Method Detail

      • toolInitialization

        public static void toolInitialization​(boolean failIfDaemonOrClient)
        Initializes this class as a tool, which means that the configuration is loaded using loadConfig() and all non-daemon configuration parts will be setup.
        Parameters:
        failIfDaemonOrClient - if true and a call to daemonInitialization() or clientInitialization() has been performed before, an AssertionError will be thrown.
      • clientInitialization

        public static void clientInitialization​(boolean failIfDaemonOrTool,
                                                java.util.function.Supplier<Config> configSupplier)
        Initializes this class as a client, which means that just an empty configuration will be used.
        Parameters:
        failIfDaemonOrTool - if true and a call to daemonInitialization() or toolInitialization() has been performed before, an AssertionError will be thrown.
      • isClientInitialized

        public static boolean isClientInitialized()
      • isToolInitialized

        public static boolean isToolInitialized()
      • isClientOrToolInitialized

        public static boolean isClientOrToolInitialized()
      • isDaemonInitialized

        public static boolean isDaemonInitialized()
      • getRawConfig

        public static Config getRawConfig()
      • setConfig

        public static void setConfig​(Config config)
      • applyEncryptionContext

        public static void applyEncryptionContext()
      • applySslContext

        public static void applySslContext()
      • applyCryptoProvider

        public static void applyCryptoProvider()
      • applySeedProvider

        public static void applySeedProvider()
      • applyTokensConfig

        public static void applyTokensConfig()
      • applySnitch

        public static void applySnitch()
      • applyPartitioner

        public static void applyPartitioner()
      • applyPartitioner

        public static void applyPartitioner​(Config conf)
      • setAuthenticator

        public static void setAuthenticator​(IAuthenticator authenticator)
      • getAuthorizer

        public static IAuthorizer getAuthorizer()
      • setAuthorizer

        public static void setAuthorizer​(IAuthorizer authorizer)
      • setNetworkAuthorizer

        public static void setNetworkAuthorizer​(INetworkAuthorizer networkAuthorizer)
      • setCIDRAuthorizer

        public static void setCIDRAuthorizer​(ICIDRAuthorizer cidrAuthorizer)
      • getCidrChecksForSuperusers

        public static boolean getCidrChecksForSuperusers()
      • getCidrGroupsCacheRefreshInterval

        public static int getCidrGroupsCacheRefreshInterval()
      • getIpCacheMaxSize

        public static int getIpCacheMaxSize()
      • setAuthFromRoot

        public static void setAuthFromRoot​(boolean fromRoot)
      • getAuthFromRoot

        public static boolean getAuthFromRoot()
      • getRoleManager

        public static IRoleManager getRoleManager()
      • setRoleManager

        public static void setRoleManager​(IRoleManager roleManager)
      • getPermissionsValidity

        public static int getPermissionsValidity()
      • setPermissionsValidity

        public static void setPermissionsValidity​(int timeout)
      • getPermissionsUpdateInterval

        public static int getPermissionsUpdateInterval()
      • setPermissionsUpdateInterval

        public static void setPermissionsUpdateInterval​(int updateInterval)
      • getPermissionsCacheMaxEntries

        public static int getPermissionsCacheMaxEntries()
      • setPermissionsCacheMaxEntries

        public static int setPermissionsCacheMaxEntries​(int maxEntries)
      • getPermissionsCacheActiveUpdate

        public static boolean getPermissionsCacheActiveUpdate()
      • setPermissionsCacheActiveUpdate

        public static void setPermissionsCacheActiveUpdate​(boolean update)
      • getRolesValidity

        public static int getRolesValidity()
      • setRolesValidity

        public static void setRolesValidity​(int validity)
      • getRolesUpdateInterval

        public static int getRolesUpdateInterval()
      • setRolesCacheActiveUpdate

        public static void setRolesCacheActiveUpdate​(boolean update)
      • getRolesCacheActiveUpdate

        public static boolean getRolesCacheActiveUpdate()
      • setRolesUpdateInterval

        public static void setRolesUpdateInterval​(int interval)
      • getRolesCacheMaxEntries

        public static int getRolesCacheMaxEntries()
      • setRolesCacheMaxEntries

        public static int setRolesCacheMaxEntries​(int maxEntries)
      • getCredentialsValidity

        public static int getCredentialsValidity()
      • setCredentialsValidity

        public static void setCredentialsValidity​(int timeout)
      • getCredentialsUpdateInterval

        public static int getCredentialsUpdateInterval()
      • setCredentialsUpdateInterval

        public static void setCredentialsUpdateInterval​(int updateInterval)
      • getCredentialsCacheMaxEntries

        public static int getCredentialsCacheMaxEntries()
      • setCredentialsCacheMaxEntries

        public static int setCredentialsCacheMaxEntries​(int maxEntries)
      • getCredentialsCacheActiveUpdate

        public static boolean getCredentialsCacheActiveUpdate()
      • setCredentialsCacheActiveUpdate

        public static void setCredentialsCacheActiveUpdate​(boolean update)
      • getMaxValueSize

        public static int getMaxValueSize()
      • setMaxValueSize

        public static void setMaxValueSize​(int maxValueSizeInBytes)
      • createAllDirectories

        public static void createAllDirectories()
        Creates all storage-related directories.
      • getPartitioner

        public static IPartitioner getPartitioner()
      • getPartitionerName

        public static java.lang.String getPartitionerName()
      • setEndpointSnitch

        public static void setEndpointSnitch​(IEndpointSnitch eps)
      • setDefaultFailureDetector

        public static void setDefaultFailureDetector()
      • getColumnIndexSize

        public static int getColumnIndexSize​(int defaultValue)
      • getColumnIndexSizeInKiB

        public static int getColumnIndexSizeInKiB()
      • setColumnIndexSizeInKiB

        public static void setColumnIndexSizeInKiB​(int val)
      • getColumnIndexCacheSize

        public static int getColumnIndexCacheSize()
      • getColumnIndexCacheSizeInKiB

        public static int getColumnIndexCacheSizeInKiB()
      • setColumnIndexCacheSize

        public static void setColumnIndexCacheSize​(int val)
      • getBatchSizeWarnThreshold

        public static int getBatchSizeWarnThreshold()
      • getBatchSizeWarnThresholdInKiB

        public static int getBatchSizeWarnThresholdInKiB()
      • getBatchSizeFailThreshold

        public static long getBatchSizeFailThreshold()
      • getBatchSizeFailThresholdInKiB

        public static int getBatchSizeFailThresholdInKiB()
      • getUnloggedBatchAcrossPartitionsWarnThreshold

        public static int getUnloggedBatchAcrossPartitionsWarnThreshold()
      • setBatchSizeWarnThresholdInKiB

        public static void setBatchSizeWarnThresholdInKiB​(int threshold)
      • setBatchSizeFailThresholdInKiB

        public static void setBatchSizeFailThresholdInKiB​(int threshold)
      • getInitialTokens

        public static java.util.Collection<java.lang.String> getInitialTokens()
      • getAllocateTokensForKeyspace

        public static java.lang.String getAllocateTokensForKeyspace()
      • getAllocateTokensForLocalRf

        public static java.lang.Integer getAllocateTokensForLocalRf()
      • tokensFromString

        public static java.util.Collection<java.lang.String> tokensFromString​(java.lang.String tokenString)
      • getNumTokens

        public static int getNumTokens()
      • getReplaceTokens

        public static java.util.Collection<java.lang.String> getReplaceTokens()
      • getReplaceNode

        public static java.util.UUID getReplaceNode()
      • getClusterName

        public static java.lang.String getClusterName()
      • getStoragePort

        public static int getStoragePort()
      • getSSLStoragePort

        public static int getSSLStoragePort()
      • nativeTransportIdleTimeout

        public static long nativeTransportIdleTimeout()
      • setNativeTransportIdleTimeout

        public static void setNativeTransportIdleTimeout​(long nativeTransportTimeout)
      • getRpcTimeout

        public static long getRpcTimeout​(java.util.concurrent.TimeUnit unit)
      • setRpcTimeout

        public static void setRpcTimeout​(long timeOutInMillis)
      • getReadRpcTimeout

        public static long getReadRpcTimeout​(java.util.concurrent.TimeUnit unit)
      • setReadRpcTimeout

        public static void setReadRpcTimeout​(long timeOutInMillis)
      • getRangeRpcTimeout

        public static long getRangeRpcTimeout​(java.util.concurrent.TimeUnit unit)
      • setRangeRpcTimeout

        public static void setRangeRpcTimeout​(long timeOutInMillis)
      • getWriteRpcTimeout

        public static long getWriteRpcTimeout​(java.util.concurrent.TimeUnit unit)
      • setWriteRpcTimeout

        public static void setWriteRpcTimeout​(long timeOutInMillis)
      • getCounterWriteRpcTimeout

        public static long getCounterWriteRpcTimeout​(java.util.concurrent.TimeUnit unit)
      • setCounterWriteRpcTimeout

        public static void setCounterWriteRpcTimeout​(long timeOutInMillis)
      • getCasContentionTimeout

        public static long getCasContentionTimeout​(java.util.concurrent.TimeUnit unit)
      • setCasContentionTimeout

        public static void setCasContentionTimeout​(long timeOutInMillis)
      • getTruncateRpcTimeout

        public static long getTruncateRpcTimeout​(java.util.concurrent.TimeUnit unit)
      • setTruncateRpcTimeout

        public static void setTruncateRpcTimeout​(long timeOutInMillis)
      • getRepairRpcTimeout

        public static long getRepairRpcTimeout​(java.util.concurrent.TimeUnit unit)
      • setRepairRpcTimeout

        public static void setRepairRpcTimeout​(java.lang.Long timeOutInMillis)
      • hasCrossNodeTimeout

        public static boolean hasCrossNodeTimeout()
      • setCrossNodeTimeout

        public static void setCrossNodeTimeout​(boolean crossNodeTimeout)
      • getSlowQueryTimeout

        public static long getSlowQueryTimeout​(java.util.concurrent.TimeUnit unit)
      • getMinRpcTimeout

        public static long getMinRpcTimeout​(java.util.concurrent.TimeUnit unit)
        Returns:
        the minimum configured {read, write, range, truncate, misc} timeout
      • getNativeTransportQueueMaxItemAgeThreshold

        public static double getNativeTransportQueueMaxItemAgeThreshold()
        How much time the item is allowed to spend in (currently only Native) queue, compared to nativeTransportIdleTimeout(), before backpressure starts being applied. For example, setting this value to 0.5 means and having the largest of read/range/write/counter timeouts to 10 seconds means that if any item spends more than 5 seconds in the queue, backpressure will be applied to the socket associated with this queue. Set to 0 or any negative value to fully disable.
      • setNativeTransportMaxQueueItemAgeThreshold

        public static void setNativeTransportMaxQueueItemAgeThreshold​(double threshold)
      • getNativeTransportMinBackoffOnQueueOverload

        public static long getNativeTransportMinBackoffOnQueueOverload​(java.util.concurrent.TimeUnit timeUnit)
      • getNativeTransportMaxBackoffOnQueueOverload

        public static long getNativeTransportMaxBackoffOnQueueOverload​(java.util.concurrent.TimeUnit timeUnit)
      • setNativeTransportBackoffOnQueueOverload

        public static void setNativeTransportBackoffOnQueueOverload​(long minBackoffMillis,
                                                                    long maxBackoffMillis,
                                                                    java.util.concurrent.TimeUnit timeUnit)
      • getNativeTransportTimeout

        public static long getNativeTransportTimeout​(java.util.concurrent.TimeUnit timeUnit)
      • setNativeTransportTimeout

        public static void setNativeTransportTimeout​(long dealine,
                                                     java.util.concurrent.TimeUnit timeUnit)
      • getEnforceNativeDeadlineForHints

        public static boolean getEnforceNativeDeadlineForHints()
      • setEnforceNativeDeadlineForHints

        public static void setEnforceNativeDeadlineForHints​(boolean value)
      • getNativeTransportThrowOnOverload

        public static boolean getNativeTransportThrowOnOverload()
      • setNativeTransportThrowOnOverload

        public static void setNativeTransportThrowOnOverload​(boolean throwOnOverload)
      • getPingTimeout

        public static long getPingTimeout​(java.util.concurrent.TimeUnit unit)
      • getPhiConvictThreshold

        public static double getPhiConvictThreshold()
      • setPhiConvictThreshold

        public static void setPhiConvictThreshold​(double phiConvictThreshold)
      • getConcurrentReaders

        public static int getConcurrentReaders()
      • setConcurrentReaders

        public static void setConcurrentReaders​(int concurrent_reads)
      • getConcurrentWriters

        public static int getConcurrentWriters()
      • setConcurrentWriters

        public static void setConcurrentWriters​(int concurrent_writers)
      • getConcurrentCounterWriters

        public static int getConcurrentCounterWriters()
      • setConcurrentCounterWriters

        public static void setConcurrentCounterWriters​(int concurrent_counter_writes)
      • getConcurrentViewWriters

        public static int getConcurrentViewWriters()
      • setConcurrentViewWriters

        public static void setConcurrentViewWriters​(int concurrent_materialized_view_writes)
      • getFlushWriters

        public static int getFlushWriters()
      • getAvailableProcessors

        public static int getAvailableProcessors()
      • getConcurrentCompactors

        public static int getConcurrentCompactors()
      • setConcurrentCompactors

        public static void setConcurrentCompactors​(int value)
      • getCompactionThroughputMebibytesPerSecAsInt

        public static int getCompactionThroughputMebibytesPerSecAsInt()
      • getCompactionThroughputBytesPerSec

        public static double getCompactionThroughputBytesPerSec()
      • getCompactionThroughputMebibytesPerSec

        public static double getCompactionThroughputMebibytesPerSec()
      • setCompactionThroughputBytesPerSec

        public static void setCompactionThroughputBytesPerSec​(int value)
      • setCompactionThroughputMebibytesPerSec

        public static void setCompactionThroughputMebibytesPerSec​(int value)
      • getConcurrentValidations

        public static int getConcurrentValidations()
      • getConcurrentIndexBuilders

        public static int getConcurrentIndexBuilders()
      • setConcurrentIndexBuilders

        public static void setConcurrentIndexBuilders​(int value)
      • setConcurrentValidations

        public static void setConcurrentValidations​(int value)
      • getConcurrentViewBuilders

        public static int getConcurrentViewBuilders()
      • setConcurrentViewBuilders

        public static void setConcurrentViewBuilders​(int value)
      • getMinFreeSpacePerDriveInMebibytes

        public static long getMinFreeSpacePerDriveInMebibytes()
      • getMinFreeSpacePerDriveInBytes

        public static long getMinFreeSpacePerDriveInBytes()
      • setMinFreeSpacePerDriveInMebibytes

        public static long setMinFreeSpacePerDriveInMebibytes​(long mebiBytes)
      • getMaxSpaceForCompactionsPerDrive

        public static double getMaxSpaceForCompactionsPerDrive()
      • setMaxSpaceForCompactionsPerDrive

        public static void setMaxSpaceForCompactionsPerDrive​(double percentage)
      • getDisableSTCSInL0

        public static boolean getDisableSTCSInL0()
      • setDisableSTCSInL0

        public static void setDisableSTCSInL0​(boolean disabled)
      • getStreamThroughputOutboundMegabitsPerSec

        public static int getStreamThroughputOutboundMegabitsPerSec()
      • getStreamThroughputOutboundMegabitsPerSecAsDouble

        public static double getStreamThroughputOutboundMegabitsPerSecAsDouble()
      • getStreamThroughputOutboundMebibytesPerSec

        public static double getStreamThroughputOutboundMebibytesPerSec()
      • getStreamThroughputOutboundBytesPerSec

        public static double getStreamThroughputOutboundBytesPerSec()
      • getStreamThroughputOutboundMebibytesPerSecAsInt

        public static int getStreamThroughputOutboundMebibytesPerSecAsInt()
      • setStreamThroughputOutboundMebibytesPerSecAsInt

        public static void setStreamThroughputOutboundMebibytesPerSecAsInt​(int value)
      • setStreamThroughputOutboundBytesPerSec

        public static void setStreamThroughputOutboundBytesPerSec​(long value)
      • setStreamThroughputOutboundMegabitsPerSec

        public static void setStreamThroughputOutboundMegabitsPerSec​(int value)
      • getEntireSSTableStreamThroughputOutboundMebibytesPerSec

        public static double getEntireSSTableStreamThroughputOutboundMebibytesPerSec()
      • getEntireSSTableStreamThroughputOutboundBytesPerSec

        public static double getEntireSSTableStreamThroughputOutboundBytesPerSec()
      • setEntireSSTableStreamThroughputOutboundMebibytesPerSec

        public static void setEntireSSTableStreamThroughputOutboundMebibytesPerSec​(int value)
      • getInterDCStreamThroughputOutboundMegabitsPerSec

        public static int getInterDCStreamThroughputOutboundMegabitsPerSec()
      • getInterDCStreamThroughputOutboundMegabitsPerSecAsDouble

        public static double getInterDCStreamThroughputOutboundMegabitsPerSecAsDouble()
      • getInterDCStreamThroughputOutboundMebibytesPerSec

        public static double getInterDCStreamThroughputOutboundMebibytesPerSec()
      • getInterDCStreamThroughputOutboundBytesPerSec

        public static double getInterDCStreamThroughputOutboundBytesPerSec()
      • getInterDCStreamThroughputOutboundMebibytesPerSecAsInt

        public static int getInterDCStreamThroughputOutboundMebibytesPerSecAsInt()
      • setInterDCStreamThroughputOutboundMebibytesPerSecAsInt

        public static void setInterDCStreamThroughputOutboundMebibytesPerSecAsInt​(int value)
      • setInterDCStreamThroughputOutboundBytesPerSec

        public static void setInterDCStreamThroughputOutboundBytesPerSec​(long value)
      • setInterDCStreamThroughputOutboundMegabitsPerSec

        public static void setInterDCStreamThroughputOutboundMegabitsPerSec​(int value)
      • getEntireSSTableInterDCStreamThroughputOutboundBytesPerSec

        public static double getEntireSSTableInterDCStreamThroughputOutboundBytesPerSec()
      • getEntireSSTableInterDCStreamThroughputOutboundMebibytesPerSec

        public static double getEntireSSTableInterDCStreamThroughputOutboundMebibytesPerSec()
      • setEntireSSTableInterDCStreamThroughputOutboundMebibytesPerSec

        public static void setEntireSSTableInterDCStreamThroughputOutboundMebibytesPerSec​(int value)
      • useSpecificLocationForLocalSystemData

        public static boolean useSpecificLocationForLocalSystemData()
        Checks if the local system data must be stored in a specific location which supports redundancy.
        Returns:
        true if the local system keyspaces data must be stored in a different location, false otherwise.
      • getLocalSystemKeyspacesDataFileLocations

        public static java.lang.String[] getLocalSystemKeyspacesDataFileLocations()
        Returns the locations where the local system keyspaces data should be stored.

        If the local_system_data_file_directory was unspecified, the local system keyspaces data should be stored in the first data directory. This approach guarantees that the server can tolerate the lost of all the disks but the first one.

        Returns:
        the locations where should be stored the local system keyspaces data
      • getNonLocalSystemKeyspacesDataFileLocations

        public static java.lang.String[] getNonLocalSystemKeyspacesDataFileLocations()
        Returns the locations where the non local system keyspaces data should be stored.
        Returns:
        the locations where the non local system keyspaces data should be stored.
      • getAllDataFileLocations

        public static java.lang.String[] getAllDataFileLocations()
        Returns the list of all the directories where the data files can be stored (for local system and non local system keyspaces).
        Returns:
        the list of all the directories where the data files can be stored.
      • getCommitLogLocation

        public static java.lang.String getCommitLogLocation()
      • setCommitLogLocation

        public static void setCommitLogLocation​(java.lang.String value)
      • setCommitLogCompression

        public static void setCommitLogCompression​(ParameterizedClass compressor)
      • getCommitLogMaxCompressionBuffersInPool

        public static int getCommitLogMaxCompressionBuffersInPool()
        Maximum number of buffers in the compression pool. The default value is 3, it should not be set lower than that (one segment in compression, one written to, one in reserve); delays in compression may cause the log to use more, depending on how soon the sync policy stops all writing threads.
      • setCommitLogMaxCompressionBuffersPerPool

        public static void setCommitLogMaxCompressionBuffersPerPool​(int buffers)
      • getMaxMutationSize

        public static int getMaxMutationSize()
      • getTombstoneWarnThreshold

        public static int getTombstoneWarnThreshold()
      • setTombstoneWarnThreshold

        public static void setTombstoneWarnThreshold​(int threshold)
      • getTombstoneFailureThreshold

        public static int getTombstoneFailureThreshold()
      • setTombstoneFailureThreshold

        public static void setTombstoneFailureThreshold​(int threshold)
      • getCachedReplicaRowsWarnThreshold

        public static int getCachedReplicaRowsWarnThreshold()
      • setCachedReplicaRowsWarnThreshold

        public static void setCachedReplicaRowsWarnThreshold​(int threshold)
      • getCachedReplicaRowsFailThreshold

        public static int getCachedReplicaRowsFailThreshold()
      • setCachedReplicaRowsFailThreshold

        public static void setCachedReplicaRowsFailThreshold​(int threshold)
      • getCommitLogSegmentSize

        public static int getCommitLogSegmentSize()
        size of commitlog segments to allocate
      • setCommitLogSegmentSize

        public static void setCommitLogSegmentSize​(int sizeMebibytes)
        Update commitlog_segment_size in the tests. CommitLogSegmentManagerCDC uses the CommitLogSegmentSize to estimate the file size on allocation. It is important to keep the value unchanged for the estimation to be correct.
        Parameters:
        sizeMebibytes -
      • getCommitLogWriteDiskAccessMode

        public static Config.DiskAccessMode getCommitLogWriteDiskAccessMode()
        Return commitlog disk access mode.
      • setCommitLogWriteDiskAccessMode

        public static void setCommitLogWriteDiskAccessMode​(Config.DiskAccessMode diskAccessMode)
      • initializeCommitLogDiskAccessMode

        public static void initializeCommitLogDiskAccessMode()
      • getSavedCachesLocation

        public static java.lang.String getSavedCachesLocation()
      • getSeedProvider

        public static SeedProvider getSeedProvider()
      • setSeedProvider

        public static void setSeedProvider​(SeedProvider newSeedProvider)
      • getListenAddress

        public static java.net.InetAddress getListenAddress()
      • setListenAddress

        public static void setListenAddress​(java.net.InetAddress newlistenAddress)
      • getBroadcastAddress

        public static java.net.InetAddress getBroadcastAddress()
      • shouldListenOnBroadcastAddress

        public static boolean shouldListenOnBroadcastAddress()
      • setShouldListenOnBroadcastAddress

        public static void setShouldListenOnBroadcastAddress​(boolean shouldListenOnBroadcastAddress)
      • setListenOnBroadcastAddress

        public static void setListenOnBroadcastAddress​(boolean listen_on_broadcast_address)
      • setInternodeAuthenticator

        public static void setInternodeAuthenticator​(IInternodeAuthenticator internodeAuthenticator)
      • setBroadcastAddress

        public static void setBroadcastAddress​(java.net.InetAddress broadcastAdd)
      • getRpcAddress

        public static java.net.InetAddress getRpcAddress()
        This is the address used to bind for the native protocol to communicate with clients. Most usages in the code refer to it as native address although some places still call it RPC address. It's not thrift RPC anymore so native is more appropriate. The address alone is not enough to uniquely identify this instance because multiple instances might use the same interface with different ports.
      • setBroadcastRpcAddress

        public static void setBroadcastRpcAddress​(java.net.InetAddress broadcastRPCAddr)
      • getBroadcastRpcAddress

        public static java.net.InetAddress getBroadcastRpcAddress()
        This is the address used to reach this instance for the native protocol to communicate with clients. Most usages in the code refer to it as native address although some places still call it RPC address. It's not thrift RPC anymore so native is more appropriate. The address alone is not enough to uniquely identify this instance because multiple instances might use the same interface with different ports. May be null, please use FBUtilities.getBroadcastNativeAddressAndPort() instead.
      • getRpcKeepAlive

        public static boolean getRpcKeepAlive()
      • getInternodeSocketSendBufferSizeInBytes

        public static int getInternodeSocketSendBufferSizeInBytes()
      • getInternodeSocketReceiveBufferSizeInBytes

        public static int getInternodeSocketReceiveBufferSizeInBytes()
      • getInternodeApplicationSendQueueCapacityInBytes

        public static int getInternodeApplicationSendQueueCapacityInBytes()
      • getInternodeApplicationSendQueueReserveEndpointCapacityInBytes

        public static int getInternodeApplicationSendQueueReserveEndpointCapacityInBytes()
      • getInternodeApplicationSendQueueReserveGlobalCapacityInBytes

        public static int getInternodeApplicationSendQueueReserveGlobalCapacityInBytes()
      • getInternodeApplicationReceiveQueueCapacityInBytes

        public static int getInternodeApplicationReceiveQueueCapacityInBytes()
      • getInternodeApplicationReceiveQueueReserveEndpointCapacityInBytes

        public static int getInternodeApplicationReceiveQueueReserveEndpointCapacityInBytes()
      • getInternodeApplicationReceiveQueueReserveGlobalCapacityInBytes

        public static int getInternodeApplicationReceiveQueueReserveGlobalCapacityInBytes()
      • getInternodeTcpConnectTimeoutInMS

        public static int getInternodeTcpConnectTimeoutInMS()
      • setInternodeTcpConnectTimeoutInMS

        public static void setInternodeTcpConnectTimeoutInMS​(int value)
      • getInternodeTcpUserTimeoutInMS

        public static int getInternodeTcpUserTimeoutInMS()
      • setInternodeTcpUserTimeoutInMS

        public static void setInternodeTcpUserTimeoutInMS​(int value)
      • getInternodeStreamingTcpUserTimeoutInMS

        public static int getInternodeStreamingTcpUserTimeoutInMS()
      • setInternodeStreamingTcpUserTimeoutInMS

        public static void setInternodeStreamingTcpUserTimeoutInMS​(int value)
      • getInternodeMaxMessageSizeInBytes

        public static int getInternodeMaxMessageSizeInBytes()
      • setInternodeMaxMessageSizeInBytes

        public static void setInternodeMaxMessageSizeInBytes​(int value)
      • startNativeTransport

        public static boolean startNativeTransport()
      • getNativeTransportPort

        public static int getNativeTransportPort()
        This is the port used with RPC address for the native protocol to communicate with clients. Now that thrift RPC is no longer in use there is no RPC port.
      • setNativeTransportPort

        public static void setNativeTransportPort​(int port)
      • getNativeTransportPortSSL

        public static int getNativeTransportPortSSL()
      • setNativeTransportPortSSL

        public static void setNativeTransportPortSSL​(java.lang.Integer port)
      • getNativeTransportMaxThreads

        public static int getNativeTransportMaxThreads()
      • setNativeTransportMaxThreads

        public static void setNativeTransportMaxThreads​(int max_threads)
      • getNativeTransportMaxAuthThreads

        public static java.lang.Integer getNativeTransportMaxAuthThreads()
      • getNativeTransportMaxFrameSize

        public static int getNativeTransportMaxFrameSize()
      • setNativeTransportMaxFrameSize

        public static void setNativeTransportMaxFrameSize​(int bytes)
      • getNativeTransportMaxConcurrentConnections

        public static long getNativeTransportMaxConcurrentConnections()
      • setNativeTransportMaxConcurrentConnections

        public static void setNativeTransportMaxConcurrentConnections​(long nativeTransportMaxConcurrentConnections)
      • getNativeTransportMaxConcurrentConnectionsPerIp

        public static long getNativeTransportMaxConcurrentConnectionsPerIp()
      • setNativeTransportMaxConcurrentConnectionsPerIp

        public static void setNativeTransportMaxConcurrentConnectionsPerIp​(long native_transport_max_concurrent_connections_per_ip)
      • useNativeTransportLegacyFlusher

        public static boolean useNativeTransportLegacyFlusher()
      • getNativeTransportAllowOlderProtocols

        public static boolean getNativeTransportAllowOlderProtocols()
      • setNativeTransportAllowOlderProtocols

        public static void setNativeTransportAllowOlderProtocols​(boolean isEnabled)
      • getCommitLogSyncGroupWindow

        public static long getCommitLogSyncGroupWindow()
      • setCommitLogSyncGroupWindow

        public static void setCommitLogSyncGroupWindow​(long windowMillis)
      • getNativeTransportReceiveQueueCapacityInBytes

        public static int getNativeTransportReceiveQueueCapacityInBytes()
      • setNativeTransportReceiveQueueCapacityInBytes

        public static void setNativeTransportReceiveQueueCapacityInBytes​(int queueSize)
      • getNativeTransportMaxRequestDataInFlightPerIpInBytes

        public static long getNativeTransportMaxRequestDataInFlightPerIpInBytes()
      • getPaxosContentionWaitRandomizer

        public static java.lang.String getPaxosContentionWaitRandomizer()
      • getPaxosContentionMinWait

        public static java.lang.String getPaxosContentionMinWait()
      • getPaxosContentionMaxWait

        public static java.lang.String getPaxosContentionMaxWait()
      • getPaxosContentionMinDelta

        public static java.lang.String getPaxosContentionMinDelta()
      • setPaxosContentionWaitRandomizer

        public static void setPaxosContentionWaitRandomizer​(java.lang.String waitRandomizer)
      • setPaxosContentionMinWait

        public static void setPaxosContentionMinWait​(java.lang.String minWait)
      • setPaxosContentionMaxWait

        public static void setPaxosContentionMaxWait​(java.lang.String maxWait)
      • setPaxosContentionMinDelta

        public static void setPaxosContentionMinDelta​(java.lang.String minDelta)
      • skipPaxosRepairOnTopologyChange

        public static boolean skipPaxosRepairOnTopologyChange()
      • setSkipPaxosRepairOnTopologyChange

        public static void setSkipPaxosRepairOnTopologyChange​(boolean value)
      • getPaxosPurgeGrace

        public static long getPaxosPurgeGrace​(java.util.concurrent.TimeUnit units)
      • setPaxosPurgeGrace

        public static void setPaxosPurgeGrace​(long seconds)
      • paxosRepairEnabled

        public static boolean paxosRepairEnabled()
      • setPaxosRepairEnabled

        public static void setPaxosRepairEnabled​(boolean v)
      • skipPaxosRepairOnTopologyChangeKeyspaces

        public static java.util.Set<java.lang.String> skipPaxosRepairOnTopologyChangeKeyspaces()
      • setSkipPaxosRepairOnTopologyChangeKeyspaces

        public static void setSkipPaxosRepairOnTopologyChangeKeyspaces​(java.lang.String keyspaces)
      • paxoTopologyRepairNoDcChecks

        public static boolean paxoTopologyRepairNoDcChecks()
      • paxoTopologyRepairStrictEachQuorum

        public static boolean paxoTopologyRepairStrictEachQuorum()
      • setNativeTransportMaxRequestDataInFlightPerIpInBytes

        public static void setNativeTransportMaxRequestDataInFlightPerIpInBytes​(long maxRequestDataInFlightInBytes)
      • getNativeTransportMaxRequestDataInFlightInBytes

        public static long getNativeTransportMaxRequestDataInFlightInBytes()
      • setNativeTransportConcurrentRequestDataInFlightInBytes

        public static void setNativeTransportConcurrentRequestDataInFlightInBytes​(long maxRequestDataInFlightInBytes)
      • getNativeTransportMaxRequestsPerSecond

        public static int getNativeTransportMaxRequestsPerSecond()
      • setNativeTransportMaxRequestsPerSecond

        public static void setNativeTransportMaxRequestsPerSecond​(int perSecond)
      • setNativeTransportRateLimitingEnabled

        public static void setNativeTransportRateLimitingEnabled​(boolean enabled)
      • getNativeTransportRateLimitingEnabled

        public static boolean getNativeTransportRateLimitingEnabled()
      • getCommitLogSyncPeriod

        public static int getCommitLogSyncPeriod()
      • getPeriodicCommitLogSyncBlock

        public static long getPeriodicCommitLogSyncBlock()
      • setCommitLogSyncPeriod

        public static void setCommitLogSyncPeriod​(int periodMillis)
      • isSnapshotBeforeCompaction

        public static boolean isSnapshotBeforeCompaction()
      • isAutoSnapshot

        public static boolean isAutoSnapshot()
      • setAutoSnapshot

        public static void setAutoSnapshot​(boolean autoSnapshot)
      • getAutoSnapshot

        public static boolean getAutoSnapshot()
      • getSnapshotLinksPerSecond

        public static long getSnapshotLinksPerSecond()
      • setSnapshotLinksPerSecond

        public static void setSnapshotLinksPerSecond​(long throttle)
      • getSnapshotRateLimiter

        public static com.google.common.util.concurrent.RateLimiter getSnapshotRateLimiter()
      • isAutoBootstrap

        public static boolean isAutoBootstrap()
      • setHintedHandoffEnabled

        public static void setHintedHandoffEnabled​(boolean hintedHandoffEnabled)
      • hintedHandoffEnabled

        public static boolean hintedHandoffEnabled()
      • hintedHandoffDisabledDCs

        public static java.util.Set<java.lang.String> hintedHandoffDisabledDCs()
      • useDeterministicTableID

        public static boolean useDeterministicTableID()
      • useDeterministicTableID

        public static void useDeterministicTableID​(boolean value)
      • enableHintsForDC

        public static void enableHintsForDC​(java.lang.String dc)
      • disableHintsForDC

        public static void disableHintsForDC​(java.lang.String dc)
      • setMaxHintWindow

        public static void setMaxHintWindow​(int ms)
      • getMaxHintWindow

        public static int getMaxHintWindow()
      • setMaxHintsSizePerHostInMiB

        public static void setMaxHintsSizePerHostInMiB​(int value)
      • getMaxHintsSizePerHostInMiB

        public static int getMaxHintsSizePerHostInMiB()
      • getMaxHintsSizePerHost

        public static long getMaxHintsSizePerHost()
      • getHintsDirectory

        public static File getHintsDirectory()
      • hintWindowPersistentEnabled

        public static boolean hintWindowPersistentEnabled()
      • getSerializedCachePath

        public static File getSerializedCachePath​(CacheService.CacheType cacheType,
                                                  java.lang.String version,
                                                  java.lang.String extension)
      • getDynamicUpdateInterval

        public static int getDynamicUpdateInterval()
      • setDynamicUpdateInterval

        public static void setDynamicUpdateInterval​(int dynamicUpdateInterval)
      • getDynamicResetInterval

        public static int getDynamicResetInterval()
      • setDynamicResetInterval

        public static void setDynamicResetInterval​(int dynamicResetInterval)
      • getDynamicBadnessThreshold

        public static double getDynamicBadnessThreshold()
      • setDynamicBadnessThreshold

        public static void setDynamicBadnessThreshold​(double dynamicBadnessThreshold)
      • getNativeProtocolEncryptionOptions

        public static EncryptionOptions getNativeProtocolEncryptionOptions()
      • updateNativeProtocolEncryptionOptions

        public static void updateNativeProtocolEncryptionOptions​(java.util.function.Function<EncryptionOptions,​EncryptionOptions> update)
      • getHintedHandoffThrottleInKiB

        public static int getHintedHandoffThrottleInKiB()
      • setHintedHandoffThrottleInKiB

        public static void setHintedHandoffThrottleInKiB​(int throttleInKiB)
      • getBatchlogReplayThrottleInKiB

        public static int getBatchlogReplayThrottleInKiB()
      • setBatchlogReplayThrottleInKiB

        public static void setBatchlogReplayThrottleInKiB​(int throttleInKiB)
      • getMaxHintsDeliveryThreads

        public static int getMaxHintsDeliveryThreads()
      • getHintsFlushPeriodInMS

        public static int getHintsFlushPeriodInMS()
      • getMaxHintsFileSize

        public static long getMaxHintsFileSize()
      • setHintsCompression

        public static void setHintsCompression​(ParameterizedClass parameterizedClass)
      • isAutoHintsCleanupEnabled

        public static boolean isAutoHintsCleanupEnabled()
      • setAutoHintsCleanupEnabled

        public static void setAutoHintsCleanupEnabled​(boolean value)
      • getTransferHintsOnDecommission

        public static boolean getTransferHintsOnDecommission()
      • setTransferHintsOnDecommission

        public static void setTransferHintsOnDecommission​(boolean enabled)
      • isIncrementalBackupsEnabled

        public static boolean isIncrementalBackupsEnabled()
      • setIncrementalBackupsEnabled

        public static void setIncrementalBackupsEnabled​(boolean value)
      • getFileCacheEnabled

        public static boolean getFileCacheEnabled()
      • setFileCacheEnabled

        public static void setFileCacheEnabled​(boolean enabled)
      • getFileCacheSizeInMiB

        public static int getFileCacheSizeInMiB()
      • getNetworkingCacheSizeInMiB

        public static int getNetworkingCacheSizeInMiB()
      • getFileCacheRoundUp

        public static boolean getFileCacheRoundUp()
      • getDiskOptimizationEstimatePercentile

        public static double getDiskOptimizationEstimatePercentile()
      • getTotalCommitlogSpaceInMiB

        public static long getTotalCommitlogSpaceInMiB()
      • shouldMigrateKeycacheOnCompaction

        public static boolean shouldMigrateKeycacheOnCompaction()
      • setMigrateKeycacheOnCompaction

        public static void setMigrateKeycacheOnCompaction​(boolean migrateCacheEntry)
      • getSSTablePreemptiveOpenIntervalInMiB

        public static int getSSTablePreemptiveOpenIntervalInMiB()
        This method can return negative number for disabled
      • setSSTablePreemptiveOpenIntervalInMiB

        public static void setSSTablePreemptiveOpenIntervalInMiB​(int mib)
        Negative number for disabled
      • getTrickleFsync

        public static boolean getTrickleFsync()
      • getTrickleFsyncIntervalInKiB

        public static int getTrickleFsyncIntervalInKiB()
      • getKeyCacheSizeInMiB

        public static long getKeyCacheSizeInMiB()
      • getIndexSummaryCapacityInMiB

        public static long getIndexSummaryCapacityInMiB()
      • getKeyCacheSavePeriod

        public static int getKeyCacheSavePeriod()
      • setKeyCacheSavePeriod

        public static void setKeyCacheSavePeriod​(int keyCacheSavePeriod)
      • getKeyCacheKeysToSave

        public static int getKeyCacheKeysToSave()
      • setKeyCacheKeysToSave

        public static void setKeyCacheKeysToSave​(int keyCacheKeysToSave)
      • getRowCacheClassName

        public static java.lang.String getRowCacheClassName()
      • getRowCacheSizeInMiB

        public static long getRowCacheSizeInMiB()
      • setRowCacheSizeInMiB

        public static void setRowCacheSizeInMiB​(long val)
      • getRowCacheSavePeriod

        public static int getRowCacheSavePeriod()
      • setRowCacheSavePeriod

        public static void setRowCacheSavePeriod​(int rowCacheSavePeriod)
      • getRowCacheKeysToSave

        public static int getRowCacheKeysToSave()
      • getPaxosCacheSizeInMiB

        public static long getPaxosCacheSizeInMiB()
      • getCounterCacheSizeInMiB

        public static long getCounterCacheSizeInMiB()
      • setRowCacheKeysToSave

        public static void setRowCacheKeysToSave​(int rowCacheKeysToSave)
      • getCounterCacheSavePeriod

        public static int getCounterCacheSavePeriod()
      • setCounterCacheSavePeriod

        public static void setCounterCacheSavePeriod​(int counterCacheSavePeriod)
      • getCacheLoadTimeout

        public static int getCacheLoadTimeout()
      • setCacheLoadTimeout

        public static void setCacheLoadTimeout​(int seconds)
      • getCounterCacheKeysToSave

        public static int getCounterCacheKeysToSave()
      • setCounterCacheKeysToSave

        public static void setCounterCacheKeysToSave​(int counterCacheKeysToSave)
      • getStreamingKeepAlivePeriod

        public static int getStreamingKeepAlivePeriod()
      • getStreamingConnectionsPerHost

        public static int getStreamingConnectionsPerHost()
      • streamEntireSSTables

        public static boolean streamEntireSSTables()
      • setStreamEntireSSTables

        public static boolean setStreamEntireSSTables​(boolean value)
      • getSkipStreamDiskSpaceCheck

        public static boolean getSkipStreamDiskSpaceCheck()
      • setSkipStreamDiskSpaceCheck

        public static void setSkipStreamDiskSpaceCheck​(boolean value)
      • getLocalDataCenter

        public static java.lang.String getLocalDataCenter()
      • setLocalDataCenter

        public static void setLocalDataCenter​(java.lang.String value)
      • getLocalComparator

        public static java.util.Comparator<Replica> getLocalComparator()
      • getInterDCTcpNoDelay

        public static boolean getInterDCTcpNoDelay()
      • getMemtableHeapSpaceInMiB

        public static long getMemtableHeapSpaceInMiB()
      • getMemtableOffheapSpaceInMiB

        public static long getMemtableOffheapSpaceInMiB()
      • getRepairSessionMaxTreeDepth

        public static int getRepairSessionMaxTreeDepth()
      • setRepairSessionMaxTreeDepth

        public static void setRepairSessionMaxTreeDepth​(int depth)
      • getRepairSessionSpaceInMiB

        public static int getRepairSessionSpaceInMiB()
      • setRepairSessionSpaceInMiB

        public static void setRepairSessionSpaceInMiB​(int sizeInMiB)
      • getConcurrentMerkleTreeRequests

        public static int getConcurrentMerkleTreeRequests()
      • setConcurrentMerkleTreeRequests

        public static void setConcurrentMerkleTreeRequests​(int value)
      • getPaxosRepairParallelism

        public static int getPaxosRepairParallelism()
      • setPaxosRepairParallelism

        public static void setPaxosRepairParallelism​(int v)
      • getMemtableCleanupThreshold

        public static java.lang.Float getMemtableCleanupThreshold()
      • getMemtableConfigurations

        public static java.util.Map<java.lang.String,​InheritingClass> getMemtableConfigurations()
      • getIndexSummaryResizeIntervalInMinutes

        public static int getIndexSummaryResizeIntervalInMinutes()
      • setIndexSummaryResizeIntervalInMinutes

        public static void setIndexSummaryResizeIntervalInMinutes​(int value)
      • hasLargeAddressSpace

        public static boolean hasLargeAddressSpace()
      • getTracetypeRepairTTL

        public static int getTracetypeRepairTTL()
      • getTracetypeQueryTTL

        public static int getTracetypeQueryTTL()
      • getPreparedStatementsCacheSizeMiB

        public static long getPreparedStatementsCacheSizeMiB()
      • enableUserDefinedFunctions

        public static boolean enableUserDefinedFunctions()
      • enableScriptedUserDefinedFunctions

        public static boolean enableScriptedUserDefinedFunctions()
      • enableUserDefinedFunctionsThreads

        public static boolean enableUserDefinedFunctionsThreads()
      • getUserDefinedFunctionWarnTimeout

        public static long getUserDefinedFunctionWarnTimeout()
      • setUserDefinedFunctionWarnTimeout

        public static void setUserDefinedFunctionWarnTimeout​(long userDefinedFunctionWarnTimeout)
      • allowInsecureUDFs

        public static boolean allowInsecureUDFs()
      • allowExtraInsecureUDFs

        public static boolean allowExtraInsecureUDFs()
      • getMaterializedViewsEnabled

        public static boolean getMaterializedViewsEnabled()
      • setMaterializedViewsEnabled

        public static void setMaterializedViewsEnabled​(boolean enableMaterializedViews)
      • getSASIIndexesEnabled

        public static boolean getSASIIndexesEnabled()
      • setSASIIndexesEnabled

        public static void setSASIIndexesEnabled​(boolean enableSASIIndexes)
      • getDefaultSecondaryIndex

        public static java.lang.String getDefaultSecondaryIndex()
      • setDefaultSecondaryIndex

        public static void setDefaultSecondaryIndex​(java.lang.String name)
      • getDefaultSecondaryIndexEnabled

        public static boolean getDefaultSecondaryIndexEnabled()
      • setDefaultSecondaryIndexEnabled

        public static void setDefaultSecondaryIndexEnabled​(boolean enabled)
      • isTransientReplicationEnabled

        public static boolean isTransientReplicationEnabled()
      • setTransientReplicationEnabledUnsafe

        public static void setTransientReplicationEnabledUnsafe​(boolean enabled)
      • enableDropCompactStorage

        public static boolean enableDropCompactStorage()
      • setEnableDropCompactStorage

        public static void setEnableDropCompactStorage​(boolean enableDropCompactStorage)
      • getUserDefinedFunctionFailTimeout

        public static long getUserDefinedFunctionFailTimeout()
      • setUserDefinedFunctionFailTimeout

        public static void setUserDefinedFunctionFailTimeout​(long userDefinedFunctionFailTimeout)
      • getGCLogThreshold

        public static long getGCLogThreshold()
      • setGCLogThreshold

        public static void setGCLogThreshold​(int gcLogThreshold)
      • getGCWarnThreshold

        public static long getGCWarnThreshold()
      • setGCWarnThreshold

        public static void setGCWarnThreshold​(int threshold)
      • isCDCEnabled

        public static boolean isCDCEnabled()
      • setCDCEnabled

        public static void setCDCEnabled​(boolean cdc_enabled)
      • getCDCBlockWrites

        public static boolean getCDCBlockWrites()
      • setCDCBlockWrites

        public static void setCDCBlockWrites​(boolean val)
      • isCDCOnRepairEnabled

        public static boolean isCDCOnRepairEnabled()
      • setCDCOnRepairEnabled

        public static void setCDCOnRepairEnabled​(boolean val)
      • getCDCLogLocation

        public static java.lang.String getCDCLogLocation()
      • getCDCTotalSpace

        public static long getCDCTotalSpace()
      • setCDCTotalSpaceInMiB

        public static void setCDCTotalSpaceInMiB​(int mibs)
      • getCDCDiskCheckInterval

        public static int getCDCDiskCheckInterval()
      • setEncryptionContext

        public static void setEncryptionContext​(EncryptionContext ec)
      • searchConcurrencyFactor

        public static int searchConcurrencyFactor()
      • isUnsafeSystem

        public static boolean isUnsafeSystem()
      • diagnosticEventsEnabled

        public static boolean diagnosticEventsEnabled()
      • setDiagnosticEventsEnabled

        public static void setDiagnosticEventsEnabled​(boolean enabled)
      • getIdealConsistencyLevel

        public static ConsistencyLevel getIdealConsistencyLevel()
      • setIdealConsistencyLevel

        public static void setIdealConsistencyLevel​(ConsistencyLevel cl)
      • getRepairCommandPoolSize

        public static int getRepairCommandPoolSize()
      • getBlockForPeersInRemoteDatacenters

        public static boolean getBlockForPeersInRemoteDatacenters()
      • getBlockForPeersTimeoutInSeconds

        public static int getBlockForPeersTimeoutInSeconds()
      • automaticSSTableUpgrade

        public static boolean automaticSSTableUpgrade()
      • setAutomaticSSTableUpgradeEnabled

        public static void setAutomaticSSTableUpgradeEnabled​(boolean enabled)
      • maxConcurrentAutoUpgradeTasks

        public static int maxConcurrentAutoUpgradeTasks()
      • setMaxConcurrentAutoUpgradeTasks

        public static void setMaxConcurrentAutoUpgradeTasks​(int value)
      • getAuditLoggingOptions

        public static AuditLogOptions getAuditLoggingOptions()
      • setAuditLoggingOptions

        public static void setAuditLoggingOptions​(AuditLogOptions auditLoggingOptions)
      • getRepairedDataTrackingForRangeReadsEnabled

        public static boolean getRepairedDataTrackingForRangeReadsEnabled()
      • setRepairedDataTrackingForRangeReadsEnabled

        public static void setRepairedDataTrackingForRangeReadsEnabled​(boolean enabled)
      • getRepairedDataTrackingForPartitionReadsEnabled

        public static boolean getRepairedDataTrackingForPartitionReadsEnabled()
      • setRepairedDataTrackingForPartitionReadsEnabled

        public static void setRepairedDataTrackingForPartitionReadsEnabled​(boolean enabled)
      • snapshotOnRepairedDataMismatch

        public static boolean snapshotOnRepairedDataMismatch()
      • setSnapshotOnRepairedDataMismatch

        public static void setSnapshotOnRepairedDataMismatch​(boolean enabled)
      • snapshotOnDuplicateRowDetection

        public static boolean snapshotOnDuplicateRowDetection()
      • setSnapshotOnDuplicateRowDetection

        public static void setSnapshotOnDuplicateRowDetection​(boolean enabled)
      • reportUnconfirmedRepairedDataMismatches

        public static boolean reportUnconfirmedRepairedDataMismatches()
      • reportUnconfirmedRepairedDataMismatches

        public static void reportUnconfirmedRepairedDataMismatches​(boolean enabled)
      • strictRuntimeChecks

        public static boolean strictRuntimeChecks()
      • useOffheapMerkleTrees

        public static boolean useOffheapMerkleTrees()
      • useOffheapMerkleTrees

        public static void useOffheapMerkleTrees​(boolean value)
      • getValidationPreviewPurgeHeadStartInSec

        public static int getValidationPreviewPurgeHeadStartInSec()
      • checkForDuplicateRowsDuringReads

        public static boolean checkForDuplicateRowsDuringReads()
      • setCheckForDuplicateRowsDuringReads

        public static void setCheckForDuplicateRowsDuringReads​(boolean enabled)
      • checkForDuplicateRowsDuringCompaction

        public static boolean checkForDuplicateRowsDuringCompaction()
      • setCheckForDuplicateRowsDuringCompaction

        public static void setCheckForDuplicateRowsDuringCompaction​(boolean enabled)
      • getRepairPendingCompactionRejectThreshold

        public static int getRepairPendingCompactionRejectThreshold()
      • setRepairPendingCompactionRejectThreshold

        public static void setRepairPendingCompactionRejectThreshold​(int value)
      • getInitialRangeTombstoneListAllocationSize

        public static int getInitialRangeTombstoneListAllocationSize()
      • setInitialRangeTombstoneListAllocationSize

        public static void setInitialRangeTombstoneListAllocationSize​(int size)
      • getRangeTombstoneListGrowthFactor

        public static double getRangeTombstoneListGrowthFactor()
      • setRangeTombstoneListGrowthFactor

        public static void setRangeTombstoneListGrowthFactor​(double resizeFactor)
      • getAutocompactionOnStartupEnabled

        public static boolean getAutocompactionOnStartupEnabled()
      • autoOptimiseIncRepairStreams

        public static boolean autoOptimiseIncRepairStreams()
      • setAutoOptimiseIncRepairStreams

        public static void setAutoOptimiseIncRepairStreams​(boolean enabled)
      • autoOptimiseFullRepairStreams

        public static boolean autoOptimiseFullRepairStreams()
      • setAutoOptimiseFullRepairStreams

        public static void setAutoOptimiseFullRepairStreams​(boolean enabled)
      • autoOptimisePreviewRepairStreams

        public static boolean autoOptimisePreviewRepairStreams()
      • setAutoOptimisePreviewRepairStreams

        public static void setAutoOptimisePreviewRepairStreams​(boolean enabled)
      • getAuthWriteConsistencyLevel

        @Deprecated(since="4.1")
        public static ConsistencyLevel getAuthWriteConsistencyLevel()
        Deprecated.
        See CASSANDRA-17195
      • getAuthReadConsistencyLevel

        public static ConsistencyLevel getAuthReadConsistencyLevel()
      • setAuthWriteConsistencyLevel

        public static void setAuthWriteConsistencyLevel​(ConsistencyLevel cl)
      • setAuthReadConsistencyLevel

        public static void setAuthReadConsistencyLevel​(ConsistencyLevel cl)
      • getConsecutiveMessageErrorsThreshold

        public static int getConsecutiveMessageErrorsThreshold()
      • setConsecutiveMessageErrorsThreshold

        public static void setConsecutiveMessageErrorsThreshold​(int value)
      • getPartitionDenylistEnabled

        public static boolean getPartitionDenylistEnabled()
      • setPartitionDenylistEnabled

        public static void setPartitionDenylistEnabled​(boolean enabled)
      • getDenylistWritesEnabled

        public static boolean getDenylistWritesEnabled()
      • setDenylistWritesEnabled

        public static void setDenylistWritesEnabled​(boolean enabled)
      • getDenylistReadsEnabled

        public static boolean getDenylistReadsEnabled()
      • setDenylistReadsEnabled

        public static void setDenylistReadsEnabled​(boolean enabled)
      • getDenylistRangeReadsEnabled

        public static boolean getDenylistRangeReadsEnabled()
      • setDenylistRangeReadsEnabled

        public static void setDenylistRangeReadsEnabled​(boolean enabled)
      • getDenylistRefreshSeconds

        public static int getDenylistRefreshSeconds()
      • setDenylistRefreshSeconds

        public static void setDenylistRefreshSeconds​(int seconds)
      • getDenylistInitialLoadRetrySeconds

        public static int getDenylistInitialLoadRetrySeconds()
      • setDenylistInitialLoadRetrySeconds

        public static void setDenylistInitialLoadRetrySeconds​(int seconds)
      • getDenylistConsistencyLevel

        public static ConsistencyLevel getDenylistConsistencyLevel()
      • setDenylistConsistencyLevel

        public static void setDenylistConsistencyLevel​(ConsistencyLevel cl)
      • getDenylistMaxKeysPerTable

        public static int getDenylistMaxKeysPerTable()
      • setDenylistMaxKeysPerTable

        public static void setDenylistMaxKeysPerTable​(int value)
      • getDenylistMaxKeysTotal

        public static int getDenylistMaxKeysTotal()
      • setDenylistMaxKeysTotal

        public static void setDenylistMaxKeysTotal​(int value)
      • getAuthCacheWarmingEnabled

        public static boolean getAuthCacheWarmingEnabled()
      • getClientErrorReportingExclusions

        public static SubnetGroups getClientErrorReportingExclusions()
      • getInternodeErrorReportingExclusions

        public static SubnetGroups getInternodeErrorReportingExclusions()
      • getReadThresholdsEnabled

        public static boolean getReadThresholdsEnabled()
      • setReadThresholdsEnabled

        public static void setReadThresholdsEnabled​(boolean value)
      • getDefaultKeyspaceRF

        public static int getDefaultKeyspaceRF()
      • setDefaultKeyspaceRF

        public static void setDefaultKeyspaceRF​(int value)
                                         throws java.lang.IllegalArgumentException
        Throws:
        java.lang.IllegalArgumentException
      • getUseStatementsEnabled

        public static boolean getUseStatementsEnabled()
      • setUseStatementsEnabled

        public static void setUseStatementsEnabled​(boolean enabled)
      • getForceNewPreparedStatementBehaviour

        public static boolean getForceNewPreparedStatementBehaviour()
      • setForceNewPreparedStatementBehaviour

        public static void setForceNewPreparedStatementBehaviour​(boolean value)
      • getStreamingStatsEnabled

        public static boolean getStreamingStatsEnabled()
      • setStreamingStatsEnabled

        public static void setStreamingStatsEnabled​(boolean streamingStatsEnabled)
      • setStreamingSlowEventsLogTimeout

        public static void setStreamingSlowEventsLogTimeout​(java.lang.String value)
      • isUUIDSSTableIdentifiersEnabled

        public static boolean isUUIDSSTableIdentifiersEnabled()
      • getRepairStateSize

        public static int getRepairStateSize()
      • setRepairStateSize

        public static void setRepairStateSize​(int size)
      • topPartitionsEnabled

        public static boolean topPartitionsEnabled()
      • getMaxTopSizePartitionCount

        public static int getMaxTopSizePartitionCount()
      • setMaxTopSizePartitionCount

        public static void setMaxTopSizePartitionCount​(int value)
      • getMaxTopTombstonePartitionCount

        public static int getMaxTopTombstonePartitionCount()
      • setMaxTopTombstonePartitionCount

        public static void setMaxTopTombstonePartitionCount​(int value)
      • getMinTrackedPartitionTombstoneCount

        public static long getMinTrackedPartitionTombstoneCount()
      • setMinTrackedPartitionTombstoneCount

        public static void setMinTrackedPartitionTombstoneCount​(long value)
      • getDumpHeapOnUncaughtException

        public static boolean getDumpHeapOnUncaughtException()
      • getHeapDumpPath

        public static java.nio.file.Path getHeapDumpPath()
        As this is at its heart a debug operation (getting a one-shot heapdump from an uncaught exception), we support both the more evolved cassandra.yaml approach but also the -XX param to override it on a one-off basis so you don't have to change the full config of a node or a cluster in order to get a heap dump from a single node that's misbehaving.
        Returns:
        the absolute path of the -XX param if provided, else the heap_dump_path in cassandra.yaml
      • setDumpHeapOnUncaughtException

        public static void setDumpHeapOnUncaughtException​(boolean enabled)
      • getSStableReadRatePersistenceEnabled

        public static boolean getSStableReadRatePersistenceEnabled()
      • setSStableReadRatePersistenceEnabled

        public static void setSStableReadRatePersistenceEnabled​(boolean enabled)
      • getClientRequestSizeMetricsEnabled

        public static boolean getClientRequestSizeMetricsEnabled()
      • setClientRequestSizeMetricsEnabled

        public static void setClientRequestSizeMetricsEnabled​(boolean enabled)
      • getSSTableFormats

        public static com.google.common.collect.ImmutableMap<java.lang.String,​SSTableFormat<?,​?>> getSSTableFormats()
      • getSelectedSSTableFormat

        public static SSTableFormat<?,​?> getSelectedSSTableFormat()
      • setSelectedSSTableFormat

        public static void setSelectedSSTableFormat​(SSTableFormat<?,​?> format)
      • getDynamicDataMaskingEnabled

        public static boolean getDynamicDataMaskingEnabled()
      • setDynamicDataMaskingEnabled

        public static void setDynamicDataMaskingEnabled​(boolean enabled)
      • getSeverityDuringDecommission

        public static java.util.OptionalDouble getSeverityDuringDecommission()
      • getSaiSSTableIndexesPerQueryWarnThreshold

        public static int getSaiSSTableIndexesPerQueryWarnThreshold()
      • getSaiSSTableIndexesPerQueryFailThreshold

        public static int getSaiSSTableIndexesPerQueryFailThreshold()
      • getLogOutOfTokenRangeRequests

        public static boolean getLogOutOfTokenRangeRequests()
      • setLogOutOfTokenRangeRequests

        public static void setLogOutOfTokenRangeRequests​(boolean enabled)
      • getRejectOutOfTokenRangeRequests

        public static boolean getRejectOutOfTokenRangeRequests()
      • setRejectOutOfTokenRangeRequests

        public static void setRejectOutOfTokenRangeRequests​(boolean enabled)