public class ColumnFamilyStore extends java.lang.Object implements ColumnFamilyStoreMBean
| Modifier and Type | Class and Description | 
|---|---|
| static class  | ColumnFamilyStore.AbstractScanIterator | 
| static class  | ColumnFamilyStore.ViewFragment | 
| Modifier and Type | Field and Description | 
|---|---|
| Directories | directories | 
| SecondaryIndexManager | indexManager | 
| java.util.concurrent.ConcurrentMap<java.nio.ByteBuffer,java.nio.ByteBuffer> | internedNames | 
| Keyspace | keyspace | 
| CFMetaData | metadata | 
| ColumnFamilyMetrics | metric | 
| java.lang.String | name | 
| IPartitioner | partitioner | 
| static java.util.concurrent.ExecutorService | postFlushExecutor | 
| long | sampleLatencyNanos | 
| Modifier and Type | Method and Description | 
|---|---|
| void | addSSTable(SSTableReader sstable) | 
| void | addSSTables(java.util.Collection<SSTableReader> sstables) | 
| static java.lang.Iterable<ColumnFamilyStore> | all() | 
| void | apply(DecoratedKey key,
     ColumnFamily columnFamily,
     SecondaryIndexManager.Updater indexer)Insert/Update the column family for this key. | 
| void | cleanupCache() | 
| void | clearSnapshot(java.lang.String snapshotName)Clear all the snapshots for a given column family. | 
| void | clearUnsafe()For testing. | 
| java.lang.Iterable<ColumnFamilyStore> | concatWithIndexes() | 
| boolean | containsCachedRow(DecoratedKey key) | 
| static ColumnFamilyStore | createColumnFamilyStore(Keyspace keyspace,
                       java.lang.String columnFamily,
                       boolean loadSSTables) | 
| static ColumnFamilyStore | createColumnFamilyStore(Keyspace keyspace,
                       java.lang.String columnFamily,
                       IPartitioner partitioner,
                       CFMetaData metadata) | 
| void | disableAutoCompaction() | 
| ReplayPosition | discardSSTables(long truncatedAt)Discard all SSTables that were created before given timestamp. | 
| void | enableAutoCompaction() | 
| void | enableAutoCompaction(boolean waitForFutures)used for tests - to be able to check things after a minor compaction | 
| long | estimateKeys() | 
| java.util.List<Row> | filter(ColumnFamilyStore.AbstractScanIterator rowIterator,
      ExtendedFilter filter) | 
| void | forceBlockingFlush() | 
| void | forceCleanup(CounterId.OneShotRenewer renewer) | 
| java.util.concurrent.Future<?> | forceFlush() | 
| void | forceMajorCompaction()force a major compaction of this column family | 
| int | gcBefore(long now) | 
| long | getAllMemtablesLiveSize() | 
| java.util.Set<SSTableReader> | getAndReferenceOverlappingSSTables(java.util.Collection<SSTableReader> sstables)like getOverlappingSSTables, but acquires references before returning | 
| long | getBloomFilterDiskSpaceUsed() | 
| long | getBloomFilterFalsePositives() | 
| double | getBloomFilterFalseRatio() | 
| long | getBloomFilterOffHeapMemoryUsed() | 
| java.util.List<java.lang.String> | getBuiltIndexes()Returns a list of the names of the built column indexes for current store | 
| ColumnFamily | getColumnFamily(DecoratedKey key,
               java.nio.ByteBuffer start,
               java.nio.ByteBuffer finish,
               boolean reversed,
               int limit,
               long timestamp) | 
