Package | Description |
---|---|
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.regionserver.handler | |
org.apache.hadoop.hbase.util |
Modifier and Type | Class and Description |
---|---|
class |
KeyValueHeap
Implements a heap merge across any number of KeyValueScanners.
|
class |
MobStoreScanner
Scanner scans both the memstore and the MOB Store.
|
class |
NonLazyKeyValueScanner
A "non-lazy" scanner which always does a real seek operation.
|
class |
NonReversedNonLazyKeyValueScanner
A "non-reversed & non-lazy" scanner which does not support backward scanning and always does
a real seek operation.
|
class |
ReversedKeyValueHeap
ReversedKeyValueHeap is used for supporting reversed scanning.
|
class |
ReversedMobStoreScanner
ReversedMobStoreScanner extends from ReversedStoreScanner, and is used to support reversed
scanning in both the memstore and the MOB store.
|
class |
ReversedStoreScanner
ReversedStoreScanner extends from StoreScanner, and is used to support reversed scanning.
|
class |
SegmentScanner
A scanner of a single memstore segment.
|
class |
SnapshotSegmentScanner
A basic SegmentScanner used against an ImmutableScanner snapshot Used flushing where we do a
single pass, no reverse scanning or inserts happening.
|
class |
StoreFileScanner
KeyValueScanner adaptor over the Reader.
|
class |
StoreScanner
Scanner scans both the memstore and the Store.
|
Modifier and Type | Field and Description |
---|---|
protected KeyValueScanner |
KeyValueHeap.current
The current sub-scanner, i.e.
|
Modifier and Type | Field and Description |
---|---|
(package private) List<KeyValueScanner> |
StoreScanner.currentScanners |
private List<KeyValueScanner> |
StoreScanner.flushedstoreFileScanners |
protected PriorityQueue<KeyValueScanner> |
KeyValueHeap.heap |
private List<KeyValueScanner> |
StoreScanner.memStoreScannersAfterFlush |
(package private) List<KeyValueScanner> |
MemStoreMergerSegmentsIterator.scanners |
protected List<KeyValueScanner> |
KeyValueHeap.scannersForDelayedClose |
private List<KeyValueScanner> |
StoreScanner.scannersForDelayedClose |
Modifier and Type | Method and Description |
---|---|
protected 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() |
protected KeyValueScanner |
Segment.getScanner(long readPoint)
Creates the scanner for the given read point
|
KeyValueScanner |
CompositeImmutableSegment.getScanner(long readPoint)
Creates the scanner for the given read point
|
KeyValueScanner |
HStore.getScanner(Scan scan,
NavigableSet<byte[]> targetCols,
long readPt)
Return a scanner for both the memstore and the HStore files.
|
protected KeyValueScanner |
KeyValueHeap.pollRealKV()
Fetches the top sub-scanner from the priority queue, ensuring that a real seek has been done on
it.
|
Modifier and Type | Method and Description |
---|---|
protected List<KeyValueScanner> |
CompactingMemStore.createList(int capacity) |
(package private) List<KeyValueScanner> |
StoreScanner.getAllScannersForTesting()
Used in testing.
|
PriorityQueue<KeyValueScanner> |
KeyValueHeap.getHeap()
Returns the current Heap
|
List<KeyValueScanner> |
MemStoreSnapshot.getScanners()
Create new
SnapshotSegmentScanner s for iterating over the snapshot. |
List<KeyValueScanner> |
HStore.getScanners(boolean cacheBlocks,
boolean isGet,
boolean usePread,
boolean isCompaction,
ScanQueryMatcher matcher,
byte[] startRow,
byte[] stopRow,
long readPt)
Get all scanners with no filtering based on TTL (that happens further down the line).
|
List<KeyValueScanner> |
HStore.getScanners(boolean cacheBlocks,
boolean usePread,
boolean isCompaction,
ScanQueryMatcher matcher,
byte[] startRow,
boolean includeStartRow,
byte[] stopRow,
boolean includeStopRow,
long readPt)
Get all scanners with no filtering based on TTL (that happens further down the line).
|
List<KeyValueScanner> |
HStore.getScanners(List<HStoreFile> files,
boolean cacheBlocks,
boolean isGet,
boolean usePread,
boolean isCompaction,
ScanQueryMatcher matcher,
byte[] startRow,
byte[] stopRow,
long readPt,
boolean includeMemstoreScanner)
Create scanners on the given files and if needed on the memstore with no filtering based on TTL
(that happens further down the line).
|
List<KeyValueScanner> |
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)
Create scanners on the given files and if needed on the memstore with no filtering based on TTL
(that happens further down the line).
|
List<KeyValueScanner> |
Segment.getScanners(long readPoint) |
List<KeyValueScanner> |
CompositeImmutableSegment.getScanners(long readPoint) |
List<KeyValueScanner> |
CompactingMemStore.getScanners(long readPt)
This method is protected under HStore read lock.
|
List<KeyValueScanner> |
DefaultMemStore.getScanners(long readPt) |
List<KeyValueScanner> |
MemStore.getScanners(long readPt) |
(package private) List<KeyValueScanner> |
CompositeImmutableSegment.getSnapshotScanners() |
(package private) List<KeyValueScanner> |
ImmutableSegment.getSnapshotScanners()
We create a new
SnapshotSegmentScanner to increase the reference count of
MemStoreLABImpl used by this segment. |
List<KeyValueScanner> |
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 scanners
|
protected 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 Type | Method and Description |
---|---|
int |
ReversedKeyValueHeap.ReversedKVScannerComparator.compare(KeyValueScanner left,
KeyValueScanner right) |
int |
KeyValueHeap.KVScannerComparator.compare(KeyValueScanner left,
KeyValueScanner right) |
static boolean |
NonLazyKeyValueScanner.doRealSeek(KeyValueScanner scanner,
Cell kv,
boolean forward) |
private void |
CellArrayImmutableSegment.reinitializeCellSet(int numOfCells,
KeyValueScanner segmentScanner,
CellSet oldCellSet,
MemStoreCompactionStrategy.Action action) |
private void |
CellChunkImmutableSegment.reinitializeCellSet(int numOfCells,
KeyValueScanner segmentScanner,
CellSet oldCellSet,
MemStoreSizing memstoreSizing,
MemStoreCompactionStrategy.Action action) |
Modifier and Type | Method and Description |
---|---|
private void |
StoreScanner.addCurrentScanners(List<? extends KeyValueScanner> scanners) |
static void |
AbstractMemStore.addToScanners(List<? extends Segment> segments,
long readPt,
List<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 InternalScanner |
StoreFlusher.createScanner(List<KeyValueScanner> snapshotScanners,
FlushLifeCycleTracker tracker)
Creates the scanner for flushing snapshot.
|
RegionScanner |
Region.getScanner(Scan scan,
List<KeyValueScanner> additionalScanners)
Return an iterator that scans over the HRegion, returning the indicated columns and rows
specified by the
Scan . |
RegionScannerImpl |
HRegion.getScanner(Scan scan,
List<KeyValueScanner> additionalScanners) |
private RegionScannerImpl |
HRegion.getScanner(Scan scan,
List<KeyValueScanner> additionalScanners,
long nonceGroup,
long nonce) |
private IOException |
RegionScannerImpl.handleException(List<KeyValueScanner> instantiatedScanners,
Throwable t) |
protected void |
RegionScannerImpl.initializeKVHeap(List<KeyValueScanner> scanners,
List<KeyValueScanner> joinedScanners,
HRegion region) |
protected void |
RegionScannerImpl.initializeKVHeap(List<KeyValueScanner> scanners,
List<KeyValueScanner> joinedScanners,
HRegion region) |
protected void |
ReversedRegionScannerImpl.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,
Cell kv)
Seek storefiles in parallel to optimize IO latency as much as possible
|
List<KeyValueScanner> |
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 scanners
|
protected 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,
Cell seekKey,
boolean isLazy,
boolean isParallelSeek) |
protected void |
StoreScanner.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 List<KeyValueScanner> |
StoreScanner.selectScannersFrom(HStore store,
List<? extends KeyValueScanner> allScanners)
Filters the given list of scanners using Bloom filter, time range, and TTL.
|
void |
StoreScanner.updateReaders(List<HStoreFile> sfs,
List<KeyValueScanner> memStoreScanners) |
void |
ChangedReadersObserver.updateReaders(List<HStoreFile> sfs,
List<KeyValueScanner> memStoreScanners)
Notify observers.
|
Constructor and Description |
---|
KeyValueHeap(List<? extends KeyValueScanner> scanners,
CellComparator comparator)
Constructor.
|
KeyValueHeap(List<? extends KeyValueScanner> scanners,
KeyValueHeap.KVScannerComparator comparator)
Constructor.
|
RegionScannerImpl(Scan scan,
List<KeyValueScanner> additionalScanners,
HRegion region,
long nonceGroup,
long nonce) |
ReversedKeyValueHeap(List<? extends KeyValueScanner> scanners,
CellComparator comparator)
nnn
|
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.
|
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.
|
StoreScanner(HStore store,
ScanInfo scanInfo,
List<? extends KeyValueScanner> scanners,
ScanType scanType,
long smallestReadPoint,
long earliestPutTs,
byte[] dropDeletesFromRow,
byte[] dropDeletesToRow) |
StoreScanner(ScanInfo scanInfo,
int maxVersions,
ScanType scanType,
List<? extends KeyValueScanner> scanners) |
StoreScanner(ScanInfo scanInfo,
ScanType scanType,
List<? extends KeyValueScanner> scanners) |
StoreScanner(Scan scan,
ScanInfo scanInfo,
NavigableSet<byte[]> columns,
List<? extends KeyValueScanner> scanners) |
StoreScanner(Scan scan,
ScanInfo scanInfo,
NavigableSet<byte[]> columns,
List<? extends KeyValueScanner> scanners,
ScanType scanType) |
Modifier and Type | Field and Description |
---|---|
private KeyValueScanner |
ParallelSeekHandler.scanner |
Constructor and Description |
---|
ParallelSeekHandler(KeyValueScanner scanner,
Cell keyValue,
long readPoint,
CountDownLatch latch) |
Modifier and Type | Class and Description |
---|---|
class |
CollectionBackedScanner
Utility scanner that wraps a sortable collection and serves as a KeyValueScanner.
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.