Uses of Interface
org.apache.hadoop.hbase.client.RegionInfo
Packages that use 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.
The Region Normalizer subsystem is responsible for coaxing all the regions in a table toward
a "normal" size, according to their storefile size.
-
Uses of RegionInfo in org.apache.hadoop.hbase
Classes in org.apache.hadoop.hbase that implement RegionInfoModifier and TypeClassDescriptionclassDeprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.Fields in org.apache.hadoop.hbase declared as RegionInfoMethods in org.apache.hadoop.hbase that return RegionInfoModifier and TypeMethodDescriptionprivate static RegionInfoMetaTableAccessor.getClosestRegionInfo(Connection connection, TableName tableName, byte[] row) Returns Get closest metatable region row to passedrowHRegionLocation.getRegion()Returns regionInfostatic RegionInfoMetaTableAccessor.getRegionInfo(Result data) Returns RegionInfo object from the column HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog table Result.static RegionInfoMetaTableAccessor.getRegionInfo(Result r, byte[] qualifier) Returns the RegionInfo object from the columnHConstants.CATALOG_FAMILYandqualifierof the catalog table result.static RegionInfoMetaTableAccessor.parseRegionInfoFromRegionName(byte[] regionName) Returns an HRI parsed from this regionName.Methods in org.apache.hadoop.hbase that return types with arguments of type RegionInfoModifier and TypeMethodDescriptionstatic List<RegionInfo>MetaTableAccessor.getAllRegions(Connection connection, boolean excludeOfflinedSplitParents) Lists all of the regions currently in META.static PairOfSameType<RegionInfo>MetaTableAccessor.getDaughterRegions(Result data) Returns the daughter regions by reading the corresponding columns of the catalog table Result.private static Optional<RegionInfo>AsyncMetaTableAccessor.getHRegionInfo(Result r, byte[] qualifier) Returns the RegionInfo object from the columnHConstants.CATALOG_FAMILYandqualifierof the catalog table result.private static List<RegionInfo>MetaTableAccessor.getListOfRegionInfos(List<Pair<RegionInfo, ServerName>> pairs) static List<RegionInfo>MetaTableAccessor.getMergeRegions(Cell[] cells) Returns Deserialized regioninfo values taken from column values that match the regex 'info:merge.*' in array ofcells.static List<RegionInfo>MetaTableAccessor.getMergeRegions(Connection connection, RegionInfo regionInfo) Returns Return all regioninfos listed in the 'info:merge*' columns of theregionInforow.static Map<String,RegionInfo> MetaTableAccessor.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.static NavigableMap<RegionInfo,Result> MetaTableAccessor.getServerUserRegions(Connection connection, ServerName serverName) Get the user regions a given server is hosting.static List<RegionInfo>MetaTableAccessor.getTableRegions(Connection connection, TableName tableName) Gets all of the regions of the specified table.static List<RegionInfo>MetaTableAccessor.getTableRegions(Connection connection, TableName tableName, boolean excludeOfflinedSplitParents) Gets all of the regions of the specified table.private static CompletableFuture<List<Pair<RegionInfo,ServerName>>> AsyncMetaTableAccessor.getTableRegionsAndLocations(AsyncTable<AdvancedScanResultConsumer> metaTable, TableName tableName, boolean excludeOfflinedSplitParents) Used to get table regions' info and server.static List<Pair<RegionInfo,ServerName>> MetaTableAccessor.getTableRegionsAndLocations(Connection connection, TableName tableName) Do not use this method to get meta table regions, use methods in MetaTableLocator instead.static List<Pair<RegionInfo,ServerName>> MetaTableAccessor.getTableRegionsAndLocations(Connection connection, TableName tableName, boolean excludeOfflinedSplitParents) Do not use this method to get meta table regions, use methods in MetaTableLocator instead.Methods in org.apache.hadoop.hbase with parameters of type RegionInfoModifier and TypeMethodDescriptionprivate static PutMetaTableAccessor.addDaughtersToPut(Put put, RegionInfo splitA, RegionInfo splitB) Adds split daughters to the Putstatic PutMetaTableAccessor.addRegionInfo(Put p, RegionInfo hri) static voidMetaTableAccessor.addRegionToMeta(Connection connection, RegionInfo regionInfo) Adds a (single) hbase:meta row for the specified new region and its daughters.static voidMetaTableAccessor.addSplitsToParent(Connection connection, RegionInfo regionInfo, RegionInfo splitA, RegionInfo splitB) Adds daughter region infos to hbase:meta row for the specified region.static voidMetaTableAccessor.deleteMergeQualifiers(Connection connection, RegionInfo mergeRegion) Deletes merge qualifiers for the specified merge region.static voidMetaTableAccessor.deleteRegionInfo(Connection connection, RegionInfo regionInfo) Deletes the specified region from META.static ResultMetaTableAccessor.getCatalogFamilyRow(Connection connection, RegionInfo ri) Returns Return theHConstants.CATALOG_FAMILYrow from hbase:meta.static List<RegionInfo>MetaTableAccessor.getMergeRegions(Connection connection, RegionInfo regionInfo) Returns Return all regioninfos listed in the 'info:merge*' columns of theregionInforow.static byte[]MetaTableAccessor.getMetaKeyForRegion(RegionInfo regionInfo) Returns the row key to use for this regionInfoprivate static HRegionLocationAsyncMetaTableAccessor.getRegionLocation(Result r, RegionInfo regionInfo, int replicaId) Returns the HRegionLocation parsed from the given meta row Result for the given regionInfo and replicaId.static HRegionLocationMetaTableAccessor.getRegionLocation(Connection connection, RegionInfo regionInfo) Returns the HRegionLocation from meta for the given regionprivate static HRegionLocationMetaTableAccessor.getRegionLocation(Result r, RegionInfo regionInfo, int replicaId) Returns the HRegionLocation parsed from the given meta row Result for the given regionInfo and replicaId.static ResultMetaTableAccessor.getRegionResult(Connection connection, RegionInfo regionInfo) Gets the result in hbase:meta for the specified region.static booleanMetaTableAccessor.hasMergeRegions(Connection conn, RegionInfo regionInfo) Check whether the givenregionInfohas any 'info:merge*' columns.static DeleteMetaTableAccessor.makeDeleteFromRegionInfo(RegionInfo regionInfo, long ts) Generates and returns a Delete containing the region info for the catalog tablestatic PutMetaTableAccessor.makePutForReplicationBarrier(RegionInfo regionInfo, long openSeqNum, long ts) static PutMetaTableAccessor.makePutFromRegionInfo(RegionInfo regionInfo) Generates and returns aPutcontaining theRegionInfofor the catalog table.static PutMetaTableAccessor.makePutFromRegionInfo(RegionInfo regionInfo, long ts) Generates and returns aPutcontaining theRegionInfofor the catalog table.static voidMetaTableAccessor.mergeRegions(Connection connection, RegionInfo mergedRegion, Map<RegionInfo, Long> parentSeqNum, ServerName sn, int regionReplication) Merge regions into one in an atomic operation.voidRegionStateListener.onRegionMerged(RegionInfo mergedRegion) Process region merge event.voidRegionStateListener.onRegionSplit(RegionInfo hri) Process region split event.voidRegionStateListener.onRegionSplitReverted(RegionInfo hri) Process region split reverted event.static voidMetaTableAccessor.splitRegion(Connection connection, RegionInfo parent, long parentOpenSeqNum, RegionInfo splitA, RegionInfo splitB, ServerName sn, int regionReplication) Splits the region into two in an atomic operation.private static voidMetaTableAccessor.updateLocation(Connection connection, RegionInfo regionInfo, ServerName sn, long openSeqNum, long masterSystemTime) Updates the location of the specified region to be the specified server.static voidMetaTableAccessor.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 voidMetaTableAccessor.updateRegionState(Connection connection, RegionInfo ri, RegionState.State state) Update state column in hbase:meta.Method parameters in org.apache.hadoop.hbase with type arguments of type RegionInfoModifier and TypeMethodDescription(package private) static PutMetaTableAccessor.addMergeRegions(Put put, Collection<RegionInfo> mergeRegions) static voidMetaTableAccessor.addRegionsToMeta(Connection connection, List<RegionInfo> regionInfos, int regionReplication) Adds a hbase:meta row for each of the specified new regions.private static voidMetaTableAccessor.addRegionsToMeta(Connection connection, List<RegionInfo> regionInfos, int regionReplication, long ts) Adds a hbase:meta row for each of the specified new regions.private static voidMetaTableAccessor.addReplicationParent(Put put, List<RegionInfo> parents) static voidMetaTableAccessor.deleteRegionInfos(Connection connection, List<RegionInfo> regionsInfo) Deletes the specified regions from META.private static voidMetaTableAccessor.deleteRegionInfos(Connection connection, List<RegionInfo> regionsInfo, long ts) Deletes the specified regions from META.private static List<RegionInfo>MetaTableAccessor.getListOfRegionInfos(List<Pair<RegionInfo, ServerName>> pairs) static byte[]MetaTableAccessor.getParentsBytes(List<RegionInfo> parents) static voidMetaTableAccessor.mergeRegions(Connection connection, RegionInfo mergedRegion, Map<RegionInfo, Long> parentSeqNum, ServerName sn, int regionReplication) Merge regions into one in an atomic operation.static voidMetaTableAccessor.overwriteRegions(Connection connection, List<RegionInfo> regionInfos, int regionReplication) Overwrites the specified regions from hbase:meta.Constructors in org.apache.hadoop.hbase with parameters of type RegionInfoModifierConstructorDescriptionHRegionInfo(RegionInfo other) Deprecated.Construct a copy of another HRegionInfoHRegionLocation(RegionInfo regionInfo, ServerName serverName) HRegionLocation(RegionInfo regionInfo, ServerName serverName, long seqNum) -
Uses of RegionInfo in org.apache.hadoop.hbase.backup
Methods in org.apache.hadoop.hbase.backup with parameters of type RegionInfoModifier and TypeMethodDescriptionprivate static voidHFileArchiver.archive(org.apache.hadoop.fs.FileSystem fs, RegionInfo regionInfo, byte[] family, Collection<HStoreFile> compactedFiles, org.apache.hadoop.fs.Path storeArchiveDir) static voidHFileArchiver.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 voidHFileArchiver.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 voidHFileArchiver.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 voidHFileArchiver.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 voidHFileArchiver.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 voidHFileArchiver.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 booleanHFileArchiver.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
Methods in org.apache.hadoop.hbase.backup.util with parameters of type RegionInfoModifier and TypeMethodDescriptionstatic voidBackupUtils.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
Classes in org.apache.hadoop.hbase.client that implement RegionInfoModifier and TypeClassDescriptionclassDeprecated.(package private) classAn implementation of RegionInfo that adds mutable methods so can build a RegionInfo instance.(package private) classDeprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.Fields in org.apache.hadoop.hbase.client declared as RegionInfoModifier and TypeFieldDescriptionstatic final RegionInfoRegionInfoBuilder.FIRST_META_REGIONINFORegionInfo for first meta region You cannot use this builder to make an instance of theRegionInfoBuilder.FIRST_META_REGIONINFO.private final RegionInfoRegionCoprocessorRpcChannelImpl.region(package private) final RegionInfoHTableMultiplexer.PutStatus.regionInfostatic final RegionInfoRegionInfoBuilder.UNDEFINEDFields in org.apache.hadoop.hbase.client with type parameters of type RegionInfoModifier and TypeFieldDescriptionstatic final Comparator<RegionInfo>RegionInfo.COMPARATORprivate ArrayList<RegionInfo>TableSnapshotScanner.regionsMethods in org.apache.hadoop.hbase.client that return RegionInfoModifier and TypeMethodDescriptionRegionInfoBuilder.build()static RegionInfoRegionInfo.createMobRegionInfo(TableName tableName) Creates a RegionInfo object for MOB data.static RegionInfoRegionReplicaUtil.getRegionInfoForDefaultReplica(RegionInfo regionInfo) Returns the RegionInfo for the default replicaId (0).static RegionInfoRegionReplicaUtil.getRegionInfoForReplica(RegionInfo regionInfo, int replicaId) Returns the RegionInfo for the given replicaId.static RegionInfoRegionInfo.parseFrom(byte[] bytes) Returns A deserializedRegionInfostatic RegionInfoRegionInfo.parseFrom(byte[] bytes, int offset, int len) Parse a serialized representation ofRegionInfostatic RegionInfoRegionInfo.parseFrom(DataInputStream in) Parses an RegionInfo instance from the passed in stream.static RegionInfoRegionInfo.parseFromOrNull(byte[] bytes) Returns A deserializedRegionInfoor null if we failed deserialize or passed bytes nullstatic RegionInfoRegionInfo.parseFromOrNull(byte[] bytes, int offset, int len) Returns A deserializedRegionInfoor null if we failed deserialize or passed bytes nullMethods in org.apache.hadoop.hbase.client that return types with arguments of type RegionInfoModifier 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)(package private) Pair<RegionInfo,ServerName> HBaseAdmin.getRegion(byte[] regionName) private CompletableFuture<RegionInfo>RawAsyncHBaseAdmin.getRegionInfo(byte[] regionNameOrEncodedRegionName) Get the region info for the passed region name.Admin.getRegions(ServerName serverName) Get all the online regions on a region server.Admin.getRegions(TableName tableName) Get the regions of a given table.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) HBaseAdmin.getRegions(ServerName sn) HBaseAdmin.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.Methods in org.apache.hadoop.hbase.client with parameters of type RegionInfoModifier and TypeMethodDescriptionstatic booleanRegionInfo.areAdjacent(RegionInfo regionA, RegionInfo regionB) Check whether two regions are adjacent; i.e.voidMetaCache.clearCache(RegionInfo hri) Deletes the cached location of the region if necessary, based on some error from source.
Synchronized because of calls in cacheLocation which need to be executed atomicallyprivate voidHBaseAdmin.compact(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface admin, RegionInfo hri, boolean major, byte[] family) private CompletableFuture<Void>RawAsyncHBaseAdmin.compact(ServerName sn, RegionInfo hri, boolean major, byte[] columnFamily) Compact the region at specific region server.private static intRegionReplicaUtil.compareRegionInfosWithoutReplicaId(RegionInfo regionInfoA, RegionInfo regionInfoB) default intRegionInfo.compareTo(RegionInfo other) private <S,R> CompletableFuture<R> RawAsyncTableImpl.coprocessorService(Function<com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, RegionInfo region, byte[] row) private voidHBaseAdmin.flush(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface admin, RegionInfo info, byte[] columnFamily) private CompletableFuture<Void>RawAsyncHBaseAdmin.flush(ServerName serverName, RegionInfo regionInfo, byte[] columnFamily) static byte[]RegionInfoDisplay.getEndKeyForDisplay(RegionInfo ri, org.apache.hadoop.conf.Configuration conf) Get the end key for display.static RegionInfoRegionReplicaUtil.getRegionInfoForDefaultReplica(RegionInfo regionInfo) Returns the RegionInfo for the default replicaId (0).static RegionInfoRegionReplicaUtil.getRegionInfoForReplica(RegionInfo regionInfo, int replicaId) Returns the RegionInfo for the given replicaId.static StringRegionInfo.getRegionNameAsString(RegionInfo ri, byte[] regionName) static StringRegionInfoDisplay.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 StringRegionInfo.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.private MasterCallable<org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.TruncateRegionResponse>HBaseAdmin.getTruncateRegionCallable(TableName tableName, RegionInfo hri) default booleanRegionInfo.isAdjacent(RegionInfo other) Returns True if region is adjacent, either just before or just after this one.static booleanRegionReplicaUtil.isDefaultReplica(RegionInfo hri) Returns true if this region is a default replica for the regiondefault booleanRegionInfo.isNext(RegionInfo after) Returns True if region is next, adjacent but 'after' this one.default booleanRegionInfo.isOverlap(RegionInfo other) Returns True if an overlap in region range.static booleanRegionReplicaUtil.isReplicasForSameRegion(RegionInfo regionInfoA, RegionInfo regionInfoB) private booleanTableSnapshotScanner.isValidRegion(RegionInfo hri) private booleanRawAsyncTableImpl.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 RegionInfoBuilderRegionInfoBuilder.newBuilder(RegionInfo regionInfo) (package private) static booleanConnectionUtils.noMoreResultsForReverseScan(Scan scan, RegionInfo info) (package private) static booleanConnectionUtils.noMoreResultsForScan(Scan scan, RegionInfo info) voidAsyncTable.CoprocessorCallback.onRegionComplete(RegionInfo region, R resp) Indicate that the respose of a region is availablevoidAsyncTable.CoprocessorCallback.onRegionError(RegionInfo region, Throwable error) Indicate that the error for a region is availableprivate CompletableFuture<Void>RawAsyncHBaseAdmin.split(RegionInfo hri, byte[] splitPoint) HBaseAdmin.splitRegionAsync(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) (package private) voidConnectionImplementation.updateCachedLocation(RegionInfo hri, ServerName source, ServerName serverName, long seqNum) Method parameters in org.apache.hadoop.hbase.client with type arguments of type RegionInfoModifier 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 CacheEvictionStatsHBaseAdmin.clearBlockCache(ServerName sn, List<RegionInfo> hris) private CompletableFuture<CacheEvictionStats>RawAsyncHBaseAdmin.clearBlockCache(ServerName serverName, List<RegionInfo> hris) static StringRegionInfo.getShortNameToLog(List<RegionInfo> ris) Returns a String of short, printable names forhris(usually encoded name) for us logging.static voidRegionReplicaUtil.removeNonDefaultRegions(Collection<RegionInfo> regions) Removes the non-default replicas from the passed regions collectionConstructors in org.apache.hadoop.hbase.client with parameters of type RegionInfoModifierConstructorDescriptionClientSideRegionScanner(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path rootDir, TableDescriptor htd, RegionInfo hri, Scan scan, ScanMetrics scanMetrics) FlushRegionCallable(ClusterConnection connection, RpcControllerFactory rpcControllerFactory, RegionInfo regionInfo, boolean writeFlushWalMarker) ImmutableHRegionInfo(RegionInfo other) Deprecated.PutStatus(RegionInfo regionInfo, Put put, int maxAttempCount) (package private)RegionCoprocessorRpcChannelImpl(AsyncConnectionImpl conn, TableName tableName, RegionInfo region, byte[] row, long rpcTimeoutNs, long operationTimeoutNs) privateRegionInfoBuilder(RegionInfo regionInfo) -
Uses of RegionInfo in org.apache.hadoop.hbase.client.locking
Method parameters in org.apache.hadoop.hbase.client.locking with type arguments of type RegionInfoModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.LockServiceProtos.LockRequestLockServiceClient.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
Methods in org.apache.hadoop.hbase.coprocessor that return RegionInfoModifier and TypeMethodDescriptionRegionCoprocessorEnvironment.getRegionInfo()Returns region information for the region this coprocessor is running onMethods in org.apache.hadoop.hbase.coprocessor with parameters of type RegionInfoModifier and TypeMethodDescriptiondefault voidMasterObserver.postAssign(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo regionInfo) Called after the region assignment has been requested.default voidMasterObserver.postCompletedCreateTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) Called after the createTable operation has been requested.default voidMasterObserver.postCompletedMergeRegionsAction(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo[] regionsToMerge, RegionInfo mergedRegion) called after the regions merge.default voidMasterObserver.postCompletedSplitRegionAction(ObserverContext<MasterCoprocessorEnvironment> c, RegionInfo regionInfoA, RegionInfo regionInfoB) Called after the region is split.default voidMasterObserver.postCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) Called after the createTable operation has been requested.default voidMasterObserver.postMergeRegions(ObserverContext<MasterCoprocessorEnvironment> c, RegionInfo[] regionsToMerge) called after merge regions request.default voidMasterObserver.postMergeRegionsCommitAction(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo[] regionsToMerge, RegionInfo mergedRegion) This will be called after META step as part of regions merge transaction.default voidMasterObserver.postMove(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo region, ServerName srcServer, ServerName destServer) Called after the region move has been requested.default voidMasterObserver.postRegionOffline(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo regionInfo) Called after the region has been marked offline.default voidRegionObserver.postReplayWALs(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, RegionInfo info, org.apache.hadoop.fs.Path edits) Called after replaying WALs for this region.default voidMasterObserver.postRequestLock(ObserverContext<MasterCoprocessorEnvironment> ctx, String namespace, TableName tableName, RegionInfo[] regionInfos, String description) Called after new LockProcedure is queued.default voidMasterObserver.postRollBackMergeRegionsAction(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo[] regionsToMerge) This will be called after the roll back of the regions merge.default voidMasterObserver.postTruncateRegion(ObserverContext<MasterCoprocessorEnvironment> c, RegionInfo regionInfo) Called after the truncate region procedure is called.default voidMasterObserver.postTruncateRegionAction(ObserverContext<MasterCoprocessorEnvironment> c, RegionInfo regionInfo) Called post the region is truncated.default voidMasterObserver.postUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo regionInfo) Called after the region unassignment has been requested.default voidMasterObserver.postUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo regionInfo, boolean force) Deprecated.in 2.4.0.default voidRegionObserver.postWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, RegionInfo info, WALKey logKey, WALEdit logEdit) Called after aWALEditreplayed for this region.default voidWALObserver.postWALWrite(ObserverContext<? extends WALCoprocessorEnvironment> ctx, RegionInfo info, WALKey logKey, WALEdit logEdit) Deprecated.Since hbase-2.0.0.default voidMasterObserver.preAssign(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo regionInfo) Called prior to assigning a specific region.default voidMasterObserver.preCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) Called before a new table is created byHMaster.default voidMasterObserver.preCreateTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) Called before a new table is created byHMaster.default voidMasterObserver.preMergeRegions(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo[] regionsToMerge) Called before merge regions request.default voidMasterObserver.preMergeRegionsAction(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo[] regionsToMerge) Called before the regions merge.default voidMasterObserver.preMergeRegionsCommitAction(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo[] regionsToMerge, List<Mutation> metaEntries) This will be called before update META step as part of regions merge transaction.default voidMasterObserver.preMove(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo region, ServerName srcServer, ServerName destServer) Called prior to moving a given region from one region server to another.default voidMasterObserver.preRegionOffline(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo regionInfo) Called prior to marking a given region as offline.default voidRegionObserver.preReplayWALs(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, RegionInfo info, org.apache.hadoop.fs.Path edits) Called before replaying WALs for this region.default voidMasterObserver.preRequestLock(ObserverContext<MasterCoprocessorEnvironment> ctx, String namespace, TableName tableName, RegionInfo[] regionInfos, String description) Called before new LockProcedure is queued.default voidMasterObserver.preTruncateRegion(ObserverContext<MasterCoprocessorEnvironment> c, RegionInfo regionInfo) Called before the truncate region procedure is called.default voidMasterObserver.preTruncateRegionAction(ObserverContext<MasterCoprocessorEnvironment> c, RegionInfo regionInfo) Called before the region is truncated.default voidMasterObserver.preUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo regionInfo) Called prior to unassigning a given region.default voidMasterObserver.preUnassign(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo regionInfo, boolean force) Deprecated.in 2.4.0.default voidRegionObserver.preWALRestore(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, RegionInfo info, WALKey logKey, WALEdit logEdit) Called before aWALEditreplayed for this region.default voidWALObserver.preWALWrite(ObserverContext<? extends WALCoprocessorEnvironment> ctx, RegionInfo info, WALKey logKey, WALEdit logEdit) Deprecated.Since hbase-2.0.0. -
Uses of RegionInfo in org.apache.hadoop.hbase.coprocessor.example
Methods in org.apache.hadoop.hbase.coprocessor.example with parameters of type RegionInfoModifier and TypeMethodDescriptionvoidExampleMasterObserverWithMetrics.postCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) voidExampleMasterObserverWithMetrics.preCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) -
Uses of RegionInfo in org.apache.hadoop.hbase.favored
Fields in org.apache.hadoop.hbase.favored with type parameters of type RegionInfoModifier and TypeFieldDescriptionprivate final Map<ServerName,List<RegionInfo>> FavoredNodesManager.primaryRSToRegionMapprivate final Map<ServerName,List<RegionInfo>> FavoredNodesManager.secondaryRSToRegionMapprivate final Map<ServerName,List<RegionInfo>> FavoredNodesManager.teritiaryRSToRegionMapMethods in org.apache.hadoop.hbase.favored that return types with arguments of type RegionInfoModifier 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) Methods in org.apache.hadoop.hbase.favored with parameters of type RegionInfoModifier and TypeMethodDescriptionprivate voidFavoredNodeLoadBalancer.addRegionToMap(Map<ServerName, List<RegionInfo>> assignmentMapForFavoredNodes, RegionInfo region, ServerName host) private voidFavoredNodesManager.addToReplicaLoad(RegionInfo hri, List<ServerName> servers) private voidFavoredNodeLoadBalancer.assignRegionToAvailableFavoredNode(Map<ServerName, List<RegionInfo>> assignmentMapForFavoredNodes, RegionInfo region, ServerName primaryHost, ServerName secondaryHost, ServerName tertiaryHost) voidFavoredNodesManager.deleteFavoredNodesForRegion(RegionInfo regionInfo) FavoredNodeAssignmentHelper.generateFavoredNodes(RegionInfo hri) voidFavoredNodeLoadBalancer.generateFavoredNodesForDaughter(List<ServerName> servers, RegionInfo parent, RegionInfo regionA, RegionInfo regionB) voidFavoredNodesPromoter.generateFavoredNodesForDaughter(List<ServerName> servers, RegionInfo parent, RegionInfo hriA, RegionInfo hriB) voidFavoredNodeLoadBalancer.generateFavoredNodesForMergedRegion(RegionInfo merged, RegionInfo[] mergeParents) voidFavoredNodesPromoter.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 planFavoredNodesManager.getFavoredNodesWithDNPort(RegionInfo regionInfo) FavoredNodeAssignmentHelper.getSecondaryAndTertiary(RegionInfo regionInfo, ServerName primaryRS) static booleanFavoredNodesManager.isFavoredNodeApplicable(RegionInfo regionInfo) private static PutFavoredNodeAssignmentHelper.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) voidFavoredNodesPlan.updateFavoredNodesMap(RegionInfo region, List<ServerName> servers) Update an assignment to the planMethod parameters in org.apache.hadoop.hbase.favored with type arguments of type RegionInfoModifier and TypeMethodDescriptionprivate voidFavoredNodeLoadBalancer.addRegionToMap(Map<ServerName, List<RegionInfo>> assignmentMapForFavoredNodes, RegionInfo region, ServerName host) private voidFavoredNodeLoadBalancer.assignRegionToAvailableFavoredNode(Map<ServerName, List<RegionInfo>> assignmentMapForFavoredNodes, RegionInfo region, ServerName primaryHost, ServerName secondaryHost, ServerName tertiaryHost) private voidFavoredNodeLoadBalancer.assignSecondaryAndTertiaryNodesForRegion(FavoredNodeAssignmentHelper assignmentHelper, List<RegionInfo> regions, Map<RegionInfo, ServerName> primaryRSMap) private voidFavoredNodeLoadBalancer.assignSecondaryAndTertiaryNodesForRegion(FavoredNodeAssignmentHelper assignmentHelper, List<RegionInfo> regions, Map<RegionInfo, ServerName> primaryRSMap) protected List<RegionPlan>FavoredNodeLoadBalancer.balanceTable(TableName tableName, Map<ServerName, List<RegionInfo>> loadOfOneTable) voidFavoredNodesManager.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) voidFavoredNodeAssignmentHelper.placePrimaryRSAsRoundRobin(Map<ServerName, List<RegionInfo>> assignmentMap, Map<RegionInfo, ServerName> primaryRSMap, List<RegionInfo> regions) voidFavoredNodeAssignmentHelper.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 voidFavoredNodeLoadBalancer.roundRobinAssignmentImpl(FavoredNodeAssignmentHelper assignmentHelper, Map<ServerName, List<RegionInfo>> assignmentMap, List<RegionInfo> regions, List<ServerName> servers) private voidFavoredNodeLoadBalancer.roundRobinAssignmentImpl(FavoredNodeAssignmentHelper assignmentHelper, Map<ServerName, List<RegionInfo>> assignmentMap, List<RegionInfo> regions, List<ServerName> servers) private Pair<Map<ServerName,List<RegionInfo>>, List<RegionInfo>> FavoredNodeLoadBalancer.segregateRegionsAndAssignRegionsWithFavoredNodes(List<RegionInfo> regions, List<ServerName> availableServers) voidFavoredNodesManager.updateFavoredNodes(Map<RegionInfo, List<ServerName>> regionFNMap) static voidFavoredNodeAssignmentHelper.updateMetaWithFavoredNodesInfo(Map<RegionInfo, List<ServerName>> regionToFavoredNodes, org.apache.hadoop.conf.Configuration conf) Update meta table with favored nodes infostatic voidFavoredNodeAssignmentHelper.updateMetaWithFavoredNodesInfo(Map<RegionInfo, List<ServerName>> regionToFavoredNodes, Connection connection) Update meta table with favored nodes info -
Uses of RegionInfo in org.apache.hadoop.hbase.io
Methods in org.apache.hadoop.hbase.io with parameters of type RegionInfoModifier and TypeMethodDescriptionstatic StringHFileLink.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 StringHFileLink.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 StringHFileLink.createHFileLinkName(RegionInfo hfileRegionInfo, String hfileName) Create a new HFileLink name -
Uses of RegionInfo in org.apache.hadoop.hbase.ipc
Fields in org.apache.hadoop.hbase.ipc declared as RegionInfoModifier and TypeFieldDescriptionprivate RegionInfoHBaseRpcControllerImpl.regionInfoRpc target Region's RegionInfo we are going against.Methods in org.apache.hadoop.hbase.ipc that return RegionInfoModifier and TypeMethodDescriptiondefault RegionInfoHBaseRpcController.getRegionInfo()Returns Target Region's RegionInfo or null if not available or pertinent.HBaseRpcControllerImpl.getRegionInfo()Methods in org.apache.hadoop.hbase.ipc with parameters of type RegionInfoModifier and TypeMethodDescriptionprivate static StringIPCUtil.getCallTarget(Address addr, RegionInfo regionInfo) RpcControllerFactory.newController(RegionInfo regionInfo, List<CellScannable> cellIterables) RpcControllerFactory.newController(RegionInfo regionInfo, CellScanner cellScanner) (package private) static IOExceptionIPCUtil.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.Constructors in org.apache.hadoop.hbase.ipc with parameters of type RegionInfoModifierConstructorDescription(package private)HBaseRpcControllerImpl(RegionInfo regionInfo, List<CellScannable> cellIterables) (package private)HBaseRpcControllerImpl(RegionInfo regionInfo, CellScanner cellScanner) -
Uses of RegionInfo in org.apache.hadoop.hbase.mapreduce
Methods in org.apache.hadoop.hbase.mapreduce that return RegionInfo -
Uses of RegionInfo in org.apache.hadoop.hbase.master
Fields in org.apache.hadoop.hbase.master declared as RegionInfoModifier and TypeFieldDescriptionprivate final RegionInfoRegionPlan.hriprivate final RegionInfoRegionState.hriFields in org.apache.hadoop.hbase.master with type parameters of type RegionInfoModifier and TypeFieldDescriptionprivate final Map<ServerName,List<RegionInfo>> SnapshotOfRegionAssignmentFromMeta.currentRSToRegionMapthe regionServer to region mapprivate List<RegionInfo>AssignmentVerificationReport.nonFavoredAssignedRegionListprivate final Map<ServerName,List<RegionInfo>> SnapshotOfRegionAssignmentFromMeta.primaryRSToRegionMapprivate final Map<String,RegionInfo> SnapshotOfRegionAssignmentFromMeta.regionNameToRegionInfoMapthe region name to region info mapprivate List<RegionInfo>AssignmentVerificationReport.regionsWithoutValidFavoredNodesprivate Map<RegionInfo,ServerName> SnapshotOfRegionAssignmentFromMeta.regionToRegionServerMapthe region to region server mapprivate final Map<ServerName,List<RegionInfo>> SnapshotOfRegionAssignmentFromMeta.secondaryRSToRegionMapprivate final Map<TableName,List<RegionInfo>> SnapshotOfRegionAssignmentFromMeta.tableToRegionMapthe table name to region mapprivate final Map<ServerName,List<RegionInfo>> SnapshotOfRegionAssignmentFromMeta.teritiaryRSToRegionMapprivate List<RegionInfo>AssignmentVerificationReport.unAssignedRegionsListMethods in org.apache.hadoop.hbase.master that return RegionInfoModifier and TypeMethodDescriptionRegionState.getRegion()private RegionInfoMasterRpcServices.getRegionInfo(org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionSpecifier rs) GetRegionInfofrom Master using content ofHBaseProtos.RegionSpecifieras key.RegionPlan.getRegionInfo()Methods in org.apache.hadoop.hbase.master that return types with arguments of type RegionInfoModifier 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.Methods in org.apache.hadoop.hbase.master with parameters of type RegionInfoModifier and TypeMethodDescriptionprivate voidSnapshotOfRegionAssignmentFromMeta.addAssignment(RegionInfo regionInfo, ServerName server) private voidSnapshotOfRegionAssignmentFromMeta.addPrimaryAssignment(RegionInfo regionInfo, ServerName server) private voidSnapshotOfRegionAssignmentFromMeta.addRegion(RegionInfo regionInfo) private voidSnapshotOfRegionAssignmentFromMeta.addSecondaryAssignment(RegionInfo regionInfo, ServerName server) private voidSnapshotOfRegionAssignmentFromMeta.addTeritiaryAssignment(RegionInfo regionInfo, ServerName server) static voidServerManager.closeRegionSilentlyAndWait(ClusterConnection connection, ServerName server, RegionInfo region, long timeout) Contacts a region server and waits up to timeout ms to close the region.static RegionStateRegionState.createForTesting(RegionInfo region, RegionState.State state) voidMasterFileSystem.deleteFamilyFromFS(org.apache.hadoop.fs.Path rootDir, RegionInfo region, byte[] familyName) voidMasterFileSystem.deleteFamilyFromFS(RegionInfo region, byte[] familyName) org.apache.hadoop.fs.PathMasterFileSystem.getRegionDir(RegionInfo region) Returns the directory for a giveregion.booleanServerManager.isRegionInServerManagerStates(RegionInfo hri) private booleanHMaster.isRegionOnline(RegionInfo ri) longHMaster.mergeRegions(RegionInfo[] regionsToMerge, boolean forcible, long ng, long nonce) longMasterServices.mergeRegions(RegionInfo[] regionsToMerge, boolean forcible, long nonceGroup, long nonce) Merge regions in a table.voidMasterCoprocessorHost.postAssign(RegionInfo regionInfo) voidMasterCoprocessorHost.postCompletedCreateTableAction(TableDescriptor htd, RegionInfo[] regions, User user) voidMasterCoprocessorHost.postCompletedMergeRegionsAction(RegionInfo[] regionsToMerge, RegionInfo mergedRegion, User user) Invoked after completing merge regions operationvoidMasterCoprocessorHost.postCompletedSplitRegionAction(RegionInfo regionInfoA, RegionInfo regionInfoB, User user) Invoked just after a splitvoidMasterCoprocessorHost.postCreateTable(TableDescriptor htd, RegionInfo[] regions) voidMasterCoprocessorHost.postMergeRegions(RegionInfo[] regionsToMerge) voidMasterCoprocessorHost.postMergeRegionsCommit(RegionInfo[] regionsToMerge, RegionInfo mergedRegion, User user) Invoked after merge regions operation writes the new region to hbase:metavoidMasterCoprocessorHost.postMove(RegionInfo region, ServerName srcServer, ServerName destServer) voidMasterCoprocessorHost.postRegionOffline(RegionInfo regionInfo) voidMasterCoprocessorHost.postRequestLock(String namespace, TableName tableName, RegionInfo[] regionInfos, LockType type, String description) voidMasterCoprocessorHost.postRollBackMergeRegionsAction(RegionInfo[] regionsToMerge, User user) Invoked after rollback merge regions operationvoidMasterCoprocessorHost.postTruncateRegion(RegionInfo regionInfo) Invoked after calling the truncate region procedurevoidMasterCoprocessorHost.postTruncateRegionAction(RegionInfo region, User user) Invoked after calling the truncate region procedurevoidMasterCoprocessorHost.postUnassign(RegionInfo regionInfo) voidMasterCoprocessorHost.preAssign(RegionInfo regionInfo) voidMasterCoprocessorHost.preCreateTable(TableDescriptor htd, RegionInfo[] regions) voidMasterCoprocessorHost.preCreateTableAction(TableDescriptor htd, RegionInfo[] regions, User user) voidMasterCoprocessorHost.preMergeRegions(RegionInfo[] regionsToMerge) voidMasterCoprocessorHost.preMergeRegionsAction(RegionInfo[] regionsToMerge, User user) Invoked just before a mergevoidMasterCoprocessorHost.preMergeRegionsCommit(RegionInfo[] regionsToMerge, List<Mutation> metaEntries, User user) Invoked before merge regions operation writes the new region to hbase:metavoidMasterCoprocessorHost.preMove(RegionInfo region, ServerName srcServer, ServerName destServer) voidMasterCoprocessorHost.preRegionOffline(RegionInfo regionInfo) voidMasterCoprocessorHost.preRequestLock(String namespace, TableName tableName, RegionInfo[] regionInfos, LockType type, String description) voidMasterCoprocessorHost.preTruncateRegion(RegionInfo regionInfo) Invoked just before calling the truncate region procedurevoidMasterCoprocessorHost.preTruncateRegionAction(RegionInfo region, User user) Invoked just before calling the truncate region procedurevoidMasterCoprocessorHost.preUnassign(RegionInfo regionInfo) LoadBalancer.randomAssignment(RegionInfo regionInfo, List<ServerName> servers) Get a random region server from the listvoidLoadBalancer.regionOffline(RegionInfo regionInfo) Marks the region as offline at balancer.voidLoadBalancer.regionOnline(RegionInfo regionInfo, ServerName sn) Marks the region as online at balancer.voidServerManager.removeRegion(RegionInfo regionInfo) Called by delete table and similar to notify the ServerManager that a region was removed.voidServerManager.sendRegionWarmup(ServerName server, RegionInfo region) Sends a WARMUP RPC to the specified server to warmup the specified region.longHMaster.splitRegion(RegionInfo regionInfo, byte[] splitRow, long nonceGroup, long nonce) longMasterServices.splitRegion(RegionInfo regionInfo, byte[] splitRow, long nonceGroup, long nonce) Split a region.longHMaster.truncateRegion(RegionInfo regionInfo, long nonceGroup, long nonce) longMasterServices.truncateRegion(RegionInfo regionInfo, long nonceGroup, long nonce) Truncate regionMethod parameters in org.apache.hadoop.hbase.master with type arguments of type RegionInfoModifier and TypeMethodDescriptionLoadBalancer.balanceCluster(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) Perform the major balance operation for cluster.voidServerManager.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 voidLoadBalancer.updateBalancerLoadInfo(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) In some scenarios, Balancer needs to update internal status or information according to the current tables loadConstructors in org.apache.hadoop.hbase.master with parameters of type RegionInfoModifierConstructorDescriptionRegionPlan(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
Fields in org.apache.hadoop.hbase.master.assignment declared as RegionInfoModifier and TypeFieldDescriptionprivate RegionInfoSplitTableRegionProcedure.daughterOneRIprivate RegionInfoSplitTableRegionProcedure.daughterTwoRIprivate RegionInfoGCMergedRegionsProcedure.fatherDeprecated.private RegionInfoGCMergedRegionsProcedure.mergedChildDeprecated.private RegionInfoGCMultipleMergedRegionsProcedure.mergedChildprivate RegionInfoMergeTableRegionsProcedure.mergedRegionThe resulting merged region.private RegionInfoGCMergedRegionsProcedure.motherDeprecated.protected RegionInfoRegionRemoteProcedureBase.regionprivate final RegionInfoRegionStateNode.regionInfoprivate RegionInfoRegionTransitionProcedure.regionInfoDeprecated.private RegionInfo[]MergeTableRegionsProcedure.regionsToMergeTwo or more regions to merge, the 'merge parents'.Fields in org.apache.hadoop.hbase.master.assignment with type parameters of type RegionInfoModifier and TypeFieldDescriptionprivate static final Set<RegionInfo>AssignmentManager.META_REGION_SETprivate List<RegionInfo>GCMultipleMergedRegionsProcedure.parentsprivate final ConcurrentSkipListMap<RegionInfo,RegionStateNode> RegionStates.regionInTransitionprivate final ConcurrentSkipListMap<RegionInfo,RegionStateNode> RegionStates.regionOfflineRegions marked as offline on a read of hbase:meta.private final ConcurrentMap<RegionInfo,RegionStateNode> RegionStateNode.ritMapMethods in org.apache.hadoop.hbase.master.assignment that return RegionInfoModifier and TypeMethodDescriptionprivate static RegionInfoMergeTableRegionsProcedure.createMergedRegionInfo(RegionInfo[] regionsToMerge) Create merged region info by looking at passed inregionsToMergeto 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) RegionInfoMergeTableRegionsProcedure.getMergedRegion()Returns The merged region.private RegionInfoAssignmentManager.getMetaForRegion(RegionInfo regionInfo) AssignmentManager.getMetaRegionFromName(byte[] regionName) private RegionInfoSplitTableRegionProcedure.getParentRegion()AssignmentManager.getRegionInfo(byte[] regionName) Resolve a cachedRegionInfofrom the region name as abyte[].AssignmentManager.getRegionInfo(String encodedRegionName) Resolve a cachedRegionInfofrom the encoded region name as aString.private RegionInfoAssignmentManager.getRegionInfo(RegionStateNode rsn) RegionStateNode.getRegionInfo()RegionStates.RegionFailedOpen.getRegionInfo()RegionTransitionProcedure.getRegionInfo()Deprecated.Methods in org.apache.hadoop.hbase.master.assignment that return types with arguments of type RegionInfoModifier and TypeMethodDescriptionAssignmentManager.getAssignedRegions()RegionStates.getAssignedRegions()RegionStates.getAssignmentsForBalancer(TableStateManager tableStateManager, List<ServerName> onlineServers) This is an EXPENSIVE clone.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()Methods in org.apache.hadoop.hbase.master.assignment with parameters of type RegionInfoModifier and TypeMethodDescriptionlongAssignmentManager.assign(RegionInfo regionInfo) longAssignmentManager.assign(RegionInfo regionInfo, ServerName sn) static TransitRegionStateProcedureTransitRegionStateProcedure.assign(MasterProcedureEnv env, RegionInfo region, boolean forceNewPlan, ServerName targetServer) static TransitRegionStateProcedureTransitRegionStateProcedure.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 voidAssignmentManagerUtil.checkClosedRegion(MasterProcedureEnv env, RegionInfo regionInfo) private voidAssignmentManager.checkMetaLoaded(RegionInfo hri) Used to check if the meta loading is done.private static voidMergeTableRegionsProcedure.checkRegionsToMerge(MasterProcedureEnv env, RegionInfo[] regions, boolean force) private voidSplitTableRegionProcedure.checkSplittable(MasterProcedureEnv env, RegionInfo regionToSplit) Check whether the region is splittableprivate TransitRegionStateProcedureAssignmentManager.createAssignProcedure(RegionInfo regionInfo, ServerName sn, boolean override) Create an assign TransitRegionStateProcedure.private static RegionInfoMergeTableRegionsProcedure.createMergedRegionInfo(RegionInfo[] regionsToMerge) Create merged region info by looking at passed inregionsToMergeto 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) Create one TransitRegionStateProcedure to assign a region w/o specifying a target server.AssignmentManager.createOneUnassignProcedure(RegionInfo ri, boolean override) Create one TransitRegionStateProcedure to unassign a region.(package private) RegionStateNodeRegionStates.createRegionStateNode(RegionInfo regionInfo) AssignmentManager.createSplitProcedure(RegionInfo regionToSplit, byte[] splitKey) AssignmentManager.createTruncateRegionProcedure(RegionInfo regionToTruncate) voidRegionStates.deleteRegion(RegionInfo regionInfo) voidRegionStateStore.deleteRegion(RegionInfo regionInfo) private static longSplitTableRegionProcedure.getDaughterRegionIdTimestamp(RegionInfo hri) Calculate daughter regionid to use.RegionStates.getFailedOpen(RegionInfo regionInfo) AssignmentManager.getFavoredNodes(RegionInfo regionInfo) private ProcedureEvent<?>AssignmentManager.getMetaAssignEvent(RegionInfo metaRegionInfo) private RegionInfoAssignmentManager.getMetaForRegion(RegionInfo regionInfo) private longRegionStateStore.getOpenSeqNumForParentRegion(RegionInfo region) RegionStates.getOrCreateRegionStateNode(RegionInfo regionInfo) (package private) static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoResponseAssignmentManagerUtil.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.GetRegionInfoResponseAssignmentManagerUtil.getRegionInfoResponse(MasterProcedureEnv env, ServerName regionLocation, RegionInfo hri, boolean includeBestSplitRow) RegionStates.getRegionServerOfRegion(RegionInfo regionInfo) RegionStates.getRegionState(RegionInfo regionInfo) static RegionState.StateRegionStateStore.getRegionState(Result r, RegionInfo regionInfo) Pull the region state from a catalog tableResult.RegionStates.getRegionStateNode(RegionInfo regionInfo) RegionStates.getRegionTransitionState(RegionInfo hri) private voidAssignmentManager.handleRegionOverStuckWarningThreshold(RegionInfo regionInfo) private booleanAssignmentManager.isCarryingRegion(ServerName serverName, RegionInfo regionInfo) private booleanAssignmentManager.isMetaRegion(RegionInfo regionInfo) booleanRegionStates.isRegionInRegionStates(RegionInfo hri) booleanRegionStates.isRegionInState(RegionInfo regionInfo, RegionState.State... state) booleanRegionStates.isRegionInTransition(RegionInfo regionInfo) booleanRegionStates.isRegionOffline(RegionInfo regionInfo) Returns True if region is offline (In OFFLINE or CLOSED state).booleanRegionStates.isRegionOnline(RegionInfo regionInfo) booleanAssignmentManager.RegionInTransitionStat.isRegionOverThreshold(RegionInfo regionInfo) booleanAssignmentManager.RegionInTransitionStat.isRegionTwiceOverThreshold(RegionInfo regionInfo) voidAssignmentManager.markRegionAsMerged(RegionInfo child, ServerName serverName, RegionInfo[] mergeParents) When called here, the merge has happened.voidAssignmentManager.markRegionAsSplit(RegionInfo parent, ServerName serverName, RegionInfo daughterA, RegionInfo daughterB) voidRegionStateStore.mergeRegions(RegionInfo child, RegionInfo[] parents, ServerName serverName) private List<org.apache.hadoop.fs.Path>MergeTableRegionsProcedure.mergeStoreFiles(MasterProcedureEnv env, HRegionFileSystem regionFs, HRegionFileSystem mergeRegionFs, RegionInfo mergedRegion) private voidRegionStateStore.mirrorMetaLocation(RegionInfo regionInfo, ServerName serverName, RegionState.State state) voidAssignmentManager.move(RegionInfo regionInfo) static TransitRegionStateProcedureTransitRegionStateProcedure.move(MasterProcedureEnv env, RegionInfo region, ServerName targetServer) voidAssignmentManager.offlineRegion(RegionInfo regionInfo) voidAssignmentManager.onlineRegion(RegionInfo regionInfo, ServerName serverName) voidAssignmentManager.populateRegionStatesFromMeta(RegionInfo regionInfo) Attempt to loadregionInfofrom META, adding any results to theAssignmentManager.regionStateStoreIs NOT aware of replica regions.voidRegionStates.removeFromFailedOpen(RegionInfo regionInfo) static TransitRegionStateProcedureTransitRegionStateProcedure.reopen(MasterProcedureEnv env, RegionInfo region) private voidAssignmentManager.setMetaAssigned(RegionInfo metaRegionInfo, boolean assigned) voidRegionTransitionProcedure.setRegionInfo(RegionInfo regionInfo) Deprecated.private booleanAssignmentManager.shouldAssignFavoredNodes(RegionInfo region) voidRegionStateStore.splitRegion(RegionInfo parent, RegionInfo hriA, RegionInfo hriB, ServerName serverName) longAssignmentManager.unassign(RegionInfo regionInfo) static TransitRegionStateProcedureTransitRegionStateProcedure.unassign(MasterProcedureEnv env, RegionInfo region) static TransitRegionStateProcedureTransitRegionStateProcedure.unassignSplitMerge(MasterProcedureEnv env, RegionInfo region) private voidRegionStateStore.updateRegionLocation(RegionInfo regionInfo, RegionState.State state, Put put) private voidAssignmentManager.updateRegionMergeTransition(ServerStateNode serverNode, org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode state, RegionInfo merged, RegionInfo hriA, RegionInfo hriB) private voidAssignmentManager.updateRegionSplitTransition(ServerStateNode serverNode, org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode state, RegionInfo parent, RegionInfo hriA, RegionInfo hriB) voidRegionStates.updateRegionState(RegionInfo regionInfo, RegionState.State state) private voidAssignmentManager.updateRegionTransition(ServerStateNode serverNode, org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode state, RegionInfo regionInfo, long seqId, long procId) voidAssignmentManager.RegionMetaLoadingVisitor.visitRegionState(Result result, RegionInfo regionInfo, RegionState.State state, ServerName regionLocation, ServerName lastHost, long openSeqNum) voidRegionStateStore.RegionStateVisitor.visitRegionState(Result result, RegionInfo regionInfo, RegionState.State state, ServerName regionLocation, ServerName lastHost, long openSeqNum) booleanAssignmentManager.waitMetaAssigned(Procedure<?> proc, RegionInfo regionInfo) Notice that this event does not mean the AM has already finished region state rebuilding.Method parameters in org.apache.hadoop.hbase.master.assignment with type arguments of type RegionInfoModifier and TypeMethodDescriptionprivate voidAssignmentManager.acceptPlan(HashMap<RegionInfo, RegionStateNode> regions, Map<ServerName, List<RegionInfo>> plan) private voidAssignmentManager.acceptPlan(HashMap<RegionInfo, RegionStateNode> regions, Map<ServerName, List<RegionInfo>> plan) private voidAssignmentManager.addToPendingAssignment(HashMap<RegionInfo, RegionStateNode> regions, Collection<RegionInfo> pendingRegions) private voidAssignmentManager.addToPendingAssignment(HashMap<RegionInfo, RegionStateNode> regions, Collection<RegionInfo> pendingRegions) private booleanAssignmentManager.containsBogusAssignments(Map<RegionInfo, RegionStateNode> regions, List<RegionInfo> hirs) private booleanAssignmentManager.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 voidRegionStates.createSnapshot(RegionStateNode node, Map<ServerName, List<RegionInfo>> result) (package private) static TransitRegionStateProcedure[]AssignmentManagerUtil.createUnassignProceduresForSplitOrMerge(MasterProcedureEnv env, Stream<RegionInfo> regions, int regionReplication) voidRegionStates.deleteRegions(List<RegionInfo> regionInfos) voidRegionStateStore.deleteRegions(List<RegionInfo> regions) AssignmentManager.getSnapShotOfAssignment(Collection<RegionInfo> regions) RegionStates.getSnapShotOfAssignment(Collection<RegionInfo> regions) private voidAssignmentManager.processAssignmentPlans(HashMap<RegionInfo, RegionStateNode> regions, HashMap<RegionInfo, ServerName> retainMap, List<RegionInfo> hris, List<ServerName> servers) private voidAssignmentManager.processAssignmentPlans(HashMap<RegionInfo, RegionStateNode> regions, HashMap<RegionInfo, ServerName> retainMap, List<RegionInfo> hris, List<ServerName> servers) (package private) static voidAssignmentManagerUtil.removeNonDefaultReplicas(MasterProcedureEnv env, Stream<RegionInfo> regions, int regionReplication) (package private) static voidAssignmentManagerUtil.reopenRegionsForRollback(MasterProcedureEnv env, List<RegionInfo> regions, int regionReplication, ServerName targetServer) Constructors in org.apache.hadoop.hbase.master.assignment with parameters of type RegionInfoModifierConstructorDescriptionAssignmentProcedureEvent(RegionInfo regionInfo) CloseRegionProcedure(TransitRegionStateProcedure parent, RegionInfo region, ServerName targetServer, ServerName assignCandidate, boolean evictCache) 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) protectedRegionRemoteProcedureBase(TransitRegionStateProcedure parent, RegionInfo region, ServerName targetServer) (package private)RegionStateNode(RegionInfo regionInfo, ConcurrentMap<RegionInfo, RegionStateNode> ritMap) RegionTransitionProcedure(RegionInfo regionInfo) Deprecated.SplitTableRegionProcedure(MasterProcedureEnv env, RegionInfo regionToSplit, byte[] splitRow) protectedTransitRegionStateProcedure(MasterProcedureEnv env, RegionInfo hri, ServerName assignCandidate, boolean forceNewPlan, TransitRegionStateProcedure.TransitionType type) protectedTransitRegionStateProcedure(MasterProcedureEnv env, RegionInfo hri, ServerName assignCandidate, boolean forceNewPlan, TransitRegionStateProcedure.TransitionType type, boolean isSplit) Constructor parameters in org.apache.hadoop.hbase.master.assignment with type arguments of type RegionInfoModifierConstructorDescriptionGCMultipleMergedRegionsProcedure(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
Fields in org.apache.hadoop.hbase.master.balancer declared as RegionInfoFields in org.apache.hadoop.hbase.master.balancer with type parameters of type RegionInfoModifier and TypeFieldDescriptionprivate org.apache.hbase.thirdparty.com.google.common.cache.LoadingCache<RegionInfo,HDFSBlocksDistribution> RegionLocationFinder.cache(package private) Map<ServerName,List<RegionInfo>> BalancerClusterState.clusterStateprivate final Map<ServerName,List<RegionInfo>> ClusterLoadState.clusterStateprivate List<RegionInfo>SimpleLoadBalancer.BalanceInfo.hriListprivate org.apache.hbase.thirdparty.com.google.common.cache.CacheLoader<RegionInfo,HDFSBlocksDistribution> RegionLocationFinder.loader(package private) Map<RegionInfo,Integer> BalancerClusterState.regionsToIndexprivate final NavigableMap<ServerAndLoad,List<RegionInfo>> ClusterLoadState.serversByLoadMethods in org.apache.hadoop.hbase.master.balancer that return RegionInfoModifier and TypeMethodDescriptionprivate RegionInfoCacheAwareLoadBalancer.getRegionInfoByEncodedName(BalancerClusterState cluster, String regionName) Methods in org.apache.hadoop.hbase.master.balancer that return types with arguments of type RegionInfoModifier and TypeMethodDescriptionprivate Map<ServerName,List<RegionInfo>> MaintenanceLoadBalancer.assign(Collection<RegionInfo> regions, List<ServerName> servers) protected Map<ServerName,List<RegionInfo>> BaseLoadBalancer.assignMasterSystemRegions(Collection<RegionInfo> regions, List<ServerName> servers) Deprecated.since 2.4.0, will be removed in 3.0.0.private org.apache.hbase.thirdparty.com.google.common.cache.LoadingCache<RegionInfo,HDFSBlocksDistribution> RegionLocationFinder.createCache()Create a cache for region to list of serversprivate Map<ServerName,List<RegionInfo>> FavoredStochasticBalancer.generateFNForRegionsWithoutFN(FavoredNodeAssignmentHelper helper, List<RegionInfo> regions) (package private) org.apache.hbase.thirdparty.com.google.common.cache.LoadingCache<RegionInfo,HDFSBlocksDistribution> RegionLocationFinder.getCache()(package private) Map<ServerName,List<RegionInfo>> ClusterLoadState.getClusterState()(package private) List<RegionInfo>SimpleLoadBalancer.BalanceInfo.getHriList()private Map<ServerName,List<RegionInfo>> BaseLoadBalancer.getRegionAssignmentsByServer(Collection<RegionInfo> regions) (package private) NavigableMap<ServerAndLoad,List<RegionInfo>> ClusterLoadState.getServersByLoad()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) 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) MaintenanceLoadBalancer.roundRobinAssignment(List<RegionInfo> regions, List<ServerName> servers) private Pair<Map<ServerName,List<RegionInfo>>, List<RegionInfo>> FavoredStochasticBalancer.segregateRegionsAndAssignRegionsWithFavoredNodes(Collection<RegionInfo> regions, List<ServerName> onlineServers) private Pair<Map<ServerName,List<RegionInfo>>, List<RegionInfo>> FavoredStochasticBalancer.segregateRegionsAndAssignRegionsWithFavoredNodes(Collection<RegionInfo> regions, List<ServerName> onlineServers) protected final Map<ServerName,List<RegionInfo>> BaseLoadBalancer.toEnsumbleTableLoad(Map<TableName, Map<ServerName, List<RegionInfo>>> LoadOfAllTable) Methods in org.apache.hadoop.hbase.master.balancer with parameters of type RegionInfoModifier and TypeMethodDescriptionprivate voidFavoredStochasticBalancer.addRegionToMap(Map<ServerName, List<RegionInfo>> assignmentMapForFavoredNodes, RegionInfo region, ServerName host) private voidFavoredStochasticBalancer.assignRegionToAvailableFavoredNode(Map<ServerName, List<RegionInfo>> assignmentMapForFavoredNodes, RegionInfo region, ServerName primaryHost, ServerName secondaryHost, ServerName tertiaryHost) private org.apache.hbase.thirdparty.com.google.common.util.concurrent.ListenableFuture<HDFSBlocksDistribution>RegionLocationFinder.asyncGetBlockDistribution(RegionInfo hri) intRegionInfoComparator.compare(RegionInfo l, RegionInfo r) (package private) voidBalancerClusterState.doAssignRegion(RegionInfo regionInfo, ServerName serverName) voidFavoredStochasticBalancer.generateFavoredNodesForDaughter(List<ServerName> servers, RegionInfo parent, RegionInfo regionA, RegionInfo regionB) voidFavoredStochasticBalancer.generateFavoredNodesForMergedRegion(RegionInfo merged, RegionInfo[] mergeParents) RegionLocationFinder.getBlockDistribution(RegionInfo hri) FavoredStochasticBalancer.getFavoredNodes(RegionInfo regionInfo) protected List<ServerName>RegionLocationFinder.getTopBlockLocations(RegionInfo region) protected List<ServerName>RegionLocationFinder.getTopBlockLocations(RegionInfo region, String currentHost) Returns an ordered list of hosts which have better locality for this region than the current host.protected HDFSBlocksDistributionRegionLocationFinder.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 ServerNameBaseLoadBalancer.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) MaintenanceLoadBalancer.randomAssignment(RegionInfo regionInfo, List<ServerName> servers) voidBaseLoadBalancer.regionOffline(RegionInfo regionInfo) voidMaintenanceLoadBalancer.regionOffline(RegionInfo regionInfo) voidBaseLoadBalancer.regionOnline(RegionInfo regionInfo, ServerName sn) voidMaintenanceLoadBalancer.regionOnline(RegionInfo regionInfo, ServerName sn) private voidBalancerClusterState.registerRegion(RegionInfo region, int regionIndex, int serverIndex, Map<String, Deque<BalancerRegionLoad>> loads, RegionLocationFinder regionFinder) Helper for Cluster constructor to handle a regionbooleanBaseLoadBalancer.shouldBeOnMaster(RegionInfo region) Deprecated.since 2.4.0, will be removed in 3.0.0.private voidFavoredStochasticBalancer.updateFavoredNodesForRegion(RegionInfo regionInfo, List<ServerName> newFavoredNodes) (package private) booleanBalancerClusterState.wouldLowerAvailability(RegionInfo regionInfo, ServerName serverName) Return true if the placement of region on server would lower the availability of the region in questionMethod parameters in org.apache.hadoop.hbase.master.balancer with type arguments of type RegionInfoModifier and TypeMethodDescriptionprivate voidFavoredStochasticBalancer.addRegionToMap(Map<ServerName, List<RegionInfo>> assignmentMapForFavoredNodes, RegionInfo region, ServerName host) private Map<ServerName,List<RegionInfo>> MaintenanceLoadBalancer.assign(Collection<RegionInfo> regions, List<ServerName> servers) protected Map<ServerName,List<RegionInfo>> BaseLoadBalancer.assignMasterSystemRegions(Collection<RegionInfo> regions, List<ServerName> servers) Deprecated.since 2.4.0, will be removed in 3.0.0.private voidFavoredStochasticBalancer.assignRegionToAvailableFavoredNode(Map<ServerName, List<RegionInfo>> assignmentMapForFavoredNodes, RegionInfo region, ServerName primaryHost, ServerName secondaryHost, ServerName tertiaryHost) 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 List<RegionPlan>BaseLoadBalancer.balanceMasterRegions(Map<ServerName, List<RegionInfo>> clusterMap) Deprecated.since 2.4.0, will be removed in 3.0.0.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) 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 BalancerClusterStateBaseLoadBalancer.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) private voidFavoredStochasticBalancer.mergeAssignmentMaps(Map<ServerName, List<RegionInfo>> assignmentMap, Map<ServerName, List<RegionInfo>> otherAssignments) protected voidBaseLoadBalancer.preBalanceCluster(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) Called before actually executing balanceCluster.protected voidSimpleLoadBalancer.preBalanceCluster(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) voidRegionLocationFinder.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) 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 voidBaseLoadBalancer.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 voidBaseLoadBalancer.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) MaintenanceLoadBalancer.roundRobinAssignment(List<RegionInfo> regions, List<ServerName> servers) private Pair<Map<ServerName,List<RegionInfo>>, List<RegionInfo>> FavoredStochasticBalancer.segregateRegionsAndAssignRegionsWithFavoredNodes(Collection<RegionInfo> regions, List<ServerName> onlineServers) (package private) voidSimpleLoadBalancer.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) voidStochasticLoadBalancer.updateBalancerLoadInfo(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) private voidStochasticLoadBalancer.updateBalancerTableLoadInfo(TableName tableName, Map<ServerName, List<RegionInfo>> loadOfOneTable) Constructor parameters in org.apache.hadoop.hbase.master.balancer with type arguments of type RegionInfoModifierConstructorDescriptionBalanceInfo(int nextRegionForUnload, int numRegionsAdded, List<RegionInfo> hriList) (package private)BalancerClusterState(Collection<RegionInfo> unassignedRegions, Map<ServerName, List<RegionInfo>> clusterState, Map<String, Deque<BalancerRegionLoad>> loads, RegionLocationFinder 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, RegionLocationFinder regionFinder, RackManager rackManager, Map<String, Pair<ServerName, Float>> oldRegionServerRegionCacheRatio) (package private)BalancerClusterState(Map<ServerName, List<RegionInfo>> clusterState, Map<String, Deque<BalancerRegionLoad>> loads, RegionLocationFinder regionFinder, RackManager rackManager) protectedBalancerClusterState(Map<ServerName, List<RegionInfo>> clusterState, Map<String, Deque<BalancerRegionLoad>> loads, RegionLocationFinder 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
Fields in org.apache.hadoop.hbase.master.http declared as RegionInfoFields in org.apache.hadoop.hbase.master.http with type parameters of type RegionInfoModifier and TypeFieldDescriptionprivate final Map<String,RegionInfo> RegionReplicaInfo.mergeRegionInfoprivate final Map<String,RegionInfo> RegionReplicaInfo.splitRegionInfoMethods in org.apache.hadoop.hbase.master.http that return RegionInfoMethods in org.apache.hadoop.hbase.master.http that return types with arguments of type RegionInfoModifier and TypeMethodDescriptionRegionReplicaInfo.getMergeRegionInfo()RegionReplicaInfo.getSplitRegionInfo() -
Uses of RegionInfo in org.apache.hadoop.hbase.master.http.hbck.resource
Methods in org.apache.hadoop.hbase.master.http.hbck.resource with parameters of type RegionInfo -
Uses of RegionInfo in org.apache.hadoop.hbase.master.janitor
Fields in org.apache.hadoop.hbase.master.janitor declared as RegionInfoModifier and TypeFieldDescriptionprivate RegionInfoReportMakingVisitor.highestEndKeyRegionInfoKeep account of the highest end key seen as we move through hbase:meta.private RegionInfoReportMakingVisitor.previousRegionInfo from previous row.Fields in org.apache.hadoop.hbase.master.janitor with type parameters of type RegionInfoModifier 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.unknownServersTODO: If CatalogJanitor finds an 'Unknown Server', it should 'fix' it by queuing aHBCKServerCrashProcedurefor found server for it to clean up meta.Methods in org.apache.hadoop.hbase.master.janitor that return RegionInfoModifier and TypeMethodDescriptionprivate static RegionInfoMetaFixer.buildRegionInfo(TableName tn, byte[] start, byte[] end) (package private) static RegionInfoMetaFixer.getRegionInfoWithLargestEndKey(RegionInfo a, RegionInfo b) private RegionInfoReportMakingVisitor.metaTableConsistencyCheck(Result metaTableRow) Check row.Methods in org.apache.hadoop.hbase.master.janitor that return types with arguments of type RegionInfoModifier and TypeMethodDescription(package private) static List<SortedSet<RegionInfo>>MetaFixer.calculateMerges(int maxMergeCount, List<Pair<RegionInfo, RegionInfo>> overlaps) Run throughoverlapsand return a list of merges to run.private static List<RegionInfo>MetaFixer.createMetaEntries(MasterServices masterServices, List<RegionInfo> newRegionInfos) Create entries in thehbase:metafor each providedRegionInfo.private static List<RegionInfo>MetaFixer.createRegionInfosForHoles(List<Pair<RegionInfo, RegionInfo>> holes) Create a newRegionInfocorresponding 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()Methods in org.apache.hadoop.hbase.master.janitor with parameters of type RegionInfoModifier and TypeMethodDescriptionprivate voidReportMakingVisitor.addHole(RegionInfo a, RegionInfo b) private voidReportMakingVisitor.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 booleanCatalogJanitor.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 booleanCatalogJanitor.cleanParent(RegionInfo parent, Result rowContent) If daughters no longer hold reference to the parents, delete the parent.(package private) static booleanCatalogJanitor.cleanParent(MasterServices services, RegionInfo parent, Result rowContent) intCatalogJanitor.SplitParentFirstComparator.compare(RegionInfo left, RegionInfo right) (package private) static RegionInfoMetaFixer.getRegionInfoWithLargestEndKey(RegionInfo a, RegionInfo b) (package private) static booleanMetaFixer.isOverlap(RegionInfo ri, Pair<RegionInfo, RegionInfo> pair) (package private) booleanReportMakingVisitor.isTableDisabled(RegionInfo ri) Returns True if table is disabled or disabling; defaults false!private booleanReportMakingVisitor.isTableTransition(RegionInfo ri) Returns True iff first row in hbase:meta or if we've broached a new table in hbase:metaMethod parameters in org.apache.hadoop.hbase.master.janitor with type arguments of type RegionInfoModifier and TypeMethodDescription(package private) static List<SortedSet<RegionInfo>>MetaFixer.calculateMerges(int maxMergeCount, List<Pair<RegionInfo, RegionInfo>> overlaps) Run throughoverlapsand return a list of merges to run.(package private) static List<SortedSet<RegionInfo>>MetaFixer.calculateMerges(int maxMergeCount, List<Pair<RegionInfo, RegionInfo>> overlaps) Run throughoverlapsand return a list of merges to run.private static voidMetaFixer.calculateTableMerges(int maxMergeCount, List<SortedSet<RegionInfo>> merges, Collection<Pair<RegionInfo, RegionInfo>> overlaps) private static voidMetaFixer.calculateTableMerges(int maxMergeCount, List<SortedSet<RegionInfo>> merges, Collection<Pair<RegionInfo, RegionInfo>> overlaps) private static voidMetaFixer.calculateTableMerges(int maxMergeCount, List<SortedSet<RegionInfo>> merges, Collection<Pair<RegionInfo, RegionInfo>> overlaps) (package private) static booleanCatalogJanitor.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:metafor each providedRegionInfo.private static List<RegionInfo>MetaFixer.createRegionInfosForHoles(List<Pair<RegionInfo, RegionInfo>> holes) Create a newRegionInfocorresponding to each provided "hole" pair.private static List<RegionInfo>MetaFixer.createRegionInfosForHoles(List<Pair<RegionInfo, RegionInfo>> holes) Create a newRegionInfocorresponding 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 booleanMetaFixer.isOverlap(RegionInfo ri, Pair<RegionInfo, RegionInfo> pair) (package private) static booleanMetaFixer.isOverlap(RegionInfo ri, Pair<RegionInfo, RegionInfo> pair) -
Uses of RegionInfo in org.apache.hadoop.hbase.master.locking
Fields in org.apache.hadoop.hbase.master.locking declared as RegionInfoModifier and TypeFieldDescriptionprivate final RegionInfo[]LockManager.MasterLock.regionInfosprivate RegionInfo[]LockProcedure.regionInfosMethods in org.apache.hadoop.hbase.master.locking with parameters of type RegionInfoModifier and TypeMethodDescriptionLockManager.createMasterLock(RegionInfo[] regionInfos, String description) longLockManager.RemoteLocks.requestRegionsLock(RegionInfo[] regionInfos, String description, NonceKey nonceKey) Constructors in org.apache.hadoop.hbase.master.locking with parameters of type RegionInfoModifierConstructorDescriptionLockProcedure(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
Fields in org.apache.hadoop.hbase.master.normalizer declared as RegionInfoFields in org.apache.hadoop.hbase.master.normalizer with type parameters of type RegionInfoModifier and TypeFieldDescriptionprivate final List<RegionInfo>SimpleRegionNormalizer.NormalizeContext.tableRegionsMethods in org.apache.hadoop.hbase.master.normalizer that return RegionInfoMethods in org.apache.hadoop.hbase.master.normalizer that return types with arguments of type RegionInfoMethods in org.apache.hadoop.hbase.master.normalizer with parameters of type RegionInfoModifier and TypeMethodDescriptionMergeNormalizationPlan.Builder.addTarget(RegionInfo regionInfo, long regionSizeMb) private longSimpleRegionNormalizer.getRegionSizeMB(RegionInfo hri) Returns size of region in MB and if region is not found than -1private booleanSimpleRegionNormalizer.isLargeEnoughForMerge(SimpleRegionNormalizer.NormalizerConfiguration normalizerConfiguration, SimpleRegionNormalizer.NormalizeContext ctx, RegionInfo regionInfo) ReturntruewhenregionInfohas a size that is sufficient to be considered for a merge operation,falseotherwise.private static booleanSimpleRegionNormalizer.isOldEnoughForMerge(SimpleRegionNormalizer.NormalizerConfiguration normalizerConfiguration, SimpleRegionNormalizer.NormalizeContext ctx, RegionInfo regionInfo) ReturntruewhenregionInfohas a creation date that is old enough to be considered for a merge operation,falseotherwise.private booleanSimpleRegionNormalizer.skipForMerge(SimpleRegionNormalizer.NormalizerConfiguration normalizerConfiguration, SimpleRegionNormalizer.NormalizeContext ctx, RegionInfo regionInfo) Determine if aRegionInfoshould be considered for a merge operation.private static booleanSimpleRegionNormalizer.skipForSplit(RegionState state, RegionInfo regionInfo) Determine if a region inRegionStateshould be considered for a split operation.Method parameters in org.apache.hadoop.hbase.master.normalizer with type arguments of type RegionInfoModifier and TypeMethodDescriptionprivate doubleSimpleRegionNormalizer.getAverageRegionSizeMb(List<RegionInfo> tableRegions, TableDescriptor tableDescriptor) Also make sure tableRegions contains regions of the same tableConstructors in org.apache.hadoop.hbase.master.normalizer with parameters of type RegionInfoModifierConstructorDescription(package private)NormalizationTarget(RegionInfo regionInfo, long regionSizeMb) (package private)SplitNormalizationPlan(RegionInfo splitTarget, long splitTargetSizeMb) -
Uses of RegionInfo in org.apache.hadoop.hbase.master.procedure
Fields in org.apache.hadoop.hbase.master.procedure declared as RegionInfoModifier and TypeFieldDescriptionprivate RegionInfoAbstractStateMachineRegionProcedure.hriprivate RegionInfoFlushRegionProcedure.regionprivate RegionInfoSnapshotRegionProcedure.regionprivate RegionInfoSnapshotVerifyProcedure.regionprotected final RegionInfoRSProcedureDispatcher.RegionOperation.regionInfoFields in org.apache.hadoop.hbase.master.procedure with type parameters of type RegionInfoModifier and TypeFieldDescriptionprivate List<RegionInfo>CloneSnapshotProcedure.newRegionsprivate List<RegionInfo>CreateTableProcedure.newRegionsprivate final List<RegionInfo>HBCKServerCrashProcedure.UnknownServerVisitor.reassignsprivate List<RegionInfo>DeleteTableProcedure.regionsprivate List<RegionInfo>TruncateTableProcedure.regionsprivate List<RegionInfo>ServerCrashProcedure.regionsOnCrashedServerRegions that were on the crashed server.private List<RegionInfo>RestoreSnapshotProcedure.regionsToAddprivate List<RegionInfo>RestoreSnapshotProcedure.regionsToRemoveprivate List<RegionInfo>RestoreSnapshotProcedure.regionsToRestoreMethods in org.apache.hadoop.hbase.master.procedure that return RegionInfoModifier and TypeMethodDescription(package private) RegionInfoCreateTableProcedure.getFirstRegionInfo()(package private) RegionInfoTruncateTableProcedure.getFirstRegionInfo()AbstractStateMachineRegionProcedure.getRegion()Returns The RegionInfo of the region we are operating on.SnapshotRegionProcedure.getRegion()Methods in org.apache.hadoop.hbase.master.procedure that return types with arguments of type RegionInfoModifier 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) Methods in org.apache.hadoop.hbase.master.procedure with parameters of type RegionInfoModifier and TypeMethodDescriptionprotected static voidAbstractStateMachineTableProcedure.checkOnline(MasterProcedureEnv env, RegionInfo ri) Check region is online.protected final org.apache.hadoop.fs.PathAbstractStateMachineTableProcedure.getWALRegionDir(MasterProcedureEnv env, RegionInfo region) private booleanServerCrashProcedure.isDefaultMetaRegion(RegionInfo hri) protected voidAbstractStateMachineRegionProcedure.setRegion(RegionInfo hri) Used when deserializing.booleanMasterProcedureScheduler.waitRegion(Procedure<?> procedure, RegionInfo regionInfo) Suspend the procedure if the specified region is already locked.booleanMasterProcedureScheduler.waitRegions(Procedure<?> procedure, TableName table, RegionInfo... regionInfos) Suspend the procedure if the specified set of regions are already locked.voidMasterProcedureScheduler.wakeRegion(Procedure<?> procedure, RegionInfo regionInfo) Wake the procedures waiting for the specified regionvoidMasterProcedureScheduler.wakeRegions(Procedure<?> procedure, TableName table, RegionInfo... regionInfos) Wake the procedures waiting for the specified regionsMethod parameters in org.apache.hadoop.hbase.master.procedure with type arguments of type RegionInfoModifier and TypeMethodDescriptionprivate voidRestoreSnapshotProcedure.addRegionsToInMemoryStates(List<RegionInfo> regionInfos, MasterProcedureEnv env, int regionReplication) Add regions to in-memory statesprivate static voidCreateTableProcedure.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 voidServerCrashProcedure.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 voidMasterDDLOperationHelper.deleteColumnFamilyFromFileSystem(MasterProcedureEnv env, TableName tableName, List<RegionInfo> regionInfoList, byte[] familyName, boolean hasMob) Remove the column family from the file systemprotected static voidDeleteTableProcedure.deleteFromFs(MasterProcedureEnv env, TableName tableName, List<RegionInfo> regions, boolean archive) protected static voidDeleteTableProcedure.deleteFromMeta(MasterProcedureEnv env, TableName tableName, List<RegionInfo> regions) private voidRestoreSnapshotProcedure.deleteRegionsFromInMemoryStates(List<RegionInfo> regionInfos, MasterProcedureEnv env, int regionReplication) Delete regions from in-memory statesprivate static intEnableTableProcedure.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 voidSnapshotProcedure.snapshotSplitOrClosedRegions(MasterProcedureEnv env, List<RegionInfo> regions, String threadPoolName) protected static voidProcedureSyncWait.waitRegionInTransition(MasterProcedureEnv env, List<RegionInfo> regions) Constructors in org.apache.hadoop.hbase.master.procedure with parameters of type RegionInfoModifierConstructorDescriptionprotectedprotectedAbstractStateMachineRegionProcedure(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) RegionOpenOperation(RemoteProcedureDispatcher.RemoteProcedure remoteProcedure, RegionInfo regionInfo, long procId) protectedRegionOperation(RemoteProcedureDispatcher.RemoteProcedure remoteProcedure, RegionInfo regionInfo, long procId) 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
Methods in org.apache.hadoop.hbase.master.region that return RegionInfoModifier and TypeMethodDescriptionprivate static RegionInfoMasterRegion.loadRegionInfo(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path tableDir) Methods in org.apache.hadoop.hbase.master.region with parameters of type RegionInfoModifier and TypeMethodDescriptionprivate static WALMasterRegion.createWAL(WALFactory walFactory, MasterRegionWALRoller walRoller, String serverName, org.apache.hadoop.fs.FileSystem walFs, org.apache.hadoop.fs.Path walRootDir, RegionInfo regionInfo) private static HRegionMasterRegion.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 voidMasterRegion.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 voidMasterRegion.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.snapshot
Methods in org.apache.hadoop.hbase.master.snapshot with parameters of type RegionInfoModifier and TypeMethodDescriptionprotected voidTakeSnapshotHandler.snapshotDisabledRegion(RegionInfo regionInfo) Take a snapshot of the specified disabled regionprivate voidEnabledTableSnapshotHandler.snapshotMobRegion(RegionInfo regionInfo) Takes a snapshot of the mob regionprivate voidMasterSnapshotVerifier.verifyRegionInfo(RegionInfo region, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest manifest) Verify that the regionInfo is validMethod parameters in org.apache.hadoop.hbase.master.snapshot with type arguments of type RegionInfoModifier and TypeMethodDescriptionvoidDisabledTableSnapshotHandler.snapshotRegions(List<Pair<RegionInfo, ServerName>> regionsAndLocations) protected voidEnabledTableSnapshotHandler.snapshotRegions(List<Pair<RegionInfo, ServerName>> regions) This method kicks off a snapshot procedure.protected abstract voidTakeSnapshotHandler.snapshotRegions(List<Pair<RegionInfo, ServerName>> regions) Snapshot the specified regions -
Uses of RegionInfo in org.apache.hadoop.hbase.mob
Methods in org.apache.hadoop.hbase.mob that return RegionInfoModifier and TypeMethodDescriptionstatic RegionInfoMobUtils.getMobRegionInfo(TableName tableName) Gets the RegionInfo of the mob files.Methods in org.apache.hadoop.hbase.mob with parameters of type RegionInfoModifier and TypeMethodDescriptionstatic booleanMobUtils.isMobRegionInfo(RegionInfo regionInfo) Gets whether the current RegionInfo is a mob one.private voidMobFileCompactionChore.startCompaction(Admin admin, TableName table, RegionInfo region, byte[] cf) -
Uses of RegionInfo in org.apache.hadoop.hbase.namespace
Methods in org.apache.hadoop.hbase.namespace with parameters of type RegionInfoModifier and TypeMethodDescriptionvoidNamespaceAuditor.checkQuotaToSplitRegion(RegionInfo hri) voidNamespaceAuditor.removeRegionFromNamespaceUsage(RegionInfo hri) voidNamespaceStateManager.removeRegionFromTable(RegionInfo hri) voidNamespaceAuditor.updateQuotaForRegionMerge(RegionInfo mergedRegion) -
Uses of RegionInfo in org.apache.hadoop.hbase.quotas
Fields in org.apache.hadoop.hbase.quotas with type parameters of type RegionInfoModifier and TypeFieldDescriptionprivate static final Map<RegionInfo,Long> MasterQuotaManager.EMPTY_MAPMasterQuotaManager.regionSizesprivate Map<RegionInfo,Long> NamespaceQuotaSnapshotStore.regionUsageprivate Map<RegionInfo,Long> TableQuotaSnapshotStore.regionUsageprivate final ConcurrentHashMap<RegionInfo,RegionSize> RegionSizeStoreImpl.storeMethods in org.apache.hadoop.hbase.quotas that return types with arguments of type RegionInfoModifier 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()Methods in org.apache.hadoop.hbase.quotas with parameters of type RegionInfoModifier and TypeMethodDescriptionvoidMasterQuotaManager.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) voidNoOpRegionSizeStore.incrementRegionSize(RegionInfo regionInfo, long delta) voidRegionSizeStore.incrementRegionSize(RegionInfo regionInfo, long delta) Atomically alter the size of a region.voidRegionSizeStoreImpl.incrementRegionSize(RegionInfo regionInfo, long delta) voidMasterQuotaManager.onRegionMerged(RegionInfo mergedRegion) voidMasterQuotaManager.onRegionSplit(RegionInfo hri) voidMasterQuotaManager.onRegionSplitReverted(RegionInfo hri) voidNoOpRegionSizeStore.put(RegionInfo regionInfo, long size) voidRegionSizeStore.put(RegionInfo regionInfo, long size) Atomically sets the givensizefor a region.voidRegionSizeStoreImpl.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) Method parameters in org.apache.hadoop.hbase.quotas with type arguments of type RegionInfoModifier and TypeMethodDescription(package private) voidQuotaObserverChore.initializeSnapshotStores(Map<RegionInfo, Long> regionSizes) (package private) voidRegionSizeReportingChore.removeNonOnlineRegions(RegionSizeStore store, Set<RegionInfo> onlineRegions) voidNamespaceQuotaSnapshotStore.setRegionUsage(Map<RegionInfo, Long> regionUsage) voidQuotaSnapshotStore.setRegionUsage(Map<RegionInfo, Long> regionUsage) Updatesthiswith the latest snapshot of filesystem use by region.voidTableQuotaSnapshotStore.setRegionUsage(Map<RegionInfo, Long> regionUsage) Constructor parameters in org.apache.hadoop.hbase.quotas with type arguments of type RegionInfoModifierConstructorDescriptionNamespaceQuotaSnapshotStore(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
Fields in org.apache.hadoop.hbase.regionserver declared as RegionInfoModifier and TypeFieldDescriptionprivate final RegionInfo[]RegionServerServices.RegionStateTransitionContext.hrisprivate final RegionInfoSplitRequest.parentprivate RegionInfoSnapshotVerifyCallable.regionprivate RegionInfoFlushRegionCallable.regionInfoprivate final RegionInfoHRegionFileSystem.regionInfoprivate RegionInfoSnapshotRegionCallable.regionInfo(package private) final RegionInfoHRegionFileSystem.regionInfoForFsMethods in org.apache.hadoop.hbase.regionserver that return RegionInfoModifier and TypeMethodDescriptionRegionServerServices.RegionStateTransitionContext.getHris()HRegion.getRegionInfo()HRegionFileSystem.getRegionInfo()Returns theRegionInfothat 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 RegionInfoHRegionFileSystem.loadRegionInfoFileContent(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path regionDir) Create aRegionInfofrom the serialized version on-disk.Methods in org.apache.hadoop.hbase.regionserver with parameters of type RegionInfoModifier and TypeMethodDescription(package private) voidHRegionFileSystem.cleanupDaughterRegion(RegionInfo regionInfo) Remove daughter regionvoidHRegionFileSystem.cleanupMergedRegion(RegionInfo mergedRegion) Remove merged regionprivate voidHRegionServer.closeRegionIgnoreErrors(RegionInfo region, boolean abort) Try to close the region, logs a warning on failure but continues.org.apache.hadoop.fs.PathHRegionFileSystem.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 voidCompactionTool.CompactionWorker.compactStoreFiles(org.apache.hadoop.fs.Path tableDir, TableDescriptor htd, RegionInfo hri, String familyName, boolean compactOnce, boolean major) Execute the actual compaction job.static HDFSBlocksDistributionHRegion.computeHDFSBlocksDistribution(org.apache.hadoop.conf.Configuration conf, TableDescriptor tableDescriptor, RegionInfo regionInfo) This is a helper function to compute HDFS block distribution on demandstatic HDFSBlocksDistributionHRegion.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.RegionSpaceUseHRegionServer.convertRegionSize(RegionInfo regionInfo, Long sizeInBytes) Converts a pair ofRegionInfoandlonginto aRegionServerStatusProtos.RegionSpaceUseprotobuf message.static HRegionHRegion.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 HRegionHRegion.createHRegion(RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, TableDescriptor hTableDescriptor, WAL wal) static HRegionHRegion.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 HRegionHRegion.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 HRegionFileSystemHRegion.createRegionDir(org.apache.hadoop.conf.Configuration configuration, RegionInfo ri, org.apache.hadoop.fs.Path rootDir) Create the region directory in the filesystem.static HRegionFileSystemHRegionFileSystem.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.voidHRegionFileSystem.createSplitsDir(RegionInfo daughterA, RegionInfo daughterB) Creates region split daughter directories under the table dir.static voidHRegionFileSystem.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 voidHRegion.doSyncOfUnflushedWALChanges(WAL wal, RegionInfo hri) Sync unflushed WAL changes.(package private) org.apache.hadoop.fs.PathHRegionFileSystem.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.PathHRegionFileSystem.getSplitsDir(RegionInfo hri) private static HStoreCompactionTool.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.PathHRegionFileSystem.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.PathHRegionFileSystem.mergeStoreFile(RegionInfo mergingRegion, String familyName, HStoreFile f) Write out a merge reference under the given merges directory.static HRegionHRegion.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_IMPLconfiguration property.static HRegionHRegion.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 HRegionHRegion.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 HRegionHRegion.openHRegion(org.apache.hadoop.fs.Path rootDir, RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf) Open a Region.static HRegionHRegion.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 HRegionHRegion.openHRegion(RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf) Open a Region.static HRegionHRegion.openHRegion(RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf, RegionServerServices rsServices, CancelableProgressable reporter) Open a Region.static HRegionHRegion.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 HRegionHRegion.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 HRegionFileSystemHRegionFileSystem.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.voidRegionCoprocessorHost.postReplayWALs(RegionInfo info, org.apache.hadoop.fs.Path edits) voidRegionCoprocessorHost.postWALRestore(RegionInfo info, WALKey logKey, WALEdit logEdit) Deprecated.Since hbase-2.0.0.voidRegionCoprocessorHost.preReplayWALs(RegionInfo info, org.apache.hadoop.fs.Path edits) booleanRegionCoprocessorHost.preWALRestore(RegionInfo info, WALKey logKey, WALEdit logEdit) Deprecated.Since hbase-2.0.0.static booleanHRegion.rowIsInRange(RegionInfo info, byte[] row) Determines if the specified row is within the row range specified by the specified RegionInfostatic booleanHRegion.rowIsInRange(RegionInfo info, byte[] row, int offset, short length) org.apache.hadoop.fs.PathHRegionFileSystem.splitStoreFile(RegionInfo hri, String familyName, HStoreFile f, byte[] splitRow, boolean top, RegionSplitPolicy splitPolicy) Write out a split reference.(package private) voidHStore.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.voidRSSnapshotVerifier.verifyRegion(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot, RegionInfo region) static HRegionHRegion.warmupHRegion(RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf, RegionServerServices rsServices, CancelableProgressable reporter) Method parameters in org.apache.hadoop.hbase.regionserver with type arguments of type RegionInfoModifier and TypeMethodDescriptionHRegionServer.regionLock(List<RegionInfo> regionInfos, String description, Abortable abort) RegionServerServices.regionLock(List<RegionInfo> regionInfos, String description, Abortable abort) Master based locks on namespaces/tables/regions.Constructors in org.apache.hadoop.hbase.regionserver with parameters of type RegionInfoModifierConstructorDescriptionHRegion(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 procId, long masterSystemTime, RegionInfo hri) RegionStateTransitionContext(org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode code, long openSeqNum, long masterSystemTime, RegionInfo... hris) -
Uses of RegionInfo in org.apache.hadoop.hbase.regionserver.handler
Fields in org.apache.hadoop.hbase.regionserver.handler declared as RegionInfoModifier and TypeFieldDescriptionprivate final RegionInfoAssignRegionHandler.regionInfoprivate final RegionInfoCloseRegionHandler.regionInfoprivate final RegionInfoOpenRegionHandler.regionInfoDeprecated.Methods in org.apache.hadoop.hbase.regionserver.handler that return RegionInfoModifier and TypeMethodDescriptionCloseRegionHandler.getRegionInfo()OpenRegionHandler.getRegionInfo()Deprecated.Methods in org.apache.hadoop.hbase.regionserver.handler with parameters of type RegionInfoModifier and TypeMethodDescriptionstatic AssignRegionHandlerAssignRegionHandler.create(HRegionServer server, RegionInfo regionInfo, long openProcId, TableDescriptor tableDesc, long masterSystemTime) private static booleanOpenRegionHandler.isRegionStillOpening(RegionInfo regionInfo, RegionServerServices rsServices) Deprecated.Constructors in org.apache.hadoop.hbase.regionserver.handler with parameters of type RegionInfoModifierConstructorDescriptionAssignRegionHandler(HRegionServer server, RegionInfo regionInfo, long openProcId, TableDescriptor tableDesc, long masterSystemTime, EventType eventType) CloseMetaHandler(Server server, RegionServerServices rsServices, RegionInfo regionInfo, boolean abort) protectedCloseRegionHandler(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.protectedOpenRegionHandler(Server server, RegionServerServices rsServices, RegionInfo regionInfo, TableDescriptor htd, long masterSystemTime, EventType eventType) Deprecated. -
Uses of RegionInfo in org.apache.hadoop.hbase.regionserver.wal
Fields in org.apache.hadoop.hbase.regionserver.wal declared as RegionInfoMethods in org.apache.hadoop.hbase.regionserver.wal that return RegionInfoMethods in org.apache.hadoop.hbase.regionserver.wal with parameters of type RegionInfoModifier and TypeMethodDescriptionprotected abstract longAbstractFSWAL.append(RegionInfo info, WALKeyImpl key, WALEdit edits, boolean inMemstore) Append a set of edits to the WAL.protected longAsyncFSWAL.append(RegionInfo hri, WALKeyImpl key, WALEdit edits, boolean inMemstore) protected longFSHLog.append(RegionInfo hri, WALKeyImpl key, WALEdit edits, boolean inMemstore) longAbstractFSWAL.appendData(RegionInfo info, WALKeyImpl key, WALEdit edits) longAbstractFSWAL.appendMarker(RegionInfo info, WALKeyImpl key, WALEdit edits) private static WALKeyImplWALUtil.doFullMarkerAppendTransaction(WAL wal, NavigableMap<byte[], Integer> replicationScope, RegionInfo hri, WALEdit edit, MultiVersionConcurrencyControl mvcc, Map<String, byte[]> extendedAttributes, boolean sync) A 'full' WAL transaction involves starting an mvcc transaction followed by an append, an optional sync, and then a call to complete the mvcc transaction.voidWALCoprocessorHost.postWALWrite(RegionInfo info, WALKey logKey, WALEdit logEdit) voidWALCoprocessorHost.preWALWrite(RegionInfo info, WALKey logKey, WALEdit logEdit) protected final longAbstractFSWAL.stampSequenceIdAndPublishToRingBuffer(RegionInfo hri, WALKeyImpl key, WALEdit edits, boolean inMemstore, com.lmax.disruptor.RingBuffer<RingBufferTruck> ringBuffer) default voidWALActionsListener.visitLogEntryBeforeWrite(RegionInfo info, WALKey logKey, WALEdit logEdit) Called before each write.static WALKeyImplWALUtil.writeBulkLoadMarkerAndSync(WAL wal, NavigableMap<byte[], Integer> replicationScope, RegionInfo hri, org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.BulkLoadDescriptor desc, MultiVersionConcurrencyControl mvcc) Write a log marker that a bulk load has succeeded and is about to be committed.static WALKeyImplWALUtil.writeCompactionMarker(WAL wal, NavigableMap<byte[], Integer> replicationScope, RegionInfo hri, org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.CompactionDescriptor c, MultiVersionConcurrencyControl mvcc) Write the marker that a compaction has succeeded and is about to be committed.static WALKeyImplWALUtil.writeFlushMarker(WAL wal, NavigableMap<byte[], Integer> replicationScope, RegionInfo hri, org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptor f, boolean sync, MultiVersionConcurrencyControl mvcc) Write a flush marker indicating a start / abort or a complete of a region flushprivate static WALKeyImplWALUtil.writeMarker(WAL wal, NavigableMap<byte[], Integer> replicationScope, RegionInfo hri, WALEdit edit, MultiVersionConcurrencyControl mvcc, Map<String, byte[]> extendedAttributes) static WALKeyImplWALUtil.writeRegionEventMarker(WAL wal, NavigableMap<byte[], Integer> replicationScope, RegionInfo hri, org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.RegionEventDescriptor r, MultiVersionConcurrencyControl mvcc) Write a region open marker indicating that the region is opened.static voidWALUtil.writeReplicationMarkerAndSync(WAL wal, MultiVersionConcurrencyControl mvcc, RegionInfo regionInfo, byte[] rowKey, long timestamp) Constructors in org.apache.hadoop.hbase.regionserver.wal with parameters of type RegionInfoModifierConstructorDescription(package private)FSWALEntry(long txid, WALKeyImpl key, WALEdit edit, RegionInfo regionInfo, boolean inMemstore, ServerCall<?> rpcCall) -
Uses of RegionInfo in org.apache.hadoop.hbase.replication.regionserver
Fields in org.apache.hadoop.hbase.replication.regionserver declared as RegionInfoMethods in org.apache.hadoop.hbase.replication.regionserver with parameters of type RegionInfoModifier and TypeMethodDescriptionReplicationSourceManager.addCatalogReplicationSource(RegionInfo regionInfo) Add an hbase:meta Catalog replication source.private ReplicationSourceInterfaceReplicationSourceManager.createCatalogReplicationSource(RegionInfo regionInfo) Create, initialize, and start the Catalog ReplicationSource.voidReplicationSourceManager.removeCatalogReplicationSource(RegionInfo regionInfo) Remove the hbase:meta Catalog replication source.voidReplicationSourceWALActionListener.visitLogEntryBeforeWrite(RegionInfo info, WALKey logKey, WALEdit logEdit) Constructors in org.apache.hadoop.hbase.replication.regionserver with parameters of type RegionInfoModifierConstructorDescriptionRegionReplicaReplayCallable(ClusterConnection connection, RpcControllerFactory rpcControllerFactory, TableName tableName, HRegionLocation location, RegionInfo regionInfo, byte[] row, List<WAL.Entry> entries, AtomicLong skippedEntries) -
Uses of RegionInfo in org.apache.hadoop.hbase.rsgroup
Methods in org.apache.hadoop.hbase.rsgroup that return types with arguments of type RegionInfoModifier 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>RSGroupAdminServer.getRegions(Address server) Returns List of Regions associated with thisserver.(package private) Map<TableName,Map<ServerName, List<RegionInfo>>> RSGroupAdminServer.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) Methods in org.apache.hadoop.hbase.rsgroup with parameters of type RegionInfoModifier and TypeMethodDescriptionprivate voidRSGroupAdminServer.addRegion(LinkedList<RegionInfo> regions, RegionInfo hri) private AddressRSGroupAdminServer.getRegionAddress(RegionInfo hri) voidRSGroupAdminEndpoint.preCreateTableAction(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor desc, RegionInfo[] regions) RSGroupBasedLoadBalancer.randomAssignment(RegionInfo region, List<ServerName> servers) voidRSGroupBasedLoadBalancer.regionOffline(RegionInfo regionInfo) voidRSGroupBasedLoadBalancer.regionOnline(RegionInfo regionInfo, ServerName sn) Method parameters in org.apache.hadoop.hbase.rsgroup with type arguments of type RegionInfoModifier and TypeMethodDescriptionprivate voidRSGroupAdminServer.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) RSGroupBasedLoadBalancer.retainAssignment(Map<RegionInfo, ServerName> regions, List<ServerName> servers) RSGroupBasedLoadBalancer.roundRobinAssignment(List<RegionInfo> regions, List<ServerName> servers) voidRSGroupBasedLoadBalancer.updateBalancerLoadInfo(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) private booleanRSGroupAdminServer.waitForRegionMovement(List<Pair<RegionInfo, Future<byte[]>>> regionMoveFutures, String groupName, int retryCount) Wait for all the region move to complete. -
Uses of RegionInfo in org.apache.hadoop.hbase.security.access
Methods in org.apache.hadoop.hbase.security.access with parameters of type RegionInfoModifier and TypeMethodDescriptionvoidAccessChecker.checkLockPermissions(User user, String namespace, TableName tableName, RegionInfo[] regionInfos, String reason) voidAccessController.checkLockPermissions(ObserverContext<?> ctx, String namespace, TableName tableName, RegionInfo[] regionInfos, String reason) voidNoopAccessChecker.checkLockPermissions(User user, String namespace, TableName tableName, RegionInfo[] regionInfos, String reason) voidAccessController.postCompletedCreateTableAction(ObserverContext<MasterCoprocessorEnvironment> c, TableDescriptor desc, RegionInfo[] regions) voidSnapshotScannerHDFSAclController.postCompletedCreateTableAction(ObserverContext<MasterCoprocessorEnvironment> c, TableDescriptor desc, RegionInfo[] regions) voidAccessController.preAssign(ObserverContext<MasterCoprocessorEnvironment> c, RegionInfo regionInfo) voidAccessController.preCreateTable(ObserverContext<MasterCoprocessorEnvironment> c, TableDescriptor desc, RegionInfo[] regions) Observer implementationsvoidCoprocessorWhitelistMasterObserver.preCreateTable(ObserverContext<MasterCoprocessorEnvironment> ctx, TableDescriptor htd, RegionInfo[] regions) voidAccessController.preMergeRegions(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo[] regionsToMerge) voidAccessController.preMove(ObserverContext<MasterCoprocessorEnvironment> c, RegionInfo region, ServerName srcServer, ServerName destServer) voidAccessController.preRegionOffline(ObserverContext<MasterCoprocessorEnvironment> c, RegionInfo regionInfo) voidAccessController.preRequestLock(ObserverContext<MasterCoprocessorEnvironment> ctx, String namespace, TableName tableName, RegionInfo[] regionInfos, String description) voidAccessController.preUnassign(ObserverContext<MasterCoprocessorEnvironment> c, RegionInfo regionInfo) -
Uses of RegionInfo in org.apache.hadoop.hbase.snapshot
Fields in org.apache.hadoop.hbase.snapshot with type parameters of type RegionInfoModifier and TypeFieldDescriptionprivate List<RegionInfo>RestoreSnapshotHelper.RestoreMetaChanges.regionsToAddprivate List<RegionInfo>RestoreSnapshotHelper.RestoreMetaChanges.regionsToRemoveprivate List<RegionInfo>RestoreSnapshotHelper.RestoreMetaChanges.regionsToRestoreMethods in org.apache.hadoop.hbase.snapshot that return RegionInfoModifier 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 newRegionInfofrom the snapshot region info.static RegionInfoRestoreSnapshotHelper.cloneRegionInfo(TableName tableName, RegionInfo snapshotRegionInfo) Methods in org.apache.hadoop.hbase.snapshot that return types with arguments of type RegionInfoModifier 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 tableMethods in org.apache.hadoop.hbase.snapshot with parameters of type RegionInfoModifier and TypeMethodDescriptionvoidSnapshotManifest.addMobRegion(RegionInfo regionInfo) protected voidSnapshotManifest.addMobRegion(RegionInfo regionInfo, SnapshotManifest.RegionVisitor visitor) voidSnapshotManifest.addRegion(org.apache.hadoop.fs.Path tableDir, RegionInfo regionInfo) Creates a 'manifest' for the specified region, by reading directly from the disk.protected voidSnapshotManifest.addRegion(org.apache.hadoop.fs.Path tableDir, RegionInfo regionInfo, SnapshotManifest.RegionVisitor visitor) (package private) voidRestoreSnapshotHelper.RestoreMetaChanges.addRegionToRemove(RegionInfo hri) (package private) voidRestoreSnapshotHelper.RestoreMetaChanges.addRegionToRestore(RegionInfo hri) (package private) SnapshotInfo.SnapshotStats.FileInfoSnapshotInfo.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.SnapshotRegionManifestSnapshotManifestV1.buildManifestFromDisk(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path tableDir, RegionInfo regionInfo) private voidRestoreSnapshotHelper.cloneHdfsMobRegion(Map<String, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest> regionManifests, RegionInfo region) Clone the mob region.private voidRestoreSnapshotHelper.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 voidRestoreSnapshotHelper.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 newRegionInfofrom the snapshot region info.static RegionInfoRestoreSnapshotHelper.cloneRegionInfo(TableName tableName, RegionInfo snapshotRegionInfo) SnapshotManifest.RegionVisitor.regionOpen(RegionInfo regionInfo) SnapshotManifestV1.ManifestBuilder.regionOpen(RegionInfo regionInfo) org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.BuilderSnapshotManifestV2.ManifestBuilder.regionOpen(RegionInfo regionInfo) private voidRestoreSnapshotHelper.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 StringRestoreSnapshotHelper.restoreReferenceFile(org.apache.hadoop.fs.Path familyDir, RegionInfo regionInfo, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile storeFile) Create a newReferenceas copy of the source one.private voidRestoreSnapshotHelper.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 voidRestoreSnapshotHelper.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 StringRestoreSnapshotHelper.restoreStoreFile(org.apache.hadoop.fs.Path familyDir, RegionInfo regionInfo, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile storeFile, boolean createBackRef) Create a newHFileLinkto reference the store file.(package private) voidRestoreSnapshotHelper.RestoreMetaChanges.setNewRegions(RegionInfo[] hris) voidSnapshotReferenceUtil.StoreFileVisitor.storeFile(RegionInfo regionInfo, String familyName, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile storeFile) static voidSnapshotReferenceUtil.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 fileMethod parameters in org.apache.hadoop.hbase.snapshot with type arguments of type RegionInfoModifier 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 voidRestoreSnapshotHelper.removeHdfsRegions(ThreadPoolExecutor exec, List<RegionInfo> regions) Remove specified regions from the file-system, using the archiver.private voidRestoreSnapshotHelper.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 voidRestoreSnapshotHelper.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.voidRestoreSnapshotHelper.RestoreMetaChanges.updateMetaParentRegions(Connection connection, List<RegionInfo> regionInfos) -
Uses of RegionInfo in org.apache.hadoop.hbase.testing
Methods in org.apache.hadoop.hbase.testing with parameters of type RegionInfoModifier and TypeMethodDescriptionTestingHBaseCluster.getRegion(RegionInfo regionInfo) Get the server sideRegioninterface for the specific region.TestingHBaseClusterImpl.getRegion(RegionInfo regionInfo) -
Uses of RegionInfo in org.apache.hadoop.hbase.thrift2.client
Methods in org.apache.hadoop.hbase.thrift2.client that return types with arguments of type RegionInfoModifier and TypeMethodDescriptionThriftAdmin.getRegions(ServerName serverName) ThriftAdmin.getRegions(TableName tableName) -
Uses of RegionInfo in org.apache.hadoop.hbase.tool
Fields in org.apache.hadoop.hbase.tool declared as RegionInfoModifier and TypeFieldDescriptionprivate RegionInfoCanaryTool.RegionServerTask.regionprivate RegionInfoCanaryTool.RegionTask.regionprivate RegionInfoCanaryTool.RegionTaskResult.regionMethods in org.apache.hadoop.hbase.tool that return RegionInfoMethods in org.apache.hadoop.hbase.tool that return types with arguments of type RegionInfoModifier 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()Methods in org.apache.hadoop.hbase.tool with parameters of type RegionInfoModifier and TypeMethodDescriptionprivate voidCanaryTool.RegionStdOutSink.incFailuresCountDetails(ServerName serverName, RegionInfo region) voidCanaryTool.RegionStdOutSink.publishReadFailure(ServerName serverName, RegionInfo region, Exception e) voidCanaryTool.RegionStdOutSink.publishReadFailure(ServerName serverName, RegionInfo region, ColumnFamilyDescriptor column, Exception e) voidCanaryTool.RegionStdOutSink.publishReadTiming(ServerName serverName, RegionInfo region, ColumnFamilyDescriptor column, long msTime) voidCanaryTool.RegionStdOutSink.publishWriteFailure(ServerName serverName, RegionInfo region, Exception e) voidCanaryTool.RegionStdOutSink.publishWriteFailure(ServerName serverName, RegionInfo region, ColumnFamilyDescriptor column, Exception e) voidCanaryTool.RegionStdOutSink.publishWriteTiming(ServerName serverName, RegionInfo region, ColumnFamilyDescriptor column, long msTime) Method parameters in org.apache.hadoop.hbase.tool with type arguments of type RegionInfoModifier and TypeMethodDescriptionprivate Map<String,List<RegionInfo>> CanaryTool.RegionServerMonitor.doFilterRegionServerByName(Map<String, List<RegionInfo>> fullRsAndRMap) private voidCanaryTool.RegionServerMonitor.monitorRegionServers(Map<String, List<RegionInfo>> rsAndRMap, CanaryTool.RegionServerStdOutSink regionServerSink) Constructors in org.apache.hadoop.hbase.tool with parameters of type RegionInfoModifierConstructorDescription(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
Classes in org.apache.hadoop.hbase.util that implement RegionInfoModifier and TypeClassDescriptionstatic classStores the regioninfo entries scanned from METAFields in org.apache.hadoop.hbase.util declared as RegionInfoModifier and TypeFieldDescription(package private) RegionInfoHbckRegionInfo.HdfsEntry.hriprivate RegionInfoHbckRegionInfo.primaryHRIForDeployedReplicaprivate final RegionInfoMoveWithAck.regionprivate final RegionInfoMoveWithoutAck.regionprivate RegionInfoHbckRegionInfo.OnlineEntry.regionInfo(package private) RegionInfoHbckRegionInfo.MetaEntry.splitA(package private) RegionInfoHbckRegionInfo.MetaEntry.splitBFields in org.apache.hadoop.hbase.util with type parameters of type RegionInfoModifier and TypeFieldDescriptionprivate final List<RegionInfo>MoveWithAck.movedRegionsprivate final List<RegionInfo>MoveWithoutAck.movedRegionsprivate org.apache.hbase.thirdparty.com.google.common.collect.ImmutableList<RegionInfo>HbckTableInfo.regionsFromMetaMethods in org.apache.hadoop.hbase.util that return RegionInfoModifier and TypeMethodDescriptionstatic RegionInfoModifyRegionUtils.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.OnlineEntry.getRegionInfo()static RegionInfoServerRegionReplicaUtil.getRegionInfoForFs(RegionInfo regionInfo) Returns the regionInfo object to use for interacting with the file system.Methods in org.apache.hadoop.hbase.util that return types with arguments of type RegionInfoModifier 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) Methods in org.apache.hadoop.hbase.util with parameters of type RegionInfoModifier and TypeMethodDescriptionvoidHbckRegionInfo.addServer(RegionInfo regionInfo, ServerName serverName) static voidHBaseFsckRepair.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 HRegionHBaseFsckRepair.createHDFSRegionDir(org.apache.hadoop.conf.Configuration conf, RegionInfo hri, TableDescriptor htd) Creates, flushes, and closes a new region.static RegionInfoModifyRegionUtils.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 booleanFSUtils.deleteRegionDir(org.apache.hadoop.conf.Configuration conf, RegionInfo hri) Delete the region directory if exists.voidModifyRegionUtils.RegionEditTask.editRegion(RegionInfo region) static voidHBaseFsckRepair.fixMetaHoleOnlineAndAddReplicas(org.apache.hadoop.conf.Configuration conf, RegionInfo hri, Collection<ServerName> servers, int numReplicas) Puts the specified RegionInfo into META with replica related columnsstatic voidHBaseFsckRepair.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 voidHBaseFsckRepair.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 voidHBaseFsckRepair.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.PathFSUtils.getRegionDirFromRootDir(org.apache.hadoop.fs.Path rootDir, RegionInfo region) static org.apache.hadoop.fs.PathFSUtils.getRegionDirFromTableDir(org.apache.hadoop.fs.Path tableDir, RegionInfo region) static RegionInfoServerRegionReplicaUtil.getRegionInfoForFs(RegionInfo regionInfo) Returns the regionInfo object to use for interacting with the file system.(package private) static ServerNameMoveWithAck.getServerNameForRegion(RegionInfo region, Admin admin, Connection conn) Get servername that is up in hbase:meta hosting the given region.static org.apache.hadoop.fs.PathHFileArchiveUtil.getStoreArchivePath(org.apache.hadoop.conf.Configuration conf, RegionInfo region, byte[] family) Gets the directory to archive a store directory.static org.apache.hadoop.fs.PathHFileArchiveUtil.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.PathHFileArchiveUtil.getStoreArchivePathForArchivePath(org.apache.hadoop.fs.Path archivePath, RegionInfo region, byte[] family) static org.apache.hadoop.fs.PathHFileArchiveUtil.getStoreArchivePathForRootDir(org.apache.hadoop.fs.Path rootDir, RegionInfo region, byte[] family) Gets the archive directory under specified root dir.static StoreFileInfoServerRegionReplicaUtil.getStoreFileInfo(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, RegionInfo regionInfo, RegionInfo regionInfoForFs, String familyName, org.apache.hadoop.fs.Path path) Returns a StoreFileInfo from the given FileStatus.private booleanMoveWithAck.isSameServer(RegionInfo region, ServerName serverName) Returns true if passed region is still on serverName when we look at hbase:meta.private voidMoveWithAck.isSuccessfulScan(RegionInfo region) Tries to scan a row from passed regionstatic voidHBaseFsckRepair.removeParentInMeta(org.apache.hadoop.conf.Configuration conf, RegionInfo hri) static voidHBaseFsckRepair.waitUntilAssigned(Admin admin, RegionInfo region) Method parameters in org.apache.hadoop.hbase.util with type arguments of type RegionInfoModifier and TypeMethodDescriptionstatic voidModifyRegionUtils.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 voidRegionMover.loadRegions(List<RegionInfo> regionsToMove) private voidRegionMover.writeFile(String filename, List<RegionInfo> movedRegions) Write the number of regions moved in the first line followed by regions moved in subsequent linesConstructors in org.apache.hadoop.hbase.util with parameters of type RegionInfoModifierConstructorDescriptionMetaEntry(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) Constructor parameters in org.apache.hadoop.hbase.util with type arguments of type RegionInfoModifierConstructorDescription(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
Fields in org.apache.hadoop.hbase.util.compaction declared as RegionInfoMethods in org.apache.hadoop.hbase.util.compaction that return RegionInfoModifier and TypeMethodDescription(package private) RegionInfoMajorCompactionRequest.getRegion()Methods in org.apache.hadoop.hbase.util.compaction that return types with arguments of type RegionInfoModifier and TypeMethodDescriptionprivate Map<ServerName,List<RegionInfo>> MajorCompactor.getServerRegionsMap()Methods in org.apache.hadoop.hbase.util.compaction with parameters of type RegionInfoModifier 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) Constructors in org.apache.hadoop.hbase.util.compaction with parameters of type RegionInfoModifierConstructorDescription(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
Methods in org.apache.hadoop.hbase.wal with parameters of type RegionInfoModifier and TypeMethodDescriptionprivate longDisabledWALProvider.DisabledWAL.append(RegionInfo info, WALKeyImpl key, WALEdit edits, boolean inMemstore) longDisabledWALProvider.DisabledWAL.appendData(RegionInfo info, WALKeyImpl key, WALEdit edits) longWAL.appendData(RegionInfo info, WALKeyImpl key, WALEdit edits) Append a set of data edits to the WAL.longDisabledWALProvider.DisabledWAL.appendMarker(RegionInfo info, WALKeyImpl key, WALEdit edits) longWAL.appendMarker(RegionInfo info, WALKeyImpl key, WALEdit edits) Append an operational 'meta' event marker edit to the WAL.static WALEditWALEdit.createBulkLoadEvent(RegionInfo hri, org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.BulkLoadDescriptor bulkLoadDescriptor) Create a bulk loader WALEditstatic WALEditWALEdit.createCompaction(RegionInfo hri, org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.CompactionDescriptor c) Returns A Marker WALEdit that hascserialized as its valuestatic WALEditWALEdit.createFlushWALEdit(RegionInfo hri, org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptor f) static WALEditWALEdit.createRegionEventWALEdit(RegionInfo hri, org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.RegionEventDescriptor regionEventDesc) static longWALSplitUtil.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.static byte[]WALEdit.getRowForRegion(RegionInfo hri) AbstractFSWALProvider.getWAL(RegionInfo region) DisabledWALProvider.getWAL(RegionInfo region) RegionGroupingProvider.getWAL(RegionInfo region) WALFactory.getWAL(RegionInfo region) WALProvider.getWAL(RegionInfo region) static booleanWALSplitUtil.hasRecoveredEdits(org.apache.hadoop.conf.Configuration conf, RegionInfo regionInfo) Check whether there is recovered.edits in the region dir