| ColumnFamily | getColumnFamily(QueryFilter filter)get a list of columns starting from a given column, in a specified order. | 
| java.lang.String | getColumnFamilyName() | 
| AbstractCompactionStrategy | getCompactionStrategy() | 
| java.lang.String | getCompactionStrategyClass()Gets the compaction strategy class name | 
| AbstractType<?> | getComparator() | 
| long | getCompressionMetadataOffHeapMemoryUsed() | 
| java.util.Map<java.lang.String,java.lang.String> | getCompressionParameters()Get the compression parameters | 
| double | getCompressionRatio() | 
| DataTracker | getDataTracker()Package protected for access from the CompactionManager. | 
| double | getDroppableTombstoneRatio()Get the ratio of droppable tombstones to real columns (and non-droppable tombstones) | 
| long[] | getEstimatedColumnCountHistogram() | 
| long[] | getEstimatedRowSizeHistogram() | 
| long | getExpectedCompactedFileSize(java.lang.Iterable<SSTableReader> sstables,
                            OperationType operation)Calculate expected file size of SSTable after compaction. | 
| long | getIndexSummaryOffHeapMemoryUsed() | 
| long[] | getLifetimeReadLatencyHistogramMicros() | 
| long[] | getLifetimeWriteLatencyHistogramMicros() | 
| double | getLiveCellsPerSlice()Number of live cells retreived during the last slicequery | 
| long | getLiveDiskSpaceUsed() | 
| int | getLiveSSTableCount() | 
| int | getMaximumCompactionThreshold()Gets the maximum number of sstables in queue before compaction kicks off | 
| long | getMaxRowSize() | 
| SSTableReader | getMaxSizeFile(java.lang.Iterable<SSTableReader> sstables) | 
| int | getMeanColumns() | 
| long | getMeanRowSize() | 
| long | getMemtableColumnsCount()Returns the total number of columns present in the memtable. | 
| long | getMemtableDataSize()Returns the total amount of data stored in the memtable, including
 column related overhead. | 
| java.util.Set<Memtable> | getMemtablesPendingFlush() | 
| int | getMemtableSwitchCount()Returns the number of times that a flush has resulted in the
 memtable being switched out. | 
| int | getMinimumCompactionThreshold()Gets the minimum number of sstables in queue before compaction kicks off | 
| long | getMinRowSize() | 
| java.util.Set<SSTableReader> | getOverlappingSSTables(java.util.Collection<SSTableReader> sstables) | 
| int | getPendingTasks() | 
| java.util.List<Row> | getRangeSlice(AbstractBounds<RowPosition> range,
             java.util.List<IndexExpression> rowFilter,
             IDiskAtomFilter columnFilter,
             int maxResults) | 
| java.util.List<Row> | getRangeSlice(AbstractBounds<RowPosition> range,
             java.util.List<IndexExpression> rowFilter,
             IDiskAtomFilter columnFilter,
             int maxResults,
             long now) | 
| java.util.List<Row> | getRangeSlice(AbstractBounds<RowPosition> range,
             java.util.List<IndexExpression> rowFilter,
             IDiskAtomFilter columnFilter,
             int maxResults,
             long now,
             boolean countCQL3Rows,
             boolean isPaging) | 
| java.util.List<Row> | getRangeSlice(ExtendedFilter filter) | 
| ColumnFamily | getRawCachedRow(DecoratedKey key) | 
| long | getReadCount() | 
| long | getRecentBloomFilterFalsePositives() | 
| double | getRecentBloomFilterFalseRatio() | 
| long[] | getRecentReadLatencyHistogramMicros() | 
| double | getRecentReadLatencyMicros() | 
| long[] | getRecentSSTablesPerReadHistogram() | 
| long[] | getRecentWriteLatencyHistogramMicros() | 
| double | getRecentWriteLatencyMicros() | 
| long | getSnapshotCreationTime(java.lang.String snapshotName) | 
| java.util.List<SSTableReader> | getSnapshotSSTableReader(java.lang.String tag) | 
| int[] | getSSTableCountPerLevel() | 
| java.util.Collection<SSTableReader> | getSSTables() | 
| java.util.List<java.lang.String> | getSSTablesForKey(java.lang.String key)Returns a list of filenames that contain the given key on this node | 
| long[] | getSSTablesPerReadHistogram() | 
| java.lang.String | getTempSSTablePath(java.io.File directory) | 
| double | getTombstonesPerSlice()Number of tombstoned cells retreived during the last slicequery | 
| ColumnFamily | getTopLevelColumns(QueryFilter filter,
                  int gcBefore) | 
