public class StorageService extends javax.management.NotificationBroadcasterSupport implements IEndpointStateChangeSubscriber, StorageServiceMBean
Modifier and Type | Class and Description |
---|---|
static class |
StorageService.Mode |
StorageServiceMBean.StageConcurrency
Modifier and Type | Field and Description |
---|---|
static int |
INDEFINITE |
static StorageService |
instance |
static int |
RING_DELAY |
static int |
SCHEMA_DELAY_MILLIS |
SSTablesGlobalTracker |
sstablesTracker |
static boolean |
useStrictConsistency |
VersionedValue.VersionedValueFactory |
valueFactory |
Constructor and Description |
---|
StorageService() |
Modifier and Type | Method and Description |
---|---|
protected void |
addExpireTimeIfFound(InetAddressAndPort endpoint,
long expireTime) |
boolean |
addPostShutdownHook(java.lang.Runnable hook)
Add a runnable which will be called after shutdown or drain.
|
boolean |
addPreShutdownHook(java.lang.Runnable hook)
Add a runnable which will be called before shut down or drain.
|
boolean |
authSetupCalled() |
boolean |
autoOptimiseFullRepairStreams() |
boolean |
autoOptimiseIncRepairStreams() |
boolean |
autoOptimisePreviewRepairStreams() |
void |
beforeChange(InetAddressAndPort endpoint,
EndpointState currentState,
ApplicationState newStateKey,
VersionedValue newValue) |
boolean |
bootstrap(java.util.Collection<Token> tokens,
long bootstrapTimeoutMillis)
Bootstrap node by fetching data from other nodes.
|
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 |
checkForEndpointCollision(java.util.UUID localHostId,
java.util.Set<InetAddressAndPort> peers) |
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 |
confirmReplication(InetAddressAndPort node) |
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<TokenRange> |
describeLocalRing(java.lang.String keyspace)
The same as
describeRing(String) but considers only the part of the ring formed by nodes in the local DC. |
java.util.List<TokenRange> |
describeRing(java.lang.String keyspace)
The TokenRange for a given keyspace.
|
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 |
java.util.List<java.lang.String> |
describeRingWithPortJMX(java.lang.String keyspace) |
void |
disableAuditLog() |
void |
disableAutoCompaction() |
void |
disableAutoCompaction(java.lang.String ks,
java.lang.String... tables) |
void |
disableNativeTransportOldProtocolVersions() |
void |
doAuthSetup(boolean setUpSchema) |
void |
drain()
Shuts node off to writes, empties memtables and the commit log.
|
protected void |
drain(boolean isFinalShutdown) |
void |
dropPreparedStatements(boolean memoryOnly) |
java.util.LinkedHashMap<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.
|
java.util.LinkedHashMap<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() |
protected long |
extractExpireTime(java.lang.String[] pieces) |
void |
finishJoiningRing(boolean didBootstrap,
java.util.Collection<Token> tokens) |
int |
forceKeyspaceCleanup(int jobs,
java.lang.String keyspaceName,
java.lang.String... tables) |
int |
forceKeyspaceCleanup(java.lang.String keyspaceName,
java.lang.String... tables)
Trigger a cleanup of keys on a single keyspace
|
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 a keyspace and column families.
|
void |
forceRemoveCompletion()
Force a remove operation to complete.
|
void |
forceTerminateAllRepairSessions() |
int |
garbageCollect(java.lang.String tombstoneOptionString,
int jobs,
java.lang.String keyspaceName,
java.lang.String... columnFamilies)
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.List<Range<Token>> |
getAllRanges(java.util.List<Token> sortedTokens)
Get all ranges that span the ring given a set
of tokens.
|
java.util.Map<java.lang.String,java.lang.Boolean> |
getAutoCompactionStatus(java.lang.String ks,
java.lang.String... tables) |
java.lang.String |
getBatchlogEndpointStrategy() |
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() |
InetAddressAndPort |
getEndpointForHostId(java.util.UUID hostId) |
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> |
getEndpointWithPortToHostId() |
javax.management.openmbean.CompositeData |
getFullQueryLoggerOptions()
Returns the current state of FQL.
|
java.util.UUID |
getHostIdForEndpoint(InetAddressAndPort address) |
java.util.Map<java.lang.String,java.lang.String> |
getHostIdMap()
|
java.util.Map<java.lang.String,java.lang.String> |
getHostIdToEndpoint()
Retrieve the mapping of host ID to endpoint
|
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.Set<InetAddressAndPort> |
getLiveRingMembers() |
java.util.Set<InetAddressAndPort> |
getLiveRingMembers(boolean excludeDeadStates) |
java.util.Map<java.lang.String,java.lang.String> |
getLoadMap()
Human-readable load value.
|
java.util.Map<java.lang.String,java.lang.String> |
getLoadMapWithPort() |
java.lang.String |
getLoadString()
Human-readable load value
|
java.util.List<Range<Token>> |
getLocalAndPendingRanges(java.lang.String ks) |
java.lang.String |
getLocalHostId()
Retrieve this hosts unique ID
|
java.util.UUID |
getLocalHostUUID() |
java.util.Collection<Range<Token>> |
getLocalPrimaryRange() |
java.util.Collection<Range<Token>> |
getLocalPrimaryRangeForEndpoint(InetAddressAndPort referenceEndpoint) |
RangesAtEndpoint |
getLocalReplicas(java.lang.String keyspaceName) |
java.lang.String[] |
getLocalSystemKeyspacesDataFileLocations()
Returns the locations where the local system keyspaces data should be stored.
|
java.util.Collection<Token> |
getLocalTokens() |
java.util.Map<java.lang.String,java.lang.String> |
getLoggingLevels()
get the runtime logging levels
|
int |
getMaxHintTTL()
Returns upper bound on the hint ttl
|
boolean |
getMigrateKeycacheOnCompaction() |
java.util.List<java.lang.String> |
getMovingNodes()
Deprecated.
|
java.util.List<java.lang.String> |
getMovingNodesWithPort() |
java.lang.String |
getNativeaddress(InetAddressAndPort endpoint,
boolean withPort)
Return the native address associated with an endpoint as a string.
|
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 keyspaceName,
java.nio.ByteBuffer key) |
java.util.List<java.lang.String> |
getNaturalEndpointsWithPort(java.lang.String keyspaceName,
java.lang.String cf,
java.lang.String key) |
EndpointsForToken |
getNaturalReplicasForToken(java.lang.String keyspaceName,
java.nio.ByteBuffer key) |
EndpointsForToken |
getNaturalReplicasForToken(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() |
OwnedRanges |
getNormalizedLocalRanges(java.lang.String keyspaceName) |
java.lang.String |
getOperationMode()
get the operational mode (leaving, joining, normal, decommissioned, client)
|
java.util.Map<java.lang.String,long[]> |
getOutOfRangeOperationCounts()
Get the per-keyspace counts of operations that the node has received for tokens outside
its owned ranges.
|
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.lang.String,java.util.Set<java.lang.String>> |
getOutstandingSchemaVersionsWithPort() |
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.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)
Retrieve a map of pending ranges to endpoints that describe the ring topology
|
java.util.Map<java.util.List<java.lang.String>,java.util.List<java.lang.String>> |
getPendingRangeToEndpointWithPortMap(java.lang.String keyspace) |
java.util.List<Pair<java.lang.String,java.lang.String>> |
getPreparedStatements() |
java.util.Collection<Range<Token>> |
getPrimaryRangeForEndpointWithinDC(java.lang.String keyspace,
InetAddressAndPort referenceEndpoint)
Get the "primary ranges" within local DC for the specified keyspace and endpoint.
|
java.util.Collection<Range<Token>> |
getPrimaryRanges(java.lang.String keyspace) |
java.util.Collection<Range<Token>> |
getPrimaryRangesForEndpoint(java.lang.String keyspace,
InetAddressAndPort ep)
Get the "primary ranges" for the specified keyspace and endpoint.
|
java.util.Collection<Range<Token>> |
getPrimaryRangesWithinDC(java.lang.String keyspace) |
long |
getRangeRpcTimeout() |
EndpointsByRange |
getRangeToAddressMap(java.lang.String keyspace) |
EndpointsByRange |
getRangeToAddressMapInLocalDC(java.lang.String keyspace) |
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>> |
getRangeToEndpointMap(java.lang.String keyspace,
boolean withPort)
for a keyspace, return the ranges and corresponding listen addresses.
|
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)
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.
|
java.lang.String |
getRemovalStatusWithPort() |
java.lang.Long |
getRepairRpcTimeout() |
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.
|
java.util.List<Pair<Range<Token>,java.lang.Long>> |
getSplits(java.lang.String keyspaceName,
java.lang.String cfName,
Range<Token> range,
int keysPerSplit) |
int |
getSSTablePreemptiveOpenIntervalInMB() |
int |
getStreamThroughputMbPerSec() |
int |
getTableCountWarnThreshold() |
Token.TokenFactory |
getTokenFactory() |
TokenMetadata |
getTokenMetadata() |
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.
|
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.
|
boolean |
getTransferHintsOnDecommission() |
long |
getTruncateRpcTimeout() |
java.util.List<java.lang.String> |
getUnreachableNodes()
Deprecated.
|
java.util.List<java.lang.String> |
getUnreachableNodesWithPort() |
java.lang.Iterable<ColumnFamilyStore> |
getValidColumnFamilies(boolean allowIndexes,
boolean autoAddIndexes,
java.lang.String keyspaceName,
java.lang.String... cfNames) |
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> |
getViewBuildStatuses(java.lang.String keyspace,
java.lang.String view,
boolean withPort) |
java.util.Map<java.lang.String,java.lang.String> |
getViewBuildStatusesWithPort(java.lang.String keyspace,
java.lang.String view) |
long |
getWriteRpcTimeout() |
void |
gossipSnitchInfo() |
boolean |
hasJoined() |
void |
incOutOfRangeOperationCount() |
void |
initServer() |
void |
initServer(int delay) |
boolean |
isAuditLogEnabled() |
boolean |
isAuthSetupComplete() |
boolean |
isBootstrapMode()
Check if currently bootstrapping.
|
boolean |
isConcurrentValidatorsLimitEnforced() |
boolean |
isDaemonSetupCompleted() |
boolean |
isDrained() |
boolean |
isDraining() |
boolean |
isEndpointValidForWrite(java.lang.String keyspace,
Token token) |
boolean |
isFullQueryLogEnabled() |
boolean |
isGossipActive() |
boolean |
isGossipRunning() |
boolean |
isHintTtlUseMutationCreationTime()
Returns whether we are using the creation time of the mutation for determining hint ttl
|
boolean |
isIncrementalBackupsEnabled() |
boolean |
isInitialized() |
boolean |
isInShutdownHook()
Deprecated.
|
boolean |
isJoined() |
boolean |
isJoining() |
boolean |
isMoving() |
boolean |
isNativeTransportRunning() |
boolean |
isNormal() |
boolean |
isOutOfTokenRangeRequestLoggingEnabled()
Toggles to turn on the logging or rejection of operations for token ranges that the node does not own,
or is not about to acquire.
|
boolean |
isOutOfTokenRangeRequestRejectionEnabled() |
static boolean |
isReplacingSameAddress() |
boolean |
isReplacingSameHostAddressAndHostId(java.util.UUID hostId) |
boolean |
isRpcReady(InetAddressAndPort endpoint) |
static boolean |
isSeed() |
boolean |
isShutdown() |
boolean |
isStarting()
Returns whether the storage service is starting or not
|
boolean |
isSurveyMode() |
void |
joinRing() |
void |
joinTokenRing(boolean finishJoiningRing,
boolean shouldBootstrap,
long schemaTimeoutMillis,
long bootstrapTimeoutMillis) |
void |
loadNewSSTables(java.lang.String ksName,
java.lang.String cfName)
Deprecated.
|
void |
move(java.lang.String newToken) |
void |
onAlive(InetAddressAndPort endpoint,
EndpointState state) |
void |
onChange(InetAddressAndPort endpoint,
ApplicationState state,
VersionedValue value) |
void |
onDead(InetAddressAndPort endpoint,
EndpointState state) |
void |
onJoin(InetAddressAndPort endpoint,
EndpointState epState)
Use to inform interested parties about the change in the state
for specified endpoint
|
void |
onRemove(InetAddressAndPort endpoint) |
void |
onRestart(InetAddressAndPort endpoint,
EndpointState state)
Called whenever a node is restarted.
|
void |
populateTokenMetadata() |
java.util.Collection<InetAddressAndPort> |
prepareForBootstrap(long schemaDelay) |
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
StorageServiceMBean.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 |
register(IEndpointLifecycleSubscriber subscriber) |
void |
registerDaemon(CassandraDaemon daemon) |
void |
reloadLocalSchema() |
int |
relocateSSTables(int jobs,
java.lang.String keyspaceName,
java.lang.String... columnFamilies) |
int |
relocateSSTables(java.lang.String keyspaceName,
java.lang.String... columnFamilies) |
void |
removeNode(java.lang.String hostIdString)
Remove a node that has died, attempting to restore the replica count.
|
boolean |
removePostShutdownHook(java.lang.Runnable hook)
Remove a postshutdownhook
|
boolean |
removePreShutdownHook(java.lang.Runnable hook)
Remove a preshutdown hook
|
void |
removeShutdownHook()
In the event of forceful termination we need to remove the shutdown hook to prevent hanging (OOM for instance)
|
Pair<java.lang.Integer,java.util.concurrent.Future<?>> |
repair(java.lang.String keyspace,
java.util.Map<java.lang.String,java.lang.String> repairSpec,
java.util.List<ProgressListener> listeners) |
int |
repairAsync(java.lang.String keyspace,
java.util.Map<java.lang.String,java.lang.String> repairSpec)
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 durationMillis,
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... tables) |
int |
scrub(boolean disableSnapshot,
boolean skipCorrupted,
boolean checkData,
int jobs,
java.lang.String keyspaceName,
java.lang.String... tables) |
int |
scrub(boolean disableSnapshot,
boolean skipCorrupted,
boolean checkData,
java.lang.String keyspaceName,
java.lang.String... tables) |
int |
scrub(boolean disableSnapshot,
boolean skipCorrupted,
java.lang.String keyspaceName,
java.lang.String... tables)
Scrub (deserialize + reserialize at the latest version, skipping bad rows if any) the given keyspace.
|
void |
setAutoOptimiseFullRepairStreams(boolean enabled) |
void |
setAutoOptimiseIncRepairStreams(boolean enabled) |
void |
setAutoOptimisePreviewRepairStreams(boolean enabled) |
void |
setBatchlogEndpointStrategy(java.lang.String batchlogEndpointStrategy)
See
Config.BatchlogEndpointStrategy for valid values. |
void |
setBatchlogReplayThrottleInKB(int throttleInKB) |
void |
setBatchSizeFailureThreshold(int threshold)
Sets the threshold for rejecting queries due to a large batch size
|
void |
setBatchSizeWarnThreshold(int threshold)
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 |
setGossipTokens(java.util.Collection<Token> tokens) |
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 |
setIsShutdownUnsafeForTests(boolean isShutdown)
for in-jvm dtest use - forces isShutdown to be set to whatever passed in.
|
void |
setKeyspaceCountWarnThreshold(int value) |
void |
setLoggingLevel(java.lang.String classQualifier,
java.lang.String rawLevel)
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 |
setMaxHintTTL(int maxHintTTL)
Sets the upper bound on the hint ttl
|
void |
setMigrateKeycacheOnCompaction(boolean invalidateKeyCacheOnCompaction) |
void |
setMovingModeUnsafe() |
void |
setNativeTransportMaxConcurrentRequestsInBytes(long newLimit) |
void |
setNativeTransportMaxConcurrentRequestsInBytesPerIp(long newLimit) |
void |
setNormalModeUnsafe()
Only used in jvm dtest when not using GOSSIP.
|
void |
setOutOfTokenRangeRequestLoggingEnabled(boolean enabled) |
void |
setOutOfTokenRangeRequestRejectionEnabled(boolean enabled) |
IPartitioner |
setPartitionerUnsafe(IPartitioner newPartitioner) |
void |
setRangeRpcTimeout(long value) |
void |
setRangeTombstoneListResizeGrowthFactor(double growthFactor)
Sets the resize factor to use when growing/resizing a RangeTombstoneList
|
void |
setReadRpcTimeout(long value) |
void |
setRepairRpcTimeout(java.lang.Long timeoutInMillis) |
void |
setRepairSessionMaxTreeDepth(int depth) |
void |
setRpcReady(boolean value)
Set the RPC status.
|
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 |
setTokens(java.util.Collection<Token> tokens)
This method updates the local token on disk
|
void |
setTombstoneFailureThreshold(int threshold)
Sets the threshold for abandoning queries with many tombstones
|
void |
setTombstoneWarnThreshold(int threshold)
Sets the threshold for warning queries with many tombstones
|
void |
setTraceProbability(double probability)
Enables/Disables tracing for the whole system.
|
void |
setTransferHintsOnDecommission(boolean enabled) |
void |
setTruncateRpcTimeout(long value) |
void |
setUpDistributedSystemKeyspaces() |
void |
setUseCreationTimeForHintTtl(boolean enabled)
Sets whether we are using the creation time of the mutation for determining hint ttl
|
void |
setWriteRpcTimeout(long value) |
boolean |
shouldTraceProbablistically() |
void |
shutdownServer() |
java.util.concurrent.Future<StreamState> |
startBootstrap(java.util.Collection<Token> tokens) |
void |
startGossiping() |
void |
startNativeTransport() |
void |
stopClient() |
void |
stopDaemon() |
void |
stopFullQueryLogger()
Stop logging queries but leave any generated files on disk.
|
void |
stopGossiping() |
void |
stopNativeTransport() |
void |
stopTransports() |
void |
takeMultipleTableSnapshot(java.lang.String tag,
java.lang.String... tableList)
Takes the snapshot of a multiple column family from different keyspaces.
|
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)
Takes the snapshot for the given keyspaces.
|
void |
takeTableSnapshot(java.lang.String keyspaceName,
java.lang.String tableName,
java.lang.String tag)
Takes the snapshot of a specific table.
|
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 |
unregister(IEndpointLifecycleSubscriber subscriber) |
void |
unsafeInitialize() |
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.
|
void |
updateTopology() |
void |
updateTopology(InetAddressAndPort endpoint) |
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)
Rewrite all sstables to the latest version.
|
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)
Deprecated.
|
void |
waitForSchema(long delay) |
addNotificationListener, getNotificationInfo, handleNotification, removeNotificationListener, removeNotificationListener, sendNotification
public static final int INDEFINITE
public static final int RING_DELAY
public static final int SCHEMA_DELAY_MILLIS
public volatile VersionedValue.VersionedValueFactory valueFactory
public static final StorageService instance
public static final boolean useStrictConsistency
public final SSTablesGlobalTracker sstablesTracker
public java.util.Map<java.lang.String,long[]> getOutOfRangeOperationCounts()
StorageServiceMBean
Map<String, long[]>
, keys are keyspace names and the
values are the counts for read, write and paxos ops respectivly.
e.g. keyspace_name -> [reads, writes, paxos].getOutOfRangeOperationCounts
in interface StorageServiceMBean
public void incOutOfRangeOperationCount()
@Deprecated public boolean isInShutdownHook()
public boolean isShutdown()
public void setIsShutdownUnsafeForTests(boolean isShutdown)
public RangesAtEndpoint getLocalReplicas(java.lang.String keyspaceName)
public java.util.List<Range<Token>> getLocalAndPendingRanges(java.lang.String ks)
public OwnedRanges getNormalizedLocalRanges(java.lang.String keyspaceName)
public java.util.Collection<Range<Token>> getPrimaryRanges(java.lang.String keyspace)
public java.util.Collection<Range<Token>> getPrimaryRangesWithinDC(java.lang.String keyspace)
public boolean isSurveyMode()
public boolean hasJoined()
public void setTokens(java.util.Collection<Token> tokens)
public void setGossipTokens(java.util.Collection<Token> tokens)
public void registerDaemon(CassandraDaemon daemon)
public void register(IEndpointLifecycleSubscriber subscriber)
public void unregister(IEndpointLifecycleSubscriber subscriber)
public void stopGossiping()
stopGossiping
in interface StorageServiceMBean
public void startGossiping()
startGossiping
in interface StorageServiceMBean
public boolean isGossipRunning()
isGossipRunning
in interface StorageServiceMBean
public void startNativeTransport()
startNativeTransport
in interface StorageServiceMBean
public void stopNativeTransport()
stopNativeTransport
in interface StorageServiceMBean
public boolean isNativeTransportRunning()
isNativeTransportRunning
in interface StorageServiceMBean
public void enableNativeTransportOldProtocolVersions()
enableNativeTransportOldProtocolVersions
in interface StorageServiceMBean
public void disableNativeTransportOldProtocolVersions()
disableNativeTransportOldProtocolVersions
in interface StorageServiceMBean
public void stopTransports()
public void stopClient()
public boolean isInitialized()
isInitialized
in interface StorageServiceMBean
public boolean isGossipActive()
public boolean isDaemonSetupCompleted()
public void stopDaemon()
stopDaemon
in interface StorageServiceMBean
public void checkForEndpointCollision(java.util.UUID localHostId, java.util.Set<InetAddressAndPort> peers) throws ConfigurationException
ConfigurationException
public void unsafeInitialize() throws ConfigurationException
ConfigurationException
public void initServer() throws ConfigurationException
ConfigurationException
public void initServer(int delay) throws ConfigurationException
ConfigurationException
public void populateTokenMetadata()
public void removeShutdownHook()
public static boolean isSeed()
public void waitForSchema(long delay)
public void joinTokenRing(boolean finishJoiningRing, boolean shouldBootstrap, long schemaTimeoutMillis, long bootstrapTimeoutMillis) throws ConfigurationException
ConfigurationException
public static boolean isReplacingSameAddress()
public void gossipSnitchInfo()
public void joinRing() throws java.io.IOException
joinRing
in interface StorageServiceMBean
java.io.IOException
public void finishJoiningRing(boolean didBootstrap, java.util.Collection<Token> tokens)
public void doAuthSetup(boolean setUpSchema)
public boolean isAuthSetupComplete()
public boolean authSetupCalled()
public void setUpDistributedSystemKeyspaces()
public boolean isJoined()
isJoined
in interface StorageServiceMBean
public void rebuild(java.lang.String sourceDc)
StorageServiceMBean
rebuild
in interface StorageServiceMBean
sourceDc
- Name of DC from which to select sources for streaming or null to pick any nodepublic void rebuild(java.lang.String sourceDc, java.lang.String keyspace, java.lang.String tokens, java.lang.String specificSources)
StorageServiceMBean
StorageServiceMBean.rebuild(String)
, but only for specified keyspace and ranges.rebuild
in interface StorageServiceMBean
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]"public void setRpcTimeout(long value)
setRpcTimeout
in interface StorageServiceMBean
public long getRpcTimeout()
getRpcTimeout
in interface StorageServiceMBean
public void setReadRpcTimeout(long value)
setReadRpcTimeout
in interface StorageServiceMBean
public long getReadRpcTimeout()
getReadRpcTimeout
in interface StorageServiceMBean
public void setRangeRpcTimeout(long value)
setRangeRpcTimeout
in interface StorageServiceMBean
public long getRangeRpcTimeout()
getRangeRpcTimeout
in interface StorageServiceMBean
public void setWriteRpcTimeout(long value)
setWriteRpcTimeout
in interface StorageServiceMBean
public long getWriteRpcTimeout()
getWriteRpcTimeout
in interface StorageServiceMBean
public void setInternodeTcpConnectTimeoutInMS(int value)
setInternodeTcpConnectTimeoutInMS
in interface StorageServiceMBean
public int getInternodeTcpConnectTimeoutInMS()
getInternodeTcpConnectTimeoutInMS
in interface StorageServiceMBean
public void setInternodeTcpUserTimeoutInMS(int value)
setInternodeTcpUserTimeoutInMS
in interface StorageServiceMBean
public int getInternodeTcpUserTimeoutInMS()
getInternodeTcpUserTimeoutInMS
in interface StorageServiceMBean
public void setInternodeStreamingTcpUserTimeoutInMS(int value)
setInternodeStreamingTcpUserTimeoutInMS
in interface StorageServiceMBean
public int getInternodeStreamingTcpUserTimeoutInMS()
getInternodeStreamingTcpUserTimeoutInMS
in interface StorageServiceMBean
public void setCounterWriteRpcTimeout(long value)
setCounterWriteRpcTimeout
in interface StorageServiceMBean
public long getCounterWriteRpcTimeout()
getCounterWriteRpcTimeout
in interface StorageServiceMBean
public void setCasContentionTimeout(long value)
setCasContentionTimeout
in interface StorageServiceMBean
public long getCasContentionTimeout()
getCasContentionTimeout
in interface StorageServiceMBean
public void setTruncateRpcTimeout(long value)
setTruncateRpcTimeout
in interface StorageServiceMBean
public long getTruncateRpcTimeout()
getTruncateRpcTimeout
in interface StorageServiceMBean
public void setStreamThroughputMbPerSec(int value)
setStreamThroughputMbPerSec
in interface StorageServiceMBean
public int getStreamThroughputMbPerSec()
getStreamThroughputMbPerSec
in interface StorageServiceMBean
public void setInterDCStreamThroughputMbPerSec(int value)
setInterDCStreamThroughputMbPerSec
in interface StorageServiceMBean
public int getInterDCStreamThroughputMbPerSec()
getInterDCStreamThroughputMbPerSec
in interface StorageServiceMBean
public int getCompactionThroughputMbPerSec()
getCompactionThroughputMbPerSec
in interface StorageServiceMBean
public void setCompactionThroughputMbPerSec(int value)
setCompactionThroughputMbPerSec
in interface StorageServiceMBean
public int getBatchlogReplayThrottleInKB()
getBatchlogReplayThrottleInKB
in interface StorageServiceMBean
public void setBatchlogReplayThrottleInKB(int throttleInKB)
setBatchlogReplayThrottleInKB
in interface StorageServiceMBean
public int getConcurrentCompactors()
getConcurrentCompactors
in interface StorageServiceMBean
public void setConcurrentCompactors(int value)
setConcurrentCompactors
in interface StorageServiceMBean
public void bypassConcurrentValidatorsLimit()
bypassConcurrentValidatorsLimit
in interface StorageServiceMBean
public void enforceConcurrentValidatorsLimit()
enforceConcurrentValidatorsLimit
in interface StorageServiceMBean
public boolean isConcurrentValidatorsLimitEnforced()
isConcurrentValidatorsLimitEnforced
in interface StorageServiceMBean
public int getConcurrentValidators()
getConcurrentValidators
in interface StorageServiceMBean
public void setConcurrentValidators(int value)
setConcurrentValidators
in interface StorageServiceMBean
public int getConcurrentViewBuilders()
getConcurrentViewBuilders
in interface StorageServiceMBean
public void setConcurrentViewBuilders(int value)
setConcurrentViewBuilders
in interface StorageServiceMBean
public boolean isIncrementalBackupsEnabled()
isIncrementalBackupsEnabled
in interface StorageServiceMBean
public void setIncrementalBackupsEnabled(boolean value)
setIncrementalBackupsEnabled
in interface StorageServiceMBean
public void setMovingModeUnsafe()
public void setNormalModeUnsafe()
public java.util.Collection<InetAddressAndPort> prepareForBootstrap(long schemaDelay)
public boolean bootstrap(java.util.Collection<Token> tokens, long bootstrapTimeoutMillis)
tokens
- bootstrapping tokenspublic java.util.concurrent.Future<StreamState> startBootstrap(java.util.Collection<Token> tokens)
public boolean resumeBootstrap()
StorageServiceMBean
resumeBootstrap
in interface StorageServiceMBean
public java.util.Map<java.lang.String,java.util.List<java.lang.Integer>> getConcurrency(java.util.List<java.lang.String> stageNames)
getConcurrency
in interface StorageServiceMBean
public void setConcurrency(java.lang.String threadPoolName, int newCorePoolSize, int newMaximumPoolSize)
StorageServiceMBean
setConcurrency
in interface StorageServiceMBean
public boolean isBootstrapMode()
StorageServiceMBean
SystemKeyspace.bootstrapComplete()
is called,
as setting bootstrap to complete is called only when the node joins the ring.isBootstrapMode
in interface StorageServiceMBean
public TokenMetadata getTokenMetadata()
public java.util.Map<java.util.List<java.lang.String>,java.util.List<java.lang.String>> getRangeToEndpointMap(java.lang.String keyspace)
StorageServiceMBean
getRangeToEndpointMap
in interface StorageServiceMBean
public java.util.Map<java.util.List<java.lang.String>,java.util.List<java.lang.String>> getRangeToEndpointWithPortMap(java.lang.String keyspace)
getRangeToEndpointWithPortMap
in interface StorageServiceMBean
public java.util.Map<java.util.List<java.lang.String>,java.util.List<java.lang.String>> getRangeToEndpointMap(java.lang.String keyspace, boolean withPort)
keyspace
- public java.lang.String getNativeaddress(InetAddressAndPort endpoint, boolean withPort)
endpoint
- The endpoint to get rpc address forpublic java.util.Map<java.util.List<java.lang.String>,java.util.List<java.lang.String>> getRangeToRpcaddressMap(java.lang.String keyspace)
StorageServiceMBean
getRangeToRpcaddressMap
in interface StorageServiceMBean
public java.util.Map<java.util.List<java.lang.String>,java.util.List<java.lang.String>> getRangeToNativeaddressWithPortMap(java.lang.String keyspace)
getRangeToNativeaddressWithPortMap
in interface StorageServiceMBean
public java.util.Map<java.util.List<java.lang.String>,java.util.List<java.lang.String>> getPendingRangeToEndpointMap(java.lang.String keyspace)
StorageServiceMBean
getPendingRangeToEndpointMap
in interface StorageServiceMBean
keyspace
- the keyspace to get the pending range map for.public java.util.Map<java.util.List<java.lang.String>,java.util.List<java.lang.String>> getPendingRangeToEndpointWithPortMap(java.lang.String keyspace)
getPendingRangeToEndpointWithPortMap
in interface StorageServiceMBean
public EndpointsByRange getRangeToAddressMap(java.lang.String keyspace)
public EndpointsByRange getRangeToAddressMapInLocalDC(java.lang.String keyspace)
public java.util.List<java.lang.String> describeRingJMX(java.lang.String keyspace) throws java.io.IOException
StorageServiceMBean
describeRing(String)
but converts TokenRange to the String for JMX compatibilitydescribeRingJMX
in interface StorageServiceMBean
keyspace
- The keyspace to fetch information aboutjava.io.IOException
public java.util.List<java.lang.String> describeRingWithPortJMX(java.lang.String keyspace) throws java.io.IOException
describeRingWithPortJMX
in interface StorageServiceMBean
java.io.IOException
public java.util.List<TokenRange> describeRing(java.lang.String keyspace) throws InvalidRequestException
keyspace
- The keyspace to fetch information aboutInvalidRequestException
- if there is no ring information available about keyspacepublic java.util.List<TokenRange> describeLocalRing(java.lang.String keyspace) throws InvalidRequestException
describeRing(String)
but considers only the part of the ring formed by nodes in the local DC.InvalidRequestException
public java.util.Map<java.lang.String,java.lang.String> getTokenToEndpointMap()
StorageServiceMBean
getTokenToEndpointMap
in interface StorageServiceMBean
public java.util.Map<java.lang.String,java.lang.String> getTokenToEndpointWithPortMap()
getTokenToEndpointWithPortMap
in interface StorageServiceMBean
public java.lang.String getLocalHostId()
StorageServiceMBean
getLocalHostId
in interface StorageServiceMBean
public java.util.UUID getLocalHostUUID()
public java.util.Map<java.lang.String,java.lang.String> getHostIdMap()
StorageServiceMBean
getHostIdMap
in interface StorageServiceMBean
public java.util.Map<java.lang.String,java.lang.String> getEndpointToHostId()
StorageServiceMBean
getEndpointToHostId
in interface StorageServiceMBean
public java.util.Map<java.lang.String,java.lang.String> getEndpointWithPortToHostId()
getEndpointWithPortToHostId
in interface StorageServiceMBean
public java.util.Map<java.lang.String,java.lang.String> getHostIdToEndpoint()
StorageServiceMBean
getHostIdToEndpoint
in interface StorageServiceMBean
public java.util.Map<java.lang.String,java.lang.String> getHostIdToEndpointWithPort()
getHostIdToEndpointWithPort
in interface StorageServiceMBean
public void beforeChange(InetAddressAndPort endpoint, EndpointState currentState, ApplicationState newStateKey, VersionedValue newValue)
beforeChange
in interface IEndpointStateChangeSubscriber
public void onChange(InetAddressAndPort endpoint, ApplicationState state, VersionedValue value)
onChange
in interface IEndpointStateChangeSubscriber
public void updateTopology(InetAddressAndPort endpoint)
public void updateTopology()
public boolean isRpcReady(InetAddressAndPort endpoint)
public void setRpcReady(boolean value)
value
- - true indicates that RPC is ready, false indicates the opposite.public boolean isReplacingSameHostAddressAndHostId(java.util.UUID hostId)
protected void addExpireTimeIfFound(InetAddressAndPort endpoint, long expireTime)
protected long extractExpireTime(java.lang.String[] pieces)
public void onJoin(InetAddressAndPort endpoint, EndpointState epState)
IEndpointStateChangeSubscriber
onJoin
in interface IEndpointStateChangeSubscriber
endpoint
- endpoint for which the state change occurred.epState
- state that actually changed for the above endpoint.public void onAlive(InetAddressAndPort endpoint, EndpointState state)
onAlive
in interface IEndpointStateChangeSubscriber
public void onRemove(InetAddressAndPort endpoint)
onRemove
in interface IEndpointStateChangeSubscriber
public void onDead(InetAddressAndPort endpoint, EndpointState state)
onDead
in interface IEndpointStateChangeSubscriber
public void onRestart(InetAddressAndPort endpoint, EndpointState state)
IEndpointStateChangeSubscriber
state.isAlive() == false
as state
is from before the restarted node is marked up.onRestart
in interface IEndpointStateChangeSubscriber
public java.lang.String getLoadString()
StorageServiceMBean
getLoadString
in interface StorageServiceMBean
public java.util.Map<java.lang.String,java.lang.String> getLoadMapWithPort()
getLoadMapWithPort
in interface StorageServiceMBean
public java.util.Map<java.lang.String,java.lang.String> getLoadMap()
StorageServiceMBean
getLoadMap
in interface StorageServiceMBean
public final void deliverHints(java.lang.String host)
deliverHints
in interface StorageServiceMBean
public java.util.Collection<Token> getLocalTokens()
@Nullable public InetAddressAndPort getEndpointForHostId(java.util.UUID hostId)
@Nullable public java.util.UUID getHostIdForEndpoint(InetAddressAndPort address)
public java.util.List<java.lang.String> getTokens()
StorageServiceMBean
getTokens
in interface StorageServiceMBean
public java.util.List<java.lang.String> getTokens(java.lang.String endpoint) throws java.net.UnknownHostException
StorageServiceMBean
getTokens
in interface StorageServiceMBean
endpoint
- string representation of an nodejava.net.UnknownHostException
public java.lang.String getReleaseVersion()
StorageServiceMBean
getReleaseVersion
in interface StorageServiceMBean
public java.lang.String getSchemaVersion()
StorageServiceMBean
getSchemaVersion
in interface StorageServiceMBean
public java.lang.String getKeyspaceReplicationInfo(java.lang.String keyspaceName)
StorageServiceMBean
getKeyspaceReplicationInfo
in interface StorageServiceMBean
@Deprecated public java.util.List<java.lang.String> getLeavingNodes()
StorageServiceMBean
getLeavingNodes
in interface StorageServiceMBean
public java.util.List<java.lang.String> getLeavingNodesWithPort()
getLeavingNodesWithPort
in interface StorageServiceMBean
@Deprecated public java.util.List<java.lang.String> getMovingNodes()
StorageServiceMBean
getMovingNodes
in interface StorageServiceMBean
public java.util.List<java.lang.String> getMovingNodesWithPort()
getMovingNodesWithPort
in interface StorageServiceMBean
@Deprecated public java.util.List<java.lang.String> getJoiningNodes()
StorageServiceMBean
getJoiningNodes
in interface StorageServiceMBean
public java.util.List<java.lang.String> getJoiningNodesWithPort()
getJoiningNodesWithPort
in interface StorageServiceMBean
@Deprecated public java.util.List<java.lang.String> getLiveNodes()
StorageServiceMBean
getLiveNodes
in interface StorageServiceMBean
public java.util.List<java.lang.String> getLiveNodesWithPort()
getLiveNodesWithPort
in interface StorageServiceMBean
public java.util.Set<InetAddressAndPort> getLiveRingMembers()
public java.util.Set<InetAddressAndPort> getLiveRingMembers(boolean excludeDeadStates)
@Deprecated public java.util.List<java.lang.String> getUnreachableNodes()
StorageServiceMBean
getUnreachableNodes
in interface StorageServiceMBean
public java.util.List<java.lang.String> getUnreachableNodesWithPort()
getUnreachableNodesWithPort
in interface StorageServiceMBean
public java.lang.String[] getAllDataFileLocations()
StorageServiceMBean
getAllDataFileLocations
in interface StorageServiceMBean
public java.lang.String[] getLocalSystemKeyspacesDataFileLocations()
StorageServiceMBean
getLocalSystemKeyspacesDataFileLocations
in interface StorageServiceMBean
public java.lang.String[] getNonLocalSystemKeyspacesDataFileLocations()
StorageServiceMBean
getNonLocalSystemKeyspacesDataFileLocations
in interface StorageServiceMBean
public java.lang.String getCommitLogLocation()
StorageServiceMBean
getCommitLogLocation
in interface StorageServiceMBean
public java.lang.String getSavedCachesLocation()
StorageServiceMBean
getSavedCachesLocation
in interface StorageServiceMBean
public int getCurrentGenerationNumber()
StorageServiceMBean
getCurrentGenerationNumber
in interface StorageServiceMBean
public int forceKeyspaceCleanup(java.lang.String keyspaceName, java.lang.String... tables) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
StorageServiceMBean
forceKeyspaceCleanup
in interface StorageServiceMBean
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
public int forceKeyspaceCleanup(int jobs, java.lang.String keyspaceName, java.lang.String... tables) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
forceKeyspaceCleanup
in interface StorageServiceMBean
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
public int scrub(boolean disableSnapshot, boolean skipCorrupted, java.lang.String keyspaceName, java.lang.String... tables) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
StorageServiceMBean
scrub
in interface StorageServiceMBean
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
public int scrub(boolean disableSnapshot, boolean skipCorrupted, boolean checkData, java.lang.String keyspaceName, java.lang.String... tables) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
scrub
in interface StorageServiceMBean
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
public int scrub(boolean disableSnapshot, boolean skipCorrupted, boolean checkData, int jobs, java.lang.String keyspaceName, java.lang.String... tables) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
scrub
in interface StorageServiceMBean
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
public int scrub(boolean disableSnapshot, boolean skipCorrupted, boolean checkData, boolean reinsertOverflowedTTL, int jobs, java.lang.String keyspaceName, java.lang.String... tables) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
scrub
in interface StorageServiceMBean
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
@Deprecated public int verify(boolean extendedVerify, java.lang.String keyspaceName, java.lang.String... tableNames) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
StorageServiceMBean
verify
in interface StorageServiceMBean
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
public 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
verify
in interface StorageServiceMBean
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
public int upgradeSSTables(java.lang.String keyspaceName, boolean excludeCurrentVersion, java.lang.String... tableNames) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
StorageServiceMBean
upgradeSSTables
in interface StorageServiceMBean
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
public 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
upgradeSSTables
in interface StorageServiceMBean
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
public java.util.List<Pair<java.lang.String,java.lang.String>> getPreparedStatements()
public void dropPreparedStatements(boolean memoryOnly)
public void forceKeyspaceCompaction(boolean splitOutput, java.lang.String keyspaceName, java.lang.String... tableNames) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
StorageServiceMBean
forceKeyspaceCompaction
in interface StorageServiceMBean
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
public int relocateSSTables(java.lang.String keyspaceName, java.lang.String... columnFamilies) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
relocateSSTables
in interface StorageServiceMBean
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
public int relocateSSTables(int jobs, java.lang.String keyspaceName, java.lang.String... columnFamilies) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
relocateSSTables
in interface StorageServiceMBean
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
public int garbageCollect(java.lang.String tombstoneOptionString, int jobs, java.lang.String keyspaceName, java.lang.String... columnFamilies) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
StorageServiceMBean
garbageCollect
in interface StorageServiceMBean
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
public void takeSnapshot(java.lang.String tag, java.util.Map<java.lang.String,java.lang.String> options, java.lang.String... entities) throws java.io.IOException
takeSnapshot
in interface StorageServiceMBean
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
public void takeTableSnapshot(java.lang.String keyspaceName, java.lang.String tableName, java.lang.String tag) throws java.io.IOException
takeTableSnapshot
in interface StorageServiceMBean
keyspaceName
- the keyspace which holds the specified tabletableName
- the table to snapshottag
- the tag given to the snapshot; may not be null or emptyjava.io.IOException
public 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
StorageServiceMBean
forceKeyspaceCompactionForTokenRange
in interface StorageServiceMBean
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
public void takeSnapshot(java.lang.String tag, java.lang.String... keyspaceNames) throws java.io.IOException
takeSnapshot
in interface StorageServiceMBean
tag
- the tag given to the snapshot; may not be null or emptykeyspaceNames
- the names of the keyspaces to snapshot; empty means "all."java.io.IOException
public void takeMultipleTableSnapshot(java.lang.String tag, java.lang.String... tableList) throws java.io.IOException
takeMultipleTableSnapshot
in interface StorageServiceMBean
tag
- the tag given to the snapshot; may not be null or emptytableList
- list of tables from different keyspace in the form of ks1.cf1 ks2.cf2java.io.IOException
public void clearSnapshot(java.lang.String tag, java.lang.String... keyspaceNames) throws java.io.IOException
clearSnapshot
in interface StorageServiceMBean
java.io.IOException
public java.util.Map<java.lang.String,javax.management.openmbean.TabularData> getSnapshotDetails()
StorageServiceMBean
getSnapshotDetails
in interface StorageServiceMBean
public long trueSnapshotsSize()
StorageServiceMBean
trueSnapshotsSize
in interface StorageServiceMBean
public void setSnapshotLinksPerSecond(long throttle)
StorageServiceMBean
setSnapshotLinksPerSecond
in interface StorageServiceMBean
public long getSnapshotLinksPerSecond()
StorageServiceMBean
getSnapshotLinksPerSecond
in interface StorageServiceMBean
public void refreshSizeEstimates() throws java.util.concurrent.ExecutionException
StorageServiceMBean
refreshSizeEstimates
in interface StorageServiceMBean
java.util.concurrent.ExecutionException
public void cleanupSizeEstimates()
StorageServiceMBean
cleanupSizeEstimates
in interface StorageServiceMBean
public java.lang.Iterable<ColumnFamilyStore> getValidColumnFamilies(boolean allowIndexes, boolean autoAddIndexes, java.lang.String keyspaceName, java.lang.String... cfNames) throws java.io.IOException
allowIndexes
- Allow index CF names to be passed inautoAddIndexes
- Automatically add secondary indexes if a CF has themkeyspaceName
- keyspacecfNames
- CFsjava.lang.IllegalArgumentException
- when given CF name does not existjava.io.IOException
public void forceKeyspaceFlush(java.lang.String keyspaceName, java.lang.String... tableNames) throws java.io.IOException
forceKeyspaceFlush
in interface StorageServiceMBean
keyspaceName
- tableNames
- java.io.IOException
public int repairAsync(java.lang.String keyspace, java.util.Map<java.lang.String,java.lang.String> repairSpec)
StorageServiceMBean
repairAsync
in interface StorageServiceMBean
keyspace
- Keyspace name to repair. Should not be null.repairSpec
- repair option.public Pair<java.lang.Integer,java.util.concurrent.Future<?>> repair(java.lang.String keyspace, java.util.Map<java.lang.String,java.lang.String> repairSpec, java.util.List<ProgressListener> listeners)
public Token.TokenFactory getTokenFactory()
public void forceTerminateAllRepairSessions()
forceTerminateAllRepairSessions
in interface StorageServiceMBean
@Nullable public java.util.List<java.lang.String> getParentRepairStatus(int cmd)
StorageServiceMBean
getParentRepairStatus
in interface StorageServiceMBean
cmd
- the int reference returned when issuing the repairorg.apache.cassandra.repair.RepairRunnable.Status
followed by final message or messages of the sessionpublic void setRepairSessionMaxTreeDepth(int depth)
setRepairSessionMaxTreeDepth
in interface StorageServiceMBean
public int getRepairSessionMaxTreeDepth()
getRepairSessionMaxTreeDepth
in interface StorageServiceMBean
public java.util.Collection<Range<Token>> getPrimaryRangesForEndpoint(java.lang.String keyspace, InetAddressAndPort ep)
AbstractReplicationStrategy.calculateNaturalReplicas(org.apache.cassandra.dht.Token, org.apache.cassandra.locator.TokenMetadata)
.keyspace
- Keyspace name to check primary rangesep
- endpoint we are interested in.public java.util.Collection<Range<Token>> getPrimaryRangeForEndpointWithinDC(java.lang.String keyspace, InetAddressAndPort referenceEndpoint)
keyspace
- Keyspace name to check primary rangesreferenceEndpoint
- endpoint we are interested in.getPrimaryRangesForEndpoint(String, InetAddressAndPort)
public java.util.Collection<Range<Token>> getLocalPrimaryRangeForEndpoint(InetAddressAndPort referenceEndpoint)
public java.util.List<Range<Token>> getAllRanges(java.util.List<Token> sortedTokens)
@Deprecated public java.util.List<java.net.InetAddress> getNaturalEndpoints(java.lang.String keyspaceName, java.lang.String cf, java.lang.String key)
getNaturalEndpoints
in interface StorageServiceMBean
keyspaceName
- keyspace name also known as keyspacecf
- Column family namekey
- key for which we need to find the endpointpublic java.util.List<java.lang.String> getNaturalEndpointsWithPort(java.lang.String keyspaceName, java.lang.String cf, java.lang.String key)
getNaturalEndpointsWithPort
in interface StorageServiceMBean
@Deprecated public java.util.List<java.net.InetAddress> getNaturalEndpoints(java.lang.String keyspaceName, java.nio.ByteBuffer key)
getNaturalEndpoints
in interface StorageServiceMBean
public java.util.List<java.lang.String> getNaturalEndpointsWithPort(java.lang.String keyspaceName, java.nio.ByteBuffer key)
getNaturalEndpointsWithPort
in interface StorageServiceMBean
public EndpointsForToken getNaturalReplicasForToken(java.lang.String keyspaceName, java.lang.String cf, java.lang.String key)
public EndpointsForToken getNaturalReplicasForToken(java.lang.String keyspaceName, java.nio.ByteBuffer key)
public boolean isEndpointValidForWrite(java.lang.String keyspace, Token token)
public void setLoggingLevel(java.lang.String classQualifier, java.lang.String rawLevel) throws java.lang.Exception
StorageServiceMBean
< jmxConfigurator />
setsetLoggingLevel
in interface StorageServiceMBean
classQualifier
- The logger's classQualiferrawLevel
- The log leveljava.lang.Exception
Level.toLevel(String)
public java.util.Map<java.lang.String,java.lang.String> getLoggingLevels()
StorageServiceMBean
getLoggingLevels
in interface StorageServiceMBean
public java.util.List<Pair<Range<Token>,java.lang.Long>> getSplits(java.lang.String keyspaceName, java.lang.String cfName, Range<Token> range, int keysPerSplit)
public void decommission(boolean force) throws java.lang.InterruptedException
StorageServiceMBean
decommission
in interface StorageServiceMBean
force
- Decommission even if this will reduce N to be less than RF.java.lang.InterruptedException
public void move(java.lang.String newToken) throws java.io.IOException
move
in interface StorageServiceMBean
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
public java.lang.String getRemovalStatus()
StorageServiceMBean
getRemovalStatus
in interface StorageServiceMBean
public java.lang.String getRemovalStatusWithPort()
getRemovalStatusWithPort
in interface StorageServiceMBean
public void forceRemoveCompletion()
forceRemoveCompletion
in interface StorageServiceMBean
public void removeNode(java.lang.String hostIdString)
removeNode
in interface StorageServiceMBean
hostIdString
- Host ID for the nodepublic void confirmReplication(InetAddressAndPort node)
public java.lang.String getOperationMode()
StorageServiceMBean
getOperationMode
in interface StorageServiceMBean
public boolean isStarting()
StorageServiceMBean
isStarting
in interface StorageServiceMBean
public boolean isMoving()
public boolean isJoining()
public boolean isDrained()
isDrained
in interface StorageServiceMBean
public boolean isDraining()
isDraining
in interface StorageServiceMBean
public boolean isNormal()
public java.lang.String getDrainProgress()
StorageServiceMBean
getDrainProgress
in interface StorageServiceMBean
public void drain() throws java.io.IOException, java.lang.InterruptedException, java.util.concurrent.ExecutionException
drain
in interface StorageServiceMBean
java.io.IOException
java.lang.InterruptedException
java.util.concurrent.ExecutionException
protected void drain(boolean isFinalShutdown) throws java.io.IOException, java.lang.InterruptedException, java.util.concurrent.ExecutionException
java.io.IOException
java.lang.InterruptedException
java.util.concurrent.ExecutionException
public void disableAutoCompaction()
public boolean addPreShutdownHook(java.lang.Runnable hook)
hook:
- the code to runpublic boolean removePreShutdownHook(java.lang.Runnable hook)
public boolean addPostShutdownHook(java.lang.Runnable hook)
hook:
- the code to runpublic boolean removePostShutdownHook(java.lang.Runnable hook)
public IPartitioner setPartitionerUnsafe(IPartitioner newPartitioner)
public void truncate(java.lang.String keyspace, java.lang.String table) throws java.util.concurrent.TimeoutException, java.io.IOException
StorageServiceMBean
truncate
in interface StorageServiceMBean
keyspace
- The keyspace to delete fromtable
- The column family to delete data from.java.util.concurrent.TimeoutException
java.io.IOException
public java.util.Map<java.net.InetAddress,java.lang.Float> getOwnership()
StorageServiceMBean
"token -> %age of cluster owned by that token"
getOwnership
in interface StorageServiceMBean
public java.util.Map<java.lang.String,java.lang.Float> getOwnershipWithPort()
getOwnershipWithPort
in interface StorageServiceMBean
public java.util.LinkedHashMap<java.net.InetAddress,java.lang.Float> effectiveOwnership(java.lang.String keyspace) throws java.lang.IllegalStateException
StorageServiceMBean
effectiveOwnership
in interface StorageServiceMBean
java.lang.IllegalStateException
public java.util.LinkedHashMap<java.lang.String,java.lang.Float> effectiveOwnershipWithPort(java.lang.String keyspace) throws java.lang.IllegalStateException
effectiveOwnershipWithPort
in interface StorageServiceMBean
java.lang.IllegalStateException
public java.util.List<java.lang.String> getKeyspaces()
getKeyspaces
in interface StorageServiceMBean
public java.util.List<java.lang.String> getNonSystemKeyspaces()
getNonSystemKeyspaces
in interface StorageServiceMBean
public java.util.List<java.lang.String> getNonLocalStrategyKeyspaces()
getNonLocalStrategyKeyspaces
in interface StorageServiceMBean
public java.util.Map<java.lang.String,java.lang.String> getViewBuildStatuses(java.lang.String keyspace, java.lang.String view, boolean withPort)
public java.util.Map<java.lang.String,java.lang.String> getViewBuildStatuses(java.lang.String keyspace, java.lang.String view)
getViewBuildStatuses
in interface StorageServiceMBean
public java.util.Map<java.lang.String,java.lang.String> getViewBuildStatusesWithPort(java.lang.String keyspace, java.lang.String view)
getViewBuildStatusesWithPort
in interface StorageServiceMBean
public void setDynamicUpdateInterval(int dynamicUpdateInterval)
setDynamicUpdateInterval
in interface StorageServiceMBean
public int getDynamicUpdateInterval()
getDynamicUpdateInterval
in interface StorageServiceMBean
public 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
StorageServiceMBean
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.updateSnitch
in interface StorageServiceMBean
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
public java.lang.String getBatchlogEndpointStrategy()
getBatchlogEndpointStrategy
in interface StorageServiceMBean
public void setBatchlogEndpointStrategy(java.lang.String batchlogEndpointStrategy)
StorageServiceMBean
Config.BatchlogEndpointStrategy
for valid values.setBatchlogEndpointStrategy
in interface StorageServiceMBean
public void bulkLoad(java.lang.String directory)
StorageServiceMBean
bulkLoad
in interface StorageServiceMBean
public java.lang.String bulkLoadAsync(java.lang.String directory)
StorageServiceMBean
bulkLoadAsync
in interface StorageServiceMBean
public void rescheduleFailedDeletions()
rescheduleFailedDeletions
in interface StorageServiceMBean
@Deprecated public void loadNewSSTables(java.lang.String ksName, java.lang.String cfName)
loadNewSSTables
in interface StorageServiceMBean
ksName
- The parent keyspace namecfName
- The ColumnFamily name where SSTables belongColumnFamilyStoreMBean.loadNewSSTables()
public java.util.List<java.lang.String> sampleKeyRange()
sampleKeyRange
in interface StorageServiceMBean
public java.util.Map<java.lang.String,java.util.List<javax.management.openmbean.CompositeData>> samplePartitions(int durationMillis, int capacity, int count, java.util.List<java.lang.String> samplers) throws javax.management.openmbean.OpenDataException
samplePartitions
in interface StorageServiceMBean
javax.management.openmbean.OpenDataException
public void rebuildSecondaryIndex(java.lang.String ksName, java.lang.String cfName, java.lang.String... idxNames)
StorageServiceMBean
rebuildSecondaryIndex
in interface StorageServiceMBean
public void resetLocalSchema()
resetLocalSchema
in interface StorageServiceMBean
public void reloadLocalSchema()
reloadLocalSchema
in interface StorageServiceMBean
public void setTraceProbability(double probability)
StorageServiceMBean
setTraceProbability
in interface StorageServiceMBean
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)public double getTraceProbability()
StorageServiceMBean
getTraceProbability
in interface StorageServiceMBean
public boolean shouldTraceProbablistically()
public void disableAutoCompaction(java.lang.String ks, java.lang.String... tables) throws java.io.IOException
disableAutoCompaction
in interface StorageServiceMBean
java.io.IOException
public void enableAutoCompaction(java.lang.String ks, java.lang.String... tables) throws java.io.IOException
enableAutoCompaction
in interface StorageServiceMBean
java.io.IOException
public java.util.Map<java.lang.String,java.lang.Boolean> getAutoCompactionStatus(java.lang.String ks, java.lang.String... tables) throws java.io.IOException
getAutoCompactionStatus
in interface StorageServiceMBean
java.io.IOException
public java.lang.String getClusterName()
getClusterName
in interface StorageServiceMBean
public java.lang.String getPartitionerName()
getPartitionerName
in interface StorageServiceMBean
public void setSSTablePreemptiveOpenIntervalInMB(int intervalInMB)
setSSTablePreemptiveOpenIntervalInMB
in interface StorageServiceMBean
public int getSSTablePreemptiveOpenIntervalInMB()
getSSTablePreemptiveOpenIntervalInMB
in interface StorageServiceMBean
public boolean getMigrateKeycacheOnCompaction()
getMigrateKeycacheOnCompaction
in interface StorageServiceMBean
public void setMigrateKeycacheOnCompaction(boolean invalidateKeyCacheOnCompaction)
setMigrateKeycacheOnCompaction
in interface StorageServiceMBean
public int getTombstoneWarnThreshold()
StorageServiceMBean
getTombstoneWarnThreshold
in interface StorageServiceMBean
public void setTombstoneWarnThreshold(int threshold)
StorageServiceMBean
setTombstoneWarnThreshold
in interface StorageServiceMBean
public int getTombstoneFailureThreshold()
StorageServiceMBean
getTombstoneFailureThreshold
in interface StorageServiceMBean
public void setTombstoneFailureThreshold(int threshold)
StorageServiceMBean
setTombstoneFailureThreshold
in interface StorageServiceMBean
public int getCachedReplicaRowsWarnThreshold()
StorageServiceMBean
getCachedReplicaRowsWarnThreshold
in interface StorageServiceMBean
public void setCachedReplicaRowsWarnThreshold(int threshold)
StorageServiceMBean
setCachedReplicaRowsWarnThreshold
in interface StorageServiceMBean
public int getCachedReplicaRowsFailThreshold()
StorageServiceMBean
getCachedReplicaRowsFailThreshold
in interface StorageServiceMBean
public void setCachedReplicaRowsFailThreshold(int threshold)
StorageServiceMBean
setCachedReplicaRowsFailThreshold
in interface StorageServiceMBean
public int getColumnIndexCacheSize()
StorageServiceMBean
getColumnIndexCacheSize
in interface StorageServiceMBean
public void setColumnIndexCacheSize(int cacheSizeInKB)
StorageServiceMBean
setColumnIndexCacheSize
in interface StorageServiceMBean
public int getBatchSizeFailureThreshold()
StorageServiceMBean
getBatchSizeFailureThreshold
in interface StorageServiceMBean
public void setBatchSizeFailureThreshold(int threshold)
StorageServiceMBean
setBatchSizeFailureThreshold
in interface StorageServiceMBean
public int getBatchSizeWarnThreshold()
StorageServiceMBean
getBatchSizeWarnThreshold
in interface StorageServiceMBean
public void setBatchSizeWarnThreshold(int threshold)
StorageServiceMBean
setBatchSizeWarnThreshold
in interface StorageServiceMBean
public int getInitialRangeTombstoneListAllocationSize()
StorageServiceMBean
getInitialRangeTombstoneListAllocationSize
in interface StorageServiceMBean
public void setInitialRangeTombstoneListAllocationSize(int size)
StorageServiceMBean
setInitialRangeTombstoneListAllocationSize
in interface StorageServiceMBean
public double getRangeTombstoneResizeListGrowthFactor()
StorageServiceMBean
getRangeTombstoneResizeListGrowthFactor
in interface StorageServiceMBean
public void setRangeTombstoneListResizeGrowthFactor(double growthFactor) throws java.lang.IllegalStateException
StorageServiceMBean
setRangeTombstoneListResizeGrowthFactor
in interface StorageServiceMBean
java.lang.IllegalStateException
public boolean getTransferHintsOnDecommission()
getTransferHintsOnDecommission
in interface StorageServiceMBean
public void setTransferHintsOnDecommission(boolean enabled)
setTransferHintsOnDecommission
in interface StorageServiceMBean
public boolean isHintTtlUseMutationCreationTime()
StorageServiceMBean
isHintTtlUseMutationCreationTime
in interface StorageServiceMBean
public void setUseCreationTimeForHintTtl(boolean enabled)
StorageServiceMBean
setUseCreationTimeForHintTtl
in interface StorageServiceMBean
public void setHintedHandoffThrottleInKB(int throttleInKB)
StorageServiceMBean
setHintedHandoffThrottleInKB
in interface StorageServiceMBean
public int getMaxHintTTL()
StorageServiceMBean
getMaxHintTTL
in interface StorageServiceMBean
public void setMaxHintTTL(int maxHintTTL)
StorageServiceMBean
setMaxHintTTL
in interface StorageServiceMBean
public void clearConnectionHistory()
StorageServiceMBean
clearConnectionHistory
in interface StorageServiceMBean
public void disableAuditLog()
disableAuditLog
in interface StorageServiceMBean
public 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, java.lang.IllegalStateException
enableAuditLog
in interface StorageServiceMBean
ConfigurationException
java.lang.IllegalStateException
public 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, java.lang.IllegalStateException
enableAuditLog
in interface StorageServiceMBean
ConfigurationException
java.lang.IllegalStateException
public boolean isAuditLogEnabled()
isAuditLogEnabled
in interface StorageServiceMBean
public java.lang.String getCorruptedTombstoneStrategy()
getCorruptedTombstoneStrategy
in interface StorageServiceMBean
public void setCorruptedTombstoneStrategy(java.lang.String strategy)
setCorruptedTombstoneStrategy
in interface StorageServiceMBean
public long getNativeTransportMaxConcurrentRequestsInBytes()
getNativeTransportMaxConcurrentRequestsInBytes
in interface StorageServiceMBean
public void setNativeTransportMaxConcurrentRequestsInBytes(long newLimit)
setNativeTransportMaxConcurrentRequestsInBytes
in interface StorageServiceMBean
public long getNativeTransportMaxConcurrentRequestsInBytesPerIp()
getNativeTransportMaxConcurrentRequestsInBytesPerIp
in interface StorageServiceMBean
public void setNativeTransportMaxConcurrentRequestsInBytesPerIp(long newLimit)
setNativeTransportMaxConcurrentRequestsInBytesPerIp
in interface StorageServiceMBean
public boolean isOutOfTokenRangeRequestLoggingEnabled()
StorageServiceMBean
isOutOfTokenRangeRequestLoggingEnabled
in interface StorageServiceMBean
public void setOutOfTokenRangeRequestLoggingEnabled(boolean enabled)
setOutOfTokenRangeRequestLoggingEnabled
in interface StorageServiceMBean
public boolean isOutOfTokenRangeRequestRejectionEnabled()
isOutOfTokenRangeRequestRejectionEnabled
in interface StorageServiceMBean
public void setOutOfTokenRangeRequestRejectionEnabled(boolean enabled)
setOutOfTokenRangeRequestRejectionEnabled
in interface StorageServiceMBean
public void shutdownServer()
public void enableFullQueryLogger(java.lang.String path, java.lang.String rollCycle, java.lang.Boolean blocking, int maxQueueWeight, long maxLogSize, java.lang.String archiveCommand, int maxArchiveRetries)
StorageServiceMBean
enableFullQueryLogger
in interface StorageServiceMBean
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 commandpublic void resetFullQueryLogger()
StorageServiceMBean
resetFullQueryLogger
in interface StorageServiceMBean
public void stopFullQueryLogger()
StorageServiceMBean
stopFullQueryLogger
in interface StorageServiceMBean
public boolean isFullQueryLogEnabled()
isFullQueryLogEnabled
in interface StorageServiceMBean
public javax.management.openmbean.CompositeData getFullQueryLoggerOptions()
StorageServiceMBean
getFullQueryLoggerOptions
in interface StorageServiceMBean
public java.util.Map<java.lang.String,java.util.Set<java.net.InetAddress>> getOutstandingSchemaVersions()
StorageServiceMBean
getOutstandingSchemaVersions
in interface StorageServiceMBean
public java.util.Map<java.lang.String,java.util.Set<java.lang.String>> getOutstandingSchemaVersionsWithPort()
getOutstandingSchemaVersionsWithPort
in interface StorageServiceMBean
public boolean autoOptimiseIncRepairStreams()
autoOptimiseIncRepairStreams
in interface StorageServiceMBean
public void setAutoOptimiseIncRepairStreams(boolean enabled)
setAutoOptimiseIncRepairStreams
in interface StorageServiceMBean
public boolean autoOptimiseFullRepairStreams()
autoOptimiseFullRepairStreams
in interface StorageServiceMBean
public void setAutoOptimiseFullRepairStreams(boolean enabled)
setAutoOptimiseFullRepairStreams
in interface StorageServiceMBean
public boolean autoOptimisePreviewRepairStreams()
autoOptimisePreviewRepairStreams
in interface StorageServiceMBean
public void setAutoOptimisePreviewRepairStreams(boolean enabled)
setAutoOptimisePreviewRepairStreams
in interface StorageServiceMBean
public int getTableCountWarnThreshold()
getTableCountWarnThreshold
in interface StorageServiceMBean
public void setTableCountWarnThreshold(int value)
setTableCountWarnThreshold
in interface StorageServiceMBean
public int getKeyspaceCountWarnThreshold()
getKeyspaceCountWarnThreshold
in interface StorageServiceMBean
public void setKeyspaceCountWarnThreshold(int value)
setKeyspaceCountWarnThreshold
in interface StorageServiceMBean
public java.lang.Long getRepairRpcTimeout()
getRepairRpcTimeout
in interface StorageServiceMBean
public void setRepairRpcTimeout(java.lang.Long timeoutInMillis)
setRepairRpcTimeout
in interface StorageServiceMBean
Copyright © 2009- The Apache Software Foundation