Interface ColumnFamilyStoreMBean

  • All Known Implementing Classes:
    ColumnFamilyStore

    public interface ColumnFamilyStoreMBean
    The MBean interface for ColumnFamilyStore
    • Method Detail

      • getColumnFamilyName

        @Deprecated(since="3.0")
        java.lang.String getColumnFamilyName()
        Deprecated.
        See CASSANDRA-9448
      • getTableName

        java.lang.String getTableName()
      • forceMajorCompaction

        void forceMajorCompaction​(boolean splitOutput)
                           throws java.util.concurrent.ExecutionException,
                                  java.lang.InterruptedException
        force a major compaction of this column family
        Parameters:
        splitOutput - true if the output of the major compaction should be split in several sstables
        Throws:
        java.util.concurrent.ExecutionException
        java.lang.InterruptedException
      • forceCompactionForTokenRange

        @Deprecated(since="4.1")
        void forceCompactionForTokenRange​(java.util.Collection<Range<Token>> tokenRanges)
                                   throws java.util.concurrent.ExecutionException,
                                          java.lang.InterruptedException
        Deprecated.
        See CASSANDRA-17527
        Forces a major compaction of specified token ranges in this column family.

        The token ranges will be interpreted as closed intervals to match the closed interval defined by the first and last keys of a sstable, even though the Range class is suppossed to be half-open by definition.

        Parameters:
        tokenRanges - The token ranges to be compacted, interpreted as closed intervals.
        Throws:
        java.util.concurrent.ExecutionException
        java.lang.InterruptedException
      • forceCompactionForTokenRanges

        void forceCompactionForTokenRanges​(java.lang.String... tokenRanges)
        Forces a major compaction of specified token ranges in this column family.

        The token ranges will be interpreted as closed intervals to match the closed interval defined by the first and last keys of a sstable, even though the Range class is suppossed to be half-open by definition.

      • getMinimumCompactionThreshold

        int getMinimumCompactionThreshold()
        Gets the minimum number of sstables in queue before compaction kicks off
      • setMinimumCompactionThreshold

        void setMinimumCompactionThreshold​(int threshold)
        Sets the minimum number of sstables in queue before compaction kicks off
      • getMaximumCompactionThreshold

        int getMaximumCompactionThreshold()
        Gets the maximum number of sstables in queue before compaction kicks off
      • setCompactionThresholds

        void setCompactionThresholds​(int minThreshold,
                                     int maxThreshold)
        Sets the maximum and maximum number of SSTables in queue before compaction kicks off
      • setMaximumCompactionThreshold

        void setMaximumCompactionThreshold​(int threshold)
        Sets the maximum number of sstables in queue before compaction kicks off
      • setCompactionParametersJson

        void setCompactionParametersJson​(java.lang.String options)
        Sets the compaction parameters locally for this node Note that this will be set until an ALTER with compaction = {..} is executed or the node is restarted
        Parameters:
        options - compaction options with the same syntax as when doing ALTER ... WITH compaction = {..}
      • getCompactionParametersJson

        java.lang.String getCompactionParametersJson()
      • setCompactionParameters

        void setCompactionParameters​(java.util.Map<java.lang.String,​java.lang.String> options)
        Sets the compaction parameters locally for this node Note that this will be set until an ALTER with compaction = {..} is executed or the node is restarted
        Parameters:
        options - compaction options map
      • getCompactionParameters

        java.util.Map<java.lang.String,​java.lang.String> getCompactionParameters()
      • getCompressionParameters

        java.util.Map<java.lang.String,​java.lang.String> getCompressionParameters()
        Get the compression parameters
      • getCompressionParametersJson

        java.lang.String getCompressionParametersJson()
      • setCompressionParameters

        void setCompressionParameters​(java.util.Map<java.lang.String,​java.lang.String> opts)
        Set the compression parameters locally for this node
        Parameters:
        opts - map of string names to values
      • setCompressionParametersJson

        void setCompressionParametersJson​(java.lang.String options)
      • setCrcCheckChance

        void setCrcCheckChance​(double crcCheckChance)
        Set new crc check chance
      • isAutoCompactionDisabled

        boolean isAutoCompactionDisabled()
      • estimateKeys

        long estimateKeys()
      • getBuiltIndexes

        java.util.List<java.lang.String> getBuiltIndexes()
        Returns a list of the names of the built column indexes for current store
        Returns:
        list of the index names
      • getSSTablesForKey

        java.util.List<java.lang.String> getSSTablesForKey​(java.lang.String key)
        Returns a list of filenames that contain the given key on this node
        Parameters:
        key -
        Returns:
        list of filenames containing the key
      • getSSTablesForKey

        java.util.List<java.lang.String> getSSTablesForKey​(java.lang.String key,
                                                           boolean hexFormat)
        Returns a list of filenames that contain the given key on this node
        Parameters:
        key -
        hexFormat - if key is in hex string format
        Returns:
        list of filenames containing the key
      • getSSTablesForKeyWithLevel

        java.util.Map<java.lang.Integer,​java.util.Set<java.lang.String>> getSSTablesForKeyWithLevel​(java.lang.String key,
                                                                                                          boolean hexFormat)
        Returns a list of filenames that contain the given key and which level they belong to. Requires table to be compacted with LeveledCompactionStrategy
        Parameters:
        key -
        hexFormat -
        Returns:
        list of filenames and levels containing the key
      • importNewSSTables

        @Deprecated(since="4.0")
        java.util.List<java.lang.String> importNewSSTables​(java.util.Set<java.lang.String> srcPaths,
                                                           boolean resetLevel,
                                                           boolean clearRepaired,
                                                           boolean verifySSTables,
                                                           boolean verifyTokens,
                                                           boolean invalidateCaches,
                                                           boolean extendedVerify)
        Deprecated.
        See CASSANDRA-16407
      • importNewSSTables

        @Deprecated(since="5.0")
        java.util.List<java.lang.String> importNewSSTables​(java.util.Set<java.lang.String> srcPaths,
                                                           boolean resetLevel,
                                                           boolean clearRepaired,
                                                           boolean verifySSTables,
                                                           boolean verifyTokens,
                                                           boolean invalidateCaches,
                                                           boolean extendedVerify,
                                                           boolean copyData)
        Deprecated.
        See CASSANDRA-18714
      • importNewSSTables

        java.util.List<java.lang.String> importNewSSTables​(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)
        Load new sstables from the given directory
        Parameters:
        srcPaths - the path to the new sstables - if it is an empty set, the data directories will be scanned
        resetLevel - if the level should be reset to 0 on the new sstables
        clearRepaired - if repaired info should be wiped from the new sstables
        verifySSTables - if the new sstables should be verified that they are not corrupt
        verifyTokens - if the tokens in the new sstables should be verified that they are owned by the current node
        invalidateCaches - if row cache should be invalidated for the keys in the new sstables
        extendedVerify - if we should run an extended verify checking all values in the new sstables
        copyData - if we should copy data from source paths instead of moving them
        validateIndexChecksum - if we should also validate checksum for SAI indexes
        failOnMissingIndex - if loading should fail when SSTables do not contain built SAI indexes too
        Returns:
        list of failed import directories
      • loadNewSSTables

        @Deprecated(since="4.0")
        void loadNewSSTables()
        Deprecated.
        See CASSANDRA-6719
      • getUnleveledSSTables

        int getUnleveledSSTables()
        Returns:
        the number of SSTables in L0. Always return 0 if Leveled compaction is not enabled.
      • getSSTableCountPerLevel

        int[] getSSTableCountPerLevel()
        Returns:
        sstable count for each level. null unless leveled compaction is used. array index corresponds to level(int[0] is for level 0, ...).
      • getPerLevelSizeBytes

        long[] getPerLevelSizeBytes()
        Returns:
        total size on disk for each level. null unless leveled compaction is used. array index corresponds to level(int[0] is for level 0, ...).
      • isLeveledCompaction

        boolean isLeveledCompaction()
        Returns:
        true if the table is using LeveledCompactionStrategy. false otherwise.
      • getSSTableCountPerTWCSBucket

        int[] getSSTableCountPerTWCSBucket()
        Returns:
        sstable count for each bucket in TWCS. null unless time window compaction is used. array index corresponds to bucket(int[0] is for most recent, ...).
      • getLevelFanoutSize

        int getLevelFanoutSize()
        Returns:
        sstable fanout size for level compaction strategy.
      • getDroppableTombstoneRatio

        double getDroppableTombstoneRatio()
        Get the ratio of droppable tombstones to real columns (and non-droppable tombstones)
        Returns:
        ratio
      • trueSnapshotsSize

        long trueSnapshotsSize()
        Returns:
        the size of SSTables in "snapshots" subdirectory which aren't live anymore
      • beginLocalSampling

        void beginLocalSampling​(java.lang.String sampler,
                                int capacity,
                                int durationMillis)
        begin sampling for a specific sampler with a given capacity. The cardinality may be larger than the capacity, but depending on the use case it may affect its accuracy
      • finishLocalSampling

        java.util.List<javax.management.openmbean.CompositeData> finishLocalSampling​(java.lang.String sampler,
                                                                                     int count)
                                                                              throws javax.management.openmbean.OpenDataException
        Returns:
        top count items for the sampler since beginLocalSampling was called
        Throws:
        javax.management.openmbean.OpenDataException
      • isCompactionDiskSpaceCheckEnabled

        boolean isCompactionDiskSpaceCheckEnabled()
      • compactionDiskSpaceCheck

        void compactionDiskSpaceCheck​(boolean enable)
      • setNeverPurgeTombstones

        void setNeverPurgeTombstones​(boolean value)
      • getNeverPurgeTombstones

        boolean getNeverPurgeTombstones()
      • hasMisplacedSSTables

        boolean hasMisplacedSSTables()
        Check SSTables whether or not they are misplaced.
        Returns:
        true if any of the SSTables is misplaced. If all SSTables are correctly placed or the partitioner does not support splitting, it returns false.
      • getDataPaths

        java.util.List<java.lang.String> getDataPaths()
                                               throws java.io.IOException
        Throws:
        java.io.IOException
      • getTopSizePartitions

        java.util.Map<java.lang.String,​java.lang.Long> getTopSizePartitions()
      • getTopSizePartitionsLastUpdate

        java.lang.Long getTopSizePartitionsLastUpdate()
      • getTopTombstonePartitions

        java.util.Map<java.lang.String,​java.lang.Long> getTopTombstonePartitions()
      • getTopTombstonePartitionsLastUpdate

        java.lang.Long getTopTombstonePartitionsLastUpdate()
      • getMaxSSTableSize

        long getMaxSSTableSize()
        Returns the size of the biggest SSTable of this table.
        Returns:
        (physical) size of the biggest SSTable of this table on disk or 0 if no SSTable is present
      • getMaxSSTableDuration

        long getMaxSSTableDuration()
        Returns the longest duration of an SSTable, in milliseconds, of this table, computed as maxTimestamp - minTimestamp. It returns 0 if there are no SSTables or if maxTimestamp or minTimestamp is equal to Long.MAX_VALUE. Effectively non-zero for tables on TimeWindowCompactionStrategy.
        Returns:
        the biggest maxTimestamp - minTimestamp among all SSTables of this table or 0 if no SSTable is present