| long | getTotalAllMemtablesLiveSize() | 
| long | getTotalDiskSpaceUsed() | 
| long | getTotalMemtableLiveSize() | 
| long | getTotalReadLatencyMicros() | 
| long | getTotalWriteLatencyMicros() | 
| java.util.Set<SSTableReader> | getUncompactingSSTables() | 
| int | getUnleveledSSTables() | 
| long | getWriteCount() | 
| void | initRowCache() | 
| java.nio.ByteBuffer | internOrCopy(java.nio.ByteBuffer name,
            Allocator allocator) | 
| void | invalidate()call when dropping or renaming a CF. | 
| void | invalidateCachedRow(DecoratedKey key) | 
| void | invalidateCachedRow(RowCacheKey key) | 
| boolean | isAutoCompactionDisabled() | 
| boolean | isEmpty() | 
| boolean | isIndex()true if this CFS contains secondary index data | 
| boolean | isValid() | 
| java.lang.Iterable<DecoratedKey> | keySamples(Range<Token> range) | 
| void | loadNewSSTables()#Scan through Keyspace/ColumnFamily's data directory
 determine which SSTables should be loaded and load them | 
| static void | loadNewSSTables(java.lang.String ksName,
               java.lang.String cfName)See # StorageService.loadNewSSTables(String, String)for more info | 
| ExtendedFilter | makeExtendedFilter(AbstractBounds<RowPosition> range,
                  IDiskAtomFilter columnFilter,
                  java.util.List<IndexExpression> rowFilter,
                  int maxResults,
                  boolean countCQL3Rows,
                  boolean isPaging,
                  long timestamp) | 
| ExtendedFilter | makeExtendedFilter(AbstractBounds<RowPosition> keyRange,
                  SliceQueryFilter columnRange,
                  java.nio.ByteBuffer columnStart,
                  java.nio.ByteBuffer columnStop,
                  java.util.List<IndexExpression> rowFilter,
                  int maxResults,
                  boolean countCQL3Rows,
                  long now)Allows generic range paging with the slice column filter. | 
| java.lang.Iterable<SSTableReader> | markAllCompacting() | 
| java.util.Collection<SSTableReader> | markCurrentSSTablesReferenced()Get the current sstables, acquiring references on all of them. | 
| void | markObsolete(java.util.Collection<SSTableReader> sstables,
            OperationType compactionType) | 
| ColumnFamilyStore.ViewFragment | markReferenced(AbstractBounds<RowPosition> rowBounds) | 
| ColumnFamilyStore.ViewFragment | markReferenced(java.util.Collection<AbstractBounds<RowPosition>> rowBoundsCollection) | 
| ColumnFamilyStore.ViewFragment | markReferenced(DecoratedKey key) | 
| java.nio.ByteBuffer | maybeIntern(java.nio.ByteBuffer name) | 
| void | maybeUpdateRowCache(DecoratedKey key) | 
| long | oldestUnflushedMemtable()Returns the creation time of the oldest memtable not fully flushed yet. | 
| static void | rebuildSecondaryIndex(java.lang.String ksName,
                     java.lang.String cfName,
                     java.lang.String... idxNames) | 
| void | reload() | 
| static ColumnFamily | removeDeleted(ColumnFamily cf,
             int gcBefore)Removes deleted columns and purges gc-able tombstones. | 
| static ColumnFamily | removeDeleted(ColumnFamily cf,
             int gcBefore,
             SecondaryIndexManager.Updater indexer) | 
| static ColumnFamily | removeDeletedCF(ColumnFamily cf,
               int gcBefore)Purges gc-able top-level and range tombstones, returning `cf` if there are any columns or tombstones left,
 null otherwise. | 
| static long | removeDeletedColumnsOnly(ColumnFamily cf,
                        int gcBefore) | 
| static long | removeDeletedColumnsOnly(ColumnFamily cf,
                        int gcBefore,
                        SecondaryIndexManager.Updater indexer)Removes only per-cell tombstones, cells that are shadowed by a row-level or range tombstone, or
 columns that have been dropped from the schema (for CQL3 tables only). | 
