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)
        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()
      • applyEncryptionContext

        public static void applyEncryptionContext()
      • applySslContext

        public static void applySslContext()
      • 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)
      • 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)
      • getRolesValidity

        public static int getRolesValidity()
      • setRolesValidity

        public static void setRolesValidity​(int validity)
      • getRolesUpdateInterval

        public static int getRolesUpdateInterval()
      • 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)
      • 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)
      • getColumnIndexSize

        public static int getColumnIndexSize()
      • getColumnIndexSizeInKB

        public static int getColumnIndexSizeInKB()
      • setColumnIndexSize

        public static void setColumnIndexSize​(int val)
      • getColumnIndexCacheSize

        public static int getColumnIndexCacheSize()
      • getColumnIndexCacheSizeInKB

        public static int getColumnIndexCacheSizeInKB()
      • setColumnIndexCacheSize

        public static void setColumnIndexCacheSize​(int val)
      • getBatchSizeWarnThreshold

        public static int getBatchSizeWarnThreshold()
      • getBatchSizeWarnThresholdInKB

        public static int getBatchSizeWarnThresholdInKB()
      • getBatchSizeFailThreshold

        public static long getBatchSizeFailThreshold()
      • getBatchSizeFailThresholdInKB

        public static int getBatchSizeFailThresholdInKB()
      • getUnloggedBatchAcrossPartitionsWarnThreshold

        public static int getUnloggedBatchAcrossPartitionsWarnThreshold()
      • setBatchSizeWarnThresholdInKB

        public static void setBatchSizeWarnThresholdInKB​(int threshold)
      • setBatchSizeFailThresholdInKB

        public static void setBatchSizeFailThresholdInKB​(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)
      • hasCrossNodeTimeout

        public static boolean hasCrossNodeTimeout()
      • setCrossNodeTimeout

        public static void setCrossNodeTimeout​(boolean crossNodeTimeout)
      • getSlowQueryTimeout

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

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

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

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

        public static void setRepairRpcTimeout​(long time,
                                               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()
      • getConcurrentCompactors

        public static int getConcurrentCompactors()
      • setConcurrentCompactors

        public static void setConcurrentCompactors​(int value)
      • getCompactionThroughputMbPerSec

        public static int getCompactionThroughputMbPerSec()
      • setCompactionThroughputMbPerSec

        public static void setCompactionThroughputMbPerSec​(int value)
      • getCompactionLargePartitionWarningThreshold

        public static long getCompactionLargePartitionWarningThreshold()
      • getConcurrentValidations

        public static int getConcurrentValidations()
      • setConcurrentValidations

        public static void setConcurrentValidations​(int value)
      • getConcurrentViewBuilders

        public static int getConcurrentViewBuilders()
      • setConcurrentViewBuilders

        public static void setConcurrentViewBuilders​(int value)
      • getMinFreeSpacePerDriveInBytes

        public static long getMinFreeSpacePerDriveInBytes()
      • getDisableSTCSInL0

        public static boolean getDisableSTCSInL0()
      • setDisableSTCSInL0

        public static void setDisableSTCSInL0​(boolean disabled)
      • getStreamThroughputOutboundMegabitsPerSec

        public static int getStreamThroughputOutboundMegabitsPerSec()
      • setStreamThroughputOutboundMegabitsPerSec

        public static void setStreamThroughputOutboundMegabitsPerSec​(int value)
      • getInterDCStreamThroughputOutboundMegabitsPerSec

        public static int getInterDCStreamThroughputOutboundMegabitsPerSec()
      • setInterDCStreamThroughputOutboundMegabitsPerSec

        public static void setInterDCStreamThroughputOutboundMegabitsPerSec​(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 sizeMegabytes)
      • 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)
      • getNativeTransportMaxFrameSize

        public static int getNativeTransportMaxFrameSize()
      • 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 double getCommitLogSyncGroupWindow()
      • setCommitLogSyncGroupWindow

        public static void setCommitLogSyncGroupWindow​(double windowMillis)
      • getNativeTransportReceiveQueueCapacityInBytes

        public static int getNativeTransportReceiveQueueCapacityInBytes()
      • setNativeTransportReceiveQueueCapacityInBytes

        public static void setNativeTransportReceiveQueueCapacityInBytes​(int queueSize)
      • getNativeTransportMaxConcurrentRequestsInBytesPerIp

        public static long getNativeTransportMaxConcurrentRequestsInBytesPerIp()
      • setNativeTransportMaxConcurrentRequestsInBytesPerIp

        public static void setNativeTransportMaxConcurrentRequestsInBytesPerIp​(long maxConcurrentRequestsInBytes)
      • getNativeTransportMaxConcurrentRequestsInBytes

        public static long getNativeTransportMaxConcurrentRequestsInBytes()
      • setNativeTransportMaxConcurrentRequestsInBytes

        public static void setNativeTransportMaxConcurrentRequestsInBytes​(long maxConcurrentRequestsInBytes)
      • 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()
      • 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()
      • getHintsDirectory

        public static java.io.File getHintsDirectory()
      • getSerializedCachePath

        public static java.io.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)
      • getHintedHandoffThrottleInKB

        public static int getHintedHandoffThrottleInKB()
      • setHintedHandoffThrottleInKB

        public static void setHintedHandoffThrottleInKB​(int throttleInKB)
      • getBatchlogReplayThrottleInKB

        public static int getBatchlogReplayThrottleInKB()
      • setBatchlogReplayThrottleInKB

        public static void setBatchlogReplayThrottleInKB​(int throttleInKB)
      • getMaxHintsDeliveryThreads

        public static int getMaxHintsDeliveryThreads()
      • getHintsFlushPeriodInMS

        public static int getHintsFlushPeriodInMS()
      • getMaxHintsFileSize

        public static long getMaxHintsFileSize()
      • setHintsCompression

        public static void setHintsCompression​(ParameterizedClass parameterizedClass)
      • isIncrementalBackupsEnabled

        public static boolean isIncrementalBackupsEnabled()
      • setIncrementalBackupsEnabled

        public static void setIncrementalBackupsEnabled​(boolean value)
      • getFileCacheEnabled

        public static boolean getFileCacheEnabled()
      • getFileCacheSizeInMB

        public static int getFileCacheSizeInMB()
      • getNetworkingCacheSizeInMB

        public static int getNetworkingCacheSizeInMB()
      • getFileCacheRoundUp

        public static boolean getFileCacheRoundUp()
      • getDiskOptimizationEstimatePercentile

        public static double getDiskOptimizationEstimatePercentile()
      • getTotalCommitlogSpaceInMB

        public static long getTotalCommitlogSpaceInMB()
      • shouldMigrateKeycacheOnCompaction

        public static boolean shouldMigrateKeycacheOnCompaction()
      • setMigrateKeycacheOnCompaction

        public static void setMigrateKeycacheOnCompaction​(boolean migrateCacheEntry)
      • getSSTablePreemptiveOpenIntervalInMB

        public static int getSSTablePreemptiveOpenIntervalInMB()
      • setSSTablePreemptiveOpenIntervalInMB

        public static void setSSTablePreemptiveOpenIntervalInMB​(int mb)
      • getTrickleFsync

        public static boolean getTrickleFsync()
      • getTrickleFsyncIntervalInKb

        public static int getTrickleFsyncIntervalInKb()
      • getKeyCacheSizeInMB

        public static long getKeyCacheSizeInMB()
      • getIndexSummaryCapacityInMB

        public static long getIndexSummaryCapacityInMB()
      • 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()
      • getRowCacheSizeInMB

        public static long getRowCacheSizeInMB()
      • setRowCacheSizeInMB

        public static void setRowCacheSizeInMB​(long val)
      • getRowCacheSavePeriod

        public static int getRowCacheSavePeriod()
      • setRowCacheSavePeriod

        public static void setRowCacheSavePeriod​(int rowCacheSavePeriod)
      • getRowCacheKeysToSave

        public static int getRowCacheKeysToSave()
      • getCounterCacheSizeInMB

        public static long getCounterCacheSizeInMB()
      • 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()
      • getLocalDataCenter

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

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

        public static boolean getInterDCTcpNoDelay()
      • getMemtableHeapSpaceInMb

        public static long getMemtableHeapSpaceInMb()
      • getMemtableOffheapSpaceInMb

        public static long getMemtableOffheapSpaceInMb()
      • getRepairSessionMaxTreeDepth

        public static int getRepairSessionMaxTreeDepth()
      • setRepairSessionMaxTreeDepth

        public static void setRepairSessionMaxTreeDepth​(int depth)
      • getRepairSessionSpaceInMegabytes

        public static int getRepairSessionSpaceInMegabytes()
      • setRepairSessionSpaceInMegabytes

        public static void setRepairSessionSpaceInMegabytes​(int sizeInMegabytes)
      • getMemtableCleanupThreshold

        public static java.lang.Float getMemtableCleanupThreshold()
      • 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()
      • getWindowsTimerInterval

        public static int getWindowsTimerInterval()
      • getPreparedStatementsCacheSizeMB

        public static long getPreparedStatementsCacheSizeMB()
      • enableUserDefinedFunctions

        public static boolean enableUserDefinedFunctions()
      • enableScriptedUserDefinedFunctions

        public static boolean enableScriptedUserDefinedFunctions()
      • enableScriptedUserDefinedFunctions

        public static void enableScriptedUserDefinedFunctions​(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()
      • getEnableMaterializedViews

        public static boolean getEnableMaterializedViews()
      • setEnableMaterializedViews

        public static void setEnableMaterializedViews​(boolean enableMaterializedViews)
      • getEnableSASIIndexes

        public static boolean getEnableSASIIndexes()
      • setEnableSASIIndexes

        public static void setEnableSASIIndexes​(boolean enableSASIIndexes)
      • 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)
      • getCDCLogLocation

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

        public static int getCDCSpaceInMB()
      • setCDCSpaceInMB

        public static void setCDCSpaceInMB​(int input)
      • 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)
      • tableCountWarnThreshold

        public static int tableCountWarnThreshold()
      • setTableCountWarnThreshold

        public static void setTableCountWarnThreshold​(int value)
      • keyspaceCountWarnThreshold

        public static int keyspaceCountWarnThreshold()
      • setKeyspaceCountWarnThreshold

        public static void setKeyspaceCountWarnThreshold​(int value)
      • getConsecutiveMessageErrorsThreshold

        public static int getConsecutiveMessageErrorsThreshold()
      • setConsecutiveMessageErrorsThreshold

        public static void setConsecutiveMessageErrorsThreshold​(int value)
      • getForceNewPreparedStatementBehaviour

        public static boolean getForceNewPreparedStatementBehaviour()
      • setForceNewPreparedStatementBehaviour

        public static void setForceNewPreparedStatementBehaviour​(boolean value)