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.compactions | |
org.apache.hadoop.hbase.security.access |
Modifier and Type | Method and Description |
---|---|
protected ScanInfo |
ZooKeeperScanPolicyObserver.getScanInfo(Store store,
RegionCoprocessorEnvironment e) |
InternalScanner |
ZooKeeperScanPolicyObserver.preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
List<? extends KeyValueScanner> scanners,
ScanType scanType,
long earliestPutTs,
InternalScanner s) |
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 | Class and Description |
---|---|
class |
HStore
A Store holds a column family in a Region.
|
Modifier and Type | Field and Description |
---|---|
protected Store |
StoreScanner.store |
protected Store |
StoreFlusher.store |
private Store |
CompactSplitThread.CompactionRunner.store |
Modifier and Type | Field and Description |
---|---|
private ConcurrentMap<Store,Long> |
HRegion.lastStoreFlushTimeMap |
protected Map<byte[],Store> |
HRegion.stores |
Modifier and Type | Method and Description |
---|---|
Store |
Region.getStore(byte[] family)
Return the Store for the given family
|
Store |
HRegion.getStore(byte[] column) |
private Store |
HRegion.getStore(Cell cell)
Return HStore instance.
|
Modifier and Type | Method and Description |
---|---|
List<Store> |
Region.getStores()
Return the list of Stores managed by this region
|
List<Store> |
HRegion.getStores() |
abstract Collection<Store> |
FlushPolicy.selectStoresToFlush() |
Collection<Store> |
FlushLargeStoresPolicy.selectStoresToFlush() |
Collection<Store> |
FlushAllStoresPolicy.selectStoresToFlush() |
Modifier and Type | Method and Description |
---|---|
boolean |
HRegion.compact(CompactionContext compaction,
Store store,
CompactionThroughputController throughputController) |
boolean |
HRegion.compact(CompactionContext compaction,
Store store,
CompactionThroughputController throughputController,
User user) |
static StoreEngine<?,?,?,?> |
StoreEngine.create(Store store,
org.apache.hadoop.conf.Configuration conf,
KeyValue.KVComparator kvComparator)
Create the StoreEngine configured for the given Store.
|
protected void |
StripeStoreEngine.createComponents(org.apache.hadoop.conf.Configuration conf,
Store store,
KeyValue.KVComparator comparator) |
protected abstract void |
StoreEngine.createComponents(org.apache.hadoop.conf.Configuration conf,
Store store,
KeyValue.KVComparator kvComparator)
Create the StoreEngine's components.
|
protected void |
DefaultStoreEngine.createComponents(org.apache.hadoop.conf.Configuration conf,
Store store,
KeyValue.KVComparator kvComparator) |
private void |
StoreEngine.createComponentsOnce(org.apache.hadoop.conf.Configuration conf,
Store store,
KeyValue.KVComparator kvComparator) |
private long |
HRegion.doDropStoreMemstoreContentsForSeqId(Store s,
long currentSeqId) |
private List<Cell> |
HRegion.doGet(Store store,
byte[] row,
Map.Entry<byte[],List<Cell>> family,
TimeRange tr)
Run a Get against passed in
store on passed row , etc. |
private long |
HRegion.dropMemstoreContentsForSeqId(long seqId,
Store store)
Drops the memstore contents after replaying a flush descriptor or region open event replay
if the memstore edits have seqNums smaller than the given seq id
|
void |
RegionCoprocessorHost.postCompact(Store store,
StoreFile resultFile,
CompactionRequest request)
Called after the store compaction has completed.
|
void |
RegionCoprocessorHost.postCompactSelection(Store store,
com.google.common.collect.ImmutableList<StoreFile> selected,
CompactionRequest request)
Called after the
StoreFile s to be compacted have been selected from the available
candidates. |
void |
RegionCoprocessorHost.postFlush(Store store,
StoreFile storeFile)
Invoked after a memstore flush
|
InternalScanner |
RegionCoprocessorHost.preCompact(Store store,
InternalScanner scanner,
ScanType scanType,
CompactionRequest request)
Called prior to rewriting the store files selected for compaction
|
InternalScanner |
RegionCoprocessorHost.preCompactScannerOpen(Store store,
List<StoreFileScanner> scanners,
ScanType scanType,
long earliestPutTs,
CompactionRequest request)
|
boolean |
RegionCoprocessorHost.preCompactSelection(Store store,
List<StoreFile> candidates,
CompactionRequest request)
Called prior to selecting the
StoreFile s for compaction from the list of currently
available candidates. |
InternalScanner |
RegionCoprocessorHost.preFlush(Store store,
InternalScanner scanner)
Invoked before a memstore flush
|
InternalScanner |
RegionCoprocessorHost.preFlushScannerOpen(Store store,
KeyValueScanner memstoreScanner)
|
KeyValueScanner |
RegionCoprocessorHost.preStoreScannerOpen(Store store,
Scan scan,
NavigableSet<byte[]> targetCols)
|
CompactionRequest |
CompactSplitThread.requestCompaction(Region r,
Store s,
String why,
CompactionRequest request) |
CompactionRequest |
CompactionRequestor.requestCompaction(Region r,
Store s,
String why,
CompactionRequest request) |
CompactionRequest |
CompactSplitThread.requestCompaction(Region r,
Store s,
String why,
int priority,
CompactionRequest request,
User user) |
CompactionRequest |
CompactionRequestor.requestCompaction(Region r,
Store s,
String why,
int pri,
CompactionRequest request,
User user) |
private CompactionRequest |
CompactSplitThread.requestCompactionInternal(Region r,
Store s,
String why,
int priority,
CompactionRequest request,
boolean selectNow,
User user) |
void |
CompactSplitThread.requestSystemCompaction(Region r,
Store s,
String why) |
protected boolean |
HRegion.restoreEdit(Store s,
Cell cell)
Used by tests
|
private CompactionContext |
CompactSplitThread.selectCompaction(Region r,
Store s,
int priority,
CompactionRequest request,
User user) |
private boolean |
FlushLargeStoresPolicy.shouldFlush(Store store) |
(package private) boolean |
HRegion.shouldFlushStore(Store store)
Should the store be flushed because it is old enough.
|
boolean |
DefaultMemStore.shouldSeek(Scan scan,
Store store,
long oldestUnexpiredTS)
Check if this memstore may contain the required keys
|
boolean |
DefaultMemStore.MemStoreScanner.shouldUseScanner(Scan scan,
Store store,
long oldestUnexpiredTS) |
boolean |
KeyValueScanner.shouldUseScanner(Scan scan,
Store store,
long oldestUnexpiredTS)
Allows to filter out scanners (both StoreFile and memstore) that we don't
want to use based on criteria such as Bloom filters and timestamp ranges.
|
boolean |
NonLazyKeyValueScanner.shouldUseScanner(Scan scan,
Store store,
long oldestUnexpiredTS) |
boolean |
StoreFileScanner.shouldUseScanner(Scan scan,
Store store,
long oldestUnexpiredTS) |
Modifier and Type | Method and Description |
---|---|
private Region.FlushResult |
HRegion.internalFlushcache(Collection<Store> storesToFlush,
MonitoredTask status,
boolean writeFlushWalMarker)
Flushing given stores.
|
protected Region.FlushResult |
HRegion.internalFlushcache(WAL wal,
long myseqid,
Collection<Store> storesToFlush,
MonitoredTask status,
boolean writeFlushWalMarker)
Flush the memstore.
|
protected Region.FlushResult |
HRegion.internalFlushCacheAndCommit(WAL wal,
MonitoredTask status,
HRegion.PrepareFlushResult prepareResult,
Collection<Store> storesToFlush) |
protected HRegion.PrepareFlushResult |
HRegion.internalPrepareFlushCache(WAL wal,
long myseqid,
Collection<Store> storesToFlush,
MonitoredTask status,
boolean writeFlushWalMarker) |
private boolean |
HRegion.isAllFamilies(Collection<Store> families) |
List<CompactionRequest> |
CompactSplitThread.requestCompaction(Region r,
String why,
int p,
List<Pair<CompactionRequest,Store>> requests,
User user) |
List<CompactionRequest> |
CompactionRequestor.requestCompaction(Region r,
String why,
int pri,
List<Pair<CompactionRequest,Store>> requests,
User user) |
List<CompactionRequest> |
CompactSplitThread.requestCompaction(Region r,
String why,
List<Pair<CompactionRequest,Store>> requests) |
List<CompactionRequest> |
CompactionRequestor.requestCompaction(Region r,
String why,
List<Pair<CompactionRequest,Store>> requests) |
private List<CompactionRequest> |
CompactSplitThread.requestCompactionInternal(Region r,
String why,
int p,
List<Pair<CompactionRequest,Store>> requests,
boolean selectNow,
User user) |
Constructor and Description |
---|
CompactSplitThread.CompactionRunner(Store store,
Region region,
CompactionContext compaction,
ThreadPoolExecutor parent,
User user) |
DefaultStoreFlusher(org.apache.hadoop.conf.Configuration conf,
Store store) |
ReversedStoreScanner(Store store,
ScanInfo scanInfo,
Scan scan,
NavigableSet<byte[]> columns,
long readPt)
Opens a scanner across memstore, snapshot, and all StoreFiles.
|
StoreFlusher(org.apache.hadoop.conf.Configuration conf,
Store store) |
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) |
StoreScanner(Store store,
ScanInfo scanInfo,
Scan scan,
NavigableSet<byte[]> columns,
long readPt)
Opens a scanner across memstore, snapshot, and all StoreFiles.
|
StoreScanner(Store store,
Scan scan,
ScanInfo scanInfo,
NavigableSet<byte[]> columns,
long readPt,
boolean cacheBlocks)
An internal constructor.
|
StripeStoreFlusher(org.apache.hadoop.conf.Configuration conf,
Store store,
StripeCompactionPolicy policy,
StripeStoreFileManager stripes) |
Modifier and Type | Field and Description |
---|---|
protected Store |
Compactor.store |
Modifier and Type | Method and Description |
---|---|
protected InternalScanner |
Compactor.createScanner(Store store,
List<StoreFileScanner> scanners,
long smallestReadPoint,
long earliestPutTs,
byte[] dropDeletesFromRow,
byte[] dropDeletesToRow) |
protected InternalScanner |
Compactor.createScanner(Store store,
List<StoreFileScanner> scanners,
ScanType scanType,
long smallestReadPoint,
long earliestPutTs) |
Constructor and Description |
---|
Compactor(org.apache.hadoop.conf.Configuration conf,
Store store) |
DefaultCompactor(org.apache.hadoop.conf.Configuration conf,
Store store) |
StripeCompactor(org.apache.hadoop.conf.Configuration conf,
Store store) |
Modifier and Type | Method and Description |
---|---|
InternalScanner |
AccessController.preCompact(ObserverContext<RegionCoprocessorEnvironment> e,
Store store,
InternalScanner scanner,
ScanType scanType) |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.