|
||||||||||
PREV CLASS NEXT CLASS | FRAMES NO FRAMES | |||||||||
SUMMARY: NESTED | FIELD | CONSTR | METHOD | DETAIL: FIELD | CONSTR | METHOD |
java.lang.Objectorg.apache.cassandra.service.StorageService
public class StorageService
Nested Class Summary | |
---|---|
static class |
StorageService.Verb
|
Field Summary | |
---|---|
static StorageService |
instance
|
static DebuggableScheduledThreadPoolExecutor |
optionalTasks
tasks that do not need to be waited for on shutdown/drain |
static int |
RING_DELAY
|
static DebuggableScheduledThreadPoolExecutor |
scheduledTasks
This pool is used for periodic short (sub-second) tasks. |
static DebuggableScheduledThreadPoolExecutor |
tasks
This pool is used by tasks that can have longer execution times, and usually are non periodic. |
VersionedValue.VersionedValueFactory |
valueFactory
|
static StorageService.Verb[] |
VERBS
|
static java.util.EnumMap<StorageService.Verb,Stage> |
verbStages
|
Constructor Summary | |
---|---|
StorageService()
|
Method Summary | |
---|---|
protected void |
addExpireTimeIfFound(java.net.InetAddress endpoint,
long expireTime)
|
void |
bulkLoad(java.lang.String directory)
|
static void |
calculatePendingRanges(AbstractReplicationStrategy strategy,
java.lang.String table)
|
void |
clearSnapshot(java.lang.String tag,
java.lang.String... tableNames)
Remove the snapshot with the given name from the given tables. |
void |
confirmReplication(java.net.InetAddress node)
|
void |
decommission()
transfer this node's data to other machines and remove it from service. |
void |
deliverHints(java.net.InetAddress endpoint)
Deliver hints to the specified node when it has crashed and come back up/ marked as alive after a network partition |
void |
deliverHints(java.lang.String host)
force hint delivery to an endpoint |
java.util.List<org.apache.cassandra.thrift.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 |
void |
drain()
shuts node off to writes, empties memtables and the commit log. |
protected long |
extractExpireTime(java.lang.String[] pieces)
|
void |
finishBootstrapping()
|
void |
flushLargestMemtables()
Flushes the two largest memtables by ops and by throughput |
void |
forceRemoveCompletion()
Force a remove operation to complete. |
void |
forceTableCleanup(java.lang.String tableName,
java.lang.String... columnFamilies)
Trigger a cleanup of keys on a single keyspace |
void |
forceTableCompaction(java.lang.String tableName,
java.lang.String... columnFamilies)
Forces major compaction of a single keyspace |
void |
forceTableFlush(java.lang.String tableName,
java.lang.String... columnFamilies)
Flush all memtables for a table and column families. |
AntiEntropyService.RepairFuture |
forceTableRepair(Range range,
java.lang.String tableName,
java.lang.String... columnFamilies)
|
void |
forceTableRepair(java.lang.String tableName,
java.lang.String... columnFamilies)
Trigger proactive repair for a table and column families. |
void |
forceTableRepairPrimaryRange(java.lang.String tableName,
java.lang.String... columnFamilies)
Triggers proactive repair but only for the node primary range. |
void |
forceTerminateAllRepairSessions()
|
java.lang.String[] |
getAllDataFileLocations()
Get the list of all data file locations from conf |
java.lang.String[] |
getAllDataFileLocationsForTable(java.lang.String table)
Get the list of data file locations for a given table |
java.util.List<Range> |
getAllRanges(java.util.List<Token> sortedTokens)
Get all ranges that span the ring given a set of tokens. |
Token |
getBootstrapToken()
return a token to which if a node bootstraps it will get about 1/2 of this node's range |
java.lang.String |
getCommitLogLocation()
Get location of the commit log |
int |
getCompactionThroughputMbPerSec()
|
int |
getCurrentGenerationNumber()
Return the generation value for this node. |
java.lang.String |
getDrainProgress()
get the progress of a drain operation |
int |
getExceptionCount()
|
java.util.List<java.lang.String> |
getJoiningNodes()
Retrieve the list of nodes currently bootstrapping into the ring. |
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.net.InetAddress> |
getLiveNaturalEndpoints(java.lang.String table,
java.nio.ByteBuffer key)
This method attempts to return N endpoints that are responsible for storing the specified key i.e for replication. |
java.util.List<java.net.InetAddress> |
getLiveNaturalEndpoints(java.lang.String table,
Token token)
|
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. |
double |
getLoad()
raw load value |
java.util.Map<java.lang.String,java.lang.String> |
getLoadMap()
Human-readable load value. |
java.lang.String |
getLoadString()
Human-readable load value |
Range |
getLocalPrimaryRange()
|
java.util.Collection<Range> |
getLocalRanges(java.lang.String table)
|
Token |
getLocalToken()
|
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 table,
java.nio.ByteBuffer key)
|
java.util.List<java.net.InetAddress> |
getNaturalEndpoints(java.lang.String table,
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.net.InetAddress> |
getNaturalEndpoints(java.lang.String table,
Token token)
This method returns the N endpoints that are responsible for storing the specified key i.e for replication. |
java.lang.String |
getOperationMode()
get the operational mode (leaving, joining, normal, decommissioned, client) |
java.util.Map<Token,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" |
static IPartitioner |
getPartitioner()
|
java.util.Map<Range,java.util.List<java.lang.String>> |
getPendingRangeToEndpointMap(java.lang.String keyspace)
Retrieve a map of pending ranges to endpoints that describe the ring topology |
Range |
getPrimaryRangeForEndpoint(java.net.InetAddress ep)
Get the primary range for the specified endpoint. |
java.util.Map<Range,java.util.List<java.net.InetAddress>> |
getRangeToAddressMap(java.lang.String keyspace)
|
java.util.Map<Range,java.util.List<java.lang.String>> |
getRangeToEndpointMap(java.lang.String keyspace)
for a keyspace, return the ranges and corresponding listen addresses. |
java.util.Map<Range,java.util.List<java.lang.String>> |
getRangeToRpcaddressMap(java.lang.String keyspace)
for a keyspace, return the ranges and corresponding RPC addresses for a given keyspace. |
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 |
getRpcaddress(java.net.InetAddress endpoint)
Return the rpc address associated with an endpoint as a string. |
java.lang.String |
getSavedCachesLocation()
Get location of the saved caches dir |
java.util.List<Token> |
getSplits(java.lang.String table,
java.lang.String cfName,
Range range,
int keysPerSplit)
|
java.net.InetAddress |
getSuccessor(java.net.InetAddress ep)
|
java.lang.String |
getToken()
Fetch a string representation of the token. |
TokenMetadata |
getTokenMetadata()
|
java.util.Map<Token,java.lang.String> |
getTokenToEndpointMap()
Retrieve a map of tokens to endpoints, including the bootstrapping ones. |
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.lang.Iterable<ColumnFamilyStore> |
getValidColumnFamilies(java.lang.String tableName,
java.lang.String... cfNames)
|
void |
initClient()
|
void |
initClient(int delay)
|
void |
initServer()
|
void |
initServer(int delay)
|
void |
invalidateKeyCaches(java.lang.String tableName,
java.lang.String... columnFamilies)
|
void |
invalidateRowCaches(java.lang.String tableName,
java.lang.String... columnFamilies)
|
boolean |
isBootstrapMode()
|
boolean |
isClientMode()
|
boolean |
isInitialized()
|
boolean |
isJoined()
|
boolean |
isRPCServerRunning()
|
void |
joinRing()
|
void |
loadNewSSTables(java.lang.String ksName,
java.lang.String cfName)
#Load new SSTables to the given keyspace/columnFamily |
void |
move(java.lang.String newToken)
|
void |
onAlive(java.net.InetAddress endpoint,
EndpointState state)
|
void |
onChange(java.net.InetAddress endpoint,
ApplicationState state,
VersionedValue value)
|
void |
onDead(java.net.InetAddress endpoint,
EndpointState state)
|
void |
onJoin(java.net.InetAddress endpoint,
EndpointState epState)
Use to inform interested parties about the change in the state for specified endpoint |
void |
onRemove(java.net.InetAddress endpoint)
|
void |
onRestart(java.net.InetAddress endpoint,
EndpointState state)
Called whenever a node is restarted. |
void |
reduceCacheSizes()
|
void |
registerDaemon(CassandraDaemon daemon)
|
void |
removeToken(java.lang.String tokenString)
Remove a node that has died, attempting to restore the replica count. |
void |
removeToken(java.lang.String tokenString,
int delay)
|
void |
requestGC()
|
void |
rescheduleFailedDeletions()
|
void |
saveCaches()
save row and key caches |
void |
scrub(java.lang.String tableName,
java.lang.String... columnFamilies)
Scrub (deserialize + reserialize at the latest version, skipping bad rows if any) the given keyspace. |
void |
setCompactionThroughputMbPerSec(int value)
|
void |
setLog4jLevel(java.lang.String classQualifier,
java.lang.String rawLevel)
set the logging level at runtime |
void |
setToken(Token token)
This method updates the local token on disk |
void |
startGossiping()
|
void |
startRPCServer()
|
void |
stopClient()
|
void |
stopGossiping()
|
void |
stopRPCServer()
|
void |
takeSnapshot(java.lang.String tag,
java.lang.String... tableNames)
Takes the snapshot for the given tables. |
void |
truncate(java.lang.String keyspace,
java.lang.String columnFamily)
Truncates (deletes) the given columnFamily 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 |
void |
upgradeSSTables(java.lang.String tableName,
java.lang.String... columnFamilies)
Rewrite all sstables to the latest version. |
Methods inherited from class java.lang.Object |
---|
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait |
Field Detail |
---|
public static final int RING_DELAY
public static final StorageService.Verb[] VERBS
public static final java.util.EnumMap<StorageService.Verb,Stage> verbStages
public static final DebuggableScheduledThreadPoolExecutor scheduledTasks
public static final DebuggableScheduledThreadPoolExecutor tasks
public static final DebuggableScheduledThreadPoolExecutor optionalTasks
public VersionedValue.VersionedValueFactory valueFactory
public static final StorageService instance
Constructor Detail |
---|
public StorageService()
Method Detail |
---|
public static IPartitioner getPartitioner()
public java.util.Collection<Range> getLocalRanges(java.lang.String table)
public Range getLocalPrimaryRange()
public void finishBootstrapping()
public void setToken(Token token)
public void registerDaemon(CassandraDaemon daemon)
public void stopGossiping()
stopGossiping
in interface StorageServiceMBean
public void startGossiping()
startGossiping
in interface StorageServiceMBean
public void startRPCServer()
startRPCServer
in interface StorageServiceMBean
public void stopRPCServer()
stopRPCServer
in interface StorageServiceMBean
public boolean isRPCServerRunning()
isRPCServerRunning
in interface StorageServiceMBean
public void stopClient()
public boolean isInitialized()
isInitialized
in interface StorageServiceMBean
public void initClient() throws java.io.IOException, ConfigurationException
java.io.IOException
ConfigurationException
public void initClient(int delay) throws java.io.IOException, ConfigurationException
java.io.IOException
ConfigurationException
public void initServer() throws java.io.IOException, ConfigurationException
java.io.IOException
ConfigurationException
public void initServer(int delay) throws java.io.IOException, ConfigurationException
java.io.IOException
ConfigurationException
public void joinRing() throws java.io.IOException, ConfigurationException
joinRing
in interface StorageServiceMBean
java.io.IOException
ConfigurationException
public boolean isJoined()
isJoined
in interface StorageServiceMBean
public int getCompactionThroughputMbPerSec()
getCompactionThroughputMbPerSec
in interface StorageServiceMBean
public void setCompactionThroughputMbPerSec(int value)
setCompactionThroughputMbPerSec
in interface StorageServiceMBean
public boolean isBootstrapMode()
public TokenMetadata getTokenMetadata()
public java.util.Map<Range,java.util.List<java.lang.String>> getRangeToEndpointMap(java.lang.String keyspace)
getRangeToEndpointMap
in interface StorageServiceMBean
keyspace
-
public java.lang.String getRpcaddress(java.net.InetAddress endpoint)
endpoint
- The endpoint to get rpc address for
public java.util.Map<Range,java.util.List<java.lang.String>> getRangeToRpcaddressMap(java.lang.String keyspace)
getRangeToRpcaddressMap
in interface StorageServiceMBean
keyspace
-
public java.util.Map<Range,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<Range,java.util.List<java.net.InetAddress>> getRangeToAddressMap(java.lang.String keyspace)
public java.util.List<java.lang.String> describeRingJMX(java.lang.String keyspace) throws org.apache.cassandra.thrift.InvalidRequestException
describeRing(String)
but converts TokenRange to the String for JMX compatibility
describeRingJMX
in interface StorageServiceMBean
keyspace
- The keyspace to fetch information about
org.apache.cassandra.thrift.InvalidRequestException
- if there is no ring information available about keyspacepublic java.util.List<org.apache.cassandra.thrift.TokenRange> describeRing(java.lang.String keyspace) throws org.apache.cassandra.thrift.InvalidRequestException
keyspace
- The keyspace to fetch information about
org.apache.cassandra.thrift.InvalidRequestException
- if there is no ring information available about keyspacepublic java.util.Map<Token,java.lang.String> getTokenToEndpointMap()
StorageServiceMBean
getTokenToEndpointMap
in interface StorageServiceMBean
public void onChange(java.net.InetAddress endpoint, ApplicationState state, VersionedValue value)
onChange
in interface IEndpointStateChangeSubscriber
protected void addExpireTimeIfFound(java.net.InetAddress endpoint, long expireTime)
protected long extractExpireTime(java.lang.String[] pieces)
public static void calculatePendingRanges(AbstractReplicationStrategy strategy, java.lang.String table)
public void onJoin(java.net.InetAddress 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(java.net.InetAddress endpoint, EndpointState state)
onAlive
in interface IEndpointStateChangeSubscriber
public void onRemove(java.net.InetAddress endpoint)
onRemove
in interface IEndpointStateChangeSubscriber
public void onDead(java.net.InetAddress endpoint, EndpointState state)
onDead
in interface IEndpointStateChangeSubscriber
public void onRestart(java.net.InetAddress endpoint, EndpointState state)
IEndpointStateChangeSubscriber
state.isAlive() == false
as state
is from before the restarted node is marked up.
onRestart
in interface IEndpointStateChangeSubscriber
public double getLoad()
getLoad
in interface StorageServiceMBean
public java.lang.String getLoadString()
StorageServiceMBean
getLoadString
in interface StorageServiceMBean
public java.util.Map<java.lang.String,java.lang.String> getLoadMap()
StorageServiceMBean
getLoadMap
in interface StorageServiceMBean
public final void deliverHints(java.net.InetAddress endpoint)
public final void deliverHints(java.lang.String host) throws java.net.UnknownHostException
StorageServiceMBean
deliverHints
in interface StorageServiceMBean
java.net.UnknownHostException
public Token getLocalToken()
public java.lang.String getToken()
StorageServiceMBean
getToken
in interface StorageServiceMBean
public java.lang.String getReleaseVersion()
StorageServiceMBean
getReleaseVersion
in interface StorageServiceMBean
public java.util.List<java.lang.String> getLeavingNodes()
StorageServiceMBean
getLeavingNodes
in interface StorageServiceMBean
public java.util.List<java.lang.String> getMovingNodes()
StorageServiceMBean
getMovingNodes
in interface StorageServiceMBean
public java.util.List<java.lang.String> getJoiningNodes()
StorageServiceMBean
getJoiningNodes
in interface StorageServiceMBean
public java.util.List<java.lang.String> getLiveNodes()
StorageServiceMBean
getLiveNodes
in interface StorageServiceMBean
public java.util.List<java.lang.String> getUnreachableNodes()
StorageServiceMBean
getUnreachableNodes
in interface StorageServiceMBean
public java.lang.String[] getAllDataFileLocations()
StorageServiceMBean
getAllDataFileLocations
in interface StorageServiceMBean
public java.lang.String[] getAllDataFileLocationsForTable(java.lang.String table)
StorageServiceMBean
getAllDataFileLocationsForTable
in interface StorageServiceMBean
table
- the table to get locations for.
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 void forceTableCleanup(java.lang.String tableName, java.lang.String... columnFamilies) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
StorageServiceMBean
forceTableCleanup
in interface StorageServiceMBean
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
public void scrub(java.lang.String tableName, java.lang.String... columnFamilies) 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 void upgradeSSTables(java.lang.String tableName, java.lang.String... columnFamilies) 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 void forceTableCompaction(java.lang.String tableName, java.lang.String... columnFamilies) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
StorageServiceMBean
forceTableCompaction
in interface StorageServiceMBean
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
public void invalidateKeyCaches(java.lang.String tableName, java.lang.String... columnFamilies) throws java.io.IOException
invalidateKeyCaches
in interface StorageServiceMBean
java.io.IOException
public void invalidateRowCaches(java.lang.String tableName, java.lang.String... columnFamilies) throws java.io.IOException
invalidateRowCaches
in interface StorageServiceMBean
java.io.IOException
public void takeSnapshot(java.lang.String tag, java.lang.String... tableNames) throws java.io.IOException
takeSnapshot
in interface StorageServiceMBean
tag
- the tag given to the snapshot; may not be null or emptytableNames
- the name of the tables to snapshot; empty means "all."
java.io.IOException
public void clearSnapshot(java.lang.String tag, java.lang.String... tableNames) throws java.io.IOException
clearSnapshot
in interface StorageServiceMBean
java.io.IOException
public java.lang.Iterable<ColumnFamilyStore> getValidColumnFamilies(java.lang.String tableName, java.lang.String... cfNames) throws java.io.IOException
java.io.IOException
public void forceTableFlush(java.lang.String tableName, java.lang.String... columnFamilies) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
forceTableFlush
in interface StorageServiceMBean
tableName
- columnFamilies
-
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
public void forceTableRepair(java.lang.String tableName, java.lang.String... columnFamilies) throws java.io.IOException
forceTableRepair
in interface StorageServiceMBean
tableName
- columnFamilies
-
java.io.IOException
public void forceTableRepairPrimaryRange(java.lang.String tableName, java.lang.String... columnFamilies) throws java.io.IOException
StorageServiceMBean
forceTableRepairPrimaryRange
in interface StorageServiceMBean
java.io.IOException
public AntiEntropyService.RepairFuture forceTableRepair(Range range, java.lang.String tableName, java.lang.String... columnFamilies) throws java.io.IOException
java.io.IOException
public void forceTerminateAllRepairSessions()
forceTerminateAllRepairSessions
in interface StorageServiceMBean
public java.net.InetAddress getSuccessor(java.net.InetAddress ep)
public Range getPrimaryRangeForEndpoint(java.net.InetAddress ep)
ep
- endpoint we are interested in.
public java.util.List<Range> getAllRanges(java.util.List<Token> sortedTokens)
public java.util.List<java.net.InetAddress> getNaturalEndpoints(java.lang.String table, java.lang.String cf, java.lang.String key)
getNaturalEndpoints
in interface StorageServiceMBean
table
- keyspace name also known as tablecf
- Column family namekey
- - key for which we need to find the endpoint return value -
the endpoint responsible for this keypublic java.util.List<java.net.InetAddress> getNaturalEndpoints(java.lang.String table, java.nio.ByteBuffer key)
getNaturalEndpoints
in interface StorageServiceMBean
public java.util.List<java.net.InetAddress> getNaturalEndpoints(java.lang.String table, Token token)
token
- - token for which we need to find the endpoint return value -
the endpoint responsible for this tokenpublic java.util.List<java.net.InetAddress> getLiveNaturalEndpoints(java.lang.String table, java.nio.ByteBuffer key)
key
- - key for which we need to find the endpoint return value -
the endpoint responsible for this keypublic java.util.List<java.net.InetAddress> getLiveNaturalEndpoints(java.lang.String table, Token token)
public void setLog4jLevel(java.lang.String classQualifier, java.lang.String rawLevel)
StorageServiceMBean
setLog4jLevel
in interface StorageServiceMBean
public java.util.List<Token> getSplits(java.lang.String table, java.lang.String cfName, Range range, int keysPerSplit)
public Token getBootstrapToken()
public void decommission() throws java.lang.InterruptedException
StorageServiceMBean
decommission
in interface StorageServiceMBean
java.lang.InterruptedException
public void move(java.lang.String newToken) throws java.io.IOException, java.lang.InterruptedException, ConfigurationException
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
java.lang.InterruptedException
ConfigurationException
public java.lang.String getRemovalStatus()
getRemovalStatus
in interface StorageServiceMBean
public void forceRemoveCompletion()
forceRemoveCompletion
in interface StorageServiceMBean
public void removeToken(java.lang.String tokenString)
removeToken
in interface StorageServiceMBean
tokenString
- token for the nodepublic void removeToken(java.lang.String tokenString, int delay)
public void confirmReplication(java.net.InetAddress node)
public boolean isClientMode()
public void requestGC()
public java.lang.String getOperationMode()
StorageServiceMBean
getOperationMode
in interface StorageServiceMBean
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
public void truncate(java.lang.String keyspace, java.lang.String columnFamily) throws org.apache.cassandra.thrift.UnavailableException, java.util.concurrent.TimeoutException, java.io.IOException
StorageServiceMBean
truncate
in interface StorageServiceMBean
keyspace
- The keyspace to delete fromcolumnFamily
- The column family to delete data from.
org.apache.cassandra.thrift.UnavailableException
- if some of the hosts in the ring are down.
java.util.concurrent.TimeoutException
java.io.IOException
public void saveCaches() throws java.util.concurrent.ExecutionException, java.lang.InterruptedException
StorageServiceMBean
saveCaches
in interface StorageServiceMBean
java.util.concurrent.ExecutionException
java.lang.InterruptedException
public java.util.Map<Token,java.lang.Float> getOwnership()
StorageServiceMBean
getOwnership
in interface StorageServiceMBean
public java.util.List<java.lang.String> getKeyspaces()
getKeyspaces
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 ConfigurationException
StorageServiceMBean
updateSnitch
in interface StorageServiceMBean
epSnitchClassName
- the canonical path name for a class implementing IEndpointSnitchdynamic
- boolean that decides whether dynamicsnitch is used or notdynamicUpdateInterval
- integer, in ms (default 100)dynamicResetInterval
- integer, in ms (default 600,000)dynamicBadnessThreshold
- double, (default 0.0)
ConfigurationException
- classname not found on classpathpublic void flushLargestMemtables()
public void reduceCacheSizes()
public void bulkLoad(java.lang.String directory)
bulkLoad
in interface StorageServiceMBean
public int getExceptionCount()
getExceptionCount
in interface StorageServiceMBean
public void rescheduleFailedDeletions()
rescheduleFailedDeletions
in interface StorageServiceMBean
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 belong
|
||||||||||
PREV CLASS NEXT CLASS | FRAMES NO FRAMES | |||||||||
SUMMARY: NESTED | FIELD | CONSTR | METHOD | DETAIL: FIELD | CONSTR | METHOD |