Uses of Interface
org.apache.hadoop.hbase.client.RegionInfo
Package
Description
Provides HBase Client
Table of Contents
Tools to help define network clients and servers.
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
The Region Normalizer subsystem is responsible for coaxing all the regions in a table toward
a "normal" size, according to their storefile size.
Multi Cluster Replication
-
Uses of RegionInfo in org.apache.hadoop.hbase
Modifier and TypeMethodDescriptionprivate static RegionInfo
MetaTableAccessor.getClosestRegionInfo
(Connection connection, TableName tableName, byte[] row) Returns Get closest metatable region row to passedrow
HRegionLocation.getRegion()
Returns regionInfostatic RegionInfo
CatalogFamilyFormat.getRegionInfo
(Result data) Returns RegionInfo object from the column HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog table Result.static RegionInfo
CatalogFamilyFormat.getRegionInfo
(Result r, byte[] qualifier) Returns the RegionInfo object from the columnHConstants.CATALOG_FAMILY
andqualifier
of the catalog table result.static RegionInfo
CatalogFamilyFormat.parseRegionInfoFromRegionName
(byte[] regionName) Returns an HRI parsed from this regionName.Modifier and TypeMethodDescriptionHBaseTestingUtility.createMultiRegionsInMeta
(org.apache.hadoop.conf.Configuration conf, TableDescriptor htd, byte[][] startKeys) Deprecated.Create rows in hbase:meta for regions of the specified table with the specified start keys.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 List<RegionInfo>
MetaTableAccessor.getListOfRegionInfos
(List<Pair<RegionInfo, ServerName>> pairs) static List<RegionInfo>
CatalogFamilyFormat.getMergeRegions
(Cell[] cells) Returns Deserialized regioninfo values taken from column values that match the regex 'info:merge.*' in array ofcells
.static Map<String,
RegionInfo> CatalogFamilyFormat.getMergeRegionsWithName
(Cell[] cells) Returns Deserialized values of <qualifier,regioninfo> pairs taken from column values that match the regex 'info:merge.*' in array ofcells
.static Pair<RegionInfo,
ServerName> MetaTableAccessor.getRegion
(Connection connection, byte[] regionName) Deprecated.private List<RegionInfo>
HBaseTestingUtility.getRegions
(TableName tableName) Deprecated.Returns all regions of the specified tablestatic 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>>> ClientMetaTableAccessor.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 TypeMethodDescriptionstatic Put
MetaTableAccessor.addDaughtersToPut
(Put put, RegionInfo splitA, RegionInfo splitB) Adds split daughters to the Putstatic Put
MetaTableAccessor.addRegionInfo
(Put p, RegionInfo hri) static void
MetaTableAccessor.addSplitsToParent
(Connection connection, RegionInfo regionInfo, RegionInfo splitA, RegionInfo splitB) Adds daughter region infos to hbase:meta row for the specified region.void
HBaseTestingUtility.assertRegionOnlyOnServer
(RegionInfo hri, ServerName server, long timeout) Deprecated.Check to make sure the region is open on the specified region server, but not on any other one.void
HBaseTestingUtility.assertRegionOnServer
(RegionInfo hri, ServerName server, long timeout) Deprecated.Due to async racing issue, a region may not be in the online region list of a region server yet, after the assignment znode is deleted and the new assignment is recorded in master.boolean
HBaseTestingUtility.assignRegion
(RegionInfo regionInfo) Deprecated.Uses directly the assignment manager to assign the region.HBaseTestingUtility.createLocalHRegion
(RegionInfo info, org.apache.hadoop.conf.Configuration conf, TableDescriptor desc, WAL wal) Deprecated.Create an HRegion that writes to the local tmp dirs with specified walHBaseTestingUtility.createLocalHRegion
(RegionInfo info, TableDescriptor desc) Deprecated.Create an HRegion that writes to the local tmp dirs.static HRegion
HBaseTestingUtility.createRegionAndWAL
(RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, TableDescriptor htd) Deprecated.Create a region with it's own WAL.static HRegion
HBaseTestingUtility.createRegionAndWAL
(RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, TableDescriptor htd, boolean initialize) Deprecated.Create a region with it's own WAL.static HRegion
HBaseTestingUtility.createRegionAndWAL
(RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, TableDescriptor htd, BlockCache blockCache) Deprecated.Create a region with it's own WAL.static HRegion
HBaseTestingUtility.createRegionAndWAL
(RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, TableDescriptor htd, MobFileCache mobFileCache) Deprecated.Create a region with it's own WAL.static WAL
HBaseTestingUtility.createWal
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.Path rootDir, RegionInfo hri) Deprecated.Create an unmanaged WAL.static Result
MetaTableAccessor.getCatalogFamilyRow
(Connection connection, RegionInfo ri) Returns Return theHConstants.CATALOG_FAMILY
row from hbase:meta.static byte[]
CatalogFamilyFormat.getMetaKeyForRegion
(RegionInfo regionInfo) Returns the row key to use for this regionInfostatic HRegionLocation
CatalogFamilyFormat.getRegionLocation
(Result r, RegionInfo regionInfo, int replicaId) Returns the HRegionLocation parsed from the given meta row Result for the given regionInfo and replicaId.static HRegionLocation
MetaTableAccessor.getRegionLocation
(Connection connection, RegionInfo regionInfo) Returns the HRegionLocation from meta for the given regionstatic Result
MetaTableAccessor.getRegionResult
(Connection connection, RegionInfo regionInfo) Gets the result in hbase:meta for the specified region.MockRegionServerServices.getWAL
(RegionInfo regionInfo) static Delete
MetaTableAccessor.makeDeleteFromRegionInfo
(RegionInfo regionInfo, long ts) Generates and returns a Delete containing the region info for the catalog tablestatic Put
MetaTableAccessor.makePutFromRegionInfo
(RegionInfo regionInfo) Generates and returns aPut
containing theRegionInfo
for the catalog table.static Put
MetaTableAccessor.makePutFromRegionInfo
(RegionInfo regionInfo, long ts) Generates and returns aPut
containing theRegionInfo
for the catalog table.void
HBaseTestingUtility.moveRegionAndWait
(RegionInfo destRegion, ServerName destServer) Deprecated.Move region to destination server and wait till region is completely moved and onlinevoid
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.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 TypeMethodDescriptionstatic void
MetaTableAccessor.addRegionsToMeta
(Connection connection, List<RegionInfo> regionInfos, int regionReplication) Adds a hbase:meta row for each of the specified new regions.static void
MetaTableAccessor.addRegionsToMeta
(Connection connection, List<RegionInfo> regionInfos, int regionReplication, long ts) Adds a hbase:meta row for each of the specified new regions.private static List<RegionInfo>
MetaTableAccessor.getListOfRegionInfos
(List<Pair<RegionInfo, ServerName>> pairs) MockRegionServerServices.regionLock
(List<RegionInfo> regionInfos, String description, Abortable abort) ModifierConstructorDescriptionHRegionLocation
(RegionInfo regionInfo, ServerName serverName) HRegionLocation
(RegionInfo regionInfo, ServerName serverName, long seqNum) -
Uses of RegionInfo in org.apache.hadoop.hbase.backup
Modifier and TypeMethodDescriptionprivate 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 deletionstatic 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 deletionstatic 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 directorystatic 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 filestatic 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 deletionstatic boolean
HFileArchiver.exists
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, RegionInfo info) Returns True if the Region exits in the filesystem. -
Uses of RegionInfo in org.apache.hadoop.hbase.backup.util
Modifier and TypeMethodDescriptionstatic void
BackupUtils.writeRegioninfoOnFilesystem
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path regionInfoDir, RegionInfo regionInfo) Write the .regioninfo file on-disk. -
Uses of RegionInfo in org.apache.hadoop.hbase.client
Modifier and TypeClassDescription(package private) class
An implementation of RegionInfo that adds mutable methods so can build a RegionInfo instance.Modifier and TypeFieldDescriptionstatic final RegionInfo
RegionInfoBuilder.FIRST_META_REGIONINFO
RegionInfo for first meta region You cannot use this builder to make an instance of theRegionInfoBuilder.FIRST_META_REGIONINFO
.private final RegionInfo
RegionCoprocessorRpcChannelImpl.region
private final RegionInfo
AsyncRegionReplicationRetryingCaller.replica
static final RegionInfo
RegionInfoBuilder.UNDEFINED
Modifier and TypeFieldDescriptionstatic final Comparator<RegionInfo>
RegionInfo.COMPARATOR
private ArrayList<RegionInfo>
TableSnapshotScanner.regions
private final Set<RegionInfo>
SimpleRequestController.TaskCountChecker.regionsIncluded
Modifier and TypeMethodDescriptionRegionInfoBuilder.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) Returns A deserializedRegionInfo
static RegionInfo
RegionInfo.parseFrom
(byte[] bytes, int offset, int len) Parse a serialized representation ofRegionInfo
static RegionInfo
RegionInfo.parseFrom
(DataInputStream in) Parses an RegionInfo instance from the passed in stream.static RegionInfo
RegionInfo.parseFromOrNull
(byte[] bytes) Returns A deserializedRegionInfo
or null if we failed deserialize or passed bytes nullstatic RegionInfo
RegionInfo.parseFromOrNull
(byte[] bytes, int offset, int len) Returns A deserializedRegionInfo
or null if we failed deserialize or passed bytes nullModifier and TypeMethodDescriptionstatic List<RegionInfo>
RegionReplicaUtil.addReplicas
(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<RegionInfo>
RawAsyncHBaseAdmin.getRegionInfo
(byte[] regionNameOrEncodedRegionName) Get the region info for the passed region name.Admin.getRegions
(ServerName serverName) Get all the online regions on a region server.Admin.getRegions
(TableName tableName) Get the regions of a given table.AdminOverAsyncAdmin.getRegions
(ServerName serverName) AdminOverAsyncAdmin.getRegions
(TableName tableName) AsyncAdmin.getRegions
(ServerName serverName) Get all the online regions on a region server.AsyncAdmin.getRegions
(TableName tableName) Get the regions of a given table.AsyncHBaseAdmin.getRegions
(ServerName serverName) AsyncHBaseAdmin.getRegions
(TableName tableName) RawAsyncHBaseAdmin.getRegions
(ServerName serverName) RawAsyncHBaseAdmin.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 TypeMethodDescriptionstatic boolean
RegionInfo.areAdjacent
(RegionInfo regionA, RegionInfo regionB) Check whether two regions are adjacent; i.e.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) default int
RegionInfo.compareTo
(RegionInfo other) private <S,
R> CompletableFuture<R> RawAsyncTableImpl.coprocessorService
(Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, RegionInfo region, byte[] row) private <S,
R> void RawAsyncTableImpl.coprocessorServiceUntilComplete
(Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, AsyncTable.PartialResultCoprocessorCallback<S, R> callback, AtomicBoolean locateFinished, AtomicInteger unfinishedRequest, RegionInfo region, io.opentelemetry.api.trace.Span span) private CompletableFuture<org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.FlushRegionResponse>
RawAsyncHBaseAdmin.flush
(ServerName serverName, RegionInfo regionInfo, byte[] columnFamily, boolean writeFlushWALMarker) static byte[]
RegionInfoDisplay.getEndKeyForDisplay
(RegionInfo ri, org.apache.hadoop.conf.Configuration conf) Get the end key for display.AsyncTable.PartialResultCoprocessorCallback.getNextCallable
(R response, RegionInfo region) Subclasses should implement this to tell AsyncTable whether the given response is "final" or whether the AsyncTable should send another request to the coprocessor to fetch more results from the given region.NoopPartialResultCoprocessorCallback.getNextCallable
(R response, RegionInfo region) 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) Returns a String of short, printable names forhris
(usually encoded name) for us logging.static byte[]
RegionInfoDisplay.getStartKeyForDisplay
(RegionInfo ri, org.apache.hadoop.conf.Configuration conf) Get the start key for display.AsyncTable.PartialResultCoprocessorCallback.getWaitInterval
(R response, RegionInfo region) Subclasses should implement this such that, when the above method returns non-null, this method returns the duration that AsyncTable should wait before sending the next request to the given region.NoopPartialResultCoprocessorCallback.getWaitInterval
(R response, RegionInfo region) default boolean
RegionInfo.isAdjacent
(RegionInfo other) Returns True if region is adjacent, either just before or just after this one.static boolean
RegionReplicaUtil.isDefaultReplica
(RegionInfo hri) Returns true if this region is a default replica for the regiondefault boolean
RegionInfo.isNext
(RegionInfo after) Returns True if region is next, adjacent but 'after' this one.default boolean
RegionInfo.isOverlap
(RegionInfo other) Returns True if an overlap in region range.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) Indicate that the respose of a region is availablevoid
NoopPartialResultCoprocessorCallback.onRegionComplete
(RegionInfo region, R resp) void
AsyncTable.CoprocessorCallback.onRegionError
(RegionInfo region, Throwable error) Indicate that the error for a region is availablevoid
NoopPartialResultCoprocessorCallback.onRegionError
(RegionInfo region, Throwable error) AsyncClusterConnection.replicate
(RegionInfo replica, List<WAL.Entry> entries, int numRetries, long rpcTimeoutNs, long operationTimeoutNs) Replicate wal edits to a secondary replica.AsyncClusterConnectionImpl.replicate
(RegionInfo replica, List<WAL.Entry> entries, int retries, long rpcTimeoutNs, long operationTimeoutNs) private CompletableFuture<Void>
RawAsyncHBaseAdmin.split
(RegionInfo hri, byte[] splitPoint) static byte[]
RegionInfo.toByteArray
(RegionInfo ri) Returns This instance serialized as protobuf w/ a magic pb prefix.static byte[]
RegionInfo.toDelimitedByteArray
(RegionInfo ri) Use this instead oftoByteArray(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).static byte[]
RegionInfo.toDelimitedByteArray
(RegionInfo... infos) Serializes given RegionInfo's as a byte array.private CompletableFuture<Void>
RawAsyncHBaseAdmin.truncateRegion
(RegionInfo hri) Modifier and TypeMethodDescriptionstatic List<RegionInfo>
RegionReplicaUtil.addReplicas
(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) static String
RegionInfo.getShortNameToLog
(List<RegionInfo> ris) Returns a String of short, printable names forhris
(usually encoded name) for us logging.static void
RegionReplicaUtil.removeNonDefaultRegions
(Collection<RegionInfo> regions) Removes the non-default replicas from the passed regions collectionModifierConstructorDescriptionAsyncRegionReplicationRetryingCaller
(org.apache.hbase.thirdparty.io.netty.util.HashedWheelTimer retryTimer, AsyncClusterConnectionImpl conn, int maxAttempts, long rpcTimeoutNs, long operationTimeoutNs, RegionInfo replica, List<WAL.Entry> entries) 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) (package private)
RegionCoprocessorRpcChannel
(AsyncConnectionImpl conn, TableName tableName, RegionInfo region, byte[] row, long rpcTimeoutNs, long operationTimeoutNs) (package private)
RegionCoprocessorRpcChannelImpl
(AsyncConnectionImpl conn, TableName tableName, RegionInfo region, byte[] row, long rpcTimeoutNs, long operationTimeoutNs) private
RegionInfoBuilder
(RegionInfo regionInfo) -
Uses of RegionInfo in org.apache.hadoop.hbase.client.locking
Modifier and TypeMethodDescriptionstatic 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) LockServiceClient.regionLock
(List<RegionInfo> regionInfos, String description, Abortable abort) Create a new EntityLock object to acquire exclusive lock on multiple regions of same tables. -
Uses of RegionInfo in org.apache.hadoop.hbase.coprocessor
Modifier and TypeMethodDescriptionRegionCoprocessorEnvironment.getRegionInfo()
Returns region information for the region this coprocessor is running onModifier and TypeMethodDescriptiondefault 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.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.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.postTruncateRegion
(ObserverContext<MasterCoprocessorEnvironment> c, RegionInfo regionInfo) Called after the truncate region procedure is called.default void
MasterObserver.postTruncateRegionAction
(ObserverContext<MasterCoprocessorEnvironment> c, RegionInfo regionInfo) Called post the region is truncated.default void
MasterObserver.postUnassign
(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo regionInfo) Called after the region unassignment has been requested.default void
WALObserver.postWALWrite
(ObserverContext<? extends WALCoprocessorEnvironment> ctx, RegionInfo info, WALKey logKey, WALEdit logEdit) Called after aWALEdit
is writen to WAL.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 byHMaster
.default void
MasterObserver.preCreateTableAction
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) Called before a new table is created byHMaster
.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.preTruncateRegion
(ObserverContext<MasterCoprocessorEnvironment> c, RegionInfo regionInfo) Called before the truncate region procedure is called.default void
MasterObserver.preTruncateRegionAction
(ObserverContext<MasterCoprocessorEnvironment> c, RegionInfo regionInfo) Called before the region is truncated.default void
MasterObserver.preUnassign
(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo regionInfo) Called prior to unassigning a given region.default void
WALObserver.preWALWrite
(ObserverContext<? extends WALCoprocessorEnvironment> ctx, RegionInfo info, WALKey logKey, WALEdit logEdit) Called before aWALEdit
is writen to WAL. -
Uses of RegionInfo in org.apache.hadoop.hbase.coprocessor.example
Modifier and TypeMethodDescriptionvoid
ExampleMasterObserverWithMetrics.postCreateTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) void
ExampleMasterObserverWithMetrics.preCreateTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) -
Uses of RegionInfo in org.apache.hadoop.hbase.favored
Modifier and TypeFieldDescriptionprivate final Map<ServerName,
List<RegionInfo>> FavoredNodesManager.primaryRSToRegionMap
private final Map<ServerName,
List<RegionInfo>> FavoredNodesManager.secondaryRSToRegionMap
private final Map<ServerName,
List<RegionInfo>> FavoredNodesManager.teritiaryRSToRegionMap
Modifier and TypeMethodDescriptionstatic 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) FavoredNodeAssignmentHelper.generateFavoredNodesRoundRobin
(Map<ServerName, List<RegionInfo>> assignmentMap, List<RegionInfo> regions) FavoredNodesManager.getRegionsOfFavoredNode
(ServerName serverName) private Map<ServerName,
Set<RegionInfo>> FavoredNodeAssignmentHelper.mapRSToPrimaries
(Map<RegionInfo, ServerName> primaryRSMap) FavoredNodeAssignmentHelper.placeSecondaryAndTertiaryRS
(Map<RegionInfo, ServerName> primaryRSMap) FavoredNodeAssignmentHelper.placeSecondaryAndTertiaryWithRestrictions
(Map<RegionInfo, ServerName> primaryRSMap) For regions that share the primary, avoid placing the secondary and tertiary on a same RS.FavoredNodeLoadBalancer.roundRobinAssignment
(List<RegionInfo> regions, List<ServerName> servers) private Pair<Map<ServerName,
List<RegionInfo>>, List<RegionInfo>> FavoredNodeLoadBalancer.segregateRegionsAndAssignRegionsWithFavoredNodes
(List<RegionInfo> regions, List<ServerName> availableServers) private Pair<Map<ServerName,
List<RegionInfo>>, List<RegionInfo>> FavoredNodeLoadBalancer.segregateRegionsAndAssignRegionsWithFavoredNodes
(List<RegionInfo> regions, List<ServerName> availableServers) Modifier and TypeMethodDescriptionprivate 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) 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
FavoredNodesPromoter.generateFavoredNodesForMergedRegion
(RegionInfo merged, RegionInfo[] mergeParents) FavoredNodeLoadBalancer.getFavoredNodes
(RegionInfo regionInfo) FavoredNodesManager.getFavoredNodes
(RegionInfo regionInfo) FavoredNodesPlan.getFavoredNodes
(RegionInfo region) Returns the list of favored region server for this region based on the planFavoredNodesPromoter.getFavoredNodes
(RegionInfo regionInfo) FavoredNodesManager.getFavoredNodesWithDNPort
(RegionInfo regionInfo) This should only be used when sending FN information to the region servers.FavoredNodeAssignmentHelper.getSecondaryAndTertiary
(RegionInfo regionInfo, ServerName primaryRS) static boolean
FavoredNodesManager.isFavoredNodeApplicable
(RegionInfo regionInfo) Favored nodes are not applicable for system tables.private static Put
FavoredNodeAssignmentHelper.makePut
(RegionInfo regionInfo, List<ServerName> favoredNodeList) private ServerName[]
FavoredNodeAssignmentHelper.multiRackCaseWithRestrictions
(Map<ServerName, Set<RegionInfo>> serverToPrimaries, Map<RegionInfo, ServerName[]> secondaryAndTertiaryMap, String primaryRack, ServerName primaryRS, RegionInfo regionInfo) FavoredNodeLoadBalancer.randomAssignment
(RegionInfo regionInfo, List<ServerName> servers) (package private) List<ServerName>
FavoredNodesPlan.removeFavoredNodes
(RegionInfo region) Remove a favored node assignmentprivate ServerName[]
FavoredNodeAssignmentHelper.singleRackCase
(RegionInfo regionInfo, ServerName primaryRS, String primaryRack) void
FavoredNodesPlan.updateFavoredNodesMap
(RegionInfo region, List<ServerName> servers) Update an assignment to the planModifier and TypeMethodDescriptionprivate 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) protected List<RegionPlan>
FavoredNodeLoadBalancer.balanceTable
(TableName tableName, Map<ServerName, List<RegionInfo>> loadOfOneTable) 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) FavoredNodeAssignmentHelper.generateFavoredNodesRoundRobin
(Map<ServerName, List<RegionInfo>> assignmentMap, List<RegionInfo> regions) 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) 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) FavoredNodeAssignmentHelper.placeSecondaryAndTertiaryRS
(Map<RegionInfo, ServerName> primaryRSMap) FavoredNodeAssignmentHelper.placeSecondaryAndTertiaryWithRestrictions
(Map<RegionInfo, ServerName> primaryRSMap) For regions that share the primary, avoid placing the secondary and tertiary on a same RS.FavoredNodeLoadBalancer.roundRobinAssignment
(List<RegionInfo> regions, List<ServerName> servers) private void
FavoredNodeLoadBalancer.roundRobinAssignmentImpl
(FavoredNodeAssignmentHelper assignmentHelper, Map<ServerName, List<RegionInfo>> assignmentMap, List<RegionInfo> regions) private void
FavoredNodeLoadBalancer.roundRobinAssignmentImpl
(FavoredNodeAssignmentHelper assignmentHelper, Map<ServerName, List<RegionInfo>> assignmentMap, List<RegionInfo> regions) 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 infostatic void
FavoredNodeAssignmentHelper.updateMetaWithFavoredNodesInfo
(Map<RegionInfo, List<ServerName>> regionToFavoredNodes, Connection connection) Update meta table with favored nodes info -
Uses of RegionInfo in org.apache.hadoop.hbase.io
Modifier and TypeMethodDescriptionstatic String
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 HFileLinkstatic String
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 HFileLinkstatic String
HFileLink.createHFileLinkName
(RegionInfo hfileRegionInfo, String hfileName) Create a new HFileLink name -
Uses of RegionInfo in org.apache.hadoop.hbase.ipc
Modifier and TypeFieldDescriptionprivate RegionInfo
HBaseRpcControllerImpl.regionInfo
Rpc target Region's RegionInfo we are going against.Modifier and TypeMethodDescriptiondefault RegionInfo
HBaseRpcController.getRegionInfo()
Returns Target Region's RegionInfo or null if not available or pertinent.HBaseRpcControllerImpl.getRegionInfo()
Modifier and TypeMethodDescriptionprivate static String
IPCUtil.getCallTarget
(Address addr, RegionInfo regionInfo) RpcControllerFactory.newController
(RegionInfo regionInfo, List<ExtendedCellScannable> cellIterables) RpcControllerFactory.newController
(RegionInfo regionInfo, ExtendedCellScanner cellScanner) (package private) static IOException
IPCUtil.wrapException
(Address addr, RegionInfo regionInfo, Throwable error) Takes an Exception, the address, and if pertinent, the RegionInfo for the Region we were trying to connect to and returns an IOException with the input exception as the cause.ModifierConstructorDescription(package private)
HBaseRpcControllerImpl
(RegionInfo regionInfo, List<ExtendedCellScannable> cellIterables) (package private)
HBaseRpcControllerImpl
(RegionInfo regionInfo, ExtendedCellScanner cellScanner) -
Uses of RegionInfo in org.apache.hadoop.hbase.mapred
ModifierConstructorDescriptionTableSnapshotRegionSplit
(TableDescriptor htd, RegionInfo regionInfo, List<String> locations, Scan scan, org.apache.hadoop.fs.Path restoreDir) -
Uses of RegionInfo in org.apache.hadoop.hbase.mapreduce
Modifier and TypeFieldDescriptionprivate RegionInfo
TableSnapshotInputFormatImpl.InputSplit.regionInfo
Modifier and TypeMethodDescriptionTableSnapshotInputFormat.TableSnapshotRegionSplit.getRegion()
TableSnapshotInputFormatImpl.InputSplit.getRegionInfo()
Modifier and TypeMethodDescriptionstatic List<RegionInfo>
TableSnapshotInputFormatImpl.getRegionInfosFromManifest
(SnapshotManifest manifest) Modifier and TypeMethodDescriptionTableSnapshotInputFormatImpl.calculateLocationsForInputSplit
(org.apache.hadoop.conf.Configuration conf, TableDescriptor htd, RegionInfo hri, org.apache.hadoop.fs.Path tableDir) Compute block locations for snapshot files (which will get the locations for referred hfiles) only when localityEnabled is true.Modifier and TypeMethodDescriptionTableSnapshotInputFormatImpl.getSplits
(Scan scan, SnapshotManifest manifest, List<RegionInfo> regionManifests, org.apache.hadoop.fs.Path restoreDir, org.apache.hadoop.conf.Configuration conf) TableSnapshotInputFormatImpl.getSplits
(Scan scan, SnapshotManifest manifest, List<RegionInfo> regionManifests, org.apache.hadoop.fs.Path restoreDir, org.apache.hadoop.conf.Configuration conf, RegionSplitter.SplitAlgorithm sa, int numSplits) ModifierConstructorDescriptionInputSplit
(TableDescriptor htd, RegionInfo regionInfo, List<String> locations, Scan scan, org.apache.hadoop.fs.Path restoreDir) TableSnapshotRegionSplit
(TableDescriptor htd, RegionInfo regionInfo, List<String> locations, Scan scan, org.apache.hadoop.fs.Path restoreDir) -
Uses of RegionInfo in org.apache.hadoop.hbase.master
Modifier and TypeFieldDescriptionprivate final RegionInfo
RegionPlan.hri
private final RegionInfo
RegionState.hri
Modifier and TypeFieldDescriptionprivate final Map<ServerName,
List<RegionInfo>> SnapshotOfRegionAssignmentFromMeta.currentRSToRegionMap
the regionServer to region mapprivate List<RegionInfo>
AssignmentVerificationReport.nonFavoredAssignedRegionList
private final Map<ServerName,
List<RegionInfo>> SnapshotOfRegionAssignmentFromMeta.primaryRSToRegionMap
private final Map<String,
RegionInfo> SnapshotOfRegionAssignmentFromMeta.regionNameToRegionInfoMap
the region name to region info mapprivate List<RegionInfo>
AssignmentVerificationReport.regionsWithoutValidFavoredNodes
private Map<RegionInfo,
ServerName> SnapshotOfRegionAssignmentFromMeta.regionToRegionServerMap
the region to region server mapprivate final Map<ServerName,
List<RegionInfo>> SnapshotOfRegionAssignmentFromMeta.secondaryRSToRegionMap
private final Map<TableName,
List<RegionInfo>> SnapshotOfRegionAssignmentFromMeta.tableToRegionMap
the table name to region mapprivate final Map<ServerName,
List<RegionInfo>> SnapshotOfRegionAssignmentFromMeta.teritiaryRSToRegionMap
private List<RegionInfo>
AssignmentVerificationReport.unAssignedRegionsList
Modifier and TypeMethodDescriptionRegionState.getRegion()
private RegionInfo
MasterRpcServices.getRegionInfo
(org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionSpecifier rs) GetRegionInfo
from Master using content ofHBaseProtos.RegionSpecifier
as key.RegionPlan.getRegionInfo()
Modifier and TypeMethodDescription(package private) List<RegionInfo>
AssignmentVerificationReport.getNonFavoredAssignedRegions()
Return the regions not assigned to its favored nodesSnapshotOfRegionAssignmentFromMeta.getPrimaryToRegionInfoMap()
SnapshotOfRegionAssignmentFromMeta.getRegionNameToRegionInfoMap()
Get the regioninfo for a regionSnapshotOfRegionAssignmentFromMeta.getRegionServerToRegionMap()
Get regionserver to region map(package private) List<RegionInfo>
AssignmentVerificationReport.getRegionsWithoutValidFavoredNodes()
Return the regions without favored nodesSnapshotOfRegionAssignmentFromMeta.getRegionToRegionServerMap()
Get region to region server mapSnapshotOfRegionAssignmentFromMeta.getSecondaryToRegionInfoMap()
SnapshotOfRegionAssignmentFromMeta.getTableToRegionMap()
Get regions for tablesSnapshotOfRegionAssignmentFromMeta.getTertiaryToRegionInfoMap()
(package private) List<RegionInfo>
AssignmentVerificationReport.getUnassignedRegions()
Return the unassigned regionsLoadBalancer.retainAssignment
(Map<RegionInfo, ServerName> regions, List<ServerName> servers) Assign regions to the previously hosting region serverLoadBalancer.roundRobinAssignment
(List<RegionInfo> regions, List<ServerName> servers) Perform a Round Robin assignment of regions.Modifier and TypeMethodDescriptionprivate void
SnapshotOfRegionAssignmentFromMeta.addAssignment
(RegionInfo regionInfo, ServerName server) 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) static void
ServerManager.closeRegionSilentlyAndWait
(AsyncClusterConnection connection, ServerName server, RegionInfo region, long timeout) Contacts a region server and waits up to timeout ms to close the region.static RegionState
RegionState.createForTesting
(RegionInfo region, RegionState.State state) void
MasterFileSystem.deleteFamilyFromFS
(org.apache.hadoop.fs.Path rootDir, RegionInfo region, byte[] familyName) void
MasterFileSystem.deleteFamilyFromFS
(RegionInfo region, byte[] familyName) org.apache.hadoop.fs.Path
MasterFileSystem.getRegionDir
(RegionInfo region) Returns the directory for a giveregion
.boolean
ServerManager.isRegionInServerManagerStates
(RegionInfo hri) private boolean
HMaster.isRegionOnline
(RegionInfo ri) long
HMaster.mergeRegions
(RegionInfo[] regionsToMerge, boolean forcible, long ng, long nonce) long
MasterServices.mergeRegions
(RegionInfo[] regionsToMerge, boolean forcible, long nonceGroup, long nonce) Merge regions in a table.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 operationvoid
MasterCoprocessorHost.postCompletedSplitRegionAction
(RegionInfo regionInfoA, RegionInfo regionInfoB, User user) Invoked just after a splitvoid
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:metavoid
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 operationvoid
MasterCoprocessorHost.postTruncateRegion
(RegionInfo regionInfo) Invoked after calling the truncate region procedurevoid
MasterCoprocessorHost.postTruncateRegionAction
(RegionInfo region, User user) Invoked after calling the truncate region procedurevoid
MasterCoprocessorHost.postUnassign
(RegionInfo regionInfo) 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 mergevoid
MasterCoprocessorHost.preMergeRegionsCommit
(RegionInfo[] regionsToMerge, List<Mutation> metaEntries, User user) Invoked before merge regions operation writes the new region to hbase:metavoid
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.preTruncateRegion
(RegionInfo regionInfo) Invoked just before calling the truncate region procedurevoid
MasterCoprocessorHost.preTruncateRegionAction
(RegionInfo region, User user) Invoked just before calling the truncate region procedurevoid
MasterCoprocessorHost.preUnassign
(RegionInfo regionInfo) LoadBalancer.randomAssignment
(RegionInfo regionInfo, List<ServerName> servers) Get a random region server from the listvoid
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.long
HMaster.splitRegion
(RegionInfo regionInfo, byte[] splitRow, long nonceGroup, long nonce) long
MasterServices.splitRegion
(RegionInfo regionInfo, byte[] splitRow, long nonceGroup, long nonce) Split a region.long
HMaster.truncateRegion
(RegionInfo regionInfo, long nonceGroup, long nonce) long
MasterServices.truncateRegion
(RegionInfo regionInfo, long nonceGroup, long nonce) Truncate regionprivate void
HMaster.warmUpRegion
(ServerName server, RegionInfo region) Modifier and TypeMethodDescriptionLoadBalancer.balanceCluster
(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) Perform the major balance operation for cluster.void
ServerManager.removeRegions
(List<RegionInfo> regions) Called by delete table and similar to notify the ServerManager that a region was removed.LoadBalancer.retainAssignment
(Map<RegionInfo, ServerName> regions, List<ServerName> servers) Assign regions to the previously hosting region serverLoadBalancer.roundRobinAssignment
(List<RegionInfo> regions, List<ServerName> servers) Perform a Round Robin assignment of regions.default void
LoadBalancer.updateBalancerLoadInfo
(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) In some scenarios, Balancer needs to update internal status or information according to the current tables loadModifierConstructorDescriptionRegionPlan
(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) -
Uses of RegionInfo in org.apache.hadoop.hbase.master.assignment
Modifier and TypeFieldDescriptionprivate RegionInfo
SplitTableRegionProcedure.daughterOneRI
private RegionInfo
SplitTableRegionProcedure.daughterTwoRI
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 final RegionInfo
RegionStateNode.regionInfo
private final RegionInfo
RegionStateNodeLock.regionInfo
private RegionInfo
RegionTransitionProcedure.regionInfo
Deprecated.private RegionInfo[]
MergeTableRegionsProcedure.regionsToMerge
Two or more regions to merge, the 'merge parents'.Modifier and TypeFieldDescriptionprivate static final Set<RegionInfo>
AssignmentManager.META_REGION_SET
private List<RegionInfo>
GCMultipleMergedRegionsProcedure.parents
private final ConcurrentSkipListMap<RegionInfo,
RegionStateNode> RegionStates.regionInTransition
private final ConcurrentSkipListMap<RegionInfo,
RegionStateNode> RegionStates.regionOffline
Regions marked as offline on a read of hbase:meta.private final ConcurrentMap<RegionInfo,
RegionStateNode> RegionStateNode.ritMap
Modifier and TypeMethodDescriptionprivate static RegionInfo
MergeTableRegionsProcedure.createMergedRegionInfo
(RegionInfo[] regionsToMerge) Create merged region info by looking at passed inregionsToMerge
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.SplitTableRegionProcedure.getDaughterOneRI()
SplitTableRegionProcedure.getDaughterTwoRI()
(package private) RegionInfo
MergeTableRegionsProcedure.getMergedRegion()
Returns The merged region.private RegionInfo
AssignmentManager.getMetaForRegion
(RegionInfo regionInfo) AssignmentManager.getMetaRegionFromName
(byte[] regionName) private RegionInfo
SplitTableRegionProcedure.getParentRegion()
AssignmentManager.getRegionInfo
(byte[] regionName) Resolve a cachedRegionInfo
from the region name as abyte[]
.AssignmentManager.getRegionInfo
(String encodedRegionName) Resolve a cachedRegionInfo
from the encoded region name as aString
.private RegionInfo
AssignmentManager.getRegionInfo
(RegionStateNode rsn) RegionStateNode.getRegionInfo()
RegionStates.RegionFailedOpen.getRegionInfo()
RegionTransitionProcedure.getRegionInfo()
Deprecated.Modifier and TypeMethodDescriptionAssignmentManager.getAssignedRegions()
RegionStates.getAssignedRegions()
RegionStates.getAssignmentsForBalancer
(TableStateManager tableStateManager, List<ServerName> onlineServers) This is an EXPENSIVE clone.RegionStateStore.getMergeRegions
(RegionInfo region) Returns Return all regioninfos listed in the 'info:merge*' columns of the givenregion
.AssignmentManager.getMetaRegionSet()
RegionStates.getRegionAssignments()
RegionStates.getRegionByStateOfTable
(TableName tableName) ServerStateNode.getRegionInfoList()
RegionStates.getRegionsOfTable
(TableName table) Returns Return online regions of table; does not include OFFLINE or SPLITTING regions.private List<RegionInfo>
RegionStates.getRegionsOfTable
(TableName table, Predicate<RegionStateNode> filter) Returns Return the regions of the table and filter them.RegionStates.getRegionsOfTableForDeleting
(TableName table) Get the regions for deleting a table.RegionStates.getRegionsOfTableForEnabling
(TableName table) Get the regions for enabling a table.AssignmentManager.getRegionsOnServer
(ServerName serverName) Returns the regions hosted by the specified server.AssignmentManager.getSnapShotOfAssignment
(Collection<RegionInfo> regions) RegionStates.getSnapShotOfAssignment
(Collection<RegionInfo> regions) ServerStateNode.getSystemRegionInfoList()
private List<RegionInfo>
AssignmentManager.getSystemTables
(ServerName serverName) AssignmentManager.getTableRegions
(TableName tableName, boolean excludeOfflinedSplitParents) AssignmentManager.getTableRegionsAndLocations
(TableName tableName, boolean excludeOfflinedSplitParents) (package private) ArrayList<RegionInfo>
RegionStates.getTableRegionsInfo
(TableName tableName) private HashMap<RegionInfo,
RegionStateNode> AssignmentManager.waitOnAssignQueue()
Modifier and TypeMethodDescriptionlong
AssignmentManager.assign
(RegionInfo regionInfo) long
AssignmentManager.assign
(RegionInfo regionInfo, ServerName sn) static TransitRegionStateProcedure
TransitRegionStateProcedure.assign
(MasterProcedureEnv env, RegionInfo region, boolean forceNewPlan, ServerName targetServer) static TransitRegionStateProcedure
TransitRegionStateProcedure.assign
(MasterProcedureEnv env, RegionInfo region, ServerName targetServer) Future<byte[]>
AssignmentManager.assignAsync
(RegionInfo regionInfo) Submits a procedure that assigns a region without waiting for it to finishFuture<byte[]>
AssignmentManager.assignAsync
(RegionInfo regionInfo, ServerName sn) Submits a procedure that assigns a region to a target server without waiting for it to finish(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) Check whether the region is splittableprivate TransitRegionStateProcedure
AssignmentManager.createAssignProcedure
(RegionInfo regionInfo, ServerName sn, boolean override, boolean force) Create an assign TransitRegionStateProcedure.private static RegionInfo
MergeTableRegionsProcedure.createMergedRegionInfo
(RegionInfo[] regionsToMerge) Create merged region info by looking at passed inregionsToMerge
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.AssignmentManager.createMergeProcedure
(RegionInfo... ris) AssignmentManager.createMoveRegionProcedure
(RegionInfo regionInfo, ServerName targetServer) AssignmentManager.createOneAssignProcedure
(RegionInfo ri, boolean override, boolean force) Create one TransitRegionStateProcedure to assign a region w/o specifying a target server.AssignmentManager.createOneUnassignProcedure
(RegionInfo ri, boolean override, boolean force) Create one TransitRegionStateProcedure to unassign a region.(package private) RegionStateNode
RegionStates.createRegionStateNode
(RegionInfo regionInfo) AssignmentManager.createSplitProcedure
(RegionInfo regionToSplit, byte[] splitKey) AssignmentManager.createTruncateRegionProcedure
(RegionInfo regionToTruncate) void
RegionStateStore.deleteMergeQualifiers
(RegionInfo mergeRegion) Deletes merge qualifiers for the specified merge region.void
RegionStates.deleteRegion
(RegionInfo regionInfo) void
RegionStateStore.deleteRegion
(RegionInfo regionInfo) Deletes the specified region.private static long
SplitTableRegionProcedure.getDaughterRegionIdTimestamp
(RegionInfo hri) Calculate daughter regionid to use.RegionStates.getFailedOpen
(RegionInfo regionInfo) AssignmentManager.getFavoredNodes
(RegionInfo regionInfo) RegionStateStore.getMergeRegions
(RegionInfo region) Returns Return all regioninfos listed in the 'info:merge*' columns of the givenregion
.private ProcedureEvent<?>
AssignmentManager.getMetaAssignEvent
(RegionInfo metaRegionInfo) private RegionInfo
AssignmentManager.getMetaForRegion
(RegionInfo regionInfo) private long
RegionStateStore.getOpenSeqNumForParentRegion
(RegionInfo region) RegionStates.getOrCreateRegionStateNode
(RegionInfo regionInfo) private Result
RegionStateStore.getRegionCatalogResult
(RegionInfo region) (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) RegionStates.getRegionServerOfRegion
(RegionInfo regionInfo) RegionStates.getRegionState
(RegionInfo regionInfo) static RegionState.State
RegionStateStore.getRegionState
(Result r, RegionInfo regionInfo) Pull the region state from a catalog tableResult
.RegionStates.getRegionStateNode
(RegionInfo regionInfo) RegionStates.getRegionTransitionState
(RegionInfo hri) private void
AssignmentManager.handleRegionOverStuckWarningThreshold
(RegionInfo regionInfo) boolean
RegionStateStore.hasMergeRegions
(RegionInfo region) Check whether the givenregion
has any 'info:merge*' columns.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) Returns True if region is offline (In OFFLINE or CLOSED state).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.markRegionAsSplit
(RegionInfo parent, ServerName serverName, RegionInfo daughterA, RegionInfo daughterB) void
RegionStateStore.mergeRegions
(RegionInfo child, RegionInfo[] parents, ServerName serverName, TableDescriptor htd) private List<org.apache.hadoop.fs.Path>
MergeTableRegionsProcedure.mergeStoreFiles
(MasterProcedureEnv env, HRegionFileSystem regionFs, HRegionFileSystem mergeRegionFs, RegionInfo mergedRegion) private void
RegionStateStore.mirrorMetaLocation
(RegionInfo regionInfo, ServerName serverName, RegionState.State state) void
AssignmentManager.move
(RegionInfo regionInfo) static TransitRegionStateProcedure
TransitRegionStateProcedure.move
(MasterProcedureEnv env, RegionInfo region, ServerName targetServer) private void
RegionStateStore.multiMutate
(RegionInfo ri, List<Mutation> mutations) Performs an atomic multi-mutate operation against the given table.void
AssignmentManager.offlineRegion
(RegionInfo regionInfo) void
AssignmentManager.onlineRegion
(RegionInfo regionInfo, ServerName serverName) void
AssignmentManager.populateRegionStatesFromMeta
(RegionInfo regionInfo) Attempt to loadregionInfo
from META, adding any results to theAssignmentManager.regionStateStore
Is NOT aware of replica regions.void
RegionStates.removeFromFailedOpen
(RegionInfo regionInfo) static TransitRegionStateProcedure
TransitRegionStateProcedure.reopen
(MasterProcedureEnv env, RegionInfo region) private void
AssignmentManager.setMetaAssigned
(RegionInfo metaRegionInfo, boolean assigned) void
RegionTransitionProcedure.setRegionInfo
(RegionInfo regionInfo) Deprecated.private boolean
AssignmentManager.shouldAssignFavoredNodes
(RegionInfo region) void
RegionStateStore.splitRegion
(RegionInfo parent, RegionInfo splitA, RegionInfo splitB, ServerName serverName, TableDescriptor htd) Splits the region into two in an atomic operation.long
AssignmentManager.unassign
(RegionInfo regionInfo) static TransitRegionStateProcedure
TransitRegionStateProcedure.unassign
(MasterProcedureEnv env, RegionInfo region) static TransitRegionStateProcedure
TransitRegionStateProcedure.unassignSplitMerge
(MasterProcedureEnv env, RegionInfo region) private CompletableFuture<Void>
RegionStateStore.updateRegionLocation
(RegionInfo regionInfo, RegionState.State state, Put put) private void
AssignmentManager.updateRegionMergeTransition
(ServerStateNode serverNode, org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode state, RegionInfo merged, RegionInfo hriA, RegionInfo hriB) private void
AssignmentManager.updateRegionSplitTransition
(ServerStateNode serverNode, 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
(ServerStateNode serverNode, org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode state, RegionInfo regionInfo, long seqId, long procId) void
AssignmentManager.RegionMetaLoadingVisitor.visitRegionState
(Result result, RegionInfo regionInfo, RegionState.State state, ServerName regionLocation, ServerName lastHost, long openSeqNum) 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 TypeMethodDescriptionprivate 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) (package private) static Put
RegionStateStore.addMergeRegions
(Put put, Collection<RegionInfo> mergeRegions) 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) 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) Tied toAssignmentManager.createAssignProcedures(List)
in that it is called if caller is unable to run this method.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 theregionReplication
.(package private) static TransitRegionStateProcedure[]
AssignmentManagerUtil.createAssignProceduresForOpeningNewRegions
(MasterProcedureEnv env, List<RegionInfo> regions, int regionReplication, ServerName targetServer) (package private) static TransitRegionStateProcedure[]
AssignmentManagerUtil.createAssignProceduresForSplitDaughters
(MasterProcedureEnv env, List<RegionInfo> daughters, int regionReplication, ServerName parentServer) AssignmentManager.createRoundRobinAssignProcedures
(List<RegionInfo> hris) Create round-robin assigns.AssignmentManager.createRoundRobinAssignProcedures
(List<RegionInfo> hris, List<ServerName> serversToExclude) Create round-robin assigns.private static TransitRegionStateProcedure[]
AssignmentManagerUtil.createRoundRobinAssignProcedures
(MasterProcedureEnv env, List<RegionInfo> regions, int regionReplication, List<ServerName> serversToExclude, boolean ignoreIfInTransition) Create round robin assign procedures for the given regions, according to theregionReplication
.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
RegionStates.deleteRegions
(List<RegionInfo> regionInfos) void
RegionStateStore.deleteRegions
(List<RegionInfo> regions) Deletes the specified regions.private void
RegionStateStore.deleteRegions
(List<RegionInfo> regions, long ts) AssignmentManager.getSnapShotOfAssignment
(Collection<RegionInfo> regions) RegionStates.getSnapShotOfAssignment
(Collection<RegionInfo> regions) void
RegionStateStore.overwriteRegions
(List<RegionInfo> regionInfos, int regionReplication) Overwrites the specified regions from hbase:meta.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) ModifierConstructorDescriptionAssignmentProcedureEvent
(RegionInfo regionInfo) CloseRegionProcedure
(TransitRegionStateProcedure parent, RegionInfo region, ServerName targetServer, ServerName assignCandidate, boolean isSplit) GCMergedRegionsProcedure
(MasterProcedureEnv env, RegionInfo mergedChild, RegionInfo father, RegionInfo mother) Deprecated.GCMultipleMergedRegionsProcedure
(MasterProcedureEnv env, RegionInfo mergedChild, List<RegionInfo> parents) GCRegionProcedure
(MasterProcedureEnv env, RegionInfo hri) MergeTableRegionsProcedure
(MasterProcedureEnv env, RegionInfo[] regionsToMerge, boolean force) OpenRegionProcedure
(TransitRegionStateProcedure parent, RegionInfo region, ServerName targetServer) protected
RegionRemoteProcedureBase
(TransitRegionStateProcedure parent, RegionInfo region, ServerName targetServer) (package private)
RegionStateNode
(RegionInfo regionInfo, ConcurrentMap<RegionInfo, RegionStateNode> ritMap) (package private)
RegionStateNodeLock
(RegionInfo regionInfo) RegionTransitionProcedure
(RegionInfo regionInfo) Deprecated.SplitTableRegionProcedure
(MasterProcedureEnv env, RegionInfo regionToSplit, byte[] splitRow) protected
TransitRegionStateProcedure
(MasterProcedureEnv env, RegionInfo hri, ServerName assignCandidate, boolean forceNewPlan, TransitRegionStateProcedure.TransitionType type) protected
TransitRegionStateProcedure
(MasterProcedureEnv env, RegionInfo hri, ServerName assignCandidate, boolean forceNewPlan, TransitRegionStateProcedure.TransitionType type, boolean isSplit) ModifierConstructorDescriptionGCMultipleMergedRegionsProcedure
(MasterProcedureEnv env, RegionInfo mergedChild, List<RegionInfo> parents) (package private)
RegionStateNode
(RegionInfo regionInfo, ConcurrentMap<RegionInfo, RegionStateNode> ritMap) -
Uses of RegionInfo in org.apache.hadoop.hbase.master.balancer
Modifier and TypeFieldDescriptionprivate org.apache.hbase.thirdparty.com.google.common.cache.LoadingCache<RegionInfo,
HDFSBlocksDistribution> RegionHDFSBlockLocationFinder.cache
(package private) Map<ServerName,
List<RegionInfo>> BalancerClusterState.clusterState
private final Map<ServerName,
List<RegionInfo>> ClusterLoadState.clusterState
private List<RegionInfo>
SimpleLoadBalancer.BalanceInfo.hriList
private org.apache.hbase.thirdparty.com.google.common.cache.CacheLoader<RegionInfo,
HDFSBlocksDistribution> RegionHDFSBlockLocationFinder.loader
private List<RegionInfo>
LoadBalancerPerformanceEvaluation.regions
private Map<RegionInfo,
ServerName> LoadBalancerPerformanceEvaluation.regionServerMap
(package private) Map<RegionInfo,
Integer> BalancerClusterState.regionsToIndex
private final NavigableMap<ServerAndLoad,
List<RegionInfo>> ClusterLoadState.serversByLoad
private Map<TableName,
Map<ServerName, List<RegionInfo>>> LoadBalancerPerformanceEvaluation.tableServerRegionMap
Modifier and TypeMethodDescriptionprivate RegionInfo
CacheAwareLoadBalancer.getRegionInfoByEncodedName
(BalancerClusterState cluster, String regionName) Modifier and TypeMethodDescriptionprivate Map<ServerName,
List<RegionInfo>> MaintenanceLoadBalancer.assign
(Collection<RegionInfo> regions, List<ServerName> servers) private org.apache.hbase.thirdparty.com.google.common.cache.LoadingCache<RegionInfo,
HDFSBlocksDistribution> RegionHDFSBlockLocationFinder.createCache()
Create a cache for region to list of serversprivate Map<ServerName,
List<RegionInfo>> FavoredStochasticBalancer.generateFNForRegionsWithoutFN
(FavoredNodeAssignmentHelper helper, List<RegionInfo> regions) ClusterInfoProvider.getAssignedRegions()
Get all the regions of this cluster.MasterClusterInfoProvider.getAssignedRegions()
(package private) org.apache.hbase.thirdparty.com.google.common.cache.LoadingCache<RegionInfo,
HDFSBlocksDistribution> RegionHDFSBlockLocationFinder.getCache()
(package private) Map<ServerName,
List<RegionInfo>> ClusterLoadState.getClusterState()
(package private) List<RegionInfo>
SimpleLoadBalancer.BalanceInfo.getHriList()
private Map<ServerName,
List<RegionInfo>> BaseLoadBalancer.getRegionAssignmentsByServer
(Collection<RegionInfo> regions) (package private) NavigableMap<ServerAndLoad,
List<RegionInfo>> ClusterLoadState.getServersByLoad()
ClusterInfoProvider.getSnapShotOfAssignment
(Collection<RegionInfo> regions) Get a snapshot of the current assignment status.MasterClusterInfoProvider.getSnapShotOfAssignment
(Collection<RegionInfo> regions) 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.FavoredStochasticBalancer.retainAssignment
(Map<RegionInfo, ServerName> regions, List<ServerName> servers) Reuse BaseLoadBalancer's retainAssignment, but generate favored nodes when its missing.MaintenanceLoadBalancer.retainAssignment
(Map<RegionInfo, ServerName> regions, List<ServerName> servers) 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.FavoredStochasticBalancer.roundRobinAssignment
(List<RegionInfo> regions, List<ServerName> servers) Round robin assignment: Segregate the regions into two types: 1.MaintenanceLoadBalancer.roundRobinAssignment
(List<RegionInfo> regions, List<ServerName> servers) private Pair<Map<ServerName,
List<RegionInfo>>, List<RegionInfo>> FavoredStochasticBalancer.segregateRegionsAndAssignRegionsWithFavoredNodes
(Collection<RegionInfo> regions, List<ServerName> onlineServers) Return a pair - one with assignments when favored nodes are present and another with regions without favored nodes.private Pair<Map<ServerName,
List<RegionInfo>>, List<RegionInfo>> FavoredStochasticBalancer.segregateRegionsAndAssignRegionsWithFavoredNodes
(Collection<RegionInfo> regions, List<ServerName> onlineServers) Return a pair - one with assignments when favored nodes are present and another with regions without favored nodes.protected final Map<ServerName,
List<RegionInfo>> BaseLoadBalancer.toEnsumbleTableLoad
(Map<TableName, Map<ServerName, List<RegionInfo>>> LoadOfAllTable) Modifier and TypeMethodDescriptionprivate 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) Assign the region to primary if its available.private org.apache.hbase.thirdparty.com.google.common.util.concurrent.ListenableFuture<HDFSBlocksDistribution>
RegionHDFSBlockLocationFinder.asyncGetBlockDistribution
(RegionInfo hri) int
RegionInfoComparator.compare
(RegionInfo l, RegionInfo r) ClusterInfoProvider.computeHDFSBlocksDistribution
(org.apache.hadoop.conf.Configuration conf, TableDescriptor tableDescriptor, RegionInfo regionInfo) Compute the block distribution for the given region.MasterClusterInfoProvider.computeHDFSBlocksDistribution
(org.apache.hadoop.conf.Configuration conf, TableDescriptor tableDescriptor, RegionInfo regionInfo) (package private) void
BalancerClusterState.doAssignRegion
(RegionInfo regionInfo, ServerName serverName) void
FavoredStochasticBalancer.generateFavoredNodesForDaughter
(List<ServerName> servers, RegionInfo parent, RegionInfo regionA, RegionInfo regionB) Generate Favored Nodes for daughters during region split.void
FavoredStochasticBalancer.generateFavoredNodesForMergedRegion
(RegionInfo merged, RegionInfo[] mergeParents) Generate favored nodes for a region during merge.(package private) HDFSBlocksDistribution
RegionHDFSBlockLocationFinder.getBlockDistribution
(RegionInfo hri) FavoredStochasticBalancer.getFavoredNodes
(RegionInfo regionInfo) (package private) List<ServerName>
RegionHDFSBlockLocationFinder.getTopBlockLocations
(RegionInfo region) private HDFSBlocksDistribution
RegionHDFSBlockLocationFinder.internalGetTopBlockLocation
(RegionInfo region) Returns an ordered list of hosts that are hosting the blocks for this region.BaseLoadBalancer.randomAssignment
(RegionInfo regionInfo, List<ServerName> servers) Used to assign a single region to a random server.private ServerName
BaseLoadBalancer.randomAssignment
(BalancerClusterState cluster, RegionInfo regionInfo, List<ServerName> servers) Used to assign a single region to a random server.FavoredStochasticBalancer.randomAssignment
(RegionInfo regionInfo, List<ServerName> servers) If we have favored nodes for a region, we will return one of the FN as destination.MaintenanceLoadBalancer.randomAssignment
(RegionInfo regionInfo, List<ServerName> servers) void
BaseLoadBalancer.regionOffline
(RegionInfo regionInfo) void
MaintenanceLoadBalancer.regionOffline
(RegionInfo regionInfo) void
BaseLoadBalancer.regionOnline
(RegionInfo regionInfo, ServerName sn) void
MaintenanceLoadBalancer.regionOnline
(RegionInfo regionInfo, ServerName sn) private void
BalancerClusterState.registerRegion
(RegionInfo region, int regionIndex, int serverIndex, Map<String, Deque<BalancerRegionLoad>> loads, RegionHDFSBlockLocationFinder regionFinder) Helper for Cluster constructor to handle a regionvoid
ClusterInfoProvider.unassign
(RegionInfo regionInfo) Unassign the given region.void
MasterClusterInfoProvider.unassign
(RegionInfo regionInfo) private void
FavoredStochasticBalancer.updateFavoredNodesForRegion
(RegionInfo regionInfo, List<ServerName> newFavoredNodes) (package private) boolean
BalancerClusterState.wouldLowerAvailability
(RegionInfo regionInfo, ServerName serverName) Return true if the placement of region on server would lower the availability of the region in questionModifier and TypeMethodDescriptionprivate void
FavoredStochasticBalancer.addRegionToMap
(Map<ServerName, List<RegionInfo>> assignmentMapForFavoredNodes, RegionInfo region, ServerName host) private Map<ServerName,
List<RegionInfo>> MaintenanceLoadBalancer.assign
(Collection<RegionInfo> regions, List<ServerName> servers) private void
FavoredStochasticBalancer.assignRegionToAvailableFavoredNode
(Map<ServerName, List<RegionInfo>> assignmentMapForFavoredNodes, RegionInfo region, ServerName primaryHost, ServerName secondaryHost, ServerName tertiaryHost) Assign the region to primary if its available.final List<RegionPlan>
BaseLoadBalancer.balanceCluster
(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) Perform the major balance operation for cluster, will invokeBaseLoadBalancer.balanceTable(TableName, Map)
to do actual balance.MaintenanceLoadBalancer.balanceCluster
(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) protected abstract List<RegionPlan>
BaseLoadBalancer.balanceTable
(TableName tableName, Map<ServerName, List<RegionInfo>> loadOfOneTable) Perform the major balance operation for table, all sub classes should override this method.protected List<RegionPlan>
FavoredStochasticBalancer.balanceTable
(TableName tableName, Map<ServerName, List<RegionInfo>> loadOfOneTable) For all regions correctly assigned to favored nodes, we just use the stochastic balancer implementation.protected List<RegionPlan>
SimpleLoadBalancer.balanceTable
(TableName tableName, Map<ServerName, List<RegionInfo>> loadOfOneTable) Generate a global load balancing plan according to the specified map of server information to the most loaded regions of each server.protected List<RegionPlan>
StochasticLoadBalancer.balanceTable
(TableName tableName, Map<ServerName, List<RegionInfo>> loadOfOneTable) Given the cluster state this will try and approach an optimal balance.private BalancerClusterState
BaseLoadBalancer.createCluster
(List<ServerName> servers, Collection<RegionInfo> regions) private Map<ServerName,
List<RegionInfo>> FavoredStochasticBalancer.generateFNForRegionsWithoutFN
(FavoredNodeAssignmentHelper helper, List<RegionInfo> regions) private Map<ServerName,
List<RegionInfo>> BaseLoadBalancer.getRegionAssignmentsByServer
(Collection<RegionInfo> regions) ClusterInfoProvider.getSnapShotOfAssignment
(Collection<RegionInfo> regions) Get a snapshot of the current assignment status.MasterClusterInfoProvider.getSnapShotOfAssignment
(Collection<RegionInfo> regions) boolean
ClusterInfoProvider.hasRegionReplica
(Collection<RegionInfo> regions) Check whether we have region replicas enabled for the tables of the given regions.boolean
MasterClusterInfoProvider.hasRegionReplica
(Collection<RegionInfo> regions) private void
FavoredStochasticBalancer.mergeAssignmentMaps
(Map<ServerName, List<RegionInfo>> assignmentMap, Map<ServerName, List<RegionInfo>> otherAssignments) protected void
BaseLoadBalancer.preBalanceCluster
(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) Called before actually executing balanceCluster.protected void
SimpleLoadBalancer.preBalanceCluster
(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) (package private) void
RegionHDFSBlockLocationFinder.refreshAndWait
(Collection<RegionInfo> hris) 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.FavoredStochasticBalancer.retainAssignment
(Map<RegionInfo, ServerName> regions, List<ServerName> servers) Reuse BaseLoadBalancer's retainAssignment, but generate favored nodes when its missing.MaintenanceLoadBalancer.retainAssignment
(Map<RegionInfo, ServerName> regions, List<ServerName> servers) 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.private void
BaseLoadBalancer.roundRobinAssignment
(BalancerClusterState cluster, List<RegionInfo> regions, List<ServerName> servers, Map<ServerName, List<RegionInfo>> assignments) Round-robin a list of regions to a list of serversprivate void
BaseLoadBalancer.roundRobinAssignment
(BalancerClusterState cluster, List<RegionInfo> regions, List<ServerName> servers, Map<ServerName, List<RegionInfo>> assignments) Round-robin a list of regions to a list of serversFavoredStochasticBalancer.roundRobinAssignment
(List<RegionInfo> regions, List<ServerName> servers) Round robin assignment: Segregate the regions into two types: 1.MaintenanceLoadBalancer.roundRobinAssignment
(List<RegionInfo> regions, List<ServerName> servers) private Pair<Map<ServerName,
List<RegionInfo>>, List<RegionInfo>> FavoredStochasticBalancer.segregateRegionsAndAssignRegionsWithFavoredNodes
(Collection<RegionInfo> regions, List<ServerName> onlineServers) Return a pair - one with assignments when favored nodes are present and another with regions without favored nodes.(package private) void
SimpleLoadBalancer.setClusterLoad
(Map<TableName, Map<ServerName, List<RegionInfo>>> clusterLoad) Pass RegionStates and allow balancer to set the current cluster load.protected final Map<ServerName,
List<RegionInfo>> BaseLoadBalancer.toEnsumbleTableLoad
(Map<TableName, Map<ServerName, List<RegionInfo>>> LoadOfAllTable) void
StochasticLoadBalancer.updateBalancerLoadInfo
(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) private void
StochasticLoadBalancer.updateBalancerTableLoadInfo
(TableName tableName, Map<ServerName, List<RegionInfo>> loadOfOneTable) ModifierConstructorDescriptionBalanceInfo
(int nextRegionForUnload, int numRegionsAdded, List<RegionInfo> hriList) (package private)
BalancerClusterState
(Collection<RegionInfo> unassignedRegions, Map<ServerName, List<RegionInfo>> clusterState, Map<String, Deque<BalancerRegionLoad>> loads, RegionHDFSBlockLocationFinder regionFinder, RackManager rackManager, Map<String, Pair<ServerName, Float>> oldRegionServerRegionCacheRatio) (package private)
BalancerClusterState
(Collection<RegionInfo> unassignedRegions, Map<ServerName, List<RegionInfo>> clusterState, Map<String, Deque<BalancerRegionLoad>> loads, RegionHDFSBlockLocationFinder regionFinder, RackManager rackManager, Map<String, Pair<ServerName, Float>> oldRegionServerRegionCacheRatio) (package private)
BalancerClusterState
(Map<ServerName, List<RegionInfo>> clusterState, Map<String, Deque<BalancerRegionLoad>> loads, RegionHDFSBlockLocationFinder regionFinder, RackManager rackManager) protected
BalancerClusterState
(Map<ServerName, List<RegionInfo>> clusterState, Map<String, Deque<BalancerRegionLoad>> loads, RegionHDFSBlockLocationFinder regionFinder, RackManager rackManager, Map<String, Pair<ServerName, Float>> oldRegionServerRegionCacheRatio) ClusterLoadState
(Map<ServerName, List<RegionInfo>> clusterState) -
Uses of RegionInfo in org.apache.hadoop.hbase.master.http
Modifier and TypeFieldDescriptionprivate final Map<String,
RegionInfo> RegionReplicaInfo.mergeRegionInfo
private final Map<String,
RegionInfo> RegionReplicaInfo.splitRegionInfo
Modifier and TypeMethodDescriptionRegionReplicaInfo.getMergeRegionInfo()
RegionReplicaInfo.getSplitRegionInfo()
-
Uses of RegionInfo in org.apache.hadoop.hbase.master.http.hbck.resource
-
Uses of RegionInfo in org.apache.hadoop.hbase.master.janitor
Modifier and TypeFieldDescriptionprivate RegionInfo
ReportMakingVisitor.highestEndKeyRegionInfo
Keep account of the highest end key seen as we move through hbase:meta.private RegionInfo
ReportMakingVisitor.previous
RegionInfo from previous row.Modifier and TypeFieldDescription(package private) final List<Pair<RegionInfo,
RegionInfo>> CatalogJanitorReport.holes
(package private) final List<Pair<RegionInfo,
RegionInfo>> CatalogJanitorReport.holes
(package private) final Map<RegionInfo,
Result> CatalogJanitorReport.mergedRegions
(package private) final List<Pair<RegionInfo,
RegionInfo>> CatalogJanitorReport.overlaps
(package private) final List<Pair<RegionInfo,
RegionInfo>> CatalogJanitorReport.overlaps
(package private) final Map<RegionInfo,
Result> CatalogJanitorReport.splitParents
(package private) final List<Pair<RegionInfo,
ServerName>> CatalogJanitorReport.unknownServers
TODO: If CatalogJanitor finds an 'Unknown Server', it should 'fix' it by queuing aHBCKServerCrashProcedure
for found server for it to clean up meta.Modifier and TypeMethodDescriptionprivate static RegionInfo
MetaFixer.buildRegionInfo
(TableName tn, byte[] start, byte[] end) (package private) static RegionInfo
MetaFixer.getRegionInfoWithLargestEndKey
(RegionInfo a, RegionInfo b) private RegionInfo
ReportMakingVisitor.metaTableConsistencyCheck
(Result metaTableRow) Check row.Modifier and TypeMethodDescription(package private) static List<SortedSet<RegionInfo>>
MetaFixer.calculateMerges
(int maxMergeCount, List<Pair<RegionInfo, RegionInfo>> overlaps) Run throughoverlaps
and return a list of merges to run.private static List<RegionInfo>
MetaFixer.createMetaEntries
(MasterServices masterServices, List<RegionInfo> newRegionInfos) Create entries in thehbase:meta
for each providedRegionInfo
.private static List<RegionInfo>
MetaFixer.createRegionInfosForHoles
(List<Pair<RegionInfo, RegionInfo>> holes) Create a newRegionInfo
corresponding to each provided "hole" pair.private static Optional<RegionInfo>
MetaFixer.getHoleCover
(Pair<RegionInfo, RegionInfo> hole) CatalogJanitorReport.getHoles()
CatalogJanitorReport.getHoles()
CatalogJanitorReport.getMergedRegions()
CatalogJanitorReport.getOverlaps()
CatalogJanitorReport.getOverlaps()
CatalogJanitorReport.getUnknownServers()
Modifier and TypeMethodDescriptionprivate void
ReportMakingVisitor.addHole
(RegionInfo a, RegionInfo b) private void
ReportMakingVisitor.addOverlap
(RegionInfo a, RegionInfo b) CatalogJanitor.checkRegionReferences
(MasterServices services, TableName tableName, RegionInfo region) Checks if a region still holds references to parent.(package private) static boolean
CatalogJanitor.cleanMergeRegion
(MasterServices services, 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:metaprivate boolean
CatalogJanitor.cleanParent
(RegionInfo parent, Result rowContent) If daughters no longer hold reference to the parents, delete the parent.(package private) static boolean
CatalogJanitor.cleanParent
(MasterServices services, RegionInfo parent, Result rowContent) int
CatalogJanitor.SplitParentFirstComparator.compare
(RegionInfo left, RegionInfo right) (package private) static RegionInfo
MetaFixer.getRegionInfoWithLargestEndKey
(RegionInfo a, RegionInfo b) (package private) static boolean
MetaFixer.isOverlap
(RegionInfo ri, Pair<RegionInfo, RegionInfo> pair) (package private) boolean
ReportMakingVisitor.isTableDisabled
(RegionInfo ri) Returns True if table is disabled or disabling; defaults false!private boolean
ReportMakingVisitor.isTableTransition
(RegionInfo ri) Returns True iff first row in hbase:meta or if we've broached a new table in hbase:metaModifier and TypeMethodDescription(package private) static List<SortedSet<RegionInfo>>
MetaFixer.calculateMerges
(int maxMergeCount, List<Pair<RegionInfo, RegionInfo>> overlaps) Run throughoverlaps
and return a list of merges to run.(package private) static List<SortedSet<RegionInfo>>
MetaFixer.calculateMerges
(int maxMergeCount, List<Pair<RegionInfo, RegionInfo>> overlaps) Run throughoverlaps
and return a list of merges to run.private static void
MetaFixer.calculateTableMerges
(int maxMergeCount, List<SortedSet<RegionInfo>> merges, Collection<Pair<RegionInfo, RegionInfo>> overlaps) private static void
MetaFixer.calculateTableMerges
(int maxMergeCount, List<SortedSet<RegionInfo>> merges, Collection<Pair<RegionInfo, RegionInfo>> overlaps) private static void
MetaFixer.calculateTableMerges
(int maxMergeCount, List<SortedSet<RegionInfo>> merges, Collection<Pair<RegionInfo, RegionInfo>> overlaps) (package private) static boolean
CatalogJanitor.cleanMergeRegion
(MasterServices services, 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:metaprivate static List<RegionInfo>
MetaFixer.createMetaEntries
(MasterServices masterServices, List<RegionInfo> newRegionInfos) Create entries in thehbase:meta
for each providedRegionInfo
.private static List<RegionInfo>
MetaFixer.createRegionInfosForHoles
(List<Pair<RegionInfo, RegionInfo>> holes) Create a newRegionInfo
corresponding to each provided "hole" pair.private static List<RegionInfo>
MetaFixer.createRegionInfosForHoles
(List<Pair<RegionInfo, RegionInfo>> holes) Create a newRegionInfo
corresponding to each provided "hole" pair.private static Optional<RegionInfo>
MetaFixer.getHoleCover
(Pair<RegionInfo, RegionInfo> hole) private static Optional<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) -
Uses of RegionInfo in org.apache.hadoop.hbase.master.locking
Modifier and TypeFieldDescriptionprivate final RegionInfo[]
LockManager.MasterLock.regionInfos
private RegionInfo[]
LockProcedure.regionInfos
Modifier and TypeMethodDescriptionLockManager.createMasterLock
(RegionInfo[] regionInfos, String description) long
LockManager.RemoteLocks.requestRegionsLock
(RegionInfo[] regionInfos, String description, NonceKey nonceKey) ModifierConstructorDescriptionLockProcedure
(org.apache.hadoop.conf.Configuration conf, RegionInfo[] regionInfos, LockType type, String description, CountDownLatch lockAcquireLatch) Constructor for region lock(s).MasterLock
(RegionInfo[] regionInfos, String description) -
Uses of RegionInfo in org.apache.hadoop.hbase.master.normalizer
Modifier and TypeFieldDescriptionprivate final List<RegionInfo>
SimpleRegionNormalizer.NormalizeContext.tableRegions
Modifier and TypeMethodDescriptionMergeNormalizationPlan.Builder.addTarget
(RegionInfo regionInfo, long regionSizeMb) private long
SimpleRegionNormalizer.getRegionSizeMB
(RegionInfo hri) Returns size of region in MB and if region is not found than -1private boolean
SimpleRegionNormalizer.isLargeEnoughForMerge
(SimpleRegionNormalizer.NormalizerConfiguration normalizerConfiguration, SimpleRegionNormalizer.NormalizeContext ctx, RegionInfo regionInfo) Returntrue
whenregionInfo
has a size that is sufficient to be considered for a merge operation,false
otherwise.private static boolean
SimpleRegionNormalizer.isOldEnoughForMerge
(SimpleRegionNormalizer.NormalizerConfiguration normalizerConfiguration, SimpleRegionNormalizer.NormalizeContext ctx, RegionInfo regionInfo) Returntrue
whenregionInfo
has a creation date that is old enough to be considered for a merge operation,false
otherwise.private boolean
SimpleRegionNormalizer.skipForMerge
(SimpleRegionNormalizer.NormalizerConfiguration normalizerConfiguration, SimpleRegionNormalizer.NormalizeContext ctx, RegionInfo regionInfo) Determine if aRegionInfo
should be considered for a merge operation.private static boolean
SimpleRegionNormalizer.skipForSplit
(RegionState state, RegionInfo regionInfo) Determine if a region inRegionState
should be considered for a split operation.Modifier and TypeMethodDescriptionprivate double
SimpleRegionNormalizer.getAverageRegionSizeMb
(List<RegionInfo> tableRegions, TableDescriptor tableDescriptor) Also make sure tableRegions contains regions of the same tableModifierConstructorDescription(package private)
NormalizationTarget
(RegionInfo regionInfo, long regionSizeMb) (package private)
SplitNormalizationPlan
(RegionInfo splitTarget, long splitTargetSizeMb) -
Uses of RegionInfo in org.apache.hadoop.hbase.master.procedure
Modifier and TypeFieldDescriptionprivate RegionInfo
AbstractStateMachineRegionProcedure.hri
private RegionInfo
FlushRegionProcedure.region
private RegionInfo
SnapshotRegionProcedure.region
private RegionInfo
SnapshotVerifyProcedure.region
protected final RegionInfo
RSProcedureDispatcher.RegionOperation.regionInfo
Modifier and TypeFieldDescriptionprivate List<RegionInfo>
CloneSnapshotProcedure.newRegions
private List<RegionInfo>
CreateTableProcedure.newRegions
private final List<RegionInfo>
HBCKServerCrashProcedure.UnknownServerVisitor.reassigns
private List<RegionInfo>
DeleteTableProcedure.regions
private List<RegionInfo>
TruncateTableProcedure.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 TypeMethodDescription(package private) RegionInfo
CreateTableProcedure.getFirstRegionInfo()
(package private) RegionInfo
TruncateTableProcedure.getFirstRegionInfo()
AbstractStateMachineRegionProcedure.getRegion()
Returns The RegionInfo of the region we are operating on.SnapshotRegionProcedure.getRegion()
Modifier and TypeMethodDescriptionprotected 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.private List<RegionInfo>
CloneSnapshotProcedure.createFsLayout
(MasterProcedureEnv env, TableDescriptor tableDescriptor, List<RegionInfo> newRegions, CreateTableProcedure.CreateHdfsRegions hdfsRegionHandler) Create region layout 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) CreateTableProcedure.CreateHdfsRegions.createHdfsRegions
(MasterProcedureEnv env, org.apache.hadoop.fs.Path tableRootDir, TableName tableName, List<RegionInfo> newRegions) private Stream<RegionInfo>
SnapshotProcedure.getDefaultRegionReplica
(MasterProcedureEnv env) 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) Returns List of Regions on crashed server.private static List<RegionInfo>
TruncateTableProcedure.recreateRegionInfo
(List<RegionInfo> regions) Modifier and TypeMethodDescriptionprotected static void
AbstractStateMachineTableProcedure.checkOnline
(MasterProcedureEnv env, RegionInfo ri) Check region is online.protected final 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... regionInfos) 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 regionvoid
MasterProcedureScheduler.wakeRegions
(Procedure<?> procedure, TableName table, RegionInfo... regionInfos) Wake the procedures waiting for the specified regionsModifier and TypeMethodDescriptionprivate void
RestoreSnapshotProcedure.addRegionsToInMemoryStates
(List<RegionInfo> regionInfos, MasterProcedureEnv env, int regionReplication) Add regions to in-memory statesprivate static void
CreateTableProcedure.addRegionsToMeta
(MasterProcedureEnv env, TableDescriptor tableDescriptor, List<RegionInfo> regionInfos) Add the specified set of regions to the hbase:meta table.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.private List<RegionInfo>
CloneSnapshotProcedure.createFsLayout
(MasterProcedureEnv env, TableDescriptor tableDescriptor, List<RegionInfo> newRegions, CreateTableProcedure.CreateHdfsRegions hdfsRegionHandler) Create region layout 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) 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 systemprotected 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 statesprivate static int
EnableTableProcedure.getMaxReplicaId
(List<RegionInfo> regions) Returns Maximum region replica id found in passed list of regions.private static List<RegionInfo>
TruncateTableProcedure.recreateRegionInfo
(List<RegionInfo> regions) private void
SnapshotProcedure.snapshotSplitOrClosedRegions
(MasterProcedureEnv env, List<RegionInfo> regions, String threadPoolName) protected static void
ProcedureSyncWait.waitRegionInTransition
(MasterProcedureEnv env, List<RegionInfo> regions) ModifierConstructorDescriptionprotected
protected
AbstractStateMachineRegionProcedure
(MasterProcedureEnv env, RegionInfo hri, ProcedurePrepareLatch latch) CreateTableProcedure
(MasterProcedureEnv env, TableDescriptor tableDescriptor, RegionInfo[] newRegions) CreateTableProcedure
(MasterProcedureEnv env, TableDescriptor tableDescriptor, RegionInfo[] newRegions, ProcedurePrepareLatch syncLatch) FlushRegionProcedure
(RegionInfo region) FlushRegionProcedure
(RegionInfo region, List<byte[]> columnFamilies) RegionCloseOperation
(RemoteProcedureDispatcher.RemoteProcedure remoteProcedure, RegionInfo regionInfo, long procId, ServerName destinationServer, boolean evictCache, long initiatingMasterActiveTime) RegionOpenOperation
(RemoteProcedureDispatcher.RemoteProcedure remoteProcedure, RegionInfo regionInfo, long procId, long initiatingMasterActiveTime) protected
RegionOperation
(RemoteProcedureDispatcher.RemoteProcedure remoteProcedure, RegionInfo regionInfo, long procId, long initiatingMasterActiveTime) SnapshotRegionProcedure
(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, RegionInfo region) SnapshotVerifyProcedure
(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, RegionInfo region) TruncateRegionProcedure
(MasterProcedureEnv env, RegionInfo region, ProcedurePrepareLatch latch) -
Uses of RegionInfo in org.apache.hadoop.hbase.master.region
Modifier and TypeMethodDescriptionprivate static RegionInfo
MasterRegion.loadRegionInfo
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path tableDir) Modifier and TypeMethodDescriptionprivate static WAL
MasterRegion.createWAL
(WALFactory walFactory, MasterRegionWALRoller walRoller, String serverName, org.apache.hadoop.fs.FileSystem walFs, org.apache.hadoop.fs.Path walRootDir, RegionInfo regionInfo) private static HRegion
MasterRegion.open
(org.apache.hadoop.conf.Configuration conf, TableDescriptor td, RegionInfo regionInfo, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.fs.FileSystem walFs, org.apache.hadoop.fs.Path walRootDir, WALFactory walFactory, MasterRegionWALRoller walRoller, String serverName) private static void
MasterRegion.replayWALs
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem walFs, org.apache.hadoop.fs.Path walRootDir, org.apache.hadoop.fs.Path walsDir, RegionInfo regionInfo, String serverName, org.apache.hadoop.fs.Path replayEditsDir) private static void
MasterRegion.tryMigrate
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path tableDir, RegionInfo regionInfo, TableDescriptor oldTd, TableDescriptor newTd) -
Uses of RegionInfo in org.apache.hadoop.hbase.master.replication
Modifier and TypeMethodDescriptionprivate void
OfflineTableReplicationQueueStorage.loadRegionInfo
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path regionDir, NavigableMap<byte[], RegionInfo> startKey2RegionInfo) -
Uses of RegionInfo in org.apache.hadoop.hbase.master.snapshot
Modifier and TypeMethodDescriptionprotected void
TakeSnapshotHandler.snapshotDisabledRegion
(RegionInfo regionInfo) Take a snapshot of the specified disabled regionprivate void
EnabledTableSnapshotHandler.snapshotMobRegion
(RegionInfo regionInfo) Takes a snapshot of the mob regionprivate void
MasterSnapshotVerifier.verifyRegionInfo
(RegionInfo region, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest manifest) Verify that the regionInfo is validModifier and TypeMethodDescriptionvoid
DisabledTableSnapshotHandler.snapshotRegions
(List<Pair<RegionInfo, ServerName>> regionsAndLocations) protected void
EnabledTableSnapshotHandler.snapshotRegions
(List<Pair<RegionInfo, ServerName>> regions) This method kicks off a snapshot procedure.protected abstract void
TakeSnapshotHandler.snapshotRegions
(List<Pair<RegionInfo, ServerName>> regions) Snapshot the specified regions -
Uses of RegionInfo in org.apache.hadoop.hbase.mob
Modifier and TypeMethodDescriptionstatic RegionInfo
MobUtils.getMobRegionInfo
(TableName tableName) Gets the RegionInfo of the mob files.Modifier and TypeMethodDescriptionstatic boolean
MobUtils.isMobRegionInfo
(RegionInfo regionInfo) Gets whether the current RegionInfo is a mob one.private void
MobFileCompactionChore.startCompaction
(Admin admin, TableName table, RegionInfo region, byte[] cf) -
Uses of RegionInfo in org.apache.hadoop.hbase.namespace
Modifier and TypeMethodDescriptionvoid
NamespaceAuditor.checkQuotaToSplitRegion
(RegionInfo hri) void
NamespaceAuditor.removeRegionFromNamespaceUsage
(RegionInfo hri) void
NamespaceStateManager.removeRegionFromTable
(RegionInfo hri) void
NamespaceAuditor.updateQuotaForRegionMerge
(RegionInfo mergedRegion) -
Uses of RegionInfo in org.apache.hadoop.hbase.quotas
Modifier and TypeFieldDescriptionprivate static final Map<RegionInfo,
Long> MasterQuotaManager.EMPTY_MAP
MasterQuotaManager.regionSizes
private Map<RegionInfo,
Long> NamespaceQuotaSnapshotStore.regionUsage
private Map<RegionInfo,
Long> TableQuotaSnapshotStore.regionUsage
private final ConcurrentHashMap<RegionInfo,
RegionSize> RegionSizeStoreImpl.store
Modifier and TypeMethodDescriptionNamespaceQuotaSnapshotStore.filterBySubject
(String namespace) QuotaSnapshotStore.filterBySubject
(T subject) Filters the providedregions
, returning those which match the givensubject
.TableQuotaSnapshotStore.filterBySubject
(TableName table) (package private) HashSet<RegionInfo>
RegionSizeReportingChore.getOnlineRegionInfos
(List<? extends Region> onlineRegions) NoOpRegionSizeStore.iterator()
RegionSizeStoreImpl.iterator()
MasterQuotaManager.snapshotRegionSizes()
Modifier and TypeMethodDescriptionvoid
MasterQuotaManager.addRegionSize
(RegionInfo hri, long size, long time) NoOpRegionSizeStore.getRegionSize
(RegionInfo regionInfo) RegionSizeStore.getRegionSize
(RegionInfo regionInfo) Returns the size for the give region if one exists.RegionSizeStoreImpl.getRegionSize
(RegionInfo regionInfo) void
NoOpRegionSizeStore.incrementRegionSize
(RegionInfo regionInfo, long delta) void
RegionSizeStore.incrementRegionSize
(RegionInfo regionInfo, long delta) Atomically alter the size of a region.void
RegionSizeStoreImpl.incrementRegionSize
(RegionInfo regionInfo, long delta) void
MasterQuotaManager.onRegionMerged
(RegionInfo mergedRegion) void
MasterQuotaManager.onRegionSplit
(RegionInfo hri) void
MasterQuotaManager.onRegionSplitReverted
(RegionInfo hri) void
NoOpRegionSizeStore.put
(RegionInfo regionInfo, long size) void
RegionSizeStore.put
(RegionInfo regionInfo, long size) Atomically sets the givensize
for a region.void
RegionSizeStoreImpl.put
(RegionInfo regionInfo, long size) NoOpRegionSizeStore.remove
(RegionInfo regionInfo) RegionSizeStore.remove
(RegionInfo regionInfo) Removes the mapping for the given key, returning the value if one exists in the store.RegionSizeStoreImpl.remove
(RegionInfo regionInfo) Modifier and TypeMethodDescription(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
QuotaSnapshotStore.setRegionUsage
(Map<RegionInfo, Long> regionUsage) Updatesthis
with the latest snapshot of filesystem use by region.void
TableQuotaSnapshotStore.setRegionUsage
(Map<RegionInfo, Long> regionUsage) ModifierConstructorDescriptionNamespaceQuotaSnapshotStore
(Connection conn, QuotaObserverChore chore, Map<RegionInfo, Long> regionUsage) TableQuotaSnapshotStore
(Connection conn, QuotaObserverChore chore, Map<RegionInfo, Long> regionUsage) -
Uses of RegionInfo in org.apache.hadoop.hbase.regionserver
Modifier and TypeFieldDescriptionprivate final RegionInfo[]
RegionServerServices.RegionStateTransitionContext.hris
private final RegionInfo
SplitRequest.parent
private RegionInfo
SnapshotVerifyCallable.region
private RegionInfo
FlushRegionCallable.regionInfo
private final RegionInfo
HRegionFileSystem.regionInfo
private RegionInfo
SnapshotRegionCallable.regionInfo
(package private) final RegionInfo
HRegionFileSystem.regionInfoForFs
Modifier and TypeMethodDescriptionRegionServerServices.RegionStateTransitionContext.getHris()
HRegion.getRegionInfo()
HRegionFileSystem.getRegionInfo()
Returns theRegionInfo
that describe this on-disk region viewHStore.getRegionInfo()
Region.getRegionInfo()
Returns region information for this regionRegionCoprocessorHost.RegionEnvironment.getRegionInfo()
RegionScanner.getRegionInfo()
Returns The RegionInfo for this scanner.RegionScannerImpl.getRegionInfo()
RegionServicesForStores.getRegionInfo()
Store.getRegionInfo()
Returns the parent region info hosting this storeStoreConfigInformation.getRegionInfo()
StoreContext.getRegionInfo()
HRegionFileSystem.getRegionInfoForFS()
static RegionInfo
HRegionFileSystem.loadRegionInfoFileContent
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path regionDir) Create aRegionInfo
from the serialized version on-disk.Modifier and TypeMethodDescription(package private) void
HRegionFileSystem.cleanupDaughterRegion
(RegionInfo regionInfo) Remove daughter regionvoid
HRegionFileSystem.cleanupMergedRegion
(RegionInfo mergedRegion) Remove merged regionprivate 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, List<org.apache.hadoop.fs.Path> allRegionFiles, MasterProcedureEnv env) Commit a daughter region, moving it from the split 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 demandstatic 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 ofRegionInfo
andlong
into aRegionServerStatusProtos.RegionSpaceUse
protobuf message.static HRegionFileSystem
HRegionFileSystem.create
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path tableDir, RegionInfo regionInfo) static HRegion
HRegion.createHRegion
(org.apache.hadoop.conf.Configuration conf, RegionInfo regionInfo, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path tableDir, TableDescriptor tableDesc) Create a region under the given table directory.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 HRegion
HRegion.createHRegion
(RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, TableDescriptor hTableDescriptor, WAL wal, boolean initialize, RegionServerServices rsRpcServices) 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) Creates region split daughter directories under the table dir.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) Returns Content of the file we write out to the filesystem under a regionorg.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) static org.apache.hadoop.fs.Path
HRegionFileSystem.getStoreHomedir
(org.apache.hadoop.fs.Path tabledir, RegionInfo hri, byte[] family) HRegionServer.getWAL
(RegionInfo regionInfo) RegionServerServices.getWAL
(RegionInfo regionInfo) Returns the WAL for a particular region.org.apache.hadoop.fs.Path
HRegionFileSystem.mergeStoreFile
(RegionInfo mergingRegion, String familyName, HStoreFile f, StoreFileTracker tracker) 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 theHConstants.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, 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.openHRegionFromTableDir
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path tableDir, RegionInfo info, TableDescriptor htd, WAL wal, 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.preReplayWALs
(RegionInfo info, org.apache.hadoop.fs.Path edits) static boolean
HRegion.rowIsInRange
(RegionInfo info, byte[] row) Determines if the specified row is within the row range specified by the specified RegionInfostatic 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, StoreFileTracker tracker) 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.void
RSSnapshotVerifier.verifyRegion
(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, RegionInfo region) static HRegion
HRegion.warmupHRegion
(RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf, RegionServerServices rsServices, CancelableProgressable reporter) Modifier and TypeMethodDescriptionHRegionServer.regionLock
(List<RegionInfo> regionInfo, String description, Abortable abort) RegionServerServices.regionLock
(List<RegionInfo> regionInfos, String description, Abortable abort) Master based locks on namespaces/tables/regions.ModifierConstructorDescriptionHRegion
(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.(package private)
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(package private)
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 masterSystemTime, long initiatingMasterActiveTime, RegionInfo... hris) RegionStateTransitionContext
(org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode code, long openSeqNum, long procId, long masterSystemTime, RegionInfo hri, long initiatingMasterActiveTime) -
Uses of RegionInfo in org.apache.hadoop.hbase.regionserver.handler
Modifier and TypeFieldDescriptionprivate final RegionInfo
AssignRegionHandler.regionInfo
private final RegionInfo
CloseRegionHandler.regionInfo
private final RegionInfo
OpenRegionHandler.regionInfo
Deprecated.Modifier and TypeMethodDescriptionCloseRegionHandler.getRegionInfo()
OpenRegionHandler.getRegionInfo()
Deprecated.Modifier and TypeMethodDescriptionstatic AssignRegionHandler
AssignRegionHandler.create
(HRegionServer server, RegionInfo regionInfo, long openProcId, TableDescriptor tableDesc, long masterSystemTime, long initiatingMasterActiveTime) private static boolean
OpenRegionHandler.isRegionStillOpening
(RegionInfo regionInfo, RegionServerServices rsServices) Deprecated.ModifierConstructorDescriptionAssignRegionHandler
(HRegionServer server, RegionInfo regionInfo, long openProcId, TableDescriptor tableDesc, long masterSystemTime, long initiatingMasterActiveTime, EventType eventType) CloseMetaHandler
(Server server, RegionServerServices rsServices, RegionInfo regionInfo, boolean abort) protected
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.protected
OpenRegionHandler
(Server server, RegionServerServices rsServices, RegionInfo regionInfo, TableDescriptor htd, long masterSystemTime, EventType eventType) Deprecated. -
Uses of RegionInfo in org.apache.hadoop.hbase.regionserver.regionreplication
ModifierConstructorDescriptionRegionReplicationSink
(org.apache.hadoop.conf.Configuration conf, RegionInfo primary, TableDescriptor td, RegionReplicationBufferManager manager, Runnable flushRequester, AsyncClusterConnection conn) -
Uses of RegionInfo in org.apache.hadoop.hbase.regionserver.wal
Modifier and TypeMethodDescriptionprotected long
AbstractFSWAL.append
(RegionInfo hri, 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) static WALKeyImpl
WALUtil.createWALKey
(RegionInfo hri, MultiVersionConcurrencyControl mvcc, NavigableMap<byte[], Integer> replicationScope, Map<String, byte[]> extendedAttributes) private static WALKeyImpl
WALUtil.doFullMarkerAppendTransaction
(WAL wal, NavigableMap<byte[], Integer> replicationScope, RegionInfo hri, WALEdit edit, MultiVersionConcurrencyControl mvcc, Map<String, byte[]> extendedAttributes, boolean sync, RegionReplicationSink sink) 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 final 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, RegionReplicationSink sink) 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, RegionReplicationSink sink) 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, RegionReplicationSink sink) Write a flush marker indicating a start / abort or a complete of a region flushprivate static WALKeyImpl
WALUtil.writeMarker
(WAL wal, NavigableMap<byte[], Integer> replicationScope, RegionInfo hri, WALEdit edit, MultiVersionConcurrencyControl mvcc, Map<String, byte[]> extendedAttributes, RegionReplicationSink sink) static WALKeyImpl
WALUtil.writeRegionEventMarker
(WAL wal, NavigableMap<byte[], Integer> replicationScope, RegionInfo hri, org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.RegionEventDescriptor r, MultiVersionConcurrencyControl mvcc, RegionReplicationSink sink) Write a region open marker indicating that the region is opened.static void
WALUtil.writeReplicationMarkerAndSync
(WAL wal, MultiVersionConcurrencyControl mvcc, RegionInfo regionInfo, byte[] rowKey, long timestamp) ModifierConstructorDescription(package private)
FSWALEntry
(long txid, WALKeyImpl key, WALEdit edit, RegionInfo regionInfo, boolean inMemstore, ServerCall<?> rpcCall) -
Uses of RegionInfo in org.apache.hadoop.hbase.replication
Modifier and TypeMethodDescriptionstatic Put
ReplicationBarrierFamilyFormat.makePutForReplicationBarrier
(RegionInfo regionInfo, long openSeqNum, long ts) Modifier and TypeMethodDescriptionstatic void
ReplicationBarrierFamilyFormat.addReplicationParent
(Put put, List<RegionInfo> parents) static byte[]
ReplicationBarrierFamilyFormat.getParentsBytes
(List<RegionInfo> parents) -
Uses of RegionInfo in org.apache.hadoop.hbase.replication.regionserver
Modifier and TypeMethodDescriptionvoid
ReplicationSourceWALActionListener.visitLogEntryBeforeWrite
(RegionInfo info, WALKey logKey, WALEdit logEdit) -
Uses of RegionInfo in org.apache.hadoop.hbase.rsgroup
Modifier and TypeMethodDescriptionprivate Pair<Map<TableName,
Map<ServerName, List<RegionInfo>>>, List<RegionPlan>> RSGroupBasedLoadBalancer.correctAssignments
(Map<TableName, Map<ServerName, List<RegionInfo>>> existingAssignments) private List<Pair<List<RegionInfo>,
List<ServerName>>> RSGroupBasedLoadBalancer.generateGroupAssignments
(List<RegionInfo> regions, List<ServerName> servers) private List<RegionInfo>
RSGroupInfoManagerImpl.getRegions
(Address server) Returns List of Regions associated with thisserver
.(package private) Map<TableName,
Map<ServerName, List<RegionInfo>>> RSGroupInfoManagerImpl.getRSGroupAssignmentsByTable
(TableStateManager tableStateManager, String groupName) This is an EXPENSIVE clone.RSGroupBasedLoadBalancer.retainAssignment
(Map<RegionInfo, ServerName> regions, List<ServerName> servers) RSGroupBasedLoadBalancer.roundRobinAssignment
(List<RegionInfo> regions, List<ServerName> servers) Modifier and TypeMethodDescriptionprivate void
RSGroupInfoManagerImpl.addRegion
(LinkedList<RegionInfo> regions, RegionInfo hri) RSGroupBasedLoadBalancer.randomAssignment
(RegionInfo region, List<ServerName> servers) void
RSGroupBasedLoadBalancer.regionOffline
(RegionInfo regionInfo) void
RSGroupBasedLoadBalancer.regionOnline
(RegionInfo regionInfo, ServerName sn) Modifier and TypeMethodDescriptionprivate void
RSGroupInfoManagerImpl.addRegion
(LinkedList<RegionInfo> regions, RegionInfo hri) RSGroupBasedLoadBalancer.balanceCluster
(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) Balance by RSGroup.private Pair<Map<TableName,
Map<ServerName, List<RegionInfo>>>, List<RegionPlan>> RSGroupBasedLoadBalancer.correctAssignments
(Map<TableName, Map<ServerName, List<RegionInfo>>> existingAssignments) private List<Pair<List<RegionInfo>,
List<ServerName>>> RSGroupBasedLoadBalancer.generateGroupAssignments
(List<RegionInfo> regions, List<ServerName> servers) private <T> void
RSGroupInfoManagerImpl.moveRegionsBetweenGroups
(Set<T> regionsOwners, Set<Address> newRegionsOwners, String targetGroupName, String sourceGroupName, Function<T, List<RegionInfo>> getRegionsInfo, Function<RegionInfo, Boolean> validation) RSGroupBasedLoadBalancer.retainAssignment
(Map<RegionInfo, ServerName> regions, List<ServerName> servers) RSGroupBasedLoadBalancer.roundRobinAssignment
(List<RegionInfo> regions, List<ServerName> servers) void
RSGroupBasedLoadBalancer.updateBalancerLoadInfo
(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) private void
RSGroupInfoManagerImpl.waitForRegionMovement
(List<Pair<RegionInfo, Future<byte[]>>> regionMoveFutures, Set<String> failedRegions, String sourceGroupName, int retryCount) Wait for all the region move to complete. -
Uses of RegionInfo in org.apache.hadoop.hbase.security.access
Modifier and TypeMethodDescriptionvoid
AccessChecker.checkLockPermissions
(User user, String namespace, TableName tableName, RegionInfo[] regionInfos, String reason) void
AccessController.checkLockPermissions
(ObserverContext<?> ctx, String namespace, TableName tableName, RegionInfo[] regionInfos, String reason) void
NoopAccessChecker.checkLockPermissions
(User user, String namespace, TableName tableName, RegionInfo[] regionInfos, String reason) void
AccessController.postCompletedCreateTableAction
(ObserverContext<MasterCoprocessorEnvironment> c, TableDescriptor desc, RegionInfo[] regions) void
SnapshotScannerHDFSAclController.postCompletedCreateTableAction
(ObserverContext<MasterCoprocessorEnvironment> c, TableDescriptor desc, RegionInfo[] regions) void
AccessController.preAssign
(ObserverContext<MasterCoprocessorEnvironment> c, RegionInfo regionInfo) void
AccessController.preCreateTable
(ObserverContext<MasterCoprocessorEnvironment> c, TableDescriptor desc, RegionInfo[] regions) Observer implementationsvoid
CoprocessorWhitelistMasterObserver.preCreateTable
(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor htd, RegionInfo[] regions) void
AccessController.preMergeRegions
(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo[] regionsToMerge) void
AccessController.preMove
(ObserverContext<MasterCoprocessorEnvironment> c, RegionInfo region, ServerName srcServer, ServerName destServer) void
AccessController.preRegionOffline
(ObserverContext<MasterCoprocessorEnvironment> c, RegionInfo regionInfo) void
AccessController.preRequestLock
(ObserverContext<MasterCoprocessorEnvironment> ctx, String namespace, TableName tableName, RegionInfo[] regionInfos, String description) void
AccessController.preUnassign
(ObserverContext<MasterCoprocessorEnvironment> c, RegionInfo regionInfo) -
Uses of RegionInfo in org.apache.hadoop.hbase.snapshot
Modifier and TypeFieldDescriptionprivate List<RegionInfo>
RestoreSnapshotHelper.RestoreMetaChanges.regionsToAdd
private List<RegionInfo>
RestoreSnapshotHelper.RestoreMetaChanges.regionsToRemove
private List<RegionInfo>
RestoreSnapshotHelper.RestoreMetaChanges.regionsToRestore
Modifier and TypeMethodDescriptionprivate RegionInfo[]
RestoreSnapshotHelper.cloneHdfsRegions
(ThreadPoolExecutor exec, Map<String, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest> regionManifests, List<RegionInfo> regions) Clone specified regions.RestoreSnapshotHelper.cloneRegionInfo
(RegionInfo snapshotRegionInfo) Create a newRegionInfo
from the snapshot region info.static RegionInfo
RestoreSnapshotHelper.cloneRegionInfo
(TableName tableName, RegionInfo snapshotRegionInfo) Modifier and TypeMethodDescriptionRestoreSnapshotHelper.RestoreMetaChanges.getRegionsToAdd()
Returns the list of new regions added during the on-disk restore.RestoreSnapshotHelper.RestoreMetaChanges.getRegionsToRemove()
Returns the list of regions removed during the on-disk restore.RestoreSnapshotHelper.RestoreMetaChanges.getRegionsToRestore()
Returns the list of 'restored regions' during the on-disk restore.private List<RegionInfo>
RestoreSnapshotHelper.getTableRegions()
Returns the set of the regions contained in the tableModifier and TypeMethodDescriptionvoid
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, TableDescriptor htd) 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
(RegionInfo newRegionInfo, 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.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.RestoreSnapshotHelper.cloneRegionInfo
(RegionInfo snapshotRegionInfo) Create a newRegionInfo
from the snapshot region info.static RegionInfo
RestoreSnapshotHelper.cloneRegionInfo
(TableName tableName, RegionInfo snapshotRegionInfo) private List<StoreFileInfo>
SnapshotManifest.getStoreFiles
(org.apache.hadoop.fs.Path storePath, TableDescriptor htd, ColumnFamilyDescriptor hcd, RegionInfo regionInfo) SnapshotManifest.RegionVisitor.regionOpen
(RegionInfo regionInfo) SnapshotManifestV1.ManifestBuilder.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 String
RestoreSnapshotHelper.restoreReferenceFile
(org.apache.hadoop.fs.Path familyDir, RegionInfo regionInfo, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile storeFile, StoreFileTracker tracker) Create a newReference
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 String
RestoreSnapshotHelper.restoreStoreFile
(org.apache.hadoop.fs.Path familyDir, RegionInfo regionInfo, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile storeFile, boolean createBackRef, StoreFileTracker tracker) Create a newHFileLink
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) 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 fileModifier and TypeMethodDescriptionprivate 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) -
Uses of RegionInfo in org.apache.hadoop.hbase.testing
Modifier and TypeMethodDescriptionTestingHBaseCluster.getRegion
(RegionInfo regionInfo) Get the server sideRegion
interface for the specific region.TestingHBaseClusterImpl.getRegion
(RegionInfo regionInfo) -
Uses of RegionInfo in org.apache.hadoop.hbase.thrift2.client
Modifier and TypeMethodDescriptionThriftAdmin.getRegions
(ServerName serverName) ThriftAdmin.getRegions
(TableName tableName) -
Uses of RegionInfo in org.apache.hadoop.hbase.tool
Modifier and TypeFieldDescriptionprivate RegionInfo
CanaryTool.RegionServerTask.region
private RegionInfo
CanaryTool.RegionTask.region
private RegionInfo
CanaryTool.RegionTaskResult.region
Modifier and TypeMethodDescriptionprivate 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 TypeMethodDescriptionprivate void
CanaryTool.RegionStdOutSink.incFailuresCountDetails
(ServerName serverName, RegionInfo region) void
CanaryTool.RegionStdOutSink.publishReadFailure
(ServerName serverName, RegionInfo region, Exception e) void
CanaryTool.RegionStdOutSink.publishReadFailure
(ServerName serverName, RegionInfo region, ColumnFamilyDescriptor column, Exception e) void
CanaryTool.RegionStdOutSink.publishReadTiming
(ServerName serverName, RegionInfo region, ColumnFamilyDescriptor column, long msTime) void
CanaryTool.RegionStdOutSink.publishWriteFailure
(ServerName serverName, RegionInfo region, Exception e) void
CanaryTool.RegionStdOutSink.publishWriteFailure
(ServerName serverName, RegionInfo region, ColumnFamilyDescriptor column, Exception e) void
CanaryTool.RegionStdOutSink.publishWriteTiming
(ServerName serverName, RegionInfo region, ColumnFamilyDescriptor column, long msTime) Modifier and TypeMethodDescriptionprivate 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) ModifierConstructorDescription(package private)
RegionServerTask
(Connection connection, String serverName, RegionInfo region, CanaryTool.RegionServerStdOutSink sink, Boolean rawScanEnabled, AtomicLong successes) (package private)
RegionTask
(Connection connection, RegionInfo region, ServerName serverName, CanaryTool.RegionStdOutSink sink, CanaryTool.RegionTask.TaskType taskType, boolean rawScanEnabled, LongAdder rwLatency, boolean readAllCF) RegionTaskResult
(RegionInfo region, TableName tableName, ServerName serverName, ColumnFamilyDescriptor column) -
Uses of RegionInfo in org.apache.hadoop.hbase.util
Modifier and TypeFieldDescription(package private) RegionInfo
HbckRegionInfo.HdfsEntry.hri
(package private) RegionInfo
HbckRegionInfo.MetaEntry.hri
private RegionInfo
HbckRegionInfo.primaryHRIForDeployedReplica
private final RegionInfo
MoveWithAck.region
private final RegionInfo
MoveWithoutAck.region
private RegionInfo
HbckRegionInfo.OnlineEntry.regionInfo
(package private) RegionInfo
HbckRegionInfo.MetaEntry.splitA
(package private) RegionInfo
HbckRegionInfo.MetaEntry.splitB
Modifier and TypeFieldDescriptionprivate final List<RegionInfo>
MoveWithAck.movedRegions
private final List<RegionInfo>
MoveWithoutAck.movedRegions
private org.apache.hbase.thirdparty.com.google.common.collect.ImmutableList<RegionInfo>
HbckTableInfo.regionsFromMeta
Modifier and TypeMethodDescriptionstatic 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) HbckRegionInfo.getHdfsHRI()
HbckRegionInfo.getPrimaryHRIForDeployedReplica()
HbckRegionInfo.MetaEntry.getRegionInfo()
HbckRegionInfo.OnlineEntry.getRegionInfo()
static RegionInfo
ServerRegionReplicaUtil.getRegionInfoForFs
(RegionInfo regionInfo) Returns the regionInfo object to use for interacting with the file system.Modifier and TypeMethodDescriptionstatic 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.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.private List<RegionInfo>
HBaseFsck.WorkItemRegion.filterRegions
(List<RegionInfo> regions) private Optional<RegionInfo>
RegionMover.getMetaRegionInfoIfToBeMoved
(List<RegionInfo> regionsToMove) 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 TypeMethodDescriptionvoid
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
(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.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 boolean
FSUtils.deleteRegionDir
(org.apache.hadoop.conf.Configuration conf, RegionInfo hri) Delete the region directory if exists.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 columnsstatic 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.(package private) static ServerName
MoveWithAck.getServerNameForRegion
(RegionInfo region, Admin admin, Connection conn) 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 directorystatic org.apache.hadoop.fs.Path
HFileArchiveUtil.getStoreArchivePathForArchivePath
(org.apache.hadoop.fs.Path archivePath, RegionInfo region, byte[] family) 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, StoreFileTracker tracker) Returns a StoreFileInfo from the given FileStatus.private boolean
MoveWithAck.isSameServer
(RegionInfo region, ServerName serverName) Returns true if passed region is still on serverName when we look at hbase:meta.private void
MoveWithAck.isSuccessfulScan
(RegionInfo region) Tries to scan a row from passed regionstatic void
HBaseFsckRepair.removeParentInMeta
(org.apache.hadoop.conf.Configuration conf, RegionInfo hri) static void
HBaseFsckRepair.waitUntilAssigned
(Admin admin, RegionInfo region) Modifier and TypeMethodDescriptionstatic 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 Optional<RegionInfo>
RegionMover.getMetaRegionInfoIfToBeMoved
(List<RegionInfo> regionsToMove) private void
RegionMover.loadRegions
(List<RegionInfo> regionsToMove) 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 linesModifierConstructorDescriptionMetaEntry
(RegionInfo rinfo, ServerName regionServer, long modTime) MetaEntry
(RegionInfo rinfo, ServerName regionServer, long modTime, RegionInfo splitA, RegionInfo splitB) (package private)
MoveWithAck
(Connection conn, RegionInfo regionInfo, ServerName sourceServer, ServerName targetServer, List<RegionInfo> movedRegions) (package private)
MoveWithoutAck
(Admin admin, RegionInfo regionInfo, ServerName sourceServer, ServerName targetServer, List<RegionInfo> movedRegions) (package private)
OnlineEntry
(RegionInfo regionInfo, ServerName serverName) ModifierConstructorDescription(package private)
MoveWithAck
(Connection conn, RegionInfo regionInfo, ServerName sourceServer, ServerName targetServer, List<RegionInfo> movedRegions) (package private)
MoveWithoutAck
(Admin admin, RegionInfo regionInfo, ServerName sourceServer, ServerName targetServer, List<RegionInfo> movedRegions) -
Uses of RegionInfo in org.apache.hadoop.hbase.util.compaction
Modifier and TypeMethodDescription(package private) RegionInfo
MajorCompactionRequest.getRegion()
Modifier and TypeMethodDescriptionprivate Map<ServerName,
List<RegionInfo>> MajorCompactor.getServerRegionsMap()
Modifier and TypeMethodDescriptionprotected Optional<MajorCompactionRequest>
MajorCompactor.getMajorCompactionRequest
(RegionInfo hri) protected Optional<MajorCompactionRequest>
MajorCompactorTTL.getMajorCompactionRequest
(RegionInfo hri) (package private) static Optional<MajorCompactionRequest>
MajorCompactionRequest.newRequest
(Connection connection, RegionInfo info, Set<String> stores, long timestamp) (package private) static Optional<MajorCompactionRequest>
MajorCompactionTTLRequest.newRequest
(Connection connection, RegionInfo info, TableDescriptor htd) ModifierConstructorDescription(package private)
MajorCompactionRequest
(Connection connection, RegionInfo region) (package private)
MajorCompactionRequest
(Connection connection, RegionInfo region, Set<String> stores) (package private)
MajorCompactionTTLRequest
(Connection connection, RegionInfo region) -
Uses of RegionInfo in org.apache.hadoop.hbase.wal
Modifier and TypeMethodDescriptionprivate 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 WALEditstatic WALEdit
WALEdit.createCompaction
(RegionInfo hri, org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.CompactionDescriptor c) Returns A Marker WALEdit that hasc
serialized as its valuestatic 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) protected WAL
AbstractFSWALProvider.createRemoteWAL
(RegionInfo region, org.apache.hadoop.fs.FileSystem remoteFs, org.apache.hadoop.fs.Path remoteWALDir, String prefix, String suffix) protected abstract WAL
AbstractWALProvider.createRemoteWAL
(RegionInfo region, org.apache.hadoop.fs.FileSystem remoteFs, org.apache.hadoop.fs.Path remoteWALDir, String prefix, String suffix) protected WAL
AsyncFSWALProvider.createRemoteWAL
(RegionInfo region, org.apache.hadoop.fs.FileSystem remoteFs, org.apache.hadoop.fs.Path remoteWALDir, String prefix, String suffix) protected WAL
FSHLogProvider.createRemoteWAL
(RegionInfo region, org.apache.hadoop.fs.FileSystem remoteFs, org.apache.hadoop.fs.Path remoteWALDir, String prefix, String suffix) protected WAL
RegionGroupingProvider.createRemoteWAL
(RegionInfo region, org.apache.hadoop.fs.FileSystem remoteFs, org.apache.hadoop.fs.Path remoteWALDir, String prefix, String suffix) static long
WALSplitUtil.getMaxRegionSequenceId
(org.apache.hadoop.conf.Configuration conf, RegionInfo region, IOExceptionSupplier<org.apache.hadoop.fs.FileSystem> rootFsSupplier, IOExceptionSupplier<org.apache.hadoop.fs.FileSystem> walFsSupplier) Deprecated.Only for compatibility, will be removed in 4.0.0.private WAL
AbstractWALProvider.getRemoteWAL
(RegionInfo region, String peerId, String remoteWALDir) static byte[]
WALEdit.getRowForRegion
(RegionInfo hri) final WAL
AbstractWALProvider.getWAL
(RegionInfo region) DisabledWALProvider.getWAL
(RegionInfo region) WALFactory.getWAL
(RegionInfo region) WALProvider.getWAL
(RegionInfo region) protected T
AbstractFSWALProvider.getWAL0
(RegionInfo region) protected abstract WAL
AbstractWALProvider.getWAL0
(RegionInfo region) protected WAL
RegionGroupingProvider.getWAL0
(RegionInfo region) private WALProvider
RegionGroupingProvider.getWALProvider
(RegionInfo region) static boolean
WALSplitUtil.hasRecoveredEdits
(org.apache.hadoop.conf.Configuration conf, RegionInfo regionInfo) Check whether there is recovered.edits in the region dir
MetaTableAccessor.getRegionLocation(Connection, byte[])
instead