Modifier and Type | Field and Description |
---|---|
static com.google.common.base.Function<View,java.util.List<SSTableReader>> |
ColumnFamilyStore.CANONICAL_SSTABLES |
Refs<SSTableReader> |
ColumnFamilyStore.RefViewFragment.refs |
java.util.List<SSTableReader> |
ColumnFamilyStore.ViewFragment.sstables |
static com.google.common.base.Function<View,java.util.List<SSTableReader>> |
ColumnFamilyStore.UNREPAIRED_SSTABLES |
Modifier and Type | Method and Description |
---|---|
SSTableReader |
Memtable.flush() |
SSTableReader |
ColumnFamilyStore.getMaxSizeFile(java.lang.Iterable<SSTableReader> sstables) |
Modifier and Type | Method and Description |
---|---|
java.util.List<SSTableReader> |
Keyspace.getAllSSTables() |
Refs<SSTableReader> |
ColumnFamilyStore.getAndReferenceOverlappingSSTables(java.lang.Iterable<SSTableReader> sstables)
like getOverlappingSSTables, but acquires references before returning
|
java.util.Collection<SSTableReader> |
ColumnFamilyStore.getOverlappingSSTables(java.lang.Iterable<SSTableReader> sstables) |
java.lang.Iterable<SSTableReader> |
ColumnFamilyStore.getPermittedToCompactSSTables() |
java.util.Set<SSTableReader> |
ColumnFamilyStore.getRepairedSSTables() |
Refs<SSTableReader> |
ColumnFamilyStore.getSnapshotSSTableReader(java.lang.String tag) |
java.util.Collection<SSTableReader> |
ColumnFamilyStore.getSSTables() |
java.util.Set<SSTableReader> |
ColumnFamilyStore.getUncompactingSSTables() |
java.util.Set<SSTableReader> |
ColumnFamilyStore.getUnrepairedSSTables() |
java.util.Set<SSTableReader> |
ColumnFamilyStore.snapshot(java.lang.String snapshotName)
Take a snap shot of this columnfamily store.
|
java.util.Set<SSTableReader> |
ColumnFamilyStore.snapshot(java.lang.String snapshotName,
com.google.common.base.Predicate<SSTableReader> predicate,
boolean ephemeral) |
java.util.Set<SSTableReader> |
ColumnFamilyStore.snapshotWithoutFlush(java.lang.String snapshotName,
com.google.common.base.Predicate<SSTableReader> predicate,
boolean ephemeral) |
com.google.common.base.Function<View,java.util.List<SSTableReader>> |
ColumnFamilyStore.viewFilter(AbstractBounds<RowPosition> rowBounds) |
com.google.common.base.Function<View,java.util.List<SSTableReader>> |
ColumnFamilyStore.viewFilter(java.util.Collection<AbstractBounds<RowPosition>> rowBoundsCollection,
boolean includeRepaired) |
com.google.common.base.Function<View,java.util.List<SSTableReader>> |
ColumnFamilyStore.viewFilter(DecoratedKey key) |
Modifier and Type | Method and Description |
---|---|
void |
ColumnFamilyStore.addSSTable(SSTableReader sstable) |
Modifier and Type | Method and Description |
---|---|
void |
ColumnFamilyStore.addSSTables(java.util.Collection<SSTableReader> sstables) |
Refs<SSTableReader> |
ColumnFamilyStore.getAndReferenceOverlappingSSTables(java.lang.Iterable<SSTableReader> sstables)
like getOverlappingSSTables, but acquires references before returning
|
long |
ColumnFamilyStore.getExpectedCompactedFileSize(java.lang.Iterable<SSTableReader> sstables,
OperationType operation)
Calculate expected file size of SSTable after compaction.
|
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.
|
SSTableReader |
ColumnFamilyStore.getMaxSizeFile(java.lang.Iterable<SSTableReader> sstables) |
java.util.Collection<SSTableReader> |
ColumnFamilyStore.getOverlappingSSTables(java.lang.Iterable<SSTableReader> sstables) |
void |
ColumnFamilyStore.markObsolete(java.util.Collection<SSTableReader> sstables,
OperationType compactionType) |
ColumnFamilyStore.ViewFragment |
ColumnFamilyStore.select(com.google.common.base.Function<View,java.util.List<SSTableReader>> filter) |
ColumnFamilyStore.RefViewFragment |
ColumnFamilyStore.selectAndReference(com.google.common.base.Function<View,java.util.List<SSTableReader>> filter) |
java.util.Set<SSTableReader> |
ColumnFamilyStore.snapshot(java.lang.String snapshotName,
com.google.common.base.Predicate<SSTableReader> predicate,
boolean ephemeral) |
java.util.Set<SSTableReader> |
ColumnFamilyStore.snapshotWithoutFlush(java.lang.String snapshotName,
com.google.common.base.Predicate<SSTableReader> predicate,
boolean ephemeral) |
static java.util.UUID |
SystemKeyspace.startCompaction(ColumnFamilyStore cfs,
java.lang.Iterable<SSTableReader> toCompact)
Write compaction log, except columfamilies under system keyspace.
|
Constructor and Description |
---|
RefViewFragment(java.util.List<SSTableReader> sstables,
java.lang.Iterable<Memtable> memtables,
Refs<SSTableReader> refs) |
RefViewFragment(java.util.List<SSTableReader> sstables,
java.lang.Iterable<Memtable> memtables,
Refs<SSTableReader> refs) |
ViewFragment(java.util.List<SSTableReader> sstables,
java.lang.Iterable<Memtable> memtables) |
Constructor and Description |
---|
ReplayFilter(java.lang.Iterable<SSTableReader> onDisk,
ReplayPosition truncatedAt) |
Modifier and Type | Field and Description |
---|---|
java.util.Collection<SSTableReader> |
LeveledManifest.CompactionCandidate.sstables |
Modifier and Type | Method and Description |
---|---|
SSTableReader |
Scrubber.getNewInOrderSSTable() |
SSTableReader |
Scrubber.getNewSSTable() |
Modifier and Type | Method and Description |
---|---|
static java.util.List<Pair<SSTableReader,java.lang.Long>> |
SizeTieredCompactionStrategy.createSSTableAndLengthPairs(java.lang.Iterable<SSTableReader> sstables) |
static java.util.List<Pair<SSTableReader,java.lang.Long>> |
DateTieredCompactionStrategy.createSSTableAndMinTimestampPairs(java.lang.Iterable<SSTableReader> sstables) |
java.util.List<SSTableReader> |
AbstractCompactionStrategy.filterSSTablesForReads(java.util.List<SSTableReader> sstables) |
java.util.List<SSTableReader> |
WrappingCompactionStrategy.filterSSTablesForReads(java.util.List<SSTableReader> sstables) |
static java.lang.Iterable<SSTableReader> |
AbstractCompactionStrategy.filterSuspectSSTables(java.lang.Iterable<SSTableReader> originalCandidates)
Filters SSTables that are to be excluded from the given collection
|
java.lang.Iterable<SSTableReader> |
LeveledManifest.getAllSSTables() |
java.util.Set<SSTableReader> |
CompactionController.getFullyExpiredSSTables() |
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.
|
java.util.List<SSTableReader> |
LeveledManifest.getLevel(int i) |
java.util.SortedSet<SSTableReader> |
LeveledManifest.getLevelSorted(int level,
java.util.Comparator<SSTableReader> comparator) |
java.util.Collection<java.util.Collection<SSTableReader>> |
AbstractCompactionStrategy.groupSSTablesForAntiCompaction(java.util.Collection<SSTableReader> sstablesToGroup)
Method for grouping similar SSTables together, This will be used by
anti-compaction to determine which SSTables should be anitcompacted
as a group.
|
java.util.Collection<java.util.Collection<SSTableReader>> |
DateTieredCompactionStrategy.groupSSTablesForAntiCompaction(java.util.Collection<SSTableReader> sstablesToGroup)
DTCS should not group sstables for anticompaction - this can mix new and old data
|
java.util.Collection<java.util.Collection<SSTableReader>> |
LeveledCompactionStrategy.groupSSTablesForAntiCompaction(java.util.Collection<SSTableReader> ssTablesToGroup)
Leveled compaction strategy has guarantees on the data contained within each level so we
have to make sure we only create groups of SSTables with members from the same level.
|
java.util.Collection<java.util.Collection<SSTableReader>> |
WrappingCompactionStrategy.groupSSTablesForAntiCompaction(java.util.Collection<SSTableReader> sstablesToGroup) |
static java.util.List<SSTableReader> |
SizeTieredCompactionStrategy.mostInterestingBucket(java.util.List<java.util.List<SSTableReader>> buckets,
int minThreshold,
int maxThreshold) |
java.util.List<SSTableReader> |
CompactionManager.runIndexSummaryRedistribution(IndexSummaryRedistribution redistribution) |
Modifier and Type | Method and Description |
---|---|
void |
LeveledManifest.add(SSTableReader reader) |
abstract void |
AbstractCompactionStrategy.addSSTable(SSTableReader added) |
void |
DateTieredCompactionStrategy.addSSTable(SSTableReader sstable) |
void |
LeveledCompactionStrategy.addSSTable(SSTableReader added) |
void |
SizeTieredCompactionStrategy.addSSTable(SSTableReader added) |
void |
WrappingCompactionStrategy.addSSTable(SSTableReader added) |
static SSTableWriter |
CompactionManager.createWriter(ColumnFamilyStore cfs,
java.io.File compactionFileLocation,
long expectedBloomFilterSize,
long repairedAt,
SSTableReader sstable) |
static boolean |
CompactionManager.needsCleanup(SSTableReader sstable,
java.util.Collection<Range<Token>> ownedRanges)
Determines if a cleanup would actually remove any data in this SSTable based
on a set of owned ranges.
|
int |
LeveledManifest.remove(SSTableReader reader) |
abstract void |
AbstractCompactionStrategy.removeSSTable(SSTableReader sstable) |
void |
DateTieredCompactionStrategy.removeSSTable(SSTableReader sstable) |
void |
LeveledCompactionStrategy.removeSSTable(SSTableReader sstable) |
void |
SizeTieredCompactionStrategy.removeSSTable(SSTableReader sstable) |
void |
WrappingCompactionStrategy.removeSSTable(SSTableReader sstable) |
void |
AbstractCompactionStrategy.replaceFlushed(Memtable memtable,
SSTableReader sstable)
Handle a flushed memtable.
|
protected boolean |
AbstractCompactionStrategy.worthDroppingTombstones(SSTableReader sstable,
int gcBefore)
Check if given sstable is worth dropping tombstones at gcBefore.
|
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 java.util.List<Pair<SSTableReader,java.lang.Long>> |
SizeTieredCompactionStrategy.createSSTableAndLengthPairs(java.lang.Iterable<SSTableReader> sstables) |
static java.util.List<Pair<SSTableReader,java.lang.Long>> |
DateTieredCompactionStrategy.createSSTableAndMinTimestampPairs(java.lang.Iterable<SSTableReader> sstables) |
static SSTableWriter |
CompactionManager.createWriterForAntiCompaction(ColumnFamilyStore cfs,
java.io.File compactionFileLocation,
int expectedBloomFilterSize,
long repairedAt,
java.util.Collection<SSTableReader> sstables) |
java.util.List<SSTableReader> |
AbstractCompactionStrategy.filterSSTablesForReads(java.util.List<SSTableReader> sstables) |
java.util.List<SSTableReader> |
WrappingCompactionStrategy.filterSSTablesForReads(java.util.List<SSTableReader> sstables) |
static java.lang.Iterable<SSTableReader> |
AbstractCompactionStrategy.filterSuspectSSTables(java.lang.Iterable<SSTableReader> originalCandidates)
Filters SSTables that are to be excluded from the given collection
|
abstract CompactionAwareWriter |
AbstractCompactionTask.getCompactionAwareWriter(ColumnFamilyStore cfs,
LifecycleTransaction txn,
java.util.Set<SSTableReader> nonExpiredSSTables) |
CompactionAwareWriter |
CompactionTask.getCompactionAwareWriter(ColumnFamilyStore cfs,
LifecycleTransaction transaction,
java.util.Set<SSTableReader> nonExpiredSSTables) |
CompactionAwareWriter |
LeveledCompactionTask.getCompactionAwareWriter(ColumnFamilyStore cfs,
LifecycleTransaction txn,
java.util.Set<SSTableReader> nonExpiredSSTables) |
CompactionAwareWriter |
SSTableSplitter.SplittingCompactionTask.getCompactionAwareWriter(ColumnFamilyStore cfs,
LifecycleTransaction txn,
java.util.Set<SSTableReader> nonExpiredSSTables) |
protected CompactionController |
CompactionTask.getCompactionController(java.util.Set<SSTableReader> toCompact) |
protected CompactionController |
SSTableSplitter.SplittingCompactionTask.getCompactionController(java.util.Set<SSTableReader> toCompact) |
static SSTableFormat.Type |
CompactionTask.getFormatType(java.util.Collection<SSTableReader> sstables) |
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.
|
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.
|
java.util.SortedSet<SSTableReader> |
LeveledManifest.getLevelSorted(int level,
java.util.Comparator<SSTableReader> comparator) |
static long |
CompactionTask.getMaxDataAge(java.util.Collection<SSTableReader> sstables) |
static long |
CompactionTask.getMinRepairedAt(java.util.Set<SSTableReader> actuallyCompact) |
int |
LeveledManifest.getNextLevel(java.util.Collection<SSTableReader> sstables) |
AbstractCompactionStrategy.ScannerList |
AbstractCompactionStrategy.getScanners(java.util.Collection<SSTableReader> toCompact) |
AbstractCompactionStrategy.ScannerList |
AbstractCompactionStrategy.getScanners(java.util.Collection<SSTableReader> sstables,
Range<Token> range)
Returns a list of KeyScanners given sstables and a range on which to scan.
|
AbstractCompactionStrategy.ScannerList |
LeveledCompactionStrategy.getScanners(java.util.Collection<SSTableReader> sstables,
Range<Token> range) |
AbstractCompactionStrategy.ScannerList |
WrappingCompactionStrategy.getScanners(java.util.Collection<SSTableReader> sstables,
Range<Token> range) |
abstract AbstractCompactionTask |
AbstractCompactionStrategy.getUserDefinedTask(java.util.Collection<SSTableReader> sstables,
int gcBefore) |
AbstractCompactionTask |
DateTieredCompactionStrategy.getUserDefinedTask(java.util.Collection<SSTableReader> sstables,
int gcBefore) |
AbstractCompactionTask |
LeveledCompactionStrategy.getUserDefinedTask(java.util.Collection<SSTableReader> sstables,
int gcBefore) |
AbstractCompactionTask |
SizeTieredCompactionStrategy.getUserDefinedTask(java.util.Collection<SSTableReader> sstables,
int gcBefore) |
AbstractCompactionTask |
WrappingCompactionStrategy.getUserDefinedTask(java.util.Collection<SSTableReader> sstables,
int gcBefore) |
java.util.Collection<java.util.Collection<SSTableReader>> |
AbstractCompactionStrategy.groupSSTablesForAntiCompaction(java.util.Collection<SSTableReader> sstablesToGroup)
Method for grouping similar SSTables together, This will be used by
anti-compaction to determine which SSTables should be anitcompacted
as a group.
|
java.util.Collection<java.util.Collection<SSTableReader>> |
DateTieredCompactionStrategy.groupSSTablesForAntiCompaction(java.util.Collection<SSTableReader> sstablesToGroup)
DTCS should not group sstables for anticompaction - this can mix new and old data
|
java.util.Collection<java.util.Collection<SSTableReader>> |
LeveledCompactionStrategy.groupSSTablesForAntiCompaction(java.util.Collection<SSTableReader> ssTablesToGroup)
Leveled compaction strategy has guarantees on the data contained within each level so we
have to make sure we only create groups of SSTables with members from the same level.
|
java.util.Collection<java.util.Collection<SSTableReader>> |
WrappingCompactionStrategy.groupSSTablesForAntiCompaction(java.util.Collection<SSTableReader> sstablesToGroup) |
static java.util.List<SSTableReader> |
SizeTieredCompactionStrategy.mostInterestingBucket(java.util.List<java.util.List<SSTableReader>> buckets,
int minThreshold,
int maxThreshold) |
void |
CompactionManager.performAnticompaction(ColumnFamilyStore cfs,
java.util.Collection<Range<Token>> ranges,
Refs<SSTableReader> validatedForRepair,
LifecycleTransaction txn,
long repairedAt)
Make sure the {validatedForRepair} are marked for compaction before calling this.
|
void |
LeveledManifest.replace(java.util.Collection<SSTableReader> removed,
java.util.Collection<SSTableReader> added) |
void |
LeveledManifest.replace(java.util.Collection<SSTableReader> removed,
java.util.Collection<SSTableReader> added) |
void |
AbstractCompactionStrategy.replaceSSTables(java.util.Collection<SSTableReader> removed,
java.util.Collection<SSTableReader> added) |
void |
AbstractCompactionStrategy.replaceSSTables(java.util.Collection<SSTableReader> removed,
java.util.Collection<SSTableReader> added) |
void |
LeveledCompactionStrategy.replaceSSTables(java.util.Collection<SSTableReader> removed,
java.util.Collection<SSTableReader> added) |
void |
LeveledCompactionStrategy.replaceSSTables(java.util.Collection<SSTableReader> removed,
java.util.Collection<SSTableReader> added) |
void |
WrappingCompactionStrategy.replaceSSTables(java.util.Collection<SSTableReader> removed,
java.util.Collection<SSTableReader> added) |
void |
WrappingCompactionStrategy.replaceSSTables(java.util.Collection<SSTableReader> removed,
java.util.Collection<SSTableReader> added) |
com.google.common.util.concurrent.ListenableFuture<?> |
CompactionManager.submitAntiCompaction(ColumnFamilyStore cfs,
java.util.Collection<Range<Token>> ranges,
Refs<SSTableReader> sstables,
long repairedAt)
Submit anti-compactions for a collection of SSTables over a set of repaired ranges and marks corresponding SSTables
as repaired.
|
Constructor and Description |
---|
Verifier(ColumnFamilyStore cfs,
SSTableReader sstable,
boolean isOffline) |
Verifier(ColumnFamilyStore cfs,
SSTableReader sstable,
OutputHandler outputHandler,
boolean isOffline) |
Constructor and Description |
---|
CompactionCandidate(java.util.Collection<SSTableReader> sstables,
int level,
long maxSSTableBytes) |
CompactionController(ColumnFamilyStore cfs,
java.util.Set<SSTableReader> compacting,
int gcBefore) |
Modifier and Type | Field and Description |
---|---|
protected java.util.Set<SSTableReader> |
CompactionAwareWriter.nonExpiredSSTables |
Modifier and Type | Method and Description |
---|---|
java.util.List<SSTableReader> |
CompactionAwareWriter.finish()
we are done, return the finished sstables so that the caller can mark the old ones as compacted
|
Constructor and Description |
---|
CompactionAwareWriter(ColumnFamilyStore cfs,
LifecycleTransaction txn,
java.util.Set<SSTableReader> nonExpiredSSTables,
boolean offline) |
DefaultCompactionWriter(ColumnFamilyStore cfs,
LifecycleTransaction txn,
java.util.Set<SSTableReader> nonExpiredSSTables,
boolean offline,
OperationType compactionType) |
MajorLeveledCompactionWriter(ColumnFamilyStore cfs,
LifecycleTransaction txn,
java.util.Set<SSTableReader> nonExpiredSSTables,
long maxSSTableSize,
boolean offline,
OperationType compactionType) |
MaxSSTableSizeWriter(ColumnFamilyStore cfs,
LifecycleTransaction txn,
java.util.Set<SSTableReader> nonExpiredSSTables,
long maxSSTableSize,
int level,
boolean offline,
OperationType compactionType) |
SplittingSizeTieredCompactionWriter(ColumnFamilyStore cfs,
LifecycleTransaction txn,
java.util.Set<SSTableReader> nonExpiredSSTables,
OperationType compactionType) |
SplittingSizeTieredCompactionWriter(ColumnFamilyStore cfs,
LifecycleTransaction txn,
java.util.Set<SSTableReader> nonExpiredSSTables,
OperationType compactionType,
long smallestSSTable) |
Modifier and Type | Method and Description |
---|---|
OnDiskAtomIterator |
QueryFilter.getSSTableColumnIterator(SSTableReader sstable) |
OnDiskAtomIterator |
IDiskAtomFilter.getSSTableColumnIterator(SSTableReader sstable,
DecoratedKey key)
returns an iterator that returns columns from the given SSTable
matching the Filter criteria in sorted order.
|
OnDiskAtomIterator |
NamesQueryFilter.getSSTableColumnIterator(SSTableReader sstable,
DecoratedKey key) |
OnDiskAtomIterator |
SliceQueryFilter.getSSTableColumnIterator(SSTableReader sstable,
DecoratedKey key) |
OnDiskAtomIterator |
IDiskAtomFilter.getSSTableColumnIterator(SSTableReader sstable,
FileDataInput file,
DecoratedKey key,
RowIndexEntry indexEntry)
Get an iterator that returns columns from the given SSTable using the opened file
matching the Filter criteria in sorted order.
|
OnDiskAtomIterator |
NamesQueryFilter.getSSTableColumnIterator(SSTableReader sstable,
FileDataInput file,
DecoratedKey key,
RowIndexEntry indexEntry) |
OnDiskAtomIterator |
SliceQueryFilter.getSSTableColumnIterator(SSTableReader sstable,
FileDataInput file,
DecoratedKey key,
RowIndexEntry indexEntry) |
boolean |
IDiskAtomFilter.shouldInclude(SSTableReader sstable) |
boolean |
NamesQueryFilter.shouldInclude(SSTableReader sstable) |
boolean |
QueryFilter.shouldInclude(SSTableReader sstable) |
boolean |
SliceQueryFilter.shouldInclude(SSTableReader sstable) |
Modifier and Type | Method and Description |
---|---|
void |
SecondaryIndexManager.maybeBuildSecondaryIndexes(java.util.Collection<SSTableReader> sstables,
java.util.Set<java.lang.String> idxNames)
Does a full, blocking rebuild of the indexes specified by columns from the sstables.
|
Modifier and Type | Field and Description |
---|---|
java.util.Set<SSTableReader> |
View.compacting |
java.util.Set<SSTableReader> |
View.premature |
java.util.Set<SSTableReader> |
View.sstables |
java.util.Map<SSTableReader,SSTableReader> |
View.sstablesMap |
java.util.Map<SSTableReader,SSTableReader> |
View.sstablesMap |
Modifier and Type | Method and Description |
---|---|
SSTableReader |
LifecycleTransaction.current(SSTableReader reader)
return the current version of the provided reader, whether or not it is visible or staged;
i.e.
|
SSTableReader |
LifecycleTransaction.onlyOne() |
static SSTableReader |
LifecycleTransaction.ReaderState.visible(SSTableReader reader,
com.google.common.base.Predicate<SSTableReader> obsolete,
java.util.Collection<SSTableReader>... selectFrom) |
Modifier and Type | Method and Description |
---|---|
static java.util.List<Interval<RowPosition,SSTableReader>> |
SSTableIntervalTree.buildIntervals(java.lang.Iterable<SSTableReader> sstables) |
java.lang.Iterable<SSTableReader> |
LifecycleTransaction.current()
returns the currently visible readers managed by this transaction
|
java.util.Set<SSTableReader> |
Tracker.getCompacting() |
java.lang.Iterable<SSTableReader> |
Tracker.getPermittedToCompact() |
java.util.Set<SSTableReader> |
Tracker.getSSTables() |
java.util.Set<SSTableReader> |
Tracker.getUncompacting() |
java.lang.Iterable<SSTableReader> |
Tracker.getUncompacting(java.lang.Iterable<SSTableReader> candidates) |
java.lang.Iterable<SSTableReader> |
View.getUncompacting(java.lang.Iterable<SSTableReader> candidates) |
com.google.common.collect.Sets.SetView<SSTableReader> |
View.nonCompactingSStables() |
java.util.Set<SSTableReader> |
LifecycleTransaction.originals()
the set of readers guarded by this transaction _in their original instance/state_
call current(SSTableReader) on any reader in this set to get the latest instance
|
java.util.List<SSTableReader> |
View.sstablesInBounds(RowPosition left,
RowPosition right)
Returns the sstables that have any partition between
left and right , when both bounds are taken inclusively. |
static java.util.List<SSTableReader> |
View.sstablesInBounds(RowPosition left,
RowPosition right,
SSTableIntervalTree intervalTree) |
Modifier and Type | Method and Description |
---|---|
void |
LifecycleTransaction.cancel(SSTableReader cancel)
remove the reader from the set we're modifying
|
SSTableReader |
LifecycleTransaction.current(SSTableReader reader)
return the current version of the provided reader, whether or not it is visible or staged;
i.e.
|
boolean |
LifecycleTransaction.isObsolete(SSTableReader reader)
indicates if the reader has been marked for obsoletion
|
void |
Tracker.maybeIncrementallyBackup(SSTableReader sstable) |
void |
Tracker.notifyAdded(SSTableReader added) |
void |
Tracker.notifyDeleting(SSTableReader deleting) |
void |
LifecycleTransaction.obsolete(SSTableReader reader)
mark this reader as for obsoletion.
|
static LifecycleTransaction |
LifecycleTransaction.offline(OperationType operationType,
SSTableReader reader)
construct a Transaction for use in an offline operation
|
void |
Tracker.permitCompactionOfFlushed(SSTableReader sstable)
permit compaction of the provided sstable; this translates to notifying compaction
strategies of its existence, and potentially submitting a background task
|
void |
Tracker.replaceFlushed(Memtable memtable,
SSTableReader sstable) |
LifecycleTransaction.ReaderState |
LifecycleTransaction.state(SSTableReader reader) |
LifecycleTransaction |
Tracker.tryModify(SSTableReader sstable,
OperationType operationType) |
void |
LifecycleTransaction.update(SSTableReader reader,
boolean original)
update a reader: if !original, this is a reader that is being introduced by this transaction;
otherwise it must be in the originals() set, i.e.
|
static SSTableReader |
LifecycleTransaction.ReaderState.visible(SSTableReader reader,
com.google.common.base.Predicate<SSTableReader> obsolete,
java.util.Collection<SSTableReader>... selectFrom) |
Modifier and Type | Method and Description |
---|---|
void |
Tracker.addInitialSSTables(java.lang.Iterable<SSTableReader> sstables) |
void |
Tracker.addSSTables(java.lang.Iterable<SSTableReader> sstables) |
static SSTableIntervalTree |
SSTableIntervalTree.build(java.lang.Iterable<SSTableReader> sstables) |
static java.util.List<Interval<RowPosition,SSTableReader>> |
SSTableIntervalTree.buildIntervals(java.lang.Iterable<SSTableReader> sstables) |
void |
LifecycleTransaction.cancel(java.lang.Iterable<SSTableReader> cancels)
remove the readers from the set we're modifying
|
java.lang.Throwable |
Tracker.dropSSTables(com.google.common.base.Predicate<SSTableReader> remove,
OperationType operationType,
java.lang.Throwable accumulate)
removes all sstables that are not busy compacting.
|
java.lang.Iterable<SSTableReader> |
Tracker.getUncompacting(java.lang.Iterable<SSTableReader> candidates) |
java.lang.Iterable<SSTableReader> |
View.getUncompacting(java.lang.Iterable<SSTableReader> candidates) |
void |
Tracker.notifySSTableRepairedStatusChanged(java.util.Collection<SSTableReader> repairStatusesChanged) |
static LifecycleTransaction |
LifecycleTransaction.offline(OperationType operationType,
java.lang.Iterable<SSTableReader> readers)
construct a Transaction for use in an offline operation
|
LifecycleTransaction |
LifecycleTransaction.split(java.util.Collection<SSTableReader> readers)
remove the provided readers from this Transaction, and return a new Transaction to manage them
only permitted to be called if the current Transaction has never been used
|
LifecycleTransaction |
Tracker.tryModify(java.lang.Iterable<SSTableReader> sstables,
OperationType operationType) |
static SSTableReader |
LifecycleTransaction.ReaderState.visible(SSTableReader reader,
com.google.common.base.Predicate<SSTableReader> obsolete,
java.util.Collection<SSTableReader>... selectFrom) |
Constructor and Description |
---|
ReaderState(LifecycleTransaction.ReaderState.Action logged,
LifecycleTransaction.ReaderState.Action staged,
SSTableReader currentlyVisible,
SSTableReader nextVisible,
boolean original) |
Modifier and Type | Method and Description |
---|---|
java.util.List<SSTableReader> |
SSTableRewriter.finish()
Finishes the new file(s)
Creates final files, adds the new files to the Tracker (via replaceReader).
|
java.util.List<SSTableReader> |
SSTableRewriter.finished() |
protected java.util.Collection<SSTableReader> |
SSTableLoader.openSSTables(java.util.Map<java.net.InetAddress,java.util.Collection<Range<Token>>> ranges) |
java.util.List<SSTableReader> |
IndexSummaryRedistribution.redistributeSummaries() |
static java.util.List<SSTableReader> |
IndexSummaryManager.redistributeSummaries(IndexSummaryRedistribution redistribution)
Attempts to fairly distribute a fixed pool of memory for index summaries across a set of SSTables based on
their recent read rates.
|
Modifier and Type | Method and Description |
---|---|
static SSTableIdentityIterator |
SSTableIdentityIterator.createFragmentIterator(SSTableReader sstable,
RandomAccessReader file,
DecoratedKey key,
long dataSize,
boolean checkData)
Used only by scrubber to solve problems with data written after the END_OF_ROW marker.
|
Constructor and Description |
---|
SSTableIdentityIterator(SSTableReader sstable,
RandomAccessReader file,
DecoratedKey key)
Used to iterate through the columns of a row.
|
SSTableIdentityIterator(SSTableReader sstable,
RandomAccessReader file,
DecoratedKey key,
boolean checkData)
Used to iterate through the columns of a row.
|
Constructor and Description |
---|
IndexSummaryRedistribution(java.util.List<SSTableReader> compacting,
java.util.Map<java.util.UUID,LifecycleTransaction> transactions,
long memoryPoolBytes) |
ReducingKeyIterator(java.util.Collection<SSTableReader> sstables) |
Modifier and Type | Field and Description |
---|---|
protected SSTableReader |
SSTableWriter.TransactionalProxy.finalReader |
Modifier and Type | Field and Description |
---|---|
static java.util.Comparator<SSTableReader> |
SSTableReader.maxTimestampComparator |
static java.util.Comparator<SSTableReader> |
SSTableReader.sstableComparator |
static com.google.common.collect.Ordering<SSTableReader> |
SSTableReader.sstableOrdering |
Modifier and Type | Method and Description |
---|---|
SSTableReader |
SSTableReader.cloneWithNewStart(DecoratedKey newStart,
java.lang.Runnable runOnClose) |
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.
|
SSTableReader |
SSTableWriter.finish(boolean openResult) |
SSTableReader |
SSTableWriter.finish(long repairedAt,
long maxDataAge,
boolean openResult) |
SSTableReader |
SSTableWriter.finished()
Open the resultant SSTableReader once it has been fully written, and all related state
is ready to be finalised including other sstables being written involved in the same operation
|
static SSTableReader |
SSTableReader.internalOpen(Descriptor desc,
java.util.Set<Component> components,
CFMetaData metadata,
IPartitioner partitioner,
SegmentedFile ifile,
SegmentedFile dfile,
IndexSummary isummary,
IFilter bf,
long maxDataAge,
StatsMetadata sstableMetadata,
SSTableReader.OpenReason openReason)
Open a RowIndexedReader which already has its state initialized (by SSTableWriter).
|
static SSTableReader |
SSTableReader.open(Descriptor descriptor) |
static SSTableReader |
SSTableReader.open(Descriptor desc,
CFMetaData metadata) |
static SSTableReader |
SSTableReader.open(Descriptor descriptor,
java.util.Set<Component> components,
CFMetaData metadata,
IPartitioner partitioner) |
static SSTableReader |
SSTableReader.open(Descriptor descriptor,
java.util.Set<Component> components,
CFMetaData metadata,
IPartitioner partitioner,
boolean validate,
boolean trackHotness) |
abstract SSTableReader |
SSTableReader.Factory.open(Descriptor descriptor,
java.util.Set<Component> components,
CFMetaData metadata,
IPartitioner partitioner,
java.lang.Long maxDataAge,
StatsMetadata sstableMetadata,
SSTableReader.OpenReason openReason) |
abstract SSTableReader |
SSTableWriter.openEarly()
Open the resultant SSTableReader before it has been fully written
|
abstract SSTableReader |
SSTableWriter.openFinalEarly()
Open the resultant SSTableReader once it has been fully written, but before the
_set_ of tables that are being written together as one atomic operation are all ready
|
static SSTableReader |
SSTableReader.openForBatch(Descriptor descriptor,
java.util.Set<Component> components,
CFMetaData metadata,
IPartitioner partitioner)
Open SSTable reader to be used in batch mode(such as sstableloader).
|
static SSTableReader |
SSTableReader.openNoValidation(Descriptor descriptor,
java.util.Set<Component> components,
ColumnFamilyStore cfs) |
Modifier and Type | Method and Description |
---|---|
static java.util.Collection<SSTableReader> |
SSTableReader.openAll(java.util.Set<java.util.Map.Entry<Descriptor,java.util.Set<Component>>> entries,
CFMetaData metadata,
IPartitioner partitioner) |
Ref<SSTableReader> |
SSTableReader.ref() |
Ref<SSTableReader> |
SSTableReader.selfRef() |
Ref<SSTableReader> |
SSTableReader.tryRef() |
Modifier and Type | Method and Description |
---|---|
int |
SSTableReader.SizeComparator.compare(SSTableReader o1,
SSTableReader o2) |
Modifier and Type | Method and Description |
---|---|
static double |
SSTableReader.estimateCompactionGain(java.util.Set<SSTableReader> overlapping)
Estimates how much of the keys we would keep if the sstables were compacted together
|
static long |
SSTableReader.getApproximateKeyCount(java.util.Collection<SSTableReader> sstables)
Calculate approximate key count.
|
static long |
SSTableReader.getTotalBytes(java.lang.Iterable<SSTableReader> sstables) |
static long |
SSTableReader.getTotalUncompressedBytes(java.lang.Iterable<SSTableReader> sstables) |
Modifier and Type | Class and Description |
---|---|
class |
BigTableReader
SSTableReaders are open()ed by Keyspace.onStart; after that they are created by SSTableWriter.renameAndOpen.
|
Modifier and Type | Field and Description |
---|---|
SSTableReader |
BigTableScanner.sstable |
Modifier and Type | Method and Description |
---|---|
SSTableReader |
BigTableWriter.openEarly() |
SSTableReader |
BigTableWriter.openFinalEarly() |
Modifier and Type | Method and Description |
---|---|
static ISSTableScanner |
BigTableScanner.getScanner(SSTableReader sstable,
java.util.Collection<Range<Token>> tokenRanges,
com.google.common.util.concurrent.RateLimiter limiter) |
static ISSTableScanner |
BigTableScanner.getScanner(SSTableReader sstable,
DataRange dataRange,
com.google.common.util.concurrent.RateLimiter limiter) |
Constructor and Description |
---|
MetadataCollector(java.lang.Iterable<SSTableReader> sstables,
CellNameType columnNameComparator,
int level) |
MetadataCollector(java.lang.Iterable<SSTableReader> sstables,
CellNameType columnNameComparator,
int level,
boolean skipAncestors) |
Modifier and Type | Field and Description |
---|---|
SSTableReader |
SSTableAddedNotification.added |
SSTableReader |
SSTableDeletingNotification.deleting |
Modifier and Type | Field and Description |
---|---|
java.util.Collection<SSTableReader> |
SSTableListChangedNotification.added |
java.util.Collection<SSTableReader> |
SSTableListChangedNotification.removed |
java.util.Collection<SSTableReader> |
SSTableRepairStatusChanged.sstable |
Constructor and Description |
---|
SSTableAddedNotification(SSTableReader added) |
SSTableDeletingNotification(SSTableReader deleting) |
Constructor and Description |
---|
SSTableListChangedNotification(java.util.Collection<SSTableReader> added,
java.util.Collection<SSTableReader> removed,
OperationType compactionType) |
SSTableListChangedNotification(java.util.Collection<SSTableReader> added,
java.util.Collection<SSTableReader> removed,
OperationType compactionType) |
SSTableRepairStatusChanged(java.util.Collection<SSTableReader> repairStatusChanged) |
Modifier and Type | Method and Description |
---|---|
java.util.Set<SSTableReader> |
ActiveRepairService.currentlyRepairing(java.util.UUID cfId,
java.util.UUID parentRepairSession) |
Refs<SSTableReader> |
ActiveRepairService.ParentRepairSession.getActiveRepairedSSTableRefsForAntiCompaction(java.util.UUID cfId,
java.util.UUID parentSessionId)
Get the still active sstables we should run anticompaction on
note that validation and streaming do not call this method - they have to work on the actual active sstables on the node, we only call this
to know which sstables are still there that were there when we started the repair
|
Modifier and Type | Field and Description |
---|---|
protected SSTableReader |
StreamWriter.sstable |
Modifier and Type | Field and Description |
---|---|
Ref<SSTableReader> |
StreamSession.SSTableStreamingSections.ref |
Modifier and Type | Method and Description |
---|---|
void |
StreamTransferTask.addTransferFile(Ref<SSTableReader> ref,
long estimatedKeys,
java.util.List<Pair<java.lang.Long,java.lang.Long>> sections,
long repairedAt) |
Constructor and Description |
---|
StreamWriter(SSTableReader sstable,
java.util.Collection<Pair<java.lang.Long,java.lang.Long>> sections,
StreamSession session) |
Constructor and Description |
---|
SSTableStreamingSections(Ref<SSTableReader> ref,
java.util.List<Pair<java.lang.Long,java.lang.Long>> sections,
long estimatedKeys,
long repairedAt) |
Constructor and Description |
---|
CompressedStreamWriter(SSTableReader sstable,
java.util.Collection<Pair<java.lang.Long,java.lang.Long>> sections,
CompressionInfo compressionInfo,
StreamSession session) |
Constructor and Description |
---|
OutgoingFileMessage(Ref<SSTableReader> ref,
int sequenceNumber,
long estimatedKeys,
java.util.List<Pair<java.lang.Long,java.lang.Long>> sections,
long repairedAt,
boolean keepSSTableLevel) |
Modifier and Type | Method and Description |
---|---|
static com.google.common.collect.Multimap<SSTableReader,SSTableReader> |
SSTableExpiredBlockers.checkForExpiredSSTableBlockers(java.lang.Iterable<SSTableReader> sstables,
int gcBefore) |
static com.google.common.collect.Multimap<SSTableReader,SSTableReader> |
SSTableExpiredBlockers.checkForExpiredSSTableBlockers(java.lang.Iterable<SSTableReader> sstables,
int gcBefore) |
Modifier and Type | Method and Description |
---|---|
static com.google.common.collect.Multimap<SSTableReader,SSTableReader> |
SSTableExpiredBlockers.checkForExpiredSSTableBlockers(java.lang.Iterable<SSTableReader> sstables,
int gcBefore) |
Copyright © 2020 The Apache Software Foundation