Uses of Interface
org.apache.hadoop.hbase.regionserver.KeyValueScanner
Package
Description
-
Uses of KeyValueScanner in org.apache.hadoop.hbase.regionserver
Modifier and TypeClassDescriptionclass
Implements a heap merge across any number of KeyValueScanners.class
Scanner scans both the memstore and the MOB Store.class
A "non-lazy" scanner which always does a real seek operation.class
A "non-reversed & non-lazy" scanner which does not support backward scanning and always does a real seek operation.class
ReversedKeyValueHeap is used for supporting reversed scanning.class
ReversedMobStoreScanner extends from ReversedStoreScanner, and is used to support reversed scanning in both the memstore and the MOB store.class
ReversedStoreScanner extends from StoreScanner, and is used to support reversed scanning.class
A scanner of a single memstore segment.class
A basic SegmentScanner used against an ImmutableScanner snapshot Used flushing where we do a single pass, no reverse scanning or inserts happening.class
KeyValueScanner adaptor over the Reader.class
Scanner scans both the memstore and the Store.Modifier and TypeFieldDescriptionprotected KeyValueScanner
KeyValueHeap.current
The current sub-scanner, i.e.Modifier and TypeFieldDescription(package private) final List<KeyValueScanner>
StoreScanner.currentScanners
private final List<KeyValueScanner>
StoreScanner.flushedstoreFileScanners
protected PriorityQueue<KeyValueScanner>
KeyValueHeap.heap
private final List<KeyValueScanner>
StoreScanner.memStoreScannersAfterFlush
(package private) List<KeyValueScanner>
MemStoreMergerSegmentsIterator.scanners
protected List<KeyValueScanner>
KeyValueHeap.scannersForDelayedClose
private final List<KeyValueScanner>
StoreScanner.scannersForDelayedClose
Modifier and TypeMethodDescriptionprotected KeyValueScanner
HMobStore.createScanner
(Scan scan, ScanInfo scanInfo, NavigableSet<byte[]> targetCols, long readPt) Gets the MobStoreScanner or MobReversedStoreScanner.protected KeyValueScanner
HStore.createScanner
(Scan scan, ScanInfo scanInfo, NavigableSet<byte[]> targetCols, long readPt) (package private) KeyValueScanner
KeyValueHeap.getCurrentForTesting()
CompositeImmutableSegment.getScanner
(long readPoint) Creates the scanner for the given read pointHStore.getScanner
(Scan scan, NavigableSet<byte[]> targetCols, long readPt) Return a scanner for both the memstore and the HStore files.protected KeyValueScanner
Segment.getScanner
(long readPoint) Creates the scanner for the given read pointprotected KeyValueScanner
KeyValueHeap.pollRealKV()
Fetches the top sub-scanner from the priority queue, ensuring that a real seek has been done on it.Modifier and TypeMethodDescriptionprotected List<KeyValueScanner>
CompactingMemStore.createList
(int capacity) (package private) List<KeyValueScanner>
StoreScanner.getAllScannersForTesting()
Used in testing.KeyValueHeap.getHeap()
Returns the current HeapCompactingMemStore.getScanners
(long readPt) This method is protected underHStore#lock
read lock.CompositeImmutableSegment.getScanners
(long readPoint) DefaultMemStore.getScanners
(long readPt) HStore.getScanners
(boolean cacheBlocks, boolean isGet, boolean usePread, boolean isCompaction, ScanQueryMatcher matcher, byte[] startRow, byte[] stopRow, long readPt, boolean onlyLatestVersion) Get all scanners with no filtering based on TTL (that happens further down the line).HStore.getScanners
(boolean cacheBlocks, boolean usePread, boolean isCompaction, ScanQueryMatcher matcher, byte[] startRow, boolean includeStartRow, byte[] stopRow, boolean includeStopRow, long readPt, boolean onlyLatestVersion) Get all scanners with no filtering based on TTL (that happens further down the line).HStore.getScanners
(List<HStoreFile> files, boolean cacheBlocks, boolean isGet, boolean usePread, boolean isCompaction, ScanQueryMatcher matcher, byte[] startRow, byte[] stopRow, long readPt, boolean includeMemstoreScanner, boolean onlyLatestVersion) Create scanners on the given files and if needed on the memstore with no filtering based on TTL (that happens further down the line).HStore.getScanners
(List<HStoreFile> files, boolean cacheBlocks, boolean usePread, boolean isCompaction, ScanQueryMatcher matcher, byte[] startRow, boolean includeStartRow, byte[] stopRow, boolean includeStopRow, long readPt, boolean includeMemstoreScanner, boolean onlyLatestVersion) Create scanners on the given files and if needed on the memstore with no filtering based on TTL (that happens further down the line).MemStore.getScanners
(long readPt) MemStoreSnapshot.getScanners()
Create newSnapshotSegmentScanner
s for iterating over the snapshot.Segment.getScanners
(long readPoint) (package private) List<KeyValueScanner>
CompositeImmutableSegment.getSnapshotScanners()
(package private) List<KeyValueScanner>
ImmutableSegment.getSnapshotScanners()
We create a newSnapshotSegmentScanner
to increase the reference count ofMemStoreLABImpl
used by this segment.HStore.recreateScanners
(List<KeyValueScanner> currentFileScanners, boolean cacheBlocks, boolean usePread, boolean isCompaction, ScanQueryMatcher matcher, byte[] startRow, boolean includeStartRow, byte[] stopRow, boolean includeStopRow, long readPt, boolean includeMemstoreScanner) Recreates the scanners on the current list of active store file scannersprotected List<KeyValueScanner>
StoreScanner.selectScannersFrom
(HStore store, List<? extends KeyValueScanner> allScanners) Filters the given list of scanners using Bloom filter, time range, and TTL.Modifier and TypeMethodDescriptionint
KeyValueHeap.KVScannerComparator.compare
(KeyValueScanner left, KeyValueScanner right) int
ReversedKeyValueHeap.ReversedKVScannerComparator.compare
(KeyValueScanner left, KeyValueScanner right) static boolean
NonLazyKeyValueScanner.doRealSeek
(KeyValueScanner scanner, ExtendedCell kv, boolean forward) private void
CellArrayImmutableSegment.reinitializeCellSet
(int numOfCells, KeyValueScanner segmentScanner, CellSet<ExtendedCell> oldCellSet, MemStoreCompactionStrategy.Action action) private void
CellChunkImmutableSegment.reinitializeCellSet
(int numOfCells, KeyValueScanner segmentScanner, CellSet<ExtendedCell> oldCellSet, MemStoreSizing memstoreSizing, MemStoreCompactionStrategy.Action action) Modifier and TypeMethodDescriptionprivate void
StoreScanner.addCurrentScanners
(List<? extends KeyValueScanner> scanners) protected static void
AbstractMemStore.addToScanners
(Segment segment, long readPt, List<KeyValueScanner> scanners) private static void
HStore.clearAndClose
(List<KeyValueScanner> scanners) private static void
StoreScanner.clearAndClose
(List<KeyValueScanner> scanners) private InternalScanner
MemStoreCompactorSegmentsIterator.createScanner
(HStore store, List<KeyValueScanner> scanners) Creates the scanner for compacting the pipeline.protected final InternalScanner
StoreFlusher.createScanner
(List<KeyValueScanner> snapshotScanners, FlushLifeCycleTracker tracker) Creates the scanner for flushing snapshot.HRegion.getScanner
(Scan scan, List<KeyValueScanner> additionalScanners) private RegionScannerImpl
HRegion.getScanner
(Scan scan, List<KeyValueScanner> additionalScanners, long nonceGroup, long nonce) Region.getScanner
(Scan scan, List<KeyValueScanner> additionalScanners) Return an iterator that scans over the HRegion, returning the indicated columns and rows specified by theScan
.private IOException
RegionScannerImpl.handleException
(List<KeyValueScanner> instantiatedScanners, Throwable t) protected void
RegionScannerImpl.initializeKVHeap
(List<KeyValueScanner> scanners, List<KeyValueScanner> joinedScanners, HRegion region) protected void
ReversedRegionScannerImpl.initializeKVHeap
(List<KeyValueScanner> scanners, List<KeyValueScanner> joinedScanners, HRegion region) private void
RegionScannerImpl.initializeScanners
(Scan scan, List<KeyValueScanner> additionalScanners) protected RegionScannerImpl
HRegion.instantiateRegionScanner
(Scan scan, List<KeyValueScanner> additionalScanners, long nonceGroup, long nonce) protected KeyValueHeap
ReversedStoreScanner.newKVHeap
(List<? extends KeyValueScanner> scanners, CellComparator comparator) protected KeyValueHeap
StoreScanner.newKVHeap
(List<? extends KeyValueScanner> scanners, CellComparator comparator) private void
StoreScanner.parallelSeek
(List<? extends KeyValueScanner> scanners, ExtendedCell kv) Seek storefiles in parallel to optimize IO latency as much as possibleHStore.recreateScanners
(List<KeyValueScanner> currentFileScanners, boolean cacheBlocks, boolean usePread, boolean isCompaction, ScanQueryMatcher matcher, byte[] startRow, boolean includeStartRow, byte[] stopRow, boolean includeStopRow, long readPt, boolean includeMemstoreScanner) Recreates the scanners on the current list of active store file scannersprotected void
StoreScanner.resetKVHeap
(List<? extends KeyValueScanner> scanners, CellComparator comparator) private void
StoreScanner.seekAllScanner
(ScanInfo scanInfo, List<? extends KeyValueScanner> scanners) protected void
ReversedStoreScanner.seekScanners
(List<? extends KeyValueScanner> scanners, ExtendedCell seekKey, boolean isLazy, boolean isParallelSeek) protected void
StoreScanner.seekScanners
(List<? extends KeyValueScanner> scanners, ExtendedCell seekKey, boolean isLazy, boolean isParallelSeek) Seek the specified scanners with the given keyprotected List<KeyValueScanner>
StoreScanner.selectScannersFrom
(HStore store, List<? extends KeyValueScanner> allScanners) Filters the given list of scanners using Bloom filter, time range, and TTL.ModifierConstructorDescriptionKeyValueHeap
(List<? extends KeyValueScanner> scanners, CellComparator comparator) Constructor.(package private)
KeyValueHeap
(List<? extends KeyValueScanner> scanners, KeyValueHeap.KVScannerComparator comparator) Constructor.(package private)
RegionScannerImpl
(Scan scan, List<KeyValueScanner> additionalScanners, HRegion region, long nonceGroup, long nonce) ReversedKeyValueHeap
(List<? extends KeyValueScanner> scanners, CellComparator comparator) (package private)
ReversedRegionScannerImpl
(Scan scan, List<KeyValueScanner> additionalScanners, HRegion region, long nonceGroup, long nonce) ReversedStoreScanner
(Scan scan, ScanInfo scanInfo, NavigableSet<byte[]> columns, List<? extends KeyValueScanner> scanners) Constructor for testing.(package private)
StoreScanner
(Scan scan, ScanInfo scanInfo, NavigableSet<byte[]> columns, List<? extends KeyValueScanner> scanners) (package private)
StoreScanner
(Scan scan, ScanInfo scanInfo, NavigableSet<byte[]> columns, List<? extends KeyValueScanner> scanners, ScanType scanType) StoreScanner
(HStore store, ScanInfo scanInfo, List<? extends KeyValueScanner> scanners, long smallestReadPoint, long earliestPutTs, byte[] dropDeletesFromRow, byte[] dropDeletesToRow) Used for compactions that drop deletes from a limited range of rows.StoreScanner
(HStore store, ScanInfo scanInfo, List<? extends KeyValueScanner> scanners, ScanType scanType, long smallestReadPoint, long earliestPutTs) Used for store file compaction and memstore compaction.private
StoreScanner
(HStore store, ScanInfo scanInfo, List<? extends KeyValueScanner> scanners, ScanType scanType, long smallestReadPoint, long earliestPutTs, byte[] dropDeletesFromRow, byte[] dropDeletesToRow) (package private)
StoreScanner
(ScanInfo scanInfo, int maxVersions, ScanType scanType, List<? extends KeyValueScanner> scanners) StoreScanner
(ScanInfo scanInfo, ScanType scanType, List<? extends KeyValueScanner> scanners) -
Uses of KeyValueScanner in org.apache.hadoop.hbase.regionserver.handler
ModifierConstructorDescriptionParallelSeekHandler
(KeyValueScanner scanner, ExtendedCell keyValue, long readPoint, CountDownLatch latch) -
Uses of KeyValueScanner in org.apache.hadoop.hbase.util
Modifier and TypeClassDescriptionclass
Utility scanner that wraps a sortable collection and serves as a KeyValueScanner.