public interface StorageServiceMBean
extends javax.management.NotificationEmitter
Modifier and Type | Interface and Description |
---|---|
static class |
StorageServiceMBean.StageConcurrency
Gets the concurrency settings for processing stages
|
Modifier and Type | Method and Description |
---|---|
boolean |
autoOptimiseFullRepairStreams() |
boolean |
autoOptimiseIncRepairStreams() |
boolean |
autoOptimisePreviewRepairStreams() |
void |
bulkLoad(java.lang.String directory)
Starts a bulk load and blocks until it completes.
|
java.lang.String |
bulkLoadAsync(java.lang.String directory)
Starts a bulk load asynchronously and returns the String representation of the planID for the new
streaming session.
|
void |
bypassConcurrentValidatorsLimit() |
void |
cleanupSizeEstimates()
Removes extraneous entries in system.size_estimates.
|
void |
clearConnectionHistory()
Clears the history of clients that have connected in the past
|
void |
clearSnapshot(java.lang.String tag,
java.lang.String... keyspaceNames)
Remove the snapshot with the given name from the given keyspaces.
|
void |
decommission(boolean force)
transfer this node's data to other machines and remove it from service.
|
void |
deliverHints(java.lang.String host) |
java.util.List<java.lang.String> |
describeRingJMX(java.lang.String keyspace)
Deprecated.
|
java.util.List<java.lang.String> |
describeRingWithPortJMX(java.lang.String keyspace) |
void |
disableAuditLog() |
void |
disableAutoCompaction(java.lang.String ks,
java.lang.String... tables) |
void |
disableNativeTransportOldProtocolVersions() |
void |
drain()
makes node unavailable for writes, flushes memtables and replays commitlog.
|
java.util.Map<java.net.InetAddress,java.lang.Float> |
effectiveOwnership(java.lang.String keyspace)
Deprecated.
|
java.util.Map<java.lang.String,java.lang.Float> |
effectiveOwnershipWithPort(java.lang.String keyspace) |
void |
enableAuditLog(java.lang.String loggerName,
java.util.Map<java.lang.String,java.lang.String> parameters,
java.lang.String includedKeyspaces,
java.lang.String excludedKeyspaces,
java.lang.String includedCategories,
java.lang.String excludedCategories,
java.lang.String includedUsers,
java.lang.String excludedUsers) |
void |
enableAuditLog(java.lang.String loggerName,
java.lang.String includedKeyspaces,
java.lang.String excludedKeyspaces,
java.lang.String includedCategories,
java.lang.String excludedCategories,
java.lang.String includedUsers,
java.lang.String excludedUsers) |
void |
enableAutoCompaction(java.lang.String ks,
java.lang.String... tables) |
void |
enableFullQueryLogger(java.lang.String path,
java.lang.String rollCycle,
java.lang.Boolean blocking,
int maxQueueWeight,
long maxLogSize,
java.lang.String archiveCommand,
int maxArchiveRetries)
Start the fully query logger.
|
void |
enableNativeTransportOldProtocolVersions() |
void |
enforceConcurrentValidatorsLimit() |
int |
forceKeyspaceCleanup(int jobs,
java.lang.String keyspaceName,
java.lang.String... tables) |
int |
forceKeyspaceCleanup(java.lang.String keyspaceName,
java.lang.String... tables)
Deprecated.
|
void |
forceKeyspaceCompaction(boolean splitOutput,
java.lang.String keyspaceName,
java.lang.String... tableNames)
Forces major compaction of a single keyspace
|
void |
forceKeyspaceCompactionForTokenRange(java.lang.String keyspaceName,
java.lang.String startToken,
java.lang.String endToken,
java.lang.String... tableNames)
Forces major compaction of specified token range in a single keyspace
|
void |
forceKeyspaceFlush(java.lang.String keyspaceName,
java.lang.String... tableNames)
Flush all memtables for the given column families, or all columnfamilies for the given keyspace
if none are explicitly listed.
|
void |
forceRemoveCompletion()
Force a remove operation to finish.
|
void |
forceTerminateAllRepairSessions() |
int |
garbageCollect(java.lang.String tombstoneOption,
int jobs,
java.lang.String keyspaceName,
java.lang.String... tableNames)
Rewrites all sstables from the given tables to remove deleted data.
|
java.lang.String[] |
getAllDataFileLocations()
Get the list of all data file locations from conf
|
java.util.Map<java.lang.String,java.lang.Boolean> |
getAutoCompactionStatus(java.lang.String ks,
java.lang.String... tables) |
int |
getBatchlogReplayThrottleInKB() |
int |
getBatchSizeFailureThreshold()
Returns the threshold for rejecting queries due to a large batch size
|
int |
getBatchSizeWarnThreshold()
Returns the threshold for warning queries due to a large batch size
|
int |
getCachedReplicaRowsFailThreshold()
Returns the number of rows cached at the coordinator before filtering/index queries fail outright.
|
int |
getCachedReplicaRowsWarnThreshold()
Returns the number of rows cached at the coordinator before filtering/index queries log a warning.
|
long |
getCasContentionTimeout() |
java.lang.String |
getClusterName()
Returns the name of the cluster
|
int |
getColumnIndexCacheSize()
Returns the threshold for skipping the column index when caching partition info
|
java.lang.String |
getCommitLogLocation()
Get location of the commit log
|
int |
getCompactionThroughputMbPerSec() |
java.util.Map<java.lang.String,java.util.List<java.lang.Integer>> |
getConcurrency(java.util.List<java.lang.String> stageNames) |
int |
getConcurrentCompactors() |
int |
getConcurrentValidators() |
int |
getConcurrentViewBuilders() |
java.lang.String |
getCorruptedTombstoneStrategy() |
long |
getCounterWriteRpcTimeout() |
int |
getCurrentGenerationNumber()
Return the generation value for this node.
|
java.lang.String |
getDrainProgress()
get the progress of a drain operation
|
int |
getDynamicUpdateInterval() |
java.util.Map<java.lang.String,java.lang.String> |
getEndpointToHostId()
Deprecated.
|
java.util.Map<java.lang.String,java.lang.String> |
getEndpointWithPortToHostId() |
javax.management.openmbean.CompositeData |
getFullQueryLoggerOptions()
Returns the current state of FQL.
|
java.util.Map<java.lang.String,java.lang.String> |
getHostIdMap()
Deprecated.
|
java.util.Map<java.lang.String,java.lang.String> |
getHostIdToEndpoint()
Deprecated.
|
java.util.Map<java.lang.String,java.lang.String> |
getHostIdToEndpointWithPort() |
int |
getInitialRangeTombstoneListAllocationSize()
Returns the initial allocation size of backing arrays for new RangeTombstoneList objects
|
int |
getInterDCStreamThroughputMbPerSec() |
int |
getInternodeStreamingTcpUserTimeoutInMS() |
int |
getInternodeTcpConnectTimeoutInMS() |
int |
getInternodeTcpUserTimeoutInMS() |
java.util.List<java.lang.String> |
getJoiningNodes()
Deprecated.
|
java.util.List<java.lang.String> |
getJoiningNodesWithPort() |
int |
getKeyspaceCountWarnThreshold() |
java.lang.String |
getKeyspaceReplicationInfo(java.lang.String keyspaceName)
Fetch the replication factor for a given keyspace.
|
java.util.List<java.lang.String> |
getKeyspaces() |
java.util.List<java.lang.String> |
getLeavingNodes()
Deprecated.
|
java.util.List<java.lang.String> |
getLeavingNodesWithPort() |
java.util.List<java.lang.String> |
getLiveNodes()
Deprecated.
|
java.util.List<java.lang.String> |
getLiveNodesWithPort() |
java.util.Map<java.lang.String,java.lang.String> |
getLoadMap()
Deprecated.
|
java.util.Map<java.lang.String,java.lang.String> |
getLoadMapWithPort() |
java.lang.String |
getLoadString()
Human-readable load value
|
java.lang.String |
getLocalHostId()
Retrieve this hosts unique ID
|
java.lang.String[] |
getLocalSystemKeyspacesDataFileLocations()
Returns the locations where the local system keyspaces data should be stored.
|
java.util.Map<java.lang.String,java.lang.String> |
getLoggingLevels()
get the runtime logging levels
|
boolean |
getMigrateKeycacheOnCompaction() |
java.util.List<java.lang.String> |
getMovingNodes()
Deprecated.
|
java.util.List<java.lang.String> |
getMovingNodesWithPort() |
long |
getNativeTransportMaxConcurrentRequestsInBytes() |
long |
getNativeTransportMaxConcurrentRequestsInBytesPerIp() |
java.util.List<java.net.InetAddress> |
getNaturalEndpoints(java.lang.String keyspaceName,
java.nio.ByteBuffer key)
Deprecated.
|
java.util.List<java.net.InetAddress> |
getNaturalEndpoints(java.lang.String keyspaceName,
java.lang.String cf,
java.lang.String key)
Deprecated.
|
java.util.List<java.lang.String> |
getNaturalEndpointsWithPort(java.lang.String keysapceName,
java.nio.ByteBuffer key) |
java.util.List<java.lang.String> |
getNaturalEndpointsWithPort(java.lang.String keyspaceName,
java.lang.String cf,
java.lang.String key) |
java.util.List<java.lang.String> |
getNonLocalStrategyKeyspaces() |
java.lang.String[] |
getNonLocalSystemKeyspacesDataFileLocations()
Returns the locations where should be stored the non system keyspaces data.
|
java.util.List<java.lang.String> |
getNonSystemKeyspaces() |
java.lang.String |
getOperationMode()
get the operational mode (leaving, joining, normal, decommissioned, client)
|
java.util.Map<java.lang.String,java.util.Set<java.net.InetAddress>> |
getOutstandingSchemaVersions()
Deprecated.
|
java.util.Map<java.lang.String,java.util.Set<java.lang.String>> |
getOutstandingSchemaVersionsWithPort() |
java.util.Map<java.net.InetAddress,java.lang.Float> |
getOwnership()
Deprecated.
|
java.util.Map<java.lang.String,java.lang.Float> |
getOwnershipWithPort() |
java.util.List<java.lang.String> |
getParentRepairStatus(int cmd)
Get the status of a given parent repair session.
|
java.lang.String |
getPartitionerName()
Returns the cluster partitioner
|
java.util.Map<java.util.List<java.lang.String>,java.util.List<java.lang.String>> |
getPendingRangeToEndpointMap(java.lang.String keyspace)
Deprecated.
|
java.util.Map<java.util.List<java.lang.String>,java.util.List<java.lang.String>> |
getPendingRangeToEndpointWithPortMap(java.lang.String keyspace) |
long |
getRangeRpcTimeout() |
java.util.Map<java.util.List<java.lang.String>,java.util.List<java.lang.String>> |
getRangeToEndpointMap(java.lang.String keyspace)
Deprecated.
|
java.util.Map<java.util.List<java.lang.String>,java.util.List<java.lang.String>> |
getRangeToEndpointWithPortMap(java.lang.String keyspace) |
double |
getRangeTombstoneResizeListGrowthFactor()
Returns the resize factor to use when growing/resizing a RangeTombstoneList
|
java.util.Map<java.util.List<java.lang.String>,java.util.List<java.lang.String>> |
getRangeToNativeaddressWithPortMap(java.lang.String keyspace) |
java.util.Map<java.util.List<java.lang.String>,java.util.List<java.lang.String>> |
getRangeToRpcaddressMap(java.lang.String keyspace)
Deprecated.
|
long |
getReadRpcTimeout() |
java.lang.String |
getReleaseVersion()
Fetch a string representation of the Cassandra version.
|
java.lang.String |
getRemovalStatus()
Deprecated.
|
java.lang.String |
getRemovalStatusWithPort() |
int |
getRepairSessionMaxTreeDepth() |
long |
getRpcTimeout() |
java.lang.String |
getSavedCachesLocation()
Get location of the saved caches dir
|
java.lang.String |
getSchemaVersion()
Fetch a string representation of the current Schema version.
|
java.util.Map<java.lang.String,javax.management.openmbean.TabularData> |
getSnapshotDetails()
Get the details of all the snapshot
|
long |
getSnapshotLinksPerSecond()
Get the current hardlink-per-second throttle for snapshots
A setting of zero indicates no throttling.
|
int |
getSSTablePreemptiveOpenIntervalInMB() |
int |
getStreamThroughputMbPerSec() |
int |
getTableCountWarnThreshold() |
java.util.List<java.lang.String> |
getTokens()
Fetch string representations of the tokens for this node.
|
java.util.List<java.lang.String> |
getTokens(java.lang.String endpoint)
Fetch string representations of the tokens for a specified node.
|
java.util.Map<java.lang.String,java.lang.String> |
getTokenToEndpointMap()
Deprecated.
|
java.util.Map<java.lang.String,java.lang.String> |
getTokenToEndpointWithPortMap() |
int |
getTombstoneFailureThreshold()
Returns the threshold for abandoning queries with many tombstones
|
int |
getTombstoneWarnThreshold()
Returns the threshold for warning of queries with many tombstones
|
double |
getTraceProbability()
Returns the configured tracing probability.
|
long |
getTruncateRpcTimeout() |
java.util.List<java.lang.String> |
getUnreachableNodes()
Deprecated.
|
java.util.List<java.lang.String> |
getUnreachableNodesWithPort() |
java.util.Map<java.lang.String,java.lang.String> |
getViewBuildStatuses(java.lang.String keyspace,
java.lang.String view)
Deprecated.
|
java.util.Map<java.lang.String,java.lang.String> |
getViewBuildStatusesWithPort(java.lang.String keyspace,
java.lang.String view) |
long |
getWriteRpcTimeout() |
boolean |
isAuditLogEnabled() |
boolean |
isBootstrapMode()
Check if currently bootstrapping.
|
boolean |
isConcurrentValidatorsLimitEnforced() |
boolean |
isDrained() |
boolean |
isDraining() |
boolean |
isFullQueryLogEnabled() |
boolean |
isGossipRunning() |
boolean |
isIncrementalBackupsEnabled() |
boolean |
isInitialized() |
boolean |
isJoined() |
boolean |
isNativeTransportRunning() |
boolean |
isStarting()
Returns whether the storage service is starting or not
|
void |
joinRing() |
void |
loadNewSSTables(java.lang.String ksName,
java.lang.String tableName)
Deprecated.
|
void |
move(java.lang.String newToken) |
void |
rebuild(java.lang.String sourceDc)
Initiate a process of streaming data for which we are responsible from other nodes.
|
void |
rebuild(java.lang.String sourceDc,
java.lang.String keyspace,
java.lang.String tokens,
java.lang.String specificSources)
Same as
rebuild(String) , but only for specified keyspace and ranges. |
void |
rebuildSecondaryIndex(java.lang.String ksName,
java.lang.String cfName,
java.lang.String... idxNames)
rebuild the specified indexes
|
void |
refreshSizeEstimates()
Forces refresh of values stored in system.size_estimates of all column families.
|
void |
reloadLocalSchema() |
int |
relocateSSTables(int jobs,
java.lang.String keyspace,
java.lang.String... cfnames) |
int |
relocateSSTables(java.lang.String keyspace,
java.lang.String... cfnames)
Deprecated.
|
void |
removeNode(java.lang.String token)
removeToken removes token (and all data associated with
enpoint that had it) from the ring
|
int |
repairAsync(java.lang.String keyspace,
java.util.Map<java.lang.String,java.lang.String> options)
Invoke repair asynchronously.
|
void |
rescheduleFailedDeletions() |
void |
resetFullQueryLogger()
Disable the full query logger if it is enabled.
|
void |
resetLocalSchema() |
boolean |
resumeBootstrap()
Resume bootstrap streaming when there is failed data streaming.
|
java.util.List<java.lang.String> |
sampleKeyRange()
Return a List of Tokens representing a sample of keys across all ColumnFamilyStores.
|
java.util.Map<java.lang.String,java.util.List<javax.management.openmbean.CompositeData>> |
samplePartitions(int duration,
int capacity,
int count,
java.util.List<java.lang.String> samplers) |
int |
scrub(boolean disableSnapshot,
boolean skipCorrupted,
boolean checkData,
boolean reinsertOverflowedTTL,
int jobs,
java.lang.String keyspaceName,
java.lang.String... columnFamilies) |
int |
scrub(boolean disableSnapshot,
boolean skipCorrupted,
boolean checkData,
int jobs,
java.lang.String keyspaceName,
java.lang.String... columnFamilies)
Deprecated.
|
int |
scrub(boolean disableSnapshot,
boolean skipCorrupted,
boolean checkData,
java.lang.String keyspaceName,
java.lang.String... tableNames)
Deprecated.
|
int |
scrub(boolean disableSnapshot,
boolean skipCorrupted,
java.lang.String keyspaceName,
java.lang.String... tableNames)
Deprecated.
|
void |
setAutoOptimiseFullRepairStreams(boolean enabled) |
void |
setAutoOptimiseIncRepairStreams(boolean enabled) |
void |
setAutoOptimisePreviewRepairStreams(boolean enabled) |
void |
setBatchlogReplayThrottleInKB(int value) |
void |
setBatchSizeFailureThreshold(int batchSizeDebugThreshold)
Sets the threshold for rejecting queries due to a large batch size
|
void |
setBatchSizeWarnThreshold(int batchSizeDebugThreshold)
Sets the threshold for warning queries due to a large batch size
|
void |
setCachedReplicaRowsFailThreshold(int threshold)
Sets the number of rows cached at the coordinator before filtering/index queries fail outright.
|
void |
setCachedReplicaRowsWarnThreshold(int threshold)
Sets the number of rows cached at the coordinator before filtering/index queries log a warning.
|
void |
setCasContentionTimeout(long value) |
void |
setColumnIndexCacheSize(int cacheSizeInKB)
Sets the threshold for skipping the column index when caching partition info
|
void |
setCompactionThroughputMbPerSec(int value) |
void |
setConcurrency(java.lang.String threadPoolName,
int newCorePoolSize,
int newMaximumPoolSize)
Sets the concurrency setting for processing stages
|
void |
setConcurrentCompactors(int value) |
void |
setConcurrentValidators(int value) |
void |
setConcurrentViewBuilders(int value) |
void |
setCorruptedTombstoneStrategy(java.lang.String strategy) |
void |
setCounterWriteRpcTimeout(long value) |
void |
setDynamicUpdateInterval(int dynamicUpdateInterval) |
void |
setHintedHandoffThrottleInKB(int throttleInKB)
Sets the hinted handoff throttle in kb per second, per delivery thread.
|
void |
setIncrementalBackupsEnabled(boolean value) |
void |
setInitialRangeTombstoneListAllocationSize(int size)
Sets the initial allocation size of backing arrays for new RangeTombstoneList objects
|
void |
setInterDCStreamThroughputMbPerSec(int value) |
void |
setInternodeStreamingTcpUserTimeoutInMS(int value) |
void |
setInternodeTcpConnectTimeoutInMS(int value) |
void |
setInternodeTcpUserTimeoutInMS(int value) |
void |
setKeyspaceCountWarnThreshold(int value) |
void |
setLoggingLevel(java.lang.String classQualifier,
java.lang.String level)
set the logging level at runtime
If both classQualifer and level are empty/null, it will reload the configuration to reset. If classQualifer is not empty but level is empty/null, it will set the level to null for the defined classQualifer If level cannot be parsed, then the level will be defaulted to DEBUG The logback configuration should have < jmxConfigurator /> set |
void |
setMigrateKeycacheOnCompaction(boolean invalidateKeyCacheOnCompaction) |
void |
setNativeTransportMaxConcurrentRequestsInBytes(long newLimit) |
void |
setNativeTransportMaxConcurrentRequestsInBytesPerIp(long newLimit) |
void |
setRangeRpcTimeout(long value) |
void |
setRangeTombstoneListResizeGrowthFactor(double growthFactor)
Sets the resize factor to use when growing/resizing a RangeTombstoneList
|
void |
setReadRpcTimeout(long value) |
void |
setRepairSessionMaxTreeDepth(int depth) |
void |
setRpcTimeout(long value) |
void |
setSnapshotLinksPerSecond(long throttle)
Set the current hardlink-per-second throttle for snapshots
A setting of zero indicates no throttling
|
void |
setSSTablePreemptiveOpenIntervalInMB(int intervalInMB) |
void |
setStreamThroughputMbPerSec(int value) |
void |
setTableCountWarnThreshold(int value) |
void |
setTombstoneFailureThreshold(int tombstoneDebugThreshold)
Sets the threshold for abandoning queries with many tombstones
|
void |
setTombstoneWarnThreshold(int tombstoneDebugThreshold)
Sets the threshold for warning queries with many tombstones
|
void |
setTraceProbability(double probability)
Enables/Disables tracing for the whole system.
|
void |
setTruncateRpcTimeout(long value) |
void |
setWriteRpcTimeout(long value) |
void |
startGossiping() |
void |
startNativeTransport() |
void |
stopDaemon() |
void |
stopFullQueryLogger()
Stop logging queries but leave any generated files on disk.
|
void |
stopGossiping() |
void |
stopNativeTransport() |
void |
takeMultipleTableSnapshot(java.lang.String tag,
java.lang.String... tableList)
Deprecated.
|
void |
takeSnapshot(java.lang.String tag,
java.util.Map<java.lang.String,java.lang.String> options,
java.lang.String... entities)
Takes the snapshot of a multiple column family from different keyspaces.
|
void |
takeSnapshot(java.lang.String tag,
java.lang.String... keyspaceNames)
Deprecated.
|
void |
takeTableSnapshot(java.lang.String keyspaceName,
java.lang.String tableName,
java.lang.String tag)
Deprecated.
|
long |
trueSnapshotsSize()
Get the true size taken by all snapshots across all keyspaces.
|
void |
truncate(java.lang.String keyspace,
java.lang.String table)
Truncates (deletes) the given table from the provided keyspace.
|
void |
updateSnitch(java.lang.String epSnitchClassName,
java.lang.Boolean dynamic,
java.lang.Integer dynamicUpdateInterval,
java.lang.Integer dynamicResetInterval,
java.lang.Double dynamicBadnessThreshold)
Change endpointsnitch class and dynamic-ness (and dynamic attributes) at runtime.
|
int |
upgradeSSTables(java.lang.String keyspaceName,
boolean excludeCurrentVersion,
int jobs,
java.lang.String... tableNames) |
int |
upgradeSSTables(java.lang.String keyspaceName,
boolean excludeCurrentVersion,
java.lang.String... tableNames)
Deprecated.
|
int |
verify(boolean extendedVerify,
boolean checkVersion,
boolean diskFailurePolicy,
boolean mutateRepairStatus,
boolean checkOwnsTokens,
boolean quick,
java.lang.String keyspaceName,
java.lang.String... tableNames) |
int |
verify(boolean extendedVerify,
java.lang.String keyspaceName,
java.lang.String... tableNames)
Verify (checksums of) the given keyspace.
|
@Deprecated java.util.List<java.lang.String> getLiveNodes()
java.util.List<java.lang.String> getLiveNodesWithPort()
@Deprecated java.util.List<java.lang.String> getUnreachableNodes()
java.util.List<java.lang.String> getUnreachableNodesWithPort()
@Deprecated java.util.List<java.lang.String> getJoiningNodes()
java.util.List<java.lang.String> getJoiningNodesWithPort()
@Deprecated java.util.List<java.lang.String> getLeavingNodes()
java.util.List<java.lang.String> getLeavingNodesWithPort()
@Deprecated java.util.List<java.lang.String> getMovingNodes()
java.util.List<java.lang.String> getMovingNodesWithPort()
java.util.List<java.lang.String> getTokens()
java.util.List<java.lang.String> getTokens(java.lang.String endpoint) throws java.net.UnknownHostException
endpoint
- string representation of an nodejava.net.UnknownHostException
java.lang.String getReleaseVersion()
java.lang.String getSchemaVersion()
java.lang.String getKeyspaceReplicationInfo(java.lang.String keyspaceName)
java.lang.String[] getAllDataFileLocations()
java.lang.String[] getLocalSystemKeyspacesDataFileLocations()
java.lang.String[] getNonLocalSystemKeyspacesDataFileLocations()
java.lang.String getCommitLogLocation()
java.lang.String getSavedCachesLocation()
@Deprecated java.util.Map<java.util.List<java.lang.String>,java.util.List<java.lang.String>> getRangeToEndpointMap(java.lang.String keyspace)
java.util.Map<java.util.List<java.lang.String>,java.util.List<java.lang.String>> getRangeToEndpointWithPortMap(java.lang.String keyspace)
@Deprecated java.util.Map<java.util.List<java.lang.String>,java.util.List<java.lang.String>> getRangeToRpcaddressMap(java.lang.String keyspace)
java.util.Map<java.util.List<java.lang.String>,java.util.List<java.lang.String>> getRangeToNativeaddressWithPortMap(java.lang.String keyspace)
@Deprecated java.util.List<java.lang.String> describeRingJMX(java.lang.String keyspace) throws java.io.IOException
describeRing(String)
but converts TokenRange to the String for JMX compatibilitykeyspace
- The keyspace to fetch information aboutjava.io.IOException
java.util.List<java.lang.String> describeRingWithPortJMX(java.lang.String keyspace) throws java.io.IOException
java.io.IOException
@Deprecated java.util.Map<java.util.List<java.lang.String>,java.util.List<java.lang.String>> getPendingRangeToEndpointMap(java.lang.String keyspace)
keyspace
- the keyspace to get the pending range map for.java.util.Map<java.util.List<java.lang.String>,java.util.List<java.lang.String>> getPendingRangeToEndpointWithPortMap(java.lang.String keyspace)
@Deprecated java.util.Map<java.lang.String,java.lang.String> getTokenToEndpointMap()
java.util.Map<java.lang.String,java.lang.String> getTokenToEndpointWithPortMap()
java.lang.String getLocalHostId()
@Deprecated java.util.Map<java.lang.String,java.lang.String> getHostIdMap()
@Deprecated java.util.Map<java.lang.String,java.lang.String> getEndpointToHostId()
java.util.Map<java.lang.String,java.lang.String> getEndpointWithPortToHostId()
@Deprecated java.util.Map<java.lang.String,java.lang.String> getHostIdToEndpoint()
java.util.Map<java.lang.String,java.lang.String> getHostIdToEndpointWithPort()
java.lang.String getLoadString()
@Deprecated java.util.Map<java.lang.String,java.lang.String> getLoadMap()
java.util.Map<java.lang.String,java.lang.String> getLoadMapWithPort()
int getCurrentGenerationNumber()
@Deprecated java.util.List<java.net.InetAddress> getNaturalEndpoints(java.lang.String keyspaceName, java.lang.String cf, java.lang.String key)
keyspaceName
- keyspace namecf
- Column family namekey
- - key for which we need to find the endpoint return value -
the endpoint responsible for this keyjava.util.List<java.lang.String> getNaturalEndpointsWithPort(java.lang.String keyspaceName, java.lang.String cf, java.lang.String key)
@Deprecated java.util.List<java.net.InetAddress> getNaturalEndpoints(java.lang.String keyspaceName, java.nio.ByteBuffer key)
java.util.List<java.lang.String> getNaturalEndpointsWithPort(java.lang.String keysapceName, java.nio.ByteBuffer key)
@Deprecated void takeSnapshot(java.lang.String tag, java.lang.String... keyspaceNames) throws java.io.IOException
takeSnapshot(String tag, Map options, String... entities)
instead.java.io.IOException
@Deprecated void takeTableSnapshot(java.lang.String keyspaceName, java.lang.String tableName, java.lang.String tag) throws java.io.IOException
takeSnapshot(String tag, Map options, String... entities)
instead.java.io.IOException
@Deprecated void takeMultipleTableSnapshot(java.lang.String tag, java.lang.String... tableList) throws java.io.IOException
takeSnapshot(String tag, Map options, String... entities)
instead.java.io.IOException
void takeSnapshot(java.lang.String tag, java.util.Map<java.lang.String,java.lang.String> options, java.lang.String... entities) throws java.io.IOException
tag
- the tag given to the snapshot; may not be null or emptyoptions
- Map of options (skipFlush is the only supported option for now)entities
- list of keyspaces / tables in the form of empty | ks1 ks2 ... | ks1.cf1,ks2.cf2,...java.io.IOException
void clearSnapshot(java.lang.String tag, java.lang.String... keyspaceNames) throws java.io.IOException
java.io.IOException
java.util.Map<java.lang.String,javax.management.openmbean.TabularData> getSnapshotDetails()
long trueSnapshotsSize()
void setSnapshotLinksPerSecond(long throttle)
throttle
- long getSnapshotLinksPerSecond()
void refreshSizeEstimates() throws java.util.concurrent.ExecutionException
java.util.concurrent.ExecutionException
void cleanupSizeEstimates()
void forceKeyspaceCompaction(boolean splitOutput, java.lang.String keyspaceName, java.lang.String... tableNames) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
@Deprecated int relocateSSTables(java.lang.String keyspace, java.lang.String... cfnames) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
int relocateSSTables(int jobs, java.lang.String keyspace, java.lang.String... cfnames) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
void forceKeyspaceCompactionForTokenRange(java.lang.String keyspaceName, java.lang.String startToken, java.lang.String endToken, java.lang.String... tableNames) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
@Deprecated int forceKeyspaceCleanup(java.lang.String keyspaceName, java.lang.String... tables) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
int forceKeyspaceCleanup(int jobs, java.lang.String keyspaceName, java.lang.String... tables) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
@Deprecated int scrub(boolean disableSnapshot, boolean skipCorrupted, java.lang.String keyspaceName, java.lang.String... tableNames) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
@Deprecated int scrub(boolean disableSnapshot, boolean skipCorrupted, boolean checkData, java.lang.String keyspaceName, java.lang.String... tableNames) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
@Deprecated int scrub(boolean disableSnapshot, boolean skipCorrupted, boolean checkData, int jobs, java.lang.String keyspaceName, java.lang.String... columnFamilies) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
int scrub(boolean disableSnapshot, boolean skipCorrupted, boolean checkData, boolean reinsertOverflowedTTL, int jobs, java.lang.String keyspaceName, java.lang.String... columnFamilies) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
int verify(boolean extendedVerify, java.lang.String keyspaceName, java.lang.String... tableNames) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
int verify(boolean extendedVerify, boolean checkVersion, boolean diskFailurePolicy, boolean mutateRepairStatus, boolean checkOwnsTokens, boolean quick, java.lang.String keyspaceName, java.lang.String... tableNames) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
@Deprecated int upgradeSSTables(java.lang.String keyspaceName, boolean excludeCurrentVersion, java.lang.String... tableNames) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
int upgradeSSTables(java.lang.String keyspaceName, boolean excludeCurrentVersion, int jobs, java.lang.String... tableNames) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
int garbageCollect(java.lang.String tombstoneOption, int jobs, java.lang.String keyspaceName, java.lang.String... tableNames) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
void forceKeyspaceFlush(java.lang.String keyspaceName, java.lang.String... tableNames) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
keyspaceName
- tableNames
- java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
int repairAsync(java.lang.String keyspace, java.util.Map<java.lang.String,java.lang.String> options)
keyspace
- Keyspace name to repair. Should not be null.options
- repair option.void forceTerminateAllRepairSessions()
void setRepairSessionMaxTreeDepth(int depth)
int getRepairSessionMaxTreeDepth()
@Nullable java.util.List<java.lang.String> getParentRepairStatus(int cmd)
cmd
- the int reference returned when issuing the repairorg.apache.cassandra.repair.RepairRunnable.Status
followed by final message or messages of the sessionvoid decommission(boolean force) throws java.lang.InterruptedException
force
- Decommission even if this will reduce N to be less than RF.java.lang.InterruptedException
void move(java.lang.String newToken) throws java.io.IOException
newToken
- token to move this node to.
This node will unload its data onto its neighbors, and bootstrap to the new token.java.io.IOException
void removeNode(java.lang.String token)
@Deprecated java.lang.String getRemovalStatus()
java.lang.String getRemovalStatusWithPort()
void forceRemoveCompletion()
void setLoggingLevel(java.lang.String classQualifier, java.lang.String level) throws java.lang.Exception
< jmxConfigurator />
setclassQualifier
- The logger's classQualiferlevel
- The log leveljava.lang.Exception
Level.toLevel(String)
java.util.Map<java.lang.String,java.lang.String> getLoggingLevels()
java.lang.String getOperationMode()
boolean isStarting()
java.lang.String getDrainProgress()
void drain() throws java.io.IOException, java.lang.InterruptedException, java.util.concurrent.ExecutionException
java.io.IOException
java.lang.InterruptedException
java.util.concurrent.ExecutionException
void truncate(java.lang.String keyspace, java.lang.String table) throws java.util.concurrent.TimeoutException, java.io.IOException
keyspace
- The keyspace to delete fromtable
- The column family to delete data from.java.util.concurrent.TimeoutException
java.io.IOException
@Deprecated java.util.Map<java.net.InetAddress,java.lang.Float> getOwnership()
"token -> %age of cluster owned by that token"
java.util.Map<java.lang.String,java.lang.Float> getOwnershipWithPort()
@Deprecated java.util.Map<java.net.InetAddress,java.lang.Float> effectiveOwnership(java.lang.String keyspace) throws java.lang.IllegalStateException
java.lang.IllegalStateException
java.util.Map<java.lang.String,java.lang.Float> effectiveOwnershipWithPort(java.lang.String keyspace) throws java.lang.IllegalStateException
java.lang.IllegalStateException
java.util.List<java.lang.String> getKeyspaces()
java.util.List<java.lang.String> getNonSystemKeyspaces()
java.util.List<java.lang.String> getNonLocalStrategyKeyspaces()
@Deprecated java.util.Map<java.lang.String,java.lang.String> getViewBuildStatuses(java.lang.String keyspace, java.lang.String view)
java.util.Map<java.lang.String,java.lang.String> getViewBuildStatusesWithPort(java.lang.String keyspace, java.lang.String view)
void updateSnitch(java.lang.String epSnitchClassName, java.lang.Boolean dynamic, java.lang.Integer dynamicUpdateInterval, java.lang.Integer dynamicResetInterval, java.lang.Double dynamicBadnessThreshold) throws java.lang.ClassNotFoundException
epSnitchClassName
is specified, it will configure a new snitch instance and make it a
'dynamic snitch' if dynamic
is specified and true
.
The parameters dynamicUpdateInterval
, dynamicResetInterval
and dynamicBadnessThreshold
can be specified individually to update the parameters of the dynamic snitch during runtime.epSnitchClassName
- the canonical path name for a class implementing IEndpointSnitchdynamic
- boolean that decides whether dynamicsnitch is used or not - only valid, if epSnitchClassName
is specifieddynamicUpdateInterval
- integer, in ms (defaults to the value configured in cassandra.yaml, which defaults to 100)dynamicResetInterval
- integer, in ms (defaults to the value configured in cassandra.yaml, which defaults to 600,000)dynamicBadnessThreshold
- double, (defaults to the value configured in cassandra.yaml, which defaults to 0.0)java.lang.ClassNotFoundException
void setDynamicUpdateInterval(int dynamicUpdateInterval)
int getDynamicUpdateInterval()
void stopGossiping()
void startGossiping()
boolean isGossipRunning()
void stopDaemon()
boolean isInitialized()
void stopNativeTransport()
void startNativeTransport()
boolean isNativeTransportRunning()
void enableNativeTransportOldProtocolVersions()
void disableNativeTransportOldProtocolVersions()
long getNativeTransportMaxConcurrentRequestsInBytes()
void setNativeTransportMaxConcurrentRequestsInBytes(long newLimit)
long getNativeTransportMaxConcurrentRequestsInBytesPerIp()
void setNativeTransportMaxConcurrentRequestsInBytesPerIp(long newLimit)
void joinRing() throws java.io.IOException
java.io.IOException
boolean isJoined()
boolean isDrained()
boolean isDraining()
boolean isBootstrapMode()
SystemKeyspace.bootstrapComplete()
is called,
as setting bootstrap to complete is called only when the node joins the ring.void setRpcTimeout(long value)
long getRpcTimeout()
void setReadRpcTimeout(long value)
long getReadRpcTimeout()
void setRangeRpcTimeout(long value)
long getRangeRpcTimeout()
void setWriteRpcTimeout(long value)
long getWriteRpcTimeout()
void setInternodeTcpConnectTimeoutInMS(int value)
int getInternodeTcpConnectTimeoutInMS()
void setInternodeTcpUserTimeoutInMS(int value)
int getInternodeTcpUserTimeoutInMS()
void setInternodeStreamingTcpUserTimeoutInMS(int value)
int getInternodeStreamingTcpUserTimeoutInMS()
void setCounterWriteRpcTimeout(long value)
long getCounterWriteRpcTimeout()
void setCasContentionTimeout(long value)
long getCasContentionTimeout()
void setTruncateRpcTimeout(long value)
long getTruncateRpcTimeout()
void setStreamThroughputMbPerSec(int value)
int getStreamThroughputMbPerSec()
void setInterDCStreamThroughputMbPerSec(int value)
int getInterDCStreamThroughputMbPerSec()
int getCompactionThroughputMbPerSec()
void setCompactionThroughputMbPerSec(int value)
int getBatchlogReplayThrottleInKB()
void setBatchlogReplayThrottleInKB(int value)
int getConcurrentCompactors()
void setConcurrentCompactors(int value)
void bypassConcurrentValidatorsLimit()
void enforceConcurrentValidatorsLimit()
boolean isConcurrentValidatorsLimitEnforced()
int getConcurrentValidators()
void setConcurrentValidators(int value)
int getSSTablePreemptiveOpenIntervalInMB()
void setSSTablePreemptiveOpenIntervalInMB(int intervalInMB)
boolean getMigrateKeycacheOnCompaction()
void setMigrateKeycacheOnCompaction(boolean invalidateKeyCacheOnCompaction)
int getConcurrentViewBuilders()
void setConcurrentViewBuilders(int value)
boolean isIncrementalBackupsEnabled()
void setIncrementalBackupsEnabled(boolean value)
void rebuild(java.lang.String sourceDc)
sourceDc
- Name of DC from which to select sources for streaming or null to pick any nodevoid rebuild(java.lang.String sourceDc, java.lang.String keyspace, java.lang.String tokens, java.lang.String specificSources)
rebuild(String)
, but only for specified keyspace and ranges.sourceDc
- Name of DC from which to select sources for streaming or null to pick any nodekeyspace
- Name of the keyspace which to rebuild or null to rebuild all keyspaces.tokens
- Range of tokens to rebuild or null to rebuild all token ranges. In the format of:
"(start_token_1,end_token_1],(start_token_2,end_token_2],...(start_token_n,end_token_n]"void bulkLoad(java.lang.String directory)
java.lang.String bulkLoadAsync(java.lang.String directory)
void rescheduleFailedDeletions()
@Deprecated void loadNewSSTables(java.lang.String ksName, java.lang.String tableName)
ksName
- The parent keyspace nametableName
- The ColumnFamily name where SSTables belongColumnFamilyStoreMBean.loadNewSSTables()
java.util.List<java.lang.String> sampleKeyRange()
void rebuildSecondaryIndex(java.lang.String ksName, java.lang.String cfName, java.lang.String... idxNames)
void resetLocalSchema() throws java.io.IOException
java.io.IOException
void reloadLocalSchema()
void setTraceProbability(double probability)
probability
- ]0,1[ will enable tracing on a partial number of requests with the provided probability. 0 will
disable tracing and 1 will enable tracing for all requests (which mich severely cripple the system)java.util.Map<java.lang.String,java.util.List<javax.management.openmbean.CompositeData>> samplePartitions(int duration, int capacity, int count, java.util.List<java.lang.String> samplers) throws javax.management.openmbean.OpenDataException
javax.management.openmbean.OpenDataException
double getTraceProbability()
void disableAutoCompaction(java.lang.String ks, java.lang.String... tables) throws java.io.IOException
java.io.IOException
void enableAutoCompaction(java.lang.String ks, java.lang.String... tables) throws java.io.IOException
java.io.IOException
java.util.Map<java.lang.String,java.lang.Boolean> getAutoCompactionStatus(java.lang.String ks, java.lang.String... tables) throws java.io.IOException
java.io.IOException
void deliverHints(java.lang.String host) throws java.net.UnknownHostException
java.net.UnknownHostException
java.lang.String getClusterName()
java.lang.String getPartitionerName()
int getTombstoneWarnThreshold()
void setTombstoneWarnThreshold(int tombstoneDebugThreshold)
int getTombstoneFailureThreshold()
void setTombstoneFailureThreshold(int tombstoneDebugThreshold)
int getCachedReplicaRowsWarnThreshold()
void setCachedReplicaRowsWarnThreshold(int threshold)
int getCachedReplicaRowsFailThreshold()
void setCachedReplicaRowsFailThreshold(int threshold)
int getColumnIndexCacheSize()
void setColumnIndexCacheSize(int cacheSizeInKB)
int getBatchSizeFailureThreshold()
void setBatchSizeFailureThreshold(int batchSizeDebugThreshold)
int getBatchSizeWarnThreshold()
void setBatchSizeWarnThreshold(int batchSizeDebugThreshold)
void setHintedHandoffThrottleInKB(int throttleInKB)
boolean resumeBootstrap()
java.util.Map<java.lang.String,java.util.List<java.lang.Integer>> getConcurrency(java.util.List<java.lang.String> stageNames)
void setConcurrency(java.lang.String threadPoolName, int newCorePoolSize, int newMaximumPoolSize)
void clearConnectionHistory()
void disableAuditLog()
void enableAuditLog(java.lang.String loggerName, java.util.Map<java.lang.String,java.lang.String> parameters, java.lang.String includedKeyspaces, java.lang.String excludedKeyspaces, java.lang.String includedCategories, java.lang.String excludedCategories, java.lang.String includedUsers, java.lang.String excludedUsers) throws ConfigurationException
ConfigurationException
void enableAuditLog(java.lang.String loggerName, java.lang.String includedKeyspaces, java.lang.String excludedKeyspaces, java.lang.String includedCategories, java.lang.String excludedCategories, java.lang.String includedUsers, java.lang.String excludedUsers) throws ConfigurationException
ConfigurationException
boolean isAuditLogEnabled()
java.lang.String getCorruptedTombstoneStrategy()
void setCorruptedTombstoneStrategy(java.lang.String strategy)
void enableFullQueryLogger(java.lang.String path, java.lang.String rollCycle, java.lang.Boolean blocking, int maxQueueWeight, long maxLogSize, @Nullable java.lang.String archiveCommand, int maxArchiveRetries)
path
- Path where the full query log will be stored. If null cassandra.yaml value is used.rollCycle
- How often to create a new file for query data (MINUTELY, DAILY, HOURLY)blocking
- Whether threads submitting queries to the query log should block if they can't be drained to the filesystem or alternatively drops samples and logmaxQueueWeight
- How many bytes of query data to queue before blocking or dropping samplesmaxLogSize
- How many bytes of log data to store before dropping segments. Might not be respected if a log file hasn't rolled so it can be deleted.archiveCommand
- executable archiving the rolled log files,maxArchiveRetries
- max number of times to retry a failing archive commandvoid resetFullQueryLogger()
void stopFullQueryLogger()
boolean isFullQueryLogEnabled()
javax.management.openmbean.CompositeData getFullQueryLoggerOptions()
void setInitialRangeTombstoneListAllocationSize(int size)
int getInitialRangeTombstoneListAllocationSize()
void setRangeTombstoneListResizeGrowthFactor(double growthFactor)
double getRangeTombstoneResizeListGrowthFactor()
@Deprecated java.util.Map<java.lang.String,java.util.Set<java.net.InetAddress>> getOutstandingSchemaVersions()
java.util.Map<java.lang.String,java.util.Set<java.lang.String>> getOutstandingSchemaVersionsWithPort()
boolean autoOptimiseIncRepairStreams()
void setAutoOptimiseIncRepairStreams(boolean enabled)
boolean autoOptimiseFullRepairStreams()
void setAutoOptimiseFullRepairStreams(boolean enabled)
boolean autoOptimisePreviewRepairStreams()
void setAutoOptimisePreviewRepairStreams(boolean enabled)
int getTableCountWarnThreshold()
void setTableCountWarnThreshold(int value)
int getKeyspaceCountWarnThreshold()
void setKeyspaceCountWarnThreshold(int value)
Copyright © 2009-2021 The Apache Software Foundation