Modifier and Type | Class and Description |
---|---|
class |
HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
use
RegionInfoBuilder to build RegionInfo . |
Modifier and Type | Field and Description |
---|---|
private RegionInfo |
HRegionLocation.regionInfo |
Modifier and Type | Method and Description |
---|---|
private static RegionInfo |
MetaTableAccessor.getClosestRegionInfo(Connection connection,
TableName tableName,
byte[] row) |
RegionInfo |
HRegionLocation.getRegion() |
static RegionInfo |
MetaTableAccessor.getRegionInfo(Result data)
Returns RegionInfo object from the column
HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog
table Result.
|
static RegionInfo |
MetaTableAccessor.getRegionInfo(Result r,
byte[] qualifier)
Returns the RegionInfo object from the column
HConstants.CATALOG_FAMILY and
qualifier of the catalog table result. |
static RegionInfo |
MetaTableAccessor.parseRegionInfoFromRegionName(byte[] regionName)
Returns an HRI parsed from this regionName.
|
Modifier and Type | Method and Description |
---|---|
static List<RegionInfo> |
MetaTableAccessor.getAllRegions(Connection connection,
boolean excludeOfflinedSplitParents)
Lists all of the regions currently in META.
|
static PairOfSameType<RegionInfo> |
MetaTableAccessor.getDaughterRegions(Result data)
Returns the daughter regions by reading the corresponding columns of the catalog table
Result.
|
private static Optional<RegionInfo> |
AsyncMetaTableAccessor.getHRegionInfo(Result r,
byte[] qualifier)
Returns the RegionInfo object from the column
HConstants.CATALOG_FAMILY and
qualifier of the catalog table result. |
private static List<RegionInfo> |
MetaTableAccessor.getListOfRegionInfos(List<Pair<RegionInfo,ServerName>> pairs) |
static List<RegionInfo> |
MetaTableAccessor.getMergeRegions(Cell[] cells) |
static List<RegionInfo> |
MetaTableAccessor.getMergeRegions(Connection connection,
byte[] regionName) |
static Pair<RegionInfo,ServerName> |
MetaTableAccessor.getRegion(Connection connection,
byte[] regionName)
Deprecated.
|
static NavigableMap<RegionInfo,Result> |
MetaTableAccessor.getServerUserRegions(Connection connection,
ServerName serverName) |
static List<RegionInfo> |
MetaTableAccessor.getTableRegions(Connection connection,
TableName tableName)
Gets all of the regions of the specified table.
|
static List<RegionInfo> |
MetaTableAccessor.getTableRegions(Connection connection,
TableName tableName,
boolean excludeOfflinedSplitParents)
Gets all of the regions of the specified table.
|
private static CompletableFuture<List<Pair<RegionInfo,ServerName>>> |
AsyncMetaTableAccessor.getTableRegionsAndLocations(AsyncTable<AdvancedScanResultConsumer> metaTable,
TableName tableName,
boolean excludeOfflinedSplitParents)
Used to get table regions' info and server.
|
static List<Pair<RegionInfo,ServerName>> |
MetaTableAccessor.getTableRegionsAndLocations(Connection connection,
TableName tableName)
Do not use this method to get meta table regions, use methods in MetaTableLocator instead.
|
static List<Pair<RegionInfo,ServerName>> |
MetaTableAccessor.getTableRegionsAndLocations(Connection connection,
TableName tableName,
boolean excludeOfflinedSplitParents)
Do not use this method to get meta table regions, use methods in MetaTableLocator instead.
|
Modifier and Type | Method and Description |
---|---|
private static Put |
MetaTableAccessor.addDaughtersToPut(Put put,
RegionInfo splitA,
RegionInfo splitB)
Adds split daughters to the Put
|
static Put |
MetaTableAccessor.addRegionInfo(Put p,
RegionInfo hri) |
static void |
MetaTableAccessor.addRegionToMeta(Connection connection,
RegionInfo regionInfo)
Adds a (single) hbase:meta row for the specified new region and its daughters.
|
static void |
MetaTableAccessor.addSplitsToParent(Connection connection,
RegionInfo regionInfo,
RegionInfo splitA,
RegionInfo splitB)
Adds daughter region infos to hbase:meta row for the specified region.
|
static void |
MetaTableAccessor.deleteMergeQualifiers(Connection connection,
RegionInfo mergeRegion)
Deletes merge qualifiers for the specified merge region.
|
static void |
MetaTableAccessor.deleteRegionInfo(Connection connection,
RegionInfo regionInfo)
Deletes the specified region from META.
|
static byte[] |
MetaTableAccessor.getMetaKeyForRegion(RegionInfo regionInfo)
Returns the row key to use for this regionInfo
|
static HRegionLocation |
MetaTableAccessor.getRegionLocation(Connection connection,
RegionInfo regionInfo)
Returns the HRegionLocation from meta for the given region
|
private static HRegionLocation |
AsyncMetaTableAccessor.getRegionLocation(Result r,
RegionInfo regionInfo,
int replicaId)
Returns the HRegionLocation parsed from the given meta row Result
for the given regionInfo and replicaId.
|
private static HRegionLocation |
MetaTableAccessor.getRegionLocation(Result r,
RegionInfo regionInfo,
int replicaId)
Returns the HRegionLocation parsed from the given meta row Result
for the given regionInfo and replicaId.
|
private static Delete |
MetaTableAccessor.makeDeleteFromRegionInfo(RegionInfo regionInfo,
long ts)
Generates and returns a Delete containing the region info for the catalog table
|
static Put |
MetaTableAccessor.makePutForReplicationBarrier(RegionInfo regionInfo,
long openSeqNum,
long ts) |
static Put |
MetaTableAccessor.makePutFromRegionInfo(RegionInfo regionInfo,
long ts)
Generates and returns a Put containing the region into for the catalog table
|
static void |
MetaTableAccessor.mergeRegions(Connection connection,
RegionInfo mergedRegion,
Map<RegionInfo,Long> parentSeqNum,
ServerName sn,
int regionReplication)
Merge regions into one in an atomic operation.
|
void |
RegionStateListener.onRegionMerged(RegionInfo mergedRegion)
Process region merge event.
|
void |
RegionStateListener.onRegionSplit(RegionInfo hri)
Process region split event.
|
void |
RegionStateListener.onRegionSplitReverted(RegionInfo hri)
Process region split reverted event.
|
static void |
MetaTableAccessor.splitRegion(Connection connection,
RegionInfo parent,
long parentOpenSeqNum,
RegionInfo splitA,
RegionInfo splitB,
ServerName sn,
int regionReplication)
Splits the region into two in an atomic operation.
|
private static void |
MetaTableAccessor.updateLocation(Connection connection,
RegionInfo 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,
RegionInfo regionInfo,
ServerName sn,
long openSeqNum,
long masterSystemTime)
Updates the location of the specified region in hbase:meta to be the specified server hostname
and startcode.
|
static void |
MetaTableAccessor.updateRegionState(Connection connection,
RegionInfo ri,
RegionState.State state)
Update state column in hbase:meta.
|
Modifier and Type | Method and Description |
---|---|
(package private) static Put |
MetaTableAccessor.addMergeRegions(Put put,
Collection<RegionInfo> mergeRegions) |
static void |
MetaTableAccessor.addRegionsToMeta(Connection connection,
List<RegionInfo> regionInfos,
int regionReplication)
Adds a hbase:meta row for each of the specified new regions.
|
private static void |
MetaTableAccessor.addRegionsToMeta(Connection connection,
List<RegionInfo> regionInfos,
int regionReplication,
long ts)
Adds a hbase:meta row for each of the specified new regions.
|
private static void |
MetaTableAccessor.addReplicationParent(Put put,
List<RegionInfo> parents) |
static void |
MetaTableAccessor.deleteRegionInfos(Connection connection,
List<RegionInfo> regionsInfo)
Deletes the specified regions from META.
|
private static void |
MetaTableAccessor.deleteRegionInfos(Connection connection,
List<RegionInfo> regionsInfo,
long ts)
Deletes the specified regions from META.
|
private static List<RegionInfo> |
MetaTableAccessor.getListOfRegionInfos(List<Pair<RegionInfo,ServerName>> pairs) |
static byte[] |
MetaTableAccessor.getParentsBytes(List<RegionInfo> parents) |
static void |
MetaTableAccessor.mergeRegions(Connection connection,
RegionInfo mergedRegion,
Map<RegionInfo,Long> parentSeqNum,
ServerName sn,
int regionReplication)
Merge regions into one in an atomic operation.
|
static void |
MetaTableAccessor.overwriteRegions(Connection connection,
List<RegionInfo> regionInfos,
int regionReplication)
Overwrites the specified regions from hbase:meta.
|
Constructor and Description |
---|
HRegionInfo(RegionInfo other)
Deprecated.
Costruct a copy of another HRegionInfo
|
HRegionLocation(RegionInfo regionInfo,
ServerName serverName) |
HRegionLocation(RegionInfo regionInfo,
ServerName serverName,
long seqNum) |
Modifier and Type | Method and Description |
---|---|
private static void |
HFileArchiver.archive(org.apache.hadoop.fs.FileSystem fs,
RegionInfo regionInfo,
byte[] family,
Collection<HStoreFile> compactedFiles,
org.apache.hadoop.fs.Path storeArchiveDir) |
static void |
HFileArchiver.archiveFamily(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.conf.Configuration conf,
RegionInfo parent,
org.apache.hadoop.fs.Path tableDir,
byte[] family)
Remove from the specified region the store files of the specified column family,
either by archiving them or outright deletion
|
static void |
HFileArchiver.archiveFamilyByFamilyDir(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.conf.Configuration conf,
RegionInfo parent,
org.apache.hadoop.fs.Path familyDir,
byte[] family)
Removes from the specified region the store files of the specified column family,
either by archiving them or outright deletion
|
static void |
HFileArchiver.archiveRecoveredEdits(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
RegionInfo regionInfo,
byte[] family,
Collection<HStoreFile> replayedEdits)
Archive recovered edits using existing logic for archiving store files.
|
static void |
HFileArchiver.archiveRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
RegionInfo info)
Cleans up all the files for a HRegion by archiving the HFiles to the archive directory
|
static void |
HFileArchiver.archiveStoreFile(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
RegionInfo regionInfo,
org.apache.hadoop.fs.Path tableDir,
byte[] family,
org.apache.hadoop.fs.Path storeFile)
Archive the store file
|
static void |
HFileArchiver.archiveStoreFiles(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
RegionInfo regionInfo,
org.apache.hadoop.fs.Path tableDir,
byte[] family,
Collection<HStoreFile> compactedFiles)
Remove the store files, either by archiving them or outright deletion
|
static boolean |
HFileArchiver.exists(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
RegionInfo info) |
Modifier and Type | Class and Description |
---|---|
class |
ImmutableHRegionInfo
Deprecated.
|
(package private) static class |
RegionInfoBuilder.MutableRegionInfo
An implementation of RegionInfo that adds mutable methods so can build a RegionInfo instance.
|
(package private) class |
UnmodifyableHRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
|
Modifier and Type | Field and Description |
---|---|
static RegionInfo |
RegionInfoBuilder.FIRST_META_REGIONINFO
RegionInfo for first meta region
You cannot use this builder to make an instance of the
RegionInfoBuilder.FIRST_META_REGIONINFO . |
private RegionInfo |
RegionCoprocessorRpcChannelImpl.region |
(package private) RegionInfo |
HTableMultiplexer.PutStatus.regionInfo |
static RegionInfo |
RegionInfo.UNDEFINED |
Modifier and Type | Field and Description |
---|---|
static Comparator<RegionInfo> |
RegionInfo.COMPARATOR |
private ArrayList<RegionInfo> |
TableSnapshotScanner.regions |
Modifier and Type | Method and Description |
---|---|
RegionInfo |
RegionInfoBuilder.build() |
static RegionInfo |
RegionInfo.createMobRegionInfo(TableName tableName)
Creates a RegionInfo object for MOB data.
|
static RegionInfo |
RegionReplicaUtil.getRegionInfoForDefaultReplica(RegionInfo regionInfo)
Returns the RegionInfo for the default replicaId (0).
|
static RegionInfo |
RegionReplicaUtil.getRegionInfoForReplica(RegionInfo regionInfo,
int replicaId)
Returns the RegionInfo for the given replicaId.
|
static RegionInfo |
RegionInfo.parseFrom(byte[] bytes) |
static RegionInfo |
RegionInfo.parseFrom(byte[] bytes,
int offset,
int len) |
static RegionInfo |
RegionInfo.parseFrom(DataInputStream in)
Parses an RegionInfo instance from the passed in stream.
|
static RegionInfo |
RegionInfo.parseFromOrNull(byte[] bytes) |
static RegionInfo |
RegionInfo.parseFromOrNull(byte[] bytes,
int offset,
int len) |
Modifier and Type | Method and Description |
---|---|
static List<RegionInfo> |
RegionReplicaUtil.addReplicas(TableDescriptor tableDescriptor,
List<RegionInfo> regions,
int oldReplicaCount,
int newReplicaCount)
Create any replicas for the regions (the default replicas that was already created is passed to
the method)
|
(package private) Pair<RegionInfo,ServerName> |
HBaseAdmin.getRegion(byte[] regionName) |
private CompletableFuture<RegionInfo> |
RawAsyncHBaseAdmin.getRegionInfo(byte[] regionNameOrEncodedRegionName)
Get the region info for the passed region name.
|
List<RegionInfo> |
Admin.getRegions(ServerName serverName)
Get all the online regions on a region server.
|
CompletableFuture<List<RegionInfo>> |
AsyncAdmin.getRegions(ServerName serverName)
Get all the online regions on a region server.
|
CompletableFuture<List<RegionInfo>> |
RawAsyncHBaseAdmin.getRegions(ServerName serverName) |
CompletableFuture<List<RegionInfo>> |
AsyncHBaseAdmin.getRegions(ServerName serverName) |
List<RegionInfo> |
HBaseAdmin.getRegions(ServerName sn) |
List<RegionInfo> |
Admin.getRegions(TableName tableName)
Get the regions of a given table.
|
CompletableFuture<List<RegionInfo>> |
AsyncAdmin.getRegions(TableName tableName)
Get the regions of a given table.
|
CompletableFuture<List<RegionInfo>> |
RawAsyncHBaseAdmin.getRegions(TableName tableName) |
CompletableFuture<List<RegionInfo>> |
AsyncHBaseAdmin.getRegions(TableName tableName) |
List<RegionInfo> |
HBaseAdmin.getRegions(TableName tableName) |
static List<RegionInfo> |
RegionInfo.parseDelimitedFrom(byte[] bytes,
int offset,
int length)
Parses all the RegionInfo instances from the passed in stream until EOF.
|
Modifier and Type | Method and Description |
---|---|
static boolean |
RegionInfo.areAdjacent(RegionInfo regionA,
RegionInfo regionB)
Check whether two regions are adjacent; i.e.
|
void |
MetaCache.clearCache(RegionInfo hri)
Deletes the cached location of the region if necessary, based on some error from source.
|
private void |
HBaseAdmin.compact(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface admin,
RegionInfo hri,
boolean major,
byte[] family) |
private CompletableFuture<Void> |
RawAsyncHBaseAdmin.compact(ServerName sn,
RegionInfo hri,
boolean major,
byte[] columnFamily)
Compact the region at specific region server.
|
private static int |
RegionReplicaUtil.compareRegionInfosWithoutReplicaId(RegionInfo regionInfoA,
RegionInfo regionInfoB) |
int |
RegionInfoBuilder.MutableRegionInfo.compareTo(RegionInfo other) |
private <S,R> CompletableFuture<R> |
RawAsyncTableImpl.coprocessorService(Function<com.google.protobuf.RpcChannel,S> stubMaker,
ServiceCaller<S,R> callable,
RegionInfo region,
byte[] row) |
private void |
HBaseAdmin.flush(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface admin,
RegionInfo info) |
private CompletableFuture<Void> |
RawAsyncHBaseAdmin.flush(ServerName serverName,
RegionInfo regionInfo) |
static byte[] |
RegionInfoDisplay.getEndKeyForDisplay(RegionInfo ri,
org.apache.hadoop.conf.Configuration conf)
Get the end key for display.
|
static RegionInfo |
RegionReplicaUtil.getRegionInfoForDefaultReplica(RegionInfo regionInfo)
Returns the RegionInfo for the default replicaId (0).
|
static RegionInfo |
RegionReplicaUtil.getRegionInfoForReplica(RegionInfo regionInfo,
int replicaId)
Returns the RegionInfo for the given replicaId.
|
static String |
RegionInfo.getRegionNameAsString(RegionInfo ri,
byte[] regionName) |
static String |
RegionInfoDisplay.getRegionNameAsStringForDisplay(RegionInfo ri,
org.apache.hadoop.conf.Configuration conf)
Get the region name for display.
|
static byte[] |
RegionInfoDisplay.getRegionNameForDisplay(RegionInfo ri,
org.apache.hadoop.conf.Configuration conf)
Get the region name for display.
|
static String |
RegionInfo.getShortNameToLog(RegionInfo... hris) |
static byte[] |
RegionInfoDisplay.getStartKeyForDisplay(RegionInfo ri,
org.apache.hadoop.conf.Configuration conf)
Get the start key for display.
|
default boolean |
RegionInfo.isAdjacent(RegionInfo other) |
static boolean |
RegionReplicaUtil.isDefaultReplica(RegionInfo hri) |
default boolean |
RegionInfo.isNext(RegionInfo after) |
default boolean |
RegionInfo.isOverlap(RegionInfo other) |
static boolean |
RegionReplicaUtil.isReplicasForSameRegion(RegionInfo regionInfoA,
RegionInfo regionInfoB) |
private boolean |
TableSnapshotScanner.isValidRegion(RegionInfo hri) |
private boolean |
RawAsyncTableImpl.locateFinished(RegionInfo region,
byte[] endKey,
boolean endKeyInclusive) |
private CompletableFuture<Void> |
RawAsyncHBaseAdmin.moveRegion(RegionInfo regionInfo,
org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MoveRegionRequest request) |
static RegionInfoBuilder |
RegionInfoBuilder.newBuilder(RegionInfo regionInfo) |
(package private) static boolean |
ConnectionUtils.noMoreResultsForReverseScan(Scan scan,
RegionInfo info) |
(package private) static boolean |
ConnectionUtils.noMoreResultsForScan(Scan scan,
RegionInfo info) |
void |
AsyncTable.CoprocessorCallback.onRegionComplete(RegionInfo region,
R resp) |
void |
AsyncTable.CoprocessorCallback.onRegionError(RegionInfo region,
Throwable error) |
private CompletableFuture<Void> |
RawAsyncHBaseAdmin.split(RegionInfo hri,
byte[] splitPoint) |
(package private) Future<Void> |
HBaseAdmin.splitRegionAsync(RegionInfo hri,
byte[] splitPoint) |
static byte[] |
RegionInfo.toByteArray(RegionInfo ri) |
static byte[] |
RegionInfo.toDelimitedByteArray(RegionInfo... infos)
Serializes given RegionInfo's as a byte array.
|
static byte[] |
RegionInfo.toDelimitedByteArray(RegionInfo ri)
Use this instead of
toByteArray(RegionInfo) when writing to a stream and you want to use
the pb mergeDelimitedFrom (w/o the delimiter, pb reads to EOF which may not be what you want). |
(package private) void |
ConnectionImplementation.updateCachedLocation(RegionInfo hri,
ServerName source,
ServerName serverName,
long seqNum) |
Modifier and Type | Method and Description |
---|---|
static List<RegionInfo> |
RegionReplicaUtil.addReplicas(TableDescriptor tableDescriptor,
List<RegionInfo> regions,
int oldReplicaCount,
int newReplicaCount)
Create any replicas for the regions (the default replicas that was already created is passed to
the method)
|
private CompletableFuture<CacheEvictionStats> |
RawAsyncHBaseAdmin.clearBlockCache(ServerName serverName,
List<RegionInfo> hris) |
private CacheEvictionStats |
HBaseAdmin.clearBlockCache(ServerName sn,
List<RegionInfo> hris) |
static String |
RegionInfo.getShortNameToLog(List<RegionInfo> ris) |
static void |
RegionReplicaUtil.removeNonDefaultRegions(Collection<RegionInfo> regions)
Removes the non-default replicas from the passed regions collection
|
Constructor and Description |
---|
ClientSideRegionScanner(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootDir,
TableDescriptor htd,
RegionInfo hri,
Scan scan,
ScanMetrics scanMetrics) |
FlushRegionCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
RegionInfo regionInfo,
boolean writeFlushWalMarker) |
ImmutableHRegionInfo(RegionInfo other)
Deprecated.
|
PutStatus(RegionInfo regionInfo,
Put put,
int maxAttempCount) |
RegionCoprocessorRpcChannelImpl(AsyncConnectionImpl conn,
TableName tableName,
RegionInfo region,
byte[] row,
long rpcTimeoutNs,
long operationTimeoutNs) |
RegionInfoBuilder(RegionInfo regionInfo) |
Modifier and Type | Method and Description |
---|---|
protected abstract void |
AsyncAggregationClient.AbstractAggregationCallback.aggregate(RegionInfo region,
org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse resp) |
void |
AsyncAggregationClient.AbstractAggregationCallback.onRegionComplete(RegionInfo region,
org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse resp) |
void |
AsyncAggregationClient.AbstractAggregationCallback.onRegionError(RegionInfo region,
Throwable error) |
Modifier and Type | Method and Description |
---|---|
static org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockRequest |
LockServiceClient.buildLockRequest(org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockType type,
String namespace,
TableName tableName,
List<RegionInfo> regionInfos,
String description,
long nonceGroup,
long nonce) |
EntityLock |
LockServiceClient.regionLock(List<RegionInfo> regionInfos,
String description,
Abortable abort)
Create a new EntityLock object to acquire exclusive lock on multiple regions of same tables.
|
Modifier and Type | Method and Description |
---|---|
RegionInfo |
RegionCoprocessorEnvironment.getRegionInfo() |
Modifier and Type | Method and Description |
---|---|
private static org.apache.hadoop.io.SequenceFile.Writer.Option |
Export.getOutputPath(org.apache.hadoop.conf.Configuration conf,
RegionInfo info,
org.apache.hadoop.hbase.protobuf.generated.ExportProtos.ExportRequest request) |
private static List<org.apache.hadoop.io.SequenceFile.Writer.Option> |
Export.getWriterOptions(org.apache.hadoop.conf.Configuration conf,
RegionInfo info,
org.apache.hadoop.hbase.protobuf.generated.ExportProtos.ExportRequest request) |
default void |
MasterObserver.postAssign(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo regionInfo)
Called after the region assignment has been requested.
|
default void |
MasterObserver.postCompletedCreateTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableDescriptor desc,
RegionInfo[] regions)
Called after the createTable operation has been requested.
|
default void |
MasterObserver.postCompletedMergeRegionsAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo[] regionsToMerge,
RegionInfo mergedRegion)
called after the regions merge.
|
default void |
MasterObserver.postCompletedMergeRegionsAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo[] regionsToMerge,
RegionInfo mergedRegion)
called after the regions merge.
|
default void |
MasterObserver.postCompletedSplitRegionAction(ObserverContext<MasterCoprocessorEnvironment> c,
RegionInfo regionInfoA,
RegionInfo regionInfoB)
Called after the region is split.
|
default void |
MasterObserver.postCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableDescriptor desc,
RegionInfo[] regions)
Called after the createTable operation has been requested.
|
default void |
MasterObserver.postMergeRegions(ObserverContext<MasterCoprocessorEnvironment> c,
RegionInfo[] regionsToMerge)
called after merge regions request.
|
default void |
MasterObserver.postMergeRegionsCommitAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo[] regionsToMerge,
RegionInfo mergedRegion)
This will be called after META step as part of regions merge transaction.
|
default void |
MasterObserver.postMergeRegionsCommitAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo[] regionsToMerge,
RegionInfo mergedRegion)
This will be called after META step as part of regions merge transaction.
|
default void |
MasterObserver.postMove(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo region,
ServerName srcServer,
ServerName destServer)
Called after the region move has been requested.
|
default void |
MasterObserver.postRegionOffline(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo regionInfo)
Called after the region has been marked offline.
|
default void |
RegionObserver.postReplayWALs(ObserverContext<? extends RegionCoprocessorEnvironment> ctx,
RegionInfo info,
org.apache.hadoop.fs.Path edits)
Called after replaying WALs for this region.
|
default void |
MasterObserver.postRequestLock(ObserverContext<MasterCoprocessorEnvironment> ctx,
String namespace,
TableName tableName,
RegionInfo[] regionInfos,
String description)
Called after new LockProcedure is queued.
|
default void |
MasterObserver.postRollBackMergeRegionsAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo[] regionsToMerge)
This will be called after the roll back of the regions merge.
|
default void |
MasterObserver.postUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo regionInfo,
boolean force)
Called after the region unassignment has been requested.
|
default void |
RegionObserver.postWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment> ctx,
RegionInfo info,
WALKey logKey,
WALEdit logEdit)
Called after a
WALEdit
replayed for this region. |
default void |
WALObserver.postWALWrite(ObserverContext<? extends WALCoprocessorEnvironment> ctx,
RegionInfo info,
WALKey logKey,
WALEdit logEdit)
Deprecated.
Since hbase-2.0.0. To be replaced with an alternative that does not expose
InterfaceAudience classes such as WALKey and WALEdit. Will be removed in hbase-3.0.0.
|
default void |
MasterObserver.preAssign(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo regionInfo)
Called prior to assigning a specific region.
|
default void |
MasterObserver.preCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableDescriptor desc,
RegionInfo[] regions)
Called before a new table is created by
HMaster . |
default void |
MasterObserver.preCreateTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableDescriptor desc,
RegionInfo[] regions)
Called before a new table is created by
HMaster . |
default void |
MasterObserver.preMergeRegions(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo[] regionsToMerge)
Called before merge regions request.
|
default void |
MasterObserver.preMergeRegionsAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo[] regionsToMerge)
Called before the regions merge.
|
default void |
MasterObserver.preMergeRegionsCommitAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo[] regionsToMerge,
List<Mutation> metaEntries)
This will be called before update META step as part of regions merge transaction.
|
default void |
MasterObserver.preMove(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo region,
ServerName srcServer,
ServerName destServer)
Called prior to moving a given region from one region server to another.
|
default void |
MasterObserver.preRegionOffline(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo regionInfo)
Called prior to marking a given region as offline.
|
default void |
RegionObserver.preReplayWALs(ObserverContext<? extends RegionCoprocessorEnvironment> ctx,
RegionInfo info,
org.apache.hadoop.fs.Path edits)
Called before replaying WALs for this region.
|
default void |
MasterObserver.preRequestLock(ObserverContext<MasterCoprocessorEnvironment> ctx,
String namespace,
TableName tableName,
RegionInfo[] regionInfos,
String description)
Called before new LockProcedure is queued.
|
default void |
MasterObserver.preUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo regionInfo,
boolean force)
Called prior to unassigning a given region.
|
default void |
RegionObserver.preWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment> ctx,
RegionInfo info,
WALKey logKey,
WALEdit logEdit)
Called before a
WALEdit
replayed for this region. |
default void |
WALObserver.preWALWrite(ObserverContext<? extends WALCoprocessorEnvironment> ctx,
RegionInfo info,
WALKey logKey,
WALEdit logEdit)
Deprecated.
Since hbase-2.0.0. To be replaced with an alternative that does not expose
InterfaceAudience classes such as WALKey and WALEdit. Will be removed in hbase-3.0.0.
|
private Scan |
Export.validateKey(RegionInfo region,
org.apache.hadoop.hbase.protobuf.generated.ExportProtos.ExportRequest request) |
Modifier and Type | Method and Description |
---|---|
void |
ExampleMasterObserverWithMetrics.postCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableDescriptor desc,
RegionInfo[] regions) |
void |
ExampleMasterObserverWithMetrics.preCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableDescriptor desc,
RegionInfo[] regions) |
Modifier and Type | Field and Description |
---|---|
private Map<ServerName,List<RegionInfo>> |
FavoredNodesManager.primaryRSToRegionMap |
private Map<ServerName,List<RegionInfo>> |
FavoredNodesManager.secondaryRSToRegionMap |
private Map<ServerName,List<RegionInfo>> |
FavoredNodesManager.teritiaryRSToRegionMap |
Modifier and Type | Method and Description |
---|---|
private void |
FavoredNodeLoadBalancer.addRegionToMap(Map<ServerName,List<RegionInfo>> assignmentMapForFavoredNodes,
RegionInfo region,
ServerName host) |
private void |
FavoredNodesManager.addToReplicaLoad(RegionInfo hri,
List<ServerName> servers) |
private void |
FavoredNodeLoadBalancer.assignRegionToAvailableFavoredNode(Map<ServerName,List<RegionInfo>> assignmentMapForFavoredNodes,
RegionInfo region,
ServerName primaryHost,
ServerName secondaryHost,
ServerName tertiaryHost) |
void |
FavoredNodesManager.deleteFavoredNodesForRegion(RegionInfo regionInfo) |
List<ServerName> |
FavoredNodeAssignmentHelper.generateFavoredNodes(RegionInfo hri) |
void |
FavoredNodeLoadBalancer.generateFavoredNodesForDaughter(List<ServerName> servers,
RegionInfo parent,
RegionInfo regionA,
RegionInfo regionB) |
void |
FavoredNodesPromoter.generateFavoredNodesForDaughter(List<ServerName> servers,
RegionInfo parent,
RegionInfo hriA,
RegionInfo hriB) |
void |
FavoredNodeLoadBalancer.generateFavoredNodesForMergedRegion(RegionInfo merged,
RegionInfo[] mergeParents) |
void |
FavoredNodeLoadBalancer.generateFavoredNodesForMergedRegion(RegionInfo merged,
RegionInfo[] mergeParents) |
void |
FavoredNodesPromoter.generateFavoredNodesForMergedRegion(RegionInfo merged,
RegionInfo[] mergeParents) |
void |
FavoredNodesPromoter.generateFavoredNodesForMergedRegion(RegionInfo merged,
RegionInfo[] mergeParents) |
List<ServerName> |
FavoredNodesPlan.getFavoredNodes(RegionInfo region) |
List<ServerName> |
FavoredNodeLoadBalancer.getFavoredNodes(RegionInfo regionInfo) |
List<ServerName> |
FavoredNodesManager.getFavoredNodes(RegionInfo regionInfo) |
List<ServerName> |
FavoredNodesManager.getFavoredNodesWithDNPort(RegionInfo regionInfo) |
ServerName[] |
FavoredNodeAssignmentHelper.getSecondaryAndTertiary(RegionInfo regionInfo,
ServerName primaryRS) |
static boolean |
FavoredNodesManager.isFavoredNodeApplicable(RegionInfo regionInfo) |
private static Put |
FavoredNodeAssignmentHelper.makePutFromRegionInfo(RegionInfo regionInfo,
List<ServerName> favoredNodeList)
Generates and returns a Put containing the region info for the catalog table and the servers
|
private ServerName[] |
FavoredNodeAssignmentHelper.multiRackCase(RegionInfo regionInfo,
ServerName primaryRS,
String primaryRack)
Place secondary and tertiary nodes in a multi rack case.
|
private ServerName[] |
FavoredNodeAssignmentHelper.multiRackCaseWithRestrictions(Map<ServerName,Set<RegionInfo>> serverToPrimaries,
Map<RegionInfo,ServerName[]> secondaryAndTertiaryMap,
String primaryRack,
ServerName primaryRS,
RegionInfo regionInfo) |
ServerName |
FavoredNodeLoadBalancer.randomAssignment(RegionInfo regionInfo,
List<ServerName> servers) |
List<ServerName> |
FavoredNodesPlan.removeFavoredNodes(RegionInfo region)
Remove a favored node assignment
|
private ServerName[] |
FavoredNodeAssignmentHelper.singleRackCase(RegionInfo regionInfo,
ServerName primaryRS,
String primaryRack) |
void |
FavoredNodesPlan.updateFavoredNodesMap(RegionInfo region,
List<ServerName> servers)
Update an assignment to the plan
|
Modifier and Type | Method and Description |
---|---|
private void |
FavoredNodeLoadBalancer.addRegionToMap(Map<ServerName,List<RegionInfo>> assignmentMapForFavoredNodes,
RegionInfo region,
ServerName host) |
private void |
FavoredNodeLoadBalancer.assignRegionToAvailableFavoredNode(Map<ServerName,List<RegionInfo>> assignmentMapForFavoredNodes,
RegionInfo region,
ServerName primaryHost,
ServerName secondaryHost,
ServerName tertiaryHost) |
private void |
FavoredNodeLoadBalancer.assignSecondaryAndTertiaryNodesForRegion(FavoredNodeAssignmentHelper assignmentHelper,
List<RegionInfo> regions,
Map<RegionInfo,ServerName> primaryRSMap) |
private void |
FavoredNodeLoadBalancer.assignSecondaryAndTertiaryNodesForRegion(FavoredNodeAssignmentHelper assignmentHelper,
List<RegionInfo> regions,
Map<RegionInfo,ServerName> primaryRSMap) |
List<RegionPlan> |
FavoredNodeLoadBalancer.balanceCluster(Map<ServerName,List<RegionInfo>> clusterState) |
List<RegionPlan> |
FavoredNodeLoadBalancer.balanceCluster(TableName tableName,
Map<ServerName,List<RegionInfo>> clusterState) |
void |
FavoredNodesManager.deleteFavoredNodesForRegions(Collection<RegionInfo> regionInfoList) |
static Set<RegionInfo> |
FavoredNodesManager.filterNonFNApplicableRegions(Collection<RegionInfo> regions)
Filter and return regions for which favored nodes is not applicable.
|
private Map<RegionInfo,List<ServerName>> |
FavoredNodeAssignmentHelper.generateFavoredNodes(Map<RegionInfo,ServerName> primaryRSMap) |
Map<RegionInfo,List<ServerName>> |
FavoredNodeAssignmentHelper.generateFavoredNodesRoundRobin(Map<ServerName,List<RegionInfo>> assignmentMap,
List<RegionInfo> regions) |
Map<RegionInfo,List<ServerName>> |
FavoredNodeAssignmentHelper.generateFavoredNodesRoundRobin(Map<ServerName,List<RegionInfo>> assignmentMap,
List<RegionInfo> regions) |
private Map<ServerName,Set<RegionInfo>> |
FavoredNodeAssignmentHelper.mapRSToPrimaries(Map<RegionInfo,ServerName> primaryRSMap) |
private ServerName[] |
FavoredNodeAssignmentHelper.multiRackCaseWithRestrictions(Map<ServerName,Set<RegionInfo>> serverToPrimaries,
Map<RegionInfo,ServerName[]> secondaryAndTertiaryMap,
String primaryRack,
ServerName primaryRS,
RegionInfo regionInfo) |
private ServerName[] |
FavoredNodeAssignmentHelper.multiRackCaseWithRestrictions(Map<ServerName,Set<RegionInfo>> serverToPrimaries,
Map<RegionInfo,ServerName[]> secondaryAndTertiaryMap,
String primaryRack,
ServerName primaryRS,
RegionInfo regionInfo) |
void |
FavoredNodeAssignmentHelper.placePrimaryRSAsRoundRobin(Map<ServerName,List<RegionInfo>> assignmentMap,
Map<RegionInfo,ServerName> primaryRSMap,
List<RegionInfo> regions) |
void |
FavoredNodeAssignmentHelper.placePrimaryRSAsRoundRobin(Map<ServerName,List<RegionInfo>> assignmentMap,
Map<RegionInfo,ServerName> primaryRSMap,
List<RegionInfo> regions) |
void |
FavoredNodeAssignmentHelper.placePrimaryRSAsRoundRobin(Map<ServerName,List<RegionInfo>> assignmentMap,
Map<RegionInfo,ServerName> primaryRSMap,
List<RegionInfo> regions) |
Map<RegionInfo,ServerName[]> |
FavoredNodeAssignmentHelper.placeSecondaryAndTertiaryRS(Map<RegionInfo,ServerName> primaryRSMap) |
Map<RegionInfo,ServerName[]> |
FavoredNodeAssignmentHelper.placeSecondaryAndTertiaryWithRestrictions(Map<RegionInfo,ServerName> primaryRSMap)
For regions that share the primary, avoid placing the secondary and tertiary
on a same RS.
|
Map<ServerName,List<RegionInfo>> |
FavoredNodeLoadBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers) |
private void |
FavoredNodeLoadBalancer.roundRobinAssignmentImpl(FavoredNodeAssignmentHelper assignmentHelper,
Map<ServerName,List<RegionInfo>> assignmentMap,
List<RegionInfo> regions,
List<ServerName> servers) |
private void |
FavoredNodeLoadBalancer.roundRobinAssignmentImpl(FavoredNodeAssignmentHelper assignmentHelper,
Map<ServerName,List<RegionInfo>> assignmentMap,
List<RegionInfo> regions,
List<ServerName> servers) |
private Pair<Map<ServerName,List<RegionInfo>>,List<RegionInfo>> |
FavoredNodeLoadBalancer.segregateRegionsAndAssignRegionsWithFavoredNodes(List<RegionInfo> regions,
List<ServerName> availableServers) |
void |
FavoredNodesManager.updateFavoredNodes(Map<RegionInfo,List<ServerName>> regionFNMap) |
static void |
FavoredNodeAssignmentHelper.updateMetaWithFavoredNodesInfo(Map<RegionInfo,List<ServerName>> regionToFavoredNodes,
org.apache.hadoop.conf.Configuration conf)
Update meta table with favored nodes info
|
static void |
FavoredNodeAssignmentHelper.updateMetaWithFavoredNodesInfo(Map<RegionInfo,List<ServerName>> regionToFavoredNodes,
Connection connection)
Update meta table with favored nodes info
|
Modifier and Type | Method and Description |
---|---|
static boolean |
HFileLink.create(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path dstFamilyPath,
RegionInfo hfileRegionInfo,
String hfileName)
Create a new HFileLink
|
static boolean |
HFileLink.create(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path dstFamilyPath,
RegionInfo hfileRegionInfo,
String hfileName,
boolean createBackRef)
Create a new HFileLink
|
static String |
HFileLink.createHFileLinkName(RegionInfo hfileRegionInfo,
String hfileName)
Create a new HFileLink name
|
Modifier and Type | Method and Description |
---|---|
RegionInfo |
TableSnapshotInputFormat.TableSnapshotRegionSplit.getRegion() |
Modifier and Type | Field and Description |
---|---|
private RegionInfo |
CatalogJanitor.ReportMakingVisitor.highestEndKeyRegionInfo
Keep account of the highest end key seen as we move through hbase:meta.
|
private RegionInfo |
RegionState.hri |
private RegionInfo |
RegionPlan.hri |
private RegionInfo |
CatalogJanitor.ReportMakingVisitor.previous
RegionInfo from previous row.
|
Modifier and Type | Field and Description |
---|---|
private Map<ServerName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.currentRSToRegionMap
the regionServer to region map
|
private List<Pair<RegionInfo,RegionInfo>> |
CatalogJanitor.Report.holes |
private List<Pair<RegionInfo,RegionInfo>> |
CatalogJanitor.Report.holes |
(package private) Map<RegionInfo,Result> |
CatalogJanitor.Report.mergedRegions |
private List<RegionInfo> |
AssignmentVerificationReport.nonFavoredAssignedRegionList |
private List<Pair<RegionInfo,RegionInfo>> |
CatalogJanitor.Report.overlaps |
private List<Pair<RegionInfo,RegionInfo>> |
CatalogJanitor.Report.overlaps |
private Map<ServerName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.primaryRSToRegionMap |
private Map<String,RegionInfo> |
SnapshotOfRegionAssignmentFromMeta.regionNameToRegionInfoMap
the region name to region info map
|
private List<RegionInfo> |
AssignmentVerificationReport.regionsWithoutValidFavoredNodes |
private Map<RegionInfo,ServerName> |
SnapshotOfRegionAssignmentFromMeta.regionToRegionServerMap
the region to region server map
|
private Map<ServerName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.secondaryRSToRegionMap |
(package private) Map<RegionInfo,Result> |
CatalogJanitor.Report.splitParents |
private Map<TableName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.tableToRegionMap
the table name to region map
|
private Map<ServerName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.teritiaryRSToRegionMap |
private List<RegionInfo> |
AssignmentVerificationReport.unAssignedRegionsList |
private List<Pair<RegionInfo,ServerName>> |
CatalogJanitor.Report.unknownServers
TODO: If CatalogJanitor finds an 'Unknown Server', it should 'fix' it by queuing
a
HBCKServerCrashProcedure for
found server for it to clean up meta. |
Modifier and Type | Method and Description |
---|---|
private RegionInfo |
MetaFixer.buildRegionInfo(TableName tn,
byte[] start,
byte[] end) |
private RegionInfo |
MetaFixer.getHoleCover(Pair<RegionInfo,RegionInfo> hole) |
RegionInfo |
RegionState.getRegion() |
RegionInfo |
RegionPlan.getRegionInfo() |
private RegionInfo |
MasterRpcServices.getRegionInfo(org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionSpecifier rs)
Get RegionInfo from Master using content of RegionSpecifier as key.
|
(package private) static RegionInfo |
MetaFixer.getRegionInfoWithLargestEndKey(RegionInfo a,
RegionInfo b) |
private RegionInfo |
CatalogJanitor.ReportMakingVisitor.metaTableConsistencyCheck(Result metaTableRow)
Check row.
|
Modifier and Type | Method and Description |
---|---|
(package private) static List<SortedSet<RegionInfo>> |
MetaFixer.calculateMerges(int maxMergeCount,
List<Pair<RegionInfo,RegionInfo>> overlaps)
Run through
overlaps and return a list of merges to run. |
List<Pair<RegionInfo,RegionInfo>> |
CatalogJanitor.Report.getHoles() |
List<Pair<RegionInfo,RegionInfo>> |
CatalogJanitor.Report.getHoles() |
(package private) List<RegionInfo> |
AssignmentVerificationReport.getNonFavoredAssignedRegions()
Return the regions not assigned to its favored nodes
|
List<Pair<RegionInfo,RegionInfo>> |
CatalogJanitor.Report.getOverlaps() |
List<Pair<RegionInfo,RegionInfo>> |
CatalogJanitor.Report.getOverlaps() |
Map<ServerName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.getPrimaryToRegionInfoMap() |
Map<String,RegionInfo> |
SnapshotOfRegionAssignmentFromMeta.getRegionNameToRegionInfoMap()
Get the regioninfo for a region
|
Map<ServerName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.getRegionServerToRegionMap()
Get regionserver to region map
|
(package private) List<RegionInfo> |
AssignmentVerificationReport.getRegionsWithoutValidFavoredNodes()
Return the regions without favored nodes
|
Map<RegionInfo,ServerName> |
SnapshotOfRegionAssignmentFromMeta.getRegionToRegionServerMap()
Get region to region server map
|
Map<ServerName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.getSecondaryToRegionInfoMap() |
Map<TableName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.getTableToRegionMap()
Get regions for tables
|
Map<ServerName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.getTertiaryToRegionInfoMap() |
(package private) List<RegionInfo> |
AssignmentVerificationReport.getUnassignedRegions()
Return the unassigned regions
|
List<Pair<RegionInfo,ServerName>> |
CatalogJanitor.Report.getUnknownServers() |
Map<ServerName,List<RegionInfo>> |
LoadBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers)
Assign regions to the previously hosting region server
|
Map<ServerName,List<RegionInfo>> |
LoadBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers)
Perform a Round Robin assignment of regions.
|
Modifier and Type | Method and Description |
---|---|
private void |
SnapshotOfRegionAssignmentFromMeta.addAssignment(RegionInfo regionInfo,
ServerName server) |
private void |
CatalogJanitor.ReportMakingVisitor.addHole(RegionInfo a,
RegionInfo b) |
private void |
CatalogJanitor.ReportMakingVisitor.addOverlap(RegionInfo a,
RegionInfo b) |
private void |
SnapshotOfRegionAssignmentFromMeta.addPrimaryAssignment(RegionInfo regionInfo,
ServerName server) |
private void |
SnapshotOfRegionAssignmentFromMeta.addRegion(RegionInfo regionInfo) |
private void |
SnapshotOfRegionAssignmentFromMeta.addSecondaryAssignment(RegionInfo regionInfo,
ServerName server) |
private void |
SnapshotOfRegionAssignmentFromMeta.addTeritiaryAssignment(RegionInfo regionInfo,
ServerName server) |
private Pair<Boolean,Boolean> |
CatalogJanitor.checkDaughterInFs(RegionInfo parent,
RegionInfo daughter)
Checks if a daughter region -- either splitA or splitB -- still holds
references to parent.
|
boolean |
CatalogJanitor.cleanMergeQualifier(RegionInfo region)
Checks if the specified region has merge qualifiers, if so, try to clean them.
|
private boolean |
CatalogJanitor.cleanMergeRegion(RegionInfo mergedRegion,
List<RegionInfo> parents)
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(RegionInfo parent,
Result rowContent)
If daughters no longer hold reference to the parents, delete the parent.
|
static void |
ServerManager.closeRegionSilentlyAndWait(ClusterConnection connection,
ServerName server,
RegionInfo region,
long timeout)
Contacts a region server and waits up to timeout ms
to close the region.
|
int |
CatalogJanitor.SplitParentFirstComparator.compare(RegionInfo left,
RegionInfo right) |
static RegionState |
RegionState.createForTesting(RegionInfo region,
RegionState.State state) |
void |
MasterFileSystem.deleteFamilyFromFS(org.apache.hadoop.fs.Path rootDir,
RegionInfo region,
byte[] familyName) |
void |
MasterFileSystem.deleteFamilyFromFS(RegionInfo region,
byte[] familyName) |
org.apache.hadoop.fs.Path |
MasterFileSystem.getRegionDir(RegionInfo region) |
(package private) static RegionInfo |
MetaFixer.getRegionInfoWithLargestEndKey(RegionInfo a,
RegionInfo b) |
(package private) static boolean |
MetaFixer.isOverlap(RegionInfo ri,
Pair<RegionInfo,RegionInfo> pair) |
boolean |
ServerManager.isRegionInServerManagerStates(RegionInfo hri) |
private boolean |
HMaster.isRegionOnline(RegionInfo ri) |
(package private) boolean |
CatalogJanitor.ReportMakingVisitor.isTableDisabled(RegionInfo ri) |
private boolean |
CatalogJanitor.ReportMakingVisitor.isTableTransition(RegionInfo ri) |
long |
MasterServices.mergeRegions(RegionInfo[] regionsToMerge,
boolean forcible,
long nonceGroup,
long nonce)
Merge regions in a table.
|
long |
HMaster.mergeRegions(RegionInfo[] regionsToMerge,
boolean forcible,
long ng,
long nonce) |
void |
MasterCoprocessorHost.postAssign(RegionInfo regionInfo) |
void |
MasterCoprocessorHost.postCompletedCreateTableAction(TableDescriptor htd,
RegionInfo[] regions,
User user) |
void |
MasterCoprocessorHost.postCompletedMergeRegionsAction(RegionInfo[] regionsToMerge,
RegionInfo mergedRegion,
User user)
Invoked after completing merge regions operation
|
void |
MasterCoprocessorHost.postCompletedMergeRegionsAction(RegionInfo[] regionsToMerge,
RegionInfo mergedRegion,
User user)
Invoked after completing merge regions operation
|
void |
MasterCoprocessorHost.postCompletedSplitRegionAction(RegionInfo regionInfoA,
RegionInfo regionInfoB,
User user)
Invoked just after a split
|
void |
MasterCoprocessorHost.postCreateTable(TableDescriptor htd,
RegionInfo[] regions) |
void |
MasterCoprocessorHost.postMergeRegions(RegionInfo[] regionsToMerge) |
void |
MasterCoprocessorHost.postMergeRegionsCommit(RegionInfo[] regionsToMerge,
RegionInfo mergedRegion,
User user)
Invoked after merge regions operation writes the new region to hbase:meta
|
void |
MasterCoprocessorHost.postMergeRegionsCommit(RegionInfo[] regionsToMerge,
RegionInfo mergedRegion,
User user)
Invoked after merge regions operation writes the new region to hbase:meta
|
void |
MasterCoprocessorHost.postMove(RegionInfo region,
ServerName srcServer,
ServerName destServer) |
void |
MasterCoprocessorHost.postRegionOffline(RegionInfo regionInfo) |
void |
MasterCoprocessorHost.postRequestLock(String namespace,
TableName tableName,
RegionInfo[] regionInfos,
LockType type,
String description) |
void |
MasterCoprocessorHost.postRollBackMergeRegionsAction(RegionInfo[] regionsToMerge,
User user)
Invoked after rollback merge regions operation
|
void |
MasterCoprocessorHost.postUnassign(RegionInfo regionInfo,
boolean force) |
void |
MasterCoprocessorHost.preAssign(RegionInfo regionInfo) |
void |
MasterCoprocessorHost.preCreateTable(TableDescriptor htd,
RegionInfo[] regions) |
void |
MasterCoprocessorHost.preCreateTableAction(TableDescriptor htd,
RegionInfo[] regions,
User user) |
void |
MasterCoprocessorHost.preMergeRegions(RegionInfo[] regionsToMerge) |
void |
MasterCoprocessorHost.preMergeRegionsAction(RegionInfo[] regionsToMerge,
User user)
Invoked just before a merge
|
void |
MasterCoprocessorHost.preMergeRegionsCommit(RegionInfo[] regionsToMerge,
List<Mutation> metaEntries,
User user)
Invoked before merge regions operation writes the new region to hbase:meta
|
void |
MasterCoprocessorHost.preMove(RegionInfo region,
ServerName srcServer,
ServerName destServer) |
void |
MasterCoprocessorHost.preRegionOffline(RegionInfo regionInfo) |
void |
MasterCoprocessorHost.preRequestLock(String namespace,
TableName tableName,
RegionInfo[] regionInfos,
LockType type,
String description) |
void |
MasterCoprocessorHost.preUnassign(RegionInfo regionInfo,
boolean force) |
ServerName |
LoadBalancer.randomAssignment(RegionInfo regionInfo,
List<ServerName> servers)
Get a random region server from the list
|
void |
LoadBalancer.regionOffline(RegionInfo regionInfo)
Marks the region as offline at balancer.
|
void |
LoadBalancer.regionOnline(RegionInfo regionInfo,
ServerName sn)
Marks the region as online at balancer.
|
void |
ServerManager.removeRegion(RegionInfo regionInfo)
Called by delete table and similar to notify the ServerManager that a region was removed.
|
void |
ServerManager.sendRegionWarmup(ServerName server,
RegionInfo region)
Sends a WARMUP RPC to the specified server to warmup the specified region.
|
long |
MasterServices.splitRegion(RegionInfo regionInfo,
byte[] splitRow,
long nonceGroup,
long nonce)
Split a region.
|
long |
HMaster.splitRegion(RegionInfo regionInfo,
byte[] splitRow,
long nonceGroup,
long nonce) |
Modifier and Type | Method and Description |
---|---|
List<RegionPlan> |
LoadBalancer.balanceCluster(Map<ServerName,List<RegionInfo>> clusterState)
Perform the major balance operation
|
List<RegionPlan> |
LoadBalancer.balanceCluster(TableName tableName,
Map<ServerName,List<RegionInfo>> clusterState)
Perform the major balance operation
|
(package private) static List<SortedSet<RegionInfo>> |
MetaFixer.calculateMerges(int maxMergeCount,
List<Pair<RegionInfo,RegionInfo>> overlaps)
Run through
overlaps and return a list of merges to run. |
(package private) static List<SortedSet<RegionInfo>> |
MetaFixer.calculateMerges(int maxMergeCount,
List<Pair<RegionInfo,RegionInfo>> overlaps)
Run through
overlaps and return a list of merges to run. |
private boolean |
CatalogJanitor.cleanMergeRegion(RegionInfo mergedRegion,
List<RegionInfo> parents)
If merged region no longer holds reference to the merge regions, archive
merge region on hdfs and perform deleting references in hbase:meta
|
private RegionInfo |
MetaFixer.getHoleCover(Pair<RegionInfo,RegionInfo> hole) |
private RegionInfo |
MetaFixer.getHoleCover(Pair<RegionInfo,RegionInfo> hole) |
(package private) static boolean |
MetaFixer.isOverlap(RegionInfo ri,
Pair<RegionInfo,RegionInfo> pair) |
(package private) static boolean |
MetaFixer.isOverlap(RegionInfo ri,
Pair<RegionInfo,RegionInfo> pair) |
void |
ServerManager.removeRegions(List<RegionInfo> regions)
Called by delete table and similar to notify the ServerManager that a region was removed.
|
Map<ServerName,List<RegionInfo>> |
LoadBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers)
Assign regions to the previously hosting region server
|
Map<ServerName,List<RegionInfo>> |
LoadBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers)
Perform a Round Robin assignment of regions.
|
void |
LoadBalancer.setClusterLoad(Map<TableName,Map<ServerName,List<RegionInfo>>> ClusterLoad)
Pass RegionStates and allow balancer to set the current cluster load.
|
Constructor and Description |
---|
RegionPlan(RegionInfo hri,
ServerName source,
ServerName dest)
Instantiate a plan for a region move, moving the specified region from
the specified source server to the specified destination server.
|
RegionState(RegionInfo region,
RegionState.State state,
long stamp,
ServerName serverName) |
RegionState(RegionInfo region,
RegionState.State state,
long stamp,
ServerName serverName,
long ritDuration) |
RegionState(RegionInfo region,
RegionState.State state,
ServerName serverName) |
Modifier and Type | Field and Description |
---|---|
private RegionInfo |
SplitTableRegionProcedure.daughter_1_RI |
private RegionInfo |
SplitTableRegionProcedure.daughter_2_RI |
private RegionInfo |
GCMergedRegionsProcedure.father
Deprecated.
|
private RegionInfo |
GCMergedRegionsProcedure.mergedChild
Deprecated.
|
private RegionInfo |
GCMultipleMergedRegionsProcedure.mergedChild |
private RegionInfo |
MergeTableRegionsProcedure.mergedRegion
The resulting merged region.
|
private RegionInfo |
GCMergedRegionsProcedure.mother
Deprecated.
|
protected RegionInfo |
RegionRemoteProcedureBase.region |
private RegionInfo |
RegionStateNode.regionInfo |
private RegionInfo |
RegionTransitionProcedure.regionInfo
Deprecated.
|
private RegionInfo[] |
MergeTableRegionsProcedure.regionsToMerge
Two or more regions to merge, the 'merge parents'.
|
Modifier and Type | Field and Description |
---|---|
private static Set<RegionInfo> |
AssignmentManager.META_REGION_SET |
private List<RegionInfo> |
GCMultipleMergedRegionsProcedure.parents |
private ConcurrentSkipListMap<RegionInfo,RegionStateNode> |
RegionStates.regionInTransition |
private ConcurrentSkipListMap<RegionInfo,RegionStateNode> |
RegionStates.regionOffline
Regions marked as offline on a read of hbase:meta.
|
private ConcurrentMap<RegionInfo,RegionStateNode> |
RegionStateNode.ritMap |
Modifier and Type | Method and Description |
---|---|
private static RegionInfo |
MergeTableRegionsProcedure.createMergedRegionInfo(RegionInfo[] regionsToMerge)
Create merged region info by looking at passed in
regionsToMerge
to figure what extremes for start and end keys to use; merged region needs
to have an extent sufficient to cover all regions-to-merge. |
(package private) RegionInfo |
MergeTableRegionsProcedure.getMergedRegion() |
private RegionInfo |
AssignmentManager.getMetaForRegion(RegionInfo regionInfo) |
RegionInfo |
AssignmentManager.getMetaRegionFromName(byte[] regionName) |
private RegionInfo |
SplitTableRegionProcedure.getParentRegion() |
RegionInfo |
RegionStates.RegionFailedOpen.getRegionInfo() |
RegionInfo |
RegionStateNode.getRegionInfo() |
RegionInfo |
RegionTransitionProcedure.getRegionInfo()
Deprecated.
|
RegionInfo |
AssignmentManager.getRegionInfo(byte[] regionName) |
Modifier and Type | Method and Description |
---|---|
static TransitRegionStateProcedure |
TransitRegionStateProcedure.assign(MasterProcedureEnv env,
RegionInfo region,
boolean forceNewPlan,
ServerName targetServer) |
static TransitRegionStateProcedure |
TransitRegionStateProcedure.assign(MasterProcedureEnv env,
RegionInfo region,
ServerName targetServer) |
long |
AssignmentManager.assign(RegionInfo regionInfo) |
long |
AssignmentManager.assign(RegionInfo regionInfo,
ServerName sn) |
(package private) static void |
AssignmentManagerUtil.checkClosedRegion(MasterProcedureEnv env,
RegionInfo regionInfo) |
private void |
AssignmentManager.checkMetaLoaded(RegionInfo hri)
Used to check if the meta loading is done.
|
private static void |
MergeTableRegionsProcedure.checkRegionsToMerge(MasterProcedureEnv env,
RegionInfo[] regions,
boolean force) |
private void |
SplitTableRegionProcedure.checkSplittable(MasterProcedureEnv env,
RegionInfo regionToSplit,
byte[] splitRow)
Check whether the region is splittable
|
private static RegionInfo |
MergeTableRegionsProcedure.createMergedRegionInfo(RegionInfo[] regionsToMerge)
Create merged region info by looking at passed in
regionsToMerge
to figure what extremes for start and end keys to use; merged region needs
to have an extent sufficient to cover all regions-to-merge. |
MergeTableRegionsProcedure |
AssignmentManager.createMergeProcedure(RegionInfo... ris) |
TransitRegionStateProcedure |
AssignmentManager.createMoveRegionProcedure(RegionInfo regionInfo,
ServerName targetServer) |
TransitRegionStateProcedure |
AssignmentManager.createOneAssignProcedure(RegionInfo hri,
boolean override)
Create one TransitRegionStateProcedure to assign a region w/o specifying a target server.
|
TransitRegionStateProcedure |
AssignmentManager.createOneUnassignProcedure(RegionInfo hri,
boolean override)
Create one TransitRegionStateProcedure to unassign a region.
|
(package private) RegionStateNode |
RegionStates.createRegionStateNode(RegionInfo regionInfo) |
SplitTableRegionProcedure |
AssignmentManager.createSplitProcedure(RegionInfo regionToSplit,
byte[] splitKey) |
void |
RegionStateStore.deleteRegion(RegionInfo regionInfo) |
void |
RegionStates.deleteRegion(RegionInfo regionInfo) |
private static long |
SplitTableRegionProcedure.getDaughterRegionIdTimestamp(RegionInfo hri)
Calculate daughter regionid to use.
|
RegionStates.RegionFailedOpen |
RegionStates.getFailedOpen(RegionInfo regionInfo) |
List<ServerName> |
AssignmentManager.getFavoredNodes(RegionInfo regionInfo) |
private ProcedureEvent<?> |
AssignmentManager.getMetaAssignEvent(RegionInfo metaRegionInfo) |
private RegionInfo |
AssignmentManager.getMetaForRegion(RegionInfo regionInfo) |
private long |
RegionStateStore.getOpenSeqNumForParentRegion(RegionInfo region) |
RegionStateNode |
RegionStates.getOrCreateRegionStateNode(RegionInfo regionInfo) |
(package private) static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoResponse |
AssignmentManagerUtil.getRegionInfoResponse(MasterProcedureEnv env,
ServerName regionLocation,
RegionInfo hri)
Raw call to remote regionserver to get info on a particular region.
|
(package private) static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoResponse |
AssignmentManagerUtil.getRegionInfoResponse(MasterProcedureEnv env,
ServerName regionLocation,
RegionInfo hri,
boolean includeBestSplitRow) |
ServerName |
RegionStates.getRegionServerOfRegion(RegionInfo regionInfo) |
RegionState |
RegionStates.getRegionState(RegionInfo regionInfo) |
static RegionState.State |
RegionStateStore.getRegionState(Result r,
RegionInfo regionInfo)
Pull the region state from a catalog table
Result . |
RegionStateNode |
RegionStates.getRegionStateNode(RegionInfo regionInfo) |
RegionState |
RegionStates.getRegionTransitionState(RegionInfo hri) |
private void |
AssignmentManager.handleRegionOverStuckWarningThreshold(RegionInfo regionInfo) |
private boolean |
AssignmentManager.isCarryingRegion(ServerName serverName,
RegionInfo regionInfo) |
private boolean |
AssignmentManager.isMetaRegion(RegionInfo regionInfo) |
boolean |
RegionStates.isRegionInRegionStates(RegionInfo hri) |
boolean |
RegionStates.isRegionInState(RegionInfo regionInfo,
RegionState.State... state) |
boolean |
RegionStates.isRegionInTransition(RegionInfo regionInfo) |
boolean |
RegionStates.isRegionOffline(RegionInfo regionInfo) |
boolean |
RegionStates.isRegionOnline(RegionInfo regionInfo) |
boolean |
AssignmentManager.RegionInTransitionStat.isRegionOverThreshold(RegionInfo regionInfo) |
boolean |
AssignmentManager.RegionInTransitionStat.isRegionTwiceOverThreshold(RegionInfo regionInfo) |
void |
AssignmentManager.markRegionAsMerged(RegionInfo child,
ServerName serverName,
RegionInfo[] mergeParents)
When called here, the merge has happened.
|
void |
AssignmentManager.markRegionAsMerged(RegionInfo child,
ServerName serverName,
RegionInfo[] mergeParents)
When called here, the merge has happened.
|
void |
AssignmentManager.markRegionAsSplit(RegionInfo parent,
ServerName serverName,
RegionInfo daughterA,
RegionInfo daughterB) |
void |
RegionStateStore.mergeRegions(RegionInfo child,
RegionInfo[] parents,
ServerName serverName) |
void |
RegionStateStore.mergeRegions(RegionInfo child,
RegionInfo[] parents,
ServerName serverName) |
static TransitRegionStateProcedure |
TransitRegionStateProcedure.move(MasterProcedureEnv env,
RegionInfo region,
ServerName targetServer) |
void |
AssignmentManager.move(RegionInfo regionInfo) |
void |
AssignmentManager.offlineRegion(RegionInfo regionInfo) |
void |
AssignmentManager.onlineRegion(RegionInfo regionInfo,
ServerName serverName) |
void |
RegionStates.removeFromFailedOpen(RegionInfo regionInfo) |
void |
RegionStates.removeFromOfflineRegions(RegionInfo regionInfo) |
static TransitRegionStateProcedure |
TransitRegionStateProcedure.reopen(MasterProcedureEnv env,
RegionInfo region) |
private void |
AssignmentManager.setMetaAssigned(RegionInfo metaRegionInfo,
boolean assigned) |
protected void |
RegionTransitionProcedure.setRegionInfo(RegionInfo regionInfo)
Deprecated.
|
private boolean |
AssignmentManager.shouldAssignFavoredNodes(RegionInfo region) |
void |
RegionStateStore.splitRegion(RegionInfo parent,
RegionInfo hriA,
RegionInfo hriB,
ServerName serverName) |
static TransitRegionStateProcedure |
TransitRegionStateProcedure.unassign(MasterProcedureEnv env,
RegionInfo region) |
long |
AssignmentManager.unassign(RegionInfo regionInfo) |
private void |
RegionStateStore.updateMetaLocation(RegionInfo regionInfo,
ServerName serverName,
RegionState.State state) |
private void |
RegionStateStore.updateRegionLocation(RegionInfo regionInfo,
RegionState.State state,
Put put) |
private void |
AssignmentManager.updateRegionMergeTransition(ServerName serverName,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode state,
RegionInfo merged,
RegionInfo hriA,
RegionInfo hriB) |
private void |
AssignmentManager.updateRegionSplitTransition(ServerName serverName,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode state,
RegionInfo parent,
RegionInfo hriA,
RegionInfo hriB) |
void |
RegionStates.updateRegionState(RegionInfo regionInfo,
RegionState.State state) |
private void |
AssignmentManager.updateRegionTransition(ServerName serverName,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode state,
RegionInfo regionInfo,
long seqId,
long procId) |
private void |
RegionStateStore.updateUserRegionLocation(RegionInfo regionInfo,
RegionState.State state,
ServerName regionLocation,
long openSeqNum,
long pid) |
void |
RegionStateStore.RegionStateVisitor.visitRegionState(Result result,
RegionInfo regionInfo,
RegionState.State state,
ServerName regionLocation,
ServerName lastHost,
long openSeqNum) |
boolean |
AssignmentManager.waitMetaAssigned(Procedure<?> proc,
RegionInfo regionInfo)
Notice that this event does not mean the AM has already finished region state rebuilding.
|
Modifier and Type | Method and Description |
---|---|
private void |
AssignmentManager.acceptPlan(HashMap<RegionInfo,RegionStateNode> regions,
Map<ServerName,List<RegionInfo>> plan) |
private void |
AssignmentManager.acceptPlan(HashMap<RegionInfo,RegionStateNode> regions,
Map<ServerName,List<RegionInfo>> plan) |
private void |
AssignmentManager.addToPendingAssignment(HashMap<RegionInfo,RegionStateNode> regions,
Collection<RegionInfo> pendingRegions) |
private void |
AssignmentManager.addToPendingAssignment(HashMap<RegionInfo,RegionStateNode> regions,
Collection<RegionInfo> pendingRegions) |
private boolean |
AssignmentManager.containsBogusAssignments(Map<RegionInfo,RegionStateNode> regions,
List<RegionInfo> hirs) |
private boolean |
AssignmentManager.containsBogusAssignments(Map<RegionInfo,RegionStateNode> regions,
List<RegionInfo> hirs) |
TransitRegionStateProcedure[] |
AssignmentManager.createAssignProcedures(List<RegionInfo> hris)
Create an array of TransitRegionStateProcedure w/o specifying a target server.
|
private TransitRegionStateProcedure[] |
AssignmentManager.createAssignProcedures(Map<ServerName,List<RegionInfo>> assignments) |
private static TransitRegionStateProcedure[] |
AssignmentManagerUtil.createAssignProcedures(MasterProcedureEnv env,
List<RegionInfo> regions,
int regionReplication,
ServerName targetServer,
boolean ignoreIfInTransition)
Create assign procedures for the give regions, according to the
regionReplication . |
(package private) static TransitRegionStateProcedure[] |
AssignmentManagerUtil.createAssignProceduresForOpeningNewRegions(MasterProcedureEnv env,
List<RegionInfo> regions,
int regionReplication,
ServerName targetServer) |
TransitRegionStateProcedure[] |
AssignmentManager.createRoundRobinAssignProcedures(List<RegionInfo> hris)
Create round-robin assigns.
|
TransitRegionStateProcedure[] |
AssignmentManager.createRoundRobinAssignProcedures(List<RegionInfo> hris,
List<ServerName> serversToExclude)
Create round-robin assigns.
|
private void |
RegionStates.createSnapshot(RegionStateNode node,
Map<ServerName,List<RegionInfo>> result) |
(package private) static TransitRegionStateProcedure[] |
AssignmentManagerUtil.createUnassignProceduresForSplitOrMerge(MasterProcedureEnv env,
Stream<RegionInfo> regions,
int regionReplication) |
void |
RegionStateStore.deleteRegions(List<RegionInfo> regions) |
void |
RegionStates.deleteRegions(List<RegionInfo> regionInfos) |
Map<ServerName,List<RegionInfo>> |
RegionStates.getSnapShotOfAssignment(Collection<RegionInfo> regions) |
Map<ServerName,List<RegionInfo>> |
AssignmentManager.getSnapShotOfAssignment(Collection<RegionInfo> regions) |
private void |
AssignmentManager.processAssignmentPlans(HashMap<RegionInfo,RegionStateNode> regions,
HashMap<RegionInfo,ServerName> retainMap,
List<RegionInfo> hris,
List<ServerName> servers) |
private void |
AssignmentManager.processAssignmentPlans(HashMap<RegionInfo,RegionStateNode> regions,
HashMap<RegionInfo,ServerName> retainMap,
List<RegionInfo> hris,
List<ServerName> servers) |
private void |
AssignmentManager.processAssignmentPlans(HashMap<RegionInfo,RegionStateNode> regions,
HashMap<RegionInfo,ServerName> retainMap,
List<RegionInfo> hris,
List<ServerName> servers) |
(package private) static void |
AssignmentManagerUtil.removeNonDefaultReplicas(MasterProcedureEnv env,
Stream<RegionInfo> regions,
int regionReplication) |
(package private) static void |
AssignmentManagerUtil.reopenRegionsForRollback(MasterProcedureEnv env,
List<RegionInfo> regions,
int regionReplication,
ServerName targetServer) |
Constructor and Description |
---|
GCMultipleMergedRegionsProcedure(MasterProcedureEnv env,
RegionInfo mergedChild,
List<RegionInfo> parents) |
RegionStateNode(RegionInfo regionInfo,
ConcurrentMap<RegionInfo,RegionStateNode> ritMap) |
Modifier and Type | Field and Description |
---|---|
(package private) RegionInfo[] |
BaseLoadBalancer.Cluster.regions |
Modifier and Type | Field and Description |
---|---|
private org.apache.hbase.thirdparty.com.google.common.cache.LoadingCache<RegionInfo,HDFSBlocksDistribution> |
RegionLocationFinder.cache |
(package private) Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.Cluster.clusterState |
private Map<ServerName,List<RegionInfo>> |
ClusterLoadState.clusterState |
private static List<RegionInfo> |
BaseLoadBalancer.EMPTY_REGION_LIST |
private List<RegionInfo> |
SimpleLoadBalancer.BalanceInfo.hriList |
private org.apache.hbase.thirdparty.com.google.common.cache.CacheLoader<RegionInfo,HDFSBlocksDistribution> |
RegionLocationFinder.loader |
(package private) Map<RegionInfo,Integer> |
BaseLoadBalancer.Cluster.regionsToIndex |
private NavigableMap<ServerAndLoad,List<RegionInfo>> |
ClusterLoadState.serversByLoad |
Modifier and Type | Method and Description |
---|---|
protected Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.assignMasterSystemRegions(Collection<RegionInfo> regions,
List<ServerName> servers)
If master is configured to carry system tables only, in here is
where we figure what to assign it.
|
private org.apache.hbase.thirdparty.com.google.common.cache.LoadingCache<RegionInfo,HDFSBlocksDistribution> |
RegionLocationFinder.createCache()
Create a cache for region to list of servers
|
private Map<ServerName,List<RegionInfo>> |
FavoredStochasticBalancer.generateFNForRegionsWithoutFN(FavoredNodeAssignmentHelper helper,
List<RegionInfo> regions) |
(package private) org.apache.hbase.thirdparty.com.google.common.cache.LoadingCache<RegionInfo,HDFSBlocksDistribution> |
RegionLocationFinder.getCache() |
(package private) Map<ServerName,List<RegionInfo>> |
ClusterLoadState.getClusterState() |
(package private) List<RegionInfo> |
SimpleLoadBalancer.BalanceInfo.getHriList() |
protected Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.getRegionAssignmentsByServer(Collection<RegionInfo> regions) |
(package private) NavigableMap<ServerAndLoad,List<RegionInfo>> |
ClusterLoadState.getServersByLoad() |
Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers)
Generates a bulk assignment startup plan, attempting to reuse the existing
assignment information from META, but adjusting for the specified list of
available/online servers available for assignment.
|
Map<ServerName,List<RegionInfo>> |
FavoredStochasticBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers) |
Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers)
Generates a bulk assignment plan to be used on cluster startup using a
simple round-robin assignment.
|
Map<ServerName,List<RegionInfo>> |
FavoredStochasticBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers) |
private Pair<Map<ServerName,List<RegionInfo>>,List<RegionInfo>> |
FavoredStochasticBalancer.segregateRegionsAndAssignRegionsWithFavoredNodes(Collection<RegionInfo> regions,
List<ServerName> onlineServers) |
private Pair<Map<ServerName,List<RegionInfo>>,List<RegionInfo>> |
FavoredStochasticBalancer.segregateRegionsAndAssignRegionsWithFavoredNodes(Collection<RegionInfo> regions,
List<ServerName> onlineServers) |
Modifier and Type | Method and Description |
---|---|
private void |
FavoredStochasticBalancer.addRegionToMap(Map<ServerName,List<RegionInfo>> assignmentMapForFavoredNodes,
RegionInfo region,
ServerName host) |
private void |
FavoredStochasticBalancer.assignRegionToAvailableFavoredNode(Map<ServerName,List<RegionInfo>> assignmentMapForFavoredNodes,
RegionInfo region,
ServerName primaryHost,
ServerName secondaryHost,
ServerName tertiaryHost) |
private org.apache.hbase.thirdparty.com.google.common.util.concurrent.ListenableFuture<HDFSBlocksDistribution> |
RegionLocationFinder.asyncGetBlockDistribution(RegionInfo hri) |
int |
RegionInfoComparator.compare(RegionInfo l,
RegionInfo r) |
(package private) void |
BaseLoadBalancer.Cluster.doAssignRegion(RegionInfo regionInfo,
ServerName serverName) |
void |
FavoredStochasticBalancer.generateFavoredNodesForDaughter(List<ServerName> servers,
RegionInfo parent,
RegionInfo regionA,
RegionInfo regionB) |
void |
FavoredStochasticBalancer.generateFavoredNodesForMergedRegion(RegionInfo merged,
RegionInfo[] mergeParents) |
void |
FavoredStochasticBalancer.generateFavoredNodesForMergedRegion(RegionInfo merged,
RegionInfo[] mergeParents) |
HDFSBlocksDistribution |
RegionLocationFinder.getBlockDistribution(RegionInfo hri) |
List<ServerName> |
FavoredStochasticBalancer.getFavoredNodes(RegionInfo regionInfo) |
protected List<ServerName> |
RegionLocationFinder.getTopBlockLocations(RegionInfo region) |
protected List<ServerName> |
RegionLocationFinder.getTopBlockLocations(RegionInfo region,
String currentHost)
Returns an ordered list of hosts which have better locality for this region
than the current host.
|
protected HDFSBlocksDistribution |
RegionLocationFinder.internalGetTopBlockLocation(RegionInfo region)
Returns an ordered list of hosts that are hosting the blocks for this
region.
|
private ServerName |
BaseLoadBalancer.randomAssignment(BaseLoadBalancer.Cluster cluster,
RegionInfo regionInfo,
List<ServerName> servers)
Used to assign a single region to a random server.
|
ServerName |
BaseLoadBalancer.randomAssignment(RegionInfo regionInfo,
List<ServerName> servers)
Used to assign a single region to a random server.
|
ServerName |
FavoredStochasticBalancer.randomAssignment(RegionInfo regionInfo,
List<ServerName> servers) |
void |
BaseLoadBalancer.regionOffline(RegionInfo regionInfo) |
void |
BaseLoadBalancer.regionOnline(RegionInfo regionInfo,
ServerName sn) |
private void |
BaseLoadBalancer.Cluster.registerRegion(RegionInfo region,
int regionIndex,
int serverIndex,
Map<String,Deque<BalancerRegionLoad>> loads,
RegionLocationFinder regionFinder)
Helper for Cluster constructor to handle a region
|
boolean |
BaseLoadBalancer.shouldBeOnMaster(RegionInfo region)
Check if a region belongs to some system table.
|
private void |
FavoredStochasticBalancer.updateFavoredNodesForRegion(RegionInfo regionInfo,
List<ServerName> newFavoredNodes) |
(package private) boolean |
BaseLoadBalancer.Cluster.wouldLowerAvailability(RegionInfo 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 |
FavoredStochasticBalancer.addRegionToMap(Map<ServerName,List<RegionInfo>> assignmentMapForFavoredNodes,
RegionInfo region,
ServerName host) |
protected Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.assignMasterSystemRegions(Collection<RegionInfo> regions,
List<ServerName> servers)
If master is configured to carry system tables only, in here is
where we figure what to assign it.
|
private void |
FavoredStochasticBalancer.assignRegionToAvailableFavoredNode(Map<ServerName,List<RegionInfo>> assignmentMapForFavoredNodes,
RegionInfo region,
ServerName primaryHost,
ServerName secondaryHost,
ServerName tertiaryHost) |
List<RegionPlan> |
StochasticLoadBalancer.balanceCluster(Map<ServerName,List<RegionInfo>> clusterState)
Given the cluster state this will try and approach an optimal balance.
|
List<RegionPlan> |
SimpleLoadBalancer.balanceCluster(Map<ServerName,List<RegionInfo>> clusterMap)
Generate a global load balancing plan according to the specified map of
server information to the most loaded regions of each server.
|
List<RegionPlan> |
FavoredStochasticBalancer.balanceCluster(Map<ServerName,List<RegionInfo>> clusterState) |
List<RegionPlan> |
StochasticLoadBalancer.balanceCluster(TableName tableName,
Map<ServerName,List<RegionInfo>> clusterState) |
List<RegionPlan> |
SimpleLoadBalancer.balanceCluster(TableName tableName,
Map<ServerName,List<RegionInfo>> clusterState) |
protected List<RegionPlan> |
BaseLoadBalancer.balanceMasterRegions(Map<ServerName,List<RegionInfo>> clusterMap)
Balance the regions that should be on master regionserver.
|
protected BaseLoadBalancer.Cluster |
BaseLoadBalancer.createCluster(List<ServerName> servers,
Collection<RegionInfo> regions) |
private Map<ServerName,List<RegionInfo>> |
FavoredStochasticBalancer.generateFNForRegionsWithoutFN(FavoredNodeAssignmentHelper helper,
List<RegionInfo> regions) |
protected Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.getRegionAssignmentsByServer(Collection<RegionInfo> regions) |
private void |
FavoredStochasticBalancer.mergeAssignmentMaps(Map<ServerName,List<RegionInfo>> assignmentMap,
Map<ServerName,List<RegionInfo>> otherAssignments) |
private void |
FavoredStochasticBalancer.mergeAssignmentMaps(Map<ServerName,List<RegionInfo>> assignmentMap,
Map<ServerName,List<RegionInfo>> otherAssignments) |
void |
RegionLocationFinder.refreshAndWait(Collection<RegionInfo> hris) |
Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers)
Generates a bulk assignment startup plan, attempting to reuse the existing
assignment information from META, but adjusting for the specified list of
available/online servers available for assignment.
|
Map<ServerName,List<RegionInfo>> |
FavoredStochasticBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers) |
private void |
BaseLoadBalancer.roundRobinAssignment(BaseLoadBalancer.Cluster cluster,
List<RegionInfo> regions,
List<ServerName> servers,
Map<ServerName,List<RegionInfo>> assignments)
Round robin a list of regions to a list of servers
|
private void |
BaseLoadBalancer.roundRobinAssignment(BaseLoadBalancer.Cluster cluster,
List<RegionInfo> regions,
List<ServerName> servers,
Map<ServerName,List<RegionInfo>> assignments)
Round robin a list of regions to a list of servers
|
Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers)
Generates a bulk assignment plan to be used on cluster startup using a
simple round-robin assignment.
|
Map<ServerName,List<RegionInfo>> |
FavoredStochasticBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers) |
private Pair<Map<ServerName,List<RegionInfo>>,List<RegionInfo>> |
FavoredStochasticBalancer.segregateRegionsAndAssignRegionsWithFavoredNodes(Collection<RegionInfo> regions,
List<ServerName> onlineServers) |
void |
BaseLoadBalancer.setClusterLoad(Map<TableName,Map<ServerName,List<RegionInfo>>> clusterLoad) |
void |
SimpleLoadBalancer.setClusterLoad(Map<TableName,Map<ServerName,List<RegionInfo>>> clusterLoad) |
Constructor and Description |
---|
BalanceInfo(int nextRegionForUnload,
int numRegionsAdded,
List<RegionInfo> hriList) |
Cluster(Collection<RegionInfo> unassignedRegions,
Map<ServerName,List<RegionInfo>> clusterState,
Map<String,Deque<BalancerRegionLoad>> loads,
RegionLocationFinder regionFinder,
RackManager rackManager) |
Cluster(Collection<RegionInfo> unassignedRegions,
Map<ServerName,List<RegionInfo>> clusterState,
Map<String,Deque<BalancerRegionLoad>> loads,
RegionLocationFinder regionFinder,
RackManager rackManager) |
Cluster(Map<ServerName,List<RegionInfo>> clusterState,
Map<String,Deque<BalancerRegionLoad>> loads,
RegionLocationFinder regionFinder,
RackManager rackManager) |
ClusterLoadState(Map<ServerName,List<RegionInfo>> clusterState) |
Modifier and Type | Field and Description |
---|---|
private RegionInfo[] |
LockManager.MasterLock.regionInfos |
private RegionInfo[] |
LockProcedure.regionInfos |
Modifier and Type | Method and Description |
---|---|
LockManager.MasterLock |
LockManager.createMasterLock(RegionInfo[] regionInfos,
String description) |
long |
LockManager.RemoteLocks.requestRegionsLock(RegionInfo[] regionInfos,
String description,
NonceKey nonceKey) |
Constructor and Description |
---|
LockProcedure(org.apache.hadoop.conf.Configuration conf,
RegionInfo[] regionInfos,
LockType type,
String description,
CountDownLatch lockAcquireLatch)
Constructor for region lock(s).
|
MasterLock(RegionInfo[] regionInfos,
String description) |
Modifier and Type | Field and Description |
---|---|
private RegionInfo |
MergeNormalizationPlan.firstRegion |
private RegionInfo |
SplitNormalizationPlan.regionInfo |
private RegionInfo |
MergeNormalizationPlan.secondRegion |
Modifier and Type | Method and Description |
---|---|
(package private) RegionInfo |
MergeNormalizationPlan.getFirstRegion() |
RegionInfo |
SplitNormalizationPlan.getRegionInfo() |
(package private) RegionInfo |
MergeNormalizationPlan.getSecondRegion() |
Modifier and Type | Method and Description |
---|---|
private long |
SimpleRegionNormalizer.getRegionSize(RegionInfo hri) |
void |
RegionNormalizer.planSkipped(RegionInfo hri,
NormalizationPlan.PlanType type)
Notification for the case where plan couldn't be executed due to constraint violation, such as
namespace quota
|
void |
SimpleRegionNormalizer.planSkipped(RegionInfo hri,
NormalizationPlan.PlanType type) |
void |
SplitNormalizationPlan.setRegionInfo(RegionInfo regionInfo) |
Constructor and Description |
---|
MergeNormalizationPlan(RegionInfo firstRegion,
RegionInfo secondRegion) |
SplitNormalizationPlan(RegionInfo regionInfo,
byte[] splitPoint) |
Modifier and Type | Field and Description |
---|---|
private RegionInfo |
AbstractStateMachineRegionProcedure.hri |
protected RegionInfo |
RSProcedureDispatcher.RegionOperation.regionInfo |
Modifier and Type | Field and Description |
---|---|
private List<RegionInfo> |
CreateTableProcedure.newRegions |
private List<RegionInfo> |
CloneSnapshotProcedure.newRegions |
private List<RegionInfo> |
HBCKServerCrashProcedure.UnknownServerVisitor.reassigns |
private List<RegionInfo> |
TruncateTableProcedure.regions |
private List<RegionInfo> |
DeleteTableProcedure.regions |
private List<RegionInfo> |
ServerCrashProcedure.regionsOnCrashedServer
Regions that were on the crashed server.
|
private List<RegionInfo> |
RestoreSnapshotProcedure.regionsToAdd |
private List<RegionInfo> |
RestoreSnapshotProcedure.regionsToRemove |
private List<RegionInfo> |
RestoreSnapshotProcedure.regionsToRestore |
Modifier and Type | Method and Description |
---|---|
(package private) RegionInfo |
TruncateTableProcedure.getFirstRegionInfo() |
(package private) RegionInfo |
CreateTableProcedure.getFirstRegionInfo() |
RegionInfo |
AbstractStateMachineRegionProcedure.getRegion() |
Modifier and Type | Method and Description |
---|---|
protected static List<RegionInfo> |
CreateTableProcedure.addTableToMeta(MasterProcedureEnv env,
TableDescriptor tableDescriptor,
List<RegionInfo> regions) |
private List<RegionInfo> |
CloneSnapshotProcedure.createFilesystemLayout(MasterProcedureEnv env,
TableDescriptor tableDescriptor,
List<RegionInfo> newRegions)
Create regions in file system.
|
protected static List<RegionInfo> |
CreateTableProcedure.createFsLayout(MasterProcedureEnv env,
TableDescriptor tableDescriptor,
List<RegionInfo> newRegions) |
protected static List<RegionInfo> |
CreateTableProcedure.createFsLayout(MasterProcedureEnv env,
TableDescriptor tableDescriptor,
List<RegionInfo> newRegions,
CreateTableProcedure.CreateHdfsRegions hdfsRegionHandler) |
private List<RegionInfo> |
CloneSnapshotProcedure.createFsLayout(MasterProcedureEnv env,
TableDescriptor tableDescriptor,
List<RegionInfo> newRegions,
CreateTableProcedure.CreateHdfsRegions hdfsRegionHandler)
Create region layout in file system.
|
List<RegionInfo> |
CreateTableProcedure.CreateHdfsRegions.createHdfsRegions(MasterProcedureEnv env,
org.apache.hadoop.fs.Path tableRootDir,
TableName tableName,
List<RegionInfo> newRegions) |
private List<RegionInfo> |
HBCKServerCrashProcedure.UnknownServerVisitor.getReassigns() |
private List<RegionInfo> |
ModifyTableProcedure.getRegionInfoList(MasterProcedureEnv env)
Fetches all Regions for a table.
|
(package private) List<RegionInfo> |
HBCKServerCrashProcedure.getRegionsOnCrashedServer(MasterProcedureEnv env)
If no Regions found in Master context, then we will search hbase:meta for references
to the passed server.
|
(package private) List<RegionInfo> |
ServerCrashProcedure.getRegionsOnCrashedServer(MasterProcedureEnv env) |
private static List<RegionInfo> |
TruncateTableProcedure.recreateRegionInfo(List<RegionInfo> regions) |
Modifier and Type | Method and Description |
---|---|
protected static void |
AbstractStateMachineTableProcedure.checkOnline(MasterProcedureEnv env,
RegionInfo ri)
Check region is online.
|
protected org.apache.hadoop.fs.Path |
AbstractStateMachineTableProcedure.getWALRegionDir(MasterProcedureEnv env,
RegionInfo region) |
private boolean |
ServerCrashProcedure.isDefaultMetaRegion(RegionInfo hri) |
protected void |
AbstractStateMachineRegionProcedure.setRegion(RegionInfo hri)
Used when deserializing.
|
boolean |
MasterProcedureScheduler.waitRegion(Procedure<?> procedure,
RegionInfo regionInfo)
Suspend the procedure if the specified region is already locked.
|
boolean |
MasterProcedureScheduler.waitRegions(Procedure<?> procedure,
TableName table,
RegionInfo... regionInfo)
Suspend the procedure if the specified set of regions are already locked.
|
void |
MasterProcedureScheduler.wakeRegion(Procedure<?> procedure,
RegionInfo regionInfo)
Wake the procedures waiting for the specified region
|
void |
MasterProcedureScheduler.wakeRegions(Procedure<?> procedure,
TableName table,
RegionInfo... regionInfo)
Wake the procedures waiting for the specified regions
|
Modifier and Type | Method and Description |
---|---|
private void |
RestoreSnapshotProcedure.addRegionsToInMemoryStates(List<RegionInfo> regionInfos,
MasterProcedureEnv env,
int regionReplication)
Add regions to in-memory states
|
private static void |
CreateTableProcedure.addRegionsToMeta(MasterProcedureEnv env,
TableDescriptor tableDescriptor,
List<RegionInfo> regionInfos)
Add the specified set of regions to the hbase:meta table.
|
private static void |
ModifyTableProcedure.addRegionsToMeta(MasterProcedureEnv env,
TableDescriptor tableDescriptor,
List<RegionInfo> regionInfos) |
protected static List<RegionInfo> |
CreateTableProcedure.addTableToMeta(MasterProcedureEnv env,
TableDescriptor tableDescriptor,
List<RegionInfo> regions) |
private void |
ServerCrashProcedure.assignRegions(MasterProcedureEnv env,
List<RegionInfo> regions)
Assign the regions on the crashed RS to other Rses.
|
private List<RegionInfo> |
CloneSnapshotProcedure.createFilesystemLayout(MasterProcedureEnv env,
TableDescriptor tableDescriptor,
List<RegionInfo> newRegions)
Create regions in file system.
|
protected static List<RegionInfo> |
CreateTableProcedure.createFsLayout(MasterProcedureEnv env,
TableDescriptor tableDescriptor,
List<RegionInfo> newRegions) |
protected static List<RegionInfo> |
CreateTableProcedure.createFsLayout(MasterProcedureEnv env,
TableDescriptor tableDescriptor,
List<RegionInfo> newRegions,
CreateTableProcedure.CreateHdfsRegions hdfsRegionHandler) |
private List<RegionInfo> |
CloneSnapshotProcedure.createFsLayout(MasterProcedureEnv env,
TableDescriptor tableDescriptor,
List<RegionInfo> newRegions,
CreateTableProcedure.CreateHdfsRegions hdfsRegionHandler)
Create region layout in file system.
|
List<RegionInfo> |
CreateTableProcedure.CreateHdfsRegions.createHdfsRegions(MasterProcedureEnv env,
org.apache.hadoop.fs.Path tableRootDir,
TableName tableName,
List<RegionInfo> newRegions) |
static void |
MasterDDLOperationHelper.deleteColumnFamilyFromFileSystem(MasterProcedureEnv env,
TableName tableName,
List<RegionInfo> regionInfoList,
byte[] familyName,
boolean hasMob)
Remove the column family from the file system
|
protected static void |
DeleteTableProcedure.deleteFromFs(MasterProcedureEnv env,
TableName tableName,
List<RegionInfo> regions,
boolean archive) |
protected static void |
DeleteTableProcedure.deleteFromMeta(MasterProcedureEnv env,
TableName tableName,
List<RegionInfo> regions) |
private void |
RestoreSnapshotProcedure.deleteRegionsFromInMemoryStates(List<RegionInfo> regionInfos,
MasterProcedureEnv env,
int regionReplication)
Delete regions from in-memory states
|
private int |
EnableTableProcedure.getNumberOfReplicasFromMeta(Connection connection,
int regionReplicaCount,
List<RegionInfo> regionsOfTable) |
private Result |
EnableTableProcedure.getRegionFromMeta(Connection connection,
List<RegionInfo> regionsOfTable) |
private static List<RegionInfo> |
TruncateTableProcedure.recreateRegionInfo(List<RegionInfo> regions) |
protected static void |
ProcedureSyncWait.waitRegionInTransition(MasterProcedureEnv env,
List<RegionInfo> regions) |
Constructor and Description |
---|
AbstractStateMachineRegionProcedure(MasterProcedureEnv env,
RegionInfo hri) |
CreateTableProcedure(MasterProcedureEnv env,
TableDescriptor tableDescriptor,
RegionInfo[] newRegions) |
CreateTableProcedure(MasterProcedureEnv env,
TableDescriptor tableDescriptor,
RegionInfo[] newRegions,
ProcedurePrepareLatch syncLatch) |
RegionCloseOperation(RemoteProcedureDispatcher.RemoteProcedure remoteProcedure,
RegionInfo regionInfo,
long procId,
ServerName destinationServer) |
RegionOpenOperation(RemoteProcedureDispatcher.RemoteProcedure remoteProcedure,
RegionInfo regionInfo,
long procId) |
RegionOperation(RemoteProcedureDispatcher.RemoteProcedure remoteProcedure,
RegionInfo regionInfo,
long procId) |
Modifier and Type | Method and Description |
---|---|
protected void |
TakeSnapshotHandler.snapshotDisabledRegion(RegionInfo regionInfo)
Take a snapshot of the specified disabled region
|
private void |
EnabledTableSnapshotHandler.snapshotMobRegion(RegionInfo regionInfo)
Takes a snapshot of the mob region
|
private void |
MasterSnapshotVerifier.verifyRegionInfo(RegionInfo region,
org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest manifest)
Verify that the regionInfo is valid
|
Modifier and Type | Method and Description |
---|---|
protected void |
EnabledTableSnapshotHandler.snapshotRegions(List<Pair<RegionInfo,ServerName>> regions)
This method kicks off a snapshot procedure.
|
void |
DisabledTableSnapshotHandler.snapshotRegions(List<Pair<RegionInfo,ServerName>> regionsAndLocations) |
protected abstract void |
TakeSnapshotHandler.snapshotRegions(List<Pair<RegionInfo,ServerName>> regions)
Snapshot the specified regions
|
Modifier and Type | Method and Description |
---|---|
static RegionInfo |
MobUtils.getMobRegionInfo(TableName tableName)
Gets the RegionInfo of the mob files.
|
Modifier and Type | Method and Description |
---|---|
static boolean |
MobUtils.isMobRegionInfo(RegionInfo regionInfo)
Gets whether the current RegionInfo is a mob one.
|
Modifier and Type | Method and Description |
---|---|
void |
NamespaceAuditor.checkQuotaToSplitRegion(RegionInfo hri) |
void |
NamespaceAuditor.removeRegionFromNamespaceUsage(RegionInfo hri) |
void |
NamespaceStateManager.removeRegionFromTable(RegionInfo hri) |
void |
NamespaceAuditor.updateQuotaForRegionMerge(RegionInfo mergedRegion) |
Modifier and Type | Field and Description |
---|---|
private static Map<RegionInfo,Long> |
MasterQuotaManager.EMPTY_MAP |
private ConcurrentHashMap<RegionInfo,MasterQuotaManager.SizeSnapshotWithTimestamp> |
MasterQuotaManager.regionSizes |
private Map<RegionInfo,Long> |
NamespaceQuotaSnapshotStore.regionUsage |
private Map<RegionInfo,Long> |
TableQuotaSnapshotStore.regionUsage |
private ConcurrentHashMap<RegionInfo,RegionSize> |
RegionSizeStoreImpl.store |
Modifier and Type | Method and Description |
---|---|
Iterable<Map.Entry<RegionInfo,Long>> |
NamespaceQuotaSnapshotStore.filterBySubject(String namespace) |
Iterable<Map.Entry<RegionInfo,Long>> |
QuotaSnapshotStore.filterBySubject(T subject)
Filters the provided
regions , returning those which match the given
subject . |
Iterable<Map.Entry<RegionInfo,Long>> |
TableQuotaSnapshotStore.filterBySubject(TableName table) |
(package private) HashSet<RegionInfo> |
RegionSizeReportingChore.getOnlineRegionInfos(List<? extends Region> onlineRegions) |
Iterator<Map.Entry<RegionInfo,RegionSize>> |
RegionSizeStoreImpl.iterator() |
Iterator<Map.Entry<RegionInfo,RegionSize>> |
NoOpRegionSizeStore.iterator() |
Map<RegionInfo,Long> |
MasterQuotaManager.snapshotRegionSizes() |
Modifier and Type | Method and Description |
---|---|
void |
MasterQuotaManager.addRegionSize(RegionInfo hri,
long size,
long time) |
RegionSize |
RegionSizeStore.getRegionSize(RegionInfo regionInfo)
Returns the size for the give region if one exists.
|
RegionSize |
RegionSizeStoreImpl.getRegionSize(RegionInfo regionInfo) |
RegionSize |
NoOpRegionSizeStore.getRegionSize(RegionInfo regionInfo) |
void |
RegionSizeStore.incrementRegionSize(RegionInfo regionInfo,
long delta)
Atomically alter the size of a region.
|
void |
RegionSizeStoreImpl.incrementRegionSize(RegionInfo regionInfo,
long delta) |
void |
NoOpRegionSizeStore.incrementRegionSize(RegionInfo regionInfo,
long delta) |
void |
MasterQuotaManager.onRegionMerged(RegionInfo mergedRegion) |
void |
MasterQuotaManager.onRegionSplit(RegionInfo hri) |
void |
MasterQuotaManager.onRegionSplitReverted(RegionInfo hri) |
void |
RegionSizeStore.put(RegionInfo regionInfo,
long size)
Atomically sets the given
size for a region. |
void |
RegionSizeStoreImpl.put(RegionInfo regionInfo,
long size) |
void |
NoOpRegionSizeStore.put(RegionInfo regionInfo,
long size) |
RegionSize |
RegionSizeStore.remove(RegionInfo regionInfo)
Removes the mapping for the given key, returning the value if one exists in the store.
|
RegionSize |
RegionSizeStoreImpl.remove(RegionInfo regionInfo) |
RegionSize |
NoOpRegionSizeStore.remove(RegionInfo regionInfo) |
Modifier and Type | Method and Description |
---|---|
(package private) void |
QuotaObserverChore.initializeSnapshotStores(Map<RegionInfo,Long> regionSizes) |
(package private) void |
RegionSizeReportingChore.removeNonOnlineRegions(RegionSizeStore store,
Set<RegionInfo> onlineRegions) |
void |
NamespaceQuotaSnapshotStore.setRegionUsage(Map<RegionInfo,Long> regionUsage) |
void |
TableQuotaSnapshotStore.setRegionUsage(Map<RegionInfo,Long> regionUsage) |
void |
QuotaSnapshotStore.setRegionUsage(Map<RegionInfo,Long> regionUsage)
Updates
this with the latest snapshot of filesystem use by region. |
Constructor and Description |
---|
NamespaceQuotaSnapshotStore(Connection conn,
QuotaObserverChore chore,
Map<RegionInfo,Long> regionUsage) |
TableQuotaSnapshotStore(Connection conn,
QuotaObserverChore chore,
Map<RegionInfo,Long> regionUsage) |
Modifier and Type | Field and Description |
---|---|
private RegionInfo[] |
RegionServerServices.RegionStateTransitionContext.hris |
private RegionInfo |
SplitRequest.parent |
private RegionInfo |
HRegionFileSystem.regionInfo |
(package private) RegionInfo |
HRegionFileSystem.regionInfoForFs |
Modifier and Type | Method and Description |
---|---|
RegionInfo[] |
RegionServerServices.RegionStateTransitionContext.getHris() |
RegionInfo |
HRegionFileSystem.getRegionInfo() |
RegionInfo |
Region.getRegionInfo() |
RegionInfo |
RegionScanner.getRegionInfo() |
RegionInfo |
RegionServicesForStores.getRegionInfo() |
RegionInfo |
RegionCoprocessorHost.RegionEnvironment.getRegionInfo() |
RegionInfo |
HStore.getRegionInfo() |
RegionInfo |
HRegion.getRegionInfo() |
RegionInfo |
HRegion.RegionScannerImpl.getRegionInfo() |
RegionInfo |
Store.getRegionInfo() |
RegionInfo |
HRegionFileSystem.getRegionInfoForFS() |
static RegionInfo |
HRegionFileSystem.loadRegionInfoFileContent(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path regionDir)
Create a
RegionInfo from the serialized version on-disk. |
Modifier and Type | Method and Description |
---|---|
(package private) void |
HRegionFileSystem.cleanupDaughterRegion(RegionInfo regionInfo)
Remove daughter region
|
void |
HRegionFileSystem.cleanupMergedRegion(RegionInfo mergedRegion)
Remove merged region
|
private void |
HRegionServer.closeRegionIgnoreErrors(RegionInfo region,
boolean abort)
Try to close the region, logs a warning on failure but continues.
|
org.apache.hadoop.fs.Path |
HRegionFileSystem.commitDaughterRegion(RegionInfo regionInfo)
Commit a daughter region, moving it from the split temporary directory
to the proper location in the filesystem.
|
void |
HRegionFileSystem.commitMergedRegion(RegionInfo mergedRegionInfo)
Commit a merged region, moving it from the merges temporary directory to
the proper location in the filesystem.
|
private void |
CompactionTool.CompactionWorker.compactStoreFiles(org.apache.hadoop.fs.Path tableDir,
TableDescriptor htd,
RegionInfo hri,
String familyName,
boolean compactOnce,
boolean major)
Execute the actual compaction job.
|
static HDFSBlocksDistribution |
HRegion.computeHDFSBlocksDistribution(org.apache.hadoop.conf.Configuration conf,
TableDescriptor tableDescriptor,
RegionInfo regionInfo)
This is a helper function to compute HDFS block distribution on demand
|
static HDFSBlocksDistribution |
HRegion.computeHDFSBlocksDistribution(org.apache.hadoop.conf.Configuration conf,
TableDescriptor tableDescriptor,
RegionInfo regionInfo,
org.apache.hadoop.fs.Path tablePath)
This is a helper function to compute HDFS block distribution on demand
|
(package private) org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionSpaceUse |
HRegionServer.convertRegionSize(RegionInfo regionInfo,
Long sizeInBytes)
Converts a pair of
RegionInfo and long into a RegionServerStatusProtos.RegionSpaceUse
protobuf message. |
static HRegion |
HRegion.createHRegion(RegionInfo info,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.conf.Configuration conf,
TableDescriptor hTableDescriptor,
WAL wal) |
static HRegion |
HRegion.createHRegion(RegionInfo info,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.conf.Configuration conf,
TableDescriptor hTableDescriptor,
WAL wal,
boolean initialize)
Convenience method creating new HRegions.
|
static HRegionFileSystem |
HRegion.createRegionDir(org.apache.hadoop.conf.Configuration configuration,
RegionInfo ri,
org.apache.hadoop.fs.Path rootDir)
Create the region directory in the filesystem.
|
static HRegionFileSystem |
HRegionFileSystem.createRegionOnFileSystem(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path tableDir,
RegionInfo regionInfo)
Create a new Region on file-system.
|
void |
HRegionFileSystem.createSplitsDir(RegionInfo daughterA,
RegionInfo daughterB)
Create the region splits directory.
|
static void |
HRegionFileSystem.deleteRegionFromFileSystem(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path tableDir,
RegionInfo regionInfo)
Remove the region from the table directory, archiving the region's hfiles.
|
private static void |
HRegion.doSyncOfUnflushedWALChanges(WAL wal,
RegionInfo hri)
Sync unflushed WAL changes.
|
(package private) org.apache.hadoop.fs.Path |
HRegionFileSystem.getMergesDir(RegionInfo hri) |
private static byte[] |
HRegionFileSystem.getRegionInfoFileContent(RegionInfo hri) |
org.apache.hadoop.fs.Path |
HRegionFileSystem.getSplitsDir(RegionInfo 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,
TableDescriptor htd,
RegionInfo 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,
RegionInfo hri,
byte[] family)
Deprecated.
|
WAL |
RegionServerServices.getWAL(RegionInfo regionInfo) |
WAL |
HRegionServer.getWAL(RegionInfo regionInfo) |
org.apache.hadoop.fs.Path |
HRegionFileSystem.mergeStoreFile(RegionInfo mergedRegion,
String familyName,
HStoreFile f,
org.apache.hadoop.fs.Path mergedDir)
Write out a merge reference under the given merges directory.
|
static HRegion |
HRegion.newHRegion(org.apache.hadoop.fs.Path tableDir,
WAL wal,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.conf.Configuration conf,
RegionInfo regionInfo,
TableDescriptor htd,
RegionServerServices rsServices)
A utility method to create new instances of HRegion based on the
HConstants.REGION_IMPL configuration property. |
static HRegion |
HRegion.openHRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.fs.Path tableDir,
RegionInfo info,
TableDescriptor htd,
WAL wal,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region.
|
static HRegion |
HRegion.openHRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootDir,
RegionInfo info,
TableDescriptor htd,
WAL wal)
Open a Region.
|
static HRegion |
HRegion.openHRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootDir,
RegionInfo info,
TableDescriptor htd,
WAL wal,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region.
|
static HRegion |
HRegion.openHRegion(org.apache.hadoop.fs.Path rootDir,
RegionInfo info,
TableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf)
Open a Region.
|
static HRegion |
HRegion.openHRegion(org.apache.hadoop.fs.Path rootDir,
RegionInfo info,
TableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region.
|
static HRegion |
HRegion.openHRegion(RegionInfo info,
TableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf)
Open a Region.
|
static HRegion |
HRegion.openHRegion(RegionInfo info,
TableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region.
|
static HRegion |
HRegion.openReadOnlyFileSystemHRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path tableDir,
RegionInfo info,
TableDescriptor htd)
Open a Region on a read-only file-system (like hdfs snapshots)
|
static HRegionFileSystem |
HRegionFileSystem.openRegionFromFileSystem(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path tableDir,
RegionInfo regionInfo,
boolean readOnly)
Open Region from file-system.
|
void |
RegionCoprocessorHost.postReplayWALs(RegionInfo info,
org.apache.hadoop.fs.Path edits) |
void |
RegionCoprocessorHost.postWALRestore(RegionInfo info,
WALKey logKey,
WALEdit logEdit)
Deprecated.
Since hbase-2.0.0. No replacement. To be removed in hbase-3.0.0 and replaced
with something that doesn't expose IntefaceAudience.Private classes.
|
void |
RegionCoprocessorHost.preReplayWALs(RegionInfo info,
org.apache.hadoop.fs.Path edits) |
boolean |
RegionCoprocessorHost.preWALRestore(RegionInfo info,
WALKey logKey,
WALEdit logEdit)
Deprecated.
Since hbase-2.0.0. No replacement. To be removed in hbase-3.0.0 and replaced
with something that doesn't expose IntefaceAudience.Private classes.
|
static boolean |
HRegion.rowIsInRange(RegionInfo info,
byte[] row)
Determines if the specified row is within the row range specified by the
specified RegionInfo
|
static boolean |
HRegion.rowIsInRange(RegionInfo info,
byte[] row,
int offset,
short length) |
org.apache.hadoop.fs.Path |
HRegionFileSystem.splitStoreFile(RegionInfo hri,
String familyName,
HStoreFile f,
byte[] splitRow,
boolean top,
RegionSplitPolicy splitPolicy)
Write out a split reference.
|
(package private) void |
HStore.updateSpaceQuotaAfterFileReplacement(RegionSizeStore sizeStore,
RegionInfo regionInfo,
Collection<HStoreFile> oldFiles,
Collection<HStoreFile> newFiles)
Updates the space quota usage for this region, removing the size for files compacted away
and adding in the size for new files.
|
static void |
HRegion.warmupHRegion(RegionInfo info,
TableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices rsServices,
CancelableProgressable reporter) |
Modifier and Type | Method and Description |
---|---|
EntityLock |
RegionServerServices.regionLock(List<RegionInfo> regionInfos,
String description,
Abortable abort)
Master based locks on namespaces/tables/regions.
|
EntityLock |
HRegionServer.regionLock(List<RegionInfo> regionInfos,
String description,
Abortable abort) |
Constructor and Description |
---|
HRegion(org.apache.hadoop.fs.Path tableDir,
WAL wal,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.conf.Configuration confParam,
RegionInfo regionInfo,
TableDescriptor htd,
RegionServerServices rsServices)
Deprecated.
Use other constructors.
|
HRegionFileSystem(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path tableDir,
RegionInfo regionInfo)
Create a view to the on-disk region
|
HRegionWALFileSystem(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path tableDir,
RegionInfo regionInfo) |
RegionStateTransitionContext(org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode code,
long openSeqNum,
long procId,
long masterSystemTime,
RegionInfo hri) |
RegionStateTransitionContext(org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode code,
long openSeqNum,
long masterSystemTime,
RegionInfo... hris) |
Modifier and Type | Field and Description |
---|---|
private RegionInfo |
OpenRegionHandler.regionInfo
Deprecated.
|
private RegionInfo |
CloseRegionHandler.regionInfo |
private RegionInfo |
AssignRegionHandler.regionInfo |
Modifier and Type | Method and Description |
---|---|
RegionInfo |
OpenRegionHandler.getRegionInfo()
Deprecated.
|
RegionInfo |
CloseRegionHandler.getRegionInfo() |
Modifier and Type | Method and Description |
---|---|
static AssignRegionHandler |
AssignRegionHandler.create(HRegionServer server,
RegionInfo regionInfo,
long openProcId,
TableDescriptor tableDesc,
long masterSystemTime) |
private static boolean |
OpenRegionHandler.isRegionStillOpening(RegionInfo regionInfo,
RegionServerServices rsServices)
Deprecated.
|
Constructor and Description |
---|
AssignRegionHandler(HRegionServer server,
RegionInfo regionInfo,
long openProcId,
TableDescriptor tableDesc,
long masterSystemTime,
EventType eventType) |
CloseMetaHandler(Server server,
RegionServerServices rsServices,
RegionInfo regionInfo,
boolean abort) |
CloseRegionHandler(Server server,
RegionServerServices rsServices,
RegionInfo regionInfo,
boolean abort,
EventType eventType,
ServerName destination) |
CloseRegionHandler(Server server,
RegionServerServices rsServices,
RegionInfo regionInfo,
boolean abort,
ServerName destination)
This method used internally by the RegionServer to close out regions.
|
OpenMetaHandler(Server server,
RegionServerServices rsServices,
RegionInfo regionInfo,
TableDescriptor htd,
long masterSystemTime) |
OpenPriorityRegionHandler(Server server,
RegionServerServices rsServices,
RegionInfo regionInfo,
TableDescriptor htd,
long masterSystemTime) |
OpenRegionHandler(Server server,
RegionServerServices rsServices,
RegionInfo regionInfo,
TableDescriptor htd,
long masterSystemTime)
Deprecated.
|
OpenRegionHandler(Server server,
RegionServerServices rsServices,
RegionInfo regionInfo,
TableDescriptor htd,
long masterSystemTime,
EventType eventType)
Deprecated.
|
Modifier and Type | Field and Description |
---|---|
private RegionInfo |
FSWALEntry.regionInfo |
Modifier and Type | Method and Description |
---|---|
(package private) RegionInfo |
FSWALEntry.getRegionInfo() |
Modifier and Type | Method and Description |
---|---|
protected long |
AsyncFSWAL.append(RegionInfo hri,
WALKeyImpl key,
WALEdit edits,
boolean inMemstore) |
protected long |
FSHLog.append(RegionInfo hri,
WALKeyImpl key,
WALEdit edits,
boolean inMemstore) |
protected abstract long |
AbstractFSWAL.append(RegionInfo info,
WALKeyImpl key,
WALEdit edits,
boolean inMemstore)
Append a set of edits to the WAL.
|
long |
AbstractFSWAL.appendData(RegionInfo info,
WALKeyImpl key,
WALEdit edits) |
long |
AbstractFSWAL.appendMarker(RegionInfo info,
WALKeyImpl key,
WALEdit edits) |
private static WALKeyImpl |
WALUtil.doFullMarkerAppendTransaction(WAL wal,
NavigableMap<byte[],Integer> replicationScope,
RegionInfo hri,
WALEdit edit,
MultiVersionConcurrencyControl mvcc,
boolean sync)
A 'full' WAL transaction involves starting an mvcc transaction followed by an append, an
optional sync, and then a call to complete the mvcc transaction.
|
void |
WALCoprocessorHost.postWALWrite(RegionInfo info,
WALKey logKey,
WALEdit logEdit) |
void |
WALCoprocessorHost.preWALWrite(RegionInfo info,
WALKey logKey,
WALEdit logEdit) |
protected long |
AbstractFSWAL.stampSequenceIdAndPublishToRingBuffer(RegionInfo hri,
WALKeyImpl key,
WALEdit edits,
boolean inMemstore,
com.lmax.disruptor.RingBuffer<RingBufferTruck> ringBuffer) |
default void |
WALActionsListener.visitLogEntryBeforeWrite(RegionInfo info,
WALKey logKey,
WALEdit logEdit)
Called before each write.
|
static WALKeyImpl |
WALUtil.writeBulkLoadMarkerAndSync(WAL wal,
NavigableMap<byte[],Integer> replicationScope,
RegionInfo hri,
org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.BulkLoadDescriptor desc,
MultiVersionConcurrencyControl mvcc)
Write a log marker that a bulk load has succeeded and is about to be committed.
|
static WALKeyImpl |
WALUtil.writeCompactionMarker(WAL wal,
NavigableMap<byte[],Integer> replicationScope,
RegionInfo hri,
org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.CompactionDescriptor c,
MultiVersionConcurrencyControl mvcc)
Write the marker that a compaction has succeeded and is about to be committed.
|
static WALKeyImpl |
WALUtil.writeFlushMarker(WAL wal,
NavigableMap<byte[],Integer> replicationScope,
RegionInfo hri,
org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptor f,
boolean sync,
MultiVersionConcurrencyControl mvcc)
Write a flush marker indicating a start / abort or a complete of a region flush
This write is for internal use only.
|
private static WALKeyImpl |
WALUtil.writeMarker(WAL wal,
NavigableMap<byte[],Integer> replicationScope,
RegionInfo hri,
WALEdit edit,
MultiVersionConcurrencyControl mvcc) |
static WALKeyImpl |
WALUtil.writeRegionEventMarker(WAL wal,
NavigableMap<byte[],Integer> replicationScope,
RegionInfo hri,
org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.RegionEventDescriptor r,
MultiVersionConcurrencyControl mvcc)
Write a region open marker indicating that the region is opened.
|
Constructor and Description |
---|
FSWALEntry(long txid,
WALKeyImpl key,
WALEdit edit,
RegionInfo regionInfo,
boolean inMemstore,
ServerCall<?> rpcCall) |
Constructor and Description |
---|
RegionReplicaReplayCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
TableName tableName,
HRegionLocation location,
RegionInfo regionInfo,
byte[] row,
List<WAL.Entry> entries,
AtomicLong skippedEntries) |
Modifier and Type | Method and Description |
---|---|
private Map<ServerName,List<RegionInfo>> |
RSGroupBasedLoadBalancer.correctAssignments(Map<ServerName,List<RegionInfo>> existingAssignments) |
private List<RegionInfo> |
RSGroupAdminServer.getRegions(Address server) |
private Map<TableName,Map<ServerName,List<RegionInfo>>> |
RSGroupAdminServer.getRSGroupAssignmentsByTable(String groupName) |
Map<ServerName,List<RegionInfo>> |
RSGroupBasedLoadBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers) |
Map<ServerName,List<RegionInfo>> |
RSGroupBasedLoadBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers) |
Modifier and Type | Method and Description |
---|---|
private void |
RSGroupAdminServer.addRegion(LinkedList<RegionInfo> regions,
RegionInfo hri) |
private ServerName |
RSGroupBasedLoadBalancer.findServerForRegion(Map<ServerName,List<RegionInfo>> existingAssignments,
RegionInfo region) |
void |
RSGroupAdminEndpoint.postCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableDescriptor desc,
RegionInfo[] regions) |
void |
RSGroupAdminEndpoint.preCreateTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx,
TableDescriptor desc,
RegionInfo[] regions) |
ServerName |
RSGroupBasedLoadBalancer.randomAssignment(RegionInfo region,
List<ServerName> servers) |
void |
RSGroupBasedLoadBalancer.regionOffline(RegionInfo regionInfo) |
void |
RSGroupBasedLoadBalancer.regionOnline(RegionInfo regionInfo,
ServerName sn) |
Modifier and Type | Method and Description |
---|---|
private void |
RSGroupAdminServer.addRegion(LinkedList<RegionInfo> regions,
RegionInfo hri) |
List<RegionPlan> |
RSGroupBasedLoadBalancer.balanceCluster(Map<ServerName,List<RegionInfo>> clusterState) |
List<RegionPlan> |
RSGroupBasedLoadBalancer.balanceCluster(TableName tableName,
Map<ServerName,List<RegionInfo>> clusterState) |
private Map<ServerName,List<RegionInfo>> |
RSGroupBasedLoadBalancer.correctAssignments(Map<ServerName,List<RegionInfo>> existingAssignments) |
private ServerName |
RSGroupBasedLoadBalancer.findServerForRegion(Map<ServerName,List<RegionInfo>> existingAssignments,
RegionInfo region) |
private void |
RSGroupBasedLoadBalancer.generateGroupMaps(List<RegionInfo> regions,
List<ServerName> servers,
org.apache.hbase.thirdparty.com.google.common.collect.ListMultimap<String,RegionInfo> regionMap,
org.apache.hbase.thirdparty.com.google.common.collect.ListMultimap<String,ServerName> serverMap) |
private void |
RSGroupBasedLoadBalancer.generateGroupMaps(List<RegionInfo> regions,
List<ServerName> servers,
org.apache.hbase.thirdparty.com.google.common.collect.ListMultimap<String,RegionInfo> regionMap,
org.apache.hbase.thirdparty.com.google.common.collect.ListMultimap<String,ServerName> serverMap) |
Map<ServerName,List<RegionInfo>> |
RSGroupBasedLoadBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers) |
Map<ServerName,List<RegionInfo>> |
RSGroupBasedLoadBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers) |
void |
RSGroupBasedLoadBalancer.setClusterLoad(Map<TableName,Map<ServerName,List<RegionInfo>>> clusterLoad) |
Modifier and Type | Field and Description |
---|---|
private List<RegionInfo> |
RestoreSnapshotHelper.RestoreMetaChanges.regionsToAdd |
private List<RegionInfo> |
RestoreSnapshotHelper.RestoreMetaChanges.regionsToRemove |
private List<RegionInfo> |
RestoreSnapshotHelper.RestoreMetaChanges.regionsToRestore |
Modifier and Type | Method and Description |
---|---|
private RegionInfo[] |
RestoreSnapshotHelper.cloneHdfsRegions(ThreadPoolExecutor exec,
Map<String,org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest> regionManifests,
List<RegionInfo> regions)
Clone specified regions.
|
RegionInfo |
RestoreSnapshotHelper.cloneRegionInfo(RegionInfo snapshotRegionInfo)
Create a new
RegionInfo from the snapshot region info. |
static RegionInfo |
RestoreSnapshotHelper.cloneRegionInfo(TableName tableName,
RegionInfo snapshotRegionInfo) |
Modifier and Type | Method and Description |
---|---|
List<RegionInfo> |
RestoreSnapshotHelper.RestoreMetaChanges.getRegionsToAdd()
Returns the list of new regions added during the on-disk restore.
|
List<RegionInfo> |
RestoreSnapshotHelper.RestoreMetaChanges.getRegionsToRemove()
Returns the list of regions removed during the on-disk restore.
|
List<RegionInfo> |
RestoreSnapshotHelper.RestoreMetaChanges.getRegionsToRestore()
Returns the list of 'restored regions' during the on-disk restore.
|
private List<RegionInfo> |
RestoreSnapshotHelper.getTableRegions() |
Modifier and Type | Method and Description |
---|---|
void |
SnapshotManifest.addMobRegion(RegionInfo regionInfo) |
protected void |
SnapshotManifest.addMobRegion(RegionInfo regionInfo,
SnapshotManifest.RegionVisitor visitor) |
void |
SnapshotManifest.addRegion(org.apache.hadoop.fs.Path tableDir,
RegionInfo regionInfo)
Creates a 'manifest' for the specified region, by reading directly from the disk.
|
protected void |
SnapshotManifest.addRegion(org.apache.hadoop.fs.Path tableDir,
RegionInfo regionInfo,
SnapshotManifest.RegionVisitor visitor) |
(package private) void |
RestoreSnapshotHelper.RestoreMetaChanges.addRegionToRemove(RegionInfo hri) |
(package private) void |
RestoreSnapshotHelper.RestoreMetaChanges.addRegionToRestore(RegionInfo hri) |
(package private) SnapshotInfo.SnapshotStats.FileInfo |
SnapshotInfo.SnapshotStats.addStoreFile(RegionInfo region,
String family,
org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile storeFile,
Map<org.apache.hadoop.fs.Path,Integer> filesMap)
Add the specified store file to the stats
|
(package private) static org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest |
SnapshotManifestV1.buildManifestFromDisk(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path tableDir,
RegionInfo regionInfo) |
private void |
RestoreSnapshotHelper.cloneHdfsMobRegion(Map<String,org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest> regionManifests,
RegionInfo region)
Clone the mob region.
|
private void |
RestoreSnapshotHelper.cloneRegion(HRegion region,
RegionInfo snapshotRegionInfo,
org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest manifest)
Clone region directory content from the snapshot info.
|
private void |
RestoreSnapshotHelper.cloneRegion(org.apache.hadoop.fs.Path regionDir,
RegionInfo snapshotRegionInfo,
org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest manifest)
Clone region directory content from the snapshot info.
|
RegionInfo |
RestoreSnapshotHelper.cloneRegionInfo(RegionInfo snapshotRegionInfo)
Create a new
RegionInfo from the snapshot region info. |
static RegionInfo |
RestoreSnapshotHelper.cloneRegionInfo(TableName tableName,
RegionInfo snapshotRegionInfo) |
HRegionFileSystem |
SnapshotManifestV1.ManifestBuilder.regionOpen(RegionInfo regionInfo) |
TRegion |
SnapshotManifest.RegionVisitor.regionOpen(RegionInfo regionInfo) |
org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder |
SnapshotManifestV2.ManifestBuilder.regionOpen(RegionInfo regionInfo) |
private void |
RestoreSnapshotHelper.restoreMobRegion(RegionInfo regionInfo,
org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest regionManifest)
Restore mob region by removing files not in the snapshot
and adding the missing ones from the snapshot.
|
private void |
RestoreSnapshotHelper.restoreReferenceFile(org.apache.hadoop.fs.Path familyDir,
RegionInfo regionInfo,
org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile storeFile)
Create a new
Reference as copy of the source one. |
private void |
RestoreSnapshotHelper.restoreRegion(RegionInfo regionInfo,
org.apache.hadoop.hbase.shaded.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.restoreRegion(RegionInfo regionInfo,
org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest regionManifest,
org.apache.hadoop.fs.Path regionDir)
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,
RegionInfo regionInfo,
org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile storeFile,
boolean createBackRef)
Create a new
HFileLink to reference the store file. |
(package private) void |
RestoreSnapshotHelper.RestoreMetaChanges.setNewRegions(RegionInfo[] hris) |
void |
SnapshotReferenceUtil.StoreFileVisitor.storeFile(RegionInfo regionInfo,
String familyName,
org.apache.hadoop.hbase.shaded.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.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot,
RegionInfo regionInfo,
String family,
org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile storeFile)
Verify the validity of the snapshot store file
|
Modifier and Type | Method and Description |
---|---|
private RegionInfo[] |
RestoreSnapshotHelper.cloneHdfsRegions(ThreadPoolExecutor exec,
Map<String,org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest> regionManifests,
List<RegionInfo> regions)
Clone specified regions.
|
private void |
RestoreSnapshotHelper.removeHdfsRegions(ThreadPoolExecutor exec,
List<RegionInfo> regions)
Remove specified regions from the file-system, using the archiver.
|
private void |
RestoreSnapshotHelper.restoreHdfsMobRegions(ThreadPoolExecutor exec,
Map<String,org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest> regionManifests,
List<RegionInfo> regions)
Restore specified mob regions by restoring content to the snapshot state.
|
private void |
RestoreSnapshotHelper.restoreHdfsRegions(ThreadPoolExecutor exec,
Map<String,org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest> regionManifests,
List<RegionInfo> regions)
Restore specified regions by restoring content to the snapshot state.
|
void |
RestoreSnapshotHelper.RestoreMetaChanges.updateMetaParentRegions(Connection connection,
List<RegionInfo> regionInfos) |
Modifier and Type | Method and Description |
---|---|
List<RegionInfo> |
ThriftAdmin.getRegions(ServerName serverName) |
List<RegionInfo> |
ThriftAdmin.getRegions(TableName tableName) |
Modifier and Type | Field and Description |
---|---|
private List<RegionInfo> |
RegionListTmpl.ImplData.m_onlineRegions |
private List<RegionInfo> |
RegionListTmplImpl.onlineRegions |
Modifier and Type | Method and Description |
---|---|
List<RegionInfo> |
RegionListTmpl.ImplData.getOnlineRegions() |
Modifier and Type | Method and Description |
---|---|
private void |
RegionListTmplImpl.__jamon_innerUnit__baseInfo(Writer jamonWriter,
List<RegionInfo> onlineRegions) |
private void |
RegionListTmplImpl.__jamon_innerUnit__compactStats(Writer jamonWriter,
List<RegionInfo> onlineRegions) |
private void |
RegionListTmplImpl.__jamon_innerUnit__memstoreStats(Writer jamonWriter,
List<RegionInfo> onlineRegions) |
private void |
RegionListTmplImpl.__jamon_innerUnit__requestStats(Writer jamonWriter,
List<RegionInfo> onlineRegions) |
private void |
RegionListTmplImpl.__jamon_innerUnit__storeStats(Writer jamonWriter,
List<RegionInfo> onlineRegions) |
org.jamon.Renderer |
RegionListTmpl.makeRenderer(HRegionServer regionServer,
List<RegionInfo> onlineRegions) |
void |
RegionListTmpl.render(Writer jamonWriter,
HRegionServer regionServer,
List<RegionInfo> onlineRegions) |
void |
RegionListTmpl.renderNoFlush(Writer jamonWriter,
HRegionServer regionServer,
List<RegionInfo> onlineRegions) |
void |
RegionListTmpl.ImplData.setOnlineRegions(List<RegionInfo> onlineRegions) |
Modifier and Type | Field and Description |
---|---|
private RegionInfo |
CanaryTool.RegionTask.region |
private RegionInfo |
CanaryTool.RegionServerTask.region |
private RegionInfo |
CanaryTool.RegionTaskResult.region |
Modifier and Type | Method and Description |
---|---|
RegionInfo |
CanaryTool.RegionTaskResult.getRegionInfo() |
Modifier and Type | Method and Description |
---|---|
private Map<String,List<RegionInfo>> |
CanaryTool.RegionServerMonitor.doFilterRegionServerByName(Map<String,List<RegionInfo>> fullRsAndRMap) |
private Map<String,List<RegionInfo>> |
CanaryTool.RegionServerMonitor.filterRegionServerByName() |
private Map<String,List<RegionInfo>> |
CanaryTool.RegionServerMonitor.getAllRegionServerByName() |
Modifier and Type | Method and Description |
---|---|
void |
CanaryTool.RegionStdOutSink.publishReadFailure(ServerName serverName,
RegionInfo region,
ColumnFamilyDescriptor column,
Exception e) |
void |
CanaryTool.RegionStdOutSink.publishReadFailure(ServerName serverName,
RegionInfo region,
Exception e) |
void |
CanaryTool.RegionStdOutSink.publishReadTiming(ServerName serverName,
RegionInfo region,
ColumnFamilyDescriptor column,
long msTime) |
void |
CanaryTool.RegionStdOutSink.publishWriteFailure(ServerName serverName,
RegionInfo region,
ColumnFamilyDescriptor column,
Exception e) |
void |
CanaryTool.RegionStdOutSink.publishWriteFailure(ServerName serverName,
RegionInfo region,
Exception e) |
void |
CanaryTool.RegionStdOutSink.publishWriteTiming(ServerName serverName,
RegionInfo region,
ColumnFamilyDescriptor column,
long msTime) |
Modifier and Type | Method and Description |
---|---|
private Map<String,List<RegionInfo>> |
CanaryTool.RegionServerMonitor.doFilterRegionServerByName(Map<String,List<RegionInfo>> fullRsAndRMap) |
private void |
CanaryTool.RegionServerMonitor.monitorRegionServers(Map<String,List<RegionInfo>> rsAndRMap,
CanaryTool.RegionServerStdOutSink regionServerSink) |
Constructor and Description |
---|
RegionServerTask(Connection connection,
String serverName,
RegionInfo region,
CanaryTool.RegionServerStdOutSink sink,
AtomicLong successes) |
RegionTask(Connection connection,
RegionInfo region,
ServerName serverName,
CanaryTool.RegionStdOutSink sink,
CanaryTool.RegionTask.TaskType taskType,
boolean rawScanEnabled,
LongAdder rwLatency) |
RegionTaskResult(RegionInfo region,
TableName tableName,
ServerName serverName,
ColumnFamilyDescriptor column) |
Modifier and Type | Class and Description |
---|---|
static class |
HbckRegionInfo.MetaEntry
Stores the regioninfo entries scanned from META
|
Modifier and Type | Field and Description |
---|---|
(package private) RegionInfo |
HbckRegionInfo.HdfsEntry.hri |
private RegionInfo |
HbckRegionInfo.primaryHRIForDeployedReplica |
private RegionInfo |
RegionMover.MoveWithAck.region |
private RegionInfo |
RegionMover.MoveWithoutAck.region |
private RegionInfo |
HbckRegionInfo.OnlineEntry.regionInfo |
(package private) RegionInfo |
HbckRegionInfo.MetaEntry.splitA |
(package private) RegionInfo |
HbckRegionInfo.MetaEntry.splitB |
Modifier and Type | Field and Description |
---|---|
private List<RegionInfo> |
RegionMover.MoveWithAck.movedRegions |
private List<RegionInfo> |
RegionMover.MoveWithoutAck.movedRegions |
private org.apache.hbase.thirdparty.com.google.common.collect.ImmutableList<RegionInfo> |
HbckTableInfo.regionsFromMeta |
Modifier and Type | Method and Description |
---|---|
static RegionInfo |
ModifyRegionUtils.createRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
TableDescriptor tableDescriptor,
RegionInfo newRegion,
ModifyRegionUtils.RegionFillTask task)
Create new set of regions on the specified file-system.
|
static RegionInfo[] |
ModifyRegionUtils.createRegionInfos(TableDescriptor tableDescriptor,
byte[][] splitKeys) |
RegionInfo |
HbckRegionInfo.getHdfsHRI() |
RegionInfo |
HbckRegionInfo.getPrimaryHRIForDeployedReplica() |
RegionInfo |
HbckRegionInfo.OnlineEntry.getRegionInfo() |
static RegionInfo |
ServerRegionReplicaUtil.getRegionInfoForFs(RegionInfo regionInfo)
Returns the regionInfo object to use for interacting with the file system.
|
Modifier and Type | Method and Description |
---|---|
static List<RegionInfo> |
ModifyRegionUtils.createRegions(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
TableDescriptor tableDescriptor,
RegionInfo[] newRegions,
ModifyRegionUtils.RegionFillTask task)
Create new set of regions on the specified file-system.
|
static List<RegionInfo> |
ModifyRegionUtils.createRegions(ThreadPoolExecutor exec,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
TableDescriptor tableDescriptor,
RegionInfo[] newRegions,
ModifyRegionUtils.RegionFillTask task)
Create new set of regions on the specified file-system.
|
private List<RegionInfo> |
HBaseFsck.WorkItemRegion.filterRegions(List<RegionInfo> regions) |
org.apache.hbase.thirdparty.com.google.common.collect.ImmutableList<RegionInfo> |
HbckTableInfo.getRegionsFromMeta(TreeMap<String,HbckRegionInfo> regionInfoMap) |
private List<RegionInfo> |
RegionMover.readRegionsFromFile(String filename) |
Modifier and Type | Method and Description |
---|---|
void |
HbckRegionInfo.addServer(RegionInfo regionInfo,
ServerName serverName) |
static void |
HBaseFsckRepair.closeRegionSilentlyAndWait(Connection connection,
ServerName server,
RegionInfo region)
Contacts a region server and waits up to hbase.hbck.close.timeout ms
(default 120s) to close the region.
|
static HRegion |
HBaseFsckRepair.createHDFSRegionDir(org.apache.hadoop.conf.Configuration conf,
RegionInfo hri,
TableDescriptor htd)
Creates, flushes, and closes a new region.
|
static RegionInfo |
ModifyRegionUtils.createRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
TableDescriptor tableDescriptor,
RegionInfo newRegion,
ModifyRegionUtils.RegionFillTask task)
Create new set of regions on the specified file-system.
|
static List<RegionInfo> |
ModifyRegionUtils.createRegions(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
TableDescriptor tableDescriptor,
RegionInfo[] newRegions,
ModifyRegionUtils.RegionFillTask task)
Create new set of regions on the specified file-system.
|
static List<RegionInfo> |
ModifyRegionUtils.createRegions(ThreadPoolExecutor exec,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.Path rootDir,
TableDescriptor tableDescriptor,
RegionInfo[] newRegions,
ModifyRegionUtils.RegionFillTask task)
Create new set of regions on the specified file-system.
|
void |
ModifyRegionUtils.RegionEditTask.editRegion(RegionInfo region) |
static void |
HBaseFsckRepair.fixMetaHoleOnlineAndAddReplicas(org.apache.hadoop.conf.Configuration conf,
RegionInfo hri,
Collection<ServerName> servers,
int numReplicas)
Puts the specified RegionInfo into META with replica related columns
|
static void |
HBaseFsckRepair.fixMultiAssignment(Connection connection,
RegionInfo region,
List<ServerName> servers)
Fix multiple assignment by doing silent closes on each RS hosting the region
and then force ZK unassigned node to OFFLINE to trigger assignment by
master.
|
static void |
HBaseFsckRepair.fixUnassigned(Admin admin,
RegionInfo region)
Fix unassigned by creating/transition the unassigned ZK node for this
region to OFFLINE state with a special flag to tell the master that this is
a forced operation by HBCK.
|
private static void |
HBaseFsckRepair.forceOfflineInZK(Admin admin,
RegionInfo region)
In 0.90, this forces an HRI offline by setting the RegionTransitionData
in ZK to have HBCK_CODE_NAME as the server.
|
static org.apache.hadoop.fs.Path |
FSUtils.getRegionDirFromRootDir(org.apache.hadoop.fs.Path rootDir,
RegionInfo region) |
static org.apache.hadoop.fs.Path |
FSUtils.getRegionDirFromTableDir(org.apache.hadoop.fs.Path tableDir,
RegionInfo region) |
static RegionInfo |
ServerRegionReplicaUtil.getRegionInfoForFs(RegionInfo regionInfo)
Returns the regionInfo object to use for interacting with the file system.
|
private ServerName |
RegionMover.getServerNameForRegion(RegionInfo region)
Get servername that is up in hbase:meta hosting the given region.
|
static org.apache.hadoop.fs.Path |
HFileArchiveUtil.getStoreArchivePath(org.apache.hadoop.conf.Configuration conf,
RegionInfo region,
byte[] family)
Gets the directory to archive a store directory.
|
static org.apache.hadoop.fs.Path |
HFileArchiveUtil.getStoreArchivePath(org.apache.hadoop.conf.Configuration conf,
RegionInfo region,
org.apache.hadoop.fs.Path tabledir,
byte[] family)
Get the directory to archive a store directory
|
static org.apache.hadoop.fs.Path |
HFileArchiveUtil.getStoreArchivePathForRootDir(org.apache.hadoop.fs.Path rootDir,
RegionInfo region,
byte[] family)
Gets the archive directory under specified root dir.
|
static StoreFileInfo |
ServerRegionReplicaUtil.getStoreFileInfo(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
RegionInfo regionInfo,
RegionInfo regionInfoForFs,
String familyName,
org.apache.hadoop.fs.Path path)
Returns a StoreFileInfo from the given FileStatus.
|
private boolean |
RegionMover.isSameServer(RegionInfo region,
ServerName serverName)
Returns true if passed region is still on serverName when we look at hbase:meta.
|
private void |
RegionMover.isSuccessfulScan(RegionInfo region)
Tries to scan a row from passed region
|
static void |
HBaseFsckRepair.removeParentInMeta(org.apache.hadoop.conf.Configuration conf,
RegionInfo hri) |
static void |
HBaseFsckRepair.waitUntilAssigned(Admin admin,
RegionInfo region) |
Modifier and Type | Method and Description |
---|---|
static void |
ModifyRegionUtils.editRegions(ThreadPoolExecutor exec,
Collection<RegionInfo> regions,
ModifyRegionUtils.RegionEditTask task)
Execute the task on the specified set of regions.
|
private List<RegionInfo> |
HBaseFsck.WorkItemRegion.filterRegions(List<RegionInfo> regions) |
private void |
RegionMover.loadRegions(List<RegionInfo> regionsToMove) |
private void |
RegionMover.unloadRegions(ServerName server,
List<ServerName> regionServers,
List<RegionInfo> movedRegions) |
private void |
RegionMover.writeFile(String filename,
List<RegionInfo> movedRegions)
Write the number of regions moved in the first line followed by regions moved in subsequent
lines
|
Constructor and Description |
---|
MetaEntry(RegionInfo rinfo,
ServerName regionServer,
long modTime) |
MetaEntry(RegionInfo rinfo,
ServerName regionServer,
long modTime,
RegionInfo splitA,
RegionInfo splitB) |
MoveWithAck(RegionInfo regionInfo,
ServerName sourceServer,
ServerName targetServer,
List<RegionInfo> movedRegions) |
MoveWithoutAck(RegionInfo regionInfo,
ServerName sourceServer,
ServerName targetServer,
List<RegionInfo> movedRegions) |
OnlineEntry(RegionInfo regionInfo,
ServerName serverName) |
Constructor and Description |
---|
MoveWithAck(RegionInfo regionInfo,
ServerName sourceServer,
ServerName targetServer,
List<RegionInfo> movedRegions) |
MoveWithoutAck(RegionInfo regionInfo,
ServerName sourceServer,
ServerName targetServer,
List<RegionInfo> movedRegions) |
Modifier and Type | Field and Description |
---|---|
private RegionInfo |
MajorCompactionRequest.region |
Modifier and Type | Method and Description |
---|---|
(package private) RegionInfo |
MajorCompactionRequest.getRegion() |
Modifier and Type | Method and Description |
---|---|
(package private) static Optional<MajorCompactionRequest> |
MajorCompactionRequest.newRequest(org.apache.hadoop.conf.Configuration configuration,
RegionInfo info,
Set<String> stores,
long timestamp) |
Constructor and Description |
---|
MajorCompactionRequest(org.apache.hadoop.conf.Configuration configuration,
RegionInfo region,
Set<String> stores,
long timestamp) |
Modifier and Type | Method and Description |
---|---|
private long |
DisabledWALProvider.DisabledWAL.append(RegionInfo info,
WALKeyImpl key,
WALEdit edits,
boolean inMemstore) |
long |
DisabledWALProvider.DisabledWAL.appendData(RegionInfo info,
WALKeyImpl key,
WALEdit edits) |
long |
WAL.appendData(RegionInfo info,
WALKeyImpl key,
WALEdit edits)
Append a set of data edits to the WAL.
|
long |
DisabledWALProvider.DisabledWAL.appendMarker(RegionInfo info,
WALKeyImpl key,
WALEdit edits) |
long |
WAL.appendMarker(RegionInfo info,
WALKeyImpl key,
WALEdit edits)
Append an operational 'meta' event marker edit to the WAL.
|
static WALEdit |
WALEdit.createBulkLoadEvent(RegionInfo hri,
org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.BulkLoadDescriptor bulkLoadDescriptor)
Create a bulk loader WALEdit
|
static WALEdit |
WALEdit.createCompaction(RegionInfo hri,
org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.CompactionDescriptor c) |
static WALEdit |
WALEdit.createFlushWALEdit(RegionInfo hri,
org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptor f) |
static WALEdit |
WALEdit.createRegionEventWALEdit(RegionInfo hri,
org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.RegionEventDescriptor regionEventDesc) |
static long |
WALSplitUtil.getMaxRegionSequenceId(org.apache.hadoop.conf.Configuration conf,
RegionInfo region,
ConcurrentMapUtils.IOExceptionSupplier<org.apache.hadoop.fs.FileSystem> rootFsSupplier,
ConcurrentMapUtils.IOExceptionSupplier<org.apache.hadoop.fs.FileSystem> walFsSupplier)
Deprecated.
Only for compatibility, will be removed in 4.0.0.
|
static byte[] |
WALEdit.getRowForRegion(RegionInfo hri) |
WAL |
WALFactory.getWAL(RegionInfo region) |
WAL |
RegionGroupingProvider.getWAL(RegionInfo region) |
WAL |
WALProvider.getWAL(RegionInfo region) |
WAL |
DisabledWALProvider.getWAL(RegionInfo region) |
T |
AbstractFSWALProvider.getWAL(RegionInfo region) |
static boolean |
WALSplitUtil.hasRecoveredEdits(org.apache.hadoop.conf.Configuration conf,
RegionInfo regionInfo)
Check whether there is recovered.edits in the region dir
|
Modifier and Type | Method and Description |
---|---|
private static List<RegionInfo> |
MetaTableLocator.getListOfRegionInfos(List<Pair<RegionInfo,ServerName>> pairs) |
static List<RegionInfo> |
MetaTableLocator.getMetaRegions(ZKWatcher zkw)
Gets the meta regions for the given path with the default replica ID.
|
static List<RegionInfo> |
MetaTableLocator.getMetaRegions(ZKWatcher zkw,
int replicaId)
Gets the meta regions for the given path and replica ID.
|
static List<Pair<RegionInfo,ServerName>> |
MetaTableLocator.getMetaRegionsAndLocations(ZKWatcher zkw) |
static List<Pair<RegionInfo,ServerName>> |
MetaTableLocator.getMetaRegionsAndLocations(ZKWatcher zkw,
int replicaId)
Gets the meta regions and their locations for the given path and replica ID.
|
Modifier and Type | Method and Description |
---|---|
private static List<RegionInfo> |
MetaTableLocator.getListOfRegionInfos(List<Pair<RegionInfo,ServerName>> pairs) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.