Interface StorageServiceMBean

  • All Superinterfaces:
    javax.management.NotificationBroadcaster, javax.management.NotificationEmitter
    All Known Implementing Classes:
    StorageService

    public interface StorageServiceMBean
    extends javax.management.NotificationEmitter
    • Method Detail

      • getLiveNodes

        @Deprecated(since="4.0")
        java.util.List<java.lang.String> getLiveNodes()
        Deprecated.
        See CASSANDRA-7544
        Retrieve the list of live nodes in the cluster, where "liveness" is determined by the failure detector of the node being queried.
        Returns:
        set of IP addresses, as Strings
      • getLiveNodesWithPort

        java.util.List<java.lang.String> getLiveNodesWithPort()
      • getUnreachableNodes

        @Deprecated(since="4.0")
        java.util.List<java.lang.String> getUnreachableNodes()
        Deprecated.
        See CASSANDRA-7544
        Retrieve the list of unreachable nodes in the cluster, as determined by this node's failure detector.
        Returns:
        set of IP addresses, as Strings
      • getUnreachableNodesWithPort

        java.util.List<java.lang.String> getUnreachableNodesWithPort()
      • getJoiningNodes

        @Deprecated(since="4.0")
        java.util.List<java.lang.String> getJoiningNodes()
        Deprecated.
        See CASSANDRA-7544
        Retrieve the list of nodes currently bootstrapping into the ring.
        Returns:
        set of IP addresses, as Strings
      • getJoiningNodesWithPort

        java.util.List<java.lang.String> getJoiningNodesWithPort()
      • getLeavingNodes

        @Deprecated(since="4.0")
        java.util.List<java.lang.String> getLeavingNodes()
        Deprecated.
        See CASSANDRA-7544
        Retrieve the list of nodes currently leaving the ring.
        Returns:
        set of IP addresses, as Strings
      • getLeavingNodesWithPort

        java.util.List<java.lang.String> getLeavingNodesWithPort()
      • getMovingNodes

        @Deprecated(since="4.0")
        java.util.List<java.lang.String> getMovingNodes()
        Deprecated.
        See CASSANDRA-7544
        Retrieve the list of nodes currently moving in the ring.
        Returns:
        set of IP addresses, as Strings
      • getMovingNodesWithPort

        java.util.List<java.lang.String> getMovingNodesWithPort()
      • getTokens

        java.util.List<java.lang.String> getTokens()
        Fetch string representations of the tokens for this node.
        Returns:
        a collection of tokens formatted as strings
      • getTokens

        java.util.List<java.lang.String> getTokens​(java.lang.String endpoint)
                                            throws java.net.UnknownHostException
        Fetch string representations of the tokens for a specified node.
        Parameters:
        endpoint - string representation of an node
        Returns:
        a collection of tokens formatted as strings
        Throws:
        java.net.UnknownHostException
      • getReleaseVersion

        java.lang.String getReleaseVersion()
        Fetch a string representation of the Cassandra version.
        Returns:
        A string representation of the Cassandra version.
      • getGitSHA

        java.lang.String getGitSHA()
        Fetch a string representation of the Cassandra git SHA.
        Returns:
        A string representation of the Cassandra git SHA.
      • getSchemaVersion

        java.lang.String getSchemaVersion()
        Fetch a string representation of the current Schema version.
        Returns:
        A string representation of the Schema version.
      • getKeyspaceReplicationInfo

        java.lang.String getKeyspaceReplicationInfo​(java.lang.String keyspaceName)
        Fetch the replication factor for a given keyspace.
        Returns:
        An integer that represents replication factor for the given keyspace.
      • getAllDataFileLocations

        java.lang.String[] getAllDataFileLocations()
        Get the list of all data file locations from conf
        Returns:
        String array of all locations
      • getLocalSystemKeyspacesDataFileLocations

        java.lang.String[] getLocalSystemKeyspacesDataFileLocations()
        Returns the locations where the local system keyspaces data should be stored.
        Returns:
        the locations where the local system keyspaces data should be stored
      • getNonLocalSystemKeyspacesDataFileLocations

        java.lang.String[] getNonLocalSystemKeyspacesDataFileLocations()
        Returns the locations where should be stored the non system keyspaces data.
        Returns:
        the locations where should be stored the non system keyspaces data
      • getCommitLogLocation

        java.lang.String getCommitLogLocation()
        Get location of the commit log
        Returns:
        a string path
      • getSavedCachesLocation

        java.lang.String getSavedCachesLocation()
        Get location of the saved caches dir
        Returns:
        a string path
      • getRangeToEndpointMap

        @Deprecated(since="4.0")
        java.util.Map<java.util.List<java.lang.String>,​java.util.List<java.lang.String>> getRangeToEndpointMap​(java.lang.String keyspace)
        Deprecated.
        See CASSANDRA-7544
        Retrieve a map of range to end points that describe the ring topology of a Cassandra cluster.
        Returns:
        mapping of ranges to end points
      • getRangeToEndpointWithPortMap

        java.util.Map<java.util.List<java.lang.String>,​java.util.List<java.lang.String>> getRangeToEndpointWithPortMap​(java.lang.String keyspace)
      • getRangeToRpcaddressMap

        @Deprecated(since="4.0")
        java.util.Map<java.util.List<java.lang.String>,​java.util.List<java.lang.String>> getRangeToRpcaddressMap​(java.lang.String keyspace)
        Deprecated.
        See CASSANDRA-7544
        Retrieve a map of range to rpc addresses that describe the ring topology of a Cassandra cluster.
        Returns:
        mapping of ranges to rpc addresses
      • getRangeToNativeaddressWithPortMap

        java.util.Map<java.util.List<java.lang.String>,​java.util.List<java.lang.String>> getRangeToNativeaddressWithPortMap​(java.lang.String keyspace)
      • describeRingJMX

        @Deprecated(since="4.0")
        java.util.List<java.lang.String> describeRingJMX​(java.lang.String keyspace)
                                                  throws java.io.IOException
        Deprecated.
        See CASSANDRA-7544
        The same as describeRing(String) but converts TokenRange to the String for JMX compatibility
        Parameters:
        keyspace - The keyspace to fetch information about
        Returns:
        a List of TokenRange(s) converted to String for the given keyspace
        Throws:
        java.io.IOException
      • describeRingWithPortJMX

        java.util.List<java.lang.String> describeRingWithPortJMX​(java.lang.String keyspace)
                                                          throws java.io.IOException
        Throws:
        java.io.IOException
      • getPendingRangeToEndpointMap

        @Deprecated(since="4.0")
        java.util.Map<java.util.List<java.lang.String>,​java.util.List<java.lang.String>> getPendingRangeToEndpointMap​(java.lang.String keyspace)
        Deprecated.
        See CASSANDRA-7544
        Retrieve a map of pending ranges to endpoints that describe the ring topology
        Parameters:
        keyspace - the keyspace to get the pending range map for.
        Returns:
        a map of pending ranges to endpoints
      • getPendingRangeToEndpointWithPortMap

        java.util.Map<java.util.List<java.lang.String>,​java.util.List<java.lang.String>> getPendingRangeToEndpointWithPortMap​(java.lang.String keyspace)
      • getTokenToEndpointMap

        @Deprecated(since="4.0")
        java.util.Map<java.lang.String,​java.lang.String> getTokenToEndpointMap()
        Deprecated.
        See CASSANDRA-7544
        Retrieve a map of tokens to endpoints, including the bootstrapping ones.
        Returns:
        a map of tokens to endpoints in ascending order
      • getTokenToEndpointWithPortMap

        java.util.Map<java.lang.String,​java.lang.String> getTokenToEndpointWithPortMap()
      • getLocalHostId

        java.lang.String getLocalHostId()
        Retrieve this hosts unique ID
      • getEndpointToHostId

        @Deprecated(since="4.0")
        java.util.Map<java.lang.String,​java.lang.String> getEndpointToHostId()
        Deprecated.
        See CASSANDRA-7544
        Retrieve the mapping of endpoint to host ID.
      • getEndpointWithPortToHostId

        java.util.Map<java.lang.String,​java.lang.String> getEndpointWithPortToHostId()
      • getHostIdToEndpoint

        @Deprecated(since="4.0")
        java.util.Map<java.lang.String,​java.lang.String> getHostIdToEndpoint()
        Deprecated.
        See CASSANDRA-7544
        Retrieve the mapping of host ID to endpoint.
      • getHostIdToEndpointWithPort

        java.util.Map<java.lang.String,​java.lang.String> getHostIdToEndpointWithPort()
      • getLoadString

        java.lang.String getLoadString()
        Human-readable load value
      • getUncompressedLoadString

        java.lang.String getUncompressedLoadString()
        Human-readable uncompressed load value
      • getLoadMap

        @Deprecated(since="4.0")
        java.util.Map<java.lang.String,​java.lang.String> getLoadMap()
        Deprecated.
        See CASSANDRA-7544
        Human-readable load value. Keys are IP addresses.
      • getLoadMapWithPort

        java.util.Map<java.lang.String,​java.lang.String> getLoadMapWithPort()
      • getCurrentGenerationNumber

        int getCurrentGenerationNumber()
        Return the generation value for this node.
        Returns:
        generation number
      • getNaturalEndpoints

        @Deprecated(since="4.0")
        java.util.List<java.net.InetAddress> getNaturalEndpoints​(java.lang.String keyspaceName,
                                                                 java.lang.String cf,
                                                                 java.lang.String key)
        Deprecated.
        See CASSANDRA-7544
        This method returns the N endpoints that are responsible for storing the specified key i.e for replication.
        Parameters:
        keyspaceName - keyspace name
        cf - Column family name
        key - - key for which we need to find the endpoint return value - the endpoint responsible for this key
      • getNaturalEndpointsWithPort

        java.util.List<java.lang.String> getNaturalEndpointsWithPort​(java.lang.String keyspaceName,
                                                                     java.lang.String cf,
                                                                     java.lang.String key)
      • getNaturalEndpoints

        @Deprecated(since="4.0")
        java.util.List<java.net.InetAddress> getNaturalEndpoints​(java.lang.String keyspaceName,
                                                                 java.nio.ByteBuffer key)
        Deprecated.
        See CASSANDRA-7544
      • getNaturalEndpointsWithPort

        java.util.List<java.lang.String> getNaturalEndpointsWithPort​(java.lang.String keysapceName,
                                                                     java.nio.ByteBuffer key)
      • takeTableSnapshot

        @Deprecated(since="3.4")
        void takeTableSnapshot​(java.lang.String keyspaceName,
                               java.lang.String tableName,
                               java.lang.String tag)
                        throws java.io.IOException
        Deprecated.
        Throws:
        java.io.IOException
      • takeMultipleTableSnapshot

        @Deprecated(since="3.4")
        void takeMultipleTableSnapshot​(java.lang.String tag,
                                       java.lang.String... tableList)
                                throws java.io.IOException
        Deprecated.
        Throws:
        java.io.IOException
      • takeSnapshot

        void takeSnapshot​(java.lang.String tag,
                          java.util.Map<java.lang.String,​java.lang.String> options,
                          java.lang.String... entities)
                   throws java.io.IOException
        Takes the snapshot of a multiple column family from different keyspaces. A snapshot name must be specified.
        Parameters:
        tag - the tag given to the snapshot; may not be null or empty
        options - 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,...
        Throws:
        java.io.IOException
      • clearSnapshot

        @Deprecated(since="5.0")
        void clearSnapshot​(java.lang.String tag,
                           java.lang.String... keyspaceNames)
                    throws java.io.IOException
        Deprecated.
        See CASSANDRA-16860
        Remove the snapshot with the given name from the given keyspaces. If no tag is specified we will remove all snapshots.
        Parameters:
        tag - name of snapshot to clear, if null or empty string, all snapshots of given keyspace will be cleared
        keyspaceNames - name of keyspaces to clear snapshots for
        Throws:
        java.io.IOException
      • clearSnapshot

        void clearSnapshot​(java.util.Map<java.lang.String,​java.lang.Object> options,
                           java.lang.String tag,
                           java.lang.String... keyspaceNames)
                    throws java.io.IOException
        Remove the snapshot with the given name from the given keyspaces. If no tag is specified we will remove all snapshots.
        Parameters:
        options - map of options for cleanup operation, consult nodetool's ClearSnapshot
        tag - name of snapshot to clear, if null or empty string, all snapshots of given keyspace will be cleared
        keyspaceNames - name of keyspaces to clear snapshots for
        Throws:
        java.io.IOException
      • getSnapshotDetails

        @Deprecated(since="4.1")
        java.util.Map<java.lang.String,​javax.management.openmbean.TabularData> getSnapshotDetails()
        Deprecated.
        See CASSANDRA-16789
        Get the details of all the snapshot
        Returns:
        A map of snapshotName to all its details in Tabular form.
      • getSnapshotDetails

        java.util.Map<java.lang.String,​javax.management.openmbean.TabularData> getSnapshotDetails​(java.util.Map<java.lang.String,​java.lang.String> options)
        Get the details of all the snapshots
        Parameters:
        options - map of options used for filtering of snapshots
        Returns:
        A map of snapshotName to all its details in Tabular form.
      • trueSnapshotsSize

        long trueSnapshotsSize()
        Get the true size taken by all snapshots across all keyspaces.
        Returns:
        True size taken by all the snapshots.
      • setSnapshotLinksPerSecond

        void setSnapshotLinksPerSecond​(long throttle)
        Set the current hardlink-per-second throttle for snapshots A setting of zero indicates no throttling
        Parameters:
        throttle -
      • getSnapshotLinksPerSecond

        long getSnapshotLinksPerSecond()
        Get the current hardlink-per-second throttle for snapshots A setting of zero indicates no throttling.
        Returns:
        snapshot links-per-second throttle
      • refreshSizeEstimates

        void refreshSizeEstimates()
                           throws java.util.concurrent.ExecutionException
        Forces refresh of values stored in system.size_estimates of all column families.
        Throws:
        java.util.concurrent.ExecutionException
      • cleanupSizeEstimates

        void cleanupSizeEstimates()
        Removes extraneous entries in system.size_estimates.
      • forceKeyspaceCompaction

        void forceKeyspaceCompaction​(boolean splitOutput,
                                     java.lang.String keyspaceName,
                                     java.lang.String... tableNames)
                              throws java.io.IOException,
                                     java.util.concurrent.ExecutionException,
                                     java.lang.InterruptedException
        Forces major compaction of a single keyspace
        Throws:
        java.io.IOException
        java.util.concurrent.ExecutionException
        java.lang.InterruptedException
      • relocateSSTables

        @Deprecated(since="3.5")
        int relocateSSTables​(java.lang.String keyspace,
                             java.lang.String... cfnames)
                      throws java.io.IOException,
                             java.util.concurrent.ExecutionException,
                             java.lang.InterruptedException
        Deprecated.
        See CASSANDRA-11179
        Throws:
        java.io.IOException
        java.util.concurrent.ExecutionException
        java.lang.InterruptedException
      • relocateSSTables

        int 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

        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 compacted
        startToken - 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

        void forceKeyspaceCompactionForPartitionKey​(java.lang.String keyspaceName,
                                                    java.lang.String partitionKey,
                                                    java.lang.String... tableNames)
                                             throws java.io.IOException,
                                                    java.util.concurrent.ExecutionException,
                                                    java.lang.InterruptedException
        Forces major compactions for the range represented by the partition key
        Throws:
        java.io.IOException
        java.util.concurrent.ExecutionException
        java.lang.InterruptedException
      • forceCompactionKeysIgnoringGcGrace

        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
        Forces compaction for a list of partition keys on a table. The method will ignore the gc_grace_seconds for the partitionKeysIgnoreGcGrace during the comapction, in order to purge the tombstones and free up space quicker.
        Throws:
        java.io.IOException
        java.util.concurrent.ExecutionException
        java.lang.InterruptedException
      • forceKeyspaceCleanup

        @Deprecated(since="3.5")
        int forceKeyspaceCleanup​(java.lang.String keyspaceName,
                                 java.lang.String... tables)
                          throws java.io.IOException,
                                 java.util.concurrent.ExecutionException,
                                 java.lang.InterruptedException
        Deprecated.
        See CASSANDRA-11179
        Trigger a cleanup of keys on a single keyspace
        Throws:
        java.io.IOException
        java.util.concurrent.ExecutionException
        java.lang.InterruptedException
      • forceKeyspaceCleanup

        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

        @Deprecated(since="3.5")
        default int scrub​(boolean disableSnapshot,
                          boolean skipCorrupted,
                          boolean checkData,
                          java.lang.String keyspaceName,
                          java.lang.String... tableNames)
                   throws java.io.IOException,
                          java.util.concurrent.ExecutionException,
                          java.lang.InterruptedException
        Deprecated.
        See CASSANDRA-11179
        Scrub (deserialize + reserialize at the latest version, skipping bad rows if any) the given keyspace. If tableNames array is empty, all CFs are scrubbed. Scrubbed CFs will be snapshotted first, if disableSnapshot is false
        Throws:
        java.io.IOException
        java.util.concurrent.ExecutionException
        java.lang.InterruptedException
      • scrub

        @Deprecated(since="3.11")
        default int scrub​(boolean disableSnapshot,
                          boolean skipCorrupted,
                          boolean checkData,
                          int jobs,
                          java.lang.String keyspaceName,
                          java.lang.String... columnFamilies)
                   throws java.io.IOException,
                          java.util.concurrent.ExecutionException,
                          java.lang.InterruptedException
        Deprecated.
        See CASSANDRA-14092
        Throws:
        java.io.IOException
        java.util.concurrent.ExecutionException
        java.lang.InterruptedException
      • scrub

        int scrub​(boolean disableSnapshot,
                  boolean skipCorrupted,
                  boolean checkData,
                  boolean reinsertOverflowedTTL,
                  int jobs,
                  java.lang.String keyspaceName,
                  java.lang.String... columnFamilies)
           throws java.io.IOException,
                  java.util.concurrent.ExecutionException,
                  java.lang.InterruptedException
        Throws:
        java.io.IOException
        java.util.concurrent.ExecutionException
        java.lang.InterruptedException
      • verify

        int verify​(boolean extendedVerify,
                   java.lang.String keyspaceName,
                   java.lang.String... tableNames)
            throws java.io.IOException,
                   java.util.concurrent.ExecutionException,
                   java.lang.InterruptedException
        Verify (checksums of) the given keyspace. If tableNames array is empty, all CFs are verified. The entire sstable will be read to ensure each cell validates if extendedVerify is true
        Throws:
        java.io.IOException
        java.util.concurrent.ExecutionException
        java.lang.InterruptedException
      • verify

        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

        @Deprecated(since="3.5")
        int upgradeSSTables​(java.lang.String keyspaceName,
                            boolean excludeCurrentVersion,
                            java.lang.String... tableNames)
                     throws java.io.IOException,
                            java.util.concurrent.ExecutionException,
                            java.lang.InterruptedException
        Deprecated.
        See CASSANDRA-11179
        Rewrite all sstables to the latest version. Unlike scrub, it doesn't skip bad rows and do not snapshot sstables first.
        Throws:
        java.io.IOException
        java.util.concurrent.ExecutionException
        java.lang.InterruptedException
      • upgradeSSTables

        @Deprecated(since="4.1")
        default 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
        Deprecated.
        See CASSANDRA-16837
        Throws:
        java.io.IOException
        java.util.concurrent.ExecutionException
        java.lang.InterruptedException
      • upgradeSSTables

        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
      • recompressSSTables

        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
      • garbageCollect

        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
        Rewrites all sstables from the given tables to remove deleted data. The tombstone option defines the granularity of the procedure: ROW removes deleted partitions and rows, CELL also removes overwritten or deleted cells.
        Throws:
        java.io.IOException
        java.util.concurrent.ExecutionException
        java.lang.InterruptedException
      • forceKeyspaceFlush

        void forceKeyspaceFlush​(java.lang.String keyspaceName,
                                java.lang.String... tableNames)
                         throws java.io.IOException,
                                java.util.concurrent.ExecutionException,
                                java.lang.InterruptedException
        Flush all memtables for the given column families, or all columnfamilies for the given keyspace if none are explicitly listed.
        Parameters:
        keyspaceName -
        tableNames -
        Throws:
        java.io.IOException
        java.util.concurrent.ExecutionException
        java.lang.InterruptedException
      • repairAsync

        int repairAsync​(java.lang.String keyspace,
                        java.util.Map<java.lang.String,​java.lang.String> options)
        Invoke repair asynchronously. You can track repair progress by subscribing JMX notification sent from this StorageServiceMBean. Notification format is: type: "repair" userObject: int array of length 2, [0]=command number, [1]=ordinal of ActiveRepairService.Status
        Parameters:
        keyspace - Keyspace name to repair. Should not be null.
        options - repair option.
        Returns:
        Repair command number, or 0 if nothing to repair
      • forceTerminateAllRepairSessions

        void forceTerminateAllRepairSessions()
      • setRepairSessionMaxTreeDepth

        @Deprecated(since="5.0")
        void setRepairSessionMaxTreeDepth​(int depth)
        Deprecated.
        use setRepairSessionMaximumTreeDepth instead as it will not throw non-standard exceptions. See CASSANDRA-17668
      • getRepairSessionMaxTreeDepth

        @Deprecated(since="5.0")
        int getRepairSessionMaxTreeDepth()
        Deprecated.
        use getRepairSessionMaximumTreeDepth instead. See CASSANDRA-17668
      • setRepairSessionMaximumTreeDepth

        void setRepairSessionMaximumTreeDepth​(int depth)
      • getRepairSessionMaximumTreeDepth

        int getRepairSessionMaximumTreeDepth()
      • getParentRepairStatus

        @Nullable
        java.util.List<java.lang.String> getParentRepairStatus​(int cmd)
        Get the status of a given parent repair session.
        Parameters:
        cmd - the int reference returned when issuing the repair
        Returns:
        status of parent repair from enum ActiveRepairService.ParentRepairStatus followed by final message or messages of the session
      • decommission

        void decommission​(boolean force)
                   throws java.lang.InterruptedException
        transfer this node's data to other machines and remove it from service.
        Parameters:
        force - Decommission even if this will reduce N to be less than RF.
        Throws:
        java.lang.InterruptedException
      • isDecommissionFailed

        boolean isDecommissionFailed()
        Returns whether a node has failed to decommission. The fact that this method returns false does not mean that there was an attempt to decommission this node which was successful.
        Returns:
        true if decommission of this node has failed, false otherwise
      • isDecommissioning

        boolean isDecommissioning()
        Returns whether a node is being decommissioned or not.
        Returns:
        true if this node is decommissioning, false otherwise
      • move

        void move​(java.lang.String newToken)
           throws java.io.IOException
        Parameters:
        newToken - token to move this node to. This node will unload its data onto its neighbors, and bootstrap to the new token.
        Throws:
        java.io.IOException
      • removeNode

        void removeNode​(java.lang.String token)
        removeToken removes token (and all data associated with enpoint that had it) from the ring
      • getRemovalStatus

        @Deprecated(since="4.0")
        java.lang.String getRemovalStatus()
        Deprecated.
        See CASSANDRA-7544
        Get the status of a token removal.
      • getRemovalStatusWithPort

        java.lang.String getRemovalStatusWithPort()
      • forceRemoveCompletion

        void forceRemoveCompletion()
        Force a remove operation to finish.
      • setLoggingLevel

        void setLoggingLevel​(java.lang.String classQualifier,
                             java.lang.String level)
                      throws java.lang.Exception
        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
        Parameters:
        classQualifier - The logger's classQualifer
        level - The log level
        Throws:
        java.lang.Exception
        See Also:
        Level.toLevel(String)
      • getLoggingLevels

        java.util.Map<java.lang.String,​java.lang.String> getLoggingLevels()
        get the runtime logging levels
      • getOperationMode

        java.lang.String getOperationMode()
        get the operational mode (leaving, joining, normal, decommissioned, client)
      • isStarting

        boolean isStarting()
        Returns whether the storage service is starting or not
      • getDrainProgress

        java.lang.String getDrainProgress()
        get the progress of a drain operation
      • drain

        void drain()
            throws java.io.IOException,
                   java.lang.InterruptedException,
                   java.util.concurrent.ExecutionException
        makes node unavailable for writes, flushes memtables and replays commitlog.
        Throws:
        java.io.IOException
        java.lang.InterruptedException
        java.util.concurrent.ExecutionException
      • truncate

        void truncate​(java.lang.String keyspace,
                      java.lang.String table)
               throws java.util.concurrent.TimeoutException,
                      java.io.IOException
        Truncates (deletes) the given table from the provided keyspace. Calling truncate results in actual deletion of all data in the cluster under the given table and it will fail unless all hosts are up. All data in the given column family will be deleted, but its definition will not be affected.
        Parameters:
        keyspace - The keyspace to delete from
        table - The column family to delete data from.
        Throws:
        java.util.concurrent.TimeoutException
        java.io.IOException
      • getOwnership

        @Deprecated(since="4.0")
        java.util.Map<java.net.InetAddress,​java.lang.Float> getOwnership()
        Deprecated.
        See CASSANDRA-7544
        given a list of tokens (representing the nodes in the cluster), returns a mapping from "token -> %age of cluster owned by that token"
      • getOwnershipWithPort

        java.util.Map<java.lang.String,​java.lang.Float> getOwnershipWithPort()
      • effectiveOwnership

        @Deprecated(since="4.0")
        java.util.Map<java.net.InetAddress,​java.lang.Float> effectiveOwnership​(java.lang.String keyspace)
                                                                              throws java.lang.IllegalStateException
        Deprecated.
        See CASSANDRA-7544
        Effective ownership is % of the data each node owns given the keyspace we calculate the percentage using replication factor. If Keyspace == null, this method will try to verify if all the keyspaces in the cluster have the same replication strategies and if yes then we will use the first else a empty Map is returned.
        Throws:
        java.lang.IllegalStateException
      • effectiveOwnershipWithPort

        java.util.Map<java.lang.String,​java.lang.Float> effectiveOwnershipWithPort​(java.lang.String keyspace)
                                                                                  throws java.lang.IllegalStateException
        Throws:
        java.lang.IllegalStateException
      • getKeyspaces

        java.util.List<java.lang.String> getKeyspaces()
      • getNonSystemKeyspaces

        java.util.List<java.lang.String> getNonSystemKeyspaces()
      • getNonLocalStrategyKeyspaces

        java.util.List<java.lang.String> getNonLocalStrategyKeyspaces()
      • getViewBuildStatuses

        @Deprecated(since="4.0")
        java.util.Map<java.lang.String,​java.lang.String> getViewBuildStatuses​(java.lang.String keyspace,
                                                                                    java.lang.String view)
        Deprecated.
        See CASSANDRA-7544
      • getViewBuildStatusesWithPort

        java.util.Map<java.lang.String,​java.lang.String> getViewBuildStatusesWithPort​(java.lang.String keyspace,
                                                                                            java.lang.String view)
      • updateSnitch

        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
        Change endpointsnitch class and dynamic-ness (and dynamic attributes) at runtime. This method is used to change the snitch implementation and/or dynamic snitch parameters. If 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.
        Parameters:
        epSnitchClassName - the canonical path name for a class implementing IEndpointSnitch
        dynamic - boolean that decides whether dynamicsnitch is used or not - only valid, if epSnitchClassName is specified
        dynamicUpdateInterval - 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)
        Throws:
        java.lang.ClassNotFoundException
      • setDynamicUpdateInterval

        void setDynamicUpdateInterval​(int dynamicUpdateInterval)
      • getDynamicUpdateInterval

        int getDynamicUpdateInterval()
      • stopGossiping

        void stopGossiping()
      • startGossiping

        void startGossiping()
      • isGossipRunning

        boolean isGossipRunning()
      • stopDaemon

        void stopDaemon()
      • isInitialized

        boolean isInitialized()
      • stopNativeTransport

        @Deprecated(since="5.0")
        default void stopNativeTransport()
        Deprecated.
      • stopNativeTransport

        void stopNativeTransport​(boolean force)
      • startNativeTransport

        void startNativeTransport()
      • isNativeTransportRunning

        boolean isNativeTransportRunning()
      • enableNativeTransportOldProtocolVersions

        void enableNativeTransportOldProtocolVersions()
      • disableNativeTransportOldProtocolVersions

        void disableNativeTransportOldProtocolVersions()
      • getNativeTransportMaxConcurrentRequestsInBytes

        long getNativeTransportMaxConcurrentRequestsInBytes()
      • setNativeTransportMaxConcurrentRequestsInBytes

        void setNativeTransportMaxConcurrentRequestsInBytes​(long newLimit)
      • getNativeTransportMaxConcurrentRequestsInBytesPerIp

        long getNativeTransportMaxConcurrentRequestsInBytesPerIp()
      • setNativeTransportMaxConcurrentRequestsInBytesPerIp

        void setNativeTransportMaxConcurrentRequestsInBytesPerIp​(long newLimit)
      • getNativeTransportMaxRequestsPerSecond

        int getNativeTransportMaxRequestsPerSecond()
      • setNativeTransportMaxRequestsPerSecond

        void setNativeTransportMaxRequestsPerSecond​(int newPerSecond)
      • setNativeTransportRateLimitingEnabled

        void setNativeTransportRateLimitingEnabled​(boolean enabled)
      • getNativeTransportRateLimitingEnabled

        boolean getNativeTransportRateLimitingEnabled()
      • joinRing

        void joinRing()
               throws java.io.IOException
        Throws:
        java.io.IOException
      • isJoined

        boolean isJoined()
      • isDrained

        boolean isDrained()
      • isDraining

        boolean isDraining()
      • isBootstrapMode

        boolean isBootstrapMode()
        Check if currently bootstrapping. Note this becomes false before SystemKeyspace.bootstrapComplete() is called, as setting bootstrap to complete is called only when the node joins the ring.
        Returns:
        True prior to bootstrap streaming completing. False prior to start of bootstrap and post streaming.
      • isBootstrapFailed

        boolean isBootstrapFailed()
        Returns whether a node has failed to bootstrap. The fact that this method returns false does not mean that there was an attempt to bootstrap this node which was successful.
        Returns:
        true if bootstrap of this node has failed, false otherwise
      • setRpcTimeout

        void setRpcTimeout​(long value)
      • getRpcTimeout

        long getRpcTimeout()
      • setReadRpcTimeout

        void setReadRpcTimeout​(long value)
      • getReadRpcTimeout

        long getReadRpcTimeout()
      • setRangeRpcTimeout

        void setRangeRpcTimeout​(long value)
      • getRangeRpcTimeout

        long getRangeRpcTimeout()
      • setWriteRpcTimeout

        void setWriteRpcTimeout​(long value)
      • getWriteRpcTimeout

        long getWriteRpcTimeout()
      • setInternodeTcpConnectTimeoutInMS

        void setInternodeTcpConnectTimeoutInMS​(int value)
      • getInternodeTcpConnectTimeoutInMS

        int getInternodeTcpConnectTimeoutInMS()
      • setInternodeTcpUserTimeoutInMS

        void setInternodeTcpUserTimeoutInMS​(int value)
      • getInternodeTcpUserTimeoutInMS

        int getInternodeTcpUserTimeoutInMS()
      • setInternodeStreamingTcpUserTimeoutInMS

        void setInternodeStreamingTcpUserTimeoutInMS​(int value)
      • getInternodeStreamingTcpUserTimeoutInMS

        int getInternodeStreamingTcpUserTimeoutInMS()
      • setCounterWriteRpcTimeout

        void setCounterWriteRpcTimeout​(long value)
      • getCounterWriteRpcTimeout

        long getCounterWriteRpcTimeout()
      • setCasContentionTimeout

        void setCasContentionTimeout​(long value)
      • getCasContentionTimeout

        long getCasContentionTimeout()
      • setTruncateRpcTimeout

        void setTruncateRpcTimeout​(long value)
      • getTruncateRpcTimeout

        long getTruncateRpcTimeout()
      • setStreamThroughputMbitPerSec

        void setStreamThroughputMbitPerSec​(int value)
      • getStreamThroughputMbitPerSec

        @Deprecated(since="4.1")
        int getStreamThroughputMbitPerSec()
        Deprecated.
        Use getStreamThroughputMbitPerSecAsDouble instead as this one will provide a rounded value. See CASSANDRA-17225
        Returns:
        stream_throughput_outbound in megabits
      • getStreamThroughputMbitPerSecAsDouble

        double getStreamThroughputMbitPerSecAsDouble()
      • setStreamThroughputMbPerSec

        @Deprecated(since="4.1")
        void setStreamThroughputMbPerSec​(int value)
        Deprecated.
        See CASSANDRA-15234
      • getStreamThroughputMbPerSec

        @Deprecated(since="4.1")
        int getStreamThroughputMbPerSec()
        Deprecated.
        Use getStreamThroughputMebibytesPerSecAsDouble instead as this one will provide a rounded value. See CASSANDRA-15234
        Returns:
        stream_throughput_outbound in MiB
      • setStreamThroughputMebibytesPerSec

        void setStreamThroughputMebibytesPerSec​(int value)
      • getStreamThroughputMebibytesPerSec

        int getStreamThroughputMebibytesPerSec()
        Below method returns stream_throughput_outbound rounded, for precise number, please, use getStreamThroughputMebibytesPerSecAsDouble
        Returns:
        stream_throughput_outbound in MiB
      • getStreamThroughputMebibytesPerSecAsDouble

        double getStreamThroughputMebibytesPerSecAsDouble()
      • setInterDCStreamThroughputMbitPerSec

        void setInterDCStreamThroughputMbitPerSec​(int value)
      • getInterDCStreamThroughputMbitPerSec

        @Deprecated(since="4.1")
        int getInterDCStreamThroughputMbitPerSec()
        Deprecated.
        Use getInterDCStreamThroughputMbitPerSecAsDouble instead as this one will provide a rounded value. See CASSANDRA-17225
        Returns:
        inter_dc_stream_throughput_outbound in megabits
      • getInterDCStreamThroughputMbitPerSecAsDouble

        double getInterDCStreamThroughputMbitPerSecAsDouble()
      • setInterDCStreamThroughputMbPerSec

        @Deprecated(since="4.1")
        void setInterDCStreamThroughputMbPerSec​(int value)
        Deprecated.
        See CASSANDRA-15234
      • getInterDCStreamThroughputMbPerSec

        @Deprecated(since="4.1")
        int getInterDCStreamThroughputMbPerSec()
        Deprecated.
        Use getInterDCStreamThroughputMebibytesPerSecAsDouble instead as this one will provide a rounded value. See CASSANDRA-15234
        Returns:
        inter_dc_stream_throughput_outbound in MiB
      • setInterDCStreamThroughputMebibytesPerSec

        void setInterDCStreamThroughputMebibytesPerSec​(int value)
      • getInterDCStreamThroughputMebibytesPerSec

        int getInterDCStreamThroughputMebibytesPerSec()
        Below method returns Inter_dc_stream_throughput_outbound rounded, for precise number, please, use getInterDCStreamThroughputMebibytesPerSecAsDouble
        Returns:
        inter_dc_stream_throughput_outbound in MiB
      • getInterDCStreamThroughputMebibytesPerSecAsDouble

        double getInterDCStreamThroughputMebibytesPerSecAsDouble()
      • setEntireSSTableStreamThroughputMebibytesPerSec

        void setEntireSSTableStreamThroughputMebibytesPerSec​(int value)
      • getEntireSSTableStreamThroughputMebibytesPerSecAsDouble

        double getEntireSSTableStreamThroughputMebibytesPerSecAsDouble()
      • setEntireSSTableInterDCStreamThroughputMebibytesPerSec

        void setEntireSSTableInterDCStreamThroughputMebibytesPerSec​(int value)
      • getEntireSSTableInterDCStreamThroughputMebibytesPerSecAsDouble

        double getEntireSSTableInterDCStreamThroughputMebibytesPerSecAsDouble()
      • getCompactionThroughtputMibPerSecAsDouble

        double getCompactionThroughtputMibPerSecAsDouble()
      • getCompactionThroughtputBytesPerSec

        long getCompactionThroughtputBytesPerSec()
      • getCompactionThroughputMbPerSec

        @Deprecated(since="4.1")
        int getCompactionThroughputMbPerSec()
        Deprecated.
        Use getCompactionThroughtputMibPerSecAsDouble instead as this one will provide a rounded value. See CASSANDRA-17225
        Returns:
        compaction_throughgput in MiB
      • setCompactionThroughputMbPerSec

        void setCompactionThroughputMbPerSec​(int value)
      • getBatchlogReplayThrottleInKB

        int getBatchlogReplayThrottleInKB()
      • setBatchlogReplayThrottleInKB

        void setBatchlogReplayThrottleInKB​(int value)
      • getConcurrentCompactors

        int getConcurrentCompactors()
      • setConcurrentCompactors

        void setConcurrentCompactors​(int value)
      • bypassConcurrentValidatorsLimit

        void bypassConcurrentValidatorsLimit()
      • enforceConcurrentValidatorsLimit

        void enforceConcurrentValidatorsLimit()
      • isConcurrentValidatorsLimitEnforced

        boolean isConcurrentValidatorsLimitEnforced()
      • getConcurrentIndexBuilders

        int getConcurrentIndexBuilders()
      • setConcurrentIndexBuilders

        void setConcurrentIndexBuilders​(int value)
      • getConcurrentValidators

        int getConcurrentValidators()
      • setConcurrentValidators

        void setConcurrentValidators​(int value)
      • getSSTablePreemptiveOpenIntervalInMB

        int getSSTablePreemptiveOpenIntervalInMB()
      • setSSTablePreemptiveOpenIntervalInMB

        void setSSTablePreemptiveOpenIntervalInMB​(int intervalInMB)
      • getMigrateKeycacheOnCompaction

        boolean getMigrateKeycacheOnCompaction()
      • setMigrateKeycacheOnCompaction

        void setMigrateKeycacheOnCompaction​(boolean invalidateKeyCacheOnCompaction)
      • getConcurrentViewBuilders

        int getConcurrentViewBuilders()
      • setConcurrentViewBuilders

        void setConcurrentViewBuilders​(int value)
      • isIncrementalBackupsEnabled

        boolean isIncrementalBackupsEnabled()
      • setIncrementalBackupsEnabled

        void setIncrementalBackupsEnabled​(boolean value)
      • rebuild

        void rebuild​(java.lang.String sourceDc)
        Initiate a process of streaming data for which we are responsible from other nodes. It is similar to bootstrap except meant to be used on a node which is already in the cluster (typically containing no data) as an alternative to running repair.
        Parameters:
        sourceDc - Name of DC from which to select sources for streaming or null to pick any node
      • rebuild

        void rebuild​(java.lang.String sourceDc,
                     java.lang.String keyspace,
                     java.lang.String tokens,
                     java.lang.String specificSources)
        Same as rebuild(String), but only for specified keyspace and ranges.
        Parameters:
        sourceDc - Name of DC from which to select sources for streaming or null to pick any node
        keyspace - 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]"
        specificSources - list of sources that can be used for rebuilding. Must be other nodes in the cluster. The format of the string is comma separated values.
      • rebuild

        void rebuild​(java.lang.String sourceDc,
                     java.lang.String keyspace,
                     java.lang.String tokens,
                     java.lang.String specificSources,
                     boolean excludeLocalDatacenterNodes)
        Same as rebuild(String), but only for specified keyspace and ranges. It excludes local data center nodes
        Parameters:
        sourceDc - Name of DC from which to select sources for streaming or null to pick any node
        keyspace - 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]"
        specificSources - list of sources that can be used for rebuilding. Mostly other nodes in the cluster.
        excludeLocalDatacenterNodes - Flag to indicate whether local data center nodes should be excluded as sources for streaming.
      • bulkLoad

        void bulkLoad​(java.lang.String directory)
        Starts a bulk load and blocks until it completes.
      • bulkLoadAsync

        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.
      • rescheduleFailedDeletions

        void rescheduleFailedDeletions()
      • loadNewSSTables

        @Deprecated(since="4.0")
        void loadNewSSTables​(java.lang.String ksName,
                             java.lang.String tableName)
        Deprecated.
        See CASSANDRA-14417
        Load new SSTables to the given keyspace/table
        Parameters:
        ksName - The parent keyspace name
        tableName - The ColumnFamily name where SSTables belong
        See Also:
        ColumnFamilyStoreMBean.loadNewSSTables()
      • sampleKeyRange

        java.util.List<java.lang.String> sampleKeyRange()
        Return a List of Tokens representing a sample of keys across all ColumnFamilyStores. Note: this should be left as an operation, not an attribute (methods starting with "get") to avoid sending potentially multiple MB of data when accessing this mbean by default. See CASSANDRA-4452.
        Returns:
        set of Tokens as Strings
      • rebuildSecondaryIndex

        void rebuildSecondaryIndex​(java.lang.String ksName,
                                   java.lang.String cfName,
                                   java.lang.String... idxNames)
        rebuild the specified indexes
      • resetLocalSchema

        void resetLocalSchema()
                       throws java.io.IOException
        Throws:
        java.io.IOException
      • reloadLocalSchema

        void reloadLocalSchema()
      • setTraceProbability

        void setTraceProbability​(double probability)
        Enables/Disables tracing for the whole system.
        Parameters:
        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)
      • samplePartitions

        java.util.Map<java.lang.String,​java.util.List<javax.management.openmbean.CompositeData>> samplePartitions​(int duration,
                                                                                                                        int capacity,
                                                                                                                        int count,
                                                                                                                        java.util.List<java.lang.String> samplers)
                                                                                                                 throws javax.management.openmbean.OpenDataException
        Throws:
        javax.management.openmbean.OpenDataException
      • samplePartitions

        java.util.Map<java.lang.String,​java.util.List<javax.management.openmbean.CompositeData>> samplePartitions​(java.lang.String keyspace,
                                                                                                                        int duration,
                                                                                                                        int capacity,
                                                                                                                        int count,
                                                                                                                        java.util.List<java.lang.String> samplers)
                                                                                                                 throws javax.management.openmbean.OpenDataException
        Throws:
        javax.management.openmbean.OpenDataException
      • startSamplingPartitions

        boolean startSamplingPartitions​(java.lang.String ks,
                                        java.lang.String table,
                                        int duration,
                                        int interval,
                                        int capacity,
                                        int count,
                                        java.util.List<java.lang.String> samplers)
                                 throws javax.management.openmbean.OpenDataException
        Start a scheduled sampling
        Parameters:
        ks - Keyspace. Nullable. If null, the scheduled sampling is on all keyspaces and tables
        table - Nullable. If null, the scheduled sampling is on all tables of the specified keyspace
        duration - Duration of each scheduled sampling job in milliseconds
        interval - Interval of each scheduled sampling job in milliseconds
        capacity - Capacity of the sampler, higher for more accuracy
        count - Number of the top samples to list
        samplers - a list of samplers to enable
        Returns:
        true if the scheduled sampling is started successfully. Otherwise return false
        Throws:
        javax.management.openmbean.OpenDataException
      • stopSamplingPartitions

        boolean stopSamplingPartitions​(java.lang.String ks,
                                       java.lang.String table)
                                throws javax.management.openmbean.OpenDataException
        Stop a scheduled sampling
        Parameters:
        ks - Keyspace. Nullable. If null, the scheduled sampling is on all keysapces and tables
        table - Nullable. If null, the scheduled sampling is on all tables of the specified keyspace
        Returns:
        true if the scheduled sampling is stopped. False is returned if the sampling task is not found
        Throws:
        javax.management.openmbean.OpenDataException
      • getSampleTasks

        java.util.List<java.lang.String> getSampleTasks()
        Returns:
        a list of qualified table names that have active scheduled sampling tasks. The format of the name is `KEYSPACE.TABLE` The wild card symbol (*) indicates all keyspace/table. For example, "*.*" indicates all tables in all keyspaces. "foo.*" indicates all tables under keyspace 'foo'. "foo.bar" indicates the scheduled sampling is enabled for the table 'bar'
      • getTraceProbability

        double getTraceProbability()
        Returns the configured tracing probability.
      • disableAutoCompaction

        void disableAutoCompaction​(java.lang.String ks,
                                   java.lang.String... tables)
                            throws java.io.IOException
        Throws:
        java.io.IOException
      • enableAutoCompaction

        void enableAutoCompaction​(java.lang.String ks,
                                  java.lang.String... tables)
                           throws java.io.IOException
        Throws:
        java.io.IOException
      • getAutoCompactionStatus

        java.util.Map<java.lang.String,​java.lang.Boolean> getAutoCompactionStatus​(java.lang.String ks,
                                                                                        java.lang.String... tables)
                                                                                 throws java.io.IOException
        Throws:
        java.io.IOException
      • deliverHints

        void deliverHints​(java.lang.String host)
                   throws java.net.UnknownHostException
        Throws:
        java.net.UnknownHostException
      • getClusterName

        java.lang.String getClusterName()
        Returns the name of the cluster
      • getPartitionerName

        java.lang.String getPartitionerName()
        Returns the cluster partitioner
      • getTombstoneWarnThreshold

        int getTombstoneWarnThreshold()
        Returns the threshold for warning of queries with many tombstones
      • setTombstoneWarnThreshold

        void setTombstoneWarnThreshold​(int tombstoneDebugThreshold)
        Sets the threshold for warning queries with many tombstones
      • getTombstoneFailureThreshold

        int getTombstoneFailureThreshold()
        Returns the threshold for abandoning queries with many tombstones
      • setTombstoneFailureThreshold

        void setTombstoneFailureThreshold​(int tombstoneDebugThreshold)
        Sets the threshold for abandoning queries with many tombstones
      • getCachedReplicaRowsWarnThreshold

        int getCachedReplicaRowsWarnThreshold()
        Returns the number of rows cached at the coordinator before filtering/index queries log a warning.
      • setCachedReplicaRowsWarnThreshold

        void setCachedReplicaRowsWarnThreshold​(int threshold)
        Sets the number of rows cached at the coordinator before filtering/index queries log a warning.
      • getCachedReplicaRowsFailThreshold

        int getCachedReplicaRowsFailThreshold()
        Returns the number of rows cached at the coordinator before filtering/index queries fail outright.
      • setCachedReplicaRowsFailThreshold

        void setCachedReplicaRowsFailThreshold​(int threshold)
        Sets the number of rows cached at the coordinator before filtering/index queries fail outright.
      • getColumnIndexSizeInKiB

        int getColumnIndexSizeInKiB()
        Returns the granularity of the collation index of rows within a partition. -1 stands for the SSTable format's default.
      • setColumnIndexSizeInKiB

        void setColumnIndexSizeInKiB​(int columnIndexSizeInKiB)
        Sets the granularity of the collation index of rows within a partition. Use -1 to select the SSTable format's default.
      • setColumnIndexSize

        @Deprecated(since="5.0")
        void setColumnIndexSize​(int columnIndexSizeInKB)
        Deprecated.
        use setColumnIndexSizeInKiB instead as it will not throw non-standard exceptions. See CASSANDRA-17668
        Sets the granularity of the collation index of rows within a partition
      • getColumnIndexCacheSize

        @Deprecated(since="5.0")
        int getColumnIndexCacheSize()
        Deprecated.
        use getColumnIndexCacheSizeInKiB. See CASSANDRA-17668
        Returns the threshold for skipping the column index when caching partition info
      • setColumnIndexCacheSize

        @Deprecated(since="5.0")
        void setColumnIndexCacheSize​(int cacheSizeInKB)
        Deprecated.
        use setColumnIndexCacheSizeInKiB instead as it will not throw non-standard exceptions. See CASSANDRA-17668
        Sets the threshold for skipping the column index when caching partition info
      • getColumnIndexCacheSizeInKiB

        int getColumnIndexCacheSizeInKiB()
        Returns the threshold for skipping the column index when caching partition info
      • setColumnIndexCacheSizeInKiB

        void setColumnIndexCacheSizeInKiB​(int cacheSizeInKiB)
        Sets the threshold for skipping the column index when caching partition info
      • getBatchSizeFailureThreshold

        int getBatchSizeFailureThreshold()
        Returns the threshold for rejecting queries due to a large batch size
      • setBatchSizeFailureThreshold

        void setBatchSizeFailureThreshold​(int batchSizeDebugThreshold)
        Sets the threshold for rejecting queries due to a large batch size
      • getBatchSizeWarnThreshold

        @Deprecated(since="5.0")
        int getBatchSizeWarnThreshold()
        Deprecated.
        use getBatchSizeWarnThresholdInKiB instead. See CASSANDRA-17668
        Returns the threshold for warning queries due to a large batch size
      • setBatchSizeWarnThreshold

        @Deprecated(since="5.0")
        void setBatchSizeWarnThreshold​(int batchSizeDebugThreshold)
        Deprecated.
        use setBatchSizeWarnThresholdInKiB instead as it will not throw non-standard exceptions. See CASSANDRA-17668
        Sets the threshold for warning queries due to a large batch size
      • getBatchSizeWarnThresholdInKiB

        int getBatchSizeWarnThresholdInKiB()
        Returns the threshold for warning queries due to a large batch size
      • setBatchSizeWarnThresholdInKiB

        void setBatchSizeWarnThresholdInKiB​(int batchSizeDebugThreshold)
        Sets the threshold for warning queries due to a large batch size
      • setHintedHandoffThrottleInKB

        void setHintedHandoffThrottleInKB​(int throttleInKB)
        Sets the hinted handoff throttle in KiB per second, per delivery thread.
      • getTransferHintsOnDecommission

        boolean getTransferHintsOnDecommission()
      • setTransferHintsOnDecommission

        void setTransferHintsOnDecommission​(boolean enabled)
      • resumeBootstrap

        boolean resumeBootstrap()
        Resume bootstrap streaming when there is failed data streaming.
        Returns:
        true if the node successfully starts resuming. (this does not mean bootstrap streaming was success.)
      • getBootstrapState

        java.lang.String getBootstrapState()
      • getConcurrency

        java.util.Map<java.lang.String,​java.util.List<java.lang.Integer>> getConcurrency​(java.util.List<java.lang.String> stageNames)
      • setConcurrency

        void setConcurrency​(java.lang.String threadPoolName,
                            int newCorePoolSize,
                            int newMaximumPoolSize)
        Sets the concurrency setting for processing stages
      • clearConnectionHistory

        void clearConnectionHistory()
        Clears the history of clients that have connected in the past
      • disableAuditLog

        void disableAuditLog()
      • enableAuditLog

        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)
                     throws java.lang.IllegalStateException
        Throws:
        java.lang.IllegalStateException
      • enableAuditLog

        @Deprecated(since="4.1")
        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
        Deprecated.
        See CASSANDRA-16725
        Throws:
        ConfigurationException
        java.lang.IllegalStateException
      • enableAuditLog

        @Deprecated(since="4.1")
        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
        Deprecated.
        See CASSANDRA-16725
        Throws:
        ConfigurationException
        java.lang.IllegalStateException
      • enableAuditLog

        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,
                            java.lang.Integer maxArchiveRetries,
                            java.lang.Boolean block,
                            java.lang.String rollCycle,
                            java.lang.Long maxLogSize,
                            java.lang.Integer maxQueueWeight,
                            java.lang.String archiveCommand)
                     throws java.lang.IllegalStateException
        Throws:
        java.lang.IllegalStateException
      • isAuditLogEnabled

        boolean isAuditLogEnabled()
      • getCorruptedTombstoneStrategy

        java.lang.String getCorruptedTombstoneStrategy()
      • setCorruptedTombstoneStrategy

        void setCorruptedTombstoneStrategy​(java.lang.String strategy)
      • enableFullQueryLogger

        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)
        Start the fully query logger.
        Parameters:
        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 log
        maxQueueWeight - How many bytes of query data to queue before blocking or dropping samples
        maxLogSize - 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 command
      • resetFullQueryLogger

        void resetFullQueryLogger()
        Disable the full query logger if it is enabled. Also delete any generated files in the last used full query log path as well as the one configure in cassandra.yaml
      • stopFullQueryLogger

        void stopFullQueryLogger()
        Stop logging queries but leave any generated files on disk.
      • isFullQueryLogEnabled

        boolean isFullQueryLogEnabled()
      • getFullQueryLoggerOptions

        javax.management.openmbean.CompositeData getFullQueryLoggerOptions()
        Returns the current state of FQL.
      • setInitialRangeTombstoneListAllocationSize

        void setInitialRangeTombstoneListAllocationSize​(int size)
        Sets the initial allocation size of backing arrays for new RangeTombstoneList objects
      • getInitialRangeTombstoneListAllocationSize

        int getInitialRangeTombstoneListAllocationSize()
        Returns the initial allocation size of backing arrays for new RangeTombstoneList objects
      • setRangeTombstoneListResizeGrowthFactor

        void setRangeTombstoneListResizeGrowthFactor​(double growthFactor)
        Sets the resize factor to use when growing/resizing a RangeTombstoneList
      • getRangeTombstoneResizeListGrowthFactor

        double getRangeTombstoneResizeListGrowthFactor()
        Returns the resize factor to use when growing/resizing a RangeTombstoneList
      • getOutstandingSchemaVersions

        @Deprecated(since="4.0")
        java.util.Map<java.lang.String,​java.util.Set<java.net.InetAddress>> getOutstandingSchemaVersions()
        Deprecated.
        See CASSANDRA-17668
        Returns a map of schema version -> list of endpoints reporting that version that we need schema updates for
      • getOutstandingSchemaVersionsWithPort

        java.util.Map<java.lang.String,​java.util.Set<java.lang.String>> getOutstandingSchemaVersionsWithPort()
      • autoOptimiseIncRepairStreams

        boolean autoOptimiseIncRepairStreams()
      • setAutoOptimiseIncRepairStreams

        void setAutoOptimiseIncRepairStreams​(boolean enabled)
      • autoOptimiseFullRepairStreams

        boolean autoOptimiseFullRepairStreams()
      • setAutoOptimiseFullRepairStreams

        void setAutoOptimiseFullRepairStreams​(boolean enabled)
      • autoOptimisePreviewRepairStreams

        boolean autoOptimisePreviewRepairStreams()
      • setAutoOptimisePreviewRepairStreams

        void setAutoOptimisePreviewRepairStreams​(boolean enabled)
      • getTableCountWarnThreshold

        @Deprecated(since="4.1")
        int getTableCountWarnThreshold()
        Deprecated.
        See CASSANDRA-17195
      • setTableCountWarnThreshold

        @Deprecated(since="4.1")
        void setTableCountWarnThreshold​(int value)
        Deprecated.
        See CASSANDRA-17195
      • getKeyspaceCountWarnThreshold

        @Deprecated(since="4.1")
        int getKeyspaceCountWarnThreshold()
        Deprecated.
        See CASSANDRA-17195
      • setKeyspaceCountWarnThreshold

        @Deprecated(since="4.1")
        void setKeyspaceCountWarnThreshold​(int value)
        Deprecated.
        See CASSANDRA-17195
      • setCompactionTombstoneWarningThreshold

        @Deprecated(since="5.0")
        void setCompactionTombstoneWarningThreshold​(int count)
        Deprecated.
        See CASSANDRA-17194
      • getCompactionTombstoneWarningThreshold

        @Deprecated(since="5.0")
        int getCompactionTombstoneWarningThreshold()
        Deprecated.
        See CASSANDRA-17194
      • getReadThresholdsEnabled

        boolean getReadThresholdsEnabled()
      • setReadThresholdsEnabled

        void setReadThresholdsEnabled​(boolean value)
      • getCoordinatorLargeReadWarnThreshold

        java.lang.String getCoordinatorLargeReadWarnThreshold()
      • setCoordinatorLargeReadWarnThreshold

        void setCoordinatorLargeReadWarnThreshold​(java.lang.String threshold)
      • getCoordinatorLargeReadAbortThreshold

        java.lang.String getCoordinatorLargeReadAbortThreshold()
      • setCoordinatorLargeReadAbortThreshold

        void setCoordinatorLargeReadAbortThreshold​(java.lang.String threshold)
      • getLocalReadTooLargeWarnThreshold

        java.lang.String getLocalReadTooLargeWarnThreshold()
      • setLocalReadTooLargeWarnThreshold

        void setLocalReadTooLargeWarnThreshold​(java.lang.String value)
      • getLocalReadTooLargeAbortThreshold

        java.lang.String getLocalReadTooLargeAbortThreshold()
      • setLocalReadTooLargeAbortThreshold

        void setLocalReadTooLargeAbortThreshold​(java.lang.String value)
      • getRowIndexReadSizeWarnThreshold

        java.lang.String getRowIndexReadSizeWarnThreshold()
      • setRowIndexReadSizeWarnThreshold

        void setRowIndexReadSizeWarnThreshold​(java.lang.String value)
      • getRowIndexReadSizeAbortThreshold

        java.lang.String getRowIndexReadSizeAbortThreshold()
      • setRowIndexReadSizeAbortThreshold

        void setRowIndexReadSizeAbortThreshold​(java.lang.String value)
      • setDefaultKeyspaceReplicationFactor

        void setDefaultKeyspaceReplicationFactor​(int value)
      • getDefaultKeyspaceReplicationFactor

        int getDefaultKeyspaceReplicationFactor()
      • getSkipPaxosRepairOnTopologyChange

        boolean getSkipPaxosRepairOnTopologyChange()
      • setSkipPaxosRepairOnTopologyChange

        void setSkipPaxosRepairOnTopologyChange​(boolean v)
      • getSkipPaxosRepairOnTopologyChangeKeyspaces

        java.lang.String getSkipPaxosRepairOnTopologyChangeKeyspaces()
      • setSkipPaxosRepairOnTopologyChangeKeyspaces

        void setSkipPaxosRepairOnTopologyChangeKeyspaces​(java.lang.String v)
      • getPaxosAutoRepairsEnabled

        boolean getPaxosAutoRepairsEnabled()
      • setPaxosAutoRepairsEnabled

        void setPaxosAutoRepairsEnabled​(boolean enabled)
      • getPaxosStateFlushEnabled

        boolean getPaxosStateFlushEnabled()
      • setPaxosStateFlushEnabled

        void setPaxosStateFlushEnabled​(boolean enabled)
      • getPaxosAutoRepairTables

        java.util.List<java.lang.String> getPaxosAutoRepairTables()
      • getPaxosPurgeGraceSeconds

        long getPaxosPurgeGraceSeconds()
      • setPaxosPurgeGraceSeconds

        void setPaxosPurgeGraceSeconds​(long v)
      • getPaxosOnLinearizabilityViolations

        java.lang.String getPaxosOnLinearizabilityViolations()
      • setPaxosOnLinearizabilityViolations

        void setPaxosOnLinearizabilityViolations​(java.lang.String v)
      • getPaxosStatePurging

        java.lang.String getPaxosStatePurging()
      • setPaxosStatePurging

        void setPaxosStatePurging​(java.lang.String v)
      • getPaxosRepairEnabled

        boolean getPaxosRepairEnabled()
      • setPaxosRepairEnabled

        void setPaxosRepairEnabled​(boolean v)
      • getPaxosDcLocalCommitEnabled

        boolean getPaxosDcLocalCommitEnabled()
      • setPaxosDcLocalCommitEnabled

        void setPaxosDcLocalCommitEnabled​(boolean v)
      • getPaxosBallotLowBound

        java.lang.String getPaxosBallotLowBound​(java.lang.String keyspace,
                                                java.lang.String table,
                                                java.lang.String key)
      • getRepairRpcTimeout

        java.lang.Long getRepairRpcTimeout()
      • setRepairRpcTimeout

        void setRepairRpcTimeout​(java.lang.Long timeoutInMillis)
      • evictHungRepairs

        void evictHungRepairs()
      • clearPaxosRepairs

        void clearPaxosRepairs()
      • setSkipPaxosRepairCompatibilityCheck

        void setSkipPaxosRepairCompatibilityCheck​(boolean v)
      • getSkipPaxosRepairCompatibilityCheck

        boolean getSkipPaxosRepairCompatibilityCheck()
      • getToken

        java.lang.String getToken​(java.lang.String keyspaceName,
                                  java.lang.String table,
                                  java.lang.String partitionKey)
      • topPartitionsEnabled

        boolean topPartitionsEnabled()
      • getMaxTopSizePartitionCount

        int getMaxTopSizePartitionCount()
      • setMaxTopSizePartitionCount

        void setMaxTopSizePartitionCount​(int value)
      • getMaxTopTombstonePartitionCount

        int getMaxTopTombstonePartitionCount()
      • setMaxTopTombstonePartitionCount

        void setMaxTopTombstonePartitionCount​(int value)
      • getMinTrackedPartitionSize

        java.lang.String getMinTrackedPartitionSize()
      • setMinTrackedPartitionSize

        void setMinTrackedPartitionSize​(java.lang.String value)
      • getMinTrackedPartitionTombstoneCount

        long getMinTrackedPartitionTombstoneCount()
      • setMinTrackedPartitionTombstoneCount

        void setMinTrackedPartitionTombstoneCount​(long value)
      • setSkipStreamDiskSpaceCheck

        void setSkipStreamDiskSpaceCheck​(boolean value)
      • getSkipStreamDiskSpaceCheck

        boolean getSkipStreamDiskSpaceCheck()
      • getNativeTransportQueueMaxItemAgeThreshold

        double getNativeTransportQueueMaxItemAgeThreshold()
      • setNativeTransportQueueMaxItemAgeThreshold

        void setNativeTransportQueueMaxItemAgeThreshold​(double threshold)
      • getNativeTransportMinBackoffOnQueueOverloadInMillis

        long getNativeTransportMinBackoffOnQueueOverloadInMillis()
      • getNativeTransportMaxBackoffOnQueueOverloadInMillis

        long getNativeTransportMaxBackoffOnQueueOverloadInMillis()
      • setNativeTransportBackoffOnQueueOverloadInMillis

        void setNativeTransportBackoffOnQueueOverloadInMillis​(long min,
                                                              long max)
      • getNativeTransportThrowOnOverload

        boolean getNativeTransportThrowOnOverload()
      • setNativeTransportThrowOnOverload

        void setNativeTransportThrowOnOverload​(boolean throwOnOverload)
      • getNativeTransportTimeoutMillis

        long getNativeTransportTimeoutMillis()
      • setNativeTransportTimeoutMillis

        void setNativeTransportTimeoutMillis​(long deadlineMillis)
      • getEnforceNativeDeadlineForHints

        boolean getEnforceNativeDeadlineForHints()
      • setEnforceNativeDeadlineForHints

        void setEnforceNativeDeadlineForHints​(boolean value)
      • isOutOfTokenRangeRequestLoggingEnabled

        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.
      • setOutOfTokenRangeRequestLoggingEnabled

        void setOutOfTokenRangeRequestLoggingEnabled​(boolean enabled)
      • isOutOfTokenRangeRequestRejectionEnabled

        boolean isOutOfTokenRangeRequestRejectionEnabled()
      • setOutOfTokenRangeRequestRejectionEnabled

        void setOutOfTokenRangeRequestRejectionEnabled​(boolean enabled)
      • getOutOfRangeOperationCounts

        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. Represented as a 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].