|
||||||||||
PREV CLASS NEXT CLASS | FRAMES NO FRAMES | |||||||||
SUMMARY: NESTED | FIELD | CONSTR | METHOD | DETAIL: FIELD | CONSTR | METHOD |
java.lang.Objectorg.apache.cassandra.db.ColumnFamilyStore
public class ColumnFamilyStore
Nested Class Summary | |
---|---|
static class |
ColumnFamilyStore.AbstractScanIterator
|
static class |
ColumnFamilyStore.ViewFragment
|
Field Summary | |
---|---|
java.lang.String |
columnFamily
|
Directories |
directories
|
SecondaryIndexManager |
indexManager
|
java.util.concurrent.ConcurrentMap<java.nio.ByteBuffer,java.nio.ByteBuffer> |
internedNames
|
CFMetaData |
metadata
|
IPartitioner |
partitioner
|
static java.util.concurrent.ExecutorService |
postFlushExecutor
|
Table |
table
|
Method Summary | |
---|---|
void |
addSSTable(SSTableReader sstable)
|
static java.lang.Iterable<ColumnFamilyStore> |
all()
|
static java.util.List<ColumnFamilyStore> |
allUserDefined()
|
void |
apply(DecoratedKey key,
ColumnFamily columnFamily)
Insert/Update the column family for this key. |
void |
clearSnapshot(java.lang.String snapshotName)
|
void |
clearUnsafe()
For testing. |
java.lang.Iterable<ColumnFamilyStore> |
concatWithIndexes()
|
boolean |
containsCachedRow(DecoratedKey key)
|
static ColumnFamilyStore |
createColumnFamilyStore(Table table,
java.lang.String columnFamily)
|
static ColumnFamilyStore |
createColumnFamilyStore(Table table,
java.lang.String columnFamily,
IPartitioner partitioner,
CFMetaData metadata)
|
SSTableWriter |
createCompactionWriter(long estimatedRows,
java.io.File location,
java.util.Collection<SSTableReader> sstables)
|
SSTableWriter |
createFlushWriter(long estimatedRows,
long estimatedSize,
ReplayPosition context)
|
void |
disableAutoCompaction()
Disable automatic compaction. |
void |
discardSSTables(long truncatedAt)
Discard all SSTables that were created before given timestamp. |
long |
estimateKeys()
|
java.util.List<Row> |
filter(ColumnFamilyStore.AbstractScanIterator rowIterator,
ExtendedFilter filter)
|
void |
forceBlockingFlush()
|
void |
forceCleanup(NodeId.OneShotRenewer renewer)
|
java.util.concurrent.Future<?> |
forceFlush()
|
void |
forceMajorCompaction()
force a major compaction of this column family |
int |
gcBefore()
|
long |
getBloomFilterDiskSpaceUsed()
|
long |
getBloomFilterFalsePositives()
|
double |
getBloomFilterFalseRatio()
|
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,
QueryPath path,
java.nio.ByteBuffer start,
java.nio.ByteBuffer finish,
boolean reversed,
int limit)
|
ColumnFamily |
getColumnFamily(QueryFilter filter)
get a list of columns starting from a given column, in a specified order. |
ColumnFamily |
getColumnFamily(QueryFilter filter,
ISortedColumns.Factory factory)
|
java.lang.String |
getColumnFamilyName()
|
AbstractCompactionStrategy |
getCompactionStrategy()
|
java.lang.String |
getCompactionStrategyClass()
Gets the compaction strategy class name |
AbstractType<?> |
getComparator()
|
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. |
long[] |
getEstimatedColumnCountHistogram()
|
long[] |
getEstimatedRowSizeHistogram()
|
long |
getExpectedCompactedFileSize(java.lang.Iterable<SSTableReader> sstables)
|
java.lang.String |
getFlushPath(long estimatedSize,
java.lang.String version)
|
long[] |
getLifetimeReadLatencyHistogramMicros()
|
long[] |
getLifetimeWriteLatencyHistogramMicros()
|
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()
|
int |
getPendingTasks()
|
java.util.List<Row> |
getRangeSlice(java.nio.ByteBuffer superColumn,
AbstractBounds<RowPosition> range,
int maxResults,
IFilter columnFilter,
java.util.List<org.apache.cassandra.thrift.IndexExpression> rowFilter)
|
java.util.List<Row> |
getRangeSlice(java.nio.ByteBuffer superColumn,
AbstractBounds<RowPosition> range,
int maxResults,
IFilter columnFilter,
java.util.List<org.apache.cassandra.thrift.IndexExpression> rowFilter,
boolean maxIsColumns,
boolean isPaging)
|
ColumnFamily |
getRawCachedRow(DecoratedKey key)
|
long |
getReadCount()
|
long |
getRecentBloomFilterFalsePositives()
|
double |
getRecentBloomFilterFalseRatio()
|
long[] |
getRecentReadLatencyHistogramMicros()
|
double |
getRecentReadLatencyMicros()
|
long[] |
getRecentSSTablesPerReadHistogram()
|
long[] |
getRecentWriteLatencyHistogramMicros()
|
double |
getRecentWriteLatencyMicros()
|
ColumnFamilyStore.AbstractScanIterator |
getSequentialIterator(java.nio.ByteBuffer superColumn,
AbstractBounds<RowPosition> range,
IFilter columnFilter)
Iterate over a range of rows and columns from memtables/sstables. |
java.util.Collection<SSTableReader> |
getSSTables()
|
long[] |
getSSTablesPerReadHistogram()
|
java.lang.String |
getTempSSTablePath(java.io.File directory)
|
java.lang.String |
getTempSSTablePath(java.io.File directory,
java.lang.String version)
|
long |
getTotalDiskSpaceUsed()
|
long |
getTotalMemtableLiveSize()
|
long |
getTotalReadLatencyMicros()
|
long |
getTotalWriteLatencyMicros()
|
java.util.Set<SSTableReader> |
getUncompactingSSTables()
|
int |
getUnleveledSSTables()
|
long |
getWriteCount()
|
boolean |
hasUnreclaimedSpace()
|
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 |
isCompactionDisabled()
|
boolean |
isEmpty()
|
boolean |
isIndex()
true if this CFS contains secondary index data |
boolean |
isKeyInRemainingSSTables(DecoratedKey key,
java.util.Set<? extends SSTable> sstablesToIgnore)
Uses bloom filters to check if key may be present in any sstable in this ColumnFamilyStore, minus a set of provided ones. |
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 |
void |
markCompacted(java.util.Collection<SSTableReader> sstables,
OperationType compactionType)
|
java.util.Collection<SSTableReader> |
markCurrentSSTablesReferenced()
Get the current sstables, acquiring references on all of them. |
ColumnFamilyStore.ViewFragment |
markReferenced(DecoratedKey key)
|
ColumnFamilyStore.ViewFragment |
markReferenced(RowPosition startWith,
RowPosition stopAt)
|
java.nio.ByteBuffer |
maybeIntern(java.nio.ByteBuffer name)
|
java.util.concurrent.Future<?> |
maybeSwitchMemtable(Memtable oldMemtable,
boolean writeCommitLog)
flush the given memtable and swap in a new one for its CFS, if it hasn't been frozen already. |
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)
|
static ColumnFamily |
removeDeletedCF(ColumnFamily cf,
int gcBefore)
|
static void |
removeDeletedColumnsOnly(ColumnFamily cf,
int gcBefore)
|
void |
replaceCompactedSSTables(java.util.Collection<SSTableReader> sstables,
java.lang.Iterable<SSTableReader> replacements,
OperationType compactionType)
|
void |
scrub()
|
static void |
scrubDataDirectories(java.lang.String table,
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(java.util.List<org.apache.cassandra.thrift.IndexExpression> clause,
AbstractBounds<RowPosition> range,
int maxResults,
IFilter dataFilter)
|
java.util.List<Row> |
search(java.util.List<org.apache.cassandra.thrift.IndexExpression> clause,
AbstractBounds<RowPosition> range,
int maxResults,
IFilter dataFilter,
boolean maxIsColumns)
|
void |
setCompactionStrategyClass(java.lang.String compactionStrategyClass)
Sets the compaction strategy by class name |
void |
setCompressionParameters(java.util.Map<java.lang.String,java.lang.String> opts)
Set the compression parameters |
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()
|
java.lang.String |
toString()
|
java.util.concurrent.Future<?> |
truncate()
Truncate practically deletes the entire column family's data |
void |
updateRowCache(DecoratedKey key,
ColumnFamily columnFamily)
|
Methods inherited from class java.lang.Object |
---|
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait |
Field Detail |
---|
public static final java.util.concurrent.ExecutorService postFlushExecutor
public final Table table
public final java.lang.String columnFamily
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
Method Detail |
---|
public void reload() throws java.io.IOException
java.io.IOException
public void setCompactionStrategyClass(java.lang.String compactionStrategyClass) throws ConfigurationException
ColumnFamilyStoreMBean
setCompactionStrategyClass
in interface ColumnFamilyStoreMBean
compactionStrategyClass
- the name of the compaction strategy class
ConfigurationException
public java.lang.String getCompactionStrategyClass()
ColumnFamilyStoreMBean
getCompactionStrategyClass
in interface ColumnFamilyStoreMBean
public java.util.Map<java.lang.String,java.lang.String> getCompressionParameters()
ColumnFamilyStoreMBean
getCompressionParameters
in interface ColumnFamilyStoreMBean
public void setCompressionParameters(java.util.Map<java.lang.String,java.lang.String> opts) throws ConfigurationException
ColumnFamilyStoreMBean
setCompressionParameters
in interface ColumnFamilyStoreMBean
opts
- map of string names to values
ConfigurationException
public void invalidate()
public long getMinRowSize()
getMinRowSize
in interface ColumnFamilyStoreMBean
public long getMaxRowSize()
getMaxRowSize
in interface ColumnFamilyStoreMBean
public long getMeanRowSize()
getMeanRowSize
in interface ColumnFamilyStoreMBean
public int getMeanColumns()
public static ColumnFamilyStore createColumnFamilyStore(Table table, java.lang.String columnFamily)
public static ColumnFamilyStore createColumnFamilyStore(Table table, java.lang.String columnFamily, IPartitioner partitioner, CFMetaData metadata)
public static void scrubDataDirectories(java.lang.String table, java.lang.String columnFamily)
public void initRowCache()
public static void loadNewSSTables(java.lang.String ksName, java.lang.String cfName)
StorageService.loadNewSSTables(String, String)
for more info
ksName
- The keyspace namecfName
- The columnFamily namepublic void loadNewSSTables()
loadNewSSTables
in interface ColumnFamilyStoreMBean
public static void rebuildSecondaryIndex(java.lang.String ksName, java.lang.String cfName, java.lang.String... idxNames)
public java.lang.String getColumnFamilyName()
getColumnFamilyName
in interface ColumnFamilyStoreMBean
public java.lang.String getFlushPath(long estimatedSize, java.lang.String version)
public java.lang.String getTempSSTablePath(java.io.File directory, java.lang.String version)
public java.lang.String getTempSSTablePath(java.io.File directory)
public java.util.concurrent.Future<?> maybeSwitchMemtable(Memtable oldMemtable, boolean writeCommitLog)
public java.util.concurrent.Future<?> forceFlush()
public void forceBlockingFlush() throws java.util.concurrent.ExecutionException, java.lang.InterruptedException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
public void updateRowCache(DecoratedKey key, ColumnFamily columnFamily)
public void apply(DecoratedKey key, ColumnFamily columnFamily)
public static ColumnFamily removeDeletedCF(ColumnFamily cf, int gcBefore)
public static ColumnFamily removeDeleted(ColumnFamily cf, int gcBefore)
public static void removeDeletedColumnsOnly(ColumnFamily cf, int gcBefore)
public boolean isKeyInRemainingSSTables(DecoratedKey key, java.util.Set<? extends SSTable> sstablesToIgnore)
public void addSSTable(SSTableReader sstable)
public long getExpectedCompactedFileSize(java.lang.Iterable<SSTableReader> sstables)
public SSTableReader getMaxSizeFile(java.lang.Iterable<SSTableReader> sstables)
public void forceCleanup(NodeId.OneShotRenewer renewer) throws java.util.concurrent.ExecutionException, java.lang.InterruptedException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
public void scrub() throws java.util.concurrent.ExecutionException, java.lang.InterruptedException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
public void sstablesRewrite() throws java.util.concurrent.ExecutionException, java.lang.InterruptedException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
public void markCompacted(java.util.Collection<SSTableReader> sstables, OperationType compactionType)
public void replaceCompactedSSTables(java.util.Collection<SSTableReader> sstables, java.lang.Iterable<SSTableReader> replacements, OperationType compactionType)
public boolean isValid()
public long getMemtableColumnsCount()
ColumnFamilyStoreMBean
getMemtableColumnsCount
in interface ColumnFamilyStoreMBean
public long getMemtableDataSize()
ColumnFamilyStoreMBean
getMemtableDataSize
in interface ColumnFamilyStoreMBean
public long getTotalMemtableLiveSize()
public int getMemtableSwitchCount()
ColumnFamilyStoreMBean
getMemtableSwitchCount
in interface ColumnFamilyStoreMBean
public DataTracker getDataTracker()
public java.util.Collection<SSTableReader> getSSTables()
public java.util.Set<SSTableReader> getUncompactingSSTables()
public long[] getRecentSSTablesPerReadHistogram()
getRecentSSTablesPerReadHistogram
in interface ColumnFamilyStoreMBean
public long[] getSSTablesPerReadHistogram()
getSSTablesPerReadHistogram
in interface ColumnFamilyStoreMBean
public long getReadCount()
getReadCount
in interface ColumnFamilyStoreMBean
public double getRecentReadLatencyMicros()
getRecentReadLatencyMicros
in interface ColumnFamilyStoreMBean
public long[] getLifetimeReadLatencyHistogramMicros()
getLifetimeReadLatencyHistogramMicros
in interface ColumnFamilyStoreMBean
public long[] getRecentReadLatencyHistogramMicros()
getRecentReadLatencyHistogramMicros
in interface ColumnFamilyStoreMBean
public long getTotalReadLatencyMicros()
getTotalReadLatencyMicros
in interface ColumnFamilyStoreMBean
public int getPendingTasks()
getPendingTasks
in interface ColumnFamilyStoreMBean
public long getWriteCount()
getWriteCount
in interface ColumnFamilyStoreMBean
public long getTotalWriteLatencyMicros()
getTotalWriteLatencyMicros
in interface ColumnFamilyStoreMBean
public double getRecentWriteLatencyMicros()
getRecentWriteLatencyMicros
in interface ColumnFamilyStoreMBean
public long[] getLifetimeWriteLatencyHistogramMicros()
getLifetimeWriteLatencyHistogramMicros
in interface ColumnFamilyStoreMBean
public long[] getRecentWriteLatencyHistogramMicros()
getRecentWriteLatencyHistogramMicros
in interface ColumnFamilyStoreMBean
public ColumnFamily getColumnFamily(DecoratedKey key, QueryPath path, java.nio.ByteBuffer start, java.nio.ByteBuffer finish, boolean reversed, int limit)
public ColumnFamily getColumnFamily(QueryFilter filter)
public ColumnFamily getColumnFamily(QueryFilter filter, ISortedColumns.Factory factory)
public int gcBefore()
public java.util.Collection<SSTableReader> markCurrentSSTablesReferenced()
public ColumnFamilyStore.ViewFragment markReferenced(DecoratedKey key)
public ColumnFamilyStore.ViewFragment markReferenced(RowPosition startWith, RowPosition stopAt)
public ColumnFamilyStore.AbstractScanIterator getSequentialIterator(java.nio.ByteBuffer superColumn, AbstractBounds<RowPosition> range, IFilter columnFilter)
superColumn
- optional SuperColumn to slice subcolumns of; null to slice top-level columnsrange
- Either a Bounds, which includes start key, or a Range, which does not.columnFilter
- description of the columns we're interested in for each rowpublic java.util.List<Row> getRangeSlice(java.nio.ByteBuffer superColumn, AbstractBounds<RowPosition> range, int maxResults, IFilter columnFilter, java.util.List<org.apache.cassandra.thrift.IndexExpression> rowFilter)
public java.util.List<Row> getRangeSlice(java.nio.ByteBuffer superColumn, AbstractBounds<RowPosition> range, int maxResults, IFilter columnFilter, java.util.List<org.apache.cassandra.thrift.IndexExpression> rowFilter, boolean maxIsColumns, boolean isPaging)
public java.util.List<Row> search(java.util.List<org.apache.cassandra.thrift.IndexExpression> clause, AbstractBounds<RowPosition> range, int maxResults, IFilter dataFilter)
public java.util.List<Row> search(java.util.List<org.apache.cassandra.thrift.IndexExpression> clause, AbstractBounds<RowPosition> range, int maxResults, IFilter dataFilter, boolean maxIsColumns)
public java.util.List<Row> filter(ColumnFamilyStore.AbstractScanIterator rowIterator, ExtendedFilter filter)
public AbstractType<?> getComparator()
public void snapshotWithoutFlush(java.lang.String snapshotName)
public void snapshot(java.lang.String snapshotName)
snapshotName
- the name of the associated with the snapshotpublic boolean snapshotExists(java.lang.String snapshotName)
public void clearSnapshot(java.lang.String snapshotName) throws java.io.IOException
java.io.IOException
public boolean hasUnreclaimedSpace()
public long getTotalDiskSpaceUsed()
getTotalDiskSpaceUsed
in interface ColumnFamilyStoreMBean
public long getLiveDiskSpaceUsed()
getLiveDiskSpaceUsed
in interface ColumnFamilyStoreMBean
public int getLiveSSTableCount()
getLiveSSTableCount
in interface ColumnFamilyStoreMBean
public 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
ColumnFamilyStoreMBean
forceMajorCompaction
in interface ColumnFamilyStoreMBean
java.lang.InterruptedException
java.util.concurrent.ExecutionException
public static java.lang.Iterable<ColumnFamilyStore> all()
public static java.util.List<ColumnFamilyStore> allUserDefined()
public java.lang.Iterable<DecoratedKey<?>> keySamples(Range<Token> range)
public void clearUnsafe()
public java.util.concurrent.Future<?> truncate() throws java.io.IOException, java.util.concurrent.ExecutionException, java.lang.InterruptedException
java.io.IOException
java.util.concurrent.ExecutionException
java.lang.InterruptedException
public long getBloomFilterFalsePositives()
getBloomFilterFalsePositives
in interface ColumnFamilyStoreMBean
public long getRecentBloomFilterFalsePositives()
getRecentBloomFilterFalsePositives
in interface ColumnFamilyStoreMBean
public double getBloomFilterFalseRatio()
getBloomFilterFalseRatio
in interface ColumnFamilyStoreMBean
public double getRecentBloomFilterFalseRatio()
getRecentBloomFilterFalseRatio
in interface ColumnFamilyStoreMBean
public long getBloomFilterDiskSpaceUsed()
getBloomFilterDiskSpaceUsed
in interface ColumnFamilyStoreMBean
public java.lang.String toString()
toString
in class java.lang.Object
public void disableAutoCompaction()
ColumnFamilyStoreMBean
disableAutoCompaction
in interface ColumnFamilyStoreMBean
public AbstractCompactionStrategy getCompactionStrategy()
public int getMinimumCompactionThreshold()
ColumnFamilyStoreMBean
getMinimumCompactionThreshold
in interface ColumnFamilyStoreMBean
public void setMinimumCompactionThreshold(int minCompactionThreshold)
ColumnFamilyStoreMBean
setMinimumCompactionThreshold
in interface ColumnFamilyStoreMBean
public int getMaximumCompactionThreshold()
ColumnFamilyStoreMBean
getMaximumCompactionThreshold
in interface ColumnFamilyStoreMBean
public void setMaximumCompactionThreshold(int maxCompactionThreshold)
ColumnFamilyStoreMBean
setMaximumCompactionThreshold
in interface ColumnFamilyStoreMBean
public boolean isCompactionDisabled()
public long estimateKeys()
estimateKeys
in interface ColumnFamilyStoreMBean
public long[] getEstimatedRowSizeHistogram()
getEstimatedRowSizeHistogram
in interface ColumnFamilyStoreMBean
public long[] getEstimatedColumnCountHistogram()
getEstimatedColumnCountHistogram
in interface ColumnFamilyStoreMBean
public double getCompressionRatio()
getCompressionRatio
in interface ColumnFamilyStoreMBean
public boolean isIndex()
public java.nio.ByteBuffer internOrCopy(java.nio.ByteBuffer name, Allocator allocator)
public java.nio.ByteBuffer maybeIntern(java.nio.ByteBuffer name)
public SSTableWriter createFlushWriter(long estimatedRows, long estimatedSize, ReplayPosition context) throws java.io.IOException
java.io.IOException
public SSTableWriter createCompactionWriter(long estimatedRows, java.io.File location, java.util.Collection<SSTableReader> sstables) throws java.io.IOException
java.io.IOException
public java.lang.Iterable<ColumnFamilyStore> concatWithIndexes()
public java.util.Set<Memtable> getMemtablesPendingFlush()
public java.util.List<java.lang.String> getBuiltIndexes()
ColumnFamilyStoreMBean
getBuiltIndexes
in interface ColumnFamilyStoreMBean
public int getUnleveledSSTables()
getUnleveledSSTables
in interface ColumnFamilyStoreMBean
public long oldestUnflushedMemtable()
public boolean isEmpty()
public void discardSSTables(long truncatedAt)
truncatedAt
- The timestamp of the truncation
(all SSTables before that timestamp are going be marked as compacted)
|
||||||||||
PREV CLASS NEXT CLASS | FRAMES NO FRAMES | |||||||||
SUMMARY: NESTED | FIELD | CONSTR | METHOD | DETAIL: FIELD | CONSTR | METHOD |