Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.ipc | |
org.apache.hadoop.hbase.master | |
org.apache.hadoop.hbase.shaded.protobuf |
Modifier and Type | Method and Description |
---|---|
RegionInfo |
HRegionLocation.getRegion() |
static RegionInfo |
CatalogFamilyFormat.getRegionInfo(Result data)
Returns RegionInfo object from the column
HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog table Result.
|
static RegionInfo |
CatalogFamilyFormat.getRegionInfo(Result r,
byte[] qualifier)
Returns the RegionInfo object from the column
HConstants.CATALOG_FAMILY and
qualifier of the catalog table result. |
static RegionInfo |
CatalogFamilyFormat.parseRegionInfoFromRegionName(byte[] regionName)
Returns an HRI parsed from this regionName.
|
Modifier and Type | Method and Description |
---|---|
static List<RegionInfo> |
CatalogFamilyFormat.getMergeRegions(Cell[] cells) |
static Map<String,RegionInfo> |
CatalogFamilyFormat.getMergeRegionsWithName(Cell[] cells) |
Modifier and Type | Method and Description |
---|---|
static byte[] |
CatalogFamilyFormat.getMetaKeyForRegion(RegionInfo regionInfo)
Returns the row key to use for this regionInfo
|
static HRegionLocation |
CatalogFamilyFormat.getRegionLocation(Result r,
RegionInfo regionInfo,
int replicaId)
Returns the HRegionLocation parsed from the given meta row Result for the given regionInfo and
replicaId.
|
Constructor and Description |
---|
HRegionLocation(RegionInfo regionInfo,
ServerName serverName) |
HRegionLocation(RegionInfo regionInfo,
ServerName serverName,
long seqNum) |
Modifier and Type | Field and Description |
---|---|
static RegionInfo |
RegionInfoBuilder.FIRST_META_REGIONINFO
RegionInfo for first meta region
You cannot use this builder to make an instance of the
RegionInfoBuilder.FIRST_META_REGIONINFO . |
static RegionInfo |
RegionInfo.UNDEFINED
Deprecated.
since 2.3.2/3.0.0; to be removed in 4.0.0 with no replacement (for internal use).
|
static RegionInfo |
RegionInfoBuilder.UNDEFINED |
Modifier and Type | Field and Description |
---|---|
static Comparator<RegionInfo> |
RegionInfo.COMPARATOR |
Modifier and Type | Method and Description |
---|---|
RegionInfo |
RegionInfoBuilder.build() |
static RegionInfo |
RegionInfo.createMobRegionInfo(TableName tableName)
Creates a RegionInfo object for MOB data.
|
static RegionInfo |
RegionReplicaUtil.getRegionInfoForDefaultReplica(RegionInfo regionInfo)
Returns the RegionInfo for the default replicaId (0).
|
static RegionInfo |
RegionReplicaUtil.getRegionInfoForReplica(RegionInfo regionInfo,
int replicaId)
Returns the RegionInfo for the given replicaId.
|
static RegionInfo |
RegionInfo.parseFrom(byte[] bytes) |
static RegionInfo |
RegionInfo.parseFrom(byte[] bytes,
int offset,
int len) |
static RegionInfo |
RegionInfo.parseFrom(DataInputStream in)
Parses an RegionInfo instance from the passed in stream.
|
static RegionInfo |
RegionInfo.parseFromOrNull(byte[] bytes) |
static RegionInfo |
RegionInfo.parseFromOrNull(byte[] bytes,
int offset,
int len) |
Modifier and Type | Method and Description |
---|---|
static 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)
|
CompletableFuture<List<RegionInfo>> |
AsyncAdmin.getRegions(ServerName serverName)
Get all the online regions on a region server.
|
List<RegionInfo> |
Admin.getRegions(ServerName serverName)
Get all the online regions on a region server.
|
CompletableFuture<List<RegionInfo>> |
AsyncAdmin.getRegions(TableName tableName)
Get the regions of a given table.
|
List<RegionInfo> |
Admin.getRegions(TableName tableName)
Get the regions of a given table.
|
static List<RegionInfo> |
RegionInfo.parseDelimitedFrom(byte[] bytes,
int offset,
int length)
Parses all the RegionInfo instances from the passed in stream until EOF.
|
Modifier and Type | Method and Description |
---|---|
static boolean |
RegionInfo.areAdjacent(RegionInfo regionA,
RegionInfo regionB)
Check whether two regions are adjacent; i.e.
|
default int |
RegionInfo.compareTo(RegionInfo other) |
static byte[] |
RegionInfoDisplay.getEndKeyForDisplay(RegionInfo ri,
org.apache.hadoop.conf.Configuration conf)
Get the end key for display.
|
static RegionInfo |
RegionReplicaUtil.getRegionInfoForDefaultReplica(RegionInfo regionInfo)
Returns the RegionInfo for the default replicaId (0).
|
static RegionInfo |
RegionReplicaUtil.getRegionInfoForReplica(RegionInfo regionInfo,
int replicaId)
Returns the RegionInfo for the given replicaId.
|
static String |
RegionInfo.getRegionNameAsString(RegionInfo ri,
byte[] regionName) |
static String |
RegionInfoDisplay.getRegionNameAsStringForDisplay(RegionInfo ri,
org.apache.hadoop.conf.Configuration conf)
Get the region name for display.
|
static byte[] |
RegionInfoDisplay.getRegionNameForDisplay(RegionInfo ri,
org.apache.hadoop.conf.Configuration conf)
Get the region name for display.
|
static String |
RegionInfo.getShortNameToLog(RegionInfo... hris) |
static byte[] |
RegionInfoDisplay.getStartKeyForDisplay(RegionInfo ri,
org.apache.hadoop.conf.Configuration conf)
Get the start key for display.
|
default boolean |
RegionInfo.isAdjacent(RegionInfo other) |
static boolean |
RegionReplicaUtil.isDefaultReplica(RegionInfo hri) |
default boolean |
RegionInfo.isNext(RegionInfo after) |
default boolean |
RegionInfo.isOverlap(RegionInfo other) |
static boolean |
RegionReplicaUtil.isReplicasForSameRegion(RegionInfo regionInfoA,
RegionInfo regionInfoB) |
static RegionInfoBuilder |
RegionInfoBuilder.newBuilder(RegionInfo regionInfo) |
void |
AsyncTable.CoprocessorCallback.onRegionComplete(RegionInfo region,
R resp) |
void |
AsyncTable.CoprocessorCallback.onRegionError(RegionInfo region,
Throwable error) |
static byte[] |
RegionInfo.toByteArray(RegionInfo ri) |
static byte[] |
RegionInfo.toDelimitedByteArray(RegionInfo... infos)
Serializes given RegionInfo's as a byte array.
|
static byte[] |
RegionInfo.toDelimitedByteArray(RegionInfo ri)
Use this instead of
toByteArray(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). |
Modifier and Type | Method and Description |
---|---|
static 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)
|
static String |
RegionInfo.getShortNameToLog(List<RegionInfo> ris) |
static void |
RegionReplicaUtil.removeNonDefaultRegions(Collection<RegionInfo> regions)
Removes the non-default replicas from the passed regions collection
|
Modifier and Type | Method and Description |
---|---|
default RegionInfo |
HBaseRpcController.getRegionInfo() |
RegionInfo |
HBaseRpcControllerImpl.getRegionInfo() |
Modifier and Type | Method and Description |
---|---|
HBaseRpcController |
RpcControllerFactory.newController(RegionInfo regionInfo,
CellScanner cellScanner) |
HBaseRpcController |
RpcControllerFactory.newController(RegionInfo regionInfo,
List<CellScannable> cellIterables) |
Modifier and Type | Method and Description |
---|---|
RegionInfo |
RegionState.getRegion() |
Modifier and Type | Method and Description |
---|---|
static RegionState |
RegionState.createForTesting(RegionInfo region,
RegionState.State state) |
Constructor and Description |
---|
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) |
Modifier and Type | Method and Description |
---|---|
static RegionInfo |
ProtobufUtil.getRegionInfo(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface admin,
byte[] regionName)
A helper to retrieve region info given a region name or an
encoded region name using admin protocol.
|
static RegionInfo |
ProtobufUtil.toRegionInfo(org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionInfo proto)
Convert HBaseProto.RegionInfo to a RegionInfo
|
Modifier and Type | Method and Description |
---|---|
static List<RegionInfo> |
ProtobufUtil.getOnlineRegions(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface admin)
A helper to get the all the online regions on a region
server using admin protocol.
|
static List<RegionInfo> |
ProtobufUtil.getOnlineRegions(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller,
org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface admin)
A helper to get the all the online regions on a region
server using admin protocol.
|
static List<RegionInfo> |
ResponseConverter.getRegionInfos(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetOnlineRegionResponse proto)
Get the list of region info from a GetOnlineRegionResponse
|
static List<RegionInfo> |
ProtobufUtil.getRegionInfos(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetOnlineRegionResponse proto)
Get the list of region info from a GetOnlineRegionResponse
|
Modifier and Type | Method and Description |
---|---|
static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ClearRegionBlockCacheRequest |
RequestConverter.buildClearRegionBlockCacheRequest(List<RegionInfo> hris)
Creates a protocol buffer ClearRegionBlockCacheRequest
|
static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetOnlineRegionResponse |
ResponseConverter.buildGetOnlineRegionResponse(List<RegionInfo> regions)
A utility to build a GetOnlineRegionResponse.
|
static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest |
RequestConverter.buildUpdateFavoredNodesRequest(List<Pair<RegionInfo,List<ServerName>>> updateRegionInfos)
Create a protocol buffer UpdateFavoredNodesRequest to update a list of favorednode mappings
|
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.