Modifier and Type | Field and Description |
---|---|
static HRegionInfo |
HRegionInfo.FIRST_META_REGIONINFO
HRegionInfo for first meta region
|
private HRegionInfo |
HRegionLocation.regionInfo |
Modifier and Type | Method and Description |
---|---|
static HRegionInfo |
HRegionInfo.convert(org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo proto)
Convert a RegionInfo to a HRegionInfo
|
static HRegionInfo |
MetaTableAccessor.getHRegionInfo(Result data)
Returns HRegionInfo object from the column
HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog
table Result.
|
static HRegionInfo |
HRegionInfo.getHRegionInfo(Result data)
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
|
private static HRegionInfo |
MetaTableAccessor.getHRegionInfo(Result r,
byte[] qualifier)
Returns the HRegionInfo object from the column
HConstants.CATALOG_FAMILY and
qualifier of the catalog table result. |
static HRegionInfo |
HRegionInfo.getHRegionInfo(Result r,
byte[] qualifier)
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
|
HRegionInfo |
HRegionLocation.getRegionInfo() |
static HRegionInfo |
HRegionInfo.parseFrom(byte[] bytes) |
(package private) static HRegionInfo |
MetaMigrationConvertingToPB.parseFrom(byte[] hriBytes)
Deprecated.
|
static HRegionInfo |
HRegionInfo.parseFrom(byte[] bytes,
int offset,
int len) |
static HRegionInfo |
HRegionInfo.parseFrom(DataInputStream in)
Parses an HRegionInfo instance from the passed in stream.
|
static HRegionInfo |
HRegionInfo.parseFromOrNull(byte[] bytes) |
static HRegionInfo |
HRegionInfo.parseFromOrNull(byte[] bytes,
int offset,
int len) |
protected static HRegionInfo |
MetaTableAccessor.parseRegionInfoFromRegionName(byte[] regionName)
Returns an HRI parsed from this regionName.
|
Modifier and Type | Method and Description |
---|---|
static PairOfSameType<HRegionInfo> |
MetaTableAccessor.getDaughterRegions(Result data)
Returns the daughter regions by reading the corresponding columns of the catalog table
Result.
|
static PairOfSameType<HRegionInfo> |
HRegionInfo.getDaughterRegions(Result data)
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
|
static Pair<HRegionInfo,ServerName> |
HRegionInfo.getHRegionInfoAndServerName(Result r)
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
|
(package private) static List<HRegionInfo> |
MetaTableAccessor.getListOfHRegionInfos(List<Pair<HRegionInfo,ServerName>> pairs) |
static PairOfSameType<HRegionInfo> |
MetaTableAccessor.getMergeRegions(Result data)
Returns the merge regions by reading the corresponding columns of the catalog table
Result.
|
static PairOfSameType<HRegionInfo> |
HRegionInfo.getMergeRegions(Result data)
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
|
static Pair<HRegionInfo,ServerName> |
MetaTableAccessor.getRegion(Connection connection,
byte[] regionName)
Deprecated.
|
static Pair<HRegionInfo,HRegionInfo> |
MetaTableAccessor.getRegionsFromMergeQualifier(Connection connection,
byte[] regionName)
Get regions from the merge qualifier of the specified merged region
|
static Pair<HRegionInfo,HRegionInfo> |
MetaTableAccessor.getRegionsFromMergeQualifier(Connection connection,
byte[] regionName)
Get regions from the merge qualifier of the specified merged region
|
static NavigableMap<HRegionInfo,Result> |
MetaTableAccessor.getServerUserRegions(Connection connection,
ServerName serverName) |
static List<HRegionInfo> |
MetaTableAccessor.getTableRegions(ZooKeeperWatcher zkw,
Connection connection,
TableName tableName)
Gets all of the regions of the specified table.
|
static List<HRegionInfo> |
MetaTableAccessor.getTableRegions(ZooKeeperWatcher zkw,
Connection connection,
TableName tableName,
boolean excludeOfflinedSplitParents)
Gets all of the regions of the specified table.
|
static List<Pair<HRegionInfo,ServerName>> |
MetaTableAccessor.getTableRegionsAndLocations(ZooKeeperWatcher zkw,
Connection connection,
TableName tableName) |
static List<Pair<HRegionInfo,ServerName>> |
MetaTableAccessor.getTableRegionsAndLocations(ZooKeeperWatcher zkw,
Connection connection,
TableName tableName,
boolean excludeOfflinedSplitParents) |
static List<HRegionInfo> |
HRegionInfo.parseDelimitedFrom(byte[] bytes,
int offset,
int length)
Parses all the HRegionInfo instances from the passed in stream until EOF.
|
Modifier and Type | Method and Description |
---|---|
static void |
MetaTableAccessor.addDaughter(Connection connection,
HRegionInfo regionInfo,
ServerName sn,
long openSeqNum)
Adds a daughter region entry to meta.
|
static Put |
MetaTableAccessor.addDaughtersToPut(Put put,
HRegionInfo splitA,
HRegionInfo splitB)
Adds split daughters to the Put
|
private static Put |
MetaTableAccessor.addRegionInfo(Put p,
HRegionInfo hri) |
static void |
MetaTableAccessor.addRegionToMeta(Connection connection,
HRegionInfo regionInfo)
Adds a hbase:meta row for the specified new region.
|
static void |
MetaTableAccessor.addRegionToMeta(Connection connection,
HRegionInfo regionInfo,
HRegionInfo splitA,
HRegionInfo splitB)
Adds a (single) hbase:meta row for the specified new region and its daughters.
|
static void |
MetaTableAccessor.addRegionToMeta(Table meta,
HRegionInfo regionInfo)
Adds a hbase:meta row for the specified new region to the given catalog table.
|
static void |
MetaTableAccessor.addRegionToMeta(Table meta,
HRegionInfo regionInfo,
HRegionInfo splitA,
HRegionInfo splitB)
Adds a (single) hbase:meta row for the specified new region and its daughters.
|
static boolean |
HRegionInfo.areAdjacent(HRegionInfo regionA,
HRegionInfo regionB)
Check whether two regions are adjacent
|
int |
HRegionInfo.compareTo(HRegionInfo o) |
static org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo |
HRegionInfo.convert(HRegionInfo info)
Convert a HRegionInfo to a RegionInfo
|
static void |
MetaTableAccessor.deleteMergeQualifiers(Connection connection,
HRegionInfo mergedRegion)
Deletes merge qualifiers for the specified merged region.
|
static void |
MetaTableAccessor.deleteRegion(Connection connection,
HRegionInfo regionInfo)
Deletes the specified region from META.
|
static byte[] |
MetaTableAccessor.getMetaKeyForRegion(HRegionInfo regionInfo)
Returns the row key to use for this regionInfo
|
static HRegionLocation |
MetaTableAccessor.getRegionLocation(Connection connection,
HRegionInfo regionInfo)
Returns the HRegionLocation from meta for the given region
|
private static HRegionLocation |
MetaTableAccessor.getRegionLocation(Result r,
HRegionInfo regionInfo,
int replicaId)
Returns the HRegionLocation parsed from the given meta row Result
for the given regionInfo and replicaId.
|
(package private) static boolean |
MetaTableAccessor.isInsideTable(HRegionInfo current,
TableName tableName) |
static Delete |
MetaTableAccessor.makeDeleteFromRegionInfo(HRegionInfo regionInfo)
Generates and returns a Delete containing the region info for the catalog
table
|
static Delete |
MetaTableAccessor.makeDeleteFromRegionInfo(HRegionInfo regionInfo,
long ts)
Generates and returns a Delete containing the region info for the catalog
table
|
static Put |
MetaTableAccessor.makePutFromRegionInfo(HRegionInfo regionInfo)
Generates and returns a Put containing the region into for the catalog table
|
static Put |
MetaTableAccessor.makePutFromRegionInfo(HRegionInfo regionInfo,
long ts)
Generates and returns a Put containing the region into for the catalog table
|
static void |
MetaTableAccessor.mergeRegions(Connection connection,
HRegionInfo mergedRegion,
HRegionInfo regionA,
HRegionInfo regionB,
ServerName sn,
int regionReplication,
long masterSystemTime)
Merge the two regions into one in an atomic operation.
|
void |
RegionStateListener.onRegionMerged(HRegionInfo hri)
Process region merge event.
|
void |
RegionStateListener.onRegionSplit(HRegionInfo hri)
Process region split event.
|
void |
RegionStateListener.onRegionSplitReverted(HRegionInfo hri)
Process region split reverted event.
|
static void |
MetaTableAccessor.splitRegion(Connection connection,
HRegionInfo parent,
HRegionInfo splitA,
HRegionInfo splitB,
ServerName sn,
int regionReplication)
Splits the region into two in an atomic operation.
|
static byte[] |
HRegionInfo.toDelimitedByteArray(HRegionInfo... infos)
Serializes given HRegionInfo's as a byte array.
|
private static void |
MetaTableAccessor.updateLocation(Connection connection,
HRegionInfo regionInfo,
ServerName sn,
long openSeqNum,
long masterSystemTime)
Updates the location of the specified region to be the specified server.
|
static void |
MetaTableAccessor.updateRegionLocation(Connection connection,
HRegionInfo 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<HRegionInfo> regionInfos,
int regionReplication)
Adds a hbase:meta row for each of the specified new regions.
|
static void |
MetaTableAccessor.addRegionsToMeta(Connection connection,
List<HRegionInfo> regionInfos,
int regionReplication,
long ts)
Adds a hbase:meta row for each of the specified new regions.
|
static void |
MetaTableAccessor.deleteRegions(Connection connection,
List<HRegionInfo> regionsInfo)
Deletes the specified regions from META.
|
static void |
MetaTableAccessor.deleteRegions(Connection connection,
List<HRegionInfo> regionsInfo,
long ts)
Deletes the specified regions from META.
|
(package private) static List<HRegionInfo> |
MetaTableAccessor.getListOfHRegionInfos(List<Pair<HRegionInfo,ServerName>> pairs) |
static void |
MetaTableAccessor.mutateRegions(Connection connection,
List<HRegionInfo> regionsToRemove,
List<HRegionInfo> regionsToAdd)
Adds and Removes the specified regions from hbase:meta
|
static void |
MetaTableAccessor.mutateRegions(Connection connection,
List<HRegionInfo> regionsToRemove,
List<HRegionInfo> regionsToAdd)
Adds and Removes the specified regions from hbase:meta
|
static void |
MetaTableAccessor.overwriteRegions(Connection connection,
List<HRegionInfo> regionInfos,
int regionReplication)
Overwrites the specified regions from hbase:meta
|
Constructor and Description |
---|
HRegionInfo(HRegionInfo other)
Costruct a copy of another HRegionInfo
|
HRegionInfo(HRegionInfo other,
int replicaId) |
HRegionLocation(HRegionInfo regionInfo,
ServerName serverName) |
HRegionLocation(HRegionInfo 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,
HRegionInfo 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.archiveRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
HRegionInfo 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,
HRegionInfo 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,
HRegionInfo regionInfo,
org.apache.hadoop.fs.Path tableDir,
byte[] family,
Collection<StoreFile> compactedFiles)
Remove the store files, either by archiving them or outright deletion
|
Modifier and Type | Class and Description |
---|---|
(package private) class |
UnmodifyableHRegionInfo |
Modifier and Type | Field and Description |
---|---|
protected HRegionInfo |
ClientScanner.currentRegion |
HRegionInfo |
HTableMultiplexer.PutStatus.regionInfo |
Modifier and Type | Field and Description |
---|---|
private ArrayList<HRegionInfo> |
TableSnapshotScanner.regions |
Modifier and Type | Method and Description |
---|---|
HRegionInfo |
RegionServerCallable.getHRegionInfo() |
HRegionInfo |
ScannerCallable.getHRegionInfo() |
HRegionInfo |
ScannerCallableWithReplicas.getHRegionInfo() |
HRegionInfo |
MultiServerCallable.getHRegionInfo() |
static HRegionInfo |
MetaScanner.getHRegionInfo(Result data)
Deprecated.
|
static HRegionInfo |
RegionReplicaUtil.getRegionInfoForDefaultReplica(HRegionInfo regionInfo)
Returns the HRegionInfo for the default replicaId (0).
|
static HRegionInfo |
RegionReplicaUtil.getRegionInfoForReplica(HRegionInfo regionInfo,
int replicaId)
Returns the HRegionInfo for the given replicaId.
|
Modifier and Type | Method and Description |
---|---|
static NavigableMap<HRegionInfo,ServerName> |
MetaScanner.allTableRegions(org.apache.hadoop.conf.Configuration conf,
Connection connection,
TableName tableName,
boolean offlined)
Deprecated.
|
static NavigableMap<HRegionInfo,ServerName> |
MetaScanner.allTableRegions(Connection connection,
TableName tableName)
Lists all of the table regions currently in META.
|
List<HRegionInfo> |
HBaseAdmin.getOnlineRegions(ServerName sn)
Get all the online regions on a region server.
|
List<HRegionInfo> |
Admin.getOnlineRegions(ServerName sn)
Get all the online regions on a region server.
|
(package private) Pair<HRegionInfo,ServerName> |
HBaseAdmin.getRegion(byte[] regionName) |
NavigableMap<HRegionInfo,ServerName> |
HTable.getRegionLocations()
Deprecated.
This is no longer a public API. Use
HTable.getAllRegionLocations() instead. |
List<HRegionInfo> |
HBaseAdmin.getTableRegions(byte[] tableName) |
List<HRegionInfo> |
HBaseAdmin.getTableRegions(TableName tableName)
get the regions of a given table.
|
List<HRegionInfo> |
Admin.getTableRegions(TableName tableName)
Get the regions of a given table.
|
static List<HRegionInfo> |
MetaScanner.listAllRegions(org.apache.hadoop.conf.Configuration conf,
Connection connection,
boolean offlined)
Lists all of the regions currently in META.
|
Modifier and Type | Method and Description |
---|---|
void |
MetaCache.clearCache(HRegionInfo hri)
Deletes the cached location of the region if necessary, based on some error from source.
|
void |
HBaseAdmin.closeRegion(ServerName sn,
HRegionInfo hri)
Close a region.
|
void |
Admin.closeRegion(ServerName sn,
HRegionInfo hri)
Close a region.
|
private void |
HBaseAdmin.compact(ServerName sn,
HRegionInfo hri,
boolean major,
byte[] family) |
private static int |
RegionReplicaUtil.compareRegionInfosWithoutReplicaId(HRegionInfo regionInfoA,
HRegionInfo regionInfoB) |
private void |
HBaseAdmin.flush(ServerName sn,
HRegionInfo hri) |
static HRegionInfo |
RegionReplicaUtil.getRegionInfoForDefaultReplica(HRegionInfo regionInfo)
Returns the HRegionInfo for the default replicaId (0).
|
static HRegionInfo |
RegionReplicaUtil.getRegionInfoForReplica(HRegionInfo regionInfo,
int replicaId)
Returns the HRegionInfo for the given replicaId.
|
static boolean |
RegionReplicaUtil.isDefaultReplica(HRegionInfo hri) |
static boolean |
RegionReplicaUtil.isReplicasForSameRegion(HRegionInfo regionInfoA,
HRegionInfo regionInfoB) |
void |
HBaseAdmin.split(ServerName sn,
HRegionInfo hri,
byte[] splitPoint) |
(package private) void |
ConnectionManager.HConnectionImplementation.updateCachedLocation(HRegionInfo hri,
ServerName source,
ServerName serverName,
long seqNum) |
Modifier and Type | Method and Description |
---|---|
protected boolean |
AsyncProcess.canTakeOperation(HRegionLocation loc,
Map<HRegionInfo,Boolean> regionsIncluded,
Map<ServerName,Boolean> serversIncluded)
Check if we should send new operations to this region or region server.
|
static void |
RegionReplicaUtil.removeNonDefaultRegions(Collection<HRegionInfo> 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,
HTableDescriptor htd,
HRegionInfo hri,
Scan scan,
ScanMetrics scanMetrics) |
FlushRegionCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
HRegionInfo regionInfo,
boolean writeFlushWalMarker) |
HTableMultiplexer.PutStatus(HRegionInfo regionInfo,
Put put,
int retryCount) |
UnmodifyableHRegionInfo(HRegionInfo info) |
Modifier and Type | Method and Description |
---|---|
boolean |
ZkCloseRegionCoordination.checkClosingState(HRegionInfo regionInfo,
CloseRegionCoordination.CloseRegionDetails crd)
In ZK-based version we're checking for bad znode state, e.g.
|
boolean |
CloseRegionCoordination.checkClosingState(HRegionInfo regionInfo,
CloseRegionCoordination.CloseRegionDetails crd)
Called before actual region closing to check that we can do close operation
on this region.
|
void |
ZkRegionMergeCoordination.clean(HRegionInfo hri) |
void |
ZKSplitTransactionCoordination.clean(HRegionInfo hri) |
void |
SplitTransactionCoordination.clean(HRegionInfo hri)
clean the split transaction
|
void |
RegionMergeCoordination.clean(HRegionInfo merged)
This method is used during rollback
|
boolean |
OpenRegionCoordination.commitOpenOnMasterSide(AssignmentManager assignmentManager,
HRegionInfo regionInfo,
OpenRegionCoordination.OpenRegionDetails ord)
Commits opening operation on HM side (steps required for "commit"
are determined by coordination implementation).
|
boolean |
ZkOpenRegionCoordination.commitOpenOnMasterSide(AssignmentManager assignmentManager,
HRegionInfo regionInfo,
OpenRegionCoordination.OpenRegionDetails ord) |
void |
ZkRegionMergeCoordination.completeRegionMergeTransaction(RegionServerServices services,
HRegionInfo mergedRegionInfo,
HRegion region_a,
HRegion region_b,
RegionMergeCoordination.RegionMergeDetails rmd,
HRegion mergedRegion) |
void |
RegionMergeCoordination.completeRegionMergeTransaction(RegionServerServices services,
HRegionInfo merged,
HRegion region_a,
HRegion region_b,
RegionMergeCoordination.RegionMergeDetails rmd,
HRegion mergedRegion)
Finish off merge transaction
|
void |
ZkRegionMergeCoordination.confirmRegionMergeTransaction(HRegionInfo merged,
HRegionInfo a,
HRegionInfo b,
ServerName serverName,
RegionMergeCoordination.RegionMergeDetails rmd) |
void |
RegionMergeCoordination.confirmRegionMergeTransaction(HRegionInfo merged,
HRegionInfo a,
HRegionInfo b,
ServerName serverName,
RegionMergeCoordination.RegionMergeDetails rmd)
Confirm that the region merge can be performed
|
private void |
ZkOpenRegionCoordination.debugLog(HRegionInfo region,
String string) |
private boolean |
ZkOpenRegionCoordination.deleteOpenedNode(HRegionInfo regionInfo,
OpenRegionCoordination.OpenRegionDetails ord) |
private boolean |
ZkOpenRegionCoordination.isRegionStillOpening(HRegionInfo regionInfo,
RegionServerServices rsServices) |
void |
ZkRegionMergeCoordination.processRegionMergeRequest(HRegionInfo p,
HRegionInfo hri_a,
HRegionInfo hri_b,
ServerName sn,
RegionMergeCoordination.RegionMergeDetails rmd) |
void |
RegionMergeCoordination.processRegionMergeRequest(HRegionInfo merged,
HRegionInfo a,
HRegionInfo b,
ServerName serverName,
RegionMergeCoordination.RegionMergeDetails rmd) |
int |
ZKSplitTransactionCoordination.processTransition(HRegionInfo p,
HRegionInfo hri_a,
HRegionInfo hri_b,
ServerName sn,
SplitTransactionCoordination.SplitTransactionDetails std) |
int |
SplitTransactionCoordination.processTransition(HRegionInfo p,
HRegionInfo hri_a,
HRegionInfo hri_b,
ServerName sn,
SplitTransactionCoordination.SplitTransactionDetails std)
Required by AssignmentManager
|
void |
ZkRegionMergeCoordination.startRegionMergeTransaction(HRegionInfo region,
ServerName serverName,
HRegionInfo a,
HRegionInfo b)
Creates a new ephemeral node in the PENDING_MERGE state for the merged region.
|
void |
RegionMergeCoordination.startRegionMergeTransaction(HRegionInfo region,
ServerName serverName,
HRegionInfo a,
HRegionInfo b)
Start the region merge transaction
|
void |
ZKSplitTransactionCoordination.startSplitTransaction(HRegion parent,
ServerName serverName,
HRegionInfo hri_a,
HRegionInfo hri_b)
Creates a new ephemeral node in the PENDING_SPLIT state for the specified region.
|
void |
SplitTransactionCoordination.startSplitTransaction(HRegion parent,
ServerName serverName,
HRegionInfo hri_a,
HRegionInfo hri_b)
init coordination for split transaction
|
boolean |
OpenRegionCoordination.tickleOpening(OpenRegionCoordination.OpenRegionDetails ord,
HRegionInfo regionInfo,
RegionServerServices rsServices,
String context)
Heartbeats to prevent timeouts.
|
boolean |
ZkOpenRegionCoordination.tickleOpening(OpenRegionCoordination.OpenRegionDetails ord,
HRegionInfo regionInfo,
RegionServerServices rsServices,
String context)
Update our OPENING state in zookeeper.
|
boolean |
OpenRegionCoordination.transitionFromOfflineToOpening(HRegionInfo regionInfo,
OpenRegionCoordination.OpenRegionDetails ord)
Transitions region from offline to opening state.
|
boolean |
ZkOpenRegionCoordination.transitionFromOfflineToOpening(HRegionInfo regionInfo,
OpenRegionCoordination.OpenRegionDetails ord)
Transition ZK node from OFFLINE to OPENING.
|
private void |
ZkRegionMergeCoordination.transitionMergingNode(HRegionInfo merged,
HRegionInfo a,
HRegionInfo b,
ServerName serverName,
RegionMergeCoordination.RegionMergeDetails rmd,
EventType beginState,
EventType endState)
Transitions an existing ephemeral node for the specified region which is
currently in the begin state to be in the end state.
|
private int |
ZKSplitTransactionCoordination.transitionSplittingNode(HRegionInfo parent,
HRegionInfo a,
HRegionInfo b,
ServerName serverName,
SplitTransactionCoordination.SplitTransactionDetails std,
EventType beginState,
EventType endState)
Transitions an existing ephemeral node for the specified region which is currently in the begin
state to be in the end state.
|
boolean |
OpenRegionCoordination.tryTransitionFromOfflineToFailedOpen(RegionServerServices rsServices,
HRegionInfo hri,
OpenRegionCoordination.OpenRegionDetails ord)
Tries transition region from offline to failed open.
|
boolean |
ZkOpenRegionCoordination.tryTransitionFromOfflineToFailedOpen(RegionServerServices rsServices,
HRegionInfo hri,
OpenRegionCoordination.OpenRegionDetails ord)
Try to transition to open.
|
boolean |
OpenRegionCoordination.tryTransitionFromOpeningToFailedOpen(HRegionInfo hri,
OpenRegionCoordination.OpenRegionDetails ord)
Tries transition from Opening to Failed open.
|
boolean |
ZkOpenRegionCoordination.tryTransitionFromOpeningToFailedOpen(HRegionInfo hri,
OpenRegionCoordination.OpenRegionDetails ord)
This is not guaranteed to succeed, we just do our best.
|
void |
ZkRegionMergeCoordination.waitForRegionMergeTransaction(RegionServerServices services,
HRegionInfo mergedRegionInfo,
HRegion region_a,
HRegion region_b,
RegionMergeCoordination.RegionMergeDetails details)
Wait for the merging node to be transitioned from pending_merge
to merging by master.
|
void |
RegionMergeCoordination.waitForRegionMergeTransaction(RegionServerServices services,
HRegionInfo mergedRegionInfo,
HRegion region_a,
HRegion region_b,
RegionMergeCoordination.RegionMergeDetails details)
Get everything ready for region merge
|
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 |
---|---|
void |
SplitLogManagerCoordination.markRegionsRecovering(ServerName serverName,
Set<HRegionInfo> userRegions)
Mark regions in recovering state for distributed log replay
|
void |
ZKSplitLogManagerCoordination.markRegionsRecovering(ServerName serverName,
Set<HRegionInfo> userRegions)
Create znodes /hbase/recovering-regions/[region_ids...]/[failed region server names ...] for
all regions of the passed in region servers
|
Modifier and Type | Method and Description |
---|---|
HRegionInfo |
RegionCoprocessorEnvironment.getRegionInfo() |
Modifier and Type | Method and Description |
---|---|
void |
MasterObserver.postAssign(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo)
Called after the region assignment has been requested.
|
void |
BaseMasterObserver.postAssign(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo) |
void |
BaseMasterAndRegionObserver.postAssign(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo) |
void |
MasterObserver.postCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
HTableDescriptor desc,
HRegionInfo[] regions)
Called after the createTable operation has been requested.
|
void |
BaseMasterObserver.postCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
HTableDescriptor desc,
HRegionInfo[] regions) |
void |
BaseMasterAndRegionObserver.postCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
HTableDescriptor desc,
HRegionInfo[] regions) |
void |
MasterObserver.postCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
HTableDescriptor desc,
HRegionInfo[] regions)
Called after the createTable operation has been requested.
|
void |
BaseMasterObserver.postCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
HTableDescriptor desc,
HRegionInfo[] regions) |
void |
BaseMasterAndRegionObserver.postCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
HTableDescriptor desc,
HRegionInfo[] regions) |
void |
MasterObserver.postMove(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo region,
ServerName srcServer,
ServerName destServer)
Called after the region move has been requested.
|
void |
BaseMasterObserver.postMove(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo region,
ServerName srcServer,
ServerName destServer) |
void |
BaseMasterAndRegionObserver.postMove(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo region,
ServerName srcServer,
ServerName destServer) |
void |
MasterObserver.postRegionOffline(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo)
Called after the region has been marked offline.
|
void |
BaseMasterObserver.postRegionOffline(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo) |
void |
BaseMasterAndRegionObserver.postRegionOffline(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo) |
void |
MasterObserver.postUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo,
boolean force)
Called after the region unassignment has been requested.
|
void |
BaseMasterObserver.postUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo,
boolean force) |
void |
BaseMasterAndRegionObserver.postUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo,
boolean force) |
void |
RegionObserver.postWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment> ctx,
HRegionInfo info,
WALKey logKey,
WALEdit logEdit)
Called after a
WALEdit
replayed for this region. |
void |
BaseRegionObserver.postWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment> env,
HRegionInfo info,
WALKey logKey,
WALEdit logEdit)
Implementers should override this version of the method and leave the deprecated one as-is.
|
void |
RegionObserver.postWALRestore(ObserverContext<RegionCoprocessorEnvironment> ctx,
HRegionInfo info,
HLogKey logKey,
WALEdit logEdit)
|
void |
BaseRegionObserver.postWALRestore(ObserverContext<RegionCoprocessorEnvironment> env,
HRegionInfo info,
HLogKey logKey,
WALEdit logEdit) |
void |
WALObserver.postWALWrite(ObserverContext<? extends WALCoprocessorEnvironment> ctx,
HRegionInfo info,
WALKey logKey,
WALEdit logEdit)
Called after a
WALEdit
is writen to WAL. |
void |
BaseWALObserver.postWALWrite(ObserverContext<? extends WALCoprocessorEnvironment> ctx,
HRegionInfo info,
WALKey logKey,
WALEdit logEdit)
Implementers should override this method and leave the deprecated version as-is.
|
void |
WALObserver.postWALWrite(ObserverContext<WALCoprocessorEnvironment> ctx,
HRegionInfo info,
HLogKey logKey,
WALEdit logEdit)
|
void |
BaseWALObserver.postWALWrite(ObserverContext<WALCoprocessorEnvironment> ctx,
HRegionInfo info,
HLogKey logKey,
WALEdit logEdit) |
void |
MasterObserver.preAssign(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo)
Called prior to assigning a specific region.
|
void |
BaseMasterObserver.preAssign(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo) |
void |
BaseMasterAndRegionObserver.preAssign(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo) |
void |
MasterObserver.preCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
HTableDescriptor desc,
HRegionInfo[] regions)
Called before a new table is created by
HMaster . |
void |
BaseMasterObserver.preCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
HTableDescriptor desc,
HRegionInfo[] regions) |
void |
BaseMasterAndRegionObserver.preCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
HTableDescriptor desc,
HRegionInfo[] regions) |
void |
MasterObserver.preCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
HTableDescriptor desc,
HRegionInfo[] regions)
Called before a new table is created by
HMaster . |
void |
BaseMasterObserver.preCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
HTableDescriptor desc,
HRegionInfo[] regions) |
void |
BaseMasterAndRegionObserver.preCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment> ctx,
HTableDescriptor desc,
HRegionInfo[] regions) |
void |
MasterObserver.preMove(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo region,
ServerName srcServer,
ServerName destServer)
Called prior to moving a given region from one region server to another.
|
void |
BaseMasterObserver.preMove(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo region,
ServerName srcServer,
ServerName destServer) |
void |
BaseMasterAndRegionObserver.preMove(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo region,
ServerName srcServer,
ServerName destServer) |
void |
MasterObserver.preRegionOffline(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo)
Called prior to marking a given region as offline.
|
void |
BaseMasterObserver.preRegionOffline(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo) |
void |
BaseMasterAndRegionObserver.preRegionOffline(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo) |
void |
MasterObserver.preUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo,
boolean force)
Called prior to unassigning a given region.
|
void |
BaseMasterObserver.preUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo,
boolean force) |
void |
BaseMasterAndRegionObserver.preUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx,
HRegionInfo regionInfo,
boolean force) |
void |
RegionObserver.preWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment> ctx,
HRegionInfo info,
WALKey logKey,
WALEdit logEdit)
Called before a
WALEdit
replayed for this region. |
void |
BaseRegionObserver.preWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment> env,
HRegionInfo info,
WALKey logKey,
WALEdit logEdit)
Implementers should override this version of the method and leave the deprecated one as-is.
|
void |
RegionObserver.preWALRestore(ObserverContext<RegionCoprocessorEnvironment> ctx,
HRegionInfo info,
HLogKey logKey,
WALEdit logEdit)
|
void |
BaseRegionObserver.preWALRestore(ObserverContext<RegionCoprocessorEnvironment> env,
HRegionInfo info,
HLogKey logKey,
WALEdit logEdit) |
boolean |
WALObserver.preWALWrite(ObserverContext<? extends WALCoprocessorEnvironment> ctx,
HRegionInfo info,
WALKey logKey,
WALEdit logEdit)
Called before a
WALEdit
is writen to WAL. |
boolean |
BaseWALObserver.preWALWrite(ObserverContext<? extends WALCoprocessorEnvironment> ctx,
HRegionInfo info,
WALKey logKey,
WALEdit logEdit)
Implementers should override this method and leave the deprecated version as-is.
|
boolean |
WALObserver.preWALWrite(ObserverContext<WALCoprocessorEnvironment> ctx,
HRegionInfo info,
HLogKey logKey,
WALEdit logEdit)
|
boolean |
BaseWALObserver.preWALWrite(ObserverContext<WALCoprocessorEnvironment> ctx,
HRegionInfo info,
HLogKey logKey,
WALEdit logEdit) |
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,
HRegionInfo 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,
HRegionInfo hfileRegionInfo,
String hfileName,
boolean createBackRef)
Create a new HFileLink
|
static String |
HFileLink.createHFileLinkName(HRegionInfo hfileRegionInfo,
String hfileName)
Create a new HFileLink name
|
Constructor and Description |
---|
TableSnapshotInputFormat.TableSnapshotRegionSplit(HTableDescriptor htd,
HRegionInfo regionInfo,
List<String> locations,
Scan scan,
org.apache.hadoop.fs.Path restoreDir) |
Modifier and Type | Field and Description |
---|---|
private HRegionInfo |
TableSnapshotInputFormatImpl.InputSplit.regionInfo |
Modifier and Type | Method and Description |
---|---|
HRegionInfo |
TableSnapshotInputFormatImpl.InputSplit.getRegionInfo() |
Modifier and Type | Method and Description |
---|---|
static List<HRegionInfo> |
TableSnapshotInputFormatImpl.getRegionInfosFromManifest(SnapshotManifest manifest) |
Modifier and Type | Method and Description |
---|---|
static List<TableSnapshotInputFormatImpl.InputSplit> |
TableSnapshotInputFormatImpl.getSplits(Scan scan,
SnapshotManifest manifest,
List<HRegionInfo> regionManifests,
org.apache.hadoop.fs.Path restoreDir,
org.apache.hadoop.conf.Configuration conf) |
Constructor and Description |
---|
TableSnapshotInputFormat.TableSnapshotRegionSplit(HTableDescriptor htd,
HRegionInfo regionInfo,
List<String> locations,
Scan scan,
org.apache.hadoop.fs.Path restoreDir) |
TableSnapshotInputFormatImpl.InputSplit(HTableDescriptor htd,
HRegionInfo regionInfo,
List<String> locations,
Scan scan,
org.apache.hadoop.fs.Path restoreDir) |
Modifier and Type | Field and Description |
---|---|
private HRegionInfo |
RegionState.hri |
private HRegionInfo |
UnAssignCallable.hri |
private HRegionInfo |
RegionPlan.hri |
private HRegionInfo |
AssignCallable.hri |
Modifier and Type | Field and Description |
---|---|
(package private) Map<ServerName,List<HRegionInfo>> |
GeneralBulkAssigner.bulkPlan |
private Map<HRegionInfo,AtomicBoolean> |
AssignmentManager.closedRegionHandlerCalled |
private Map<HRegionInfo,Set<HRegionInfo>> |
RegionStates.defaultReplicaToOtherReplicas
Maintains the mapping from the default region to the replica regions.
|
private Map<HRegionInfo,Set<HRegionInfo>> |
RegionStates.defaultReplicaToOtherReplicas
Maintains the mapping from the default region to the replica regions.
|
private Map<ServerName,List<HRegionInfo>> |
GeneralBulkAssigner.failedPlans |
private Map<ServerName,List<HRegionInfo>> |
GeneralBulkAssigner.SingleServerBulkAssigner.failedPlans |
private Map<String,PairOfSameType<HRegionInfo>> |
AssignmentManager.mergingRegions
Map of two merging regions from the region to be created.
|
private List<HRegionInfo> |
AssignmentVerificationReport.nonFavoredAssignedRegionList |
private Map<HRegionInfo,AtomicBoolean> |
AssignmentManager.openedRegionHandlerCalled |
private TreeMap<HRegionInfo,ServerName> |
RegionStates.regionAssignments
Region to server assignment map.
|
private Map<String,HRegionInfo> |
SnapshotOfRegionAssignmentFromMeta.regionNameToRegionInfoMap
the region name to region info map
|
private List<HRegionInfo> |
GeneralBulkAssigner.SingleServerBulkAssigner.regions |
private Map<ServerName,List<HRegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.regionServerToRegionMap
the regionServer to region map
|
private Map<String,HRegionInfo> |
AssignmentManager.regionsToReopen
Map of regions to reopen after the schema of a table is changed.
|
private List<HRegionInfo> |
AssignmentVerificationReport.regionsWithoutValidFavoredNodes |
private Map<HRegionInfo,ServerName> |
SnapshotOfRegionAssignmentFromMeta.regionToRegionServerMap
the region to region server map
|
(package private) Set<HRegionInfo> |
AssignmentManager.replicasToClose |
private Map<ServerName,List<HRegionInfo>> |
BulkReOpen.rsToRegions |
private Map<ServerName,Set<HRegionInfo>> |
RegionStates.serverHoldings
Server to regions assignment map.
|
private Map<HRegionInfo,PairOfSameType<HRegionInfo>> |
AssignmentManager.splitRegions |
private Map<HRegionInfo,PairOfSameType<HRegionInfo>> |
AssignmentManager.splitRegions |
private Map<TableName,List<HRegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.tableToRegionMap
the table name to region map
|
private List<HRegionInfo> |
AssignmentVerificationReport.unAssignedRegionsList |
Modifier and Type | Method and Description |
---|---|
HRegionInfo |
RegionState.getRegion() |
HRegionInfo |
RegionPlan.getRegionInfo() |
protected HRegionInfo |
RegionStates.getRegionInfo(byte[] regionName)
Get the HRegionInfo from cache, if not there, from the hbase:meta table
|
Modifier and Type | Method and Description |
---|---|
List<HRegionInfo> |
AssignmentManager.cleanOutCrashedServerReferences(ServerName sn)
Clean out crashed server removing any assignments.
|
(package private) Map<HRegionInfo,ServerName> |
RegionStates.closeAllUserRegions(Set<TableName> excludedTables)
At cluster clean re/start, mark all user regions closed except those of tables
that are excluded, such as disabled/disabling/enabling tables.
|
protected Map<TableName,Map<ServerName,List<HRegionInfo>>> |
RegionStates.getAssignmentsByTable()
This is an EXPENSIVE clone.
|
(package private) Triple<Integer,Map<HRegionInfo,Result>,Map<HRegionInfo,Result>> |
CatalogJanitor.getMergedRegionsAndSplitParents()
Scans hbase:meta and returns a number of scanned rows, and a map of merged
regions, and an ordered map of split parents.
|
(package private) Triple<Integer,Map<HRegionInfo,Result>,Map<HRegionInfo,Result>> |
CatalogJanitor.getMergedRegionsAndSplitParents()
Scans hbase:meta and returns a number of scanned rows, and a map of merged
regions, and an ordered map of split parents.
|
(package private) Triple<Integer,Map<HRegionInfo,Result>,Map<HRegionInfo,Result>> |
CatalogJanitor.getMergedRegionsAndSplitParents(TableName tableName)
Scans hbase:meta and returns a number of scanned rows, and a map of merged
regions, and an ordered map of split parents.
|
(package private) Triple<Integer,Map<HRegionInfo,Result>,Map<HRegionInfo,Result>> |
CatalogJanitor.getMergedRegionsAndSplitParents(TableName tableName)
Scans hbase:meta and returns a number of scanned rows, and a map of merged
regions, and an ordered map of split parents.
|
(package private) List<HRegionInfo> |
AssignmentVerificationReport.getNonFavoredAssignedRegions()
Return the regions not assigned to its favored nodes
|
Map<HRegionInfo,ServerName> |
RegionStates.getRegionAssignments() |
(package private) Map<ServerName,List<HRegionInfo>> |
RegionStates.getRegionAssignments(Collection<HRegionInfo> regions)
Return the replicas (including default) for the regions grouped by ServerName
|
protected Map<ServerName,List<HRegionInfo>> |
RegionStates.getRegionAssignmentsByServer()
Returns a clone of region assignments per server
|
Map<RegionState.State,List<HRegionInfo>> |
RegionStates.getRegionByStateOfTable(TableName tableName)
Gets current state of all regions of the table.
|
Map<String,HRegionInfo> |
SnapshotOfRegionAssignmentFromMeta.getRegionNameToRegionInfoMap()
Get the regioninfo for a region
|
Map<ServerName,List<HRegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.getRegionServerToRegionMap()
Get regionserver to region map
|
List<HRegionInfo> |
RegionStates.getRegionsOfTable(TableName tableName)
Gets the online regions of the specified table.
|
(package private) List<HRegionInfo> |
AssignmentVerificationReport.getRegionsWithoutValidFavoredNodes()
Return the regions without favored nodes
|
Map<HRegionInfo,ServerName> |
SnapshotOfRegionAssignmentFromMeta.getRegionToRegionServerMap()
Get region to region server map
|
Set<HRegionInfo> |
AssignmentManager.getReplicasToClose() |
Set<HRegionInfo> |
RegionStates.getServerRegions(ServerName serverName)
Get a copy of all regions assigned to a server
|
Map<ServerName,List<HRegionInfo>> |
AssignmentManager.getSnapShotOfAssignment(Collection<HRegionInfo> infos) |
(package private) Pair<HRegionInfo,ServerName> |
HMaster.getTableRegionForRow(TableName tableName,
byte[] rowKey)
Return the region and current deployment for the region containing
the given row.
|
Map<TableName,List<HRegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.getTableToRegionMap()
Get regions for tables
|
(package private) List<HRegionInfo> |
AssignmentVerificationReport.getUnassignedRegions()
Return the unassigned regions
|
Map<HRegionInfo,ServerName> |
LoadBalancer.immediateAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Sync assign a region
|
static List<HRegionInfo> |
AssignmentManager.replicaRegionsNotRecordedInMeta(Set<HRegionInfo> regionsRecordedInMeta,
MasterServices master)
Get a list of replica regions that are:
not recorded in meta yet.
|
Map<ServerName,List<HRegionInfo>> |
LoadBalancer.retainAssignment(Map<HRegionInfo,ServerName> regions,
List<ServerName> servers)
Assign regions to the previously hosting region server
|
Map<ServerName,List<HRegionInfo>> |
LoadBalancer.roundRobinAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Perform a Round Robin assignment of regions.
|
List<HRegionInfo> |
RegionStates.serverOffline(ZooKeeperWatcher watcher,
ServerName sn)
A server is offline, all regions on it are dead.
|
Modifier and Type | Method and Description |
---|---|
private void |
SnapshotOfRegionAssignmentFromMeta.addAssignment(HRegionInfo regionInfo,
ServerName server) |
private void |
SnapshotOfRegionAssignmentFromMeta.addRegion(HRegionInfo regionInfo) |
private void |
RegionStates.addToReplicaMapping(HRegionInfo hri) |
private void |
RegionStates.addToServerHoldings(ServerName serverName,
HRegionInfo hri) |
void |
AssignmentManager.assign(HRegionInfo region,
boolean setOfflineInZK)
Assigns the specified region.
|
void |
AssignmentManager.assign(HRegionInfo region,
boolean setOfflineInZK,
boolean forceNewPlan)
Use care with forceNewPlan.
|
void |
AssignmentManager.assignMeta(HRegionInfo hri)
Assigns the hbase:meta region or a replica.
|
void |
HMaster.assignRegion(HRegionInfo hri) |
(package private) Pair<Boolean,Boolean> |
CatalogJanitor.checkDaughterInFs(HRegionInfo parent,
HRegionInfo daughter)
Checks if a daughter region -- either splitA or splitB -- still holds
references to parent.
|
private String |
AssignmentManager.checkInStateForSplit(ServerName sn,
HRegionInfo p,
HRegionInfo a,
HRegionInfo b) |
boolean |
CatalogJanitor.cleanMergeQualifier(HRegionInfo region)
Checks if the specified region has merge qualifiers, if so, try to clean
them
|
(package private) boolean |
CatalogJanitor.cleanMergeRegion(HRegionInfo mergedRegion,
HRegionInfo regionA,
HRegionInfo regionB)
If merged region no longer holds reference to the merge regions, archive
merge region on hdfs and perform deleting references in hbase:meta
|
(package private) boolean |
CatalogJanitor.cleanParent(HRegionInfo parent,
Result rowContent)
If daughters no longer hold reference to the parents, delete the parent.
|
void |
RegionStates.clearLastAssignment(HRegionInfo region) |
(package private) void |
AssignmentManager.clearRegionPlan(HRegionInfo region) |
static void |
ServerManager.closeRegionSilentlyAndWait(ClusterConnection connection,
ServerName server,
HRegionInfo region,
long timeout)
Contacts a region server and waits up to timeout ms
to close the region.
|
int |
CatalogJanitor.SplitParentFirstComparator.compare(HRegionInfo left,
HRegionInfo right) |
RegionState |
RegionStates.createRegionState(HRegionInfo hri)
Add a region to RegionStates.
|
RegionState |
RegionStates.createRegionState(HRegionInfo hri,
RegionState.State newState,
ServerName serverName,
ServerName lastHost)
Add a region to RegionStates with the specified state.
|
void |
AssignmentManager.deleteClosingOrClosedNode(HRegionInfo region,
ServerName sn) |
void |
MasterFileSystem.deleteFamilyFromFS(HRegionInfo region,
byte[] familyName) |
void |
RegionStates.deleteRegion(HRegionInfo hri)
Remove a region from all state maps.
|
void |
MasterFileSystem.deleteRegion(HRegionInfo region) |
void |
HMaster.dispatchMergingRegions(HRegionInfo region_a,
HRegionInfo region_b,
boolean forcible) |
void |
MasterServices.dispatchMergingRegions(HRegionInfo region_a,
HRegionInfo region_b,
boolean forcible)
Merge two regions.
|
private void |
AssignmentManager.doMergingOfReplicas(HRegionInfo mergedHri,
HRegionInfo hri_a,
HRegionInfo hri_b) |
private void |
AssignmentManager.doSplittingOfReplicas(HRegionInfo parentHri,
HRegionInfo hri_a,
HRegionInfo hri_b) |
(package private) boolean |
RegionStates.existsInServerHoldings(ServerName serverName,
HRegionInfo hri)
Used in some unit tests
|
private RegionState |
AssignmentManager.forceRegionStateToOffline(HRegionInfo region,
boolean forceNewPlan)
Set region to OFFLINE unless it is opening and forceNewPlan is false.
|
private RegionPlan |
AssignmentManager.getRegionPlan(HRegionInfo region,
boolean forceNewPlan) |
private RegionPlan |
AssignmentManager.getRegionPlan(HRegionInfo region,
ServerName serverToExclude,
boolean forceNewPlan) |
RegionPlan |
AssignmentManager.getRegionReopenPlan(HRegionInfo hri) |
private int |
RegionStates.getRegionReplication(HRegionInfo r) |
ServerName |
RegionStates.getRegionServerOfRegion(HRegionInfo hri) |
protected RegionState |
RegionStates.getRegionState(HRegionInfo hri) |
RegionState |
RegionStates.getRegionTransitionState(HRegionInfo hri)
Get region transition state
|
(package private) void |
AssignmentManager.invokeAssign(HRegionInfo regionInfo) |
(package private) void |
AssignmentManager.invokeAssign(HRegionInfo regionInfo,
boolean newPlan) |
(package private) void |
AssignmentManager.invokeUnAssign(HRegionInfo regionInfo) |
AssignmentManager.ServerHostRegion |
AssignmentManager.isCarryingMetaReplica(ServerName serverName,
HRegionInfo metaHri) |
private AssignmentManager.ServerHostRegion |
AssignmentManager.isCarryingRegion(ServerName serverName,
HRegionInfo hri)
Check if the shutdown server carries the specific region.
|
private boolean |
AssignmentManager.isDisabledorDisablingRegionInRIT(HRegionInfo region) |
boolean |
RegionStates.isRegionInRegionStates(HRegionInfo hri) |
boolean |
ServerManager.isRegionInServerManagerStates(HRegionInfo hri) |
boolean |
RegionStates.isRegionInState(HRegionInfo hri,
RegionState.State... states) |
boolean |
RegionStates.isRegionInTransition(HRegionInfo hri) |
boolean |
RegionStates.isRegionOffline(HRegionInfo hri) |
boolean |
RegionStates.isRegionOnline(HRegionInfo hri) |
void |
RegionStates.logSplit(HRegionInfo region)
Log split is done for a given region, so it is assignable now.
|
(package private) void |
RegionStates.mergeRegions(HRegionInfo p,
HRegionInfo a,
HRegionInfo b,
ServerName sn) |
(package private) void |
RegionStateStore.mergeRegions(HRegionInfo p,
HRegionInfo a,
HRegionInfo b,
ServerName sn,
int regionReplication) |
void |
AssignmentManager.offlineDisabledRegion(HRegionInfo regionInfo) |
private void |
AssignmentManager.onRegionClosed(HRegionInfo hri) |
private void |
AssignmentManager.onRegionFailedOpen(HRegionInfo hri,
ServerName sn) |
private String |
AssignmentManager.onRegionMerge(ServerName sn,
org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode code,
HRegionInfo p,
HRegionInfo a,
HRegionInfo b) |
private String |
AssignmentManager.onRegionMergeReverted(ServerName sn,
org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode code,
HRegionInfo p,
HRegionInfo a,
HRegionInfo b) |
private void |
AssignmentManager.onRegionOpen(HRegionInfo hri,
ServerName sn,
long openSeqNum) |
private String |
AssignmentManager.onRegionSplit(ServerName sn,
org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode code,
HRegionInfo p,
HRegionInfo a,
HRegionInfo b) |
private String |
AssignmentManager.onRegionSplitReverted(ServerName sn,
HRegionInfo p,
HRegionInfo a,
HRegionInfo b) |
void |
MasterCoprocessorHost.postAssign(HRegionInfo regionInfo) |
void |
MasterCoprocessorHost.postCreateTable(HTableDescriptor htd,
HRegionInfo[] regions) |
void |
MasterCoprocessorHost.postCreateTableHandler(HTableDescriptor htd,
HRegionInfo[] regions) |
void |
MasterCoprocessorHost.postMove(HRegionInfo region,
ServerName srcServer,
ServerName destServer) |
void |
MasterCoprocessorHost.postRegionOffline(HRegionInfo regionInfo) |
void |
MasterCoprocessorHost.postUnassign(HRegionInfo regionInfo,
boolean force) |
boolean |
MasterCoprocessorHost.preAssign(HRegionInfo regionInfo) |
void |
MasterCoprocessorHost.preCreateTable(HTableDescriptor htd,
HRegionInfo[] regions) |
void |
MasterCoprocessorHost.preCreateTableHandler(HTableDescriptor htd,
HRegionInfo[] regions) |
boolean |
MasterCoprocessorHost.preMove(HRegionInfo region,
ServerName srcServer,
ServerName destServer) |
private void |
AssignmentManager.prepareDaughterReplicaForAssignment(HRegionInfo daughterHri,
HRegionInfo parentHri,
int replicaId,
Map<HRegionInfo,ServerName> map) |
void |
MasterCoprocessorHost.preRegionOffline(HRegionInfo regionInfo) |
boolean |
MasterCoprocessorHost.preUnassign(HRegionInfo regionInfo,
boolean force) |
private void |
AssignmentManager.processAlreadyOpenedRegion(HRegionInfo region,
ServerName sn) |
(package private) boolean |
AssignmentManager.processRegionInTransition(String encodedRegionName,
HRegionInfo regionInfo)
Process failover of new master for region
encodedRegionName
up in zookeeper. |
(package private) boolean |
AssignmentManager.processRegionInTransitionAndBlockUntilAssigned(HRegionInfo hri)
If region is up in zk in transition, then do fixup and block and wait until
the region is assigned and out of transition.
|
(package private) boolean |
AssignmentManager.processRegionsInTransition(RegionTransition rt,
HRegionInfo regionInfo,
OpenRegionCoordination coordination,
OpenRegionCoordination.OpenRegionDetails ord)
This call is invoked only (1) master assign meta;
(2) during failover mode startup, zk assignment node processing.
|
ServerName |
LoadBalancer.randomAssignment(HRegionInfo regionInfo,
List<ServerName> servers)
Get a random region server from the list
|
void |
AssignmentListener.regionClosed(HRegionInfo regionInfo)
The region was closed on the region server.
|
void |
LoadBalancer.regionOffline(HRegionInfo regionInfo)
Marks the region as offline at balancer.
|
void |
RegionStates.regionOffline(HRegionInfo hri)
A region is offline, won't be in transition any more.
|
void |
AssignmentManager.regionOffline(HRegionInfo regionInfo)
Marks the region as offline.
|
void |
RegionStates.regionOffline(HRegionInfo hri,
RegionState.State expectedState)
A region is offline, won't be in transition any more.
|
private void |
AssignmentManager.regionOffline(HRegionInfo regionInfo,
RegionState.State state)
A region is offline.
|
void |
LoadBalancer.regionOnline(HRegionInfo regionInfo,
ServerName sn)
Marks the region as online at balancer.
|
void |
RegionStates.regionOnline(HRegionInfo hri,
ServerName serverName) |
(package private) void |
AssignmentManager.regionOnline(HRegionInfo regionInfo,
ServerName sn)
Marks the region as online.
|
void |
RegionStates.regionOnline(HRegionInfo hri,
ServerName serverName,
long openSeqNum)
A region is online, won't be in transition any more.
|
(package private) void |
AssignmentManager.regionOnline(HRegionInfo regionInfo,
ServerName sn,
long openSeqNum) |
void |
AssignmentListener.regionOpened(HRegionInfo regionInfo,
ServerName serverName)
The region was opened on the specified server.
|
void |
AssignmentManager.removeClosedRegion(HRegionInfo hri)
When a region is closed, it should be removed from the regionsToReopen
|
private void |
RegionStates.removeFromReplicaMapping(HRegionInfo hri) |
private void |
RegionStates.removeFromServerHoldings(ServerName serverName,
HRegionInfo hri) |
void |
ServerManager.removeRegion(HRegionInfo regionInfo)
Called by delete table and similar to notify the ServerManager that a region was removed.
|
boolean |
ServerManager.sendRegionClose(ServerName server,
HRegionInfo region,
int versionOfClosingNode) |
boolean |
ServerManager.sendRegionClose(ServerName server,
HRegionInfo region,
int versionOfClosingNode,
ServerName dest,
boolean transitionInZK)
Sends an CLOSE RPC to the specified server to close the specified region.
|
private void |
AssignmentManager.sendRegionClosedNotification(HRegionInfo regionInfo) |
RegionOpeningState |
ServerManager.sendRegionOpen(ServerName server,
HRegionInfo region,
int versionOfOfflineNode,
List<ServerName> favoredNodes)
Sends an OPEN RPC to the specified server to open the specified region.
|
private void |
AssignmentManager.sendRegionOpenedNotification(HRegionInfo regionInfo,
ServerName serverName) |
void |
ServerManager.sendRegionsMerge(ServerName server,
HRegionInfo region_a,
HRegionInfo region_b,
boolean forcible)
Sends an MERGE REGIONS RPC to the specified server to merge the specified
regions.
|
void |
ServerManager.sendRegionWarmup(ServerName server,
HRegionInfo region)
Sends a WARMUP RPC to the specified server to warmup the specified region.
|
RegionState |
RegionStates.setRegionStateTOCLOSED(HRegionInfo regionInfo,
ServerName serverName)
Set the region state to CLOSED
|
private boolean |
RegionStateStore.shouldPersistStateChange(HRegionInfo hri,
RegionState state,
RegionState oldState)
Check if we should persist a state change in meta.
|
(package private) void |
RegionStates.splitRegion(HRegionInfo p,
HRegionInfo a,
HRegionInfo b,
ServerName sn) |
(package private) void |
RegionStateStore.splitRegion(HRegionInfo p,
HRegionInfo a,
HRegionInfo b,
ServerName sn,
int regionReplication) |
void |
AssignmentManager.unassign(HRegionInfo region)
Unassigns the specified region.
|
void |
AssignmentManager.unassign(HRegionInfo region,
boolean force) |
void |
AssignmentManager.unassign(HRegionInfo region,
boolean force,
ServerName dest)
Unassigns the specified region.
|
private void |
AssignmentManager.unassign(HRegionInfo region,
RegionState state,
int versionOfClosingNode,
ServerName dest,
boolean transitionInZK,
ServerName src)
Send CLOSE RPC if the server is online, otherwise, offline the region.
|
(package private) void |
AssignmentManager.updateClosedRegionHandlerTracker(HRegionInfo hri) |
(package private) void |
AssignmentManager.updateOpenedRegionHandlerTracker(HRegionInfo hri) |
void |
MasterFileSystem.updateRegionInfo(HRegionInfo region) |
RegionState |
RegionStates.updateRegionState(HRegionInfo hri,
RegionState.State state)
Update a region state.
|
RegionState |
RegionStates.updateRegionState(HRegionInfo hri,
RegionState.State state,
ServerName serverName)
Update a region state.
|
private RegionState |
RegionStates.updateRegionState(HRegionInfo hri,
RegionState.State state,
ServerName serverName,
long openSeqNum)
Update a region state.
|
boolean |
AssignmentManager.waitForAssignment(HRegionInfo regionInfo)
Waits until the specified region has completed assignment.
|
void |
RegionStates.waitOnRegionToClearRegionsInTransition(HRegionInfo hri)
Wait on region to clear regions-in-transition.
|
void |
AssignmentManager.waitOnRegionToClearRegionsInTransition(HRegionInfo hri)
Wait on region to clear regions-in-transition.
|
boolean |
AssignmentManager.waitOnRegionToClearRegionsInTransition(HRegionInfo hri,
long timeOut)
Wait on region to clear regions-in-transition or time out
|
(package private) boolean |
AssignmentManager.wasClosedHandlerCalled(HRegionInfo hri) |
(package private) boolean |
AssignmentManager.wasOpenedHandlerCalled(HRegionInfo hri) |
protected boolean |
AssignmentManager.wasRegionOnDeadServerByMeta(HRegionInfo region,
ServerName sn) |
Modifier and Type | Method and Description |
---|---|
private void |
AssignmentManager.assign(int regions,
int totalServers,
String message,
Map<ServerName,List<HRegionInfo>> bulkPlan) |
void |
AssignmentManager.assign(List<HRegionInfo> regions)
Assigns specified regions round robin, if any.
|
void |
AssignmentManager.assign(Map<HRegionInfo,ServerName> regions)
Assigns specified regions retaining assignments, if any.
|
(package private) boolean |
AssignmentManager.assign(ServerName destination,
List<HRegionInfo> regions)
Bulk assign regions to
destination . |
private void |
AssignmentManager.assignAllUserRegions(Map<HRegionInfo,ServerName> allRegions)
Assigns all user regions, if any exist.
|
List<RegionPlan> |
LoadBalancer.balanceCluster(Map<ServerName,List<HRegionInfo>> clusterState)
Perform the major balance operation
|
private void |
RegionStates.cleanFailedSplitMergeRegions(Set<HRegionInfo> hris)
This method does an RPC to hbase:meta.
|
void |
RegionStates.createRegionStates(List<HRegionInfo> hris)
Add a list of regions to RegionStates.
|
(package private) Map<ServerName,List<HRegionInfo>> |
RegionStates.getRegionAssignments(Collection<HRegionInfo> regions)
Return the replicas (including default) for the regions grouped by ServerName
|
Map<ServerName,List<HRegionInfo>> |
AssignmentManager.getSnapShotOfAssignment(Collection<HRegionInfo> infos) |
Map<HRegionInfo,ServerName> |
LoadBalancer.immediateAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Sync assign a region
|
void |
SplitLogManager.markRegionsRecovering(ServerName server,
Set<HRegionInfo> userRegions) |
private void |
AssignmentManager.prepareDaughterReplicaForAssignment(HRegionInfo daughterHri,
HRegionInfo parentHri,
int replicaId,
Map<HRegionInfo,ServerName> map) |
void |
MasterFileSystem.prepareLogReplay(ServerName serverName,
Set<HRegionInfo> regions)
Mark regions in recovering state when distributedLogReplay are set true
|
(package private) void |
AssignmentManager.processFavoredNodes(List<HRegionInfo> regions) |
void |
ServerManager.removeRegions(List<HRegionInfo> regions)
Called by delete table and similar to notify the ServerManager that a region was removed.
|
static List<HRegionInfo> |
AssignmentManager.replicaRegionsNotRecordedInMeta(Set<HRegionInfo> regionsRecordedInMeta,
MasterServices master)
Get a list of replica regions that are:
not recorded in meta yet.
|
Map<ServerName,List<HRegionInfo>> |
LoadBalancer.retainAssignment(Map<HRegionInfo,ServerName> regions,
List<ServerName> servers)
Assign regions to the previously hosting region server
|
Map<ServerName,List<HRegionInfo>> |
LoadBalancer.roundRobinAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Perform a Round Robin assignment of regions.
|
List<RegionOpeningState> |
ServerManager.sendRegionOpen(ServerName server,
List<Triple<HRegionInfo,Integer,List<ServerName>>> regionOpenInfos)
Sends an OPEN RPC to the specified server to open the specified region.
|
(package private) void |
RegionStates.setLastRegionServerOfRegions(ServerName serverName,
List<HRegionInfo> regionInfos) |
void |
AssignmentManager.setRegionsToReopen(List<HRegionInfo> regions)
Set the list of regions that will be reopened
because of an update in table schema
|
private void |
BulkReOpen.unassign(List<HRegionInfo> regions)
Unassign the list of regions.
|
protected boolean |
AssignmentManager.waitForAssignment(Collection<HRegionInfo> regionSet,
boolean waitTillAllAssigned,
int reassigningRegions,
long minEndTime)
Waits until the specified region has completed assignment, or the deadline is reached.
|
protected boolean |
AssignmentManager.waitForAssignment(Collection<HRegionInfo> regionSet,
boolean waitTillAllAssigned,
long deadline)
Waits until the specified region has completed assignment, or the deadline is reached.
|
Constructor and Description |
---|
AssignCallable(AssignmentManager assignmentManager,
HRegionInfo hri,
boolean newPlan) |
RegionPlan(HRegionInfo 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(HRegionInfo region,
RegionState.State state) |
RegionState(HRegionInfo region,
RegionState.State state,
long stamp,
ServerName serverName) |
RegionState(HRegionInfo region,
RegionState.State state,
ServerName serverName) |
UnAssignCallable(AssignmentManager assignmentManager,
HRegionInfo hri) |
Constructor and Description |
---|
BulkReOpen(Server server,
Map<ServerName,List<HRegionInfo>> serverToRegions,
AssignmentManager am) |
GeneralBulkAssigner.SingleServerBulkAssigner(ServerName regionserver,
List<HRegionInfo> regions,
AssignmentManager am,
Map<ServerName,List<HRegionInfo>> failedPlans) |
GeneralBulkAssigner.SingleServerBulkAssigner(ServerName regionserver,
List<HRegionInfo> regions,
AssignmentManager am,
Map<ServerName,List<HRegionInfo>> failedPlans) |
GeneralBulkAssigner(Server server,
Map<ServerName,List<HRegionInfo>> bulkPlan,
AssignmentManager am,
boolean waitTillAllAssigned) |
Modifier and Type | Field and Description |
---|---|
(package private) HRegionInfo[] |
BaseLoadBalancer.Cluster.regions |
Modifier and Type | Field and Description |
---|---|
private com.google.common.cache.LoadingCache<HRegionInfo,HDFSBlocksDistribution> |
RegionLocationFinder.cache |
private Map<ServerName,List<HRegionInfo>> |
ClusterLoadState.clusterState |
(package private) Map<ServerName,List<HRegionInfo>> |
BaseLoadBalancer.Cluster.clusterState |
private static List<HRegionInfo> |
BaseLoadBalancer.EMPTY_REGION_LIST |
private Map<HRegionInfo,List<ServerName>> |
FavoredNodesPlan.favoredNodesMap
the map between each region and its favored region server list
|
private com.google.common.cache.CacheLoader<HRegionInfo,HDFSBlocksDistribution> |
RegionLocationFinder.loader |
(package private) Map<HRegionInfo,Integer> |
BaseLoadBalancer.Cluster.regionsToIndex |
private NavigableMap<ServerAndLoad,List<HRegionInfo>> |
ClusterLoadState.serversByLoad |
Modifier and Type | Method and Description |
---|---|
protected Map<ServerName,List<HRegionInfo>> |
BaseLoadBalancer.assignMasterRegions(Collection<HRegionInfo> regions,
List<ServerName> servers)
Assign the regions that should be on master regionserver.
|
private com.google.common.cache.LoadingCache<HRegionInfo,HDFSBlocksDistribution> |
RegionLocationFinder.createCache()
Create a cache for region to list of servers
|
Map<HRegionInfo,List<ServerName>> |
FavoredNodesPlan.getAssignmentMap() |
(package private) Map<ServerName,List<HRegionInfo>> |
ClusterLoadState.getClusterState() |
protected Map<ServerName,List<HRegionInfo>> |
BaseLoadBalancer.getRegionAssignmentsByServer(Collection<HRegionInfo> regions) |
(package private) NavigableMap<ServerAndLoad,List<HRegionInfo>> |
ClusterLoadState.getServersByLoad() |
Map<HRegionInfo,ServerName> |
BaseLoadBalancer.immediateAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Generates an immediate assignment plan to be used by a new master for
regions in transition that do not have an already known destination.
|
private Map<ServerName,Set<HRegionInfo>> |
FavoredNodeAssignmentHelper.mapRSToPrimaries(Map<HRegionInfo,ServerName> primaryRSMap) |
(package private) Map<HRegionInfo,ServerName[]> |
FavoredNodeAssignmentHelper.placeSecondaryAndTertiaryRS(Map<HRegionInfo,ServerName> primaryRSMap) |
Map<HRegionInfo,ServerName[]> |
FavoredNodeAssignmentHelper.placeSecondaryAndTertiaryWithRestrictions(Map<HRegionInfo,ServerName> primaryRSMap)
For regions that share the primary, avoid placing the secondary and tertiary
on a same RS.
|
Map<ServerName,List<HRegionInfo>> |
BaseLoadBalancer.retainAssignment(Map<HRegionInfo,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<HRegionInfo>> |
FavoredNodeLoadBalancer.roundRobinAssignment(List<HRegionInfo> regions,
List<ServerName> servers) |
Map<ServerName,List<HRegionInfo>> |
BaseLoadBalancer.roundRobinAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Generates a bulk assignment plan to be used on cluster startup using a
simple round-robin assignment.
|
private Pair<Map<ServerName,List<HRegionInfo>>,List<HRegionInfo>> |
FavoredNodeLoadBalancer.segregateRegionsAndAssignRegionsWithFavoredNodes(List<HRegionInfo> regions,
List<ServerName> availableServers) |
private Pair<Map<ServerName,List<HRegionInfo>>,List<HRegionInfo>> |
FavoredNodeLoadBalancer.segregateRegionsAndAssignRegionsWithFavoredNodes(List<HRegionInfo> regions,
List<ServerName> availableServers) |
Modifier and Type | Method and Description |
---|---|
private void |
FavoredNodeLoadBalancer.addRegionToMap(Map<ServerName,List<HRegionInfo>> assignmentMapForFavoredNodes,
HRegionInfo region,
ServerName host) |
private void |
FavoredNodeLoadBalancer.assignRegionToAvailableFavoredNode(Map<ServerName,List<HRegionInfo>> assignmentMapForFavoredNodes,
HRegionInfo region,
ServerName primaryHost,
ServerName secondaryHost,
ServerName tertiaryHost) |
int |
RegionInfoComparator.compare(HRegionInfo l,
HRegionInfo r) |
(package private) void |
BaseLoadBalancer.Cluster.doAssignRegion(HRegionInfo regionInfo,
ServerName serverName) |
HDFSBlocksDistribution |
RegionLocationFinder.getBlockDistribution(HRegionInfo hri) |
List<ServerName> |
FavoredNodeLoadBalancer.getFavoredNodes(HRegionInfo regionInfo) |
List<ServerName> |
FavoredNodesPlan.getFavoredNodes(HRegionInfo region) |
protected List<ServerName> |
RegionLocationFinder.getTopBlockLocations(HRegionInfo region) |
protected HDFSBlocksDistribution |
RegionLocationFinder.internalGetTopBlockLocation(HRegionInfo region)
Returns an ordered list of hosts that are hosting the blocks for this
region.
|
(package private) static Put |
FavoredNodeAssignmentHelper.makePutFromRegionInfo(HRegionInfo regionInfo,
List<ServerName> favoredNodeList)
Generates and returns a Put containing the region info for the catalog table
and the servers
|
private ServerName[] |
FavoredNodeAssignmentHelper.multiRackCase(HRegionInfo regionInfo,
ServerName primaryRS,
String primaryRack) |
private ServerName[] |
FavoredNodeAssignmentHelper.multiRackCaseWithRestrictions(Map<ServerName,Set<HRegionInfo>> serverToPrimaries,
Map<HRegionInfo,ServerName[]> secondaryAndTertiaryMap,
String primaryRack,
ServerName primaryRS,
HRegionInfo regionInfo) |
private ServerName |
BaseLoadBalancer.randomAssignment(BaseLoadBalancer.Cluster cluster,
HRegionInfo regionInfo,
List<ServerName> servers)
Used to assign a single region to a random server.
|
ServerName |
FavoredNodeLoadBalancer.randomAssignment(HRegionInfo regionInfo,
List<ServerName> servers) |
ServerName |
BaseLoadBalancer.randomAssignment(HRegionInfo regionInfo,
List<ServerName> servers)
Used to assign a single region to a random server.
|
void |
BaseLoadBalancer.regionOffline(HRegionInfo regionInfo) |
void |
BaseLoadBalancer.regionOnline(HRegionInfo regionInfo,
ServerName sn) |
private void |
BaseLoadBalancer.Cluster.registerRegion(HRegionInfo region,
int regionIndex,
int serverIndex,
Map<String,Deque<RegionLoad>> loads,
RegionLocationFinder regionFinder)
Helper for Cluster constructor to handle a region
|
boolean |
BaseLoadBalancer.shouldBeOnMaster(HRegionInfo region)
Check if a region belongs to some small system table.
|
private ServerName[] |
FavoredNodeAssignmentHelper.singleRackCase(HRegionInfo regionInfo,
ServerName primaryRS,
String primaryRack) |
void |
FavoredNodesPlan.updateAssignmentPlan(HRegionInfo region,
List<ServerName> servers)
Add an assignment to the plan
|
void |
FavoredNodesPlan.updateFavoredNodesMap(HRegionInfo region,
List<ServerName> servers)
Add an assignment to the plan
|
(package private) boolean |
BaseLoadBalancer.Cluster.wouldLowerAvailability(HRegionInfo regionInfo,
ServerName serverName)
Return true if the placement of region on server would lower the availability
of the region in question
|
Modifier and Type | Method and Description |
---|---|
private void |
FavoredNodeLoadBalancer.addRegionToMap(Map<ServerName,List<HRegionInfo>> assignmentMapForFavoredNodes,
HRegionInfo region,
ServerName host) |
protected Map<ServerName,List<HRegionInfo>> |
BaseLoadBalancer.assignMasterRegions(Collection<HRegionInfo> regions,
List<ServerName> servers)
Assign the regions that should be on master regionserver.
|
private void |
FavoredNodeLoadBalancer.assignRegionToAvailableFavoredNode(Map<ServerName,List<HRegionInfo>> assignmentMapForFavoredNodes,
HRegionInfo region,
ServerName primaryHost,
ServerName secondaryHost,
ServerName tertiaryHost) |
private void |
FavoredNodeLoadBalancer.assignSecondaryAndTertiaryNodesForRegion(FavoredNodeAssignmentHelper assignmentHelper,
List<HRegionInfo> regions,
Map<HRegionInfo,ServerName> primaryRSMap) |
private void |
FavoredNodeLoadBalancer.assignSecondaryAndTertiaryNodesForRegion(FavoredNodeAssignmentHelper assignmentHelper,
List<HRegionInfo> regions,
Map<HRegionInfo,ServerName> primaryRSMap) |
List<RegionPlan> |
FavoredNodeLoadBalancer.balanceCluster(Map<ServerName,List<HRegionInfo>> clusterState) |
List<RegionPlan> |
StochasticLoadBalancer.balanceCluster(Map<ServerName,List<HRegionInfo>> clusterState)
Given the cluster state this will try and approach an optimal balance.
|
List<RegionPlan> |
SimpleLoadBalancer.balanceCluster(Map<ServerName,List<HRegionInfo>> clusterMap)
Generate a global load balancing plan according to the specified map of
server information to the most loaded regions of each server.
|
protected List<RegionPlan> |
BaseLoadBalancer.balanceMasterRegions(Map<ServerName,List<HRegionInfo>> clusterMap)
Balance the regions that should be on master regionserver.
|
protected BaseLoadBalancer.Cluster |
BaseLoadBalancer.createCluster(List<ServerName> servers,
Collection<HRegionInfo> regions) |
protected Map<ServerName,List<HRegionInfo>> |
BaseLoadBalancer.getRegionAssignmentsByServer(Collection<HRegionInfo> regions) |
Map<HRegionInfo,ServerName> |
BaseLoadBalancer.immediateAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Generates an immediate assignment plan to be used by a new master for
regions in transition that do not have an already known destination.
|
private Map<ServerName,Set<HRegionInfo>> |
FavoredNodeAssignmentHelper.mapRSToPrimaries(Map<HRegionInfo,ServerName> primaryRSMap) |
private ServerName[] |
FavoredNodeAssignmentHelper.multiRackCaseWithRestrictions(Map<ServerName,Set<HRegionInfo>> serverToPrimaries,
Map<HRegionInfo,ServerName[]> secondaryAndTertiaryMap,
String primaryRack,
ServerName primaryRS,
HRegionInfo regionInfo) |
private ServerName[] |
FavoredNodeAssignmentHelper.multiRackCaseWithRestrictions(Map<ServerName,Set<HRegionInfo>> serverToPrimaries,
Map<HRegionInfo,ServerName[]> secondaryAndTertiaryMap,
String primaryRack,
ServerName primaryRS,
HRegionInfo regionInfo) |
(package private) void |
FavoredNodeAssignmentHelper.placePrimaryRSAsRoundRobin(Map<ServerName,List<HRegionInfo>> assignmentMap,
Map<HRegionInfo,ServerName> primaryRSMap,
List<HRegionInfo> regions) |
(package private) void |
FavoredNodeAssignmentHelper.placePrimaryRSAsRoundRobin(Map<ServerName,List<HRegionInfo>> assignmentMap,
Map<HRegionInfo,ServerName> primaryRSMap,
List<HRegionInfo> regions) |
(package private) void |
FavoredNodeAssignmentHelper.placePrimaryRSAsRoundRobin(Map<ServerName,List<HRegionInfo>> assignmentMap,
Map<HRegionInfo,ServerName> primaryRSMap,
List<HRegionInfo> regions) |
(package private) Map<HRegionInfo,ServerName[]> |
FavoredNodeAssignmentHelper.placeSecondaryAndTertiaryRS(Map<HRegionInfo,ServerName> primaryRSMap) |
Map<HRegionInfo,ServerName[]> |
FavoredNodeAssignmentHelper.placeSecondaryAndTertiaryWithRestrictions(Map<HRegionInfo,ServerName> primaryRSMap)
For regions that share the primary, avoid placing the secondary and tertiary
on a same RS.
|
Map<ServerName,List<HRegionInfo>> |
BaseLoadBalancer.retainAssignment(Map<HRegionInfo,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.
|
private void |
BaseLoadBalancer.roundRobinAssignment(BaseLoadBalancer.Cluster cluster,
List<HRegionInfo> regions,
List<HRegionInfo> unassignedRegions,
List<ServerName> servers,
Map<ServerName,List<HRegionInfo>> assignments)
Round robin a list of regions to a list of servers
|
private void |
BaseLoadBalancer.roundRobinAssignment(BaseLoadBalancer.Cluster cluster,
List<HRegionInfo> regions,
List<HRegionInfo> unassignedRegions,
List<ServerName> servers,
Map<ServerName,List<HRegionInfo>> assignments)
Round robin a list of regions to a list of servers
|
private void |
BaseLoadBalancer.roundRobinAssignment(BaseLoadBalancer.Cluster cluster,
List<HRegionInfo> regions,
List<HRegionInfo> unassignedRegions,
List<ServerName> servers,
Map<ServerName,List<HRegionInfo>> assignments)
Round robin a list of regions to a list of servers
|
Map<ServerName,List<HRegionInfo>> |
FavoredNodeLoadBalancer.roundRobinAssignment(List<HRegionInfo> regions,
List<ServerName> servers) |
Map<ServerName,List<HRegionInfo>> |
BaseLoadBalancer.roundRobinAssignment(List<HRegionInfo> regions,
List<ServerName> servers)
Generates a bulk assignment plan to be used on cluster startup using a
simple round-robin assignment.
|
private void |
FavoredNodeLoadBalancer.roundRobinAssignmentImpl(FavoredNodeAssignmentHelper assignmentHelper,
Map<ServerName,List<HRegionInfo>> assignmentMap,
List<HRegionInfo> regions,
List<ServerName> servers) |
private void |
FavoredNodeLoadBalancer.roundRobinAssignmentImpl(FavoredNodeAssignmentHelper assignmentHelper,
Map<ServerName,List<HRegionInfo>> assignmentMap,
List<HRegionInfo> regions,
List<ServerName> servers) |
private Pair<Map<ServerName,List<HRegionInfo>>,List<HRegionInfo>> |
FavoredNodeLoadBalancer.segregateRegionsAndAssignRegionsWithFavoredNodes(List<HRegionInfo> regions,
List<ServerName> availableServers) |
static void |
FavoredNodeAssignmentHelper.updateMetaWithFavoredNodesInfo(Map<HRegionInfo,List<ServerName>> regionToFavoredNodes,
org.apache.hadoop.conf.Configuration conf)
Update meta table with favored nodes info
|
static void |
FavoredNodeAssignmentHelper.updateMetaWithFavoredNodesInfo(Map<HRegionInfo,List<ServerName>> regionToFavoredNodes,
Connection connection)
Update meta table with favored nodes info
|
Constructor and Description |
---|
BaseLoadBalancer.Cluster(Collection<HRegionInfo> unassignedRegions,
Map<ServerName,List<HRegionInfo>> clusterState,
Map<String,Deque<RegionLoad>> loads,
RegionLocationFinder regionFinder,
RackManager rackManager) |
BaseLoadBalancer.Cluster(Collection<HRegionInfo> unassignedRegions,
Map<ServerName,List<HRegionInfo>> clusterState,
Map<String,Deque<RegionLoad>> loads,
RegionLocationFinder regionFinder,
RackManager rackManager) |
BaseLoadBalancer.Cluster(Map<ServerName,List<HRegionInfo>> clusterState,
Map<String,Deque<RegionLoad>> loads,
RegionLocationFinder regionFinder,
RackManager rackManager) |
ClusterLoadState(Map<ServerName,List<HRegionInfo>> clusterState) |
Modifier and Type | Field and Description |
---|---|
private HRegionInfo[] |
CreateTableHandler.newRegions |
private HRegionInfo |
DispatchMergingRegionHandler.region_a |
private HRegionInfo |
DispatchMergingRegionHandler.region_b |
private HRegionInfo |
OpenedRegionHandler.regionInfo |
private HRegionInfo |
ClosedRegionHandler.regionInfo |
Modifier and Type | Field and Description |
---|---|
private List<HRegionInfo> |
DisableTableHandler.BulkDisabler.regions |
Modifier and Type | Method and Description |
---|---|
HRegionInfo |
OpenedRegionHandler.getHRegionInfo() |
HRegionInfo |
ClosedRegionHandler.getHRegionInfo() |
HRegionInfo |
TotesHRegionInfo.getHRegionInfo() |
Modifier and Type | Method and Description |
---|---|
protected List<HRegionInfo> |
CreateTableHandler.addReplicas(HTableDescriptor hTableDescriptor,
List<HRegionInfo> regions)
Create any replicas for the regions (the default replicas that was
already created is passed to the method)
|
protected List<HRegionInfo> |
CreateTableHandler.handleCreateHdfsRegions(org.apache.hadoop.fs.Path tableRootDir,
TableName tableName)
Create the on-disk structure for the table, and returns the regions info.
|
private Map<HRegionInfo,ServerName> |
EnableTableHandler.regionsToAssignWithServerName(List<Pair<HRegionInfo,ServerName>> regionsInMeta) |
Modifier and Type | Method and Description |
---|---|
private RegionLoad |
DispatchMergingRegionHandler.getRegionLoad(ServerName sn,
HRegionInfo hri) |
Modifier and Type | Method and Description |
---|---|
protected void |
CreateTableHandler.addRegionsToMeta(List<HRegionInfo> regionInfos,
int regionReplication)
Add the specified set of regions to the hbase:meta table.
|
protected List<HRegionInfo> |
CreateTableHandler.addReplicas(HTableDescriptor hTableDescriptor,
List<HRegionInfo> regions)
Create any replicas for the regions (the default replicas that was
already created is passed to the method)
|
protected abstract void |
TableEventHandler.handleTableOperation(List<HRegionInfo> regions) |
private Map<HRegionInfo,ServerName> |
EnableTableHandler.regionsToAssignWithServerName(List<Pair<HRegionInfo,ServerName>> regionsInMeta) |
boolean |
TableEventHandler.reOpenAllRegions(List<HRegionInfo> regions) |
Constructor and Description |
---|
ClosedRegionHandler(Server server,
AssignmentManager assignmentManager,
HRegionInfo regionInfo) |
CreateTableHandler(Server server,
MasterFileSystem fileSystemManager,
HTableDescriptor hTableDescriptor,
org.apache.hadoop.conf.Configuration conf,
HRegionInfo[] newRegions,
MasterServices masterServices) |
DispatchMergingRegionHandler(MasterServices services,
CatalogJanitor catalogJanitor,
HRegionInfo region_a,
HRegionInfo region_b,
boolean forcible) |
OpenedRegionHandler(Server server,
AssignmentManager assignmentManager,
HRegionInfo regionInfo,
OpenRegionCoordination coordination,
OpenRegionCoordination.OpenRegionDetails ord) |
Constructor and Description |
---|
DisableTableHandler.BulkDisabler(Server server,
List<HRegionInfo> regions) |
Modifier and Type | Field and Description |
---|---|
private HRegionInfo |
MergeNormalizationPlan.firstRegion |
private HRegionInfo |
SplitNormalizationPlan.regionInfo |
private HRegionInfo |
MergeNormalizationPlan.secondRegion |
Modifier and Type | Method and Description |
---|---|
(package private) HRegionInfo |
MergeNormalizationPlan.getFirstRegion() |
HRegionInfo |
SplitNormalizationPlan.getRegionInfo() |
(package private) HRegionInfo |
MergeNormalizationPlan.getSecondRegion() |
Modifier and Type | Method and Description |
---|---|
private long |
SimpleRegionNormalizer.getRegionSize(HRegionInfo hri) |
void |
SplitNormalizationPlan.setRegionInfo(HRegionInfo regionInfo) |
Constructor and Description |
---|
MergeNormalizationPlan(HRegionInfo firstRegion,
HRegionInfo secondRegion) |
SplitNormalizationPlan(HRegionInfo regionInfo,
byte[] splitPoint) |
Modifier and Type | Field and Description |
---|---|
private static Set<HRegionInfo> |
ServerCrashProcedure.META_REGION_SET |
private List<HRegionInfo> |
CreateTableProcedure.newRegions |
private List<HRegionInfo> |
ModifyTableProcedure.regionInfoList |
private List<HRegionInfo> |
DeleteColumnFamilyProcedure.regionInfoList |
private List<HRegionInfo> |
AddColumnFamilyProcedure.regionInfoList |
private List<HRegionInfo> |
TruncateTableProcedure.regions |
private List<HRegionInfo> |
DeleteTableProcedure.regions |
private List<HRegionInfo> |
DisableTableProcedure.BulkDisabler.regions |
private List<HRegionInfo> |
ServerCrashProcedure.regionsAssigned
Regions assigned.
|
private Set<HRegionInfo> |
ServerCrashProcedure.regionsOnCrashedServer
Regions that were on the crashed server.
|
Modifier and Type | Method and Description |
---|---|
private static List<HRegionInfo> |
CreateTableProcedure.addReplicas(MasterProcedureEnv env,
HTableDescriptor hTableDescriptor,
List<HRegionInfo> regions)
Create any replicas for the regions (the default replicas that was
already created is passed to the method)
|
protected static List<HRegionInfo> |
CreateTableProcedure.addTableToMeta(MasterProcedureEnv env,
HTableDescriptor hTableDescriptor,
List<HRegionInfo> regions) |
private List<HRegionInfo> |
ServerCrashProcedure.calcRegionsToAssign(MasterProcedureEnv env)
Figure out what we need to assign.
|
protected static List<HRegionInfo> |
CreateTableProcedure.createFsLayout(MasterProcedureEnv env,
HTableDescriptor hTableDescriptor,
List<HRegionInfo> newRegions) |
protected static List<HRegionInfo> |
CreateTableProcedure.createFsLayout(MasterProcedureEnv env,
HTableDescriptor hTableDescriptor,
List<HRegionInfo> newRegions,
CreateTableProcedure.CreateHdfsRegions hdfsRegionHandler) |
List<HRegionInfo> |
CreateTableProcedure.CreateHdfsRegions.createHdfsRegions(MasterProcedureEnv env,
org.apache.hadoop.fs.Path tableRootDir,
TableName tableName,
List<HRegionInfo> newRegions) |
private List<HRegionInfo> |
ModifyTableProcedure.getRegionInfoList(MasterProcedureEnv env) |
private List<HRegionInfo> |
DeleteColumnFamilyProcedure.getRegionInfoList(MasterProcedureEnv env) |
private List<HRegionInfo> |
AddColumnFamilyProcedure.getRegionInfoList(MasterProcedureEnv env) |
protected static List<HRegionInfo> |
ProcedureSyncWait.getRegionsFromMeta(MasterProcedureEnv env,
TableName tableName) |
private static List<HRegionInfo> |
TruncateTableProcedure.recreateRegionInfo(List<HRegionInfo> regions) |
private static Map<HRegionInfo,ServerName> |
EnableTableProcedure.regionsToAssignWithServerName(MasterProcedureEnv env,
List<Pair<HRegionInfo,ServerName>> regionsInMeta) |
Modifier and Type | Method and Description |
---|---|
private static boolean |
ServerCrashProcedure.processDeadRegion(HRegionInfo hri,
AssignmentManager assignmentManager)
Process a dead region from a dead RS.
|
private boolean |
ServerCrashProcedure.waitOnRegionToClearRegionsInTransition(AssignmentManager am,
HRegionInfo hri,
int timeout) |
Modifier and Type | Method and Description |
---|---|
protected static void |
CreateTableProcedure.addRegionsToMeta(MasterProcedureEnv env,
HTableDescriptor hTableDescriptor,
List<HRegionInfo> regionInfos)
Add the specified set of regions to the hbase:meta table.
|
private static List<HRegionInfo> |
CreateTableProcedure.addReplicas(MasterProcedureEnv env,
HTableDescriptor hTableDescriptor,
List<HRegionInfo> regions)
Create any replicas for the regions (the default replicas that was
already created is passed to the method)
|
protected static List<HRegionInfo> |
CreateTableProcedure.addTableToMeta(MasterProcedureEnv env,
HTableDescriptor hTableDescriptor,
List<HRegionInfo> regions) |
private boolean |
ServerCrashProcedure.assign(MasterProcedureEnv env,
List<HRegionInfo> hris) |
protected static void |
CreateTableProcedure.assignRegions(MasterProcedureEnv env,
TableName tableName,
List<HRegionInfo> regions) |
protected static List<HRegionInfo> |
CreateTableProcedure.createFsLayout(MasterProcedureEnv env,
HTableDescriptor hTableDescriptor,
List<HRegionInfo> newRegions) |
protected static List<HRegionInfo> |
CreateTableProcedure.createFsLayout(MasterProcedureEnv env,
HTableDescriptor hTableDescriptor,
List<HRegionInfo> newRegions,
CreateTableProcedure.CreateHdfsRegions hdfsRegionHandler) |
List<HRegionInfo> |
CreateTableProcedure.CreateHdfsRegions.createHdfsRegions(MasterProcedureEnv env,
org.apache.hadoop.fs.Path tableRootDir,
TableName tableName,
List<HRegionInfo> newRegions) |
static void |
MasterDDLOperationHelper.deleteColumnFamilyFromFileSystem(MasterProcedureEnv env,
TableName tableName,
List<HRegionInfo> regionInfoList,
byte[] familyName)
Remove the column family from the file system
|
protected static void |
DeleteTableProcedure.deleteFromFs(MasterProcedureEnv env,
TableName tableName,
List<HRegionInfo> regions,
boolean archive) |
protected static void |
DeleteTableProcedure.deleteFromMeta(MasterProcedureEnv env,
TableName tableName,
List<HRegionInfo> regions) |
private void |
ServerCrashProcedure.prepareLogReplay(MasterProcedureEnv env,
Set<HRegionInfo> regions) |
private static List<HRegionInfo> |
TruncateTableProcedure.recreateRegionInfo(List<HRegionInfo> regions) |
private static Map<HRegionInfo,ServerName> |
EnableTableProcedure.regionsToAssignWithServerName(MasterProcedureEnv env,
List<Pair<HRegionInfo,ServerName>> regionsInMeta) |
static boolean |
MasterDDLOperationHelper.reOpenAllRegions(MasterProcedureEnv env,
TableName tableName,
List<HRegionInfo> regionInfoList)
Reopen all regions from a table after a schema change operation.
|
(package private) static int |
ServerCrashProcedure.size(Collection<HRegionInfo> hris) |
private boolean |
ServerCrashProcedure.waitOnAssign(MasterProcedureEnv env,
List<HRegionInfo> hris) |
protected static void |
ProcedureSyncWait.waitRegionInTransition(MasterProcedureEnv env,
List<HRegionInfo> regions) |
Constructor and Description |
---|
CreateTableProcedure(MasterProcedureEnv env,
HTableDescriptor hTableDescriptor,
HRegionInfo[] newRegions) |
CreateTableProcedure(MasterProcedureEnv env,
HTableDescriptor hTableDescriptor,
HRegionInfo[] newRegions,
ProcedurePrepareLatch syncLatch) |
Constructor and Description |
---|
DisableTableProcedure.BulkDisabler(MasterProcedureEnv env,
TableName tableName,
List<HRegionInfo> regions) |
Modifier and Type | Method and Description |
---|---|
protected List<HRegionInfo> |
CloneSnapshotHandler.handleCreateHdfsRegions(org.apache.hadoop.fs.Path tableRootDir,
TableName tableName)
Create the on-disk regions, using the tableRootDir provided by the CreateTableHandler.
|
Modifier and Type | Method and Description |
---|---|
protected void |
TakeSnapshotHandler.snapshotDisabledRegion(HRegionInfo regionInfo)
Take a snapshot of the specified disabled region
|
private void |
MasterSnapshotVerifier.verifyRegionInfo(HRegionInfo region,
org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest manifest)
Verify that the regionInfo is valid
|
Modifier and Type | Method and Description |
---|---|
protected void |
CloneSnapshotHandler.addRegionsToMeta(List<HRegionInfo> regionInfos,
int regionReplication) |
private void |
RestoreSnapshotHandler.forceRegionsOffline(List<HRegionInfo> hris) |
protected void |
RestoreSnapshotHandler.handleTableOperation(List<HRegionInfo> hris)
The restore table is executed in place.
|
protected void |
EnabledTableSnapshotHandler.snapshotRegions(List<Pair<HRegionInfo,ServerName>> regions)
This method kicks off a snapshot procedure.
|
void |
DisabledTableSnapshotHandler.snapshotRegions(List<Pair<HRegionInfo,ServerName>> regionsAndLocations) |
protected abstract void |
TakeSnapshotHandler.snapshotRegions(List<Pair<HRegionInfo,ServerName>> regions)
Snapshot the specified regions
|
Modifier and Type | Method and Description |
---|---|
void |
NamespaceAuditor.checkQuotaToSplitRegion(HRegionInfo hri) |
void |
NamespaceAuditor.removeRegionFromNamespaceUsage(HRegionInfo hri) |
void |
NamespaceStateManager.removeRegionFromTable(HRegionInfo hri) |
void |
NamespaceAuditor.updateQuotaForRegionMerge(HRegionInfo hri) |
Modifier and Type | Method and Description |
---|---|
void |
MasterQuotaManager.onRegionMerged(HRegionInfo hri) |
void |
MasterQuotaManager.onRegionSplit(HRegionInfo hri) |
void |
MasterQuotaManager.onRegionSplitReverted(HRegionInfo hri) |
Modifier and Type | Field and Description |
---|---|
private HRegionInfo |
SplitTransactionImpl.LoggingProgressable.hri |
private HRegionInfo |
SplitTransactionImpl.hri_a |
private HRegionInfo |
SplitTransactionImpl.hri_b |
private HRegionInfo[] |
RegionServerServices.RegionStateTransitionContext.hris |
private HRegionInfo |
RegionMergeTransactionImpl.mergedRegionInfo |
private HRegionInfo |
HRegionFileSystem.regionInfo |
private HRegionInfo |
HRegionFileSystem.regionInfoForFs |
Modifier and Type | Method and Description |
---|---|
(package private) HRegionInfo |
SplitTransactionImpl.getFirstDaughter() |
HRegionInfo[] |
RegionServerServices.RegionStateTransitionContext.getHris() |
HRegionInfo |
RegionMergeTransaction.getMergedRegionInfo() |
HRegionInfo |
RegionMergeTransactionImpl.getMergedRegionInfo() |
static HRegionInfo |
RegionMergeTransactionImpl.getMergedRegionInfo(HRegionInfo a,
HRegionInfo b)
Get merged region info through the specified two regions
|
protected HRegionInfo[] |
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.
|
HRegionInfo |
Region.getRegionInfo() |
HRegionInfo |
RegionCoprocessorHost.RegionEnvironment.getRegionInfo() |
HRegionInfo |
Store.getRegionInfo() |
HRegionInfo |
HStore.getRegionInfo() |
HRegionInfo |
HRegionFileSystem.getRegionInfo() |
HRegionInfo |
RegionScanner.getRegionInfo() |
HRegionInfo |
HRegion.getRegionInfo() |
HRegionInfo |
HRegion.RegionScannerImpl.getRegionInfo() |
HRegionInfo |
HRegionFileSystem.getRegionInfoForFS() |
(package private) HRegionInfo |
SplitTransactionImpl.getSecondDaughter() |
static HRegionInfo |
HRegionFileSystem.loadRegionInfoFileContent(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path regionDir)
Create a
HRegionInfo from the serialized version on-disk. |
Modifier and Type | Method and Description |
---|---|
(package private) void |
HRegionFileSystem.cleanupDaughterRegion(HRegionInfo regionInfo)
Remove daughter region
|
(package private) void |
HRegionFileSystem.cleanupMergedRegion(HRegionInfo mergedRegion)
Remove merged region
|
private void |
HRegionServer.closeRegionIgnoreErrors(HRegionInfo region,
boolean abort)
Try to close the region, logs a warning on failure but continues.
|
(package private) org.apache.hadoop.fs.Path |
HRegionFileSystem.commitDaughterRegion(HRegionInfo regionInfo)
Commit a daughter region, moving it from the split temporary directory
to the proper location in the filesystem.
|
(package private) void |
HRegionFileSystem.commitMergedRegion(HRegionInfo mergedRegionInfo)
Commit a merged region, moving it from the merges temporary directory to
the proper location in the filesystem.
|
private void |
CompactionTool.CompactionWorker.compactStoreFiles(org.apache.hadoop.fs.Path tableDir,
HTableDescriptor htd,
HRegionInfo hri,
String familyName,
boolean compactOnce,
boolean major)
Execute the actual compaction job.
|
static HDFSBlocksDistribution |
HRegion.computeHDFSBlocksDistribution(org.apache.hadoop.conf.Configuration conf,
HTableDescriptor tableDescriptor,
HRegionInfo regionInfo)
This is a helper function to compute HDFS block distribution on demand
|
static HDFSBlocksDistribution |
HRegion.computeHDFSBlocksDistribution(org.apache.hadoop.conf.Configuration conf,
HTableDescriptor tableDescriptor,
HRegionInfo regionInfo,
org.apache.hadoop.fs.Path tablePath)
This is a helper function to compute HDFS block distribution on demand
|
(package private) HRegion |
HRegion.createDaughterRegionFromSplits(HRegionInfo hri)
Create a daughter region from given a temp directory with the region data.
|
static HRegion |
HRegion.createHRegion(HRegionInfo info,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.conf.Configuration conf,
HTableDescriptor hTableDescriptor)
Convenience method creating new HRegions.
|
static HRegion |
HRegion.createHRegion(HRegionInfo info,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.conf.Configuration conf,
HTableDescriptor hTableDescriptor,
WAL wal) |
static HRegion |
HRegion.createHRegion(HRegionInfo info,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.conf.Configuration conf,
HTableDescriptor hTableDescriptor,
WAL wal,
boolean initialize)
Convenience method creating new HRegions.
|
static HRegion |
HRegion.createHRegion(HRegionInfo info,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.conf.Configuration conf,
HTableDescriptor hTableDescriptor,
WAL wal,
boolean initialize,
boolean ignoreWAL)
Convenience method creating new HRegions.
|
static HRegion |
HRegion.createHRegion(HRegionInfo info,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.fs.Path tableDir,
org.apache.hadoop.conf.Configuration conf,
HTableDescriptor hTableDescriptor,
WAL wal,
boolean initialize,
boolean ignoreWAL)
Convenience method creating new HRegions.
|
(package private) HRegion |
RegionMergeTransactionImpl.createMergedRegionFromMerges(HRegion a,
HRegion b,
HRegionInfo mergedRegion)
Create a merged region from the merges directory under region a.
|
(package private) HRegion |
HRegion.createMergedRegionFromMerges(HRegionInfo mergedRegionInfo,
HRegion region_b)
Create a merged region given a temp directory with the region data.
|
static HRegionFileSystem |
HRegionFileSystem.createRegionOnFileSystem(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path tableDir,
HRegionInfo regionInfo)
Create a new Region on file-system.
|
static void |
HRegionFileSystem.deleteRegionFromFileSystem(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path tableDir,
HRegionInfo regionInfo)
Remove the region from the table directory, archiving the region's hfiles.
|
private static long |
SplitTransactionImpl.getDaughterRegionIdTimestamp(HRegionInfo hri)
Calculate daughter regionid to use.
|
static HRegionInfo |
RegionMergeTransactionImpl.getMergedRegionInfo(HRegionInfo a,
HRegionInfo b)
Get merged region info through the specified two regions
|
(package private) org.apache.hadoop.fs.Path |
HRegionFileSystem.getMergesDir(HRegionInfo hri) |
static org.apache.hadoop.fs.Path |
HRegion.getRegionDir(org.apache.hadoop.fs.Path rootdir,
HRegionInfo info)
Deprecated.
For tests only; to be removed.
|
private static byte[] |
HRegionFileSystem.getRegionInfoFileContent(HRegionInfo hri) |
(package private) org.apache.hadoop.fs.Path |
HRegionFileSystem.getSplitsDir(HRegionInfo hri) |
private static HStore |
CompactionTool.CompactionWorker.getStore(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path tableDir,
HTableDescriptor htd,
HRegionInfo hri,
String familyName,
org.apache.hadoop.fs.Path tempDir)
Create a "mock" HStore that uses the tmpDir specified by the user and
the store dir to compact as source.
|
static org.apache.hadoop.fs.Path |
HStore.getStoreHomedir(org.apache.hadoop.fs.Path tabledir,
HRegionInfo hri,
byte[] family)
Deprecated.
|
WAL |
RegionServerServices.getWAL(HRegionInfo regionInfo) |
WAL |
HRegionServer.getWAL(HRegionInfo regionInfo) |
private void |
RegionMergeTransactionImpl.mergeRegionsAndPutMetaEntries(HConnection hConnection,
HRegionInfo mergedRegion,
HRegionInfo regionA,
HRegionInfo regionB,
ServerName serverName,
List<Mutation> metaEntries,
int regionReplication) |
(package private) org.apache.hadoop.fs.Path |
HRegionFileSystem.mergeStoreFile(HRegionInfo mergedRegion,
String familyName,
StoreFile f,
org.apache.hadoop.fs.Path mergedDir)
Write out a merge reference under the given merges directory.
|
(package private) static HRegion |
HRegion.newHRegion(org.apache.hadoop.fs.Path tableDir,
WAL wal,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.conf.Configuration conf,
HRegionInfo regionInfo,
HTableDescriptor htd,
RegionServerServices rsServices)
A utility method to create new instances of HRegion based on the
HConstants.REGION_IMPL configuration property. |
private void |
SplitTransactionImpl.offlineParentInMetaAndputMetaEntries(HConnection hConnection,
HRegionInfo parent,
HRegionInfo splitA,
HRegionInfo splitB,
ServerName serverName,
List<Mutation> metaEntries,
int regionReplication) |
static HRegion |
HRegion.openHRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootDir,
HRegionInfo info,
HTableDescriptor htd,
WAL wal)
Open a Region.
|
static HRegion |
HRegion.openHRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootDir,
HRegionInfo info,
HTableDescriptor htd,
WAL wal,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region.
|
static HRegion |
HRegion.openHRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.fs.Path tableDir,
HRegionInfo info,
HTableDescriptor htd,
WAL wal,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region.
|
static HRegion |
HRegion.openHRegion(HRegionInfo info,
HTableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf)
Open a Region.
|
static HRegion |
HRegion.openHRegion(HRegionInfo info,
HTableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region.
|
static HRegion |
HRegion.openHRegion(org.apache.hadoop.fs.Path rootDir,
HRegionInfo info,
HTableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf)
Open a Region.
|
static HRegion |
HRegion.openHRegion(org.apache.hadoop.fs.Path rootDir,
HRegionInfo info,
HTableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region.
|
static HRegionFileSystem |
HRegionFileSystem.openRegionFromFileSystem(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path tableDir,
HRegionInfo regionInfo,
boolean readOnly)
Open Region from file-system.
|
void |
RegionCoprocessorHost.postWALRestore(HRegionInfo info,
HLogKey logKey,
WALEdit logEdit)
|
void |
RegionCoprocessorHost.postWALRestore(HRegionInfo info,
WALKey logKey,
WALEdit logEdit) |
void |
RegionMergeTransactionImpl.prepareMutationsForMerge(HRegionInfo mergedRegion,
HRegionInfo regionA,
HRegionInfo regionB,
ServerName serverName,
List<Mutation> mutations,
int regionReplication) |
boolean |
RegionCoprocessorHost.preWALRestore(HRegionInfo info,
HLogKey logKey,
WALEdit logEdit)
|
boolean |
RegionCoprocessorHost.preWALRestore(HRegionInfo info,
WALKey logKey,
WALEdit logEdit) |
boolean |
RegionServerServices.reportRegionStateTransition(org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode code,
HRegionInfo... hris)
|
boolean |
HRegionServer.reportRegionStateTransition(org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode code,
HRegionInfo... hris) |
boolean |
RegionServerServices.reportRegionStateTransition(org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode code,
long openSeqNum,
HRegionInfo... hris)
|
boolean |
HRegionServer.reportRegionStateTransition(org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode code,
long openSeqNum,
HRegionInfo... hris) |
static boolean |
HRegion.rowIsInRange(HRegionInfo info,
byte[] row)
Determines if the specified row is within the row range specified by the
specified HRegionInfo
|
static boolean |
HRegion.rowIsInRange(HRegionInfo info,
byte[] row,
int offset,
short length) |
(package private) org.apache.hadoop.fs.Path |
HRegionFileSystem.splitStoreFile(HRegionInfo hri,
String familyName,
StoreFile f,
byte[] splitRow,
boolean top,
RegionSplitPolicy splitPolicy)
Write out a split reference.
|
static void |
HRegion.warmupHRegion(HRegionInfo info,
HTableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices rsServices,
CancelableProgressable reporter) |
Constructor and Description |
---|
HRegion(org.apache.hadoop.fs.Path tableDir,
WAL wal,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.conf.Configuration confParam,
HRegionInfo regionInfo,
HTableDescriptor htd,
RegionServerServices rsServices)
Deprecated.
Use other constructors.
|
HRegionFileSystem(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path tableDir,
HRegionInfo regionInfo)
Create a view to the on-disk region
|
RegionServerServices.RegionStateTransitionContext(org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode code,
long openSeqNum,
long masterSystemTime,
HRegionInfo... hris) |
SplitTransactionImpl.LoggingProgressable(HRegionInfo hri,
long interval) |
Modifier and Type | Field and Description |
---|---|
private HRegionInfo |
CloseRegionHandler.regionInfo |
private HRegionInfo |
OpenRegionHandler.regionInfo |
Modifier and Type | Method and Description |
---|---|
HRegionInfo |
CloseRegionHandler.getRegionInfo() |
HRegionInfo |
OpenRegionHandler.getRegionInfo() |
Modifier and Type | Method and Description |
---|---|
private static boolean |
OpenRegionHandler.isRegionStillOpening(HRegionInfo regionInfo,
RegionServerServices rsServices) |
Modifier and Type | Field and Description |
---|---|
private HRegionInfo |
FSWALEntry.hri |
private HRegionInfo |
WALEditsReplaySink.ReplayServerCallable.regionInfo |
Modifier and Type | Method and Description |
---|---|
(package private) HRegionInfo |
FSWALEntry.getHRegionInfo() |
Modifier and Type | Method and Description |
---|---|
long |
FSHLog.append(HTableDescriptor htd,
HRegionInfo hri,
WALKey key,
WALEdit edits,
boolean inMemstore) |
static WALEdit |
WALEdit.createBulkLoadEvent(HRegionInfo hri,
org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor bulkLoadDescriptor)
Create a bulk loader WALEdit
|
static WALEdit |
WALEdit.createCompaction(HRegionInfo hri,
org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor c)
Create a compaction WALEdit
|
static WALEdit |
WALEdit.createFlushWALEdit(HRegionInfo hri,
org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor f) |
static WALEdit |
WALEdit.createRegionEventWALEdit(HRegionInfo hri,
org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor regionEventDesc) |
static byte[] |
WALEdit.getRowForRegion(HRegionInfo hri) |
void |
WALCoprocessorHost.postWALWrite(HRegionInfo info,
WALKey logKey,
WALEdit logEdit) |
boolean |
WALCoprocessorHost.preWALWrite(HRegionInfo info,
WALKey logKey,
WALEdit logEdit) |
private void |
WALEditsReplaySink.replayEdits(HRegionLocation regionLoc,
HRegionInfo regionInfo,
List<WAL.Entry> entries) |
private void |
WALEditsReplaySink.ReplayServerCallable.replayToServer(HRegionInfo regionInfo,
List<WAL.Entry> entries) |
void |
WALActionsListener.visitLogEntryBeforeWrite(HRegionInfo info,
WALKey logKey,
WALEdit logEdit)
Called before each write.
|
void |
WALActionsListener.Base.visitLogEntryBeforeWrite(HRegionInfo info,
WALKey logKey,
WALEdit logEdit) |
static long |
WALUtil.writeBulkLoadMarkerAndSync(WAL wal,
HTableDescriptor htd,
HRegionInfo hri,
org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor desc,
MultiVersionConcurrencyControl mvcc)
Write a log marker that a bulk load has succeeded and is about to be committed.
|
static long |
WALUtil.writeCompactionMarker(WAL wal,
HTableDescriptor htd,
HRegionInfo hri,
org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor c,
MultiVersionConcurrencyControl mvcc)
Write the marker that a compaction has succeeded and is about to be committed.
|
static long |
WALUtil.writeFlushMarker(WAL wal,
HTableDescriptor htd,
HRegionInfo hri,
org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor f,
boolean sync,
MultiVersionConcurrencyControl mvcc)
Write a flush marker indicating a start / abort or a complete of a region flush
|
private static long |
WALUtil.writeMarker(WAL wal,
HTableDescriptor htd,
HRegionInfo hri,
WALEdit edit,
MultiVersionConcurrencyControl mvcc,
boolean sync) |
static long |
WALUtil.writeRegionEventMarker(WAL wal,
HTableDescriptor htd,
HRegionInfo hri,
org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor r,
MultiVersionConcurrencyControl mvcc)
Write a region open marker indicating that the region is opened
|
Constructor and Description |
---|
FSWALEntry(long sequence,
WALKey key,
WALEdit edit,
HTableDescriptor htd,
HRegionInfo hri,
boolean inMemstore) |
WALEditsReplaySink.ReplayServerCallable(HConnection connection,
TableName tableName,
HRegionLocation regionLoc,
HRegionInfo regionInfo,
List<WAL.Entry> entries) |
Constructor and Description |
---|
RegionReplicaReplicationEndpoint.RegionReplicaReplayCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
TableName tableName,
HRegionLocation location,
HRegionInfo regionInfo,
byte[] row,
List<WAL.Entry> entries,
AtomicLong skippedEntries) |
Modifier and Type | Method and Description |
---|---|
void |
AccessController.postCreateTableHandler(ObserverContext<MasterCoprocessorEnvironment> c,
HTableDescriptor desc,
HRegionInfo[] regions) |
void |
AccessController.preAssign(ObserverContext<MasterCoprocessorEnvironment> c,
HRegionInfo regionInfo) |
void |
AccessController.preCreateTable(ObserverContext<MasterCoprocessorEnvironment> c,
HTableDescriptor desc,
HRegionInfo[] regions) |
void |
AccessController.preMove(ObserverContext<MasterCoprocessorEnvironment> c,
HRegionInfo region,
ServerName srcServer,
ServerName destServer) |
void |
AccessController.preRegionOffline(ObserverContext<MasterCoprocessorEnvironment> c,
HRegionInfo regionInfo) |
void |
AccessController.preUnassign(ObserverContext<MasterCoprocessorEnvironment> c,
HRegionInfo regionInfo,
boolean force) |
Modifier and Type | Field and Description |
---|---|
private List<HRegionInfo> |
RestoreSnapshotHelper.RestoreMetaChanges.regionsToAdd |
private List<HRegionInfo> |
RestoreSnapshotHelper.RestoreMetaChanges.regionsToRemove |
private List<HRegionInfo> |
RestoreSnapshotHelper.RestoreMetaChanges.regionsToRestore |
Modifier and Type | Method and Description |
---|---|
private HRegionInfo[] |
RestoreSnapshotHelper.cloneHdfsRegions(ThreadPoolExecutor exec,
Map<String,org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest> regionManifests,
List<HRegionInfo> regions)
Clone specified regions.
|
HRegionInfo |
RestoreSnapshotHelper.cloneRegionInfo(HRegionInfo snapshotRegionInfo)
Create a new
HRegionInfo from the snapshot region info. |
static HRegionInfo |
RestoreSnapshotHelper.cloneRegionInfo(TableName tableName,
HRegionInfo snapshotRegionInfo) |
Modifier and Type | Method and Description |
---|---|
List<HRegionInfo> |
RestoreSnapshotHelper.RestoreMetaChanges.getRegionsToAdd()
Returns the list of new regions added during the on-disk restore.
|
List<HRegionInfo> |
RestoreSnapshotHelper.RestoreMetaChanges.getRegionsToRemove()
Returns the list of regions removed during the on-disk restore.
|
List<HRegionInfo> |
RestoreSnapshotHelper.RestoreMetaChanges.getRegionsToRestore()
Returns the list of 'restored regions' during the on-disk restore.
|
private List<HRegionInfo> |
RestoreSnapshotHelper.getTableRegions() |
Modifier and Type | Method and Description |
---|---|
void |
SnapshotManifest.addRegion(org.apache.hadoop.fs.Path tableDir,
HRegionInfo regionInfo)
Creates a 'manifest' for the specified region, by reading directly from the disk.
|
(package private) void |
RestoreSnapshotHelper.RestoreMetaChanges.addRegionToRemove(HRegionInfo hri) |
(package private) void |
RestoreSnapshotHelper.RestoreMetaChanges.addRegionToRestore(HRegionInfo hri) |
(package private) SnapshotInfo.SnapshotStats.FileInfo |
SnapshotInfo.SnapshotStats.addStoreFile(HRegionInfo region,
String family,
org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile storeFile)
Add the specified store file to the stats
|
(package private) static org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest |
SnapshotManifestV1.buildManifestFromDisk(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path tableDir,
HRegionInfo regionInfo) |
private void |
RestoreSnapshotHelper.cloneRegion(HRegion region,
HRegionInfo snapshotRegionInfo,
org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest manifest)
Clone region directory content from the snapshot info.
|
HRegionInfo |
RestoreSnapshotHelper.cloneRegionInfo(HRegionInfo snapshotRegionInfo)
Create a new
HRegionInfo from the snapshot region info. |
static HRegionInfo |
RestoreSnapshotHelper.cloneRegionInfo(TableName tableName,
HRegionInfo snapshotRegionInfo) |
TRegion |
SnapshotManifest.RegionVisitor.regionOpen(HRegionInfo regionInfo) |
HRegionFileSystem |
SnapshotManifestV1.ManifestBuilder.regionOpen(HRegionInfo regionInfo) |
org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder |
SnapshotManifestV2.ManifestBuilder.regionOpen(HRegionInfo regionInfo) |
private void |
RestoreSnapshotHelper.restoreReferenceFile(org.apache.hadoop.fs.Path familyDir,
HRegionInfo regionInfo,
org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile storeFile)
Create a new
Reference as copy of the source one. |
private void |
RestoreSnapshotHelper.restoreRegion(HRegionInfo regionInfo,
org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest regionManifest)
Restore region by removing files not in the snapshot
and adding the missing ones from the snapshot.
|
private void |
RestoreSnapshotHelper.restoreStoreFile(org.apache.hadoop.fs.Path familyDir,
HRegionInfo regionInfo,
org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile storeFile,
boolean createBackRef)
Create a new
HFileLink to reference the store file. |
(package private) void |
RestoreSnapshotHelper.RestoreMetaChanges.setNewRegions(HRegionInfo[] hris) |
void |
SnapshotReferenceUtil.StoreFileVisitor.storeFile(HRegionInfo regionInfo,
String familyName,
org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile storeFile) |
private static void |
SnapshotReferenceUtil.verifyStoreFile(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path snapshotDir,
org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription snapshot,
HRegionInfo regionInfo,
String family,
org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile storeFile)
Verify the validity of the snapshot store file
|
Modifier and Type | Method and Description |
---|---|
private HRegionInfo[] |
RestoreSnapshotHelper.cloneHdfsRegions(ThreadPoolExecutor exec,
Map<String,org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest> regionManifests,
List<HRegionInfo> regions)
Clone specified regions.
|
private void |
RestoreSnapshotHelper.removeHdfsRegions(ThreadPoolExecutor exec,
List<HRegionInfo> regions)
Remove specified regions from the file-system, using the archiver.
|
private void |
RestoreSnapshotHelper.restoreHdfsRegions(ThreadPoolExecutor exec,
Map<String,org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest> regionManifests,
List<HRegionInfo> regions)
Restore specified regions by restoring content to the snapshot state.
|
void |
RestoreSnapshotHelper.RestoreMetaChanges.updateMetaParentRegions(Connection connection,
List<HRegionInfo> regionInfos) |
Modifier and Type | Field and Description |
---|---|
private List<HRegionInfo> |
RegionListTmpl.ImplData.m_onlineRegions |
private List<HRegionInfo> |
RegionListTmplImpl.onlineRegions |
Modifier and Type | Method and Description |
---|---|
List<HRegionInfo> |
RegionListTmpl.ImplData.getOnlineRegions() |
Modifier and Type | Method and Description |
---|---|
private void |
RegionListTmplImpl.__jamon_innerUnit__baseInfo(Writer jamonWriter,
List<HRegionInfo> onlineRegions) |
private void |
RegionListTmplImpl.__jamon_innerUnit__compactStats(Writer jamonWriter,
List<HRegionInfo> onlineRegions) |
private void |
RegionListTmplImpl.__jamon_innerUnit__memstoreStats(Writer jamonWriter,
List<HRegionInfo> onlineRegions) |
private void |
RegionListTmplImpl.__jamon_innerUnit__requestStats(Writer jamonWriter,
List<HRegionInfo> onlineRegions) |
private void |
RegionListTmplImpl.__jamon_innerUnit__storeStats(Writer jamonWriter,
List<HRegionInfo> onlineRegions) |
org.jamon.Renderer |
RegionListTmpl.makeRenderer(HRegionServer regionServer,
List<HRegionInfo> onlineRegions) |
void |
RegionListTmpl.render(Writer jamonWriter,
HRegionServer regionServer,
List<HRegionInfo> onlineRegions) |
void |
RegionListTmpl.renderNoFlush(Writer jamonWriter,
HRegionServer regionServer,
List<HRegionInfo> onlineRegions) |
void |
RegionListTmpl.ImplData.setOnlineRegions(List<HRegionInfo> onlineRegions) |
Modifier and Type | Field and Description |
---|---|
private HRegionInfo |
Canary.RegionTask.region |
private HRegionInfo |
Canary.RegionServerTask.region |
Modifier and Type | Method and Description |
---|---|
private Map<String,List<HRegionInfo>> |
Canary.RegionServerMonitor.doFilterRegionServerByName(Map<String,List<HRegionInfo>> fullRsAndRMap) |
private Map<String,List<HRegionInfo>> |
Canary.RegionServerMonitor.filterRegionServerByName() |
private Map<String,List<HRegionInfo>> |
Canary.RegionServerMonitor.getAllRegionServerByName() |
Modifier and Type | Method and Description |
---|---|
void |
Canary.Sink.publishReadFailure(HRegionInfo region,
Exception e) |
void |
Canary.StdOutSink.publishReadFailure(HRegionInfo region,
Exception e) |
void |
Canary.Sink.publishReadFailure(HRegionInfo region,
HColumnDescriptor column,
Exception e) |
void |
Canary.StdOutSink.publishReadFailure(HRegionInfo region,
HColumnDescriptor column,
Exception e) |
void |
Canary.Sink.publishReadTiming(HRegionInfo region,
HColumnDescriptor column,
long msTime) |
void |
Canary.StdOutSink.publishReadTiming(HRegionInfo region,
HColumnDescriptor column,
long msTime) |
void |
Canary.Sink.publishWriteFailure(HRegionInfo region,
Exception e) |
void |
Canary.StdOutSink.publishWriteFailure(HRegionInfo region,
Exception e) |
void |
Canary.Sink.publishWriteFailure(HRegionInfo region,
HColumnDescriptor column,
Exception e) |
void |
Canary.StdOutSink.publishWriteFailure(HRegionInfo region,
HColumnDescriptor column,
Exception e) |
void |
Canary.Sink.publishWriteTiming(HRegionInfo region,
HColumnDescriptor column,
long msTime) |
void |
Canary.StdOutSink.publishWriteTiming(HRegionInfo region,
HColumnDescriptor column,
long msTime) |
private static void |
Canary.sniffRegion(Admin admin,
Canary.Sink sink,
HRegionInfo region,
Table table) |
Modifier and Type | Method and Description |
---|---|
private Map<String,List<HRegionInfo>> |
Canary.RegionServerMonitor.doFilterRegionServerByName(Map<String,List<HRegionInfo>> fullRsAndRMap) |
private void |
Canary.RegionServerMonitor.monitorRegionServers(Map<String,List<HRegionInfo>> rsAndRMap) |
Constructor and Description |
---|
Canary.RegionServerTask(Connection connection,
String serverName,
HRegionInfo region,
Canary.ExtendedSink sink,
AtomicLong successes) |
Canary.RegionTask(Connection connection,
HRegionInfo region,
Canary.Sink sink,
Canary.RegionTask.TaskType taskType) |
Modifier and Type | Class and Description |
---|---|
(package private) static class |
HBaseFsck.MetaEntry
Stores the regioninfo entries scanned from META
|
Modifier and Type | Field and Description |
---|---|
(package private) HRegionInfo |
HBaseFsck.HdfsEntry.hri |
(package private) HRegionInfo |
HBaseFsck.OnlineEntry.hri |
private HRegionInfo |
HMerge.OnlineMerger.latestRegion |
private HRegionInfo |
Merge.mergeInfo |
private HRegionInfo |
HBaseFsck.HbckInfo.primaryHRIForDeployedReplica |
(package private) HRegionInfo |
HBaseFsck.MetaEntry.splitA |
(package private) HRegionInfo |
HBaseFsck.MetaEntry.splitB |
Modifier and Type | Field and Description |
---|---|
private com.google.common.collect.ImmutableList<HRegionInfo> |
HBaseFsck.TableInfo.regionsFromMeta |
Modifier and Type | Method and Description |
---|---|
static HRegionInfo[] |
ModifyRegionUtils.createHRegionInfos(HTableDescriptor hTableDescriptor,
byte[][] splitKeys) |
static HRegionInfo |
ModifyRegionUtils.createRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.fs.Path tableDir,
HTableDescriptor hTableDescriptor,
HRegionInfo newRegion,
ModifyRegionUtils.RegionFillTask task)
Create new set of regions on the specified file-system.
|
(package private) HRegionInfo |
HBaseFsck.HbckInfo.getHdfsHRI() |
(package private) HRegionInfo |
Merge.getMergedHRegionInfo() |
HRegionInfo |
HBaseFsck.HbckInfo.getPrimaryHRIForDeployedReplica() |
static HRegionInfo |
ServerRegionReplicaUtil.getRegionInfoForFs(HRegionInfo regionInfo)
Returns the regionInfo object to use for interacting with the file system.
|
protected abstract HRegionInfo[] |
HMerge.Merger.next() |
protected HRegionInfo[] |
HMerge.OnlineMerger.next() |
private HRegionInfo |
HMerge.OnlineMerger.nextRegion() |
Modifier and Type | Method and Description |
---|---|
static List<HRegionInfo> |
ModifyRegionUtils.createRegions(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
HTableDescriptor hTableDescriptor,
HRegionInfo[] newRegions)
Create new set of regions on the specified file-system.
|
static List<HRegionInfo> |
ModifyRegionUtils.createRegions(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
HTableDescriptor hTableDescriptor,
HRegionInfo[] newRegions,
ModifyRegionUtils.RegionFillTask task)
Create new set of regions on the specified file-system.
|
static List<HRegionInfo> |
ModifyRegionUtils.createRegions(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.fs.Path tableDir,
HTableDescriptor hTableDescriptor,
HRegionInfo[] newRegions,
ModifyRegionUtils.RegionFillTask task)
Create new set of regions on the specified file-system.
|
static List<HRegionInfo> |
ModifyRegionUtils.createRegions(ThreadPoolExecutor exec,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.fs.Path tableDir,
HTableDescriptor hTableDescriptor,
HRegionInfo[] newRegions,
ModifyRegionUtils.RegionFillTask task)
Create new set of regions on the specified file-system.
|
private List<HRegionInfo> |
HBaseFsck.WorkItemRegion.filterRegions(List<HRegionInfo> regions) |
com.google.common.collect.ImmutableList<HRegionInfo> |
HBaseFsck.TableInfo.getRegionsFromMeta() |
Modifier and Type | Method and Description |
---|---|
void |
HBaseFsck.HbckInfo.addServer(HRegionInfo hri,
ServerName server) |
static void |
HBaseFsckRepair.closeRegionSilentlyAndWait(HConnection connection,
ServerName server,
HRegionInfo 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,
HRegionInfo hri,
HTableDescriptor htd)
Creates, flushes, and closes a new region.
|
static HRegionInfo |
ModifyRegionUtils.createRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.fs.Path tableDir,
HTableDescriptor hTableDescriptor,
HRegionInfo newRegion,
ModifyRegionUtils.RegionFillTask task)
Create new set of regions on the specified file-system.
|
static List<HRegionInfo> |
ModifyRegionUtils.createRegions(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
HTableDescriptor hTableDescriptor,
HRegionInfo[] newRegions)
Create new set of regions on the specified file-system.
|
static List<HRegionInfo> |
ModifyRegionUtils.createRegions(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
HTableDescriptor hTableDescriptor,
HRegionInfo[] newRegions,
ModifyRegionUtils.RegionFillTask task)
Create new set of regions on the specified file-system.
|
static List<HRegionInfo> |
ModifyRegionUtils.createRegions(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.fs.Path tableDir,
HTableDescriptor hTableDescriptor,
HRegionInfo[] newRegions,
ModifyRegionUtils.RegionFillTask task)
Create new set of regions on the specified file-system.
|
static List<HRegionInfo> |
ModifyRegionUtils.createRegions(ThreadPoolExecutor exec,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.fs.Path tableDir,
HTableDescriptor hTableDescriptor,
HRegionInfo[] newRegions,
ModifyRegionUtils.RegionFillTask task)
Create new set of regions on the specified file-system.
|
static boolean |
FSUtils.deleteRegionDir(org.apache.hadoop.conf.Configuration conf,
HRegionInfo hri)
Delete the region directory if exists.
|
void |
ModifyRegionUtils.RegionEditTask.editRegion(HRegionInfo region) |
static void |
HBaseFsckRepair.fixMetaHoleOnlineAndAddReplicas(org.apache.hadoop.conf.Configuration conf,
HRegionInfo hri,
Collection<ServerName> servers,
int numReplicas)
Puts the specified HRegionInfo into META with replica related columns
|
static void |
HBaseFsckRepair.fixMultiAssignment(HConnection connection,
HRegionInfo 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,
HRegionInfo 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.
|
private static void |
HBaseFsckRepair.forceOfflineInZK(Admin admin,
HRegionInfo region)
In 0.90, this forces an HRI offline by setting the RegionTransitionData
in ZK to have HBCK_CODE_NAME as the server.
|
WAL |
MetaUtils.getLog(HRegionInfo info) |
static HRegionInfo |
ServerRegionReplicaUtil.getRegionInfoForFs(HRegionInfo 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,
HRegionInfo 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,
HRegionInfo regionInfo,
HRegionInfo regionInfoForFs,
String familyName,
org.apache.hadoop.fs.Path path)
Returns a StoreFileInfo from the given FileStatus.
|
private boolean |
HBaseFsck.isTableDisabled(HRegionInfo regionInfo)
Check if the specified region's table is disabled.
|
protected boolean |
HMerge.Merger.merge(HRegionInfo[] info) |
private HRegion |
Merge.merge(HTableDescriptor htd,
HRegion meta,
HRegionInfo info1,
HRegionInfo info2) |
static void |
HBaseFsckRepair.removeParentInMeta(org.apache.hadoop.conf.Configuration conf,
HRegionInfo hri) |
private void |
Merge.removeRegionFromMeta(HRegion meta,
HRegionInfo regioninfo) |
static void |
HBaseFsckRepair.waitUntilAssigned(Admin admin,
HRegionInfo region) |
Modifier and Type | Method and Description |
---|---|
static void |
ModifyRegionUtils.assignRegions(AssignmentManager assignmentManager,
List<HRegionInfo> regionInfos)
Triggers a bulk assignment of the specified regions
|
static void |
ModifyRegionUtils.editRegions(ThreadPoolExecutor exec,
Collection<HRegionInfo> regions,
ModifyRegionUtils.RegionEditTask task)
Execute the task on the specified set of regions.
|
private List<HRegionInfo> |
HBaseFsck.WorkItemRegion.filterRegions(List<HRegionInfo> regions) |
Constructor and Description |
---|
HBaseFsck.MetaEntry(HRegionInfo rinfo,
ServerName regionServer,
long modTime) |
HBaseFsck.MetaEntry(HRegionInfo rinfo,
ServerName regionServer,
long modTime,
HRegionInfo splitA,
HRegionInfo splitB) |
Modifier and Type | Method and Description |
---|---|
long |
WAL.append(HTableDescriptor htd,
HRegionInfo info,
WALKey key,
WALEdit edits,
boolean inMemstore)
Append a set of edits to the WAL.
|
long |
DisabledWALProvider.DisabledWAL.append(HTableDescriptor htd,
HRegionInfo info,
WALKey key,
WALEdit edits,
boolean inMemstore) |
Modifier and Type | Method and Description |
---|---|
private List<HRegionInfo> |
MetaTableLocator.getListOfHRegionInfos(List<Pair<HRegionInfo,ServerName>> pairs) |
List<HRegionInfo> |
MetaTableLocator.getMetaRegions(ZooKeeperWatcher zkw) |
List<HRegionInfo> |
MetaTableLocator.getMetaRegions(ZooKeeperWatcher zkw,
int replicaId) |
List<Pair<HRegionInfo,ServerName>> |
MetaTableLocator.getMetaRegionsAndLocations(ZooKeeperWatcher zkw) |
List<Pair<HRegionInfo,ServerName>> |
MetaTableLocator.getMetaRegionsAndLocations(ZooKeeperWatcher zkw,
int replicaId) |
Modifier and Type | Method and Description |
---|---|
static void |
ZKAssign.asyncCreateNodeOffline(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
org.apache.zookeeper.AsyncCallback.StringCallback cb,
Object ctx)
Creates an unassigned node in the OFFLINE state for the specified region.
|
static boolean |
ZKAssign.checkClosingState(ZooKeeperWatcher zkw,
HRegionInfo region,
int expectedVersion) |
static int |
ZKAssign.confirmNodeOpening(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
int expectedVersion)
Confirm an existing unassigned node for the specified region which is
currently in the OPENING state to be still in the OPENING state on
the specified server.
|
static int |
ZKAssign.createNodeClosing(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName)
Creates a new unassigned node in the CLOSING state for the specified
region.
|
static void |
ZKAssign.createNodeOffline(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName)
Creates a new unassigned node in the OFFLINE state for the specified region.
|
static void |
ZKAssign.createNodeOffline(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
EventType event) |
static int |
ZKAssign.createOrForceNodeOffline(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName)
Creates or force updates an unassigned node to the OFFLINE state for the
specified region.
|
static boolean |
ZKAssign.deleteClosingNode(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName sn)
Deletes an existing unassigned node that is in the CLOSING state for the
specified region.
|
static void |
ZKAssign.deleteNodeFailSilent(ZooKeeperWatcher watcher,
HRegionInfo regionInfo)
Delete the assignment node regardless of its current state.
|
static int |
ZKAssign.getVersion(ZooKeeperWatcher zkw,
HRegionInfo region)
Get the version of the specified znode
|
static int |
ZKAssign.transitionNode(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
EventType beginState,
EventType endState,
int expectedVersion)
Method that actually performs unassigned node transitions.
|
static int |
ZKAssign.transitionNode(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
EventType beginState,
EventType endState,
int expectedVersion,
byte[] payload) |
static int |
ZKAssign.transitionNodeClosed(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
int expectedVersion)
Transitions an existing unassigned node for the specified region which is
currently in the CLOSING state to be in the CLOSED state.
|
static int |
ZKAssign.transitionNodeOpened(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
int expectedVersion)
Transitions an existing unassigned node for the specified region which is
currently in the OPENING state to be in the OPENED state.
|
static int |
ZKAssign.transitionNodeOpening(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName)
Transitions an existing unassigned node for the specified region which is
currently in the OFFLINE state to be in the OPENING state.
|
static int |
ZKAssign.transitionNodeOpening(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
EventType beginState) |
Modifier and Type | Method and Description |
---|---|
private List<HRegionInfo> |
MetaTableLocator.getListOfHRegionInfos(List<Pair<HRegionInfo,ServerName>> pairs) |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.