| static void | removeUnfinishedCompactionLeftovers(java.lang.String keyspace,
                                   java.lang.String columnfamily,
                                   java.util.Map<java.lang.Integer,java.util.UUID> unfinishedCompactions)Replacing compacted sstables is atomic as far as observers of DataTracker are concerned, but not on the
 filesystem: first the new sstables are renamed to "live" status (i.e., the tmp marker is removed), then
 their ancestors are removed. | 
| void | replaceCompactedSSTables(java.util.Collection<SSTableReader> sstables,
                        java.util.Collection<SSTableReader> replacements,
                        OperationType compactionType) | 
| <V> V | runWithCompactionsDisabled(java.util.concurrent.Callable<V> callable,
                          boolean interruptValidation) | 
| void | scrub(boolean disableSnapshot,
     boolean skipCorrupted) | 
| static void | scrubDataDirectories(java.lang.String keyspaceName,
                    java.lang.String columnFamily)Removes unnecessary files from the cf directory at startup: these include temp files, orphans, zero-length files
 and compacted sstables. | 
| java.util.List<Row> | search(AbstractBounds<RowPosition> range,
      java.util.List<IndexExpression> clause,
      IDiskAtomFilter dataFilter,
      int maxResults) | 
| java.util.List<Row> | search(AbstractBounds<RowPosition> range,
      java.util.List<IndexExpression> clause,
      IDiskAtomFilter dataFilter,
      int maxResults,
      long now) | 
| java.util.List<Row> | search(ExtendedFilter filter) | 
| void | setCompactionStrategyClass(java.lang.String compactionStrategyClass)Sets the compaction strategy by class name | 
| void | setCompactionThresholds(int minThreshold,
                       int maxThreshold)Sets the maximum and maximum number of SSTables in queue before compaction kicks off | 
| void | setCompressionParameters(java.util.Map<java.lang.String,java.lang.String> opts)Set the compression parameters | 
| void | setCrcCheckChance(double crcCheckChance)Set new crc check chance | 
| void | setMaximumCompactionThreshold(int maxCompactionThreshold)Sets the maximum number of sstables in queue before compaction kicks off | 
| void | setMinimumCompactionThreshold(int minCompactionThreshold)Sets the minimum number of sstables in queue before compaction kicks off | 
| void | snapshot(java.lang.String snapshotName)Take a snap shot of this columnfamily store. | 
| boolean | snapshotExists(java.lang.String snapshotName) | 
| void | snapshotWithoutFlush(java.lang.String snapshotName) | 
| void | sstablesRewrite(boolean excludeCurrentVersion) | 
| java.util.concurrent.Future<?> | switchMemtable(boolean writeCommitLog,
              boolean forceSwitch)Switch and flush the current memtable, if it was dirty. | 
| java.lang.String | toString() | 
| void | truncateBlocking()Truncate deletes the entire column family's data with no expensive tombstone creation | 
public static final java.util.concurrent.ExecutorService postFlushExecutor
public final Keyspace keyspace
public final java.lang.String name
public final CFMetaData metadata
public final IPartitioner partitioner
public final SecondaryIndexManager indexManager
public final java.util.concurrent.ConcurrentMap<java.nio.ByteBuffer,java.nio.ByteBuffer> internedNames
public final Directories directories
public final ColumnFamilyMetrics metric
public volatile long sampleLatencyNanos
public void reload()
public void setCompactionStrategyClass(java.lang.String compactionStrategyClass)
ColumnFamilyStoreMBeansetCompactionStrategyClass in interface ColumnFamilyStoreMBeancompactionStrategyClass - the name of the compaction strategy classpublic java.lang.String getCompactionStrategyClass()
ColumnFamilyStoreMBeangetCompactionStrategyClass in interface ColumnFamilyStoreMBeanpublic java.util.Map<java.lang.String,java.lang.String> getCompressionParameters()
ColumnFamilyStoreMBeangetCompressionParameters in interface ColumnFamilyStoreMBeanpublic void setCompressionParameters(java.util.Map<java.lang.String,java.lang.String> opts)
ColumnFamilyStoreMBeansetCompressionParameters in interface ColumnFamilyStoreMBeanopts - map of string names to valuespublic void setCrcCheckChance(double crcCheckChance)
ColumnFamilyStoreMBeansetCrcCheckChance in interface ColumnFamilyStoreMBeanpublic void invalidate()
public long getMinRowSize()
getMinRowSize in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.minRowSizepublic long getMaxRowSize()
getMaxRowSize in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.maxRowSizepublic long getMeanRowSize()
getMeanRowSize in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.meanRowSizepublic int getMeanColumns()
public static ColumnFamilyStore createColumnFamilyStore(Keyspace keyspace, java.lang.String columnFamily, boolean loadSSTables)
public static ColumnFamilyStore createColumnFamilyStore(Keyspace keyspace, java.lang.String columnFamily, IPartitioner partitioner, CFMetaData metadata)
public static void scrubDataDirectories(java.lang.String keyspaceName,
                        java.lang.String columnFamily)
