Uses of Class
org.apache.hadoop.hbase.HRegionInfo
Package
Description
Provides HBase Client
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
-
Uses of org.apache.hadoop.hbase.HRegionInfo in org.apache.hadoop.hbase
Modifier and TypeFieldDescriptionstatic final org.apache.hadoop.hbase.HRegionInfo
HRegionInfo.FIRST_META_REGIONINFO
Deprecated.HRegionInfo for first meta regionModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.HRegionInfo
HRegionInfo.convert
(org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionInfo proto) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 Use toRegionInfo(HBaseProtos.RegionInfo) in org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil.org.apache.hadoop.hbase.HRegionInfo
HRegionLocation.getRegionInfo()
Deprecated.Since 2.0.0.static org.apache.hadoop.hbase.HRegionInfo
HRegionInfo.parseFrom
(byte[] bytes) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseRegionInfo.parseFrom(byte[])
.static org.apache.hadoop.hbase.HRegionInfo
HRegionInfo.parseFrom
(byte[] bytes, int offset, int len) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseRegionInfo.parseFrom(byte[], int, int)
.static org.apache.hadoop.hbase.HRegionInfo
HRegionInfo.parseFrom
(DataInputStream in) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseRegionInfo.parseFrom(DataInputStream)
.static org.apache.hadoop.hbase.HRegionInfo
HRegionInfo.parseFromOrNull
(byte[] bytes) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseRegionInfo.parseFromOrNull(byte[])
.static org.apache.hadoop.hbase.HRegionInfo
HRegionInfo.parseFromOrNull
(byte[] bytes, int offset, int len) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseRegionInfo.parseFromOrNull(byte[], int, int)
.Modifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.HRegionInfo>
HRegionInfo.parseDelimitedFrom
(byte[] bytes, int offset, int length) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseRegionInfo.parseDelimitedFrom(byte[], int, int)
.Modifier and TypeMethodDescriptionstatic boolean
HRegionInfo.areAdjacent
(org.apache.hadoop.hbase.HRegionInfo regionA, org.apache.hadoop.hbase.HRegionInfo regionB) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseRegionInfo.areAdjacent(RegionInfo, RegionInfo)
.static org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionInfo
HRegionInfo.convert
(org.apache.hadoop.hbase.HRegionInfo info) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 Use toRegionInfo(org.apache.hadoop.hbase.client.RegionInfo) in org.apache.hadoop.hbase.shaded.protobuf.ProtobufUtil.static byte[]
HRegionInfo.getEndKeyForDisplay
(org.apache.hadoop.hbase.HRegionInfo hri, org.apache.hadoop.conf.Configuration conf) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfoDisplay#getEndKeyForDisplay(RegionInfo, Configuration) over in hbase-server module.static String
HRegionInfo.getRegionNameAsStringForDisplay
(org.apache.hadoop.hbase.HRegionInfo hri, org.apache.hadoop.conf.Configuration conf) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfoDisplay#getRegionNameAsStringForDisplay(RegionInfo, Configuration) over in hbase-server module.static byte[]
HRegionInfo.getRegionNameForDisplay
(org.apache.hadoop.hbase.HRegionInfo hri, org.apache.hadoop.conf.Configuration conf) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfoDisplay#getRegionNameForDisplay(RegionInfo, Configuration) over in hbase-server module.static String
HRegionInfo.getShortNameToLog
(org.apache.hadoop.hbase.HRegionInfo... hris) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseRegionInfo.getShortNameToLog(RegionInfo...)
.static byte[]
HRegionInfo.getStartKeyForDisplay
(org.apache.hadoop.hbase.HRegionInfo hri, org.apache.hadoop.conf.Configuration conf) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfoDisplay#getStartKeyForDisplay(RegionInfo, Configuration) over in hbase-server module.static byte[]
HRegionInfo.toDelimitedByteArray
(org.apache.hadoop.hbase.HRegionInfo... infos) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseRegionInfo.toDelimitedByteArray(RegionInfo...)
.Modifier and TypeMethodDescriptionstatic String
HRegionInfo.getShortNameToLog
(List<org.apache.hadoop.hbase.HRegionInfo> hris) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseRegionInfo.getShortNameToLog(List)
)}.ModifierConstructorDescriptionHRegionInfo
(org.apache.hadoop.hbase.HRegionInfo other, int replicaId) Deprecated. -
Uses of org.apache.hadoop.hbase.HRegionInfo in org.apache.hadoop.hbase.client
Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.client.ImmutableHRegionInfo
Deprecated.Modifier and TypeFieldDescriptionprotected org.apache.hadoop.hbase.HRegionInfo
ClientScanner.currentRegion
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.HRegionInfo
RegionServerCallable.getHRegionInfo()
Returns the HRegionInfo for the current regionorg.apache.hadoop.hbase.HRegionInfo
ScannerCallable.getHRegionInfo()
Returns the HRegionInfo for the current regionModifier and TypeMethodDescriptionList<org.apache.hadoop.hbase.HRegionInfo>
Admin.getOnlineRegions
(org.apache.hadoop.hbase.ServerName sn) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-17980).List<org.apache.hadoop.hbase.HRegionInfo>
HBaseAdmin.getOnlineRegions
(org.apache.hadoop.hbase.ServerName sn) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseHBaseAdmin.getRegions(ServerName)
.List<org.apache.hadoop.hbase.HRegionInfo>
Admin.getTableRegions
(org.apache.hadoop.hbase.TableName tableName) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-17980).List<org.apache.hadoop.hbase.HRegionInfo>
HBaseAdmin.getTableRegions
(org.apache.hadoop.hbase.TableName tableName) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseHBaseAdmin.getRegions(TableName)
.Modifier and TypeMethodDescriptionvoid
Admin.closeRegion
(org.apache.hadoop.hbase.ServerName sn, org.apache.hadoop.hbase.HRegionInfo hri) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-18231).void
HBaseAdmin.closeRegion
(org.apache.hadoop.hbase.ServerName unused, org.apache.hadoop.hbase.HRegionInfo hri) Deprecated. -
Uses of org.apache.hadoop.hbase.HRegionInfo in org.apache.hadoop.hbase.mapred
-
Uses of org.apache.hadoop.hbase.HRegionInfo in org.apache.hadoop.hbase.mapreduce
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.HRegionInfo
TableSnapshotInputFormat.TableSnapshotRegionSplit.getRegionInfo()
Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseTableSnapshotInputFormat.TableSnapshotRegionSplit.getRegion()
org.apache.hadoop.hbase.HRegionInfo
TableSnapshotInputFormatImpl.InputSplit.getRegionInfo()
Modifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.HRegionInfo>
TableSnapshotInputFormatImpl.getRegionInfosFromManifest
(org.apache.hadoop.hbase.snapshot.SnapshotManifest manifest) Modifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit>
TableSnapshotInputFormatImpl.getSplits
(org.apache.hadoop.hbase.client.Scan scan, org.apache.hadoop.hbase.snapshot.SnapshotManifest manifest, List<org.apache.hadoop.hbase.HRegionInfo> regionManifests, org.apache.hadoop.fs.Path restoreDir, org.apache.hadoop.conf.Configuration conf) static List<org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit>
TableSnapshotInputFormatImpl.getSplits
(org.apache.hadoop.hbase.client.Scan scan, org.apache.hadoop.hbase.snapshot.SnapshotManifest manifest, List<org.apache.hadoop.hbase.HRegionInfo> regionManifests, org.apache.hadoop.fs.Path restoreDir, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm sa, int numSplits) ModifierConstructorDescriptionInputSplit
(org.apache.hadoop.hbase.client.TableDescriptor htd, org.apache.hadoop.hbase.HRegionInfo regionInfo, List<String> locations, org.apache.hadoop.hbase.client.Scan scan, org.apache.hadoop.fs.Path restoreDir) TableSnapshotRegionSplit
(org.apache.hadoop.hbase.HTableDescriptor htd, org.apache.hadoop.hbase.HRegionInfo regionInfo, List<String> locations, org.apache.hadoop.hbase.client.Scan scan, org.apache.hadoop.fs.Path restoreDir) -
Uses of org.apache.hadoop.hbase.HRegionInfo in org.apache.hadoop.hbase.util
Modifier and TypeClassDescriptionstatic class
org.apache.hadoop.hbase.util.HbckRegionInfo.MetaEntry
Stores the regioninfo entries scanned from META