Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.mapred |
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
|
org.apache.hadoop.hbase.mapreduce |
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
|
org.apache.hadoop.hbase.thrift2.client | |
org.apache.hadoop.hbase.util |
Modifier and Type | Field and Description |
---|---|
static HRegionInfo |
HRegionInfo.FIRST_META_REGIONINFO
Deprecated.
HRegionInfo for first meta region
|
Modifier and Type | Method and Description |
---|---|
static 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.
|
HRegionInfo |
HRegionLocation.getRegionInfo()
Deprecated.
Since 2.0.0. Will remove in 3.0.0. Use
HRegionLocation.getRegion() } instead. |
static 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 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 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 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 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) . |
Modifier and Type | Method and Description |
---|---|
static List<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) . |
Modifier and Type | Method and Description |
---|---|
static boolean |
HRegionInfo.areAdjacent(HRegionInfo regionA,
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(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(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(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(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(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(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(HRegionInfo... infos)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
Use
RegionInfo.toDelimitedByteArray(RegionInfo...) . |
Modifier and Type | Method and Description |
---|---|
static String |
HRegionInfo.getShortNameToLog(List<HRegionInfo> hris)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
Use
RegionInfo.getShortNameToLog(List) )}. |
Constructor and Description |
---|
HRegionInfo(HRegionInfo other,
int replicaId)
Deprecated.
|
Modifier and Type | Class and Description |
---|---|
class |
ImmutableHRegionInfo
Deprecated.
|
(package private) class |
UnmodifyableHRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
|
Modifier and Type | Field and Description |
---|---|
protected HRegionInfo |
ClientScanner.currentRegion |
Modifier and Type | Field and Description |
---|---|
private Set<HRegionInfo> |
SimpleRequestController.TaskCountChecker.regionsIncluded |
Modifier and Type | Method and Description |
---|---|
HRegionInfo |
RegionServerCallable.getHRegionInfo() |
HRegionInfo |
ScannerCallableWithReplicas.getHRegionInfo() |
HRegionInfo |
MultiServerCallable.getHRegionInfo() |
HRegionInfo |
ScannerCallable.getHRegionInfo() |
Modifier and Type | Method and Description |
---|---|
List<HRegionInfo> |
HBaseAdmin.getOnlineRegions(ServerName sn)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
Use
HBaseAdmin.getRegions(ServerName) . |
List<HRegionInfo> |
Admin.getOnlineRegions(ServerName sn)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
(HBASE-17980).
Use
Admin.getRegions(ServerName sn) . |
List<HRegionInfo> |
HBaseAdmin.getTableRegions(TableName tableName)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
Use
HBaseAdmin.getRegions(TableName) . |
List<HRegionInfo> |
Admin.getTableRegions(TableName tableName)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
(HBASE-17980).
Use
Admin.getRegions(TableName) . |
Modifier and Type | Method and Description |
---|---|
void |
HBaseAdmin.closeRegion(ServerName unused,
HRegionInfo hri)
Deprecated.
|
void |
Admin.closeRegion(ServerName sn,
HRegionInfo hri)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
(HBASE-18231).
Use
Admin.unassign(byte[], boolean) . |
Constructor and Description |
---|
UnmodifyableHRegionInfo(HRegionInfo info)
Deprecated.
|
Constructor and Description |
---|
TableSnapshotRegionSplit(HTableDescriptor htd,
HRegionInfo regionInfo,
List<String> locations,
Scan scan,
org.apache.hadoop.fs.Path restoreDir) |
Modifier and Type | Field and Description |
---|---|
private HRegionInfo |
TableSnapshotInputFormatImpl.InputSplit.regionInfo |
Modifier and Type | Method and Description |
---|---|
HRegionInfo |
TableSnapshotInputFormat.TableSnapshotRegionSplit.getRegionInfo()
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
Use
TableSnapshotInputFormat.TableSnapshotRegionSplit.getRegion() |
HRegionInfo |
TableSnapshotInputFormatImpl.InputSplit.getRegionInfo() |
Modifier and Type | Method and Description |
---|---|
static List<HRegionInfo> |
TableSnapshotInputFormatImpl.getRegionInfosFromManifest(SnapshotManifest manifest) |
Modifier and Type | Method and Description |
---|---|
private static List<String> |
TableSnapshotInputFormatImpl.calculateLocationsForInputSplit(org.apache.hadoop.conf.Configuration conf,
TableDescriptor htd,
HRegionInfo hri,
org.apache.hadoop.fs.Path tableDir,
boolean localityEnabled)
Compute block locations for snapshot files (which will get the locations for referred hfiles)
only when localityEnabled is true.
|
Modifier and Type | Method and Description |
---|---|
static List<TableSnapshotInputFormatImpl.InputSplit> |
TableSnapshotInputFormatImpl.getSplits(Scan scan,
SnapshotManifest manifest,
List<HRegionInfo> regionManifests,
org.apache.hadoop.fs.Path restoreDir,
org.apache.hadoop.conf.Configuration conf) |
static List<TableSnapshotInputFormatImpl.InputSplit> |
TableSnapshotInputFormatImpl.getSplits(Scan scan,
SnapshotManifest manifest,
List<HRegionInfo> regionManifests,
org.apache.hadoop.fs.Path restoreDir,
org.apache.hadoop.conf.Configuration conf,
RegionSplitter.SplitAlgorithm sa,
int numSplits) |
Constructor and Description |
---|
InputSplit(TableDescriptor htd,
HRegionInfo regionInfo,
List<String> locations,
Scan scan,
org.apache.hadoop.fs.Path restoreDir) |
TableSnapshotRegionSplit(HTableDescriptor htd,
HRegionInfo regionInfo,
List<String> locations,
Scan scan,
org.apache.hadoop.fs.Path restoreDir) |
Modifier and Type | Method and Description |
---|---|
List<HRegionInfo> |
ThriftAdmin.getOnlineRegions(ServerName sn) |
List<HRegionInfo> |
ThriftAdmin.getTableRegions(TableName tableName) |
Modifier and Type | Method and Description |
---|---|
void |
ThriftAdmin.closeRegion(ServerName sn,
HRegionInfo hri) |
Modifier and Type | Class and Description |
---|---|
static class |
HbckRegionInfo.MetaEntry
Stores the regioninfo entries scanned from META
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.