Package | Description |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.coprocessor |
Table of Contents
|
org.apache.hadoop.hbase.coprocessor.example | |
org.apache.hadoop.hbase.mob | |
org.apache.hadoop.hbase.mob.compactions | |
org.apache.hadoop.hbase.namespace | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.regionserver.compactions | |
org.apache.hadoop.hbase.security.access |
Modifier and Type | Method and Description |
---|---|
KeyValueScanner |
TestFromClientSide.ExceptionInReseekRegionObserver.preStoreScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
Scan scan,
NavigableSet<byte[]> targetCols,
KeyValueScanner s) |
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 | Method and Description |
---|---|
protected void |
MobStoreEngine.createCompactor(Configuration conf,
Store store)
Creates the DefaultMobCompactor.
|
protected void |
MobStoreEngine.createStoreFlusher(Configuration conf,
Store store) |
Constructor and Description |
---|
DefaultMobStoreCompactor(Configuration conf,
Store store) |
DefaultMobStoreFlusher(Configuration conf,
Store store) |
Modifier and Type | Method and Description |
---|---|
void |
TestMobCompactor.CompactTwoLatestHfilesCopro.preCompactSelection(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
List<StoreFile> candidates,
CompactionRequest request) |
Modifier and Type | Method and Description |
---|---|
void |
TestNamespaceAuditor.CustomObserver.postCompact(ObserverContext<RegionCoprocessorEnvironment> e,
Store store,
StoreFile resultFile) |
Modifier and Type | Class and Description |
---|---|
class |
HMobStore
The store implementation to save MOBs (medium objects), it extends the HStore.
|
class |
HStore
A Store holds a column family in a Region.
|
Modifier and Type | Field and Description |
---|---|
protected Store |
StoreScanner.store |
Modifier and Type | Field and Description |
---|---|
protected Map<byte[],Store> |
HRegion.stores |
Modifier and Type | Method and Description |
---|---|
Store |
TestCompaction.BlockingStoreMockMaker.createStoreMock(int priority,
String name) |
Store |
StatefulStoreMockMaker.createStoreMock(String name) |
Store |
TestCompaction.BlockingStoreMockMaker.createStoreMock(String name) |
Store |
HRegion.getStore(byte[] column) |
Store |
Region.getStore(byte[] family)
Return the Store for the given family
|
Modifier and Type | Method and Description |
---|---|
List<Store> |
HRegion.getStores() |
List<Store> |
Region.getStores()
Return the list of Stores managed by this region
|
Collection<Store> |
FlushAllStoresPolicy.selectStoresToFlush() |
Collection<Store> |
FlushLargeStoresPolicy.selectStoresToFlush() |
abstract Collection<Store> |
FlushPolicy.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,
Configuration conf,
KeyValue.KVComparator kvComparator)
Create the StoreEngine configured for the given Store.
|
protected void |
DefaultStoreEngine.createCompactionPolicy(Configuration conf,
Store store) |
protected void |
DefaultStoreEngine.createCompactor(Configuration conf,
Store store) |
protected void |
DateTieredStoreEngine.createComponents(Configuration conf,
Store store,
KeyValue.KVComparator kvComparator) |
protected void |
DefaultStoreEngine.createComponents(Configuration conf,
Store store,
KeyValue.KVComparator kvComparator) |
protected abstract void |
StoreEngine.createComponents(Configuration conf,
Store store,
KeyValue.KVComparator kvComparator)
Create the StoreEngine's components.
|
protected void |
StripeStoreEngine.createComponents(Configuration conf,
Store store,
KeyValue.KVComparator comparator) |
protected void |
TestStore.DummyStoreEngine.createComponents(Configuration conf,
Store store,
KeyValue.KVComparator comparator) |
protected StoreEngine<?,?,?,?> |
HMobStore.createStoreEngine(Store store,
Configuration conf,
KeyValue.KVComparator cellComparator)
Creates the mob store engine.
|
protected StoreEngine<?,?,?,?> |
HStore.createStoreEngine(Store store,
Configuration conf,
KeyValue.KVComparator kvComparator)
Creates the store engine configured for the given Store.
|
protected void |
DefaultStoreEngine.createStoreFlusher(Configuration conf,
Store store) |
void |
RegionCoprocessorHost.postCompact(Store store,
StoreFile resultFile,
CompactionRequest request)
Called after the store compaction has completed.
|
void |
RegionCoprocessorHost.postCompactSelection(Store store,
<any> 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 |
TestHRegionServerBulkLoad.MyObserver.preCompact(ObserverContext<RegionCoprocessorEnvironment> e,
Store store,
InternalScanner scanner,
ScanType scanType) |
InternalScanner |
RegionCoprocessorHost.preCompact(Store store,
InternalScanner scanner,
ScanType scanType,
CompactionRequest request)
Called prior to rewriting the store files selected for compaction
|
InternalScanner |
NoOpScanPolicyObserver.preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
List<? extends KeyValueScanner> scanners,
ScanType scanType,
long earliestPutTs,
InternalScanner s)
Reimplement the default behavior
|
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 |
NoOpScanPolicyObserver.preFlushScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
KeyValueScanner memstoreScanner,
InternalScanner s)
Reimplement the default behavior
|
InternalScanner |
RegionCoprocessorHost.preFlushScannerOpen(Store store,
KeyValueScanner memstoreScanner)
|
KeyValueScanner |
NoOpScanPolicyObserver.preStoreScannerOpen(ObserverContext<RegionCoprocessorEnvironment> c,
Store store,
Scan scan,
NavigableSet<byte[]> targetCols,
KeyValueScanner s) |
KeyValueScanner |
RegionCoprocessorHost.preStoreScannerOpen(Store store,
Scan scan,
NavigableSet<byte[]> targetCols)
|
CompactionRequest |
CompactionRequestor.requestCompaction(Region r,
Store s,
String why,
CompactionRequest request) |
CompactionRequest |
CompactSplitThread.requestCompaction(Region r,
Store s,
String why,
CompactionRequest request) |
CompactionRequest |
CompactionRequestor.requestCompaction(Region r,
Store s,
String why,
int pri,
CompactionRequest request,
User user) |
CompactionRequest |
CompactSplitThread.requestCompaction(Region r,
Store s,
String why,
int priority,
CompactionRequest request,
User user) |
void |
CompactSplitThread.requestSystemCompaction(Region r,
Store s,
String why) |
protected boolean |
HRegion.restoreEdit(Store s,
Cell cell)
Used by tests
|
Modifier and Type | Method and Description |
---|---|
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,
org.apache.hadoop.hbase.regionserver.HRegion.PrepareFlushResult prepareResult,
Collection<Store> storesToFlush) |
protected org.apache.hadoop.hbase.regionserver.HRegion.PrepareFlushResult |
HRegion.internalPrepareFlushCache(WAL wal,
long myseqid,
Collection<Store> storesToFlush,
MonitoredTask status,
boolean writeFlushWalMarker) |
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,
int p,
List<Pair<CompactionRequest,Store>> requests,
User user) |
List<CompactionRequest> |
CompactionRequestor.requestCompaction(Region r,
String why,
List<Pair<CompactionRequest,Store>> requests) |
List<CompactionRequest> |
CompactSplitThread.requestCompaction(Region r,
String why,
List<Pair<CompactionRequest,Store>> requests) |
Constructor and Description |
---|
DefaultStoreFlusher(Configuration conf,
Store store) |
DummyCompactor(Configuration conf,
Store store) |
DummyCompactor(Configuration conf,
Store store) |
DummyStoreFlusher(Configuration conf,
Store store) |
MobStoreScanner(Store store,
ScanInfo scanInfo,
Scan scan,
NavigableSet<byte[]> columns,
long readPt) |
StoreScanner(Store store,
boolean cacheBlocks,
Scan scan,
NavigableSet<byte[]> columns,
long ttl,
int minVersions,
long readPt)
An internal constructor.
|
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,
NavigableSet<byte[]> columns,
long readPt)
Opens a scanner across memstore, snapshot, and all StoreFiles.
|
StripeStoreFlusher(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 |
---|
AbstractMultiOutputCompactor(Configuration conf,
Store store) |
DateTieredCompactor(Configuration conf,
Store store) |
DefaultCompactor(Configuration conf,
Store store) |
StripeCompactor(Configuration conf,
Store store) |
Modifier and Type | Method and Description |
---|---|
InternalScanner |
AccessController.preCompact(ObserverContext<RegionCoprocessorEnvironment> e,
Store store,
InternalScanner scanner,
ScanType scanType) |