public static void removeUnfinishedCompactionLeftovers(java.lang.String keyspace,
                                       java.lang.String columnfamily,
                                       java.util.Map<java.lang.Integer,java.util.UUID> unfinishedCompactions)
public void initRowCache()
public static void loadNewSSTables(java.lang.String ksName,
                   java.lang.String cfName)
StorageService.loadNewSSTables(String, String) for more infoksName - The keyspace namecfName - The columnFamily namepublic void loadNewSSTables()
loadNewSSTables in interface ColumnFamilyStoreMBeanpublic static void rebuildSecondaryIndex(java.lang.String ksName,
                         java.lang.String cfName,
                         java.lang.String... idxNames)
public java.lang.String getColumnFamilyName()
getColumnFamilyName in interface ColumnFamilyStoreMBeanpublic java.lang.String getTempSSTablePath(java.io.File directory)
public java.util.concurrent.Future<?> switchMemtable(boolean writeCommitLog,
                                            boolean forceSwitch)
public java.util.concurrent.Future<?> forceFlush()
public void forceBlockingFlush()
public void maybeUpdateRowCache(DecoratedKey key)
public void apply(DecoratedKey key, ColumnFamily columnFamily, SecondaryIndexManager.Updater indexer)
public static ColumnFamily removeDeletedCF(ColumnFamily cf, int gcBefore)
gcBefore - a timestamp (in seconds); tombstones with a localDeletionTime before this will be purgedpublic static ColumnFamily removeDeleted(ColumnFamily cf, int gcBefore)
public static ColumnFamily removeDeleted(ColumnFamily cf, int gcBefore, SecondaryIndexManager.Updater indexer)
public static long removeDeletedColumnsOnly(ColumnFamily cf, int gcBefore, SecondaryIndexManager.Updater indexer)
public static long removeDeletedColumnsOnly(ColumnFamily cf, int gcBefore)
public java.util.Set<SSTableReader> getOverlappingSSTables(java.util.Collection<SSTableReader> sstables)
sstables - public java.util.Set<SSTableReader> getAndReferenceOverlappingSSTables(java.util.Collection<SSTableReader> sstables)
public void addSSTable(SSTableReader sstable)
public void addSSTables(java.util.Collection<SSTableReader> sstables)
public long getExpectedCompactedFileSize(java.lang.Iterable<SSTableReader> sstables, OperationType operation)
CLEANUP and we're not dealing with an index sstable,
 then we calculate expected file size with checking token range to be eliminated.
 Otherwise, we just add up all the files' size, which is the worst case file
 size for compaction of all the list of files given.sstables - SSTables to calculate expected compacted file sizeoperation - Operation typepublic SSTableReader getMaxSizeFile(java.lang.Iterable<SSTableReader> sstables)
public void forceCleanup(CounterId.OneShotRenewer renewer) throws java.util.concurrent.ExecutionException, java.lang.InterruptedException
java.util.concurrent.ExecutionExceptionjava.lang.InterruptedExceptionpublic void scrub(boolean disableSnapshot,
         boolean skipCorrupted)
           throws java.util.concurrent.ExecutionException,
                  java.lang.InterruptedException
