public class BigTableReader extends SSTableReader
SSTableReader.Factory, SSTableReader.OpenReason, SSTableReader.Operator, SSTableReader.SizeComparator, SSTableReader.UniqueIdentifier
RefCounted.Tidy
bf, bloomFilterTracker, dfile, generationReverseComparator, header, ifile, indexSummary, instanceId, isSuspect, keyCache, keyCacheHit, keyCacheRequest, maxDataAge, maxTimestampComparator, openReason, rowIndexEntrySerializer, sizeComparator, sstableComparator, sstableMetadata, sstableOrdering
components, compression, descriptor, first, last, metadata, TOMBSTONE_HISTOGRAM_BIN_SIZE, TOMBSTONE_HISTOGRAM_SPOOL_SIZE, TOMBSTONE_HISTOGRAM_TTL_ROUND_SECONDS
Modifier and Type | Method and Description |
---|---|
protected RowIndexEntry |
getPosition(PartitionPosition key,
SSTableReader.Operator op,
boolean updateCacheAndStats,
boolean permitMatchPastLast,
SSTableReadsListener listener) |
ISSTableScanner |
getScanner(java.util.Collection<Range<Token>> ranges,
com.google.common.util.concurrent.RateLimiter limiter)
Direct I/O SSTableScanner over a defined collection of ranges of tokens.
|
ISSTableScanner |
getScanner(ColumnFilter columns,
DataRange dataRange,
com.google.common.util.concurrent.RateLimiter limiter,
boolean isForThrift,
SSTableReadsListener listener) |
ISSTableScanner |
getScanner(java.util.Iterator<AbstractBounds<PartitionPosition>> boundsIterator)
Direct I/O SSTableScanner over an iterator of bounds.
|
ISSTableScanner |
getScanner(com.google.common.util.concurrent.RateLimiter limiter)
Direct I/O SSTableScanner over the full sstable.
|
SliceableUnfilteredRowIterator |
iterator(DecoratedKey key,
ColumnFilter selectedColumns,
boolean reversed,
boolean isForThrift,
SSTableReadsListener listener) |
SliceableUnfilteredRowIterator |
iterator(FileDataInput file,
DecoratedKey key,
RowIndexEntry indexEntry,
ColumnFilter selectedColumns,
boolean reversed,
boolean isForThrift) |
addTo, cacheKey, cloneWithNewStart, cloneWithNewSummarySamplingLevel, cloneWithRestoredStart, createLinks, equals, estimateCompactionGain, estimatedKeys, estimatedKeysForRanges, firstKeyBeyond, forceFilterFailures, getApproximateKeyCount, getAvgColumnSetPerRow, getBloomFilter, getBloomFilterFalsePositiveCount, getBloomFilterOffHeapSize, getBloomFilterSerializedSize, getBloomFilterTruePositiveCount, getCachedPosition, getCachedPosition, getCacheKey, getCompressionMetadata, getCompressionMetadataOffHeapSize, getCompressionRatio, getCrcCheckChance, getCreationTimeFor, getDataChannel, getDroppableTombstonesBefore, getEffectiveIndexInterval, getEstimatedColumnCount, getEstimatedDroppableTombstoneRatio, getEstimatedPartitionSize, getFileDataInput, getFilename, getIndexChannel, getIndexScanPosition, getIndexScanPositionFromBinarySearchResult, getIndexSummaryIndexFromBinarySearchResult, getIndexSummaryKey, getIndexSummaryOffHeapSize, getIndexSummarySamplingLevel, getIndexSummarySize, getKeyCache, getKeyCacheHit, getKeyCacheRequest, getKeySamples, getMaxIndexSummarySize, getMaxLocalDeletionTime, getMaxTimestamp, getMaxTTL, getMinIndexInterval, getMinLocalDeletionTime, getMinTimestamp, getMinTTL, getPosition, getPosition, getPosition, getPositionsForRanges, getReadMeter, getRecentBloomFilterFalsePositiveCount, getRecentBloomFilterTruePositiveCount, getScanner, getScanner, getScanner, getSSTableLevel, getSSTableMetadata, getTotalBytes, getTotalColumnsSet, getTotalRows, getTotalUncompressedBytes, hashCode, hasTombstones, incrementReadCount, internalOpen, isKeyCacheSetup, isMarkedCompacted, isMarkedSuspect, isRepaired, isReplaced, loadSummary, logOpenException, markObsolete, markSuspect, mayOverlapsWith, newSince, onDiskLength, open, open, open, open, openAll, openDataReader, openDataReader, openForBatch, openIndexReader, openNoValidation, openNoValidation, overrideReadMeter, ref, releaseSummary, reloadSSTableMetadata, resetTidying, runOnClose, saveBloomFilter, saveBloomFilter, saveSummary, saveSummary, selfRef, setCrcCheckChance, setReplaced, setupOnline, shutdownBlocking, tryRef, uncompressedLength
addComponents, appendTOC, bytesOnDisk, componentsFor, decorateKey, delete, discoverComponentsFor, estimateRowsFromIndex, getAllFilePaths, getColumnFamilyName, getIndexFilename, getKeyspaceName, getMinimalKey, getPartitioner, readTOC, toString, tryComponentFromFilename
public SliceableUnfilteredRowIterator iterator(DecoratedKey key, ColumnFilter selectedColumns, boolean reversed, boolean isForThrift, SSTableReadsListener listener)
iterator
in class SSTableReader
public SliceableUnfilteredRowIterator iterator(FileDataInput file, DecoratedKey key, RowIndexEntry indexEntry, ColumnFilter selectedColumns, boolean reversed, boolean isForThrift)
iterator
in class SSTableReader
public ISSTableScanner getScanner(ColumnFilter columns, DataRange dataRange, com.google.common.util.concurrent.RateLimiter limiter, boolean isForThrift, SSTableReadsListener listener)
getScanner
in class SSTableReader
columns
- the columns to return.dataRange
- filter to use when reading the columnslistener
- a listener used to handle internal read eventspublic ISSTableScanner getScanner(java.util.Iterator<AbstractBounds<PartitionPosition>> boundsIterator)
getScanner
in class SSTableReader
boundsIterator
- the keys to coverpublic ISSTableScanner getScanner(com.google.common.util.concurrent.RateLimiter limiter)
getScanner
in class SSTableReader
public ISSTableScanner getScanner(java.util.Collection<Range<Token>> ranges, com.google.common.util.concurrent.RateLimiter limiter)
getScanner
in class SSTableReader
ranges
- the range of keys to coverprotected RowIndexEntry getPosition(PartitionPosition key, SSTableReader.Operator op, boolean updateCacheAndStats, boolean permitMatchPastLast, SSTableReadsListener listener)
getPosition
in class SSTableReader
key
- The key to apply as the rhs to the given Operator. A 'fake' key is allowed to
allow key selection by token bounds but only if op != * EQop
- The Operator defining matching keys: the nearest key to the target matching the operator wins.updateCacheAndStats
- true if updating stats and cachelistener
- a listener used to handle internal eventsCopyright © 2020 The Apache Software Foundation