Package | Description |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.coordination | |
org.apache.hadoop.hbase.migration | |
org.apache.hadoop.hbase.regionserver | |
org.apache.hadoop.hbase.regionserver.handler | |
org.apache.hadoop.hbase.snapshot | |
org.apache.hadoop.hbase.util |
Modifier and Type | Field and Description |
---|---|
private HRegion |
ClientSideRegionScanner.region |
Modifier and Type | Method and Description |
---|---|
void |
ZkRegionMergeCoordination.completeRegionMergeTransaction(RegionServerServices services,
HRegionInfo mergedRegionInfo,
HRegion region_a,
HRegion region_b,
RegionMergeCoordination.RegionMergeDetails rmd,
HRegion mergedRegion) |
void |
RegionMergeCoordination.completeRegionMergeTransaction(RegionServerServices services,
HRegionInfo merged,
HRegion region_a,
HRegion region_b,
RegionMergeCoordination.RegionMergeDetails rmd,
HRegion mergedRegion)
Finish off merge transaction
|
void |
ZkCloseRegionCoordination.setClosedState(HRegion region,
ServerName sn,
CloseRegionCoordination.CloseRegionDetails crd)
In ZK-based version we do some znodes transitioning.
|
void |
CloseRegionCoordination.setClosedState(HRegion region,
ServerName sn,
CloseRegionCoordination.CloseRegionDetails crd)
Called after region is closed to notify all interesting parties / "register"
region as finally closed.
|
private boolean |
ZkCloseRegionCoordination.setClosedState(HRegion region,
ServerName sn,
ZkCloseRegionCoordination.ZkCloseRegionDetails zkCrd)
Transition ZK node to CLOSED
|
void |
ZKSplitTransactionCoordination.startSplitTransaction(HRegion parent,
ServerName serverName,
HRegionInfo hri_a,
HRegionInfo hri_b)
Creates a new ephemeral node in the PENDING_SPLIT state for the specified region.
|
void |
SplitTransactionCoordination.startSplitTransaction(HRegion parent,
ServerName serverName,
HRegionInfo hri_a,
HRegionInfo hri_b)
init coordination for split transaction
|
boolean |
OpenRegionCoordination.transitionToOpened(HRegion r,
OpenRegionCoordination.OpenRegionDetails ord)
Tries to move regions to OPENED state.
|
boolean |
ZkOpenRegionCoordination.transitionToOpened(HRegion r,
OpenRegionCoordination.OpenRegionDetails ord) |
void |
ZkRegionMergeCoordination.waitForRegionMergeTransaction(RegionServerServices services,
HRegionInfo mergedRegionInfo,
HRegion region_a,
HRegion region_b,
RegionMergeCoordination.RegionMergeDetails details)
Wait for the merging node to be transitioned from pending_merge
to merging by master.
|
void |
RegionMergeCoordination.waitForRegionMergeTransaction(RegionServerServices services,
HRegionInfo mergedRegionInfo,
HRegion region_a,
HRegion region_b,
RegionMergeCoordination.RegionMergeDetails details)
Get everything ready for region merge
|
Modifier and Type | Method and Description |
---|---|
(package private) void |
NamespaceUpgrade.updateAcls(HRegion region)
Deletes the old _acl_ entry, and inserts a new one using namespace.
|
Modifier and Type | Field and Description |
---|---|
private HRegion |
SplitRequest.parent |
private HRegion |
SplitTransactionImpl.parent |
private HRegion |
SplitTransactionImpl.DaughterOpener.r |
protected HRegion |
RegionSplitPolicy.region
The region configured for this split policy.
|
private HRegion |
MetricsRegionWrapperImpl.region |
protected HRegion |
FlushPolicy.region
The region configured for this flush policy.
|
private HRegion |
HStore.region |
private HRegion |
CompactSplitThread.CompactionRunner.region |
protected HRegion |
HRegion.RegionScannerImpl.region |
private HRegion |
RegionMergeRequest.region_a |
private HRegion |
RegionMergeTransactionImpl.region_a |
private HRegion |
RegionMergeRequest.region_b |
private HRegion |
RegionMergeTransactionImpl.region_b |
Modifier and Type | Method and Description |
---|---|
(package private) HRegion |
HRegion.createDaughterRegionFromSplits(HRegionInfo hri)
Create a daughter region from given a temp directory with the region data.
|
static HRegion |
HRegion.createHRegion(HRegionInfo info,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.conf.Configuration conf,
HTableDescriptor hTableDescriptor)
Convenience method creating new HRegions.
|
static HRegion |
HRegion.createHRegion(HRegionInfo info,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.conf.Configuration conf,
HTableDescriptor hTableDescriptor,
WAL wal) |
static HRegion |
HRegion.createHRegion(HRegionInfo info,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.conf.Configuration conf,
HTableDescriptor hTableDescriptor,
WAL wal,
boolean initialize)
Convenience method creating new HRegions.
|
static HRegion |
HRegion.createHRegion(HRegionInfo info,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.conf.Configuration conf,
HTableDescriptor hTableDescriptor,
WAL wal,
boolean initialize,
boolean ignoreWAL)
Convenience method creating new HRegions.
|
static HRegion |
HRegion.createHRegion(HRegionInfo info,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.fs.Path tableDir,
org.apache.hadoop.conf.Configuration conf,
HTableDescriptor hTableDescriptor,
WAL wal,
boolean initialize,
boolean ignoreWAL)
Convenience method creating new HRegions.
|
(package private) HRegion |
RegionMergeTransactionImpl.createMergedRegion(Server server,
RegionServerServices services,
User user)
Prepare the merged region and region files.
|
(package private) HRegion |
RegionMergeTransactionImpl.createMergedRegionFromMerges(HRegion a,
HRegion b,
HRegionInfo mergedRegion)
Create a merged region from the merges directory under region a.
|
(package private) HRegion |
HRegion.createMergedRegionFromMerges(HRegionInfo mergedRegionInfo,
HRegion region_b)
Create a merged region given a temp directory with the region data.
|
HRegion |
RegionMergeTransactionImpl.execute(Server server,
RegionServerServices services)
Run the transaction.
|
HRegion |
RegionMergeTransactionImpl.execute(Server server,
RegionServerServices services,
User user) |
HRegion |
HStore.getHRegion() |
static HRegion |
HRegion.merge(HRegion a,
HRegion b)
Merge two regions whether they are adjacent or not.
|
static HRegion |
HRegion.mergeAdjacent(HRegion srcA,
HRegion srcB)
Merge two HRegions.
|
(package private) static HRegion |
HRegion.newHRegion(org.apache.hadoop.fs.Path tableDir,
WAL wal,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.conf.Configuration conf,
HRegionInfo regionInfo,
HTableDescriptor htd,
RegionServerServices rsServices)
A utility method to create new instances of HRegion based on the
HConstants.REGION_IMPL configuration property. |
protected HRegion |
HRegion.openHRegion(CancelableProgressable reporter)
Open HRegion.
|
static HRegion |
HRegion.openHRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootDir,
HRegionInfo info,
HTableDescriptor htd,
WAL wal)
Open a Region.
|
static HRegion |
HRegion.openHRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootDir,
HRegionInfo info,
HTableDescriptor htd,
WAL wal,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region.
|
static HRegion |
HRegion.openHRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.fs.Path tableDir,
HRegionInfo info,
HTableDescriptor htd,
WAL wal,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region.
|
static HRegion |
HRegion.openHRegion(HRegion other,
CancelableProgressable reporter)
Useful when reopening a closed region (normally for unit tests)
|
static HRegion |
HRegion.openHRegion(HRegionInfo info,
HTableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf)
Open a Region.
|
static HRegion |
HRegion.openHRegion(HRegionInfo info,
HTableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region.
|
static HRegion |
HRegion.openHRegion(org.apache.hadoop.fs.Path rootDir,
HRegionInfo info,
HTableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf)
Open a Region.
|
static HRegion |
HRegion.openHRegion(org.apache.hadoop.fs.Path rootDir,
HRegionInfo info,
HTableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region.
|
HRegion |
RegionMergeTransactionImpl.stepsBeforePONR(Server server,
RegionServerServices services,
boolean testing) |
Modifier and Type | Method and Description |
---|---|
static void |
HRegion.addRegionToMETA(HRegion meta,
HRegion r)
Inserts a new region's meta information into the passed
meta region. |
private Map<byte[],List<StoreFile>> |
RegionMergeTransactionImpl.closeAndOfflineRegion(RegionServerServices services,
HRegion region,
boolean isRegionA,
boolean testing)
Close the merging region and offline it in regionserver
|
static void |
HRegion.closeHRegion(HRegion r)
This will do the necessary cleanup a call to
createHRegion(HRegionInfo, Path, Configuration, HTableDescriptor)
requires. |
protected void |
KeyPrefixRegionSplitPolicy.configureForRegion(HRegion region) |
protected void |
IncreasingToUpperBoundRegionSplitPolicy.configureForRegion(HRegion region) |
protected void |
RegionSplitPolicy.configureForRegion(HRegion region)
Upon construction, this method will be called with the region
to be governed.
|
protected void |
FlushPolicy.configureForRegion(HRegion region)
Upon construction, this method will be called with the region to be governed.
|
protected void |
DelimitedKeyPrefixRegionSplitPolicy.configureForRegion(HRegion region) |
protected void |
FlushLargeStoresPolicy.configureForRegion(HRegion region) |
protected void |
ConstantSizeRegionSplitPolicy.configureForRegion(HRegion region) |
static FlushPolicy |
FlushPolicyFactory.create(HRegion region,
org.apache.hadoop.conf.Configuration conf)
Create the FlushPolicy configured for the given table.
|
static RegionSplitPolicy |
RegionSplitPolicy.create(HRegion region,
org.apache.hadoop.conf.Configuration conf)
Create the RegionSplitPolicy configured for the given table.
|
(package private) HRegion |
RegionMergeTransactionImpl.createMergedRegionFromMerges(HRegion a,
HRegion b,
HRegionInfo mergedRegion)
Create a merged region from the merges directory under region a.
|
(package private) HRegion |
HRegion.createMergedRegionFromMerges(HRegionInfo mergedRegionInfo,
HRegion region_b)
Create a merged region given a temp directory with the region data.
|
private void |
HRegion.doProcessRowWithTimeout(RowProcessor<?,?> processor,
long now,
HRegion region,
List<Mutation> mutations,
WALEdit walEdit,
long timeout) |
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) |
static HRegion |
HRegion.merge(HRegion a,
HRegion b)
Merge two regions whether they are adjacent or not.
|
static HRegion |
HRegion.mergeAdjacent(HRegion srcA,
HRegion srcB)
Merge two HRegions.
|
(package private) void |
SplitTransactionImpl.openDaughterRegion(Server server,
HRegion daughter)
Open daughter regions, add them to online list and update meta.
|
static HRegion |
HRegion.openHRegion(HRegion other,
CancelableProgressable reporter)
Useful when reopening a closed region (normally for unit tests)
|
(package private) void |
RegionMergeTransactionImpl.openMergedRegion(Server server,
RegionServerServices services,
HRegion merged)
Perform time consuming opening of the merged region.
|
void |
RowProcessor.postBatchMutate(HRegion region)
The hook to be executed after the process() and applying the Mutations to region.
|
void |
MultiRowMutationProcessor.postBatchMutate(HRegion region) |
void |
BaseRowProcessor.postBatchMutate(HRegion region) |
void |
RegionServerCoprocessorHost.postMerge(HRegion regionA,
HRegion regionB,
HRegion mergedRegion) |
void |
RegionServerCoprocessorHost.postMergeCommit(HRegion regionA,
HRegion regionB,
HRegion mergedRegion) |
void |
RowProcessor.postProcess(HRegion region,
WALEdit walEdit,
boolean success)
The hook to be executed after process() and applying the Mutations to region.
|
void |
MultiRowMutationProcessor.postProcess(HRegion region,
WALEdit walEdit,
boolean success) |
void |
BaseRowProcessor.postProcess(HRegion region,
WALEdit walEdit,
boolean success) |
void |
RegionServerCoprocessorHost.postRollBackMerge(HRegion regionA,
HRegion regionB) |
void |
RowProcessor.preBatchMutate(HRegion region,
WALEdit walEdit)
The hook to be executed after the process() but before applying the Mutations to region.
|
void |
MultiRowMutationProcessor.preBatchMutate(HRegion region,
WALEdit walEdit) |
void |
BaseRowProcessor.preBatchMutate(HRegion region,
WALEdit walEdit) |
boolean |
RegionServerCoprocessorHost.preMerge(HRegion regionA,
HRegion regionB) |
boolean |
RegionServerCoprocessorHost.preMergeCommit(HRegion regionA,
HRegion regionB,
List<Mutation> metaEntries) |
void |
RowProcessor.preProcess(HRegion region,
WALEdit walEdit)
The hook to be executed before process().
|
void |
MultiRowMutationProcessor.preProcess(HRegion region,
WALEdit walEdit) |
void |
BaseRowProcessor.preProcess(HRegion region,
WALEdit walEdit) |
void |
RegionServerCoprocessorHost.preRollBackMerge(HRegion regionA,
HRegion regionB) |
void |
RowProcessor.process(long now,
HRegion region,
List<Mutation> mutations,
WALEdit walEdit)
HRegion handles the locks and MVCC and invokes this method properly.
|
void |
MultiRowMutationProcessor.process(long now,
HRegion region,
List<Mutation> mutationsToApply,
WALEdit walEdit) |
void |
RegionMergeTransactionImpl.stepsAfterPONR(Server server,
RegionServerServices services,
HRegion mergedRegion)
Deprecated.
|
void |
RegionMergeTransactionImpl.stepsAfterPONR(Server server,
RegionServerServices services,
HRegion mergedRegion,
User user) |
(package private) void |
HRegionServer.triggerFlushInPrimaryRegion(HRegion region)
Trigger a flush in the primary region replica if this region is a secondary replica.
|
Constructor and Description |
---|
HRegion.RegionScannerImpl(Scan scan,
List<KeyValueScanner> additionalScanners,
HRegion region) |
HStore(HRegion region,
HColumnDescriptor family,
org.apache.hadoop.conf.Configuration confParam)
Constructor
|
MetricsRegionWrapperImpl(HRegion region) |
ReversedRegionScannerImpl(Scan scan,
List<KeyValueScanner> additionalScanners,
HRegion region) |
SplitTransactionImpl.DaughterOpener(Server s,
HRegion r) |
Modifier and Type | Field and Description |
---|---|
private HRegion |
RegionReplicaFlushHandler.region |
private HRegion |
OpenRegionHandler.PostOpenDeployTasksThread.region |
Modifier and Type | Method and Description |
---|---|
(package private) HRegion |
OpenRegionHandler.openRegion() |
Modifier and Type | Method and Description |
---|---|
(package private) void |
OpenRegionHandler.cleanupFailedOpen(HRegion region) |
private void |
OpenRegionHandler.doCleanUpOnFailedOpen(HRegion region,
boolean transitionedToOpening,
OpenRegionCoordination.OpenRegionDetails ord) |
(package private) void |
RegionReplicaFlushHandler.triggerFlushInPrimaryRegion(HRegion region) |
(package private) boolean |
OpenRegionHandler.updateMeta(HRegion r,
long masterSystemTime)
Update ZK or META.
|
Constructor and Description |
---|
OpenRegionHandler.PostOpenDeployTasksThread(HRegion region,
Server server,
RegionServerServices services,
AtomicBoolean signaller,
long masterSystemTime) |
RegionReplicaFlushHandler(Server server,
ClusterConnection connection,
RpcRetryingCallerFactory rpcRetryingCallerFactory,
RpcControllerFactory rpcControllerFactory,
int operationTimeout,
HRegion region) |
Modifier and Type | Method and Description |
---|---|
void |
SnapshotManifest.addRegion(HRegion region)
Creates a 'manifest' for the specified region, by reading directly from the HRegion object.
|
private void |
RestoreSnapshotHelper.cloneRegion(HRegion region,
HRegionInfo snapshotRegionInfo,
org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest manifest)
Clone region directory content from the snapshot info.
|
Modifier and Type | Field and Description |
---|---|
private HRegion |
MetaUtils.metaRegion |
Modifier and Type | Field and Description |
---|---|
private Map<byte[],HRegion> |
MetaUtils.metaRegions |
Modifier and Type | Method and Description |
---|---|
static HRegion |
HBaseFsckRepair.createHDFSRegionDir(org.apache.hadoop.conf.Configuration conf,
HRegionInfo hri,
HTableDescriptor htd)
Creates, flushes, and closes a new region.
|
private HRegion |
HBaseFsck.createNewMeta()
This borrows code from MasterFileSystem.bootstrap()
|
HRegion |
MetaUtils.getMetaRegion() |
private HRegion |
Merge.merge(HTableDescriptor htd,
HRegion meta,
HRegionInfo info1,
HRegionInfo info2) |
private HRegion |
MetaUtils.openMetaRegion() |
Modifier and Type | Method and Description |
---|---|
void |
ModifyRegionUtils.RegionFillTask.fillRegion(HRegion region) |
static boolean |
ServerRegionReplicaUtil.isReadOnly(HRegion region)
Returns whether this region replica can accept writes.
|
private HRegion |
Merge.merge(HTableDescriptor htd,
HRegion meta,
HRegionInfo info1,
HRegionInfo info2) |
private void |
Merge.removeRegionFromMeta(HRegion meta,
HRegionInfo regioninfo) |
static boolean |
ServerRegionReplicaUtil.shouldReplayRecoveredEdits(HRegion region)
Returns whether to replay the recovered edits to flush the results.
|
protected abstract void |
HMerge.Merger.updateMeta(byte[] oldRegion1,
byte[] oldRegion2,
HRegion newRegion) |
protected void |
HMerge.OnlineMerger.updateMeta(byte[] oldRegion1,
byte[] oldRegion2,
HRegion newRegion) |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.