Modifier and Type | Class and Description |
---|---|
class |
HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
use
RegionInfoBuilder to build RegionInfo . |
Modifier and Type | Method and Description |
---|---|
RegionInfo |
HRegionLocation.getRegion() |
static RegionInfo |
MetaTableAccessor.getRegionInfo(Result data)
Returns RegionInfo object from the column
HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog
table Result.
|
static RegionInfo |
MetaTableAccessor.parseRegionInfoFromRegionName(byte[] regionName)
Returns an HRI parsed from this regionName.
|
Modifier and Type | Method and Description |
---|---|
static NavigableMap<RegionInfo,ServerName> |
MetaTableAccessor.allTableRegions(Connection connection,
TableName tableName)
Deprecated.
use
MetaTableAccessor.getTableRegionsAndLocations(org.apache.hadoop.hbase.client.Connection, org.apache.hadoop.hbase.TableName) , region can have multiple locations |
static List<RegionInfo> |
MetaTableAccessor.getAllRegions(Connection connection,
boolean excludeOfflinedSplitParents)
Lists all of the regions currently in META.
|
static PairOfSameType<RegionInfo> |
MetaTableAccessor.getDaughterRegions(Result data)
Returns the daughter regions by reading the corresponding columns of the catalog table
Result.
|
static PairOfSameType<RegionInfo> |
MetaTableAccessor.getMergeRegions(Result data)
Returns the merge regions by reading the corresponding columns of the catalog table
Result.
|
static Pair<RegionInfo,ServerName> |
MetaTableAccessor.getRegion(Connection connection,
byte[] regionName)
Deprecated.
|
static Pair<RegionInfo,RegionInfo> |
MetaTableAccessor.getRegionsFromMergeQualifier(Connection connection,
byte[] regionName)
Get regions from the merge qualifier of the specified merged region
|
static Pair<RegionInfo,RegionInfo> |
MetaTableAccessor.getRegionsFromMergeQualifier(Connection connection,
byte[] regionName)
Get regions from the merge qualifier of the specified merged region
|
static NavigableMap<RegionInfo,Result> |
MetaTableAccessor.getServerUserRegions(Connection connection,
ServerName serverName) |
static List<RegionInfo> |
MetaTableAccessor.getTableRegions(Connection connection,
TableName tableName)
Gets all of the regions of the specified table.
|
static List<RegionInfo> |
MetaTableAccessor.getTableRegions(Connection connection,
TableName tableName,
boolean excludeOfflinedSplitParents)
Gets all of the regions of the specified table.
|
static List<Pair<RegionInfo,ServerName>> |
MetaTableAccessor.getTableRegionsAndLocations(Connection connection,
TableName tableName)
Do not use this method to get meta table regions, use methods in MetaTableLocator instead.
|
static List<Pair<RegionInfo,ServerName>> |
MetaTableAccessor.getTableRegionsAndLocations(Connection connection,
TableName tableName,
boolean excludeOfflinedSplitParents)
Do not use this method to get meta table regions, use methods in MetaTableLocator instead.
|
Modifier and Type | Method and Description |
---|---|
static Put |
MetaTableAccessor.addDaughtersToPut(Put put,
RegionInfo splitA,
RegionInfo splitB)
Adds split daughters to the Put
|
static Put |
MetaTableAccessor.addRegionInfo(Put p,
RegionInfo hri) |
static void |
MetaTableAccessor.addRegionToMeta(Connection connection,
RegionInfo regionInfo)
Adds a (single) hbase:meta row for the specified new region and its daughters.
|
static void |
MetaTableAccessor.addSplitsToParent(Connection connection,
RegionInfo regionInfo,
RegionInfo splitA,
RegionInfo splitB)
Adds daughter region infos to hbase:meta row for the specified region.
|
static void |
MetaTableAccessor.deleteMergeQualifiers(Connection connection,
RegionInfo mergedRegion)
Deletes merge qualifiers for the specified merged region.
|
static void |
MetaTableAccessor.deleteRegion(Connection connection,
RegionInfo regionInfo)
Deletes the specified region from META.
|
static byte[] |
MetaTableAccessor.getMetaKeyForRegion(RegionInfo regionInfo)
Returns the row key to use for this regionInfo
|
static HRegionLocation |
MetaTableAccessor.getRegionLocation(Connection connection,
RegionInfo regionInfo)
Returns the HRegionLocation from meta for the given region
|
static Put |
MetaTableAccessor.makePutForReplicationBarrier(RegionInfo regionInfo,
long openSeqNum,
long ts) |
static Put |
MetaTableAccessor.makePutFromRegionInfo(RegionInfo regionInfo,
long ts)
Generates and returns a Put containing the region into for the catalog table
|
static void |
MetaTableAccessor.mergeRegions(Connection connection,
RegionInfo mergedRegion,
RegionInfo regionA,
long regionAOpenSeqNum,
RegionInfo regionB,
long regionBOpenSeqNum,
ServerName sn,
int regionReplication)
Merge the two regions into one in an atomic operation.
|
void |
RegionStateListener.onRegionMerged(RegionInfo mergedRegion)
Process region merge event.
|
void |
RegionStateListener.onRegionSplit(RegionInfo hri)
Process region split event.
|
void |
RegionStateListener.onRegionSplitReverted(RegionInfo hri)
Process region split reverted event.
|
static void |
MetaTableAccessor.splitRegion(Connection connection,
RegionInfo parent,
long parentOpenSeqNum,
RegionInfo splitA,
RegionInfo splitB,
ServerName sn,
int regionReplication)
Splits the region into two in an atomic operation.
|
static void |
MetaTableAccessor.updateRegionLocation(Connection connection,
RegionInfo regionInfo,
ServerName sn,
long openSeqNum,
long masterSystemTime)
Updates the location of the specified region in hbase:meta to be the specified server hostname
and startcode.
|
Modifier and Type | Method and Description |
---|---|
static void |
MetaTableAccessor.addRegionsToMeta(Connection connection,
List<RegionInfo> regionInfos,
int regionReplication)
Adds a hbase:meta row for each of the specified new regions.
|
static void |
MetaTableAccessor.deleteRegions(Connection connection,
List<RegionInfo> regionsInfo)
Deletes the specified regions from META.
|
static void |
MetaTableAccessor.deleteRegions(Connection connection,
List<RegionInfo> regionsInfo,
long ts)
Deletes the specified regions from META.
|
static byte[] |
MetaTableAccessor.getParentsBytes(List<RegionInfo> parents) |
static void |
MetaTableAccessor.overwriteRegions(Connection connection,
List<RegionInfo> regionInfos,
int regionReplication)
Overwrites the specified regions from hbase:meta.
|
Constructor and Description |
---|
HRegionInfo(RegionInfo other)
Deprecated.
Costruct a copy of another HRegionInfo
|
HRegionLocation(RegionInfo regionInfo,
ServerName serverName) |
HRegionLocation(RegionInfo regionInfo,
ServerName serverName,
long seqNum) |
Modifier and Type | Method and Description |
---|---|
static void |
HFileArchiver.archiveFamily(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.conf.Configuration conf,
RegionInfo parent,
org.apache.hadoop.fs.Path tableDir,
byte[] family)
Remove from the specified region the store files of the specified column family,
either by archiving them or outright deletion
|
static void |
HFileArchiver.archiveFamilyByFamilyDir(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.conf.Configuration conf,
RegionInfo parent,
org.apache.hadoop.fs.Path familyDir,
byte[] family)
Removes from the specified region the store files of the specified column family,
either by archiving them or outright deletion
|
static void |
HFileArchiver.archiveRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
RegionInfo info)
Cleans up all the files for a HRegion by archiving the HFiles to the archive directory
|
static void |
HFileArchiver.archiveStoreFile(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
RegionInfo regionInfo,
org.apache.hadoop.fs.Path tableDir,
byte[] family,
org.apache.hadoop.fs.Path storeFile)
Archive the store file
|
static void |
HFileArchiver.archiveStoreFiles(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
RegionInfo regionInfo,
org.apache.hadoop.fs.Path tableDir,
byte[] family,
Collection<HStoreFile> compactedFiles)
Remove the store files, either by archiving them or outright deletion
|
static boolean |
HFileArchiver.exists(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
RegionInfo info) |
Modifier and Type | Class and Description |
---|---|
class |
ImmutableHRegionInfo
Deprecated.
|
Modifier and Type | Field and Description |
---|---|
static RegionInfo |
RegionInfoBuilder.FIRST_META_REGIONINFO
RegionInfo for first meta region
You cannot use this builder to make an instance of the
RegionInfoBuilder.FIRST_META_REGIONINFO . |
Modifier and Type | Field and Description |
---|---|
static Comparator<RegionInfo> |
RegionInfo.COMPARATOR |
Modifier and Type | Method and Description |
---|---|
RegionInfo |
RegionInfoBuilder.build() |
static RegionInfo |
RegionInfo.createMobRegionInfo(TableName tableName)
Creates a RegionInfo object for MOB data.
|
static RegionInfo |
RegionReplicaUtil.getRegionInfoForDefaultReplica(RegionInfo regionInfo)
Returns the RegionInfo for the default replicaId (0).
|
static RegionInfo |
RegionReplicaUtil.getRegionInfoForReplica(RegionInfo regionInfo,
int replicaId)
Returns the RegionInfo for the given replicaId.
|
static RegionInfo |
RegionInfo.parseFrom(byte[] bytes) |
static RegionInfo |
RegionInfo.parseFrom(byte[] bytes,
int offset,
int len) |
static RegionInfo |
RegionInfo.parseFrom(DataInputStream in)
Parses an RegionInfo instance from the passed in stream.
|
static RegionInfo |
RegionInfo.parseFromOrNull(byte[] bytes) |
static RegionInfo |
RegionInfo.parseFromOrNull(byte[] bytes,
int offset,
int len) |
Modifier and Type | Method and Description |
---|---|
static List<RegionInfo> |
RegionReplicaUtil.addReplicas(TableDescriptor tableDescriptor,
List<RegionInfo> regions,
int oldReplicaCount,
int newReplicaCount)
Create any replicas for the regions (the default replicas that was already created is passed to
the method)
|
List<RegionInfo> |
HBaseAdmin.getRegions(ServerName sn) |
CompletableFuture<List<RegionInfo>> |
AsyncAdmin.getRegions(ServerName serverName)
Get all the online regions on a region server.
|
List<RegionInfo> |
Admin.getRegions(ServerName serverName)
Get all the online regions on a region server.
|
List<RegionInfo> |
HBaseAdmin.getRegions(TableName tableName) |
CompletableFuture<List<RegionInfo>> |
AsyncAdmin.getRegions(TableName tableName)
Get the regions of a given table.
|
List<RegionInfo> |
Admin.getRegions(TableName tableName)
Get the regions of a given table.
|
static List<RegionInfo> |
RegionInfo.parseDelimitedFrom(byte[] bytes,
int offset,
int length)
Parses all the RegionInfo instances from the passed in stream until EOF.
|
Modifier and Type | Method and Description |
---|---|
static boolean |
RegionInfo.areAdjacent(RegionInfo regionA,
RegionInfo regionB)
Check whether two regions are adjacent
|
void |
MetaCache.clearCache(RegionInfo hri)
Deletes the cached location of the region if necessary, based on some error from source.
|
static byte[] |
RegionInfoDisplay.getEndKeyForDisplay(RegionInfo ri,
org.apache.hadoop.conf.Configuration conf)
Get the end key for display.
|
static RegionInfo |
RegionReplicaUtil.getRegionInfoForDefaultReplica(RegionInfo regionInfo)
Returns the RegionInfo for the default replicaId (0).
|
static RegionInfo |
RegionReplicaUtil.getRegionInfoForReplica(RegionInfo regionInfo,
int replicaId)
Returns the RegionInfo for the given replicaId.
|
static String |
RegionInfo.getRegionNameAsString(RegionInfo ri,
byte[] regionName) |
static String |
RegionInfoDisplay.getRegionNameAsStringForDisplay(RegionInfo ri,
org.apache.hadoop.conf.Configuration conf)
Get the region name for display.
|
static byte[] |
RegionInfoDisplay.getRegionNameForDisplay(RegionInfo ri,
org.apache.hadoop.conf.Configuration conf)
Get the region name for display.
|
static String |
RegionInfo.getShortNameToLog(RegionInfo... hris) |
static byte[] |
RegionInfoDisplay.getStartKeyForDisplay(RegionInfo ri,
org.apache.hadoop.conf.Configuration conf)
Get the start key for display.
|
static boolean |
RegionReplicaUtil.isDefaultReplica(RegionInfo hri) |
static boolean |
RegionReplicaUtil.isReplicasForSameRegion(RegionInfo regionInfoA,
RegionInfo regionInfoB) |
static RegionInfoBuilder |
RegionInfoBuilder.newBuilder(RegionInfo regionInfo) |
void |
AsyncTable.CoprocessorCallback.onRegionComplete(RegionInfo region,
R resp) |
void |
AsyncTable.CoprocessorCallback.onRegionError(RegionInfo region,
Throwable error) |
static byte[] |
RegionInfo.toByteArray(RegionInfo ri) |
static byte[] |
RegionInfo.toDelimitedByteArray(RegionInfo... infos)
Serializes given RegionInfo's as a byte array.
|
static byte[] |
RegionInfo.toDelimitedByteArray(RegionInfo ri)
Use this instead of
toByteArray(RegionInfo) when writing to a stream and you want to use
the pb mergeDelimitedFrom (w/o the delimiter, pb reads to EOF which may not be what you want). |
Modifier and Type | Method and Description |
---|---|
static List<RegionInfo> |
RegionReplicaUtil.addReplicas(TableDescriptor tableDescriptor,
List<RegionInfo> regions,
int oldReplicaCount,
int newReplicaCount)
Create any replicas for the regions (the default replicas that was already created is passed to
the method)
|
static String |
RegionInfo.getShortNameToLog(List<RegionInfo> ris) |
static void |
RegionReplicaUtil.removeNonDefaultRegions(Collection<RegionInfo> regions)
Removes the non-default replicas from the passed regions collection
|
Constructor and Description |
---|
ClientSideRegionScanner(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootDir,
TableDescriptor htd,
RegionInfo hri,
Scan scan,
ScanMetrics scanMetrics) |
FlushRegionCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
RegionInfo regionInfo,
boolean writeFlushWalMarker) |
ImmutableHRegionInfo(RegionInfo other)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
static LockServiceProtos.LockRequest |
LockServiceClient.buildLockRequest(LockServiceProtos.LockType type,
String namespace,
TableName tableName,
List<RegionInfo> regionInfos,
String description,
long nonceGroup,
long nonce) |
EntityLock |
LockServiceClient.regionLock(List<RegionInfo> regionInfos,
String description,
Abortable abort)
Create a new EntityLock object to acquire exclusive lock on multiple regions of same tables.
|
Modifier and Type | Method and Description |
---|---|
RegionInfo |
RegionCoprocessorEnvironment.getRegionInfo() |
Modifier and Type | Method and Description |
---|---|
default void |
MasterObserver.postAssign(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo regionInfo)
Called after the region assignment has been requested.
|
default void |
MasterObserver.postCompletedCreateTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableDescriptor desc,
RegionInfo[] regions)
Called after the createTable operation has been requested.
|
default void |
MasterObserver.postCompletedMergeRegionsAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo[] regionsToMerge,
RegionInfo mergedRegion)
called after the regions merge.
|
default void |
MasterObserver.postCompletedMergeRegionsAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo[] regionsToMerge,
RegionInfo mergedRegion)
called after the regions merge.
|
default void |
MasterObserver.postCompletedSplitRegionAction(ObserverContext<MasterCoprocessorEnvironment> c,
RegionInfo regionInfoA,
RegionInfo regionInfoB)
Called after the region is split.
|
default void |
MasterObserver.postCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableDescriptor desc,
RegionInfo[] regions)
Called after the createTable operation has been requested.
|
default void |
MasterObserver.postMergeRegions(ObserverContext<MasterCoprocessorEnvironment> c,
RegionInfo[] regionsToMerge)
called after merge regions request.
|
default void |
MasterObserver.postMergeRegionsCommitAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo[] regionsToMerge,
RegionInfo mergedRegion)
This will be called after META step as part of regions merge transaction.
|
default void |
MasterObserver.postMergeRegionsCommitAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo[] regionsToMerge,
RegionInfo mergedRegion)
This will be called after META step as part of regions merge transaction.
|
default void |
MasterObserver.postMove(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo region,
ServerName srcServer,
ServerName destServer)
Called after the region move has been requested.
|
default void |
MasterObserver.postRegionOffline(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo regionInfo)
Called after the region has been marked offline.
|
default void |
RegionObserver.postReplayWALs(ObserverContext<? extends RegionCoprocessorEnvironment> ctx,
RegionInfo info,
org.apache.hadoop.fs.Path edits)
Called after replaying WALs for this region.
|
default void |
MasterObserver.postRequestLock(ObserverContext<MasterCoprocessorEnvironment> ctx,
String namespace,
TableName tableName,
RegionInfo[] regionInfos,
String description)
Called after new LockProcedure is queued.
|
default void |
MasterObserver.postRollBackMergeRegionsAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo[] regionsToMerge)
This will be called after the roll back of the regions merge.
|
default void |
MasterObserver.postUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo regionInfo,
boolean force)
Called after the region unassignment has been requested.
|
default void |
RegionObserver.postWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment> ctx,
RegionInfo info,
WALKey logKey,
WALEdit logEdit)
Called after a
WALEdit
replayed for this region. |
default void |
WALObserver.postWALWrite(ObserverContext<? extends WALCoprocessorEnvironment> ctx,
RegionInfo info,
WALKey logKey,
WALEdit logEdit)
Deprecated.
Since hbase-2.0.0. To be replaced with an alternative that does not expose
InterfaceAudience classes such as WALKey and WALEdit. Will be removed in hbase-3.0.0.
|
default void |
MasterObserver.preAssign(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo regionInfo)
Called prior to assigning a specific region.
|
default void |
MasterObserver.preCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableDescriptor desc,
RegionInfo[] regions)
Called before a new table is created by
HMaster . |
default void |
MasterObserver.preCreateTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableDescriptor desc,
RegionInfo[] regions)
Called before a new table is created by
HMaster . |
default void |
MasterObserver.preMergeRegions(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo[] regionsToMerge)
Called before merge regions request.
|
default void |
MasterObserver.preMergeRegionsAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo[] regionsToMerge)
Called before the regions merge.
|
default void |
MasterObserver.preMergeRegionsCommitAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo[] regionsToMerge,
List<Mutation> metaEntries)
This will be called before update META step as part of regions merge transaction.
|
default void |
MasterObserver.preMove(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo region,
ServerName srcServer,
ServerName destServer)
Called prior to moving a given region from one region server to another.
|
default void |
MasterObserver.preRegionOffline(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo regionInfo)
Called prior to marking a given region as offline.
|
default void |
RegionObserver.preReplayWALs(ObserverContext<? extends RegionCoprocessorEnvironment> ctx,
RegionInfo info,
org.apache.hadoop.fs.Path edits)
Called before replaying WALs for this region.
|
default void |
MasterObserver.preRequestLock(ObserverContext<MasterCoprocessorEnvironment> ctx,
String namespace,
TableName tableName,
RegionInfo[] regionInfos,
String description)
Called before new LockProcedure is queued.
|
default void |
MasterObserver.preUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo regionInfo,
boolean force)
Called prior to unassigning a given region.
|
default void |
RegionObserver.preWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment> ctx,
RegionInfo info,
WALKey logKey,
WALEdit logEdit)
Called before a
WALEdit
replayed for this region. |
default void |
WALObserver.preWALWrite(ObserverContext<? extends WALCoprocessorEnvironment> ctx,
RegionInfo info,
WALKey logKey,
WALEdit logEdit)
Deprecated.
Since hbase-2.0.0. To be replaced with an alternative that does not expose
InterfaceAudience classes such as WALKey and WALEdit. Will be removed in hbase-3.0.0.
|
Modifier and Type | Method and Description |
---|---|
void |
ExampleMasterObserverWithMetrics.postCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableDescriptor desc,
RegionInfo[] regions) |
void |
ExampleMasterObserverWithMetrics.preCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableDescriptor desc,
RegionInfo[] regions) |
Modifier and Type | Method and Description |
---|---|
static Set<RegionInfo> |
FavoredNodesManager.filterNonFNApplicableRegions(Collection<RegionInfo> regions)
Filter and return regions for which favored nodes is not applicable.
|
Map<RegionInfo,List<ServerName>> |
FavoredNodeAssignmentHelper.generateFavoredNodesRoundRobin(Map<ServerName,List<RegionInfo>> assignmentMap,
List<RegionInfo> regions) |
Set<RegionInfo> |
FavoredNodesManager.getRegionsOfFavoredNode(ServerName serverName) |
Map<RegionInfo,ServerName[]> |
FavoredNodeAssignmentHelper.placeSecondaryAndTertiaryRS(Map<RegionInfo,ServerName> primaryRSMap) |
Map<RegionInfo,ServerName[]> |
FavoredNodeAssignmentHelper.placeSecondaryAndTertiaryWithRestrictions(Map<RegionInfo,ServerName> primaryRSMap)
For regions that share the primary, avoid placing the secondary and tertiary
on a same RS.
|
Map<ServerName,List<RegionInfo>> |
FavoredNodeLoadBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers) |
Modifier and Type | Method and Description |
---|---|
void |
FavoredNodesManager.deleteFavoredNodesForRegion(RegionInfo regionInfo) |
List<ServerName> |
FavoredNodeAssignmentHelper.generateFavoredNodes(RegionInfo hri) |
void |
FavoredNodeLoadBalancer.generateFavoredNodesForDaughter(List<ServerName> servers,
RegionInfo parent,
RegionInfo regionA,
RegionInfo regionB) |
void |
FavoredNodesPromoter.generateFavoredNodesForDaughter(List<ServerName> servers,
RegionInfo parent,
RegionInfo hriA,
RegionInfo hriB) |
void |
FavoredNodeLoadBalancer.generateFavoredNodesForMergedRegion(RegionInfo merged,
RegionInfo regionA,
RegionInfo regionB) |
void |
FavoredNodesPromoter.generateFavoredNodesForMergedRegion(RegionInfo merged,
RegionInfo hriA,
RegionInfo hriB) |
List<ServerName> |
FavoredNodeLoadBalancer.getFavoredNodes(RegionInfo regionInfo) |
List<ServerName> |
FavoredNodesManager.getFavoredNodes(RegionInfo regionInfo) |
List<ServerName> |
FavoredNodesPlan.getFavoredNodes(RegionInfo region) |
List<ServerName> |
FavoredNodesManager.getFavoredNodesWithDNPort(RegionInfo regionInfo) |
ServerName[] |
FavoredNodeAssignmentHelper.getSecondaryAndTertiary(RegionInfo regionInfo,
ServerName primaryRS) |
static boolean |
FavoredNodesManager.isFavoredNodeApplicable(RegionInfo regionInfo) |
ServerName |
FavoredNodeLoadBalancer.randomAssignment(RegionInfo regionInfo,
List<ServerName> servers) |
List<ServerName> |
FavoredNodesPlan.removeFavoredNodes(RegionInfo region)
Remove a favored node assignment
|
void |
FavoredNodesPlan.updateFavoredNodesMap(RegionInfo region,
List<ServerName> servers)
Update an assignment to the plan
|
Modifier and Type | Method and Description |
---|---|
List<RegionPlan> |
FavoredNodeLoadBalancer.balanceCluster(Map<ServerName,List<RegionInfo>> clusterState) |
List<RegionPlan> |
FavoredNodeLoadBalancer.balanceCluster(TableName tableName,
Map<ServerName,List<RegionInfo>> clusterState) |
void |
FavoredNodesManager.deleteFavoredNodesForRegions(Collection<RegionInfo> regionInfoList) |
static Set<RegionInfo> |
FavoredNodesManager.filterNonFNApplicableRegions(Collection<RegionInfo> regions)
Filter and return regions for which favored nodes is not applicable.
|
Map<RegionInfo,List<ServerName>> |
FavoredNodeAssignmentHelper.generateFavoredNodesRoundRobin(Map<ServerName,List<RegionInfo>> assignmentMap,
List<RegionInfo> regions) |
Map<RegionInfo,List<ServerName>> |
FavoredNodeAssignmentHelper.generateFavoredNodesRoundRobin(Map<ServerName,List<RegionInfo>> assignmentMap,
List<RegionInfo> regions) |
void |
FavoredNodeAssignmentHelper.placePrimaryRSAsRoundRobin(Map<ServerName,List<RegionInfo>> assignmentMap,
Map<RegionInfo,ServerName> primaryRSMap,
List<RegionInfo> regions) |
void |
FavoredNodeAssignmentHelper.placePrimaryRSAsRoundRobin(Map<ServerName,List<RegionInfo>> assignmentMap,
Map<RegionInfo,ServerName> primaryRSMap,
List<RegionInfo> regions) |
void |
FavoredNodeAssignmentHelper.placePrimaryRSAsRoundRobin(Map<ServerName,List<RegionInfo>> assignmentMap,
Map<RegionInfo,ServerName> primaryRSMap,
List<RegionInfo> regions) |
Map<RegionInfo,ServerName[]> |
FavoredNodeAssignmentHelper.placeSecondaryAndTertiaryRS(Map<RegionInfo,ServerName> primaryRSMap) |
Map<RegionInfo,ServerName[]> |
FavoredNodeAssignmentHelper.placeSecondaryAndTertiaryWithRestrictions(Map<RegionInfo,ServerName> primaryRSMap)
For regions that share the primary, avoid placing the secondary and tertiary
on a same RS.
|
Map<ServerName,List<RegionInfo>> |
FavoredNodeLoadBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers) |
void |
FavoredNodesManager.updateFavoredNodes(Map<RegionInfo,List<ServerName>> regionFNMap) |
static void |
FavoredNodeAssignmentHelper.updateMetaWithFavoredNodesInfo(Map<RegionInfo,List<ServerName>> regionToFavoredNodes,
org.apache.hadoop.conf.Configuration conf)
Update meta table with favored nodes info
|
static void |
FavoredNodeAssignmentHelper.updateMetaWithFavoredNodesInfo(Map<RegionInfo,List<ServerName>> regionToFavoredNodes,
Connection connection)
Update meta table with favored nodes info
|
Modifier and Type | Method and Description |
---|---|
static boolean |
HFileLink.create(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path dstFamilyPath,
RegionInfo hfileRegionInfo,
String hfileName)
Create a new HFileLink
|
static boolean |
HFileLink.create(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path dstFamilyPath,
RegionInfo hfileRegionInfo,
String hfileName,
boolean createBackRef)
Create a new HFileLink
|
static String |
HFileLink.createHFileLinkName(RegionInfo hfileRegionInfo,
String hfileName)
Create a new HFileLink name
|
Modifier and Type | Method and Description |
---|---|
RegionInfo |
TableSnapshotInputFormat.TableSnapshotRegionSplit.getRegion() |
Modifier and Type | Method and Description |
---|---|
RegionInfo |
RegionState.getRegion() |
RegionInfo |
RegionPlan.getRegionInfo() |
Modifier and Type | Method and Description |
---|---|
Map<ServerName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.getPrimaryToRegionInfoMap() |
Map<String,RegionInfo> |
SnapshotOfRegionAssignmentFromMeta.getRegionNameToRegionInfoMap()
Get the regioninfo for a region
|
Map<ServerName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.getRegionServerToRegionMap()
Get regionserver to region map
|
Map<RegionInfo,ServerName> |
SnapshotOfRegionAssignmentFromMeta.getRegionToRegionServerMap()
Get region to region server map
|
Map<ServerName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.getSecondaryToRegionInfoMap() |
Map<TableName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.getTableToRegionMap()
Get regions for tables
|
Map<ServerName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.getTertiaryToRegionInfoMap() |
Map<ServerName,List<RegionInfo>> |
LoadBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers)
Assign regions to the previously hosting region server
|
Map<ServerName,List<RegionInfo>> |
LoadBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers)
Perform a Round Robin assignment of regions.
|
Modifier and Type | Method and Description |
---|---|
boolean |
CatalogJanitor.cleanMergeQualifier(RegionInfo region)
Checks if the specified region has merge qualifiers, if so, try to clean
them
|
static void |
ServerManager.closeRegionSilentlyAndWait(ClusterConnection connection,
ServerName server,
RegionInfo region,
long timeout)
Contacts a region server and waits up to timeout ms
to close the region.
|
static RegionState |
RegionState.createForTesting(RegionInfo region,
RegionState.State state) |
void |
MasterFileSystem.deleteFamilyFromFS(org.apache.hadoop.fs.Path rootDir,
RegionInfo region,
byte[] familyName) |
void |
MasterFileSystem.deleteFamilyFromFS(RegionInfo region,
byte[] familyName) |
org.apache.hadoop.fs.Path |
MasterFileSystem.getRegionDir(RegionInfo region) |
boolean |
ServerManager.isRegionInServerManagerStates(RegionInfo hri) |
long |
MasterServices.mergeRegions(RegionInfo[] regionsToMerge,
boolean forcible,
long nonceGroup,
long nonce)
Merge regions in a table.
|
long |
HMaster.mergeRegions(RegionInfo[] regionsToMerge,
boolean forcible,
long nonceGroup,
long nonce) |
void |
MasterCoprocessorHost.postAssign(RegionInfo regionInfo) |
void |
MasterCoprocessorHost.postCompletedCreateTableAction(TableDescriptor htd,
RegionInfo[] regions,
User user) |
void |
MasterCoprocessorHost.postCompletedMergeRegionsAction(RegionInfo[] regionsToMerge,
RegionInfo mergedRegion,
User user)
Invoked after completing merge regions operation
|
void |
MasterCoprocessorHost.postCompletedMergeRegionsAction(RegionInfo[] regionsToMerge,
RegionInfo mergedRegion,
User user)
Invoked after completing merge regions operation
|
void |
MasterCoprocessorHost.postCompletedSplitRegionAction(RegionInfo regionInfoA,
RegionInfo regionInfoB,
User user)
Invoked just after a split
|
void |
MasterCoprocessorHost.postCreateTable(TableDescriptor htd,
RegionInfo[] regions) |
void |
MasterCoprocessorHost.postMergeRegions(RegionInfo[] regionsToMerge) |
void |
MasterCoprocessorHost.postMergeRegionsCommit(RegionInfo[] regionsToMerge,
RegionInfo mergedRegion,
User user)
Invoked after merge regions operation writes the new region to hbase:meta
|
void |
MasterCoprocessorHost.postMergeRegionsCommit(RegionInfo[] regionsToMerge,
RegionInfo mergedRegion,
User user)
Invoked after merge regions operation writes the new region to hbase:meta
|
void |
MasterCoprocessorHost.postMove(RegionInfo region,
ServerName srcServer,
ServerName destServer) |
void |
MasterCoprocessorHost.postRegionOffline(RegionInfo regionInfo) |
void |
MasterCoprocessorHost.postRequestLock(String namespace,
TableName tableName,
RegionInfo[] regionInfos,
LockType type,
String description) |
void |
MasterCoprocessorHost.postRollBackMergeRegionsAction(RegionInfo[] regionsToMerge,
User user)
Invoked after rollback merge regions operation
|
void |
MasterCoprocessorHost.postUnassign(RegionInfo regionInfo,
boolean force) |
void |
MasterCoprocessorHost.preAssign(RegionInfo regionInfo) |
void |
MasterCoprocessorHost.preCreateTable(TableDescriptor htd,
RegionInfo[] regions) |
void |
MasterCoprocessorHost.preCreateTableAction(TableDescriptor htd,
RegionInfo[] regions,
User user) |
void |
MasterCoprocessorHost.preMergeRegions(RegionInfo[] regionsToMerge) |
void |
MasterCoprocessorHost.preMergeRegionsAction(RegionInfo[] regionsToMerge,
User user)
Invoked just before a merge
|
void |
MasterCoprocessorHost.preMergeRegionsCommit(RegionInfo[] regionsToMerge,
List<Mutation> metaEntries,
User user)
Invoked before merge regions operation writes the new region to hbase:meta
|
void |
MasterCoprocessorHost.preMove(RegionInfo region,
ServerName srcServer,
ServerName destServer) |
void |
MasterCoprocessorHost.preRegionOffline(RegionInfo regionInfo) |
void |
MasterCoprocessorHost.preRequestLock(String namespace,
TableName tableName,
RegionInfo[] regionInfos,
LockType type,
String description) |
void |
MasterCoprocessorHost.preUnassign(RegionInfo regionInfo,
boolean force) |
ServerName |
LoadBalancer.randomAssignment(RegionInfo regionInfo,
List<ServerName> servers)
Get a random region server from the list
|
void |
AssignmentListener.regionClosed(RegionInfo regionInfo)
The region was closed on the region server.
|
void |
LoadBalancer.regionOffline(RegionInfo regionInfo)
Marks the region as offline at balancer.
|
void |
LoadBalancer.regionOnline(RegionInfo regionInfo,
ServerName sn)
Marks the region as online at balancer.
|
void |
AssignmentListener.regionOpened(RegionInfo regionInfo,
ServerName serverName)
The region was opened on the specified server.
|
void |
ServerManager.removeRegion(RegionInfo regionInfo)
Called by delete table and similar to notify the ServerManager that a region was removed.
|
void |
ServerManager.sendRegionWarmup(ServerName server,
RegionInfo region)
Sends a WARMUP RPC to the specified server to warmup the specified region.
|
long |
MasterServices.splitRegion(RegionInfo regionInfo,
byte[] splitRow,
long nonceGroup,
long nonce)
Split a region.
|
long |
HMaster.splitRegion(RegionInfo regionInfo,
byte[] splitRow,
long nonceGroup,
long nonce) |
Modifier and Type | Method and Description |
---|---|
List<RegionPlan> |
LoadBalancer.balanceCluster(Map<ServerName,List<RegionInfo>> clusterState)
Perform the major balance operation
|
List<RegionPlan> |
LoadBalancer.balanceCluster(TableName tableName,
Map<ServerName,List<RegionInfo>> clusterState)
Perform the major balance operation
|
void |
ServerManager.removeRegions(List<RegionInfo> regions)
Called by delete table and similar to notify the ServerManager that a region was removed.
|
Map<ServerName,List<RegionInfo>> |
LoadBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers)
Assign regions to the previously hosting region server
|
Map<ServerName,List<RegionInfo>> |
LoadBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers)
Perform a Round Robin assignment of regions.
|
void |
LoadBalancer.setClusterLoad(Map<TableName,Map<ServerName,List<RegionInfo>>> ClusterLoad)
Pass RegionStates and allow balancer to set the current cluster load.
|
Constructor and Description |
---|
RegionPlan(RegionInfo hri,
ServerName source,
ServerName dest)
Instantiate a plan for a region move, moving the specified region from
the specified source server to the specified destination server.
|
RegionState(RegionInfo region,
RegionState.State state,
long stamp,
ServerName serverName) |
RegionState(RegionInfo region,
RegionState.State state,
long stamp,
ServerName serverName,
long ritDuration) |
RegionState(RegionInfo region,
RegionState.State state,
ServerName serverName) |
Modifier and Type | Method and Description |
---|---|
RegionInfo |
MergeTableRegionsProcedure.getMergedRegion() |
RegionInfo |
AssignmentManager.getMetaRegionFromName(byte[] regionName) |
RegionInfo |
RegionTransitionProcedure.getRegionInfo() |
RegionInfo |
RegionStates.RegionStateNode.getRegionInfo() |
RegionInfo |
RegionStates.RegionFailedOpen.getRegionInfo() |
RegionInfo |
AssignmentManager.getRegionInfo(byte[] regionName) |
Modifier and Type | Method and Description |
---|---|
static boolean |
AssignProcedure.assign(MasterServices masterServices,
RegionInfo ri)
Used by ServerCrashProcedure too skip creating Assigns if not needed.
|
void |
AssignmentManager.assign(RegionInfo regionInfo) |
void |
AssignmentManager.assign(RegionInfo regionInfo,
ServerName sn) |
AssignProcedure |
AssignmentManager.createAssignProcedure(RegionInfo regionInfo)
Called by things like DisableTableProcedure to get a list of UnassignProcedure
to unassign the regions of the table.
|
AssignProcedure |
AssignmentManager.createAssignProcedure(RegionInfo regionInfo,
boolean override) |
AssignProcedure |
AssignmentManager.createAssignProcedure(RegionInfo regionInfo,
ServerName targetServer) |
AssignProcedure |
AssignmentManager.createAssignProcedure(RegionInfo regionInfo,
ServerName targetServer,
boolean override) |
MergeTableRegionsProcedure |
AssignmentManager.createMergeProcedure(RegionInfo regionToMergeA,
RegionInfo regionToMergeB) |
protected RegionStates.RegionStateNode |
RegionStates.createRegionStateNode(RegionInfo regionInfo) |
SplitTableRegionProcedure |
AssignmentManager.createSplitProcedure(RegionInfo regionToSplit,
byte[] splitKey) |
UnassignProcedure |
AssignmentManager.createUnassignProcedure(RegionInfo regionInfo) |
UnassignProcedure |
AssignmentManager.createUnassignProcedure(RegionInfo regionInfo,
boolean override) |
void |
RegionStateStore.deleteRegion(RegionInfo regionInfo) |
void |
RegionStates.deleteRegion(RegionInfo regionInfo) |
RegionStates.RegionFailedOpen |
RegionStates.getFailedOpen(RegionInfo regionInfo) |
List<ServerName> |
AssignmentManager.getFavoredNodes(RegionInfo regionInfo) |
protected RegionStates.RegionStateNode |
RegionStates.getOrCreateRegionStateNode(RegionInfo regionInfo) |
ServerName |
RegionStates.getRegionServerOfRegion(RegionInfo regionInfo) |
RegionState |
RegionStates.getRegionState(RegionInfo regionInfo) |
RegionStates.RegionStateNode |
RegionStates.getRegionStateNode(RegionInfo regionInfo) |
RegionTransitionProcedure |
RegionStates.getRegionTransitionProcedure(RegionInfo hri) |
RegionState |
RegionStates.getRegionTransitionState(RegionInfo hri) |
boolean |
RegionStates.isRegionInRegionStates(RegionInfo hri) |
boolean |
RegionStates.isRegionInState(RegionInfo regionInfo,
RegionState.State... state) |
boolean |
RegionStates.isRegionInTransition(RegionInfo regionInfo) |
boolean |
RegionStates.isRegionOffline(RegionInfo regionInfo) |
boolean |
RegionStates.isRegionOnline(RegionInfo regionInfo) |
boolean |
AssignmentManager.RegionInTransitionStat.isRegionOverThreshold(RegionInfo regionInfo) |
boolean |
AssignmentManager.RegionInTransitionStat.isRegionTwiceOverThreshold(RegionInfo regionInfo) |
boolean |
RegionStates.isReplicaAvailableForRegion(RegionInfo info) |
void |
AssignmentManager.markRegionAsMerged(RegionInfo child,
ServerName serverName,
RegionInfo mother,
RegionInfo father)
When called here, the merge has happened.
|
void |
AssignmentManager.markRegionAsSplit(RegionInfo parent,
ServerName serverName,
RegionInfo daughterA,
RegionInfo daughterB) |
void |
RegionStateStore.mergeRegions(RegionInfo child,
RegionInfo hriA,
RegionInfo hriB,
ServerName serverName) |
void |
AssignmentManager.move(RegionInfo regionInfo) |
void |
AssignmentManager.offlineRegion(RegionInfo regionInfo) |
void |
AssignmentManager.onlineRegion(RegionInfo regionInfo,
ServerName serverName) |
void |
RegionStates.removeFromFailedOpen(RegionInfo regionInfo) |
void |
RegionStates.removeFromOfflineRegions(RegionInfo regionInfo) |
protected void |
RegionTransitionProcedure.setRegionInfo(RegionInfo regionInfo)
This setter is for subclasses to call in their
Procedure.deserializeStateData(ProcedureStateSerializer) method. |
void |
RegionStateStore.splitRegion(RegionInfo parent,
RegionInfo hriA,
RegionInfo hriB,
ServerName serverName) |
void |
AssignmentManager.unassign(RegionInfo regionInfo) |
void |
AssignmentManager.unassign(RegionInfo regionInfo,
boolean forceNewPlan) |
void |
RegionStates.updateRegionState(RegionInfo regionInfo,
RegionState.State state) |
void |
RegionStateStore.RegionStateVisitor.visitRegionState(Result result,
RegionInfo regionInfo,
RegionState.State state,
ServerName regionLocation,
ServerName lastHost,
long openSeqNum) |
boolean |
AssignmentManager.waitMetaAssigned(Procedure<?> proc,
RegionInfo regionInfo)
Notice that this event does not mean the AM has already finished region state rebuilding.
|
Modifier and Type | Method and Description |
---|---|
AssignProcedure[] |
AssignmentManager.createAssignProcedures(List<RegionInfo> hris)
Create an array of AssignProcedures w/o specifying a target server.
|
AssignProcedure[] |
AssignmentManager.createRoundRobinAssignProcedures(List<RegionInfo> hris)
Create round-robin assigns.
|
AssignProcedure[] |
AssignmentManager.createRoundRobinAssignProcedures(List<RegionInfo> hris,
List<ServerName> serversToExclude)
Create round-robin assigns.
|
void |
RegionStateStore.deleteRegions(List<RegionInfo> regions) |
void |
RegionStates.deleteRegions(List<RegionInfo> regionInfos) |
Map<ServerName,List<RegionInfo>> |
AssignmentManager.getSnapShotOfAssignment(Collection<RegionInfo> regions) |
Map<ServerName,List<RegionInfo>> |
RegionStates.getSnapShotOfAssignment(Collection<RegionInfo> regions) |
Constructor and Description |
---|
AssignProcedure(RegionInfo regionInfo) |
AssignProcedure(RegionInfo regionInfo,
ServerName destinationServer) |
AssignProcedure(RegionInfo regionInfo,
ServerName destinationServer,
boolean override) |
GCMergedRegionsProcedure(MasterProcedureEnv env,
RegionInfo mergedChild,
RegionInfo father,
RegionInfo mother) |
GCRegionProcedure(MasterProcedureEnv env,
RegionInfo hri) |
MergeTableRegionsProcedure(MasterProcedureEnv env,
RegionInfo[] regionsToMerge,
boolean forcible) |
MergeTableRegionsProcedure(MasterProcedureEnv env,
RegionInfo regionToMergeA,
RegionInfo regionToMergeB) |
MergeTableRegionsProcedure(MasterProcedureEnv env,
RegionInfo regionToMergeA,
RegionInfo regionToMergeB,
boolean forcible) |
RegionStateNode(RegionInfo regionInfo) |
RegionTransitionProcedure(RegionInfo regionInfo,
boolean override) |
SplitTableRegionProcedure(MasterProcedureEnv env,
RegionInfo regionToSplit,
byte[] splitRow) |
UnassignProcedure(RegionInfo regionInfo,
ServerName hostingServer,
boolean force,
boolean removeAfterUnassigning) |
UnassignProcedure(RegionInfo regionInfo,
ServerName hostingServer,
ServerName destinationServer,
boolean force) |
UnassignProcedure(RegionInfo regionInfo,
ServerName hostingServer,
ServerName destinationServer,
boolean override,
boolean removeAfterUnassigning) |
Modifier and Type | Method and Description |
---|---|
protected Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.assignMasterSystemRegions(Collection<RegionInfo> regions,
List<ServerName> servers)
If master is configured to carry system tables only, in here is
where we figure what to assign it.
|
protected Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.getRegionAssignmentsByServer(Collection<RegionInfo> regions) |
Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers)
Generates a bulk assignment startup plan, attempting to reuse the existing
assignment information from META, but adjusting for the specified list of
available/online servers available for assignment.
|
Map<ServerName,List<RegionInfo>> |
FavoredStochasticBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers) |
Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers)
Generates a bulk assignment plan to be used on cluster startup using a
simple round-robin assignment.
|
Map<ServerName,List<RegionInfo>> |
FavoredStochasticBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers) |
Modifier and Type | Method and Description |
---|---|
void |
FavoredStochasticBalancer.generateFavoredNodesForDaughter(List<ServerName> servers,
RegionInfo parent,
RegionInfo regionA,
RegionInfo regionB) |
void |
FavoredStochasticBalancer.generateFavoredNodesForMergedRegion(RegionInfo merged,
RegionInfo regionA,
RegionInfo regionB) |
List<ServerName> |
FavoredStochasticBalancer.getFavoredNodes(RegionInfo regionInfo) |
ServerName |
BaseLoadBalancer.randomAssignment(RegionInfo regionInfo,
List<ServerName> servers)
Used to assign a single region to a random server.
|
ServerName |
FavoredStochasticBalancer.randomAssignment(RegionInfo regionInfo,
List<ServerName> servers) |
void |
BaseLoadBalancer.regionOffline(RegionInfo regionInfo) |
void |
BaseLoadBalancer.regionOnline(RegionInfo regionInfo,
ServerName sn) |
boolean |
BaseLoadBalancer.shouldBeOnMaster(RegionInfo region)
Check if a region belongs to some system table.
|
Modifier and Type | Method and Description |
---|---|
protected Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.assignMasterSystemRegions(Collection<RegionInfo> regions,
List<ServerName> servers)
If master is configured to carry system tables only, in here is
where we figure what to assign it.
|
List<RegionPlan> |
SimpleLoadBalancer.balanceCluster(Map<ServerName,List<RegionInfo>> clusterMap)
Generate a global load balancing plan according to the specified map of
server information to the most loaded regions of each server.
|
List<RegionPlan> |
StochasticLoadBalancer.balanceCluster(Map<ServerName,List<RegionInfo>> clusterState)
Given the cluster state this will try and approach an optimal balance.
|
List<RegionPlan> |
FavoredStochasticBalancer.balanceCluster(Map<ServerName,List<RegionInfo>> clusterState) |
List<RegionPlan> |
SimpleLoadBalancer.balanceCluster(TableName tableName,
Map<ServerName,List<RegionInfo>> clusterState) |
List<RegionPlan> |
StochasticLoadBalancer.balanceCluster(TableName tableName,
Map<ServerName,List<RegionInfo>> clusterState) |
protected List<RegionPlan> |
BaseLoadBalancer.balanceMasterRegions(Map<ServerName,List<RegionInfo>> clusterMap)
Balance the regions that should be on master regionserver.
|
protected BaseLoadBalancer.Cluster |
BaseLoadBalancer.createCluster(List<ServerName> servers,
Collection<RegionInfo> regions,
boolean hasRegionReplica) |
protected Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.getRegionAssignmentsByServer(Collection<RegionInfo> regions) |
Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers)
Generates a bulk assignment startup plan, attempting to reuse the existing
assignment information from META, but adjusting for the specified list of
available/online servers available for assignment.
|
Map<ServerName,List<RegionInfo>> |
FavoredStochasticBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers) |
Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers)
Generates a bulk assignment plan to be used on cluster startup using a
simple round-robin assignment.
|
Map<ServerName,List<RegionInfo>> |
FavoredStochasticBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers) |
void |
SimpleLoadBalancer.setClusterLoad(Map<TableName,Map<ServerName,List<RegionInfo>>> clusterLoad) |
void |
BaseLoadBalancer.setClusterLoad(Map<TableName,Map<ServerName,List<RegionInfo>>> clusterLoad) |
Constructor and Description |
---|
Cluster(Collection<RegionInfo> unassignedRegions,
Map<ServerName,List<RegionInfo>> clusterState,
Map<String,Deque<org.apache.hadoop.hbase.master.balancer.BalancerRegionLoad>> loads,
org.apache.hadoop.hbase.master.balancer.RegionLocationFinder regionFinder,
RackManager rackManager) |
Cluster(Collection<RegionInfo> unassignedRegions,
Map<ServerName,List<RegionInfo>> clusterState,
Map<String,Deque<org.apache.hadoop.hbase.master.balancer.BalancerRegionLoad>> loads,
org.apache.hadoop.hbase.master.balancer.RegionLocationFinder regionFinder,
RackManager rackManager) |
Cluster(Map<ServerName,List<RegionInfo>> clusterState,
Map<String,Deque<org.apache.hadoop.hbase.master.balancer.BalancerRegionLoad>> loads,
org.apache.hadoop.hbase.master.balancer.RegionLocationFinder regionFinder,
RackManager rackManager) |
ClusterLoadState(Map<ServerName,List<RegionInfo>> clusterState) |
Modifier and Type | Method and Description |
---|---|
LockManager.MasterLock |
LockManager.createMasterLock(RegionInfo[] regionInfos,
String description) |
long |
LockManager.RemoteLocks.requestRegionsLock(RegionInfo[] regionInfos,
String description,
NonceKey nonceKey) |
Constructor and Description |
---|
LockProcedure(org.apache.hadoop.conf.Configuration conf,
RegionInfo[] regionInfos,
LockType type,
String description,
CountDownLatch lockAcquireLatch)
Constructor for region lock(s).
|
MasterLock(RegionInfo[] regionInfos,
String description) |
Modifier and Type | Method and Description |
---|---|
RegionInfo |
SplitNormalizationPlan.getRegionInfo() |
Modifier and Type | Method and Description |
---|---|
void |
SimpleRegionNormalizer.planSkipped(RegionInfo hri,
NormalizationPlan.PlanType type) |
void |
RegionNormalizer.planSkipped(RegionInfo hri,
NormalizationPlan.PlanType type)
Notification for the case where plan couldn't be executed due to constraint violation, such as
namespace quota
|
void |
SplitNormalizationPlan.setRegionInfo(RegionInfo regionInfo) |
Constructor and Description |
---|
MergeNormalizationPlan(RegionInfo firstRegion,
RegionInfo secondRegion) |
SplitNormalizationPlan(RegionInfo regionInfo,
byte[] splitPoint) |
Modifier and Type | Method and Description |
---|---|
protected RegionInfo |
AbstractStateMachineRegionProcedure.getRegion() |
RegionInfo |
RSProcedureDispatcher.RegionOperation.getRegionInfo() |
Modifier and Type | Method and Description |
---|---|
protected static List<RegionInfo> |
CreateTableProcedure.addTableToMeta(MasterProcedureEnv env,
TableDescriptor tableDescriptor,
List<RegionInfo> regions) |
protected static List<RegionInfo> |
CreateTableProcedure.createFsLayout(MasterProcedureEnv env,
TableDescriptor tableDescriptor,
List<RegionInfo> newRegions) |
protected static List<RegionInfo> |
CreateTableProcedure.createFsLayout(MasterProcedureEnv env,
TableDescriptor tableDescriptor,
List<RegionInfo> newRegions,
CreateTableProcedure.CreateHdfsRegions hdfsRegionHandler) |
List<RegionInfo> |
CreateTableProcedure.CreateHdfsRegions.createHdfsRegions(MasterProcedureEnv env,
org.apache.hadoop.fs.Path tableRootDir,
TableName tableName,
List<RegionInfo> newRegions) |
Modifier and Type | Method and Description |
---|---|
protected static void |
AbstractStateMachineTableProcedure.checkOnline(MasterProcedureEnv env,
RegionInfo ri)
Check region is online.
|
protected org.apache.hadoop.fs.Path |
AbstractStateMachineTableProcedure.getWALRegionDir(MasterProcedureEnv env,
RegionInfo region) |
protected void |
AbstractStateMachineRegionProcedure.setRegion(RegionInfo hri)
Used when deserializing.
|
boolean |
MasterProcedureScheduler.waitRegion(Procedure<?> procedure,
RegionInfo regionInfo)
Suspend the procedure if the specified region is already locked.
|
boolean |
MasterProcedureScheduler.waitRegions(Procedure<?> procedure,
TableName table,
RegionInfo... regionInfo)
Suspend the procedure if the specified set of regions are already locked.
|
void |
MasterProcedureScheduler.wakeRegion(Procedure<?> procedure,
RegionInfo regionInfo)
Wake the procedures waiting for the specified region
|
void |
MasterProcedureScheduler.wakeRegions(Procedure<?> procedure,
TableName table,
RegionInfo... regionInfo)
Wake the procedures waiting for the specified regions
|
Modifier and Type | Method and Description |
---|---|
protected static List<RegionInfo> |
CreateTableProcedure.addTableToMeta(MasterProcedureEnv env,
TableDescriptor tableDescriptor,
List<RegionInfo> regions) |
protected static List<RegionInfo> |
CreateTableProcedure.createFsLayout(MasterProcedureEnv env,
TableDescriptor tableDescriptor,
List<RegionInfo> newRegions) |
protected static List<RegionInfo> |
CreateTableProcedure.createFsLayout(MasterProcedureEnv env,
TableDescriptor tableDescriptor,
List<RegionInfo> newRegions,
CreateTableProcedure.CreateHdfsRegions hdfsRegionHandler) |
List<RegionInfo> |
CreateTableProcedure.CreateHdfsRegions.createHdfsRegions(MasterProcedureEnv env,
org.apache.hadoop.fs.Path tableRootDir,
TableName tableName,
List<RegionInfo> newRegions) |
static void |
MasterDDLOperationHelper.deleteColumnFamilyFromFileSystem(MasterProcedureEnv env,
TableName tableName,
List<RegionInfo> regionInfoList,
byte[] familyName,
boolean hasMob)
Remove the column family from the file system
|
protected static void |
DeleteTableProcedure.deleteFromFs(MasterProcedureEnv env,
TableName tableName,
List<RegionInfo> regions,
boolean archive) |
protected static void |
DeleteTableProcedure.deleteFromMeta(MasterProcedureEnv env,
TableName tableName,
List<RegionInfo> regions) |
protected static void |
ProcedureSyncWait.waitRegionInTransition(MasterProcedureEnv env,
List<RegionInfo> regions) |
Constructor and Description |
---|
AbstractStateMachineRegionProcedure(MasterProcedureEnv env,
RegionInfo hri) |
CreateTableProcedure(MasterProcedureEnv env,
TableDescriptor tableDescriptor,
RegionInfo[] newRegions) |
CreateTableProcedure(MasterProcedureEnv env,
TableDescriptor tableDescriptor,
RegionInfo[] newRegions,
ProcedurePrepareLatch syncLatch) |
RegionCloseOperation(RemoteProcedureDispatcher.RemoteProcedure remoteProcedure,
RegionInfo regionInfo,
ServerName destinationServer) |
RegionOpenOperation(RemoteProcedureDispatcher.RemoteProcedure remoteProcedure,
RegionInfo regionInfo,
List<ServerName> favoredNodes,
boolean openForReplay) |
RegionOperation(RemoteProcedureDispatcher.RemoteProcedure remoteProcedure,
RegionInfo regionInfo) |
Modifier and Type | Method and Description |
---|---|
protected void |
TakeSnapshotHandler.snapshotDisabledRegion(RegionInfo regionInfo)
Take a snapshot of the specified disabled region
|
Modifier and Type | Method and Description |
---|---|
protected void |
EnabledTableSnapshotHandler.snapshotRegions(List<Pair<RegionInfo,ServerName>> regions)
This method kicks off a snapshot procedure.
|
void |
DisabledTableSnapshotHandler.snapshotRegions(List<Pair<RegionInfo,ServerName>> regionsAndLocations) |
protected abstract void |
TakeSnapshotHandler.snapshotRegions(List<Pair<RegionInfo,ServerName>> regions)
Snapshot the specified regions
|
Modifier and Type | Method and Description |
---|---|
static RegionInfo |
MobUtils.getMobRegionInfo(TableName tableName)
Gets the RegionInfo of the mob files.
|
Modifier and Type | Method and Description |
---|---|
static boolean |
MobUtils.isMobRegionInfo(RegionInfo regionInfo)
Gets whether the current RegionInfo is a mob one.
|
Modifier and Type | Method and Description |
---|---|
void |
NamespaceAuditor.checkQuotaToSplitRegion(RegionInfo hri) |
void |
NamespaceAuditor.removeRegionFromNamespaceUsage(RegionInfo hri) |
void |
NamespaceAuditor.updateQuotaForRegionMerge(RegionInfo mergedRegion) |
Modifier and Type | Method and Description |
---|---|
Iterable<Map.Entry<RegionInfo,Long>> |
NamespaceQuotaSnapshotStore.filterBySubject(String namespace) |
Iterable<Map.Entry<RegionInfo,Long>> |
QuotaSnapshotStore.filterBySubject(T subject)
Filters the provided
regions , returning those which match the given
subject . |
Iterable<Map.Entry<RegionInfo,Long>> |
TableQuotaSnapshotStore.filterBySubject(TableName table) |
Map<RegionInfo,Long> |
MasterQuotaManager.snapshotRegionSizes() |
Modifier and Type | Method and Description |
---|---|
void |
MasterQuotaManager.addRegionSize(RegionInfo hri,
long size,
long time) |
void |
MasterQuotaManager.onRegionMerged(RegionInfo mergedRegion) |
void |
MasterQuotaManager.onRegionSplit(RegionInfo hri) |
void |
MasterQuotaManager.onRegionSplitReverted(RegionInfo hri) |
Modifier and Type | Method and Description |
---|---|
void |
NamespaceQuotaSnapshotStore.setRegionUsage(Map<RegionInfo,Long> regionUsage) |
void |
TableQuotaSnapshotStore.setRegionUsage(Map<RegionInfo,Long> regionUsage) |
void |
QuotaSnapshotStore.setRegionUsage(Map<RegionInfo,Long> regionUsage)
Updates
this with the latest snapshot of filesystem use by region. |
Constructor and Description |
---|
NamespaceQuotaSnapshotStore(Connection conn,
QuotaObserverChore chore,
Map<RegionInfo,Long> regionUsage) |
TableQuotaSnapshotStore(Connection conn,
QuotaObserverChore chore,
Map<RegionInfo,Long> regionUsage) |
Modifier and Type | Method and Description |
---|---|
RegionInfo[] |
RegionServerServices.RegionStateTransitionContext.getHris() |
protected RegionInfo[] |
HRegionServer.getMostLoadedRegions()
Get the top N most loaded regions this server is serving so we can tell the
master which regions it can reallocate if we're overloaded.
|
RegionInfo |
HRegionFileSystem.getRegionInfo() |
RegionInfo |
RegionServicesForStores.getRegionInfo() |
RegionInfo |
Store.getRegionInfo() |
RegionInfo |
HStore.getRegionInfo() |
RegionInfo |
RegionScanner.getRegionInfo() |
RegionInfo |
HRegion.getRegionInfo() |
RegionInfo |
Region.getRegionInfo() |
RegionInfo |
HRegionFileSystem.getRegionInfoForFS() |
static RegionInfo |
HRegionFileSystem.loadRegionInfoFileContent(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path regionDir)
Create a
RegionInfo from the serialized version on-disk. |
Modifier and Type | Method and Description |
---|---|
void |
HRegionFileSystem.cleanupMergedRegion(RegionInfo mergedRegion)
Remove merged region
|
org.apache.hadoop.fs.Path |
HRegionFileSystem.commitDaughterRegion(RegionInfo regionInfo)
Commit a daughter region, moving it from the split temporary directory
to the proper location in the filesystem.
|
void |
HRegionFileSystem.commitMergedRegion(RegionInfo mergedRegionInfo)
Commit a merged region, moving it from the merges temporary directory to
the proper location in the filesystem.
|
static HDFSBlocksDistribution |
HRegion.computeHDFSBlocksDistribution(org.apache.hadoop.conf.Configuration conf,
TableDescriptor tableDescriptor,
RegionInfo regionInfo)
This is a helper function to compute HDFS block distribution on demand
|
static HDFSBlocksDistribution |
HRegion.computeHDFSBlocksDistribution(org.apache.hadoop.conf.Configuration conf,
TableDescriptor tableDescriptor,
RegionInfo regionInfo,
org.apache.hadoop.fs.Path tablePath)
This is a helper function to compute HDFS block distribution on demand
|
static HRegion |
HRegion.createHRegion(RegionInfo info,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.conf.Configuration conf,
TableDescriptor hTableDescriptor,
WAL wal) |
static HRegion |
HRegion.createHRegion(RegionInfo info,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.conf.Configuration conf,
TableDescriptor hTableDescriptor,
WAL wal,
boolean initialize)
Convenience method creating new HRegions.
|
static HRegionFileSystem |
HRegionFileSystem.createRegionOnFileSystem(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path tableDir,
RegionInfo regionInfo)
Create a new Region on file-system.
|
void |
HRegionFileSystem.createSplitsDir(RegionInfo daughterA,
RegionInfo daughterB)
Create the region splits directory.
|
static void |
HRegionFileSystem.deleteRegionFromFileSystem(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path tableDir,
RegionInfo regionInfo)
Remove the region from the table directory, archiving the region's hfiles.
|
org.apache.hadoop.fs.Path |
HRegionFileSystem.getSplitsDir(RegionInfo hri) |
static org.apache.hadoop.fs.Path |
HStore.getStoreHomedir(org.apache.hadoop.fs.Path tabledir,
RegionInfo hri,
byte[] family)
Deprecated.
|
WAL |
RegionServerServices.getWAL(RegionInfo regionInfo) |
WAL |
HRegionServer.getWAL(RegionInfo regionInfo) |
org.apache.hadoop.fs.Path |
HRegionFileSystem.mergeStoreFile(RegionInfo mergedRegion,
String familyName,
HStoreFile f,
org.apache.hadoop.fs.Path mergedDir)
Write out a merge reference under the given merges directory.
|
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,
RegionInfo info,
TableDescriptor 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,
RegionInfo info,
TableDescriptor 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,
RegionInfo info,
TableDescriptor htd,
WAL wal,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region.
|
static HRegion |
HRegion.openHRegion(org.apache.hadoop.fs.Path rootDir,
RegionInfo info,
TableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf)
Open a Region.
|
static HRegion |
HRegion.openHRegion(org.apache.hadoop.fs.Path rootDir,
RegionInfo info,
TableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region.
|
static HRegion |
HRegion.openHRegion(RegionInfo info,
TableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf)
Open a Region.
|
static HRegion |
HRegion.openHRegion(RegionInfo info,
TableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region.
|
static HRegion |
HRegion.openReadOnlyFileSystemHRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path tableDir,
RegionInfo info,
TableDescriptor htd)
Open a Region on a read-only file-system (like hdfs snapshots)
|
static HRegionFileSystem |
HRegionFileSystem.openRegionFromFileSystem(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path tableDir,
RegionInfo regionInfo,
boolean readOnly)
Open Region from file-system.
|
void |
RegionCoprocessorHost.postReplayWALs(RegionInfo info,
org.apache.hadoop.fs.Path edits) |
void |
RegionCoprocessorHost.postWALRestore(RegionInfo info,
WALKey logKey,
WALEdit logEdit)
Deprecated.
Since hbase-2.0.0. No replacement. To be removed in hbase-3.0.0 and replaced
with something that doesn't expose IntefaceAudience.Private classes.
|
void |
RegionCoprocessorHost.preReplayWALs(RegionInfo info,
org.apache.hadoop.fs.Path edits) |
boolean |
RegionCoprocessorHost.preWALRestore(RegionInfo info,
WALKey logKey,
WALEdit logEdit)
Deprecated.
Since hbase-2.0.0. No replacement. To be removed in hbase-3.0.0 and replaced
with something that doesn't expose IntefaceAudience.Private classes.
|
static boolean |
HRegion.rowIsInRange(RegionInfo info,
byte[] row)
Determines if the specified row is within the row range specified by the
specified RegionInfo
|
static boolean |
HRegion.rowIsInRange(RegionInfo info,
byte[] row,
int offset,
short length) |
org.apache.hadoop.fs.Path |
HRegionFileSystem.splitStoreFile(RegionInfo hri,
String familyName,
HStoreFile f,
byte[] splitRow,
boolean top,
RegionSplitPolicy splitPolicy)
Write out a split reference.
|
static void |
HRegion.warmupHRegion(RegionInfo info,
TableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices rsServices,
CancelableProgressable reporter) |
Modifier and Type | Method and Description |
---|---|
EntityLock |
RegionServerServices.regionLock(List<RegionInfo> regionInfos,
String description,
Abortable abort)
Master based locks on namespaces/tables/regions.
|
EntityLock |
HRegionServer.regionLock(List<RegionInfo> regionInfos,
String description,
Abortable abort) |
boolean |
HRegionServer.reportRegionSizesForQuotas(Map<RegionInfo,Long> onlineRegionSizes)
Reports the given map of Regions and their size on the filesystem to the active Master.
|
Constructor and Description |
---|
HRegion(org.apache.hadoop.fs.Path tableDir,
WAL wal,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.conf.Configuration confParam,
RegionInfo regionInfo,
TableDescriptor htd,
RegionServerServices rsServices)
Deprecated.
Use other constructors.
|
RegionStateTransitionContext(RegionServerStatusProtos.RegionStateTransition.TransitionCode code,
long openSeqNum,
long masterSystemTime,
RegionInfo... hris) |
Modifier and Type | Method and Description |
---|---|
RegionInfo |
CloseRegionHandler.getRegionInfo() |
RegionInfo |
OpenRegionHandler.getRegionInfo() |
Constructor and Description |
---|
CloseMetaHandler(Server server,
RegionServerServices rsServices,
RegionInfo regionInfo,
boolean abort) |
CloseRegionHandler(Server server,
RegionServerServices rsServices,
RegionInfo regionInfo,
boolean abort,
EventType eventType,
ServerName destination) |
CloseRegionHandler(Server server,
RegionServerServices rsServices,
RegionInfo regionInfo,
boolean abort,
ServerName destination)
This method used internally by the RegionServer to close out regions.
|
OpenMetaHandler(Server server,
RegionServerServices rsServices,
RegionInfo regionInfo,
TableDescriptor htd,
long masterSystemTime) |
OpenPriorityRegionHandler(Server server,
RegionServerServices rsServices,
RegionInfo regionInfo,
TableDescriptor htd,
long masterSystemTime) |
OpenRegionHandler(Server server,
RegionServerServices rsServices,
RegionInfo regionInfo,
TableDescriptor htd,
long masterSystemTime) |
OpenRegionHandler(Server server,
RegionServerServices rsServices,
RegionInfo regionInfo,
TableDescriptor htd,
long masterSystemTime,
EventType eventType) |
Modifier and Type | Method and Description |
---|---|
long |
FSHLog.append(RegionInfo hri,
WALKeyImpl key,
WALEdit edits,
boolean inMemstore) |
long |
AsyncFSWAL.append(RegionInfo hri,
WALKeyImpl key,
WALEdit edits,
boolean inMemstore) |
abstract long |
AbstractFSWAL.append(RegionInfo info,
WALKeyImpl key,
WALEdit edits,
boolean inMemstore)
NOTE: This append, at a time that is usually after this call returns, starts an mvcc
transaction by calling 'begin' wherein which we assign this update a sequenceid.
|
static WALKeyImpl |
WALUtil.doFullAppendTransaction(WAL wal,
NavigableMap<byte[],Integer> replicationScope,
RegionInfo hri,
WALEdit edit,
MultiVersionConcurrencyControl mvcc,
boolean sync)
A 'full' WAL transaction involves starting an mvcc transaction followed by an append,
an optional sync, and then a call to complete the mvcc transaction.
|
void |
WALCoprocessorHost.postWALWrite(RegionInfo info,
WALKey logKey,
WALEdit logEdit) |
void |
WALCoprocessorHost.preWALWrite(RegionInfo info,
WALKey logKey,
WALEdit logEdit) |
protected long |
AbstractFSWAL.stampSequenceIdAndPublishToRingBuffer(RegionInfo hri,
WALKeyImpl key,
WALEdit edits,
boolean inMemstore,
com.lmax.disruptor.RingBuffer<org.apache.hadoop.hbase.regionserver.wal.RingBufferTruck> ringBuffer) |
default void |
WALActionsListener.visitLogEntryBeforeWrite(RegionInfo info,
WALKey logKey,
WALEdit logEdit)
Called before each write.
|
static WALKeyImpl |
WALUtil.writeBulkLoadMarkerAndSync(WAL wal,
NavigableMap<byte[],Integer> replicationScope,
RegionInfo hri,
WALProtos.BulkLoadDescriptor desc,
MultiVersionConcurrencyControl mvcc)
Write a log marker that a bulk load has succeeded and is about to be committed.
|
static WALKeyImpl |
WALUtil.writeCompactionMarker(WAL wal,
NavigableMap<byte[],Integer> replicationScope,
RegionInfo hri,
WALProtos.CompactionDescriptor c,
MultiVersionConcurrencyControl mvcc)
Write the marker that a compaction has succeeded and is about to be committed.
|
static WALKeyImpl |
WALUtil.writeFlushMarker(WAL wal,
NavigableMap<byte[],Integer> replicationScope,
RegionInfo hri,
WALProtos.FlushDescriptor f,
boolean sync,
MultiVersionConcurrencyControl mvcc)
Write a flush marker indicating a start / abort or a complete of a region flush
|
static WALKeyImpl |
WALUtil.writeRegionEventMarker(WAL wal,
NavigableMap<byte[],Integer> replicationScope,
RegionInfo hri,
WALProtos.RegionEventDescriptor r,
MultiVersionConcurrencyControl mvcc)
Write a region open marker indicating that the region is opened.
|
Modifier and Type | Method and Description |
---|---|
Set<RegionInfo> |
RSGroupBasedLoadBalancer.getMisplacedRegions(Map<RegionInfo,ServerName> regions) |
Map<ServerName,List<RegionInfo>> |
RSGroupBasedLoadBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers) |
Map<ServerName,List<RegionInfo>> |
RSGroupBasedLoadBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers) |
Modifier and Type | Method and Description |
---|---|
void |
RSGroupAdminEndpoint.postCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableDescriptor desc,
RegionInfo[] regions) |
void |
RSGroupAdminEndpoint.preCreateTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableDescriptor desc,
RegionInfo[] regions) |
ServerName |
RSGroupBasedLoadBalancer.randomAssignment(RegionInfo region,
List<ServerName> servers) |
void |
RSGroupBasedLoadBalancer.regionOffline(RegionInfo regionInfo) |
void |
RSGroupBasedLoadBalancer.regionOnline(RegionInfo regionInfo,
ServerName sn) |
Modifier and Type | Method and Description |
---|---|
List<RegionPlan> |
RSGroupBasedLoadBalancer.balanceCluster(Map<ServerName,List<RegionInfo>> clusterState) |
List<RegionPlan> |
RSGroupBasedLoadBalancer.balanceCluster(TableName tableName,
Map<ServerName,List<RegionInfo>> clusterState) |
Set<RegionInfo> |
RSGroupBasedLoadBalancer.getMisplacedRegions(Map<RegionInfo,ServerName> regions) |
Map<ServerName,List<RegionInfo>> |
RSGroupBasedLoadBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers) |
Map<ServerName,List<RegionInfo>> |
RSGroupBasedLoadBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers) |
void |
RSGroupBasedLoadBalancer.setClusterLoad(Map<TableName,Map<ServerName,List<RegionInfo>>> clusterLoad) |
Modifier and Type | Method and Description |
---|---|
static RegionInfo |
ProtobufUtil.getRegionInfo(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
AdminProtos.AdminService.BlockingInterface admin,
byte[] regionName)
A helper to retrieve region info given a region name
using admin protocol.
|
static RegionInfo |
ProtobufUtil.toRegionInfo(HBaseProtos.RegionInfo proto)
Convert HBaseProto.RegionInfo to a RegionInfo
|
Modifier and Type | Method and Description |
---|---|
static List<RegionInfo> |
ProtobufUtil.getOnlineRegions(AdminProtos.AdminService.BlockingInterface admin)
A helper to get the all the online regions on a region
server using admin protocol.
|
static List<RegionInfo> |
ProtobufUtil.getOnlineRegions(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
AdminProtos.AdminService.BlockingInterface admin)
A helper to get the all the online regions on a region
server using admin protocol.
|
static List<RegionInfo> |
ResponseConverter.getRegionInfos(AdminProtos.GetOnlineRegionResponse proto)
Get the list of region info from a GetOnlineRegionResponse
|
static List<RegionInfo> |
ProtobufUtil.getRegionInfos(AdminProtos.GetOnlineRegionResponse proto)
Get the list of region info from a GetOnlineRegionResponse
|
Modifier and Type | Method and Description |
---|---|
static AdminProtos.OpenRegionRequest |
RequestConverter.buildOpenRegionRequest(ServerName server,
RegionInfo region,
List<ServerName> favoredNodes)
Create a protocol buffer OpenRegionRequest for a given region
|
static AdminProtos.OpenRegionRequest.RegionOpenInfo |
RequestConverter.buildRegionOpenInfo(RegionInfo region,
List<ServerName> favoredNodes)
Create a RegionOpenInfo based on given region info and version of offline node
|
static MasterProtos.SplitTableRegionRequest |
RequestConverter.buildSplitTableRegionRequest(RegionInfo regionInfo,
byte[] splitRow,
long nonceGroup,
long nonce) |
static AdminProtos.WarmupRegionRequest |
RequestConverter.buildWarmupRegionRequest(RegionInfo regionInfo)
Create a WarmupRegionRequest for a given region name
|
static void |
ProtobufUtil.openRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
AdminProtos.AdminService.BlockingInterface admin,
ServerName server,
RegionInfo region)
A helper to open a region using admin protocol.
|
static WALProtos.CompactionDescriptor |
ProtobufUtil.toCompactionDescriptor(RegionInfo info,
byte[] regionName,
byte[] family,
List<org.apache.hadoop.fs.Path> inputPaths,
List<org.apache.hadoop.fs.Path> outputPaths,
org.apache.hadoop.fs.Path storeDir) |
static WALProtos.CompactionDescriptor |
ProtobufUtil.toCompactionDescriptor(RegionInfo info,
byte[] family,
List<org.apache.hadoop.fs.Path> inputPaths,
List<org.apache.hadoop.fs.Path> outputPaths,
org.apache.hadoop.fs.Path storeDir) |
static WALProtos.FlushDescriptor |
ProtobufUtil.toFlushDescriptor(WALProtos.FlushDescriptor.FlushAction action,
RegionInfo hri,
long flushSeqId,
Map<byte[],List<org.apache.hadoop.fs.Path>> committedFiles) |
static WALProtos.RegionEventDescriptor |
ProtobufUtil.toRegionEventDescriptor(WALProtos.RegionEventDescriptor.EventType eventType,
RegionInfo hri,
long seqId,
ServerName server,
Map<byte[],List<org.apache.hadoop.fs.Path>> storeFiles) |
static HBaseProtos.RegionInfo |
ProtobufUtil.toRegionInfo(RegionInfo info)
Convert a RegionInfo to a Proto RegionInfo
|
static void |
ProtobufUtil.warmupRegion(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
AdminProtos.AdminService.BlockingInterface admin,
RegionInfo regionInfo)
A helper to warmup a region given a region name
using admin protocol
|
Modifier and Type | Method and Description |
---|---|
static AdminProtos.ClearRegionBlockCacheRequest |
RequestConverter.buildClearRegionBlockCacheRequest(List<RegionInfo> hris)
Creates a protocol buffer ClearRegionBlockCacheRequest
|
static AdminProtos.GetOnlineRegionResponse |
ResponseConverter.buildGetOnlineRegionResponse(List<RegionInfo> regions)
A utility to build a GetOnlineRegionResponse.
|
static AdminProtos.OpenRegionRequest |
RequestConverter.buildOpenRegionRequest(ServerName server,
List<Pair<RegionInfo,List<ServerName>>> regionOpenInfos)
Create a protocol buffer OpenRegionRequest to open a list of regions
|
static AdminProtos.UpdateFavoredNodesRequest |
RequestConverter.buildUpdateFavoredNodesRequest(List<Pair<RegionInfo,List<ServerName>>> updateRegionInfos)
Create a protocol buffer UpdateFavoredNodesRequest to update a list of favorednode mappings
|
Modifier and Type | Method and Description |
---|---|
RegionInfo |
RestoreSnapshotHelper.cloneRegionInfo(RegionInfo snapshotRegionInfo)
Create a new
RegionInfo from the snapshot region info. |
static RegionInfo |
RestoreSnapshotHelper.cloneRegionInfo(TableName tableName,
RegionInfo snapshotRegionInfo) |
Modifier and Type | Method and Description |
---|---|
List<RegionInfo> |
RestoreSnapshotHelper.RestoreMetaChanges.getRegionsToAdd()
Returns the list of new regions added during the on-disk restore.
|
List<RegionInfo> |
RestoreSnapshotHelper.RestoreMetaChanges.getRegionsToRemove()
Returns the list of regions removed during the on-disk restore.
|
List<RegionInfo> |
RestoreSnapshotHelper.RestoreMetaChanges.getRegionsToRestore()
Returns the list of 'restored regions' during the on-disk restore.
|
Modifier and Type | Method and Description |
---|---|
void |
SnapshotManifest.addMobRegion(RegionInfo regionInfo) |
protected void |
SnapshotManifest.addMobRegion(RegionInfo regionInfo,
org.apache.hadoop.hbase.snapshot.SnapshotManifest.RegionVisitor visitor) |
void |
SnapshotManifest.addRegion(org.apache.hadoop.fs.Path tableDir,
RegionInfo regionInfo)
Creates a 'manifest' for the specified region, by reading directly from the disk.
|
protected void |
SnapshotManifest.addRegion(org.apache.hadoop.fs.Path tableDir,
RegionInfo regionInfo,
org.apache.hadoop.hbase.snapshot.SnapshotManifest.RegionVisitor visitor) |
RegionInfo |
RestoreSnapshotHelper.cloneRegionInfo(RegionInfo snapshotRegionInfo)
Create a new
RegionInfo from the snapshot region info. |
static RegionInfo |
RestoreSnapshotHelper.cloneRegionInfo(TableName tableName,
RegionInfo snapshotRegionInfo) |
void |
SnapshotReferenceUtil.StoreFileVisitor.storeFile(RegionInfo regionInfo,
String familyName,
SnapshotProtos.SnapshotRegionManifest.StoreFile storeFile) |
Modifier and Type | Method and Description |
---|---|
void |
RestoreSnapshotHelper.RestoreMetaChanges.updateMetaParentRegions(Connection connection,
List<RegionInfo> regionInfos) |
Modifier and Type | Method and Description |
---|---|
List<RegionInfo> |
RegionListTmpl.ImplData.getOnlineRegions() |
Modifier and Type | Method and Description |
---|---|
org.jamon.Renderer |
RegionListTmpl.makeRenderer(HRegionServer regionServer,
List<RegionInfo> onlineRegions) |
void |
RegionListTmpl.render(Writer jamonWriter,
HRegionServer regionServer,
List<RegionInfo> onlineRegions) |
void |
RegionListTmpl.renderNoFlush(Writer jamonWriter,
HRegionServer regionServer,
List<RegionInfo> onlineRegions) |
void |
RegionListTmpl.ImplData.setOnlineRegions(List<RegionInfo> onlineRegions) |
Modifier and Type | Method and Description |
---|---|
void |
Canary.RegionStdOutSink.publishReadFailure(ServerName serverName,
RegionInfo region,
ColumnFamilyDescriptor column,
Exception e) |
void |
Canary.RegionStdOutSink.publishReadFailure(ServerName serverName,
RegionInfo region,
Exception e) |
void |
Canary.RegionStdOutSink.publishReadTiming(ServerName serverName,
RegionInfo region,
ColumnFamilyDescriptor column,
long msTime) |
void |
Canary.RegionStdOutSink.publishWriteFailure(ServerName serverName,
RegionInfo region,
ColumnFamilyDescriptor column,
Exception e) |
void |
Canary.RegionStdOutSink.publishWriteFailure(ServerName serverName,
RegionInfo region,
Exception e) |
void |
Canary.RegionStdOutSink.publishWriteTiming(ServerName serverName,
RegionInfo region,
ColumnFamilyDescriptor column,
long msTime) |
Modifier and Type | Method and Description |
---|---|
static RegionInfo |
ModifyRegionUtils.createRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
TableDescriptor tableDescriptor,
RegionInfo newRegion,
ModifyRegionUtils.RegionFillTask task)
Create new set of regions on the specified file-system.
|
static RegionInfo[] |
ModifyRegionUtils.createRegionInfos(TableDescriptor tableDescriptor,
byte[][] splitKeys) |
RegionInfo |
HBaseFsck.HbckInfo.getPrimaryHRIForDeployedReplica() |
static RegionInfo |
ServerRegionReplicaUtil.getRegionInfoForFs(RegionInfo regionInfo)
Returns the regionInfo object to use for interacting with the file system.
|
Modifier and Type | Method and Description |
---|---|
static List<RegionInfo> |
ModifyRegionUtils.createRegions(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
TableDescriptor tableDescriptor,
RegionInfo[] newRegions,
ModifyRegionUtils.RegionFillTask task)
Create new set of regions on the specified file-system.
|
static List<RegionInfo> |
ModifyRegionUtils.createRegions(ThreadPoolExecutor exec,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
TableDescriptor tableDescriptor,
RegionInfo[] newRegions,
ModifyRegionUtils.RegionFillTask task)
Create new set of regions on the specified file-system.
|
org.apache.hbase.thirdparty.com.google.common.collect.ImmutableList<RegionInfo> |
HBaseFsck.TableInfo.getRegionsFromMeta() |
Modifier and Type | Method and Description |
---|---|
void |
HBaseFsck.HbckInfo.addServer(RegionInfo hri,
ServerName server) |
static void |
HBaseFsckRepair.closeRegionSilentlyAndWait(Connection connection,
ServerName server,
RegionInfo region)
Contacts a region server and waits up to hbase.hbck.close.timeout ms
(default 120s) to close the region.
|
static HRegion |
HBaseFsckRepair.createHDFSRegionDir(org.apache.hadoop.conf.Configuration conf,
RegionInfo hri,
TableDescriptor htd)
Creates, flushes, and closes a new region.
|
static RegionInfo |
ModifyRegionUtils.createRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
TableDescriptor tableDescriptor,
RegionInfo newRegion,
ModifyRegionUtils.RegionFillTask task)
Create new set of regions on the specified file-system.
|
static List<RegionInfo> |
ModifyRegionUtils.createRegions(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
TableDescriptor tableDescriptor,
RegionInfo[] newRegions,
ModifyRegionUtils.RegionFillTask task)
Create new set of regions on the specified file-system.
|
static List<RegionInfo> |
ModifyRegionUtils.createRegions(ThreadPoolExecutor exec,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
TableDescriptor tableDescriptor,
RegionInfo[] newRegions,
ModifyRegionUtils.RegionFillTask task)
Create new set of regions on the specified file-system.
|
void |
ModifyRegionUtils.RegionEditTask.editRegion(RegionInfo region) |
static void |
HBaseFsckRepair.fixMetaHoleOnlineAndAddReplicas(org.apache.hadoop.conf.Configuration conf,
RegionInfo hri,
Collection<ServerName> servers,
int numReplicas)
Puts the specified RegionInfo into META with replica related columns
|
static void |
HBaseFsckRepair.fixMultiAssignment(Connection connection,
RegionInfo region,
List<ServerName> servers)
Fix multiple assignment by doing silent closes on each RS hosting the region
and then force ZK unassigned node to OFFLINE to trigger assignment by
master.
|
static void |
HBaseFsckRepair.fixUnassigned(Admin admin,
RegionInfo region)
Fix unassigned by creating/transition the unassigned ZK node for this
region to OFFLINE state with a special flag to tell the master that this is
a forced operation by HBCK.
|
static org.apache.hadoop.fs.Path |
FSUtils.getRegionDirFromRootDir(org.apache.hadoop.fs.Path rootDir,
RegionInfo region) |
static org.apache.hadoop.fs.Path |
FSUtils.getRegionDirFromTableDir(org.apache.hadoop.fs.Path tableDir,
RegionInfo region) |
static RegionInfo |
ServerRegionReplicaUtil.getRegionInfoForFs(RegionInfo regionInfo)
Returns the regionInfo object to use for interacting with the file system.
|
static org.apache.hadoop.fs.Path |
HFileArchiveUtil.getStoreArchivePath(org.apache.hadoop.conf.Configuration conf,
RegionInfo region,
byte[] family)
Gets the directory to archive a store directory.
|
static org.apache.hadoop.fs.Path |
HFileArchiveUtil.getStoreArchivePath(org.apache.hadoop.conf.Configuration conf,
RegionInfo region,
org.apache.hadoop.fs.Path tabledir,
byte[] family)
Get the directory to archive a store directory
|
static StoreFileInfo |
ServerRegionReplicaUtil.getStoreFileInfo(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
RegionInfo regionInfo,
RegionInfo regionInfoForFs,
String familyName,
org.apache.hadoop.fs.Path path)
Returns a StoreFileInfo from the given FileStatus.
|
static void |
HBaseFsckRepair.removeParentInMeta(org.apache.hadoop.conf.Configuration conf,
RegionInfo hri) |
static void |
HBaseFsckRepair.waitUntilAssigned(Admin admin,
RegionInfo region) |
Modifier and Type | Method and Description |
---|---|
static void |
ModifyRegionUtils.editRegions(ThreadPoolExecutor exec,
Collection<RegionInfo> regions,
ModifyRegionUtils.RegionEditTask task)
Execute the task on the specified set of regions.
|
Modifier and Type | Method and Description |
---|---|
long |
WAL.append(RegionInfo info,
WALKeyImpl key,
WALEdit edits,
boolean inMemstore)
Append a set of edits to the WAL.
|
static WALEdit |
WALEdit.createBulkLoadEvent(RegionInfo hri,
WALProtos.BulkLoadDescriptor bulkLoadDescriptor)
Create a bulk loader WALEdit
|
static WALEdit |
WALEdit.createCompaction(RegionInfo hri,
WALProtos.CompactionDescriptor c)
Create a compaction WALEdit
|
static WALEdit |
WALEdit.createFlushWALEdit(RegionInfo hri,
WALProtos.FlushDescriptor f) |
static WALEdit |
WALEdit.createRegionEventWALEdit(RegionInfo hri,
WALProtos.RegionEventDescriptor regionEventDesc) |
static long |
WALSplitter.getMaxRegionSequenceId(org.apache.hadoop.conf.Configuration conf,
RegionInfo region,
CollectionUtils.IOExceptionSupplier<org.apache.hadoop.fs.FileSystem> rootFsSupplier,
CollectionUtils.IOExceptionSupplier<org.apache.hadoop.fs.FileSystem> walFsSupplier)
Deprecated.
Only for compatibility, will be removed in 4.0.0.
|
static byte[] |
WALEdit.getRowForRegion(RegionInfo hri) |
WAL |
RegionGroupingProvider.getWAL(RegionInfo region) |
T |
AbstractFSWALProvider.getWAL(RegionInfo region) |
WAL |
WALFactory.getWAL(RegionInfo region) |
WAL |
WALProvider.getWAL(RegionInfo region) |
static boolean |
WALSplitter.hasRecoveredEdits(org.apache.hadoop.conf.Configuration conf,
RegionInfo regionInfo)
Check whether there is recovered.edits in the region dir
|
Modifier and Type | Method and Description |
---|---|
List<RegionInfo> |
MetaTableLocator.getMetaRegions(ZKWatcher zkw)
Gets the meta regions for the given path with the default replica ID.
|
List<RegionInfo> |
MetaTableLocator.getMetaRegions(ZKWatcher zkw,
int replicaId)
Gets the meta regions for the given path and replica ID.
|
List<Pair<RegionInfo,ServerName>> |
MetaTableLocator.getMetaRegionsAndLocations(ZKWatcher zkw) |
List<Pair<RegionInfo,ServerName>> |
MetaTableLocator.getMetaRegionsAndLocations(ZKWatcher zkw,
int replicaId)
Gets the meta regions and their locations for the given path and replica ID.
|
Copyright © 2007–2019 Cloudera. All rights reserved.