Uses of Interface
org.apache.hadoop.hbase.regionserver.InternalScanner
Packages that use InternalScanner
Package
Description
Table of Contents
-
Uses of InternalScanner in org.apache.hadoop.hbase
Methods in org.apache.hadoop.hbase with parameters of type InternalScannerModifier and TypeMethodDescriptionint
HBaseTestingUtility.countRows
(InternalScanner scanner) Deprecated. -
Uses of InternalScanner in org.apache.hadoop.hbase.coprocessor
Methods in org.apache.hadoop.hbase.coprocessor that return InternalScannerModifier and TypeMethodDescriptiondefault InternalScanner
RegionObserver.preCompact
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Store store, InternalScanner scanner, ScanType scanType, CompactionLifeCycleTracker tracker, CompactionRequest request) Called prior to writing theStoreFile
s selected for compaction into a newStoreFile
.default InternalScanner
RegionObserver.preFlush
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Store store, InternalScanner scanner, FlushLifeCycleTracker tracker) Called before a Store's memstore is flushed to disk.default InternalScanner
RegionObserver.preMemStoreCompactionCompact
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Store store, InternalScanner scanner) Called before we do in memory compaction.Methods in org.apache.hadoop.hbase.coprocessor with parameters of type InternalScannerModifier and TypeMethodDescriptiondefault void
RegionObserver.postScannerClose
(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, InternalScanner s) Called after the client closes a scanner.default boolean
RegionObserver.postScannerFilterRow
(ObserverContext<? extends 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<? extends 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<? extends RegionCoprocessorEnvironment> c, Store store, InternalScanner scanner, ScanType scanType, CompactionLifeCycleTracker tracker, CompactionRequest request) Called prior to writing theStoreFile
s selected for compaction into a newStoreFile
.default InternalScanner
RegionObserver.preFlush
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Store store, InternalScanner scanner, FlushLifeCycleTracker tracker) Called before a Store's memstore is flushed to disk.default InternalScanner
RegionObserver.preMemStoreCompactionCompact
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Store store, InternalScanner scanner) Called before we do in memory compaction.default void
RegionObserver.preScannerClose
(ObserverContext<? extends RegionCoprocessorEnvironment> c, InternalScanner s) Called before the client closes a scanner.default boolean
RegionObserver.preScannerNext
(ObserverContext<? extends RegionCoprocessorEnvironment> c, InternalScanner s, List<Result> result, int limit, boolean hasNext) Called before the client asks for the next row on a scanner. -
Uses of InternalScanner in org.apache.hadoop.hbase.coprocessor.example
Classes in org.apache.hadoop.hbase.coprocessor.example that implement InternalScannerModifier and TypeClassDescriptionclass
A simple delegation for doing filtering onInternalScanner
.Fields in org.apache.hadoop.hbase.coprocessor.example declared as InternalScannerModifier and TypeFieldDescriptionprotected final InternalScanner
DelegatingInternalScanner.scanner
Methods in org.apache.hadoop.hbase.coprocessor.example that return InternalScannerModifier and TypeMethodDescriptionValueRewritingObserver.preCompact
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Store store, InternalScanner scanner, ScanType scanType, CompactionLifeCycleTracker tracker, CompactionRequest request) WriteHeavyIncrementObserver.preCompact
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Store store, InternalScanner scanner, ScanType scanType, CompactionLifeCycleTracker tracker, CompactionRequest request) WriteHeavyIncrementObserver.preFlush
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Store store, InternalScanner scanner, FlushLifeCycleTracker tracker) WriteHeavyIncrementObserver.preMemStoreCompactionCompact
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Store store, InternalScanner scanner) private InternalScanner
WriteHeavyIncrementObserver.wrap
(byte[] family, InternalScanner scanner) Methods in org.apache.hadoop.hbase.coprocessor.example with parameters of type InternalScannerModifier and TypeMethodDescriptionValueRewritingObserver.preCompact
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Store store, InternalScanner scanner, ScanType scanType, CompactionLifeCycleTracker tracker, CompactionRequest request) WriteHeavyIncrementObserver.preCompact
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Store store, InternalScanner scanner, ScanType scanType, CompactionLifeCycleTracker tracker, CompactionRequest request) WriteHeavyIncrementObserver.preFlush
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Store store, InternalScanner scanner, FlushLifeCycleTracker tracker) WriteHeavyIncrementObserver.preMemStoreCompactionCompact
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Store store, InternalScanner scanner) private InternalScanner
WriteHeavyIncrementObserver.wrap
(byte[] family, InternalScanner scanner) Constructors in org.apache.hadoop.hbase.coprocessor.example with parameters of type InternalScanner -
Uses of InternalScanner in org.apache.hadoop.hbase.coprocessor.example.row.stats
Classes in org.apache.hadoop.hbase.coprocessor.example.row.stats that implement InternalScannerModifier and TypeClassDescriptionprivate static class
Fields in org.apache.hadoop.hbase.coprocessor.example.row.stats declared as InternalScannerModifier and TypeFieldDescriptionprivate final InternalScanner
RowStatisticsCompactionObserver.RowStatisticsScanner.scanner
Methods in org.apache.hadoop.hbase.coprocessor.example.row.stats that return InternalScannerModifier and TypeMethodDescriptionRowStatisticsCompactionObserver.preCompact
(ObserverContext<? extends RegionCoprocessorEnvironment> context, Store store, InternalScanner scanner, ScanType scanType, CompactionLifeCycleTracker tracker, CompactionRequest request) Methods in org.apache.hadoop.hbase.coprocessor.example.row.stats with parameters of type InternalScannerModifier and TypeMethodDescriptionRowStatisticsCompactionObserver.preCompact
(ObserverContext<? extends RegionCoprocessorEnvironment> context, Store store, InternalScanner scanner, ScanType scanType, CompactionLifeCycleTracker tracker, CompactionRequest request) Constructors in org.apache.hadoop.hbase.coprocessor.example.row.stats with parameters of type InternalScannerModifierConstructorDescriptionRowStatisticsScanner
(InternalScanner scanner, RowStatisticsImpl rowStatistics, RegionCoprocessorEnvironment regionEnv, RowStatisticsRecorder customRecorder) -
Uses of InternalScanner in org.apache.hadoop.hbase.mob
Methods in org.apache.hadoop.hbase.mob with parameters of type InternalScannerModifier and TypeMethodDescriptionprotected 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. -
Uses of InternalScanner in org.apache.hadoop.hbase.regionserver
Subinterfaces of InternalScanner in org.apache.hadoop.hbase.regionserverModifier and TypeInterfaceDescriptioninterface
RegionScanner describes iterators over rows in an HRegion.Classes in org.apache.hadoop.hbase.regionserver that implement InternalScannerModifier and TypeClassDescriptionclass
Implements a heap merge across any number of KeyValueScanners.class
Scanner scans both the memstore and the MOB Store.(package private) class
RegionScannerImpl is used to combine scanners from multiple Stores (aka column families).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.(package private) class
ReversibleRegionScannerImpl extends from RegionScannerImpl, and is used to support reversed scanning.class
ReversedStoreScanner extends from StoreScanner, and is used to support reversed scanning.class
Scanner scans both the memstore and the Store.Fields in org.apache.hadoop.hbase.regionserver declared as InternalScannerModifier and TypeFieldDescriptionprivate InternalScanner
MemStoreCompactorSegmentsIterator.compactingScanner
Methods in org.apache.hadoop.hbase.regionserver that return InternalScannerModifier and TypeMethodDescriptionprivate 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.RegionCoprocessorHost.preCompact
(HStore store, InternalScanner scanner, ScanType scanType, CompactionLifeCycleTracker tracker, CompactionRequest request, User user) Called prior to rewriting the store files selected for compactionRegionCoprocessorHost.preFlush
(HStore store, InternalScanner scanner, FlushLifeCycleTracker tracker) Invoked before a memstore flushRegionCoprocessorHost.preMemStoreCompactionCompact
(HStore store, InternalScanner scanner) Invoked before compacting memstore.Methods in org.apache.hadoop.hbase.regionserver with parameters of type InternalScannerModifier and TypeMethodDescriptionprotected 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) RegionCoprocessorHost.preCompact
(HStore store, InternalScanner scanner, ScanType scanType, CompactionLifeCycleTracker tracker, CompactionRequest request, User user) Called prior to rewriting the store files selected for compactionRegionCoprocessorHost.preFlush
(HStore store, InternalScanner scanner, FlushLifeCycleTracker tracker) Invoked before a memstore flushRegionCoprocessorHost.preMemStoreCompactionCompact
(HStore store, InternalScanner scanner) Invoked before compacting memstore.boolean
RegionCoprocessorHost.preScannerClose
(InternalScanner s) Supports Coprocessor 'bypass'.RegionCoprocessorHost.preScannerNext
(InternalScanner s, List<Result> results, int limit) -
Uses of InternalScanner in org.apache.hadoop.hbase.regionserver.compactions
Methods in org.apache.hadoop.hbase.regionserver.compactions that return InternalScannerModifier and TypeMethodDescriptionprotected 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) Compactor.InternalScannerFactory.createScanner
(ScanInfo scanInfo, List<StoreFileScanner> scanners, ScanType scanType, Compactor.FileDetails fd, long smallestReadPoint) StripeCompactor.StripeInternalScannerFactory.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.Methods in org.apache.hadoop.hbase.regionserver.compactions with parameters of type InternalScannerModifier and TypeMethodDescriptionCompactor.CellSinkFactory.createWriter
(InternalScanner scanner, Compactor.FileDetails fd, boolean shouldDropBehind, boolean major, Consumer<org.apache.hadoop.fs.Path> writerCreationTracker) protected final 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. -
Uses of InternalScanner in org.apache.hadoop.hbase.security.access
Fields in org.apache.hadoop.hbase.security.access with type parameters of type InternalScannerModifier and TypeFieldDescriptionprivate Map<InternalScanner,
String> AccessController.scannerOwners
Mapping of scanner instances to the user who created themMethods in org.apache.hadoop.hbase.security.access that return InternalScannerModifier and TypeMethodDescriptionAccessController.preCompact
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Store store, InternalScanner scanner, ScanType scanType, CompactionLifeCycleTracker tracker, CompactionRequest request) Methods in org.apache.hadoop.hbase.security.access with parameters of type InternalScannerModifier and TypeMethodDescriptionvoid
AccessController.postScannerClose
(ObserverContext<? extends RegionCoprocessorEnvironment> c, InternalScanner s) AccessController.preCompact
(ObserverContext<? extends RegionCoprocessorEnvironment> c, Store store, InternalScanner scanner, ScanType scanType, CompactionLifeCycleTracker tracker, CompactionRequest request) void
AccessController.preScannerClose
(ObserverContext<? extends RegionCoprocessorEnvironment> c, InternalScanner s) boolean
AccessController.preScannerNext
(ObserverContext<? extends 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. -
Uses of InternalScanner in org.apache.hadoop.hbase.security.visibility
Fields in org.apache.hadoop.hbase.security.visibility with type parameters of type InternalScannerModifier and TypeFieldDescriptionprivate Map<InternalScanner,
String> VisibilityController.scannerOwners
Mapping of scanner instances to the user who created themMethods in org.apache.hadoop.hbase.security.visibility with parameters of type InternalScannerModifier and TypeMethodDescriptionvoid
VisibilityController.postScannerClose
(ObserverContext<? extends RegionCoprocessorEnvironment> c, InternalScanner s) void
VisibilityController.preScannerClose
(ObserverContext<? extends RegionCoprocessorEnvironment> c, InternalScanner s) boolean
VisibilityController.preScannerNext
(ObserverContext<? extends 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.