Modifier and Type | Method and Description |
---|---|
java.util.concurrent.Future<Pair<K,V>> |
AutoSavingCache.CacheSerializer.deserialize(java.io.DataInputStream in,
ColumnFamilyStore cfs) |
void |
AutoSavingCache.CacheSerializer.serialize(K key,
DataOutputPlus out,
ColumnFamilyStore cfs) |
Modifier and Type | Method and Description |
---|---|
ColumnFamilyStore |
Schema.getColumnFamilyStoreIncludingIndexes(Pair<java.lang.String,java.lang.String> ksNameAndCFName)
Retrieve a CFS by name even if that CFS is an index
An index is identified by looking for '.' in the CF name and separating to find the base table
containing the index
|
ColumnFamilyStore |
Schema.getColumnFamilyStoreInstance(java.util.UUID cfId) |
Modifier and Type | Method and Description |
---|---|
static AbstractCompactionStrategy |
CFMetaData.createCompactionStrategyInstance(java.lang.Class<? extends AbstractCompactionStrategy> compactionStrategyClass,
ColumnFamilyStore cfs,
java.util.Map<java.lang.String,java.lang.String> compactionStrategyOptions) |
AbstractCompactionStrategy |
CFMetaData.createCompactionStrategyInstance(ColumnFamilyStore cfs)
Deprecated.
|
Modifier and Type | Field and Description |
---|---|
ColumnFamilyStore |
Memtable.cfs |
ColumnFamilyStore |
DataTracker.cfstore |
Modifier and Type | Method and Description |
---|---|
static ColumnFamilyStore |
ColumnFamilyStore.createColumnFamilyStore(Keyspace keyspace,
java.lang.String columnFamily,
boolean loadSSTables) |
static ColumnFamilyStore |
ColumnFamilyStore.createColumnFamilyStore(Keyspace keyspace,
java.lang.String columnFamily,
IPartitioner partitioner,
CFMetaData metadata) |
ColumnFamilyStore |
Keyspace.getColumnFamilyStore(java.lang.String cfName) |
ColumnFamilyStore |
Keyspace.getColumnFamilyStore(java.util.UUID id) |
static ColumnFamilyStore |
SystemKeyspace.schemaCFS(java.lang.String cfName) |
Modifier and Type | Method and Description |
---|---|
static java.lang.Iterable<ColumnFamilyStore> |
ColumnFamilyStore.all() |
java.lang.Iterable<ColumnFamilyStore> |
ColumnFamilyStore.concatWithIndexes() |
java.util.Collection<ColumnFamilyStore> |
Keyspace.getColumnFamilyStores() |
Modifier and Type | Method and Description |
---|---|
static CloseableIterator<Row> |
RowIteratorFactory.getIterator(java.lang.Iterable<Memtable> memtables,
java.util.Collection<SSTableReader> sstables,
DataRange range,
ColumnFamilyStore cfs,
long now)
Get a row iterator over the provided memtables and sstables, between the provided keys
and filtered by the queryfilter.
|
static void |
Keyspace.indexRow(DecoratedKey key,
ColumnFamilyStore cfs,
java.util.Set<java.lang.String> idxNames) |
static void |
SystemKeyspace.saveTruncationRecord(ColumnFamilyStore cfs,
long truncatedAt,
ReplayPosition position) |
static java.util.UUID |
SystemKeyspace.startCompaction(ColumnFamilyStore cfs,
java.lang.Iterable<SSTableReader> toCompact)
Write compaction log, except columfamilies under system keyspace.
|
Constructor and Description |
---|
CollationController(ColumnFamilyStore cfs,
QueryFilter filter,
int gcBefore) |
DataTracker(ColumnFamilyStore cfstore) |
Memtable(ColumnFamilyStore cfs) |
Modifier and Type | Field and Description |
---|---|
protected ColumnFamilyStore |
AbstractCompactionStrategy.cfs |
protected ColumnFamilyStore |
AbstractCompactionTask.cfs |
ColumnFamilyStore |
CompactionController.cfs |
Modifier and Type | Method and Description |
---|---|
static LeveledManifest |
LeveledManifest.create(ColumnFamilyStore cfs,
int maxSSTableSize,
java.lang.Iterable<SSTableReader> sstables,
SizeTieredCompactionStrategyOptions options) |
static LeveledManifest |
LeveledManifest.create(ColumnFamilyStore cfs,
int maxSSTableSize,
java.util.List<SSTableReader> sstables) |
static SSTableWriter |
CompactionManager.createWriter(ColumnFamilyStore cfs,
java.io.File compactionFileLocation,
long expectedBloomFilterSize,
long repairedAt,
SSTableReader sstable) |
static java.util.Set<SSTableReader> |
CompactionController.getFullyExpiredSSTables(ColumnFamilyStore cfStore,
java.lang.Iterable<SSTableReader> compacting,
java.lang.Iterable<SSTableReader> overlapping,
int gcBefore)
Finds expired sstables
works something like this;
1.
|
void |
CompactionManager.performAnticompaction(ColumnFamilyStore cfs,
java.util.Collection<Range<Token>> ranges,
Refs<SSTableReader> validatedForRepair,
long repairedAt)
Make sure the {validatedForRepair} are marked for compaction before calling this.
|
CompactionManager.AllSSTableOpStatus |
CompactionManager.performCleanup(ColumnFamilyStore cfStore,
int jobs) |
void |
CompactionManager.performMaximal(ColumnFamilyStore cfStore) |
CompactionManager.AllSSTableOpStatus |
CompactionManager.performScrub(ColumnFamilyStore cfs,
boolean skipCorrupted,
boolean checkData,
boolean reinsertOverflowedTTLRows,
int jobs) |
CompactionManager.AllSSTableOpStatus |
CompactionManager.performScrub(ColumnFamilyStore cfs,
boolean skipCorrupted,
boolean checkData,
int jobs)
Deprecated.
|
CompactionManager.AllSSTableOpStatus |
CompactionManager.performSSTableRewrite(ColumnFamilyStore cfs,
boolean excludeCurrentVersion,
int jobs) |
com.google.common.util.concurrent.ListenableFuture<?> |
CompactionManager.submitAntiCompaction(ColumnFamilyStore cfs,
java.util.Collection<Range<Token>> ranges,
Refs<SSTableReader> sstables,
long repairedAt) |
java.util.List<java.util.concurrent.Future<?>> |
CompactionManager.submitBackground(ColumnFamilyStore cfs)
Call this whenever a compaction might be needed on the given columnfamily.
|
java.util.List<java.util.concurrent.Future<?>> |
CompactionManager.submitMaximal(ColumnFamilyStore cfStore,
int gcBefore) |
java.util.concurrent.Future<?> |
CompactionManager.submitUserDefined(ColumnFamilyStore cfs,
java.util.Collection<Descriptor> dataFiles,
int gcBefore) |
java.util.concurrent.Future<java.lang.Object> |
CompactionManager.submitValidation(ColumnFamilyStore cfStore,
Validator validator)
Does not mutate data, so is not scheduled.
|
Modifier and Type | Method and Description |
---|---|
void |
CompactionManager.interruptCompactionForCFs(java.lang.Iterable<ColumnFamilyStore> cfss,
boolean interruptValidation) |
boolean |
CompactionManager.isCompacting(java.lang.Iterable<ColumnFamilyStore> cfses) |
void |
CompactionManager.waitForCessation(java.lang.Iterable<ColumnFamilyStore> cfss) |
Constructor and Description |
---|
AbstractCompactionStrategy(ColumnFamilyStore cfs,
java.util.Map<java.lang.String,java.lang.String> options) |
AbstractCompactionTask(ColumnFamilyStore cfs,
java.util.Set<SSTableReader> sstables) |
CompactionController(ColumnFamilyStore cfs,
int maxValue) |
CompactionController(ColumnFamilyStore cfs,
java.util.Set<SSTableReader> compacting,
int gcBefore) |
CompactionTask(ColumnFamilyStore cfs,
java.lang.Iterable<SSTableReader> sstables,
int gcBefore,
boolean offline) |
DateTieredCompactionStrategy(ColumnFamilyStore cfs,
java.util.Map<java.lang.String,java.lang.String> options) |
LeveledCompactionStrategy(ColumnFamilyStore cfs,
java.util.Map<java.lang.String,java.lang.String> options) |
LeveledCompactionTask(ColumnFamilyStore cfs,
java.util.Collection<SSTableReader> sstables,
int level,
int gcBefore,
long maxSSTableBytes) |
Scrubber(ColumnFamilyStore cfs,
SSTableReader sstable,
boolean skipCorrupted,
boolean isOffline,
boolean checkData) |
Scrubber(ColumnFamilyStore cfs,
SSTableReader sstable,
boolean skipCorrupted,
boolean isOffline,
boolean checkData,
boolean reinsertOverflowedTTLRows) |
Scrubber(ColumnFamilyStore cfs,
SSTableReader sstable,
boolean skipCorrupted,
OutputHandler outputHandler,
boolean isOffline,
boolean checkData,
boolean reinsertOverflowedTTLRows) |
SizeTieredCompactionStrategy(ColumnFamilyStore cfs,
java.util.Map<java.lang.String,java.lang.String> options) |
SplitController(ColumnFamilyStore cfs) |
SplittingCompactionTask(ColumnFamilyStore cfs,
SSTableReader sstable,
int sstableSizeInMB) |
SSTableSplitter(ColumnFamilyStore cfs,
SSTableReader sstable,
int sstableSizeInMB) |
Upgrader(ColumnFamilyStore cfs,
SSTableReader sstable,
OutputHandler outputHandler) |
WrappingCompactionStrategy(ColumnFamilyStore cfs) |
Modifier and Type | Field and Description |
---|---|
ColumnFamilyStore |
ExtendedFilter.cfs |
Modifier and Type | Method and Description |
---|---|
static ExtendedFilter |
ExtendedFilter.create(ColumnFamilyStore cfs,
DataRange dataRange,
java.util.List<IndexExpression> clause,
int maxResults,
boolean countCQL3Rows,
long timestamp) |
Constructor and Description |
---|
ExtendedFilter(ColumnFamilyStore cfs,
DataRange dataRange,
int maxResults,
boolean countCQL3Rows,
long timestamp) |
WithClauses(ColumnFamilyStore cfs,
DataRange range,
java.util.List<IndexExpression> clause,
int maxResults,
boolean countCQL3Rows,
long timestamp) |
Modifier and Type | Field and Description |
---|---|
protected ColumnFamilyStore |
SecondaryIndex.baseCfs
Base CF that has many indexes
|
ColumnFamilyStore |
SecondaryIndexManager.baseCfs
The underlying column family containing the source data for these indexes
|
protected ColumnFamilyStore |
SecondaryIndexSearcher.baseCfs |
protected ColumnFamilyStore |
AbstractSimplePerColumnSecondaryIndex.indexCfs |
Modifier and Type | Method and Description |
---|---|
ColumnFamilyStore |
SecondaryIndex.getBaseCfs() |
ColumnFamilyStore |
AbstractSimplePerColumnSecondaryIndex.getIndexCfs() |
abstract ColumnFamilyStore |
SecondaryIndex.getIndexCfs()
Allow access to the underlying column family store if there is one
|
Modifier and Type | Method and Description |
---|---|
java.util.Set<ColumnFamilyStore> |
SecondaryIndexManager.getIndexesBackedByCfs() |
Modifier and Type | Method and Description |
---|---|
static SecondaryIndex |
SecondaryIndex.createInstance(ColumnFamilyStore baseCfs,
ColumnDefinition cdef)
This is the primary way to create a secondary index instance for a CF column.
|
Constructor and Description |
---|
SecondaryIndexBuilder(ColumnFamilyStore cfs,
java.util.Set<java.lang.String> idxNames,
ReducingKeyIterator iter) |
SecondaryIndexManager(ColumnFamilyStore baseCfs) |
Modifier and Type | Method and Description |
---|---|
SSTableReader |
SSTableReader.cloneWithNewSummarySamplingLevel(ColumnFamilyStore parent,
int samplingLevel)
Returns a new SSTableReader with the same properties as this SSTableReader except that a new IndexSummary will
be built at the target samplingLevel.
|
Constructor and Description |
---|
SSTableRewriter(ColumnFamilyStore cfs,
java.util.Set<SSTableReader> rewriting,
long maxAge,
boolean isOffline) |
SSTableRewriter(ColumnFamilyStore cfs,
java.util.Set<SSTableReader> rewriting,
long maxAge,
boolean isOffline,
boolean shouldOpenEarly) |
SSTableRewriter(ColumnFamilyStore cfs,
java.util.Set<SSTableReader> rewriting,
long maxAge,
boolean isOffline,
long preemptiveOpenInterval) |
Constructor and Description |
---|
ColumnFamilyMetrics(ColumnFamilyStore cfs)
Creates metrics for given
ColumnFamilyStore . |
Modifier and Type | Method and Description |
---|---|
void |
Validator.prepare(ColumnFamilyStore cfs,
MerkleTree tree) |
Modifier and Type | Field and Description |
---|---|
java.util.Map<java.util.UUID,ColumnFamilyStore> |
ActiveRepairService.ParentRepairSession.columnFamilyStores |
Modifier and Type | Method and Description |
---|---|
java.lang.Iterable<ColumnFamilyStore> |
StorageService.getValidColumnFamilies(boolean allowIndexes,
boolean autoAddIndexes,
java.lang.String keyspaceName,
java.lang.String... cfNames) |
Modifier and Type | Method and Description |
---|---|
java.util.concurrent.Future<Pair<CounterCacheKey,ClockAndCount>> |
CacheService.CounterCacheSerializer.deserialize(java.io.DataInputStream in,
ColumnFamilyStore cfs) |
java.util.concurrent.Future<Pair<RowCacheKey,IRowCacheEntry>> |
CacheService.RowCacheSerializer.deserialize(java.io.DataInputStream in,
ColumnFamilyStore cfs) |
java.util.concurrent.Future<Pair<KeyCacheKey,RowIndexEntry>> |
CacheService.KeyCacheSerializer.deserialize(java.io.DataInputStream input,
ColumnFamilyStore cfs) |
void |
CacheService.CounterCacheSerializer.serialize(CounterCacheKey key,
DataOutputPlus out,
ColumnFamilyStore cfs) |
void |
CacheService.KeyCacheSerializer.serialize(KeyCacheKey key,
DataOutputPlus out,
ColumnFamilyStore cfs) |
void |
CacheService.RowCacheSerializer.serialize(RowCacheKey key,
DataOutputPlus out,
ColumnFamilyStore cfs) |
Modifier and Type | Method and Description |
---|---|
java.util.UUID |
ActiveRepairService.prepareForRepair(java.net.InetAddress coordinator,
java.util.Set<java.net.InetAddress> endpoints,
java.util.Collection<Range<Token>> ranges,
java.util.List<ColumnFamilyStore> columnFamilyStores) |
void |
ActiveRepairService.registerParentRepairSession(java.util.UUID parentRepairSession,
java.net.InetAddress coordinator,
java.util.List<ColumnFamilyStore> columnFamilyStores,
java.util.Collection<Range<Token>> ranges) |
Constructor and Description |
---|
ParentRepairSession(java.net.InetAddress coordinator,
java.util.List<ColumnFamilyStore> columnFamilyStores,
java.util.Collection<Range<Token>> ranges,
long repairedAt) |
ParentRepairSession(java.net.InetAddress coordinator,
java.util.List<ColumnFamilyStore> columnFamilyStores,
java.util.Collection<Range<Token>> ranges,
long repairedAt,
boolean failed) |
Modifier and Type | Method and Description |
---|---|
static java.util.Iterator<ColumnFamily> |
QueryPagers.pageRowLocally(ColumnFamilyStore cfs,
java.nio.ByteBuffer key,
int pageSize)
Convenience method to (locally) page an internal row.
|
Modifier and Type | Method and Description |
---|---|
protected SSTableWriter |
StreamReader.createWriter(ColumnFamilyStore cfs,
long totalSize,
long repairedAt) |
protected void |
StreamReader.writeRow(DecoratedKey key,
SSTableWriter writer,
java.io.DataInput in,
ColumnFamilyStore cfs) |
Modifier and Type | Method and Description |
---|---|
static java.util.List<StreamSession.SSTableStreamingSections> |
StreamSession.getSSTableSectionsForRanges(java.util.Collection<Range<Token>> ranges,
java.util.Collection<ColumnFamilyStore> stores,
long overriddenRepairedAt,
boolean isIncremental) |
Copyright © 2020 The Apache Software Foundation