Package | Description |
---|---|
org.apache.hadoop.hbase.coprocessor |
Table of Contents
|
org.apache.hadoop.hbase.coprocessor.example | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.regionserver.handler | |
org.apache.hadoop.hbase.util |
Modifier and Type | Method and Description |
---|---|
KeyValueScanner |
RegionObserver.preStoreScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
Scan scan,
NavigableSet<byte[]> targetCols,
KeyValueScanner s)
Called before a store opens a new scanner.
|
KeyValueScanner |
BaseRegionObserver.preStoreScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
Scan scan,
NavigableSet<byte[]> targetCols,
KeyValueScanner s) |
Modifier and Type | Method and Description |
---|---|
InternalScanner |
RegionObserver.preFlushScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
KeyValueScanner memstoreScanner,
InternalScanner s)
Called before a memstore is flushed to disk and prior to creating the scanner to read from
the memstore.
|
InternalScanner |
BaseRegionObserver.preFlushScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
KeyValueScanner memstoreScanner,
InternalScanner s) |
KeyValueScanner |
RegionObserver.preStoreScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
Scan scan,
NavigableSet<byte[]> targetCols,
KeyValueScanner s)
Called before a store opens a new scanner.
|
KeyValueScanner |
BaseRegionObserver.preStoreScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
Scan scan,
NavigableSet<byte[]> targetCols,
KeyValueScanner s) |
Modifier and Type | Method and Description |
---|---|
InternalScanner |
RegionObserver.preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
List<? extends KeyValueScanner> scanners,
ScanType scanType,
long earliestPutTs,
InternalScanner s)
|
InternalScanner |
BaseRegionObserver.preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
List<? extends KeyValueScanner> scanners,
ScanType scanType,
long earliestPutTs,
InternalScanner s) |
InternalScanner |
RegionObserver.preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
List<? extends KeyValueScanner> scanners,
ScanType scanType,
long earliestPutTs,
InternalScanner s,
CompactionRequest request)
Called prior to writing the
StoreFile s selected for compaction into a new
StoreFile and prior to creating the scanner used to read the input files. |
InternalScanner |
BaseRegionObserver.preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
List<? extends KeyValueScanner> scanners,
ScanType scanType,
long earliestPutTs,
InternalScanner s,
CompactionRequest request) |
Modifier and Type | Method and Description |
---|---|
KeyValueScanner |
ZooKeeperScanPolicyObserver.preStoreScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
Scan scan,
NavigableSet<byte[]> targetCols,
KeyValueScanner s) |
Modifier and Type | Method and Description |
---|---|
InternalScanner |
ZooKeeperScanPolicyObserver.preFlushScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
KeyValueScanner memstoreScanner,
InternalScanner s) |
KeyValueScanner |
ZooKeeperScanPolicyObserver.preStoreScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
Scan scan,
NavigableSet<byte[]> targetCols,
KeyValueScanner s) |
Modifier and Type | Method and Description |
---|---|
InternalScanner |
ZooKeeperScanPolicyObserver.preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
List<? extends KeyValueScanner> scanners,
ScanType scanType,
long earliestPutTs,
InternalScanner s) |
Modifier and Type | Class and Description |
---|---|
protected class |
DefaultMemStore.MemStoreScanner |
class |
KeyValueHeap
Implements a heap merge across any number of KeyValueScanners.
|
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.
|
(package private) class |
ReversedStoreScanner
ReversedStoreScanner extends from StoreScanner, and is used to support
reversed scanning.
|
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.
|
private KeyValueScanner |
MemStoreSnapshot.scanner |
Modifier and Type | Field and Description |
---|---|
protected PriorityQueue<KeyValueScanner> |
KeyValueHeap.heap |
Modifier and Type | Method and Description |
---|---|
(package private) KeyValueScanner |
KeyValueHeap.getCurrentForTesting() |
KeyValueScanner |
MemStoreSnapshot.getScanner() |
KeyValueScanner |
Store.getScanner(Scan scan,
NavigableSet<byte[]> targetCols,
long readPt)
Return a scanner for both the memstore and the HStore files.
|
KeyValueScanner |
HStore.getScanner(Scan scan,
NavigableSet<byte[]> targetCols,
long readPt) |
protected KeyValueScanner |
KeyValueHeap.pollRealKV()
Fetches the top sub-scanner from the priority queue, ensuring that a real
seek has been done on it.
|
KeyValueScanner |
RegionCoprocessorHost.preStoreScannerOpen(Store store,
Scan scan,
NavigableSet<byte[]> targetCols)
|
Modifier and Type | Method and Description |
---|---|
(package private) List<KeyValueScanner> |
StoreScanner.getAllScannersForTesting()
Used in testing.
|
PriorityQueue<KeyValueScanner> |
KeyValueHeap.getHeap() |
List<KeyValueScanner> |
Store.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 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> |
DefaultMemStore.getScanners(long readPt) |
List<KeyValueScanner> |
MemStore.getScanners(long readPt) |
protected List<KeyValueScanner> |
StoreScanner.getScannersNoCompaction()
Get a filtered list of scanners.
|
protected List<KeyValueScanner> |
StoreScanner.selectScannersFrom(List<? extends KeyValueScanner> allScanners)
Filters the given list of scanners using Bloom filter, time range, and
TTL.
|
Modifier and Type | Method and Description |
---|---|
int |
KeyValueHeap.KVScannerComparator.compare(KeyValueScanner left,
KeyValueScanner right) |
int |
ReversedKeyValueHeap.ReversedKVScannerComparator.compare(KeyValueScanner left,
KeyValueScanner right) |
protected InternalScanner |
StoreFlusher.createScanner(KeyValueScanner snapshotScanner,
long smallestReadPoint)
Creates the scanner for flushing snapshot.
|
static boolean |
NonLazyKeyValueScanner.doRealSeek(KeyValueScanner scanner,
Cell kv,
boolean forward) |
InternalScanner |
RegionCoprocessorHost.preFlushScannerOpen(Store store,
KeyValueScanner memstoreScanner)
|
Modifier and Type | Method and Description |
---|---|
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 . |
RegionScanner |
HRegion.getScanner(Scan scan,
List<KeyValueScanner> additionalScanners) |
private IOException |
HRegion.RegionScannerImpl.handleException(List<KeyValueScanner> instantiatedScanners,
Throwable t) |
protected void |
ReversedRegionScannerImpl.initializeKVHeap(List<KeyValueScanner> scanners,
List<KeyValueScanner> joinedScanners,
HRegion region) |
protected void |
ReversedRegionScannerImpl.initializeKVHeap(List<KeyValueScanner> scanners,
List<KeyValueScanner> joinedScanners,
HRegion region) |
protected void |
HRegion.RegionScannerImpl.initializeKVHeap(List<KeyValueScanner> scanners,
List<KeyValueScanner> joinedScanners,
HRegion region) |
protected void |
HRegion.RegionScannerImpl.initializeKVHeap(List<KeyValueScanner> scanners,
List<KeyValueScanner> joinedScanners,
HRegion region) |
protected RegionScanner |
HRegion.instantiateRegionScanner(Scan scan,
List<KeyValueScanner> additionalScanners) |
private void |
StoreScanner.parallelSeek(List<? extends KeyValueScanner> scanners,
Cell kv)
Seek storefiles in parallel to optimize IO latency as much as possible
|
protected void |
StoreScanner.resetKVHeap(List<? extends KeyValueScanner> scanners,
KeyValue.KVComparator comparator) |
protected void |
ReversedStoreScanner.resetKVHeap(List<? extends KeyValueScanner> scanners,
KeyValue.KVComparator comparator) |
protected void |
StoreScanner.seekScanners(List<? extends KeyValueScanner> scanners,
Cell seekKey,
boolean isLazy,
boolean isParallelSeek)
Seek the specified scanners with the given key
|
protected void |
ReversedStoreScanner.seekScanners(List<? extends KeyValueScanner> scanners,
Cell seekKey,
boolean isLazy,
boolean isParallelSeek) |
protected List<KeyValueScanner> |
StoreScanner.selectScannersFrom(List<? extends KeyValueScanner> allScanners)
Filters the given list of scanners using Bloom filter, time range, and
TTL.
|
Constructor and Description |
---|
MemStoreSnapshot(long id,
int cellsCount,
long size,
TimeRangeTracker timeRangeTracker,
KeyValueScanner scanner,
boolean tagsPresent) |
Constructor and Description |
---|
HRegion.RegionScannerImpl(Scan scan,
List<KeyValueScanner> additionalScanners,
HRegion region) |
KeyValueHeap(List<? extends KeyValueScanner> scanners,
KeyValue.KVComparator comparator)
Constructor.
|
KeyValueHeap(List<? extends KeyValueScanner> scanners,
KeyValueHeap.KVScannerComparator comparator)
Constructor.
|
ReversedKeyValueHeap(List<? extends KeyValueScanner> scanners,
KeyValue.KVComparator comparator) |
ReversedRegionScannerImpl(Scan scan,
List<KeyValueScanner> additionalScanners,
HRegion region) |
ReversedStoreScanner(Scan scan,
ScanInfo scanInfo,
ScanType scanType,
NavigableSet<byte[]> columns,
List<KeyValueScanner> scanners)
Constructor for testing.
|
StoreScanner(Scan scan,
ScanInfo scanInfo,
ScanType scanType,
NavigableSet<byte[]> columns,
List<KeyValueScanner> scanners) |
StoreScanner(Scan scan,
ScanInfo scanInfo,
ScanType scanType,
NavigableSet<byte[]> columns,
List<KeyValueScanner> scanners,
long earliestPutTs) |
StoreScanner(Scan scan,
ScanInfo scanInfo,
ScanType scanType,
NavigableSet<byte[]> columns,
List<KeyValueScanner> scanners,
long earliestPutTs,
long readPt) |
StoreScanner(Store store,
ScanInfo scanInfo,
Scan scan,
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(Store store,
ScanInfo scanInfo,
Scan scan,
List<? extends KeyValueScanner> scanners,
ScanType scanType,
long smallestReadPoint,
long earliestPutTs)
Used for compactions.
|
StoreScanner(Store store,
ScanInfo scanInfo,
Scan scan,
List<? extends KeyValueScanner> scanners,
ScanType scanType,
long smallestReadPoint,
long earliestPutTs,
byte[] dropDeletesFromRow,
byte[] dropDeletesToRow) |
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–2019 The Apache Software Foundation. All rights reserved.