Uses of Class
org.apache.hadoop.hbase.HRegionInfo

Packages that use 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

    Fields in org.apache.hadoop.hbase declared as org.apache.hadoop.hbase.HRegionInfo in in
    Modifier and Type
    Field
    Description
    static final org.apache.hadoop.hbase.HRegionInfo
    HRegionInfo.FIRST_META_REGIONINFO
    Deprecated.
    HRegionInfo for first meta region
    Methods in org.apache.hadoop.hbase that return org.apache.hadoop.hbase.HRegionInfo in in
    Modifier and Type
    Method
    Description
    static 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 Use RegionInfo.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 Use RegionInfo.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 Use RegionInfo.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 Use RegionInfo.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 Use RegionInfo.parseFromOrNull(byte[], int, int).
    Methods in org.apache.hadoop.hbase that return types with arguments of type org.apache.hadoop.hbase.HRegionInfo in in
    Modifier and Type
    Method
    Description
    static 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 Use RegionInfo.parseDelimitedFrom(byte[], int, int).
    Methods in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.HRegionInfo in in
    Modifier and Type
    Method
    Description
    static 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 Use RegionInfo.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 Use RegionInfo.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 Use RegionInfo.toDelimitedByteArray(RegionInfo...).
    Method parameters in org.apache.hadoop.hbase with type arguments of type org.apache.hadoop.hbase.HRegionInfo in in
    Modifier and Type
    Method
    Description
    static 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 Use RegionInfo.getShortNameToLog(List))}.
    Constructors in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.HRegionInfo in in
    Modifier
    Constructor
    Description
     
    HRegionInfo(org.apache.hadoop.hbase.HRegionInfo other, int replicaId)
    Deprecated.
     
  • Uses of org.apache.hadoop.hbase.HRegionInfo in org.apache.hadoop.hbase.client

    Subclasses of org.apache.hadoop.hbase.HRegionInfo in in org.apache.hadoop.hbase.client
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.client.ImmutableHRegionInfo
    Deprecated.
    Fields in org.apache.hadoop.hbase.client declared as org.apache.hadoop.hbase.HRegionInfo in in
    Modifier and Type
    Field
    Description
    protected org.apache.hadoop.hbase.HRegionInfo
    ClientScanner.currentRegion
     
    Methods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.HRegionInfo in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.HRegionInfo
    RegionServerCallable.getHRegionInfo()
    Returns the HRegionInfo for the current region
    org.apache.hadoop.hbase.HRegionInfo
    ScannerCallable.getHRegionInfo()
    Returns the HRegionInfo for the current region
    Methods in org.apache.hadoop.hbase.client that return types with arguments of type org.apache.hadoop.hbase.HRegionInfo in in
    Modifier and Type
    Method
    Description
    List<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 Use HBaseAdmin.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 Use HBaseAdmin.getRegions(TableName).
    Methods in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.HRegionInfo in in
    Modifier and Type
    Method
    Description
    void
    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

    Constructors in org.apache.hadoop.hbase.mapred with parameters of type org.apache.hadoop.hbase.HRegionInfo in in
    Modifier
    Constructor
    Description
     
    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.mapreduce

    Methods in org.apache.hadoop.hbase.mapreduce that return org.apache.hadoop.hbase.HRegionInfo in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.HRegionInfo
    TableSnapshotInputFormat.TableSnapshotRegionSplit.getRegionInfo()
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use TableSnapshotInputFormat.TableSnapshotRegionSplit.getRegion()
    org.apache.hadoop.hbase.HRegionInfo
    TableSnapshotInputFormatImpl.InputSplit.getRegionInfo()
     
    Methods in org.apache.hadoop.hbase.mapreduce that return types with arguments of type org.apache.hadoop.hbase.HRegionInfo in in
    Modifier and Type
    Method
    Description
    static List<org.apache.hadoop.hbase.HRegionInfo>
    TableSnapshotInputFormatImpl.getRegionInfosFromManifest(org.apache.hadoop.hbase.snapshot.SnapshotManifest manifest)
     
    Method parameters in org.apache.hadoop.hbase.mapreduce with type arguments of type org.apache.hadoop.hbase.HRegionInfo in in
    Modifier and Type
    Method
    Description
    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)
     
    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)
     
    Constructors in org.apache.hadoop.hbase.mapreduce with parameters of type org.apache.hadoop.hbase.HRegionInfo in in
    Modifier
    Constructor
    Description
     
    InputSplit(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

    Subclasses of org.apache.hadoop.hbase.HRegionInfo in in org.apache.hadoop.hbase.util
    Modifier and Type
    Class
    Description
    static class 
    org.apache.hadoop.hbase.util.HbckRegionInfo.MetaEntry
    Stores the regioninfo entries scanned from META