java.util.concurrent.ExecutionExceptionjava.lang.InterruptedExceptionpublic void sstablesRewrite(boolean excludeCurrentVersion)
                     throws java.util.concurrent.ExecutionException,
                            java.lang.InterruptedException
java.util.concurrent.ExecutionExceptionjava.lang.InterruptedExceptionpublic void markObsolete(java.util.Collection<SSTableReader> sstables, OperationType compactionType)
public void replaceCompactedSSTables(java.util.Collection<SSTableReader> sstables, java.util.Collection<SSTableReader> replacements, OperationType compactionType)
public boolean isValid()
public long getMemtableColumnsCount()
ColumnFamilyStoreMBeangetMemtableColumnsCount in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.memtableColumnsCountpublic long getMemtableDataSize()
ColumnFamilyStoreMBeangetMemtableDataSize in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.memtableDataSizepublic long getTotalMemtableLiveSize()
public long getAllMemtablesLiveSize()
public long getTotalAllMemtablesLiveSize()
public int getMemtableSwitchCount()
ColumnFamilyStoreMBeangetMemtableSwitchCount in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.memtableSwitchCountpublic DataTracker getDataTracker()
public java.util.Collection<SSTableReader> getSSTables()
public java.util.Set<SSTableReader> getUncompactingSSTables()
public long[] getRecentSSTablesPerReadHistogram()
getRecentSSTablesPerReadHistogram in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.recentSSTablesPerReadpublic long[] getSSTablesPerReadHistogram()
getSSTablesPerReadHistogram in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.sstablesPerReadHistogrampublic long getReadCount()
getReadCount in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.readLatencypublic double getRecentReadLatencyMicros()
getRecentReadLatencyMicros in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.readLatencypublic long[] getLifetimeReadLatencyHistogramMicros()
getLifetimeReadLatencyHistogramMicros in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.readLatencypublic long[] getRecentReadLatencyHistogramMicros()
getRecentReadLatencyHistogramMicros in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.readLatencypublic long getTotalReadLatencyMicros()
getTotalReadLatencyMicros in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.readLatencypublic int getPendingTasks()
getPendingTasks in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.pendingTaskspublic long getWriteCount()
getWriteCount in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.writeLatencypublic long getTotalWriteLatencyMicros()
getTotalWriteLatencyMicros in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.writeLatencypublic double getRecentWriteLatencyMicros()
getRecentWriteLatencyMicros in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.writeLatencypublic long[] getLifetimeWriteLatencyHistogramMicros()
getLifetimeWriteLatencyHistogramMicros in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.writeLatencypublic long[] getRecentWriteLatencyHistogramMicros()
getRecentWriteLatencyHistogramMicros in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.writeLatencypublic ColumnFamily getColumnFamily(DecoratedKey key, java.nio.ByteBuffer start, java.nio.ByteBuffer finish, boolean reversed, int limit, long timestamp)
public int gcBefore(long now)
public ColumnFamily getColumnFamily(QueryFilter filter)
public java.util.Collection<SSTableReader> markCurrentSSTablesReferenced()
public ColumnFamilyStore.ViewFragment markReferenced(DecoratedKey key)
public ColumnFamilyStore.ViewFragment markReferenced(AbstractBounds<RowPosition> rowBounds)
public ColumnFamilyStore.ViewFragment markReferenced(java.util.Collection<AbstractBounds<RowPosition>> rowBoundsCollection)
public java.util.List<java.lang.String> getSSTablesForKey(java.lang.String key)
ColumnFamilyStoreMBeangetSSTablesForKey in interface ColumnFamilyStoreMBeanpublic ColumnFamily getTopLevelColumns(QueryFilter filter, int gcBefore)
public void cleanupCache()
public java.util.List<Row> getRangeSlice(AbstractBounds<RowPosition> range, java.util.List<IndexExpression> rowFilter, IDiskAtomFilter columnFilter, int maxResults)
public java.util.List<Row> getRangeSlice(AbstractBounds<RowPosition> range, java.util.List<IndexExpression> rowFilter, IDiskAtomFilter columnFilter, int maxResults, long now)
public ExtendedFilter makeExtendedFilter(AbstractBounds<RowPosition> keyRange, SliceQueryFilter columnRange, java.nio.ByteBuffer columnStart, java.nio.ByteBuffer columnStop, java.util.List<IndexExpression> rowFilter, int maxResults, boolean countCQL3Rows, long now)
public java.util.List<Row> getRangeSlice(AbstractBounds<RowPosition> range, java.util.List<IndexExpression> rowFilter, IDiskAtomFilter columnFilter, int maxResults, long now, boolean countCQL3Rows, boolean isPaging)
public ExtendedFilter makeExtendedFilter(AbstractBounds<RowPosition> range, IDiskAtomFilter columnFilter, java.util.List<IndexExpression> rowFilter, int maxResults, boolean countCQL3Rows, boolean isPaging, long timestamp)
public java.util.List<Row> getRangeSlice(ExtendedFilter filter)
public java.util.List<Row> search(AbstractBounds<RowPosition> range, java.util.List<IndexExpression> clause, IDiskAtomFilter dataFilter, int maxResults)
public java.util.List<Row> search(AbstractBounds<RowPosition> range, java.util.List<IndexExpression> clause, IDiskAtomFilter dataFilter, int maxResults, long now)
public java.util.List<Row> search(ExtendedFilter filter)
public java.util.List<Row> filter(ColumnFamilyStore.AbstractScanIterator rowIterator, ExtendedFilter filter)
public AbstractType<?> getComparator()
public void snapshotWithoutFlush(java.lang.String snapshotName)
public java.util.List<SSTableReader> getSnapshotSSTableReader(java.lang.String tag) throws java.io.IOException
java.io.IOExceptionpublic void snapshot(java.lang.String snapshotName)
snapshotName - the name of the associated with the snapshotpublic boolean snapshotExists(java.lang.String snapshotName)
public long getSnapshotCreationTime(java.lang.String snapshotName)
public void clearSnapshot(java.lang.String snapshotName)
snapshotName - the user supplied snapshot name. If left empty,
                     all the snapshots will be cleaned.public long getTotalDiskSpaceUsed()
