public interface StorageServiceMBean
extends javax.management.NotificationEmitter
Modifier and Type | Method and Description |
---|---|
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 |
cleanupSizeEstimates()
Removes extraneous entries in system.size_estimates.
|
void |
clearSnapshot(java.lang.String tag,
java.lang.String... keyspaceNames)
Remove the snapshot with the given name from the given keyspaces.
|
void |
decommission()
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)
The same as
describeRing(String) but converts TokenRange to the String for JMX compatibility |
void |
disableAutoCompaction(java.lang.String ks,
java.lang.String... tables) |
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)
Effective ownership is % of the data each node owns given the keyspace
we calculate the percentage using replication factor.
|
void |
enableAutoCompaction(java.lang.String ks,
java.lang.String... tables) |
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.
|
int |
forceRepairAsync(java.lang.String keyspace,
boolean isSequential,
boolean isLocal,
boolean primaryRange,
boolean fullRepair,
java.lang.String... tableNames)
Deprecated.
use
repairAsync(String keyspace, Map options) instead. |
int |
forceRepairAsync(java.lang.String keyspace,
boolean isSequential,
java.util.Collection<java.lang.String> dataCenters,
java.util.Collection<java.lang.String> hosts,
boolean primaryRange,
boolean fullRepair,
java.lang.String... tableNames)
Deprecated.
use
repairAsync(String keyspace, Map options) instead. |
int |
forceRepairAsync(java.lang.String keyspace,
int parallelismDegree,
java.util.Collection<java.lang.String> dataCenters,
java.util.Collection<java.lang.String> hosts,
boolean primaryRange,
boolean fullRepair,
java.lang.String... tableNames)
Deprecated.
use
repairAsync(String keyspace, Map options) instead. |
int |
forceRepairRangeAsync(java.lang.String beginToken,
java.lang.String endToken,
java.lang.String keyspaceName,
boolean isSequential,
boolean isLocal,
boolean fullRepair,
java.lang.String... tableNames)
Deprecated.
use
repairAsync(String keyspace, Map options) instead. |
int |
forceRepairRangeAsync(java.lang.String beginToken,
java.lang.String endToken,
java.lang.String keyspaceName,
boolean isSequential,
java.util.Collection<java.lang.String> dataCenters,
java.util.Collection<java.lang.String> hosts,
boolean fullRepair,
java.lang.String... tableNames)
Deprecated.
use
repairAsync(String keyspace, Map options) instead. |
int |
forceRepairRangeAsync(java.lang.String beginToken,
java.lang.String endToken,
java.lang.String keyspaceName,
int parallelismDegree,
java.util.Collection<java.lang.String> dataCenters,
java.util.Collection<java.lang.String> hosts,
boolean fullRepair,
java.lang.String... tableNames)
Deprecated.
use
repairAsync(String keyspace, Map options) instead. |
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
|
int |
getBatchSizeFailureThreshold()
Returns the threshold for rejecting 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
|
java.lang.String |
getCommitLogLocation()
Get location of the commit log
|
int |
getCompactionThroughputMbPerSec() |
int |
getConcurrentCompactors() |
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()
Retrieve the mapping of endpoint to host ID
|
java.util.Map<java.lang.String,java.lang.String> |
getHostIdMap()
Deprecated.
|
java.util.Map<java.lang.String,java.lang.String> |
getHostIdToEndpoint()
Retrieve the mapping of host ID to endpoint
|
int |
getInterDCStreamThroughputMbPerSec() |
java.util.List<java.lang.String> |
getJoiningNodes()
Retrieve the list of nodes currently bootstrapping into the ring.
|
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()
Retrieve the list of nodes currently leaving the ring.
|
java.util.List<java.lang.String> |
getLiveNodes()
Retrieve the list of live nodes in the cluster, where "liveness" is
determined by the failure detector of the node being queried.
|
java.util.Map<java.lang.String,java.lang.String> |
getLoadMap()
Human-readable load value.
|
java.lang.String |
getLoadString()
Human-readable load value
|
java.lang.String |
getLocalHostId()
Retrieve this hosts unique ID
|
java.util.Map<java.lang.String,java.lang.String> |
getLoggingLevels()
get the runtime logging levels
|
int |
getMaxNativeProtocolVersion()
Returns the max version that this node will negotiate for native protocol connections
|
java.util.List<java.lang.String> |
getMovingNodes()
Retrieve the list of nodes currently moving in the ring.
|
java.util.List<java.net.InetAddress> |
getNaturalEndpoints(java.lang.String keyspaceName,
java.nio.ByteBuffer key) |
java.util.List<java.net.InetAddress> |
getNaturalEndpoints(java.lang.String keyspaceName,
java.lang.String cf,
java.lang.String key)
This method returns the N endpoints that are responsible for storing the
specified key i.e for replication.
|
java.util.List<java.lang.String> |
getNonLocalStrategyKeyspaces() |
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()
Returns a map of schema version -> list of endpoints reporting that version that we need schema updates for
|
java.util.Map<java.net.InetAddress,java.lang.Float> |
getOwnership()
given a list of tokens (representing the nodes in the cluster), returns
a mapping from
"token -> %age of cluster owned by that token" |
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)
Retrieve a map of pending ranges to endpoints that describe the ring topology
|
long |
getRangeRpcTimeout() |
java.util.Map<java.util.List<java.lang.String>,java.util.List<java.lang.String>> |
getRangeToEndpointMap(java.lang.String keyspace)
Retrieve a map of range to end points that describe the ring topology
of a Cassandra cluster.
|
java.util.Map<java.util.List<java.lang.String>,java.util.List<java.lang.String>> |
getRangeToRpcaddressMap(java.lang.String keyspace)
Retrieve a map of range to rpc addresses that describe the ring topology
of a Cassandra cluster.
|
long |
getReadRpcTimeout() |
java.lang.String |
getReleaseVersion()
Fetch a string representation of the Cassandra version.
|
java.lang.String |
getRemovalStatus()
Get the status of a token removal.
|
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
|
int |
getStreamingSocketTimeout() |
int |
getStreamThroughputMbPerSec() |
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()
Retrieve a map of tokens to endpoints, including the bootstrapping
ones.
|
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()
Retrieve the list of unreachable nodes in the cluster, as determined
by this node's failure detector.
|
java.util.Map<java.lang.String,java.lang.String> |
getViewBuildStatuses(java.lang.String keyspace,
java.lang.String view) |
long |
getWriteRpcTimeout() |
boolean |
isBootstrapMode()
Check if currently bootstrapping.
|
boolean |
isDrained() |
boolean |
isDraining() |
boolean |
isGossipRunning() |
boolean |
isIncrementalBackupsEnabled() |
boolean |
isInitialized() |
boolean |
isJoined() |
boolean |
isNativeTransportRunning() |
boolean |
isRPCServerRunning() |
boolean |
isStarting()
Returns whether the storage service is starting or not
|
void |
joinRing() |
void |
loadNewSSTables(java.lang.String ksName,
java.lang.String tableName)
Load new SSTables to the given keyspace/table
|
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 |
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.
|
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 |
setBatchSizeFailureThreshold(int batchSizeDebugThreshold)
Sets the threshold for rejecting 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 |
setCompactionThroughputMbPerSec(int value) |
void |
setConcurrentCompactors(int value) |
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 |
setInterDCStreamThroughputMbPerSec(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 |
setRangeRpcTimeout(long value) |
void |
setReadRpcTimeout(long value) |
void |
setRepairSessionMaxTreeDepth(int depth) |
void |
setRpcTimeout(long value) |
void |
setStreamingSocketTimeout(int value) |
void |
setStreamThroughputMbPerSec(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 |
startRPCServer() |
void |
stopDaemon() |
void |
stopGossiping() |
void |
stopNativeTransport() |
void |
stopRPCServer() |
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,
java.lang.String keyspaceName,
java.lang.String... tableNames)
Verify (checksums of) the given keyspace.
|
java.util.List<java.lang.String> getLiveNodes()
java.util.List<java.lang.String> getUnreachableNodes()
java.util.List<java.lang.String> getJoiningNodes()
java.util.List<java.lang.String> getLeavingNodes()
java.util.List<java.lang.String> getMovingNodes()
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 getCommitLogLocation()
java.lang.String getSavedCachesLocation()
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>> getRangeToRpcaddressMap(java.lang.String keyspace)
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.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.lang.String,java.lang.String> getTokenToEndpointMap()
java.lang.String getLocalHostId()
@Deprecated java.util.Map<java.lang.String,java.lang.String> getHostIdMap()
java.util.Map<java.lang.String,java.lang.String> getEndpointToHostId()
java.util.Map<java.lang.String,java.lang.String> getHostIdToEndpoint()
java.lang.String getLoadString()
java.util.Map<java.lang.String,java.lang.String> getLoadMap()
int getCurrentGenerationNumber()
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.net.InetAddress> getNaturalEndpoints(java.lang.String keyspaceName, 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 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
keyspaceName
- the name of the keyspace to be compactedstartToken
- the token at which the compaction range starts (inclusive)endToken
- the token at which compaction range ends (inclusive)tableNames
- the names of the tables to be compactedjava.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
@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.@Deprecated int forceRepairAsync(java.lang.String keyspace, boolean isSequential, java.util.Collection<java.lang.String> dataCenters, java.util.Collection<java.lang.String> hosts, boolean primaryRange, boolean fullRepair, java.lang.String... tableNames) throws java.io.IOException
repairAsync(String keyspace, Map options)
instead.java.io.IOException
@Deprecated int forceRepairAsync(java.lang.String keyspace, int parallelismDegree, java.util.Collection<java.lang.String> dataCenters, java.util.Collection<java.lang.String> hosts, boolean primaryRange, boolean fullRepair, java.lang.String... tableNames)
repairAsync(String keyspace, Map options)
instead.parallelismDegree
- 0: sequential, 1: parallel, 2: DC parallel@Deprecated int forceRepairRangeAsync(java.lang.String beginToken, java.lang.String endToken, java.lang.String keyspaceName, boolean isSequential, java.util.Collection<java.lang.String> dataCenters, java.util.Collection<java.lang.String> hosts, boolean fullRepair, java.lang.String... tableNames) throws java.io.IOException
repairAsync(String keyspace, Map options)
instead.java.io.IOException
@Deprecated int forceRepairRangeAsync(java.lang.String beginToken, java.lang.String endToken, java.lang.String keyspaceName, int parallelismDegree, java.util.Collection<java.lang.String> dataCenters, java.util.Collection<java.lang.String> hosts, boolean fullRepair, java.lang.String... tableNames)
repairAsync(String keyspace, Map options)
instead.parallelismDegree
- 0: sequential, 1: parallel, 2: DC parallel@Deprecated int forceRepairAsync(java.lang.String keyspace, boolean isSequential, boolean isLocal, boolean primaryRange, boolean fullRepair, java.lang.String... tableNames)
repairAsync(String keyspace, Map options)
instead.@Deprecated int forceRepairRangeAsync(java.lang.String beginToken, java.lang.String endToken, java.lang.String keyspaceName, boolean isSequential, boolean isLocal, boolean fullRepair, java.lang.String... tableNames)
repairAsync(String keyspace, Map options)
instead.void forceTerminateAllRepairSessions()
void setRepairSessionMaxTreeDepth(int depth)
int getRepairSessionMaxTreeDepth()
void decommission() throws java.lang.InterruptedException
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)
java.lang.String getRemovalStatus()
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
java.util.Map<java.net.InetAddress,java.lang.Float> getOwnership()
"token -> %age of cluster owned by that token"
java.util.Map<java.net.InetAddress,java.lang.Float> effectiveOwnership(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()
java.util.Map<java.lang.String,java.lang.String> getViewBuildStatuses(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 stopRPCServer()
void startRPCServer()
boolean isRPCServerRunning()
void stopNativeTransport()
void startNativeTransport()
boolean isNativeTransportRunning()
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 setCounterWriteRpcTimeout(long value)
long getCounterWriteRpcTimeout()
void setCasContentionTimeout(long value)
long getCasContentionTimeout()
void setTruncateRpcTimeout(long value)
long getTruncateRpcTimeout()
void setStreamingSocketTimeout(int value)
int getStreamingSocketTimeout()
void setStreamThroughputMbPerSec(int value)
int getStreamThroughputMbPerSec()
void setInterDCStreamThroughputMbPerSec(int value)
int getInterDCStreamThroughputMbPerSec()
int getCompactionThroughputMbPerSec()
void setCompactionThroughputMbPerSec(int value)
int getConcurrentCompactors()
void setConcurrentCompactors(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()
void loadNewSSTables(java.lang.String ksName, java.lang.String tableName)
ksName
- The parent keyspace nametableName
- The ColumnFamily name where SSTables belongjava.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)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
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 getBatchSizeFailureThreshold()
void setBatchSizeFailureThreshold(int batchSizeDebugThreshold)
void setHintedHandoffThrottleInKB(int throttleInKB)
boolean resumeBootstrap()
int getMaxNativeProtocolVersion()
java.util.Map<java.lang.String,java.util.Set<java.net.InetAddress>> getOutstandingSchemaVersions()
Copyright © 2009- The Apache Software Foundation