Uses of Class
org.apache.cassandra.io.sstable.format.SSTableReader
-
-
Uses of SSTableReader in org.apache.cassandra.db
Fields in org.apache.cassandra.db with type parameters of type SSTableReader Modifier and Type Field Description Refs<SSTableReader>
ColumnFamilyStore.RefViewFragment. refs
java.util.List<SSTableReader>
ColumnFamilyStore.ViewFragment. sstables
Methods in org.apache.cassandra.db that return SSTableReader Modifier and Type Method Description SSTableReader
ColumnFamilyStore. getMaxSizeFile(java.lang.Iterable<SSTableReader> sstables)
Methods in org.apache.cassandra.db that return types with arguments of type SSTableReader Modifier and Type Method Description java.util.List<SSTableReader>
Keyspace. getAllSSTables(SSTableSet sstableSet)
Refs<SSTableReader>
ColumnFamilyStore. getAndReferenceOverlappingLiveSSTables(java.lang.Iterable<SSTableReader> sstables)
like getOverlappingSSTables, but acquires references before returningjava.util.Set<SSTableReader>
ColumnFamilyStore. getLiveSSTables()
java.util.Collection<SSTableReader>
ColumnFamilyStore. getOverlappingLiveSSTables(java.lang.Iterable<SSTableReader> sstables)
Refs<SSTableReader>
ColumnFamilyStore. getSnapshotSSTableReaders(java.lang.String tag)
java.lang.Iterable<SSTableReader>
ColumnFamilyStore. getSSTables(SSTableSet sstableSet)
java.lang.Iterable<SSTableReader>
ColumnFamilyStore. getUncompactingSSTables()
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, boolean skipFlush, com.google.common.util.concurrent.RateLimiter rateLimiter)
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, boolean skipFlush)
java.util.Set<SSTableReader>
ColumnFamilyStore. snapshot(java.lang.String snapshotName, com.google.common.base.Predicate<SSTableReader> predicate, boolean ephemeral, boolean skipFlush, com.google.common.util.concurrent.RateLimiter rateLimiter)
java.util.Set<SSTableReader>
ColumnFamilyStore. snapshotWithoutFlush(java.lang.String snapshotName, com.google.common.base.Predicate<SSTableReader> predicate, boolean ephemeral, com.google.common.util.concurrent.RateLimiter rateLimiter)
Method parameters in org.apache.cassandra.db with type arguments of type SSTableReader Modifier and Type Method Description void
ColumnFamilyStore. addSSTables(java.util.Collection<SSTableReader> sstables)
Refs<SSTableReader>
ColumnFamilyStore. getAndReferenceOverlappingLiveSSTables(java.lang.Iterable<SSTableReader> sstables)
like getOverlappingSSTables, but acquires references before returninglong
ColumnFamilyStore. getExpectedCompactedFileSize(java.lang.Iterable<SSTableReader> sstables, OperationType operation)
Calculate expected file size of SSTable after compaction.SSTableReader
ColumnFamilyStore. getMaxSizeFile(java.lang.Iterable<SSTableReader> sstables)
java.util.Collection<SSTableReader>
ColumnFamilyStore. getOverlappingLiveSSTables(java.lang.Iterable<SSTableReader> sstables)
static SerializationHeader
SerializationHeader. make(TableMetadata metadata, java.util.Collection<SSTableReader> sstables)
void
ColumnFamilyStore. markObsolete(java.util.Collection<SSTableReader> sstables, OperationType compactionType)
<V> V
ColumnFamilyStore. runWithCompactionsDisabled(java.util.concurrent.Callable<V> callable, com.google.common.base.Predicate<SSTableReader> sstablesPredicate, boolean interruptValidation, boolean interruptViews, boolean interruptIndexes)
Runs callable with compactions paused and compactions including sstables matching sstablePredicate stoppedColumnFamilyStore.ViewFragment
ColumnFamilyStore. select(com.google.common.base.Function<View,java.lang.Iterable<SSTableReader>> filter)
ColumnFamilyStore.RefViewFragment
ColumnFamilyStore. selectAndReference(com.google.common.base.Function<View,java.lang.Iterable<SSTableReader>> filter)
java.util.Set<SSTableReader>
ColumnFamilyStore. snapshot(java.lang.String snapshotName, com.google.common.base.Predicate<SSTableReader> predicate, boolean ephemeral, boolean skipFlush)
java.util.Set<SSTableReader>
ColumnFamilyStore. snapshot(java.lang.String snapshotName, com.google.common.base.Predicate<SSTableReader> predicate, boolean ephemeral, boolean skipFlush, com.google.common.util.concurrent.RateLimiter rateLimiter)
java.util.Set<SSTableReader>
ColumnFamilyStore. snapshotWithoutFlush(java.lang.String snapshotName, com.google.common.base.Predicate<SSTableReader> predicate, boolean ephemeral, com.google.common.util.concurrent.RateLimiter rateLimiter)
Constructor parameters in org.apache.cassandra.db with type arguments of type SSTableReader Constructor 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)
-
Uses of SSTableReader in org.apache.cassandra.db.columniterator
Fields in org.apache.cassandra.db.columniterator declared as SSTableReader Modifier and Type Field Description protected SSTableReader
AbstractSSTableIterator. sstable
Constructors in org.apache.cassandra.db.columniterator with parameters of type SSTableReader Constructor Description AbstractSSTableIterator(SSTableReader sstable, FileDataInput file, DecoratedKey key, RowIndexEntry indexEntry, Slices slices, ColumnFilter columnFilter, FileHandle ifile)
SSTableIterator(SSTableReader sstable, FileDataInput file, DecoratedKey key, RowIndexEntry indexEntry, Slices slices, ColumnFilter columns, FileHandle ifile)
SSTableReversedIterator(SSTableReader sstable, FileDataInput file, DecoratedKey key, RowIndexEntry indexEntry, Slices slices, ColumnFilter columns, FileHandle ifile)
-
Uses of SSTableReader in org.apache.cassandra.db.commitlog
Method parameters in org.apache.cassandra.db.commitlog with type arguments of type SSTableReader Modifier and Type Method Description static IntervalSet<CommitLogPosition>
CommitLogReplayer. persistedIntervals(java.lang.Iterable<SSTableReader> onDisk, CommitLogPosition truncatedAt, java.util.UUID localhostId)
A set of known safe-to-discard commit log replay positions, based on the range covered by on disk sstables and those prior to the most recent truncation record -
Uses of SSTableReader in org.apache.cassandra.db.compaction
Fields in org.apache.cassandra.db.compaction with type parameters of type SSTableReader Modifier and Type Field Description java.util.Collection<SSTableReader>
LeveledManifest.CompactionCandidate. sstables
protected java.util.Set<SSTableReader>
SizeTieredCompactionStrategy. sstables
Methods in org.apache.cassandra.db.compaction that return types with arguments of type SSTableReader Modifier and Type Method 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)
Deprecated.static java.util.List<SSTableReader>
AbstractCompactionStrategy. filterSuspectSSTables(java.lang.Iterable<SSTableReader> originalCandidates)
Filters SSTables that are to be excluded from the given collectionjava.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)
static java.util.Set<SSTableReader>
CompactionController. getFullyExpiredSSTables(ColumnFamilyStore cfStore, java.lang.Iterable<SSTableReader> compacting, java.lang.Iterable<SSTableReader> overlapping, int gcBefore, boolean ignoreOverlaps)
Finds expired sstables works something like this; 1.java.util.Set<SSTableReader>
AbstractStrategyHolder.GroupedSSTableContainer. getGroup(int i)
protected abstract java.util.Set<SSTableReader>
AbstractCompactionStrategy. getSSTables()
Returns the sstables managed by this strategy instancejava.util.Set<SSTableReader>
CompactionInfo. getSSTables()
protected java.util.Set<SSTableReader>
DateTieredCompactionStrategy. getSSTables()
Deprecated.protected java.util.Set<SSTableReader>
LeveledCompactionStrategy. getSSTables()
java.util.Set<SSTableReader>
LeveledManifest. getSSTables()
protected java.util.Set<SSTableReader>
SizeTieredCompactionStrategy. getSSTables()
protected java.util.Set<SSTableReader>
TimeWindowCompactionStrategy. getSSTables()
java.util.Set<SSTableReader>[]
LeveledManifest. getSStablesPerLevelSnapshot()
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>>
CompactionStrategyManager. groupSSTablesForAntiCompaction(java.util.Collection<SSTableReader> sstablesToGroup)
java.util.Collection<java.util.Collection<SSTableReader>>
DateTieredCompactionStrategy. groupSSTablesForAntiCompaction(java.util.Collection<SSTableReader> sstablesToGroup)
Deprecated.DTCS should not group sstables for anticompaction - this can mix new and old datajava.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.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)
Methods in org.apache.cassandra.db.compaction with parameters of type SSTableReader Modifier and Type Method Description abstract void
AbstractCompactionStrategy. addSSTable(SSTableReader added)
Adds sstable, note that implementations must handle duplicate notifications here (added already being in the compaction strategy)void
DateTieredCompactionStrategy. addSSTable(SSTableReader sstable)
Deprecated.void
LeveledCompactionStrategy. addSSTable(SSTableReader added)
void
SizeTieredCompactionStrategy. addSSTable(SSTableReader added)
void
TimeWindowCompactionStrategy. addSSTable(SSTableReader sstable)
abstract boolean
AbstractStrategyHolder. containsSSTable(SSTableReader sstable)
boolean
CompactionStrategyHolder. containsSSTable(SSTableReader sstable)
boolean
PendingRepairHolder. containsSSTable(SSTableReader sstable)
static SSTableWriter
CompactionManager. createWriter(ColumnFamilyStore cfs, java.io.File compactionFileLocation, long expectedBloomFilterSize, long repairedAt, java.util.UUID pendingRepair, boolean isTransient, SSTableReader sstable, LifecycleTransaction txn)
java.util.Collection<CompactionInfo>
ActiveCompactions. getCompactionsForSSTable(SSTableReader sstable, OperationType compactionType)
Iterates over the active compactions and tries to find CompactionInfos with the given compactionType for the given sstable Number of entries in compactions should be small (< 10) but avoid calling in any time-sensitive contextAbstractCompactionStrategy
CompactionStrategyManager. getCompactionStrategyFor(SSTableReader sstable)
return the compaction strategy for the given sstable returns differently based on the repaired status and which vnode the compaction strategy belongs toint
AbstractStrategyHolder.DestinationRouter. getIndexForSSTable(SSTableReader sstable)
abstract AbstractCompactionStrategy
AbstractStrategyHolder. getStrategyFor(SSTableReader sstable)
AbstractCompactionStrategy
CompactionStrategyHolder. getStrategyFor(SSTableReader sstable)
AbstractCompactionStrategy
PendingRepairHolder. getStrategyFor(SSTableReader sstable)
boolean
AbstractStrategyHolder. managesSSTable(SSTableReader sstable)
void
AbstractCompactionStrategy. metadataChanged(StatsMetadata oldMetadata, SSTableReader sstable)
Called when the metadata has changed for an sstable - for example if the level changed Not called when repair status changes (which is also metadata), because this results in the sstable getting removed from the compaction strategy instance.void
LeveledCompactionStrategy. metadataChanged(StatsMetadata oldMetadata, 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)
Removes sstable from the strategy, implementations must be able to handle the sstable having already been removed.void
DateTieredCompactionStrategy. removeSSTable(SSTableReader sstable)
Deprecated.void
LeveledCompactionStrategy. removeSSTable(SSTableReader sstable)
void
SizeTieredCompactionStrategy. removeSSTable(SSTableReader sstable)
void
TimeWindowCompactionStrategy. removeSSTable(SSTableReader sstable)
com.fasterxml.jackson.databind.JsonNode
CompactionLogger.Strategy. sstable(SSTableReader sstable)
protected boolean
AbstractCompactionStrategy. worthDroppingTombstones(SSTableReader sstable, int gcBefore)
Check if given sstable is worth dropping tombstones at gcBefore.Method parameters in org.apache.cassandra.db.compaction with type arguments of type SSTableReader Modifier and Type Method Description void
AbstractCompactionStrategy. addSSTables(java.lang.Iterable<SSTableReader> added)
Adds sstables, note that implementations must handle duplicate notifications here (added already being in the compaction strategy)void
LeveledCompactionStrategy. addSSTables(java.lang.Iterable<SSTableReader> sstables)
void
LeveledManifest. addSSTables(java.lang.Iterable<SSTableReader> readers)
protected void
CompactionTask. buildCompactionCandidatesForAvailableDiskSpace(java.util.Set<SSTableReader> fullyExpiredSSTables)
void
CompactionLogger. compaction(long startTime, java.util.Collection<SSTableReader> input, long endTime, java.util.Collection<SSTableReader> output)
static LeveledManifest
LeveledManifest. create(ColumnFamilyStore cfs, int maxSSTableSize, int fanoutSize, java.lang.Iterable<SSTableReader> sstables, SizeTieredCompactionStrategyOptions options)
static LeveledManifest
LeveledManifest. create(ColumnFamilyStore cfs, int maxSSTableSize, int fanoutSize, 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)
Deprecated.static SSTableWriter
CompactionManager. createWriterForAntiCompaction(ColumnFamilyStore cfs, java.io.File compactionFileLocation, int expectedBloomFilterSize, long repairedAt, java.util.UUID pendingRepair, boolean isTransient, java.util.Collection<SSTableReader> sstables, ILifecycleTransaction txn)
static java.util.List<SSTableReader>
AbstractCompactionStrategy. filterSuspectSSTables(java.lang.Iterable<SSTableReader> originalCandidates)
Filters SSTables that are to be excluded from the given collectionvoid
CompactionLogger. flush(java.util.Collection<SSTableReader> sstables)
abstract CompactionAwareWriter
AbstractCompactionTask. getCompactionAwareWriter(ColumnFamilyStore cfs, Directories directories, LifecycleTransaction txn, java.util.Set<SSTableReader> nonExpiredSSTables)
CompactionAwareWriter
CompactionTask. getCompactionAwareWriter(ColumnFamilyStore cfs, Directories directories, LifecycleTransaction transaction, java.util.Set<SSTableReader> nonExpiredSSTables)
CompactionAwareWriter
LeveledCompactionTask. getCompactionAwareWriter(ColumnFamilyStore cfs, Directories directories, LifecycleTransaction txn, java.util.Set<SSTableReader> nonExpiredSSTables)
CompactionAwareWriter
SingleSSTableLCSTask. getCompactionAwareWriter(ColumnFamilyStore cfs, Directories directories, LifecycleTransaction txn, java.util.Set<SSTableReader> nonExpiredSSTables)
CompactionAwareWriter
SSTableSplitter.SplittingCompactionTask. getCompactionAwareWriter(ColumnFamilyStore cfs, Directories directories, 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)
CompactionController
TimeWindowCompactionTask. getCompactionController(java.util.Set<SSTableReader> toCompact)
static int
SizeTieredCompactionStrategy. getEstimatedCompactionsByTasks(ColumnFamilyStore cfs, java.util.List<java.util.List<SSTableReader>> tasks)
static java.util.Set<SSTableReader>
CompactionController. getFullyExpiredSSTables(ColumnFamilyStore cfStore, java.lang.Iterable<SSTableReader> compacting, java.lang.Iterable<SSTableReader> overlapping, int gcBefore)
static java.util.Set<SSTableReader>
CompactionController. getFullyExpiredSSTables(ColumnFamilyStore cfStore, java.lang.Iterable<SSTableReader> compacting, java.lang.Iterable<SSTableReader> overlapping, int gcBefore, boolean ignoreOverlaps)
Finds expired sstables works something like this; 1.static boolean
CompactionTask. getIsTransient(java.util.Set<SSTableReader> sstables)
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)
static java.util.UUID
CompactionTask. getPendingRepair(java.util.Set<SSTableReader> sstables)
AbstractCompactionStrategy.ScannerList
AbstractCompactionStrategy. getScanners(java.util.Collection<SSTableReader> toCompact)
AbstractCompactionStrategy.ScannerList
AbstractCompactionStrategy. getScanners(java.util.Collection<SSTableReader> sstables, java.util.Collection<Range<Token>> ranges)
Returns a list of KeyScanners given sstables and a range on which to scan.AbstractCompactionStrategy.ScannerList
AbstractCompactionStrategy. getScanners(java.util.Collection<SSTableReader> sstables, Range<Token> range)
AbstractCompactionStrategy.ScannerList
CompactionStrategyManager. getScanners(java.util.Collection<SSTableReader> sstables)
AbstractCompactionStrategy.ScannerList
CompactionStrategyManager. getScanners(java.util.Collection<SSTableReader> sstables, java.util.Collection<Range<Token>> ranges)
AbstractCompactionStrategy.ScannerList
LeveledCompactionStrategy. getScanners(java.util.Collection<SSTableReader> sstables, java.util.Collection<Range<Token>> ranges)
abstract AbstractCompactionTask
AbstractCompactionStrategy. getUserDefinedTask(java.util.Collection<SSTableReader> sstables, int gcBefore)
AbstractCompactionTask
DateTieredCompactionStrategy. getUserDefinedTask(java.util.Collection<SSTableReader> sstables, int gcBefore)
Deprecated.AbstractCompactionTask
LeveledCompactionStrategy. getUserDefinedTask(java.util.Collection<SSTableReader> sstables, int gcBefore)
AbstractCompactionTask
SizeTieredCompactionStrategy. getUserDefinedTask(java.util.Collection<SSTableReader> sstables, int gcBefore)
AbstractCompactionTask
TimeWindowCompactionStrategy. getUserDefinedTask(java.util.Collection<SSTableReader> sstables, int gcBefore)
CompactionTasks
CompactionStrategyManager. getUserDefinedTasks(java.util.Collection<SSTableReader> sstables, int gcBefore)
Return a list of compaction tasks corresponding to the sstables requested.java.util.List<AbstractStrategyHolder.GroupedSSTableContainer>
CompactionStrategyManager. groupSSTables(java.lang.Iterable<SSTableReader> sstables)
Split sstables into a list of grouped sstable containers, the list index an sstable lives in matches the list index of the holder that's responsible for itjava.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>>
CompactionStrategyManager. groupSSTablesForAntiCompaction(java.util.Collection<SSTableReader> sstablesToGroup)
java.util.Collection<java.util.Collection<SSTableReader>>
DateTieredCompactionStrategy. groupSSTablesForAntiCompaction(java.util.Collection<SSTableReader> sstablesToGroup)
Deprecated.DTCS should not group sstables for anticompaction - this can mix new and old datajava.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.void
CompactionManager. interruptCompactionFor(java.lang.Iterable<TableMetadata> columnFamilies, java.util.function.Predicate<SSTableReader> sstablePredicate, boolean interruptValidation)
Try to stop all of the compactions for given ColumnFamilies.void
CompactionManager. interruptCompactionForCFs(java.lang.Iterable<ColumnFamilyStore> cfss, java.util.function.Predicate<SSTableReader> sstablePredicate, boolean interruptValidation)
boolean
CompactionManager. isCompacting(java.lang.Iterable<ColumnFamilyStore> cfses, java.util.function.Predicate<SSTableReader> sstablePredicate)
AbstractCompactionStrategy.ScannerList
CompactionStrategyManager. maybeGetScanners(java.util.Collection<SSTableReader> sstables, java.util.Collection<Range<Token>> ranges)
Create ISSTableScanners from the given sstables Delegates the call to the compaction strategies to allow LCS to create a scannerstatic java.util.List<SSTableReader>
SizeTieredCompactionStrategy. mostInterestingBucket(java.util.List<java.util.List<SSTableReader>> buckets, int minThreshold, int maxThreshold)
void
CompactionStrategyManager. mutateRepaired(java.util.Collection<SSTableReader> sstables, long repairedAt, java.util.UUID pendingRepair, boolean isTransient)
Mutates sstable repairedAt times and notifies listeners of the change with the writeLock held.void
CompactionManager. performAnticompaction(ColumnFamilyStore cfs, RangesAtEndpoint replicas, Refs<SSTableReader> validatedForRepair, LifecycleTransaction txn, java.util.UUID sessionID, java.util.function.BooleanSupplier isCancelled)
Make sure the {validatedForRepair} are marked for compaction before calling this.boolean
CompactionTask. reduceScopeForLimitedSpace(java.util.Set<SSTableReader> nonExpiredSSTables, long expectedSize)
boolean
LeveledCompactionTask. reduceScopeForLimitedSpace(java.util.Set<SSTableReader> nonExpiredSSTables, long expectedSize)
void
AbstractCompactionStrategy. removeSSTables(java.lang.Iterable<SSTableReader> removed)
Removes sstables from the strategy, implementations must be able to handle the sstables having already been removed.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)
Replaces sstables in the compaction strategy Note that implementations must be able to handle duplicate notifications here (that removed are already gone and added have already been added)void
LeveledCompactionStrategy. replaceSSTables(java.util.Collection<SSTableReader> removed, java.util.Collection<SSTableReader> added)
com.google.common.util.concurrent.ListenableFuture<?>
CompactionManager. submitPendingAntiCompaction(ColumnFamilyStore cfs, RangesAtEndpoint tokenRanges, Refs<SSTableReader> sstables, LifecycleTransaction txn, java.util.UUID sessionId, java.util.function.BooleanSupplier isCancelled)
Splits the given token ranges of the given sstables into a pending repair silovoid
CompactionManager. waitForCessation(java.lang.Iterable<ColumnFamilyStore> cfss, java.util.function.Predicate<SSTableReader> sstablePredicate)
Constructors in org.apache.cassandra.db.compaction with parameters of type SSTableReader Constructor Description Verifier(ColumnFamilyStore cfs, SSTableReader sstable, boolean isOffline, Verifier.Options options)
Verifier(ColumnFamilyStore cfs, SSTableReader sstable, OutputHandler outputHandler, boolean isOffline, Verifier.Options options)
Constructor parameters in org.apache.cassandra.db.compaction with type arguments of type SSTableReader Constructor Description CompactionCandidate(java.util.Collection<SSTableReader> sstables, int level, long maxSSTableBytes)
CompactionController(ColumnFamilyStore cfs, java.util.Set<SSTableReader> compacting, int gcBefore)
CompactionController(ColumnFamilyStore cfs, java.util.Set<SSTableReader> compacting, int gcBefore, com.google.common.util.concurrent.RateLimiter limiter, CompactionParams.TombstoneOption tombstoneOption)
CompactionInfo(TableMetadata metadata, OperationType tasktype, long bytesComplete, long totalBytes, java.util.UUID compactionId, java.util.Collection<SSTableReader> sstables)
TimeWindowCompactionController(ColumnFamilyStore cfs, java.util.Set<SSTableReader> compacting, int gcBefore, boolean ignoreOverlaps)
-
Uses of SSTableReader in org.apache.cassandra.db.compaction.writers
Fields in org.apache.cassandra.db.compaction.writers with type parameters of type SSTableReader Modifier and Type Field Description protected java.util.Set<SSTableReader>
CompactionAwareWriter. nonExpiredSSTables
Methods in org.apache.cassandra.db.compaction.writers that return types with arguments of type SSTableReader Modifier and Type Method Description java.util.Collection<SSTableReader>
CompactionAwareWriter. finish()
we are done, return the finished sstables so that the caller can mark the old ones as compactedMethod parameters in org.apache.cassandra.db.compaction.writers with type arguments of type SSTableReader Modifier and Type Method Description Directories.DataDirectory
CompactionAwareWriter. getWriteDirectory(java.lang.Iterable<SSTableReader> sstables, long estimatedWriteSize)
Return a directory where we can expect expectedWriteSize to fit.Constructor parameters in org.apache.cassandra.db.compaction.writers with type arguments of type SSTableReader Constructor Description CompactionAwareWriter(ColumnFamilyStore cfs, Directories directories, LifecycleTransaction txn, java.util.Set<SSTableReader> nonExpiredSSTables, boolean keepOriginals)
DefaultCompactionWriter(ColumnFamilyStore cfs, Directories directories, LifecycleTransaction txn, java.util.Set<SSTableReader> nonExpiredSSTables)
DefaultCompactionWriter(ColumnFamilyStore cfs, Directories directories, LifecycleTransaction txn, java.util.Set<SSTableReader> nonExpiredSSTables, boolean offline, boolean keepOriginals, int sstableLevel)
Deprecated.DefaultCompactionWriter(ColumnFamilyStore cfs, Directories directories, LifecycleTransaction txn, java.util.Set<SSTableReader> nonExpiredSSTables, boolean keepOriginals, int sstableLevel)
MajorLeveledCompactionWriter(ColumnFamilyStore cfs, Directories directories, LifecycleTransaction txn, java.util.Set<SSTableReader> nonExpiredSSTables, long maxSSTableSize)
MajorLeveledCompactionWriter(ColumnFamilyStore cfs, Directories directories, LifecycleTransaction txn, java.util.Set<SSTableReader> nonExpiredSSTables, long maxSSTableSize, boolean keepOriginals)
MaxSSTableSizeWriter(ColumnFamilyStore cfs, Directories directories, LifecycleTransaction txn, java.util.Set<SSTableReader> nonExpiredSSTables, long maxSSTableSize, int level)
MaxSSTableSizeWriter(ColumnFamilyStore cfs, Directories directories, LifecycleTransaction txn, java.util.Set<SSTableReader> nonExpiredSSTables, long maxSSTableSize, int level, boolean keepOriginals)
SplittingSizeTieredCompactionWriter(ColumnFamilyStore cfs, Directories directories, LifecycleTransaction txn, java.util.Set<SSTableReader> nonExpiredSSTables)
SplittingSizeTieredCompactionWriter(ColumnFamilyStore cfs, Directories directories, LifecycleTransaction txn, java.util.Set<SSTableReader> nonExpiredSSTables, long smallestSSTable)
-
Uses of SSTableReader in org.apache.cassandra.db.filter
Methods in org.apache.cassandra.db.filter with parameters of type SSTableReader Modifier and Type Method Description boolean
ClusteringIndexFilter. shouldInclude(SSTableReader sstable)
Whether the provided sstable may contain data that is selected by this filter (based on the sstable metadata).boolean
ClusteringIndexNamesFilter. shouldInclude(SSTableReader sstable)
boolean
ClusteringIndexSliceFilter. shouldInclude(SSTableReader sstable)
-
Uses of SSTableReader in org.apache.cassandra.db.lifecycle
Methods in org.apache.cassandra.db.lifecycle that return SSTableReader Modifier and Type Method Description SSTableReader
ILifecycleTransaction. current(SSTableReader reader)
SSTableReader
LifecycleTransaction. current(SSTableReader reader)
return the current version of the provided reader, whether or not it is visible or staged; i.e.SSTableReader
WrappedLifecycleTransaction. current(SSTableReader reader)
SSTableReader
LifecycleTransaction. onlyOne()
static SSTableReader
LifecycleTransaction.ReaderState. visible(SSTableReader reader, com.google.common.base.Predicate<SSTableReader> obsolete, java.util.Collection<SSTableReader>... selectFrom)
Methods in org.apache.cassandra.db.lifecycle that return types with arguments of type SSTableReader Modifier and Type Method Description java.lang.Iterable<SSTableReader>
View. allKnownSSTables()
static java.util.List<Interval<PartitionPosition,SSTableReader>>
SSTableIntervalTree. buildIntervals(java.lang.Iterable<SSTableReader> sstables)
java.lang.Iterable<SSTableReader>
LifecycleTransaction. current()
returns the currently visible readers managed by this transactionjava.util.Set<SSTableReader>
Tracker. getCompacting()
java.lang.Iterable<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)
java.util.Set<SSTableReader>
View. liveSSTables()
java.lang.Iterable<SSTableReader>
View. liveSSTablesInBounds(PartitionPosition left, PartitionPosition right)
Returns the sstables that have any partition betweenleft
andright
, when both bounds are taken inclusively.java.util.Set<SSTableReader>
ILifecycleTransaction. originals()
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 instancejava.util.Set<SSTableReader>
WrappedLifecycleTransaction. originals()
java.lang.Iterable<SSTableReader>
View. select(SSTableSet sstableSet)
static com.google.common.base.Function<View,java.lang.Iterable<SSTableReader>>
View. select(SSTableSet sstableSet, com.google.common.base.Predicate<SSTableReader> filter)
static com.google.common.base.Function<View,java.lang.Iterable<SSTableReader>>
View. select(SSTableSet sstableSet, DecoratedKey key)
static com.google.common.base.Function<View,java.lang.Iterable<SSTableReader>>
View. selectFunction(SSTableSet sstableSet)
static com.google.common.base.Function<View,java.lang.Iterable<SSTableReader>>
View. selectLive(AbstractBounds<PartitionPosition> rowBounds)
java.lang.Iterable<SSTableReader>
View. sstables(SSTableSet sstableSet, com.google.common.base.Predicate<SSTableReader> filter)
static java.util.List<SSTableReader>
View. sstablesInBounds(PartitionPosition left, PartitionPosition right, SSTableIntervalTree intervalTree)
Methods in org.apache.cassandra.db.lifecycle with parameters of type SSTableReader Modifier and Type Method Description void
LifecycleTransaction. cancel(SSTableReader cancel)
remove the reader from the set we're modifyingSSTableReader
ILifecycleTransaction. current(SSTableReader reader)
SSTableReader
LifecycleTransaction. current(SSTableReader reader)
return the current version of the provided reader, whether or not it is visible or staged; i.e.SSTableReader
WrappedLifecycleTransaction. current(SSTableReader reader)
boolean
ILifecycleTransaction. isObsolete(SSTableReader reader)
boolean
LifecycleTransaction. isObsolete(SSTableReader reader)
indicates if the reader has been marked for obsoletionboolean
WrappedLifecycleTransaction. isObsolete(SSTableReader reader)
void
Tracker. notifyDeleting(SSTableReader deleting)
void
Tracker. notifySSTableMetadataChanged(SSTableReader levelChanged, StatsMetadata oldMetadata)
void
ILifecycleTransaction. obsolete(SSTableReader reader)
void
LifecycleTransaction. obsolete(SSTableReader reader)
mark this reader as for obsoletion : on checkpoint() the reader will be removed from the live setvoid
WrappedLifecycleTransaction. obsolete(SSTableReader reader)
static LifecycleTransaction
LifecycleTransaction. offline(OperationType operationType, SSTableReader reader)
construct a Transaction for use in an offline operationLifecycleTransaction.ReaderState
LifecycleTransaction. state(SSTableReader reader)
LifecycleTransaction
Tracker. tryModify(SSTableReader sstable, OperationType operationType)
void
ILifecycleTransaction. update(SSTableReader reader, boolean original)
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.void
WrappedLifecycleTransaction. update(SSTableReader reader, boolean original)
static SSTableReader
LifecycleTransaction.ReaderState. visible(SSTableReader reader, com.google.common.base.Predicate<SSTableReader> obsolete, java.util.Collection<SSTableReader>... selectFrom)
Method parameters in org.apache.cassandra.db.lifecycle with type arguments of type SSTableReader Modifier and Type Method Description void
Tracker. addInitialSSTables(java.lang.Iterable<SSTableReader> sstables)
void
Tracker. addInitialSSTablesWithoutUpdatingSize(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<PartitionPosition,SSTableReader>>
SSTableIntervalTree. buildIntervals(java.lang.Iterable<SSTableReader> sstables)
void
LifecycleTransaction. cancel(java.lang.Iterable<SSTableReader> cancels)
remove the readers from the set we're modifyingjava.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. maybeIncrementallyBackup(java.lang.Iterable<SSTableReader> sstables)
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 operationvoid
Tracker. removeUnsafe(java.util.Set<SSTableReader> toRemove)
void
Tracker. replaceFlushed(Memtable memtable, java.lang.Iterable<SSTableReader> sstables)
static com.google.common.base.Function<View,java.lang.Iterable<SSTableReader>>
View. select(SSTableSet sstableSet, com.google.common.base.Predicate<SSTableReader> filter)
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 usedjava.lang.Iterable<SSTableReader>
View. sstables(SSTableSet sstableSet, com.google.common.base.Predicate<SSTableReader> filter)
LifecycleTransaction
Tracker. tryModify(java.lang.Iterable<SSTableReader> sstables, OperationType operationType)
void
ILifecycleTransaction. update(java.util.Collection<SSTableReader> readers, boolean original)
void
LifecycleTransaction. update(java.util.Collection<SSTableReader> readers, boolean original)
void
WrappedLifecycleTransaction. update(java.util.Collection<SSTableReader> readers, boolean original)
void
Tracker. updateInitialSSTableSize(java.lang.Iterable<SSTableReader> sstables)
static SSTableReader
LifecycleTransaction.ReaderState. visible(SSTableReader reader, com.google.common.base.Predicate<SSTableReader> obsolete, java.util.Collection<SSTableReader>... selectFrom)
Constructors in org.apache.cassandra.db.lifecycle with parameters of type SSTableReader Constructor Description ReaderState(LifecycleTransaction.ReaderState.Action logged, LifecycleTransaction.ReaderState.Action staged, SSTableReader currentlyVisible, SSTableReader nextVisible, boolean original)
-
Uses of SSTableReader in org.apache.cassandra.db.rows
Constructors in org.apache.cassandra.db.rows with parameters of type SSTableReader Constructor Description UnfilteredRowIteratorWithLowerBound(DecoratedKey partitionKey, SSTableReader sstable, ClusteringIndexFilter filter, ColumnFilter selectedColumns, SSTableReadsListener listener)
-
Uses of SSTableReader in org.apache.cassandra.db.streaming
Fields in org.apache.cassandra.db.streaming declared as SSTableReader Modifier and Type Field Description protected SSTableReader
CassandraStreamWriter. sstable
Fields in org.apache.cassandra.db.streaming with type parameters of type SSTableReader Modifier and Type Field Description protected java.util.Collection<SSTableReader>
CassandraStreamReceiver. sstables
Methods in org.apache.cassandra.db.streaming that return types with arguments of type SSTableReader Modifier and Type Method Description Ref<SSTableReader>
CassandraOutgoingFile. getRef()
Methods in org.apache.cassandra.db.streaming with parameters of type SSTableReader Modifier and Type Method Description boolean
CassandraOutgoingFile. contained(java.util.List<SSTableReader.PartitionPositionBounds> sections, SSTableReader sstable)
Constructors in org.apache.cassandra.db.streaming with parameters of type SSTableReader Constructor Description CassandraCompressedStreamWriter(SSTableReader sstable, CassandraStreamHeader header, StreamSession session)
CassandraEntireSSTableStreamWriter(SSTableReader sstable, StreamSession session, ComponentContext context)
CassandraStreamWriter(SSTableReader sstable, CassandraStreamHeader header, StreamSession session)
Constructor parameters in org.apache.cassandra.db.streaming with type arguments of type SSTableReader Constructor Description CassandraOutgoingFile(StreamOperation operation, Ref<SSTableReader> ref, java.util.List<SSTableReader.PartitionPositionBounds> sections, java.util.List<Range<Token>> normalizedRanges, long estimatedKeys)
-
Uses of SSTableReader in org.apache.cassandra.index
Method parameters in org.apache.cassandra.index with type arguments of type SSTableReader Modifier and Type Method Description SecondaryIndexBuilder
Index.CollatedViewIndexBuildingSupport. getIndexBuildTask(ColumnFamilyStore cfs, java.util.Set<Index> indexes, java.util.Collection<SSTableReader> sstables)
SecondaryIndexBuilder
Index.IndexBuildingSupport. getIndexBuildTask(ColumnFamilyStore cfs, java.util.Set<Index> indexes, java.util.Collection<SSTableReader> sstables)
-
Uses of SSTableReader in org.apache.cassandra.index.internal
Constructor parameters in org.apache.cassandra.index.internal with type arguments of type SSTableReader Constructor Description CollatedViewIndexBuilder(ColumnFamilyStore cfs, java.util.Set<Index> indexers, ReducingKeyIterator iter, java.util.Collection<SSTableReader> sstables)
-
Uses of SSTableReader in org.apache.cassandra.index.sasi
Methods in org.apache.cassandra.index.sasi that return SSTableReader Modifier and Type Method Description SSTableReader
SSTableIndex. getSSTable()
Constructors in org.apache.cassandra.index.sasi with parameters of type SSTableReader Constructor Description SSTableIndex(ColumnIndex index, java.io.File indexFile, SSTableReader referent)
-
Uses of SSTableReader in org.apache.cassandra.index.sasi.conf
Methods in org.apache.cassandra.index.sasi.conf that return types with arguments of type SSTableReader Modifier and Type Method Description java.lang.Iterable<SSTableReader>
ColumnIndex. init(java.util.Set<SSTableReader> sstables)
Initialize this column index with specific set of SSTables.java.lang.Iterable<SSTableReader>
DataTracker. update(java.util.Collection<SSTableReader> oldSSTables, java.util.Collection<SSTableReader> newSSTables)
Replaces old SSTables with new by creating new immutable tracker.Methods in org.apache.cassandra.index.sasi.conf with parameters of type SSTableReader Modifier and Type Method Description boolean
ColumnIndex. hasSSTable(SSTableReader sstable)
boolean
DataTracker. hasSSTable(SSTableReader sstable)
Method parameters in org.apache.cassandra.index.sasi.conf with type arguments of type SSTableReader Modifier and Type Method Description void
ColumnIndex. dropData(java.util.Collection<SSTableReader> sstablesToRebuild)
void
DataTracker. dropData(java.util.Collection<SSTableReader> sstablesToRebuild)
java.lang.Iterable<SSTableReader>
ColumnIndex. init(java.util.Set<SSTableReader> sstables)
Initialize this column index with specific set of SSTables.void
ColumnIndex. update(java.util.Collection<SSTableReader> oldSSTables, java.util.Collection<SSTableReader> newSSTables)
java.lang.Iterable<SSTableReader>
DataTracker. update(java.util.Collection<SSTableReader> oldSSTables, java.util.Collection<SSTableReader> newSSTables)
Replaces old SSTables with new by creating new immutable tracker. -
Uses of SSTableReader in org.apache.cassandra.io.sstable
Methods in org.apache.cassandra.io.sstable that return types with arguments of type SSTableReader Modifier and Type Method Description java.util.Collection<SSTableReader>
SimpleSSTableMultiWriter. finish(boolean openResult)
java.util.Collection<SSTableReader>
SimpleSSTableMultiWriter. finish(long repairedAt, long maxDataAge, boolean openResult)
java.util.Collection<SSTableReader>
SSTableMultiWriter. finish(boolean openResult)
java.util.Collection<SSTableReader>
SSTableMultiWriter. finish(long repairedAt, long maxDataAge, boolean openResult)
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.Collection<SSTableReader>
SSTableTxnWriter. finish(boolean openResult)
java.util.Collection<SSTableReader>
SimpleSSTableMultiWriter. finished()
java.util.Collection<SSTableReader>
SSTableMultiWriter. finished()
java.util.List<SSTableReader>
SSTableRewriter. finished()
java.util.Set<SSTableReader>
ISSTableScanner. getBackingSSTables()
protected java.util.Collection<SSTableReader>
SSTableLoader. openSSTables(java.util.Map<InetAddressAndPort,java.util.Collection<Range<Token>>> ranges)
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.java.util.List<SSTableReader>
IndexSummaryRedistribution. redistributeSummaries()
Methods in org.apache.cassandra.io.sstable with parameters of type SSTableReader Modifier and Type Method Description static SSTableIdentityIterator
SSTableIdentityIterator. create(SSTableReader sstable, FileDataInput dfile, RowIndexEntry<?> indexEntry, DecoratedKey key, boolean tombstoneOnly)
static SSTableIdentityIterator
SSTableIdentityIterator. create(SSTableReader sstable, RandomAccessReader file, DecoratedKey key)
Constructors in org.apache.cassandra.io.sstable with parameters of type SSTableReader Constructor Description SSTableIdentityIterator(SSTableReader sstable, DecoratedKey key, DeletionTime partitionLevelDeletion, java.lang.String filename, SSTableSimpleIterator iterator)
Constructor parameters in org.apache.cassandra.io.sstable with type arguments of type SSTableReader Constructor Description ReducingKeyIterator(java.util.Collection<SSTableReader> sstables)
-
Uses of SSTableReader in org.apache.cassandra.io.sstable.format
Fields in org.apache.cassandra.io.sstable.format declared as SSTableReader Modifier and Type Field Description protected SSTableReader
SSTableWriter.TransactionalProxy. finalReader
Fields in org.apache.cassandra.io.sstable.format with type parameters of type SSTableReader Modifier and Type Field Description static java.util.Comparator<SSTableReader>
SSTableReader. generationReverseComparator
static java.util.Comparator<SSTableReader>
SSTableReader. maxTimestampAscending
static java.util.Comparator<SSTableReader>
SSTableReader. maxTimestampDescending
static java.util.Comparator<SSTableReader>
SSTableReader. sizeComparator
static java.util.Comparator<SSTableReader>
SSTableReader. sstableComparator
static com.google.common.collect.Ordering<SSTableReader>
SSTableReader. sstableOrdering
Methods in org.apache.cassandra.io.sstable.format that return SSTableReader Modifier and Type Method Description abstract SSTableReader
SSTableReaderBuilder. build()
SSTableReader
SSTableReaderBuilder.ForBatch. build()
SSTableReader
SSTableReaderBuilder.ForRead. build()
SSTableReader
SSTableReaderBuilder.ForWriter. build()
SSTableReader
SSTableReader. cloneAndReplace(IFilter newBloomFilter)
Clone this reader with the new values and set the clone as replacement.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
SSTableReader. cloneWithRestoredStart(DecoratedKey restoredStart)
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 operationstatic SSTableReader
SSTableReader. internalOpen(Descriptor desc, java.util.Set<Component> components, TableMetadataRef metadata, FileHandle ifile, FileHandle dfile, IndexSummary summary, IFilter bf, long maxDataAge, StatsMetadata sstableMetadata, SSTableReader.OpenReason openReason, SerializationHeader header)
Open a RowIndexedReader which already has its state initialized (by SSTableWriter).static SSTableReader
SSTableReader. moveAndOpenSSTable(ColumnFamilyStore cfs, Descriptor oldDescriptor, Descriptor newDescriptor, java.util.Set<Component> components, boolean copyData)
Moves the sstable in oldDescriptor to a new place (with generation etc) in newDescriptor.abstract SSTableReader
SSTableReader.Factory. open(SSTableReaderBuilder builder)
static SSTableReader
SSTableReader. open(Descriptor descriptor)
static SSTableReader
SSTableReader. open(Descriptor descriptor, java.util.Set<Component> components, TableMetadataRef metadata)
static SSTableReader
SSTableReader. open(Descriptor descriptor, java.util.Set<Component> components, TableMetadataRef metadata, boolean validate, boolean isOffline)
Open an SSTable for readingstatic SSTableReader
SSTableReader. open(Descriptor desc, TableMetadataRef metadata)
abstract SSTableReader
SSTableWriter. openEarly()
Open the resultant SSTableReader before it has been fully writtenabstract 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 readystatic SSTableReader
SSTableReader. openForBatch(Descriptor descriptor, java.util.Set<Component> components, TableMetadataRef metadata)
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)
static SSTableReader
SSTableReader. openNoValidation(Descriptor descriptor, TableMetadataRef metadata)
Methods in org.apache.cassandra.io.sstable.format that return types with arguments of type SSTableReader Modifier and Type Method Description java.util.Collection<SSTableReader>
RangeAwareSSTableWriter. finish(boolean openResult)
java.util.Collection<SSTableReader>
RangeAwareSSTableWriter. finish(long repairedAt, long maxDataAge, boolean openResult)
java.util.Collection<SSTableReader>
RangeAwareSSTableWriter. finished()
static java.util.Collection<SSTableReader>
SSTableReader. openAll(java.util.Set<java.util.Map.Entry<Descriptor,java.util.Set<Component>>> entries, TableMetadataRef metadata)
Ref<SSTableReader>
SSTableReader. ref()
Ref<SSTableReader>
SSTableReader. selfRef()
Ref<SSTableReader>
SSTableReader. tryRef()
Methods in org.apache.cassandra.io.sstable.format with parameters of type SSTableReader Modifier and Type Method Description default void
SSTableReadsListener. onScanningStarted(SSTableReader sstable)
Handles notification that the specified SSTable is being scanned during a partition range query.default void
SSTableReadsListener. onSSTableSelected(SSTableReader sstable, RowIndexEntry<?> indexEntry, SSTableReadsListener.SelectionReason reason)
Handles notification that the specified SSTable has been selected during a single partition query.default void
SSTableReadsListener. onSSTableSkipped(SSTableReader sstable, SSTableReadsListener.SkippingReason reason)
Handles notification that the specified SSTable has been skipped during a single partition query.Method parameters in org.apache.cassandra.io.sstable.format with type arguments of type SSTableReader Modifier and Type Method Description static double
SSTableReader. estimateCompactionGain(java.util.Set<SSTableReader> overlapping)
Estimates how much of the keys we would keep if the sstables were compacted togetherstatic long
SSTableReader. getApproximateKeyCount(java.lang.Iterable<SSTableReader> sstables)
Calculate approximate key count.static long
SSTableReader. getTotalBytes(java.lang.Iterable<SSTableReader> sstables)
static long
SSTableReader. getTotalUncompressedBytes(java.lang.Iterable<SSTableReader> sstables)
-
Uses of SSTableReader in org.apache.cassandra.io.sstable.format.big
Subclasses of SSTableReader in org.apache.cassandra.io.sstable.format.big Modifier and Type Class Description class
BigTableReader
SSTableReaders are open()ed by Keyspace.onStart; after that they are created by SSTableWriter.renameAndOpen.Fields in org.apache.cassandra.io.sstable.format.big declared as SSTableReader Modifier and Type Field Description SSTableReader
BigTableScanner. sstable
Methods in org.apache.cassandra.io.sstable.format.big that return SSTableReader Modifier and Type Method Description SSTableReader
BigTableWriter. openEarly()
SSTableReader
BigTableWriter. openFinalEarly()
Methods in org.apache.cassandra.io.sstable.format.big that return types with arguments of type SSTableReader Modifier and Type Method Description java.util.Collection<SSTableReader>
BigTableZeroCopyWriter. finish(boolean openResult)
java.util.Collection<SSTableReader>
BigTableZeroCopyWriter. finish(long repairedAt, long maxDataAge, boolean openResult)
java.util.Collection<SSTableReader>
BigTableZeroCopyWriter. finished()
java.util.Set<SSTableReader>
BigTableScanner.EmptySSTableScanner. getBackingSSTables()
java.util.Set<SSTableReader>
BigTableScanner. getBackingSSTables()
Methods in org.apache.cassandra.io.sstable.format.big with parameters of type SSTableReader Modifier and Type Method Description static ISSTableScanner
BigTableScanner. getScanner(SSTableReader sstable)
static ISSTableScanner
BigTableScanner. getScanner(SSTableReader sstable, java.util.Collection<Range<Token>> tokenRanges)
static ISSTableScanner
BigTableScanner. getScanner(SSTableReader sstable, java.util.Iterator<AbstractBounds<PartitionPosition>> rangeIterator)
static ISSTableScanner
BigTableScanner. getScanner(SSTableReader sstable, ColumnFilter columns, DataRange dataRange, SSTableReadsListener listener)
Constructors in org.apache.cassandra.io.sstable.format.big with parameters of type SSTableReader Constructor Description EmptySSTableScanner(SSTableReader sstable)
-
Uses of SSTableReader in org.apache.cassandra.io.sstable.metadata
Constructor parameters in org.apache.cassandra.io.sstable.metadata with type arguments of type SSTableReader Constructor Description MetadataCollector(java.lang.Iterable<SSTableReader> sstables, ClusteringComparator comparator, int level)
-
Uses of SSTableReader in org.apache.cassandra.notifications
Fields in org.apache.cassandra.notifications declared as SSTableReader Modifier and Type Field Description SSTableReader
SSTableDeletingNotification. deleting
SSTableReader
SSTableMetadataChanged. sstable
Fields in org.apache.cassandra.notifications with type parameters of type SSTableReader Modifier and Type Field Description java.lang.Iterable<SSTableReader>
InitialSSTableAddedNotification. added
true
if the addition corresponds to theColumnFamilyStore
initialization, then the sstables are those loaded at startup.java.lang.Iterable<SSTableReader>
SSTableAddedNotification. added
The added SSTablesjava.util.Collection<SSTableReader>
SSTableListChangedNotification. added
java.util.Collection<SSTableReader>
SSTableListChangedNotification. removed
java.util.Collection<SSTableReader>
SSTableRepairStatusChanged. sstables
Constructors in org.apache.cassandra.notifications with parameters of type SSTableReader Constructor Description SSTableDeletingNotification(SSTableReader deleting)
SSTableMetadataChanged(SSTableReader levelChanged, StatsMetadata oldMetadata)
Constructor parameters in org.apache.cassandra.notifications with type arguments of type SSTableReader Constructor Description InitialSSTableAddedNotification(java.lang.Iterable<SSTableReader> added)
SSTableAddedNotification(java.lang.Iterable<SSTableReader> added, Memtable memtable)
Creates a newSSTableAddedNotification
for the specified SSTables and optional memtable.SSTableListChangedNotification(java.util.Collection<SSTableReader> added, java.util.Collection<SSTableReader> removed, OperationType compactionType)
SSTableRepairStatusChanged(java.util.Collection<SSTableReader> repairStatusChanged)
-
Uses of SSTableReader in org.apache.cassandra.repair.consistent.admin
Methods in org.apache.cassandra.repair.consistent.admin with parameters of type SSTableReader Modifier and Type Method Description PendingStat.Builder
PendingStat.Builder. addSSTable(SSTableReader sstable)
-
Uses of SSTableReader in org.apache.cassandra.streaming
Methods in org.apache.cassandra.streaming that return types with arguments of type SSTableReader Modifier and Type Method Description com.google.common.base.Predicate<SSTableReader>
PreviewKind. predicate()
-
Uses of SSTableReader in org.apache.cassandra.tools
Methods in org.apache.cassandra.tools that return types with arguments of type SSTableReader Modifier and Type Method 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)
Method parameters in org.apache.cassandra.tools with type arguments of type SSTableReader Modifier and Type Method Description static com.google.common.collect.Multimap<SSTableReader,SSTableReader>
SSTableExpiredBlockers. checkForExpiredSSTableBlockers(java.lang.Iterable<SSTableReader> sstables, int gcBefore)
-