getTotalDiskSpaceUsed in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.totalDiskSpaceUsedpublic long getLiveDiskSpaceUsed()
getLiveDiskSpaceUsed in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.liveDiskSpaceUsedpublic int getLiveSSTableCount()
getLiveSSTableCount in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.liveSSTableCountpublic ColumnFamily getRawCachedRow(DecoratedKey key)
public boolean containsCachedRow(DecoratedKey key)
public void invalidateCachedRow(RowCacheKey key)
public void invalidateCachedRow(DecoratedKey key)
public void forceMajorCompaction()
                          throws java.lang.InterruptedException,
                                 java.util.concurrent.ExecutionException
ColumnFamilyStoreMBeanforceMajorCompaction in interface ColumnFamilyStoreMBeanjava.lang.InterruptedExceptionjava.util.concurrent.ExecutionExceptionpublic static java.lang.Iterable<ColumnFamilyStore> all()
public java.lang.Iterable<DecoratedKey> keySamples(Range<Token> range)
public void clearUnsafe()
public void truncateBlocking()
public <V> V runWithCompactionsDisabled(java.util.concurrent.Callable<V> callable,
                               boolean interruptValidation)
public java.lang.Iterable<SSTableReader> markAllCompacting()
public long getBloomFilterFalsePositives()
getBloomFilterFalsePositives in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.bloomFilterFalsePositivespublic long getRecentBloomFilterFalsePositives()
getRecentBloomFilterFalsePositives in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.recentBloomFilterFalsePositivespublic double getBloomFilterFalseRatio()
getBloomFilterFalseRatio in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.bloomFilterFalseRatiopublic double getRecentBloomFilterFalseRatio()
getRecentBloomFilterFalseRatio in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.recentBloomFilterFalseRatiopublic long getBloomFilterDiskSpaceUsed()
getBloomFilterDiskSpaceUsed in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.bloomFilterDiskSpaceUsedpublic long getBloomFilterOffHeapMemoryUsed()
getBloomFilterOffHeapMemoryUsed in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.bloomFilterOffHeapMemoryUsedpublic long getIndexSummaryOffHeapMemoryUsed()
getIndexSummaryOffHeapMemoryUsed in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.indexSummaryOffHeapMemoryUsedpublic long getCompressionMetadataOffHeapMemoryUsed()
getCompressionMetadataOffHeapMemoryUsed in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.compressionMetadataOffHeapMemoryUsedpublic java.lang.String toString()
toString in class java.lang.Objectpublic void disableAutoCompaction()
public void enableAutoCompaction()
public void enableAutoCompaction(boolean waitForFutures)
waitForFutures - if we should block until autocompaction is donepublic boolean isAutoCompactionDisabled()
isAutoCompactionDisabled in interface ColumnFamilyStoreMBeanpublic AbstractCompactionStrategy getCompactionStrategy()
public void setCompactionThresholds(int minThreshold,
                           int maxThreshold)
