Package org.apache.cassandra.tools
Class NodeProbe
- java.lang.Object
-
- org.apache.cassandra.tools.NodeProbe
-
- All Implemented Interfaces:
java.lang.AutoCloseable
public class NodeProbe extends java.lang.Object implements java.lang.AutoCloseable
JMX client operations for Cassandra.
-
-
Field Summary
-
Constructor Summary
Constructors Modifier Constructor Description protected
NodeProbe()
NodeProbe(java.lang.String host)
Creates a NodeProbe using the specified JMX host and default port.NodeProbe(java.lang.String host, int port)
Creates a NodeProbe using the specified JMX host and port.NodeProbe(java.lang.String host, int port, java.lang.String username, java.lang.String password)
Creates a NodeProbe using the specified JMX host, port, username, and password.
-
Method Summary
All Methods Instance Methods Concrete Methods Deprecated Methods Modifier and Type Method Description void
assassinateEndpoint(java.lang.String address)
void
clearConnectionHistory()
void
clearSnapshot(java.lang.String tag, java.lang.String... keyspaces)
Deprecated.See CASSANDRA-16860void
clearSnapshot(java.util.Map<java.lang.String,java.lang.Object> options, java.lang.String tag, java.lang.String... keyspaces)
Remove all the existing snapshots of given tag for provided keyspaces.void
close()
protected void
connect()
Create a connection to the JMX agent and setup the M[X]Bean proxies.void
decommission(boolean force)
java.util.List<java.lang.String>
describeRing(java.lang.String keyspaceName, boolean withPort)
void
disableAuditLog()
void
disableAutoCompaction(java.lang.String ks, java.lang.String... tables)
void
disableHintedHandoff()
void
disableHintsForDC(java.lang.String dc)
void
disableOldProtocolVersions()
void
drain()
void
dropCidrGroup(java.lang.String cidrGroupName)
java.util.Map<java.net.InetAddress,java.lang.Float>
effectiveOwnership(java.lang.String keyspace)
java.util.Map<java.lang.String,java.lang.Float>
effectiveOwnershipWithPort(java.lang.String keyspace)
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
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.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, java.lang.Integer maxArchiveRetries, java.lang.Boolean block, java.lang.String rollCycle, java.lang.Long maxLogSize, java.lang.Integer maxQueueWeight, java.lang.String archiveCommand)
void
enableAutoCompaction(java.lang.String ks, java.lang.String... tableNames)
void
enableFullQueryLogger(java.lang.String path, java.lang.String rollCycle, java.lang.Boolean blocking, int maxQueueWeight, long maxLogSize, java.lang.String archiveCommand, int maxArchiveRetries)
void
enableHintedHandoff()
void
enableHintsForDC(java.lang.String dc)
void
enableOldProtocolVersions()
void
failed()
void
forceCompactionKeysIgnoringGcGrace(java.lang.String keyspaceName, java.lang.String tableName, java.lang.String... partitionKeysIgnoreGcGrace)
int
forceKeyspaceCleanup(int jobs, java.lang.String keyspaceName, java.lang.String... tables)
void
forceKeyspaceCleanup(java.io.PrintStream out, int jobs, java.lang.String keyspaceName, java.lang.String... tableNames)
void
forceKeyspaceCompaction(boolean splitOutput, java.lang.String keyspaceName, java.lang.String... tableNames)
void
forceKeyspaceCompactionForPartitionKey(java.lang.String keyspaceName, java.lang.String partitionKey, java.lang.String... tableNames)
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)
void
forceRemoveCompletion()
void
forceUserDefinedCompaction(java.lang.String datafiles)
void
garbageCollect(java.io.PrintStream out, java.lang.String tombstoneOption, int jobs, java.lang.String keyspaceName, java.lang.String... tableNames)
int
garbageCollect(java.lang.String tombstoneOption, int jobs, java.lang.String keyspaceName, java.lang.String... tableNames)
double[]
getAndResetGCStats()
AuditLogOptions
getAuditLogOptions()
AuthCacheMBean
getAuthCacheMBean(java.lang.String cacheName)
java.util.Map<java.lang.String,java.lang.Boolean>
getAutoCompactionDisabled(java.lang.String ks, java.lang.String... tableNames)
int
getBatchlogReplayThrottle()
java.lang.Object
getBufferPoolMetric(java.lang.String poolType, java.lang.String metricName)
Retrieve buffer pool metrics based on the buffer pool typejava.lang.Object
getCacheMetric(java.lang.String cacheType, java.lang.String metricName)
Retrieve cache metrics based on the cache type (KeyCache, RowCache, or CounterCache)CacheServiceMBean
getCacheServiceMBean()
ColumnFamilyStoreMBean
getCfsProxy(java.lang.String ks, java.lang.String cf)
java.lang.Object
getCidrFilteringMetric(java.lang.String metricName)
java.util.Set<java.lang.String>
getCidrGroupsOfIp(java.lang.String ipStr)
java.lang.Object
getClientMetric(java.lang.String metricName)
Retrieve Proxy metricsjava.lang.String
getClusterName()
java.lang.Object
getColumnFamilyMetric(java.lang.String ks, java.lang.String cf, java.lang.String metricName)
Retrieve ColumnFamily metricsjava.util.Iterator<java.util.Map.Entry<java.lang.String,ColumnFamilyStoreMBean>>
getColumnFamilyStoreMBeanProxies()
int
getColumnIndexSizeInKB()
javax.management.openmbean.TabularData
getCompactionHistory()
CompactionManagerMBean
getCompactionManagerProxy()
java.lang.Object
getCompactionMetric(java.lang.String metricName)
Retrieve Proxy metricsint
getCompactionThroughput()
Deprecated.See CASSANDRA-17225long
getCompactionThroughputBytes()
double
getCompactionThroughputMebibytesAsDouble()
int
getConcurrentCompactors()
int
getConcurrentViewBuilders()
java.util.Map<java.lang.String,java.lang.Long>
getCountsMetricsFromVtable()
int
getCurrentGenerationNumber()
java.lang.String
getDataCenter()
int
getDefaultKeyspaceReplicationFactor()
double
getDroppableTombstoneRatio(java.lang.String keyspace, java.lang.String table)
java.util.Map<java.lang.String,java.lang.Integer>
getDroppedMessages()
DynamicEndpointSnitchMBean
getDynamicEndpointSnitchInfoProxy()
java.lang.String
getEndpoint()
java.util.List<java.net.InetAddress>
getEndpoints(java.lang.String keyspace, java.lang.String cf, java.lang.String key)
EndpointSnitchInfoMBean
getEndpointSnitchInfoProxy()
java.util.List<java.lang.String>
getEndpointsWithPort(java.lang.String keyspace, java.lang.String cf, java.lang.String key)
double
getEntireSSTableInterDCStreamThroughput()
double
getEntireSSTableStreamThroughput()
int
getExceptionCount()
javax.management.openmbean.TabularData
getFailureDetectorPhilValues(boolean withPort)
FullQueryLoggerOptions
getFullQueryLoggerOptions()
java.lang.String
getGitSHA()
java.lang.String
getGossipInfo(boolean withPort)
java.lang.String
getGossipInfo(boolean withPort, boolean resolveIp)
GossiperMBean
getGossProxy()
java.lang.management.MemoryUsage
getHeapMemoryUsage()
java.util.Set<java.lang.String>
getHintedHandoffDisabledDCs()
java.util.Map<java.lang.String,java.lang.String>
getHostIdMap(boolean withPort)
java.util.Map<java.lang.String,java.lang.String>
getHostIdToEndpointWithPort()
int
getInterDCStreamThroughput()
Deprecated.See CASSANDRA-17225double
getInterDCStreamThroughputAsDouble()
double
getInterDCStreamThroughputMibAsDouble()
java.util.List<java.lang.String>
getJoiningNodes(boolean withPort)
java.lang.String
getKeyspaceReplicationInfo(java.lang.String keyspaceName)
java.util.List<java.lang.String>
getKeyspaces()
java.util.Map<java.lang.String,java.util.List<java.lang.Double>>
getLatenciesMetricsFromVtable()
java.util.List<java.lang.String>
getLeavingNodes(boolean withPort)
java.util.List<java.lang.String>
getLiveNodes(boolean withPort)
java.util.Map<java.lang.String,java.lang.String>
getLoadMap(boolean withPort)
java.lang.String
getLoadString()
java.lang.String
getLocalHostId()
java.util.Map<java.lang.String,java.lang.String>
getLoggingLevels()
int
getMaxHintWindow()
java.util.Map<java.lang.String,java.util.List<java.lang.Integer>>
getMaximumPoolSizes(java.util.List<java.lang.String> stageNames)
javax.management.MBeanServerConnection
getMbeanServerConn()
CassandraMetricsRegistry.JmxTimerMBean
getMessagingQueueWaitMetrics(java.lang.String verb)
MessagingServiceMBean
getMessagingServiceProxy()
java.util.List<java.lang.String>
getMovingNodes(boolean withPort)
java.util.List<java.lang.String>
getNonLocalStrategyKeyspaces()
java.util.List<java.lang.String>
getNonSystemKeyspaces()
int
getNumberOfTables()
java.lang.String
getOperationMode()
java.util.Map<java.net.InetAddress,java.lang.Float>
getOwnership()
java.util.Map<java.lang.String,java.lang.Float>
getOwnershipWithPort()
java.lang.String
getPartitioner()
java.util.Map<java.lang.String,java.util.List<javax.management.openmbean.CompositeData>>
getPartitionSample(java.lang.String ks, int capacity, int durationMillis, int count, java.util.List<java.lang.String> samplers)
java.util.Map<java.lang.String,java.util.List<javax.management.openmbean.CompositeData>>
getPartitionSample(java.lang.String ks, java.lang.String cf, int capacity, int durationMillis, int count, java.util.List<java.lang.String> samplers)
long
getPid()
CassandraMetricsRegistry.JmxTimerMBean
getProxyMetric(java.lang.String scope)
Retrieve Proxy metricsjava.lang.String
getRack()
long
getReadRepairAttempted()
long
getReadRepairRepairedBackground()
long
getReadRepairRepairedBlocking()
java.lang.String
getReleaseVersion()
java.lang.String
getRemovalStatus(boolean withPort)
ActiveRepairServiceMBean
getRepairServiceProxy()
java.util.List<java.lang.String>
getSampleTasks()
java.lang.String
getSchemaVersion()
java.util.List<java.lang.String>
getSeeds()
java.util.Map<java.lang.String,java.lang.String>
getSimpleStatesWithPort()
java.util.Map<java.lang.String,javax.management.openmbean.TabularData>
getSnapshotDetails()
Deprecated.See CASSANDRA-16789java.util.Map<java.lang.String,javax.management.openmbean.TabularData>
getSnapshotDetails(java.util.Map<java.lang.String,java.lang.String> options)
long
getSnapshotLinksPerSecond()
StorageProxyMBean
getSpProxy()
java.util.List<java.lang.String>
getSSTables(java.lang.String keyspace, java.lang.String cf, java.lang.String key, boolean hexFormat)
java.util.Map<java.lang.Integer,java.util.Set<java.lang.String>>
getSSTablesWithLevel(java.lang.String keyspace, java.lang.String cf, java.lang.String key, boolean hexFormat)
long
getStorageMetric(java.lang.String metricName)
Retrieve Proxy metricsStorageServiceMBean
getStorageService()
java.util.Set<StreamState>
getStreamStatus()
int
getStreamThroughput()
Deprecated.See CASSANDRA-17225double
getStreamThroughputAsDouble()
double
getStreamThroughputMibAsDouble()
java.lang.Object
getThreadPoolMetric(java.lang.String pathName, java.lang.String poolName, java.lang.String metricName)
com.google.common.collect.Multimap<java.lang.String,java.lang.String>
getThreadPools()
Retrieve threadpool paths and names for threadpools with metrics.long
getTimeout(java.lang.String type)
java.util.List<java.lang.String>
getTokens()
java.util.List<java.lang.String>
getTokens(java.lang.String endpoint)
java.util.Map<java.lang.String,java.lang.String>
getTokenToEndpointMap(boolean withPort)
double
getTraceProbability()
java.lang.String
getUncompressedLoadString()
java.util.List<java.lang.String>
getUnreachableNodes(boolean withPort)
long
getUptime()
java.util.Map<java.lang.String,java.lang.String>
getViewBuildStatuses(java.lang.String keyspace, java.lang.String view)
boolean
handleScheduledSampling(java.lang.String ks, java.lang.String table, int capacity, int count, int durationMillis, int intervalMillis, java.util.List<java.lang.String> samplers, boolean shouldStop)
java.util.List<java.lang.String>
importNewSSTables(java.lang.String ksName, java.lang.String cfName, java.util.Set<java.lang.String> srcPaths, boolean resetLevel, boolean clearRepaired, boolean verifySSTables, boolean verifyTokens, boolean invalidateCaches, boolean extendedVerify, boolean copyData, boolean failOnMissingIndex, boolean validateIndexChecksum)
boolean
invalidateCidrPermissionsCache(java.lang.String roleName)
void
invalidateCounterCache()
void
invalidateCredentialsCache()
void
invalidateCredentialsCache(java.lang.String roleName)
void
invalidateJmxPermissionsCache()
void
invalidateJmxPermissionsCache(java.lang.String roleName)
void
invalidateKeyCache()
void
invalidateNetworkPermissionsCache()
void
invalidateNetworkPermissionsCache(java.lang.String roleName)
void
invalidatePermissionsCache()
void
invalidatePermissionsCache(java.lang.String roleName, java.lang.String resourceName)
void
invalidateRolesCache()
void
invalidateRolesCache(java.lang.String roleName)
void
invalidateRowCache()
boolean
isBootstrapMode()
boolean
isDrained()
boolean
isDraining()
boolean
isFailed()
boolean
isGossipRunning()
boolean
isHandoffEnabled()
boolean
isIncrementalBackupsEnabled()
boolean
isInitialized()
boolean
isJoined()
boolean
isLeveledCompaction(java.lang.String keyspace, java.lang.String cf)
boolean
isNativeTransportRunning()
boolean
isStarting()
void
joinRing()
java.util.Set<java.lang.String>
listAvailableCidrGroups()
java.util.Set<java.lang.String>
listCidrsOfCidrGroup(java.lang.String cidrGroup)
java.util.List<java.util.Map<java.lang.String,java.lang.String>>
listPendingHints()
void
loadNewSSTables(java.lang.String ksName, java.lang.String cfName)
Deprecated.See CASSANDRA-6719java.lang.Double[]
metricPercentilesAsArray(CassandraMetricsRegistry.JmxHistogramMBean metric)
java.lang.Double[]
metricPercentilesAsArray(CassandraMetricsRegistry.JmxTimerMBean metric)
void
move(java.lang.String newToken)
Output
output()
void
pauseHintsDelivery()
void
printSet(java.io.PrintStream out, java.lang.String colName, java.util.Set<java.lang.String> values)
void
rebuild(java.lang.String sourceDc, java.lang.String keyspace, java.lang.String tokens, java.lang.String specificSources, boolean excludeLocalDatacenterNodes)
void
rebuildIndex(java.lang.String ksName, java.lang.String cfName, java.lang.String... idxNames)
void
recompressSSTables(java.io.PrintStream out, java.lang.String keyspaceName, int jobs, java.lang.String... tableNames)
int
recompressSSTables(java.lang.String keyspaceName, int jobs, java.lang.String... tableNames)
void
refreshSizeEstimates()
void
reloadCidrGroupsCache()
void
reloadLocalSchema()
java.util.List<java.lang.String>
reloadSeeds()
void
reloadSslCerts()
void
reloadTriggers()
void
relocateSSTables(int jobs, java.lang.String keyspace, java.lang.String[] cfnames)
void
removeNode(java.lang.String token)
void
repairAsync(java.io.PrintStream out, java.lang.String keyspace, java.util.Map<java.lang.String,java.lang.String> options)
void
replayBatchlog()
void
resetFullQueryLogger()
void
resetLocalSchema()
void
resumeBootstrap(java.io.PrintStream out)
void
resumeHintsDelivery()
java.util.List<java.lang.String>
sampleKeyRange()
int
scrub(boolean disableSnapshot, boolean skipCorrupted, boolean checkData, boolean reinsertOverflowedTTL, int jobs, java.lang.String keyspaceName, java.lang.String... tables)
void
scrub(java.io.PrintStream out, boolean disableSnapshot, boolean skipCorrupted, boolean checkData, boolean reinsertOverflowedTTL, int jobs, java.lang.String keyspaceName, java.lang.String... tables)
void
setBatchlogReplayThrottle(int value)
void
setCacheCapacities(int keyCacheCapacity, int rowCacheCapacity, int counterCacheCapacity)
void
setCacheKeysToSave(int keyCacheKeysToSave, int rowCacheKeysToSave, int counterCacheKeysToSave)
void
setColumnIndexSize(int columnIndexSizeInKiB)
void
setCompactionThreshold(java.lang.String ks, java.lang.String cf, int minimumCompactionThreshold, int maximumCompactionThreshold)
Set the compaction thresholdvoid
setCompactionThroughput(int value)
void
setConcurrency(java.lang.String stageName, int coreThreads, int maxConcurrency)
void
setConcurrentCompactors(int value)
void
setConcurrentViewBuilders(int value)
void
setDefaultKeyspaceReplicationFactor(int value)
void
setEntireSSTableInterDCStreamThroughput(int value)
void
setEntireSSTableStreamThroughput(int value)
void
setHintedHandoffThrottleInKB(int throttleInKB)
void
setIncrementalBackupsEnabled(boolean enabled)
void
setInterDCStreamThroughput(int value)
void
setInterDCStreamThroughputMiB(int value)
void
setLoggingLevel(java.lang.String classQualifier, java.lang.String level)
void
setMaxHintWindow(int value)
void
setOutput(Output output)
void
setSnapshotLinksPerSecond(long throttle)
void
setStreamThroughput(int value)
void
setStreamThroughputMiB(int value)
void
setTimeout(java.lang.String type, long value)
void
setTraceProbability(double value)
void
startGossiping()
void
startNativeTransport()
void
stop(java.lang.String string)
void
stopById(java.lang.String compactionId)
void
stopCassandraDaemon()
void
stopFullQueryLogger()
void
stopGossiping()
void
stopNativeTransport(boolean force)
void
takeMultipleTableSnapshot(java.lang.String snapshotName, java.util.Map<java.lang.String,java.lang.String> options, java.lang.String... tableList)
Take a snapshot of all column family from different keyspaces.void
takeSnapshot(java.lang.String snapshotName, java.lang.String table, java.util.Map<java.lang.String,java.lang.String> options, java.lang.String... keyspaces)
Take a snapshot of all the keyspaces, optionally specifying only a specific column family.long
trueSnapshotsSize()
void
truncate(java.lang.String keyspaceName, java.lang.String tableName)
void
truncateHints()
void
truncateHints(java.lang.String host)
void
updateCidrGroup(java.lang.String cidrGroupName, java.util.List<java.lang.String> cidrs)
void
upgradeSSTables(java.io.PrintStream out, java.lang.String keyspaceName, boolean excludeCurrentVersion, long maxSSTableTimestamp, int jobs, java.lang.String... tableNames)
int
upgradeSSTables(java.lang.String keyspaceName, boolean excludeCurrentVersion, long maxSSTableTimestamp, int jobs, java.lang.String... tableNames)
int
verify(boolean extendedVerify, boolean checkVersion, boolean diskFailurePolicy, boolean mutateRepairStatus, boolean checkOwnsTokens, boolean quick, java.lang.String keyspaceName, java.lang.String... tableNames)
void
verify(java.io.PrintStream out, boolean extendedVerify, boolean checkVersion, boolean diskFailurePolicy, boolean mutateRepairStatus, boolean checkOwnsTokens, boolean quick, java.lang.String keyspaceName, java.lang.String... tableNames)
-
-
-
Field Detail
-
jmxc
protected javax.management.remote.JMXConnector jmxc
-
mbeanServerConn
protected javax.management.MBeanServerConnection mbeanServerConn
-
compactionProxy
protected CompactionManagerMBean compactionProxy
-
ssProxy
protected StorageServiceMBean ssProxy
-
gossProxy
protected GossiperMBean gossProxy
-
memProxy
protected java.lang.management.MemoryMXBean memProxy
-
gcProxy
protected GCInspectorMXBean gcProxy
-
runtimeProxy
protected java.lang.management.RuntimeMXBean runtimeProxy
-
streamProxy
protected StreamManagerMBean streamProxy
-
msProxy
protected MessagingServiceMBean msProxy
-
fdProxy
protected FailureDetectorMBean fdProxy
-
cacheService
protected CacheServiceMBean cacheService
-
spProxy
protected StorageProxyMBean spProxy
-
hsProxy
protected HintsServiceMBean hsProxy
-
bmProxy
protected BatchlogManagerMBean bmProxy
-
arsProxy
protected ActiveRepairServiceMBean arsProxy
-
almProxy
protected AuditLogManagerMBean almProxy
-
ccProxy
protected PasswordAuthenticator.CredentialsCacheMBean ccProxy
-
jpcProxy
protected AuthorizationProxy.JmxPermissionsCacheMBean jpcProxy
-
npcProxy
protected NetworkPermissionsCacheMBean npcProxy
-
cpbProxy
protected CIDRPermissionsManagerMBean cpbProxy
-
cmbProxy
protected CIDRGroupsMappingManagerMBean cmbProxy
-
pcProxy
protected PermissionsCacheMBean pcProxy
-
rcProxy
protected RolesCacheMBean rcProxy
-
output
protected Output output
-
cfmProxy
protected CIDRFilteringMetricsTableMBean cfmProxy
-
-
Constructor Detail
-
NodeProbe
public NodeProbe(java.lang.String host, int port, java.lang.String username, java.lang.String password) throws java.io.IOException
Creates a NodeProbe using the specified JMX host, port, username, and password.- Parameters:
host
- hostname or IP address of the JMX agentport
- TCP port of the remote JMX agent- Throws:
java.io.IOException
- on connection failures
-
NodeProbe
public NodeProbe(java.lang.String host, int port) throws java.io.IOException
Creates a NodeProbe using the specified JMX host and port.- Parameters:
host
- hostname or IP address of the JMX agentport
- TCP port of the remote JMX agent- Throws:
java.io.IOException
- on connection failures
-
NodeProbe
public NodeProbe(java.lang.String host) throws java.io.IOException
Creates a NodeProbe using the specified JMX host and default port.- Parameters:
host
- hostname or IP address of the JMX agent- Throws:
java.io.IOException
- on connection failures
-
NodeProbe
protected NodeProbe()
-
-
Method Detail
-
connect
protected void connect() throws java.io.IOException
Create a connection to the JMX agent and setup the M[X]Bean proxies.- Throws:
java.io.IOException
- on connection failures
-
close
public void close() throws java.io.IOException
- Specified by:
close
in interfacejava.lang.AutoCloseable
- Throws:
java.io.IOException
-
setOutput
public void setOutput(Output output)
-
output
public Output output()
-
forceKeyspaceCleanup
public int forceKeyspaceCleanup(int jobs, java.lang.String keyspaceName, java.lang.String... tables) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
- Throws:
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
-
scrub
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
- Throws:
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
-
verify
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
- Throws:
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
-
upgradeSSTables
public int upgradeSSTables(java.lang.String keyspaceName, boolean excludeCurrentVersion, long maxSSTableTimestamp, int jobs, java.lang.String... tableNames) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
- Throws:
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
-
garbageCollect
public int garbageCollect(java.lang.String tombstoneOption, int jobs, java.lang.String keyspaceName, java.lang.String... tableNames) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
- Throws:
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
-
recompressSSTables
public int recompressSSTables(java.lang.String keyspaceName, int jobs, java.lang.String... tableNames) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
- Throws:
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
-
forceKeyspaceCleanup
public void forceKeyspaceCleanup(java.io.PrintStream out, int jobs, java.lang.String keyspaceName, java.lang.String... tableNames) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
- Throws:
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
-
scrub
public void scrub(java.io.PrintStream out, 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
- Throws:
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
-
verify
public void verify(java.io.PrintStream out, 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
- Throws:
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
-
recompressSSTables
public void recompressSSTables(java.io.PrintStream out, java.lang.String keyspaceName, int jobs, java.lang.String... tableNames) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
- Throws:
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
-
upgradeSSTables
public void upgradeSSTables(java.io.PrintStream out, java.lang.String keyspaceName, boolean excludeCurrentVersion, long maxSSTableTimestamp, int jobs, java.lang.String... tableNames) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
- Throws:
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
-
garbageCollect
public void garbageCollect(java.io.PrintStream out, java.lang.String tombstoneOption, int jobs, java.lang.String keyspaceName, java.lang.String... tableNames) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
- Throws:
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
-
forceUserDefinedCompaction
public void forceUserDefinedCompaction(java.lang.String datafiles) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
- Throws:
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
-
forceKeyspaceCompaction
public void forceKeyspaceCompaction(boolean splitOutput, java.lang.String keyspaceName, java.lang.String... tableNames) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
- Throws:
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
-
relocateSSTables
public void relocateSSTables(int jobs, java.lang.String keyspace, java.lang.String[] cfnames) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
- Throws:
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
-
forceKeyspaceCompactionForTokenRange
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
Forces major compaction of specified token range in a single keyspace.- Parameters:
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 compacted- Throws:
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
-
forceKeyspaceCompactionForPartitionKey
public void forceKeyspaceCompactionForPartitionKey(java.lang.String keyspaceName, java.lang.String partitionKey, java.lang.String... tableNames) throws java.lang.InterruptedException, java.util.concurrent.ExecutionException, java.io.IOException
- Throws:
java.lang.InterruptedException
java.util.concurrent.ExecutionException
java.io.IOException
-
forceCompactionKeysIgnoringGcGrace
public void forceCompactionKeysIgnoringGcGrace(java.lang.String keyspaceName, java.lang.String tableName, java.lang.String... partitionKeysIgnoreGcGrace) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
- Throws:
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
-
forceKeyspaceFlush
public void forceKeyspaceFlush(java.lang.String keyspaceName, java.lang.String... tableNames) throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
- Throws:
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
-
getKeyspaceReplicationInfo
public java.lang.String getKeyspaceReplicationInfo(java.lang.String keyspaceName)
-
repairAsync
public void repairAsync(java.io.PrintStream out, java.lang.String keyspace, java.util.Map<java.lang.String,java.lang.String> options) throws java.io.IOException
- Throws:
java.io.IOException
-
handleScheduledSampling
public boolean handleScheduledSampling(java.lang.String ks, java.lang.String table, int capacity, int count, int durationMillis, int intervalMillis, java.util.List<java.lang.String> samplers, boolean shouldStop) throws javax.management.openmbean.OpenDataException
- Throws:
javax.management.openmbean.OpenDataException
-
getSampleTasks
public java.util.List<java.lang.String> getSampleTasks()
-
getPartitionSample
public java.util.Map<java.lang.String,java.util.List<javax.management.openmbean.CompositeData>> getPartitionSample(java.lang.String ks, int capacity, int durationMillis, int count, java.util.List<java.lang.String> samplers) throws javax.management.openmbean.OpenDataException
- Throws:
javax.management.openmbean.OpenDataException
-
getPartitionSample
public java.util.Map<java.lang.String,java.util.List<javax.management.openmbean.CompositeData>> getPartitionSample(java.lang.String ks, java.lang.String cf, int capacity, int durationMillis, int count, java.util.List<java.lang.String> samplers) throws javax.management.openmbean.OpenDataException
- Throws:
javax.management.openmbean.OpenDataException
-
getDroppableTombstoneRatio
public double getDroppableTombstoneRatio(java.lang.String keyspace, java.lang.String table)
-
invalidateCounterCache
public void invalidateCounterCache()
-
invalidateCredentialsCache
public void invalidateCredentialsCache()
-
invalidateCredentialsCache
public void invalidateCredentialsCache(java.lang.String roleName)
-
invalidateJmxPermissionsCache
public void invalidateJmxPermissionsCache()
-
invalidateJmxPermissionsCache
public void invalidateJmxPermissionsCache(java.lang.String roleName)
-
invalidateKeyCache
public void invalidateKeyCache()
-
invalidateNetworkPermissionsCache
public void invalidateNetworkPermissionsCache()
-
invalidateNetworkPermissionsCache
public void invalidateNetworkPermissionsCache(java.lang.String roleName)
-
invalidateCidrPermissionsCache
public boolean invalidateCidrPermissionsCache(java.lang.String roleName)
-
reloadCidrGroupsCache
public void reloadCidrGroupsCache()
-
listAvailableCidrGroups
public java.util.Set<java.lang.String> listAvailableCidrGroups()
-
listCidrsOfCidrGroup
public java.util.Set<java.lang.String> listCidrsOfCidrGroup(java.lang.String cidrGroup)
-
updateCidrGroup
public void updateCidrGroup(java.lang.String cidrGroupName, java.util.List<java.lang.String> cidrs)
-
dropCidrGroup
public void dropCidrGroup(java.lang.String cidrGroupName)
-
getCidrGroupsOfIp
public java.util.Set<java.lang.String> getCidrGroupsOfIp(java.lang.String ipStr)
-
invalidatePermissionsCache
public void invalidatePermissionsCache()
-
invalidatePermissionsCache
public void invalidatePermissionsCache(java.lang.String roleName, java.lang.String resourceName)
-
invalidateRolesCache
public void invalidateRolesCache()
-
invalidateRolesCache
public void invalidateRolesCache(java.lang.String roleName)
-
invalidateRowCache
public void invalidateRowCache()
-
getAuthCacheMBean
public AuthCacheMBean getAuthCacheMBean(java.lang.String cacheName)
-
drain
public void drain() throws java.io.IOException, java.lang.InterruptedException, java.util.concurrent.ExecutionException
- Throws:
java.io.IOException
java.lang.InterruptedException
java.util.concurrent.ExecutionException
-
getTokenToEndpointMap
public java.util.Map<java.lang.String,java.lang.String> getTokenToEndpointMap(boolean withPort)
-
getLiveNodes
public java.util.List<java.lang.String> getLiveNodes(boolean withPort)
-
getJoiningNodes
public java.util.List<java.lang.String> getJoiningNodes(boolean withPort)
-
getLeavingNodes
public java.util.List<java.lang.String> getLeavingNodes(boolean withPort)
-
getMovingNodes
public java.util.List<java.lang.String> getMovingNodes(boolean withPort)
-
getUnreachableNodes
public java.util.List<java.lang.String> getUnreachableNodes(boolean withPort)
-
getLoadMap
public java.util.Map<java.lang.String,java.lang.String> getLoadMap(boolean withPort)
-
getOwnership
public java.util.Map<java.net.InetAddress,java.lang.Float> getOwnership()
-
getOwnershipWithPort
public java.util.Map<java.lang.String,java.lang.Float> getOwnershipWithPort()
-
effectiveOwnership
public java.util.Map<java.net.InetAddress,java.lang.Float> effectiveOwnership(java.lang.String keyspace) throws java.lang.IllegalStateException
- Throws:
java.lang.IllegalStateException
-
effectiveOwnershipWithPort
public java.util.Map<java.lang.String,java.lang.Float> effectiveOwnershipWithPort(java.lang.String keyspace) throws java.lang.IllegalStateException
- Throws:
java.lang.IllegalStateException
-
getMbeanServerConn
public javax.management.MBeanServerConnection getMbeanServerConn()
-
getCacheServiceMBean
public CacheServiceMBean getCacheServiceMBean()
-
getAndResetGCStats
public double[] getAndResetGCStats()
-
getColumnFamilyStoreMBeanProxies
public java.util.Iterator<java.util.Map.Entry<java.lang.String,ColumnFamilyStoreMBean>> getColumnFamilyStoreMBeanProxies()
-
getCompactionManagerProxy
public CompactionManagerMBean getCompactionManagerProxy()
-
getTokens
public java.util.List<java.lang.String> getTokens()
-
getTokens
public java.util.List<java.lang.String> getTokens(java.lang.String endpoint)
-
getHostIdToEndpointWithPort
public java.util.Map<java.lang.String,java.lang.String> getHostIdToEndpointWithPort()
-
getLocalHostId
public java.lang.String getLocalHostId()
-
getHostIdMap
public java.util.Map<java.lang.String,java.lang.String> getHostIdMap(boolean withPort)
-
getLoadString
public java.lang.String getLoadString()
-
getUncompressedLoadString
public java.lang.String getUncompressedLoadString()
-
getReleaseVersion
public java.lang.String getReleaseVersion()
-
getGitSHA
public java.lang.String getGitSHA()
-
getCurrentGenerationNumber
public int getCurrentGenerationNumber()
-
getUptime
public long getUptime()
-
getHeapMemoryUsage
public java.lang.management.MemoryUsage getHeapMemoryUsage()
-
getSnapshotLinksPerSecond
public long getSnapshotLinksPerSecond()
-
setSnapshotLinksPerSecond
public void setSnapshotLinksPerSecond(long throttle)
-
takeSnapshot
public void takeSnapshot(java.lang.String snapshotName, java.lang.String table, java.util.Map<java.lang.String,java.lang.String> options, java.lang.String... keyspaces) throws java.io.IOException
Take a snapshot of all the keyspaces, optionally specifying only a specific column family.- Parameters:
snapshotName
- the name of the snapshot.table
- the table to snapshot or all on nulloptions
- Options (skipFlush for now)keyspaces
- the keyspaces to snapshot- Throws:
java.io.IOException
-
takeMultipleTableSnapshot
public void takeMultipleTableSnapshot(java.lang.String snapshotName, java.util.Map<java.lang.String,java.lang.String> options, java.lang.String... tableList) throws java.io.IOException
Take a snapshot of all column family from different keyspaces.- Parameters:
snapshotName
- the name of the snapshot.options
- Options (skipFlush for now)tableList
- list of columnfamily from different keyspace in the form of ks1.cf1 ks2.cf2- Throws:
java.io.IOException
-
clearSnapshot
@Deprecated(since="5.0") public void clearSnapshot(java.lang.String tag, java.lang.String... keyspaces) throws java.io.IOException
Deprecated.See CASSANDRA-16860- Throws:
java.io.IOException
-
clearSnapshot
public void clearSnapshot(java.util.Map<java.lang.String,java.lang.Object> options, java.lang.String tag, java.lang.String... keyspaces) throws java.io.IOException
Remove all the existing snapshots of given tag for provided keyspaces. When no keyspaces are specified, take all keyspaces into account. When tag is not specified (null or empty string), take all tags into account.- Parameters:
options
- options to supply for snapshot clearingtag
- tag of snapshot to clearkeyspaces
- keyspaces to clear snapshots for- Throws:
java.io.IOException
-
getSnapshotDetails
public java.util.Map<java.lang.String,javax.management.openmbean.TabularData> getSnapshotDetails(java.util.Map<java.lang.String,java.lang.String> options)
-
getSnapshotDetails
@Deprecated(since="4.1") public java.util.Map<java.lang.String,javax.management.openmbean.TabularData> getSnapshotDetails()
Deprecated.See CASSANDRA-16789
-
trueSnapshotsSize
public long trueSnapshotsSize()
-
isJoined
public boolean isJoined()
-
isDrained
public boolean isDrained()
-
isDraining
public boolean isDraining()
-
isBootstrapMode
public boolean isBootstrapMode()
-
joinRing
public void joinRing() throws java.io.IOException
- Throws:
java.io.IOException
-
decommission
public void decommission(boolean force) throws java.lang.InterruptedException
- Throws:
java.lang.InterruptedException
-
move
public void move(java.lang.String newToken) throws java.io.IOException
- Throws:
java.io.IOException
-
removeNode
public void removeNode(java.lang.String token)
-
getRemovalStatus
public java.lang.String getRemovalStatus(boolean withPort)
-
forceRemoveCompletion
public void forceRemoveCompletion()
-
assassinateEndpoint
public void assassinateEndpoint(java.lang.String address) throws java.net.UnknownHostException
- Throws:
java.net.UnknownHostException
-
reloadSeeds
public java.util.List<java.lang.String> reloadSeeds()
-
getSeeds
public java.util.List<java.lang.String> getSeeds()
-
setCompactionThreshold
public void setCompactionThreshold(java.lang.String ks, java.lang.String cf, int minimumCompactionThreshold, int maximumCompactionThreshold)
Set the compaction threshold- Parameters:
minimumCompactionThreshold
- minimum compaction thresholdmaximumCompactionThreshold
- maximum compaction threshold
-
disableAutoCompaction
public void disableAutoCompaction(java.lang.String ks, java.lang.String... tables) throws java.io.IOException
- Throws:
java.io.IOException
-
enableAutoCompaction
public void enableAutoCompaction(java.lang.String ks, java.lang.String... tableNames) throws java.io.IOException
- Throws:
java.io.IOException
-
getAutoCompactionDisabled
public java.util.Map<java.lang.String,java.lang.Boolean> getAutoCompactionDisabled(java.lang.String ks, java.lang.String... tableNames) throws java.io.IOException
- Throws:
java.io.IOException
-
setIncrementalBackupsEnabled
public void setIncrementalBackupsEnabled(boolean enabled)
-
isIncrementalBackupsEnabled
public boolean isIncrementalBackupsEnabled()
-
setCacheCapacities
public void setCacheCapacities(int keyCacheCapacity, int rowCacheCapacity, int counterCacheCapacity)
-
setCacheKeysToSave
public void setCacheKeysToSave(int keyCacheKeysToSave, int rowCacheKeysToSave, int counterCacheKeysToSave)
-
setHintedHandoffThrottleInKB
public void setHintedHandoffThrottleInKB(int throttleInKB)
-
getEndpointsWithPort
public java.util.List<java.lang.String> getEndpointsWithPort(java.lang.String keyspace, java.lang.String cf, java.lang.String key)
-
getEndpoints
public java.util.List<java.net.InetAddress> getEndpoints(java.lang.String keyspace, java.lang.String cf, java.lang.String key)
-
getSSTables
public java.util.List<java.lang.String> getSSTables(java.lang.String keyspace, java.lang.String cf, java.lang.String key, boolean hexFormat)
-
getSSTablesWithLevel
public java.util.Map<java.lang.Integer,java.util.Set<java.lang.String>> getSSTablesWithLevel(java.lang.String keyspace, java.lang.String cf, java.lang.String key, boolean hexFormat)
-
isLeveledCompaction
public boolean isLeveledCompaction(java.lang.String keyspace, java.lang.String cf)
-
getStreamStatus
public java.util.Set<StreamState> getStreamStatus()
-
getOperationMode
public java.lang.String getOperationMode()
-
isStarting
public boolean isStarting()
-
truncate
public void truncate(java.lang.String keyspaceName, java.lang.String tableName)
-
getEndpointSnitchInfoProxy
public EndpointSnitchInfoMBean getEndpointSnitchInfoProxy()
-
getDynamicEndpointSnitchInfoProxy
public DynamicEndpointSnitchMBean getDynamicEndpointSnitchInfoProxy()
-
getCfsProxy
public ColumnFamilyStoreMBean getCfsProxy(java.lang.String ks, java.lang.String cf)
-
getSpProxy
public StorageProxyMBean getSpProxy()
-
getStorageService
public StorageServiceMBean getStorageService()
-
getGossProxy
public GossiperMBean getGossProxy()
-
getEndpoint
public java.lang.String getEndpoint()
-
getDataCenter
public java.lang.String getDataCenter()
-
getRack
public java.lang.String getRack()
-
getKeyspaces
public java.util.List<java.lang.String> getKeyspaces()
-
getNonSystemKeyspaces
public java.util.List<java.lang.String> getNonSystemKeyspaces()
-
getNonLocalStrategyKeyspaces
public java.util.List<java.lang.String> getNonLocalStrategyKeyspaces()
-
getClusterName
public java.lang.String getClusterName()
-
getPartitioner
public java.lang.String getPartitioner()
-
disableHintedHandoff
public void disableHintedHandoff()
-
enableHintedHandoff
public void enableHintedHandoff()
-
isHandoffEnabled
public boolean isHandoffEnabled()
-
enableHintsForDC
public void enableHintsForDC(java.lang.String dc)
-
disableHintsForDC
public void disableHintsForDC(java.lang.String dc)
-
getHintedHandoffDisabledDCs
public java.util.Set<java.lang.String> getHintedHandoffDisabledDCs()
-
getViewBuildStatuses
public java.util.Map<java.lang.String,java.lang.String> getViewBuildStatuses(java.lang.String keyspace, java.lang.String view)
-
pauseHintsDelivery
public void pauseHintsDelivery()
-
resumeHintsDelivery
public void resumeHintsDelivery()
-
truncateHints
public void truncateHints(java.lang.String host)
-
truncateHints
public void truncateHints()
-
listPendingHints
public java.util.List<java.util.Map<java.lang.String,java.lang.String>> listPendingHints()
-
refreshSizeEstimates
public void refreshSizeEstimates()
-
stopNativeTransport
public void stopNativeTransport(boolean force)
-
startNativeTransport
public void startNativeTransport()
-
isNativeTransportRunning
public boolean isNativeTransportRunning()
-
stopGossiping
public void stopGossiping()
-
startGossiping
public void startGossiping()
-
isGossipRunning
public boolean isGossipRunning()
-
stopCassandraDaemon
public void stopCassandraDaemon()
-
isInitialized
public boolean isInitialized()
-
setColumnIndexSize
public void setColumnIndexSize(int columnIndexSizeInKiB)
-
getColumnIndexSizeInKB
public int getColumnIndexSizeInKB()
-
setCompactionThroughput
public void setCompactionThroughput(int value)
-
getCompactionThroughput
@Deprecated(since="4.1") public int getCompactionThroughput()
Deprecated.See CASSANDRA-17225
-
getCompactionThroughputMebibytesAsDouble
public double getCompactionThroughputMebibytesAsDouble()
-
getCompactionThroughputBytes
public long getCompactionThroughputBytes()
-
setBatchlogReplayThrottle
public void setBatchlogReplayThrottle(int value)
-
getBatchlogReplayThrottle
public int getBatchlogReplayThrottle()
-
setConcurrentCompactors
public void setConcurrentCompactors(int value)
-
getConcurrentCompactors
public int getConcurrentCompactors()
-
setConcurrentViewBuilders
public void setConcurrentViewBuilders(int value)
-
getConcurrentViewBuilders
public int getConcurrentViewBuilders()
-
setMaxHintWindow
public void setMaxHintWindow(int value)
-
getMaxHintWindow
public int getMaxHintWindow()
-
getTimeout
public long getTimeout(java.lang.String type)
-
getStreamThroughput
@Deprecated(since="4.1") public int getStreamThroughput()
Deprecated.See CASSANDRA-17225
-
getStreamThroughputAsDouble
public double getStreamThroughputAsDouble()
-
getInterDCStreamThroughput
@Deprecated(since="4.1") public int getInterDCStreamThroughput()
Deprecated.See CASSANDRA-17225
-
getInterDCStreamThroughputAsDouble
public double getInterDCStreamThroughputAsDouble()
-
getStreamThroughputMibAsDouble
public double getStreamThroughputMibAsDouble()
-
getInterDCStreamThroughputMibAsDouble
public double getInterDCStreamThroughputMibAsDouble()
-
getEntireSSTableStreamThroughput
public double getEntireSSTableStreamThroughput()
-
getEntireSSTableInterDCStreamThroughput
public double getEntireSSTableInterDCStreamThroughput()
-
getTraceProbability
public double getTraceProbability()
-
getExceptionCount
public int getExceptionCount()
-
getDroppedMessages
public java.util.Map<java.lang.String,java.lang.Integer> getDroppedMessages()
-
loadNewSSTables
@Deprecated(since="4.0") public void loadNewSSTables(java.lang.String ksName, java.lang.String cfName)
Deprecated.See CASSANDRA-6719
-
importNewSSTables
public java.util.List<java.lang.String> importNewSSTables(java.lang.String ksName, java.lang.String cfName, java.util.Set<java.lang.String> srcPaths, boolean resetLevel, boolean clearRepaired, boolean verifySSTables, boolean verifyTokens, boolean invalidateCaches, boolean extendedVerify, boolean copyData, boolean failOnMissingIndex, boolean validateIndexChecksum)
-
rebuildIndex
public void rebuildIndex(java.lang.String ksName, java.lang.String cfName, java.lang.String... idxNames)
-
getSimpleStatesWithPort
public java.util.Map<java.lang.String,java.lang.String> getSimpleStatesWithPort()
-
getGossipInfo
public java.lang.String getGossipInfo(boolean withPort)
-
getGossipInfo
public java.lang.String getGossipInfo(boolean withPort, boolean resolveIp)
-
stop
public void stop(java.lang.String string)
-
setTimeout
public void setTimeout(java.lang.String type, long value)
-
stopById
public void stopById(java.lang.String compactionId)
-
setStreamThroughput
public void setStreamThroughput(int value)
-
setStreamThroughputMiB
public void setStreamThroughputMiB(int value)
-
setInterDCStreamThroughput
public void setInterDCStreamThroughput(int value)
-
setInterDCStreamThroughputMiB
public void setInterDCStreamThroughputMiB(int value)
-
setEntireSSTableStreamThroughput
public void setEntireSSTableStreamThroughput(int value)
-
setEntireSSTableInterDCStreamThroughput
public void setEntireSSTableInterDCStreamThroughput(int value)
-
setTraceProbability
public void setTraceProbability(double value)
-
getSchemaVersion
public java.lang.String getSchemaVersion()
-
describeRing
public java.util.List<java.lang.String> describeRing(java.lang.String keyspaceName, boolean withPort) throws java.io.IOException
- Throws:
java.io.IOException
-
rebuild
public void rebuild(java.lang.String sourceDc, java.lang.String keyspace, java.lang.String tokens, java.lang.String specificSources, boolean excludeLocalDatacenterNodes)
-
sampleKeyRange
public java.util.List<java.lang.String> sampleKeyRange()
-
resetLocalSchema
public void resetLocalSchema() throws java.io.IOException
- Throws:
java.io.IOException
-
reloadLocalSchema
public void reloadLocalSchema()
-
isFailed
public boolean isFailed()
-
failed
public void failed()
-
getReadRepairAttempted
public long getReadRepairAttempted()
-
getReadRepairRepairedBlocking
public long getReadRepairRepairedBlocking()
-
getReadRepairRepairedBackground
public long getReadRepairRepairedBackground()
-
getCacheMetric
public java.lang.Object getCacheMetric(java.lang.String cacheType, java.lang.String metricName)
Retrieve cache metrics based on the cache type (KeyCache, RowCache, or CounterCache)- Parameters:
cacheType
- KeyCach, RowCache, or CounterCachemetricName
- Capacity, Entries, HitRate, Size, Requests or Hits.
-
getBufferPoolMetric
public java.lang.Object getBufferPoolMetric(java.lang.String poolType, java.lang.String metricName)
Retrieve buffer pool metrics based on the buffer pool type- Parameters:
poolType
- networking chunk-cachemetricName
- UsedSize Size- Returns:
-
getThreadPoolMetric
public java.lang.Object getThreadPoolMetric(java.lang.String pathName, java.lang.String poolName, java.lang.String metricName)
-
getThreadPools
public com.google.common.collect.Multimap<java.lang.String,java.lang.String> getThreadPools()
Retrieve threadpool paths and names for threadpools with metrics.- Returns:
- Multimap from path (internal, request, etc.) to name
-
getNumberOfTables
public int getNumberOfTables()
-
getColumnFamilyMetric
public java.lang.Object getColumnFamilyMetric(java.lang.String ks, java.lang.String cf, java.lang.String metricName)
Retrieve ColumnFamily metrics- Parameters:
ks
- Keyspace for which stats are to be displayed or null for the global valuecf
- ColumnFamily for which stats are to be displayed or null for the keyspace value (if ks supplied)metricName
- ViewTableMetrics
.
-
getProxyMetric
public CassandraMetricsRegistry.JmxTimerMBean getProxyMetric(java.lang.String scope)
Retrieve Proxy metrics- Parameters:
scope
- RangeSlice, Read or Write
-
getMessagingQueueWaitMetrics
public CassandraMetricsRegistry.JmxTimerMBean getMessagingQueueWaitMetrics(java.lang.String verb)
-
getCompactionMetric
public java.lang.Object getCompactionMetric(java.lang.String metricName)
Retrieve Proxy metrics- Parameters:
metricName
- BytesCompacted, CompactionsAborted, CompactionsReduced, SSTablesDroppedFromCompaction, CompletedTasks, PendingTasks, PendingTasksByTableName or TotalCompactionsCompleted.
-
getClientMetric
public java.lang.Object getClientMetric(java.lang.String metricName)
Retrieve Proxy metrics- Parameters:
metricName
-
-
getCidrFilteringMetric
public java.lang.Object getCidrFilteringMetric(java.lang.String metricName)
-
getCountsMetricsFromVtable
public java.util.Map<java.lang.String,java.lang.Long> getCountsMetricsFromVtable()
-
getLatenciesMetricsFromVtable
public java.util.Map<java.lang.String,java.util.List<java.lang.Double>> getLatenciesMetricsFromVtable()
-
getStorageMetric
public long getStorageMetric(java.lang.String metricName)
Retrieve Proxy metrics- Parameters:
metricName
- Exceptions, Load, TotalHints or TotalHintsInProgress.
-
metricPercentilesAsArray
public java.lang.Double[] metricPercentilesAsArray(CassandraMetricsRegistry.JmxHistogramMBean metric)
-
metricPercentilesAsArray
public java.lang.Double[] metricPercentilesAsArray(CassandraMetricsRegistry.JmxTimerMBean metric)
-
getCompactionHistory
public javax.management.openmbean.TabularData getCompactionHistory()
-
reloadTriggers
public void reloadTriggers()
-
setLoggingLevel
public void setLoggingLevel(java.lang.String classQualifier, java.lang.String level)
-
getLoggingLevels
public java.util.Map<java.lang.String,java.lang.String> getLoggingLevels()
-
getPid
public long getPid()
-
resumeBootstrap
public void resumeBootstrap(java.io.PrintStream out) throws java.io.IOException
- Throws:
java.io.IOException
-
getMaximumPoolSizes
public java.util.Map<java.lang.String,java.util.List<java.lang.Integer>> getMaximumPoolSizes(java.util.List<java.lang.String> stageNames)
-
setConcurrency
public void setConcurrency(java.lang.String stageName, int coreThreads, int maxConcurrency)
-
replayBatchlog
public void replayBatchlog() throws java.io.IOException
- Throws:
java.io.IOException
-
getFailureDetectorPhilValues
public javax.management.openmbean.TabularData getFailureDetectorPhilValues(boolean withPort)
-
getRepairServiceProxy
public ActiveRepairServiceMBean getRepairServiceProxy()
-
reloadSslCerts
public void reloadSslCerts() throws java.io.IOException
- Throws:
java.io.IOException
-
clearConnectionHistory
public void clearConnectionHistory()
-
disableAuditLog
public void disableAuditLog()
-
enableAuditLog
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)
-
enableAuditLog
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)
-
enableAuditLog
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, java.lang.Integer maxArchiveRetries, java.lang.Boolean block, java.lang.String rollCycle, java.lang.Long maxLogSize, java.lang.Integer maxQueueWeight, java.lang.String archiveCommand)
-
enableOldProtocolVersions
public void enableOldProtocolVersions()
-
disableOldProtocolVersions
public void disableOldProtocolVersions()
-
getMessagingServiceProxy
public MessagingServiceMBean getMessagingServiceProxy()
-
enableFullQueryLogger
public void enableFullQueryLogger(java.lang.String path, java.lang.String rollCycle, java.lang.Boolean blocking, int maxQueueWeight, long maxLogSize, @Nullable java.lang.String archiveCommand, int maxArchiveRetries)
-
stopFullQueryLogger
public void stopFullQueryLogger()
-
resetFullQueryLogger
public void resetFullQueryLogger()
-
getFullQueryLoggerOptions
public FullQueryLoggerOptions getFullQueryLoggerOptions()
-
getAuditLogOptions
public AuditLogOptions getAuditLogOptions()
-
setDefaultKeyspaceReplicationFactor
public void setDefaultKeyspaceReplicationFactor(int value)
-
getDefaultKeyspaceReplicationFactor
public int getDefaultKeyspaceReplicationFactor()
-
printSet
public void printSet(java.io.PrintStream out, java.lang.String colName, java.util.Set<java.lang.String> values)
-
-