Modifier and Type | Method and Description |
---|---|
default InternalScanner |
RegionObserver.preCompact(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
InternalScanner scanner,
ScanType scanType,
CompactionLifeCycleTracker tracker,
CompactionRequest request)
Called prior to writing the
StoreFile s selected for compaction into a new
StoreFile . |
default InternalScanner |
RegionObserver.preFlush(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
InternalScanner scanner,
FlushLifeCycleTracker tracker)
Called before a Store's memstore is flushed to disk.
|
default InternalScanner |
RegionObserver.preMemStoreCompactionCompact(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
InternalScanner scanner)
Called before we do in memory compaction.
|
Modifier and Type | Method and Description |
---|---|
default void |
RegionObserver.postScannerClose(ObserverContext<RegionCoprocessorEnvironment> ctx,
InternalScanner s)
Called after the client closes a scanner.
|
default boolean |
RegionObserver.postScannerFilterRow(ObserverContext<RegionCoprocessorEnvironment> c,
InternalScanner s,
Cell curRowCell,
boolean hasMore)
This will be called by the scan flow when the current scanned row is being filtered out by the
filter.
|
default boolean |
RegionObserver.postScannerNext(ObserverContext<RegionCoprocessorEnvironment> c,
InternalScanner s,
List<Result> result,
int limit,
boolean hasNext)
Called after the client asks for the next row on a scanner.
|
default InternalScanner |
RegionObserver.preCompact(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
InternalScanner scanner,
ScanType scanType,
CompactionLifeCycleTracker tracker,
CompactionRequest request)
Called prior to writing the
StoreFile s selected for compaction into a new
StoreFile . |
default InternalScanner |
RegionObserver.preFlush(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
InternalScanner scanner,
FlushLifeCycleTracker tracker)
Called before a Store's memstore is flushed to disk.
|
default InternalScanner |
RegionObserver.preMemStoreCompactionCompact(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
InternalScanner scanner)
Called before we do in memory compaction.
|
default void |
RegionObserver.preScannerClose(ObserverContext<RegionCoprocessorEnvironment> c,
InternalScanner s)
Called before the client closes a scanner.
|
default boolean |
RegionObserver.preScannerNext(ObserverContext<RegionCoprocessorEnvironment> c,
InternalScanner s,
List<Result> result,
int limit,
boolean hasNext)
Called before the client asks for the next row on a scanner.
|
Modifier and Type | Class and Description |
---|---|
class |
DelegatingInternalScanner
A simple delegation for doing filtering on
InternalScanner . |
Modifier and Type | Field and Description |
---|---|
protected InternalScanner |
DelegatingInternalScanner.scanner |
Modifier and Type | Method and Description |
---|---|
InternalScanner |
WriteHeavyIncrementObserver.preCompact(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
InternalScanner scanner,
ScanType scanType,
CompactionLifeCycleTracker tracker,
CompactionRequest request) |
InternalScanner |
ValueRewritingObserver.preCompact(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
InternalScanner scanner,
ScanType scanType,
CompactionLifeCycleTracker tracker,
CompactionRequest request) |
InternalScanner |
WriteHeavyIncrementObserver.preFlush(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
InternalScanner scanner,
FlushLifeCycleTracker tracker) |
InternalScanner |
WriteHeavyIncrementObserver.preMemStoreCompactionCompact(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
InternalScanner scanner) |
private InternalScanner |
WriteHeavyIncrementObserver.wrap(byte[] family,
InternalScanner scanner) |
Constructor and Description |
---|
DelegatingInternalScanner(InternalScanner scanner) |
Modifier and Type | Method and Description |
---|---|
protected boolean |
DefaultMobStoreCompactor.performCompaction(Compactor.FileDetails fd,
InternalScanner scanner,
CellSink writer,
long smallestReadPoint,
boolean cleanSeqId,
ThroughputController throughputController,
CompactionRequestImpl request,
CompactionProgress progress)
Performs compaction on a column family with the mob flag enabled.
|
protected void |
DefaultMobStoreFlusher.performMobFlush(MemStoreSnapshot snapshot,
long cacheFlushId,
InternalScanner scanner,
StoreFileWriter writer,
MonitoredTask status,
ThroughputController throughputController,
Consumer<org.apache.hadoop.fs.Path> writerCreationTracker)
Flushes the cells in the mob store.
|
Modifier and Type | Interface and Description |
---|---|
interface |
RegionScanner
RegionScanner describes iterators over rows in an HRegion.
|
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.
|
(package private) class |
RegionScannerImpl
RegionScannerImpl is used to combine scanners from multiple Stores (aka column families).
|
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.
|
(package private) class |
ReversedRegionScannerImpl
ReversibleRegionScannerImpl extends from RegionScannerImpl, and is used to support reversed
scanning.
|
class |
ReversedStoreScanner
ReversedStoreScanner extends from StoreScanner, and is used to support reversed scanning.
|
class |
StoreScanner
Scanner scans both the memstore and the Store.
|
Modifier and Type | Field and Description |
---|---|
private InternalScanner |
MemStoreCompactorSegmentsIterator.compactingScanner |
Modifier and Type | Method and Description |
---|---|
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.
|
InternalScanner |
RegionCoprocessorHost.preCompact(HStore store,
InternalScanner scanner,
ScanType scanType,
CompactionLifeCycleTracker tracker,
CompactionRequest request,
User user)
Called prior to rewriting the store files selected for compaction
|
InternalScanner |
RegionCoprocessorHost.preFlush(HStore store,
InternalScanner scanner,
FlushLifeCycleTracker tracker)
Invoked before a memstore flush
|
InternalScanner |
RegionCoprocessorHost.preMemStoreCompactionCompact(HStore store,
InternalScanner scanner)
Invoked before compacting memstore.
|
Modifier and Type | Method and Description |
---|---|
protected void |
StoreFlusher.performFlush(InternalScanner scanner,
CellSink sink,
ThroughputController throughputController)
Performs memstore flush, writing data from scanner into sink.
|
void |
RegionCoprocessorHost.postScannerClose(InternalScanner s) |
boolean |
RegionCoprocessorHost.postScannerFilterRow(InternalScanner s,
Cell curRowCell)
This will be called by the scan flow when the current scanned row is being filtered out by the
filter.
|
boolean |
RegionCoprocessorHost.postScannerNext(InternalScanner s,
List<Result> results,
int limit,
boolean hasMore) |
InternalScanner |
RegionCoprocessorHost.preCompact(HStore store,
InternalScanner scanner,
ScanType scanType,
CompactionLifeCycleTracker tracker,
CompactionRequest request,
User user)
Called prior to rewriting the store files selected for compaction
|
InternalScanner |
RegionCoprocessorHost.preFlush(HStore store,
InternalScanner scanner,
FlushLifeCycleTracker tracker)
Invoked before a memstore flush
|
InternalScanner |
RegionCoprocessorHost.preMemStoreCompactionCompact(HStore store,
InternalScanner scanner)
Invoked before compacting memstore.
|
boolean |
RegionCoprocessorHost.preScannerClose(InternalScanner s)
Supports Coprocessor 'bypass'.
|
Boolean |
RegionCoprocessorHost.preScannerNext(InternalScanner s,
List<Result> results,
int limit) |
Modifier and Type | Method and Description |
---|---|
protected InternalScanner |
Compactor.createScanner(HStore store,
ScanInfo scanInfo,
List<StoreFileScanner> scanners,
long smallestReadPoint,
long earliestPutTs,
byte[] dropDeletesFromRow,
byte[] dropDeletesToRow) |
protected InternalScanner |
Compactor.createScanner(HStore store,
ScanInfo scanInfo,
List<StoreFileScanner> scanners,
ScanType scanType,
long smallestReadPoint,
long earliestPutTs) |
InternalScanner |
StripeCompactor.StripeInternalScannerFactory.createScanner(ScanInfo scanInfo,
List<StoreFileScanner> scanners,
ScanType scanType,
Compactor.FileDetails fd,
long smallestReadPoint) |
InternalScanner |
Compactor.InternalScannerFactory.createScanner(ScanInfo scanInfo,
List<StoreFileScanner> scanners,
ScanType scanType,
Compactor.FileDetails fd,
long smallestReadPoint) |
private InternalScanner |
Compactor.postCompactScannerOpen(CompactionRequestImpl request,
ScanType scanType,
InternalScanner scanner,
User user)
Calls coprocessor, if any, to create scanners - after normal scanner creation.
|
Modifier and Type | Method and Description |
---|---|
S |
Compactor.CellSinkFactory.createWriter(InternalScanner scanner,
Compactor.FileDetails fd,
boolean shouldDropBehind,
boolean major,
Consumer<org.apache.hadoop.fs.Path> writerCreationTracker) |
protected void |
AbstractMultiOutputCompactor.initMultiWriter(AbstractMultiFileWriter writer,
InternalScanner scanner,
Compactor.FileDetails fd,
boolean shouldDropBehind,
boolean major,
Consumer<org.apache.hadoop.fs.Path> writerCreationTracker) |
protected boolean |
Compactor.performCompaction(Compactor.FileDetails fd,
InternalScanner scanner,
CellSink writer,
long smallestReadPoint,
boolean cleanSeqId,
ThroughputController throughputController,
CompactionRequestImpl request,
CompactionProgress progress)
Performs the compaction.
|
private InternalScanner |
Compactor.postCompactScannerOpen(CompactionRequestImpl request,
ScanType scanType,
InternalScanner scanner,
User user)
Calls coprocessor, if any, to create scanners - after normal scanner creation.
|
Modifier and Type | Field and Description |
---|---|
private Map<InternalScanner,String> |
AccessController.scannerOwners
Mapping of scanner instances to the user who created them
|
Modifier and Type | Method and Description |
---|---|
InternalScanner |
AccessController.preCompact(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
InternalScanner scanner,
ScanType scanType,
CompactionLifeCycleTracker tracker,
CompactionRequest request) |
Modifier and Type | Method and Description |
---|---|
void |
AccessController.postScannerClose(ObserverContext<RegionCoprocessorEnvironment> c,
InternalScanner s) |
InternalScanner |
AccessController.preCompact(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
InternalScanner scanner,
ScanType scanType,
CompactionLifeCycleTracker tracker,
CompactionRequest request) |
void |
AccessController.preScannerClose(ObserverContext<RegionCoprocessorEnvironment> c,
InternalScanner s) |
boolean |
AccessController.preScannerNext(ObserverContext<RegionCoprocessorEnvironment> c,
InternalScanner s,
List<Result> result,
int limit,
boolean hasNext) |
private void |
AccessController.requireScannerOwner(InternalScanner s)
Verify, when servicing an RPC, that the caller is the scanner owner.
|
Modifier and Type | Field and Description |
---|---|
private Map<InternalScanner,String> |
VisibilityController.scannerOwners
Mapping of scanner instances to the user who created them
|
Modifier and Type | Method and Description |
---|---|
void |
VisibilityController.postScannerClose(ObserverContext<RegionCoprocessorEnvironment> c,
InternalScanner s) |
void |
VisibilityController.preScannerClose(ObserverContext<RegionCoprocessorEnvironment> c,
InternalScanner s) |
boolean |
VisibilityController.preScannerNext(ObserverContext<RegionCoprocessorEnvironment> c,
InternalScanner s,
List<Result> result,
int limit,
boolean hasNext) |
private void |
VisibilityController.requireScannerOwner(InternalScanner s)
Verify, when servicing an RPC, that the caller is the scanner owner.
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.