Modifier and Type | Method and Description |
---|---|
void |
ZKSplitTransactionCoordination.completeSplitTransaction(RegionServerServices services,
Region a,
Region b,
SplitTransactionCoordination.SplitTransactionDetails std,
Region parent)
Finish off split transaction, transition the zknode
|
void |
SplitTransactionCoordination.completeSplitTransaction(RegionServerServices services,
Region first,
Region second,
SplitTransactionCoordination.SplitTransactionDetails std,
Region parent)
Finish off split transaction
|
void |
ZKSplitTransactionCoordination.waitForSplitTransaction(RegionServerServices services,
Region parent,
HRegionInfo hri_a,
HRegionInfo hri_b,
SplitTransactionCoordination.SplitTransactionDetails sptd)
Wait for the splitting node to be transitioned from pending_split to splitting by master.
|
void |
SplitTransactionCoordination.waitForSplitTransaction(RegionServerServices services,
Region parent,
HRegionInfo hri_a,
HRegionInfo hri_b,
SplitTransactionCoordination.SplitTransactionDetails std)
Wait while coordination process the transaction
|
Modifier and Type | Method and Description |
---|---|
Region |
RegionCoprocessorEnvironment.getRegion() |
Modifier and Type | Method and Description |
---|---|
void |
RegionServerObserver.postMerge(ObserverContext<RegionServerCoprocessorEnvironment> c,
Region regionA,
Region regionB,
Region mergedRegion)
called after the regions merge.
|
void |
BaseRegionServerObserver.postMerge(ObserverContext<RegionServerCoprocessorEnvironment> c,
Region regionA,
Region regionB,
Region mergedRegion) |
void |
RegionServerObserver.postMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
Region regionA,
Region regionB,
Region mergedRegion)
This will be called after PONR step as part of regions merge transaction.
|
void |
BaseRegionServerObserver.postMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
Region regionA,
Region regionB,
Region mergedRegion) |
void |
RegionServerObserver.postRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
Region regionA,
Region regionB)
This will be called after the roll back of the regions merge.
|
void |
BaseRegionServerObserver.postRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
Region regionA,
Region regionB) |
void |
RegionObserver.postSplit(ObserverContext<RegionCoprocessorEnvironment> c,
Region l,
Region r)
Deprecated.
Use postCompleteSplit() instead
|
void |
BaseRegionObserver.postSplit(ObserverContext<RegionCoprocessorEnvironment> e,
Region l,
Region r) |
void |
RegionServerObserver.preMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
Region regionA,
Region regionB)
Called before the regions merge.
|
void |
BaseRegionServerObserver.preMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
Region regionA,
Region regionB) |
void |
RegionServerObserver.preMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
Region regionA,
Region regionB,
List<Mutation> metaEntries)
This will be called before PONR step as part of regions merge transaction.
|
void |
BaseRegionServerObserver.preMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
Region regionA,
Region regionB,
List<Mutation> metaEntries) |
void |
RegionServerObserver.preRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
Region regionA,
Region regionB)
This will be called before the roll back of the regions merge.
|
void |
BaseRegionServerObserver.preRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
Region regionA,
Region regionB) |
Constructor and Description |
---|
FlushTableSubprocedure(ProcedureMember member,
ForeignExceptionDispatcher errorListener,
long wakeFrequency,
long timeout,
List<Region> regions,
String table,
org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager.FlushTableSubprocedurePool taskManager) |
Modifier and Type | Method and Description |
---|---|
OperationQuota |
RegionServerQuotaManager.checkQuota(Region region,
List<ClientProtos.Action> actions)
Check the quota for the current (rpc-context) user.
|
OperationQuota |
RegionServerQuotaManager.checkQuota(Region region,
OperationQuota.OperationType type)
Check the quota for the current (rpc-context) user.
|
Modifier and Type | Class and Description |
---|---|
class |
HRegion |
Modifier and Type | Field and Description |
---|---|
protected Map<String,Region> |
HRegionServer.onlineRegions
Map of regions currently being served by this region server.
|
protected Map<String,Region> |
HRegionServer.recoveringRegions
Set of regions currently being in recovering state which means it can accept writes(edits from
previous failed region server) but not reads.
|
Modifier and Type | Method and Description |
---|---|
Region |
RegionMergeTransaction.execute(Server server,
RegionServerServices services)
Deprecated.
use #execute(Server, RegionServerServices, User)
|
Region |
RegionMergeTransaction.execute(Server server,
RegionServerServices services,
User user)
Run the transaction.
|
Region |
OnlineRegions.getFromOnlineRegions(String encodedRegionName)
Return
Region instance. |
Region |
HRegionServer.getFromOnlineRegions(String encodedRegionName) |
Region |
HRegionServer.getOnlineRegion(byte[] regionName) |
Region |
RegionServerServices.PostOpenDeployContext.getRegion() |
protected Region |
HRegionServer.getRegion(byte[] regionName)
Protected utility method for safely obtaining an HRegion handle.
|
protected Region |
HRegionServer.getRegionByEncodedName(byte[] regionName,
String encodedRegionName) |
Region |
HRegionServer.getRegionByEncodedName(String encodedRegionName) |
static Region |
HRegion.openHRegion(Region other,
CancelableProgressable reporter) |
Modifier and Type | Method and Description |
---|---|
PairOfSameType<Region> |
SplitTransactionImpl.execute(Server server,
RegionServerServices services) |
PairOfSameType<Region> |
SplitTransaction.execute(Server server,
RegionServerServices services)
Deprecated.
use #execute(Server, RegionServerServices, User)
|
PairOfSameType<Region> |
SplitTransactionImpl.execute(Server server,
RegionServerServices services,
User user)
Run the transaction.
|
PairOfSameType<Region> |
SplitTransaction.execute(Server server,
RegionServerServices services,
User user)
Run the transaction.
|
List<Region> |
OnlineRegions.getOnlineRegions(TableName tableName)
Get all online regions of a table in this RS.
|
List<Region> |
HRegionServer.getOnlineRegions(TableName tableName)
Gets the online regions of the specified table.
|
Collection<Region> |
HRegionServer.getOnlineRegionsLocalContext()
For tests, web ui and metrics.
|
Map<String,Region> |
RegionServerServices.getRecoveringRegions() |
Map<String,Region> |
HRegionServer.getRecoveringRegions() |
PairOfSameType<Region> |
SplitTransactionImpl.stepsAfterPONR(Server server,
RegionServerServices services,
PairOfSameType<Region> regions)
Deprecated.
|
PairOfSameType<Region> |
SplitTransactionImpl.stepsAfterPONR(Server server,
RegionServerServices services,
PairOfSameType<Region> regions,
User user) |
PairOfSameType<Region> |
SplitTransactionImpl.stepsBeforePONR(Server server,
RegionServerServices services,
boolean testing) |
Modifier and Type | Method and Description |
---|---|
void |
OnlineRegions.addToOnlineRegions(Region r)
Add to online regions.
|
void |
HRegionServer.addToOnlineRegions(Region region) |
SplitTransaction |
SplitTransactionFactory.create(Region r,
byte[] splitrow)
Create a split transaction
|
RegionMergeTransactionImpl |
RegionMergeTransactionFactory.create(Region a,
Region b,
boolean forcible)
Create a merge transaction
|
void |
FlushRequestListener.flushRequested(org.apache.hadoop.hbase.regionserver.FlushType type,
Region region)
Callback which will get called when a flush request is made for a region.
|
static Region |
HRegion.openHRegion(Region other,
CancelableProgressable reporter) |
void |
RegionServerServices.postOpenDeployTasks(Region r)
Deprecated.
|
void |
HRegionServer.postOpenDeployTasks(Region r) |
void |
RegionCoprocessorHost.postSplit(Region l,
Region r)
Invoked just after a split
|
boolean |
OnlineRegions.removeFromOnlineRegions(Region r,
ServerName destination)
This method removes Region corresponding to hri from the Map of onlineRegions.
|
boolean |
HRegionServer.removeFromOnlineRegions(Region r,
ServerName destination) |
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) |
List<CompactionRequest> |
CompactionRequestor.requestCompaction(Region r,
String why) |
List<CompactionRequest> |
CompactSplitThread.requestCompaction(Region r,
String why) |
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) |
void |
FlushRequester.requestDelayedFlush(Region region,
long delay,
boolean forceFlushAllStores)
Tell the listener the cache needs to be flushed after a delay
|
void |
FlushRequester.requestFlush(Region region,
boolean forceFlushAllStores)
Tell the listener the cache needs to be flushed.
|
void |
CompactSplitThread.requestRegionsMerge(Region a,
Region b,
boolean forcible,
long masterSystemTime,
User user) |
boolean |
CompactSplitThread.requestSplit(Region r) |
void |
CompactSplitThread.requestSplit(Region r,
byte[] midKey) |
void |
CompactSplitThread.requestSplit(Region r,
byte[] midKey,
User user) |
void |
CompactSplitThread.requestSystemCompaction(Region r,
Store s,
String why) |
void |
CompactSplitThread.requestSystemCompaction(Region r,
String why) |
Modifier and Type | Method and Description |
---|---|
PairOfSameType<Region> |
SplitTransactionImpl.stepsAfterPONR(Server server,
RegionServerServices services,
PairOfSameType<Region> regions)
Deprecated.
|
PairOfSameType<Region> |
SplitTransactionImpl.stepsAfterPONR(Server server,
RegionServerServices services,
PairOfSameType<Region> regions,
User user) |
Constructor and Description |
---|
RegionCoprocessorHost(Region region,
RegionServerServices rsServices,
org.apache.hadoop.conf.Configuration conf)
Constructor
|
RegionMergeTransactionImpl(Region a,
Region b,
boolean forcible)
Constructor
|
RegionMergeTransactionImpl(Region a,
Region b,
boolean forcible,
long masterSystemTime)
Constructor
|
RegionServerServices.PostOpenDeployContext(Region region,
long masterSystemTime) |
SplitTransactionImpl(Region r,
byte[] splitrow)
Constructor
|
Constructor and Description |
---|
FlushSnapshotSubprocedure(ProcedureMember member,
ForeignExceptionDispatcher errorListener,
long wakeFrequency,
long timeout,
List<Region> regions,
HBaseProtos.SnapshotDescription snapshot,
org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager.SnapshotSubprocedurePool taskManager) |
Modifier and Type | Method and Description |
---|---|
Region |
AccessController.getRegion() |
Modifier and Type | Method and Description |
---|---|
void |
AccessController.postMerge(ObserverContext<RegionServerCoprocessorEnvironment> c,
Region regionA,
Region regionB,
Region mergedRegion) |
void |
AccessController.postMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
Region regionA,
Region regionB,
Region mergedRegion) |
void |
AccessController.postRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
Region regionA,
Region regionB) |
void |
AccessController.preMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
Region regionA,
Region regionB) |
void |
AccessController.preMergeCommit(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
Region regionA,
Region regionB,
List<Mutation> metaEntries) |
void |
AccessController.preRollBackMerge(ObserverContext<RegionServerCoprocessorEnvironment> ctx,
Region regionA,
Region regionB) |
Modifier and Type | Method and Description |
---|---|
protected void |
DefaultVisibilityLabelServiceImpl.addSystemLabel(Region region,
Map<String,Integer> labels,
Map<String,List<Integer>> userAuths) |
static Filter |
VisibilityUtils.createVisibilityLabelFilter(Region region,
Authorizations authorizations) |
Copyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.