@InterfaceAudience.Private public class ReversedStoreScanner extends StoreScanner implements KeyValueScanner
currentScanners, DEFAULT_HBASE_CELLS_SCANNED_PER_HEARTBEAT_CHECK, HBASE_CELLS_SCANNED_PER_HEARTBEAT_CHECK, heap, LAZY_SEEK_ENABLED_BY_DEFAULT, memstoreOnlyReads, mixedReads, readPt, store, STORESCANNER_PARALLEL_SEEK_ENABLE, STORESCANNER_PREAD_MAX_BYTES
NO_NEXT_INDEXED_KEY
Constructor and Description |
---|
ReversedStoreScanner(HStore store,
ScanInfo scanInfo,
Scan scan,
NavigableSet<byte[]> columns,
long readPt)
Opens a scanner across memstore, snapshot, and all StoreFiles.
|
ReversedStoreScanner(Scan scan,
ScanInfo scanInfo,
NavigableSet<byte[]> columns,
List<? extends KeyValueScanner> scanners)
Constructor for testing.
|
Modifier and Type | Method and Description |
---|---|
boolean |
backwardSeek(Cell key)
Seek the scanner at or before the row of specified Cell, it firstly tries to seek the scanner
at or after the specified Cell, return if peek KeyValue of scanner has the same row with
specified Cell, otherwise seek the scanner at the first Cell of the row which is the previous
row of specified KeyValue
|
protected void |
checkScanOrder(Cell prevKV,
Cell kv,
CellComparator comparator)
Check whether scan as expected order nnnn
|
protected KeyValueHeap |
newKVHeap(List<? extends KeyValueScanner> scanners,
CellComparator comparator) |
boolean |
reseek(Cell kv)
Reseek the scanner at or after the specified KeyValue.
|
boolean |
seek(Cell key)
Seek the scanner at or after the specified KeyValue.
|
protected boolean |
seekAsDirection(Cell kv)
Do a backwardSeek in a reversed StoreScanner(scan backward)
|
protected void |
seekScanners(List<? extends KeyValueScanner> scanners,
Cell seekKey,
boolean isLazy,
boolean isParallelSeek)
Seek the specified scanners with the given key nn * @param isLazy true if using lazy seek
|
protected boolean |
seekToNextRow(Cell kv) |
boolean |
seekToPreviousRow(Cell key)
Seek the scanner at the first Cell of the row which is the previous row of specified key
|
checkFlushed, close, enableLazySeekGlobally, getAllScannersForTesting, getEstimatedNumberOfKvsScanned, getNextIndexedKey, getReadPoint, isScanUsePread, next, next, peek, reopenAfterFlush, resetKVHeap, selectScannersFrom, shipped, trySkipToNextColumn, trySkipToNextRow, trySwitchToStreamRead, updateReaders
seekToLastRow
doRealSeek, enforceSeek, getFilePath, isFileScanner, realSeekDone, requestSeek, shouldUseScanner
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
close, enforceSeek, getFilePath, getNextIndexedKey, getScannerOrder, isFileScanner, next, peek, realSeekDone, requestSeek, seekToLastRow, shouldUseScanner
next
public ReversedStoreScanner(HStore store, ScanInfo scanInfo, Scan scan, NavigableSet<byte[]> columns, long readPt) throws IOException
store
- who we scan n * @param scan the speccolumns
- which columns we are scanning nIOException
public ReversedStoreScanner(Scan scan, ScanInfo scanInfo, NavigableSet<byte[]> columns, List<? extends KeyValueScanner> scanners) throws IOException
IOException
protected KeyValueHeap newKVHeap(List<? extends KeyValueScanner> scanners, CellComparator comparator) throws IOException
newKVHeap
in class StoreScanner
IOException
protected void seekScanners(List<? extends KeyValueScanner> scanners, Cell seekKey, boolean isLazy, boolean isParallelSeek) throws IOException
StoreScanner
seekScanners
in class StoreScanner
isParallelSeek
- true if using parallel seek nIOException
protected boolean seekToNextRow(Cell kv) throws IOException
seekToNextRow
in class StoreScanner
IOException
protected boolean seekAsDirection(Cell kv) throws IOException
seekAsDirection
in class StoreScanner
IOException
protected void checkScanOrder(Cell prevKV, Cell kv, CellComparator comparator) throws IOException
StoreScanner
checkScanOrder
in class StoreScanner
IOException
public boolean reseek(Cell kv) throws IOException
KeyValueScanner
reseek
in interface KeyValueScanner
reseek
in class StoreScanner
kv
- seek value (should be non-null)IOException
public boolean seek(Cell key) throws IOException
KeyValueScanner
seek
in interface KeyValueScanner
seek
in class StoreScanner
key
- seek valueIOException
public boolean seekToPreviousRow(Cell key) throws IOException
KeyValueScanner
seekToPreviousRow
in interface KeyValueScanner
seekToPreviousRow
in class NonReversedNonLazyKeyValueScanner
key
- seek valueIOException
public boolean backwardSeek(Cell key) throws IOException
KeyValueScanner
backwardSeek
in interface KeyValueScanner
backwardSeek
in class NonReversedNonLazyKeyValueScanner
key
- seek KeyValueIOException
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.