ColumnFamilyStoreMBeansetCompactionThresholds in interface ColumnFamilyStoreMBeanpublic int getMinimumCompactionThreshold()
ColumnFamilyStoreMBeangetMinimumCompactionThreshold in interface ColumnFamilyStoreMBeanpublic void setMinimumCompactionThreshold(int minCompactionThreshold)
ColumnFamilyStoreMBeansetMinimumCompactionThreshold in interface ColumnFamilyStoreMBeanpublic int getMaximumCompactionThreshold()
ColumnFamilyStoreMBeangetMaximumCompactionThreshold in interface ColumnFamilyStoreMBeanpublic void setMaximumCompactionThreshold(int maxCompactionThreshold)
ColumnFamilyStoreMBeansetMaximumCompactionThreshold in interface ColumnFamilyStoreMBeanpublic double getTombstonesPerSlice()
ColumnFamilyStoreMBeangetTombstonesPerSlice in interface ColumnFamilyStoreMBeanpublic double getLiveCellsPerSlice()
ColumnFamilyStoreMBeangetLiveCellsPerSlice in interface ColumnFamilyStoreMBeanpublic long estimateKeys()
estimateKeys in interface ColumnFamilyStoreMBeanpublic long[] getEstimatedRowSizeHistogram()
getEstimatedRowSizeHistogram in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.estimatedRowSizeHistogrampublic long[] getEstimatedColumnCountHistogram()
getEstimatedColumnCountHistogram in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.estimatedColumnCountHistogrampublic double getCompressionRatio()
getCompressionRatio in interface ColumnFamilyStoreMBeanColumnFamilyMetrics.compressionRatiopublic boolean isIndex()
public java.nio.ByteBuffer internOrCopy(java.nio.ByteBuffer name,
                               Allocator allocator)
public java.nio.ByteBuffer maybeIntern(java.nio.ByteBuffer name)
public java.lang.Iterable<ColumnFamilyStore> concatWithIndexes()
public java.util.Set<Memtable> getMemtablesPendingFlush()
public java.util.List<java.lang.String> getBuiltIndexes()
ColumnFamilyStoreMBeangetBuiltIndexes in interface ColumnFamilyStoreMBeanpublic int getUnleveledSSTables()
getUnleveledSSTables in interface ColumnFamilyStoreMBeanpublic int[] getSSTableCountPerLevel()
getSSTableCountPerLevel in interface ColumnFamilyStoreMBeanpublic long oldestUnflushedMemtable()
public boolean isEmpty()
public ReplayPosition discardSSTables(long truncatedAt)
truncatedAt - The timestamp of the truncation
                    (all SSTables before that timestamp are going be marked as compacted)public double getDroppableTombstoneRatio()
ColumnFamilyStoreMBeangetDroppableTombstoneRatio in interface ColumnFamilyStoreMBeanCopyright © 2015 The Apache Software Foundation