Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.master | |
org.apache.hadoop.hbase.shaded.protobuf |
Modifier and Type | Class and Description |
---|---|
class |
HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
use
RegionInfoBuilder to build RegionInfo . |
Modifier and Type | Method and Description |
---|---|
RegionInfo |
HRegionLocation.getRegion() |
static RegionInfo |
MetaTableAccessor.getRegionInfo(Result data)
Returns RegionInfo object from the column
HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog
table Result.
|
static RegionInfo |
MetaTableAccessor.parseRegionInfoFromRegionName(byte[] regionName)
Returns an HRI parsed from this regionName.
|
Modifier and Type | Method and Description |
---|---|
static NavigableMap<RegionInfo,ServerName> |
MetaTableAccessor.allTableRegions(Connection connection,
TableName tableName)
Deprecated.
use
MetaTableAccessor.getTableRegionsAndLocations(org.apache.hadoop.hbase.client.Connection, org.apache.hadoop.hbase.TableName) , region can have multiple locations |
static 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.
|
static PairOfSameType<RegionInfo> |
MetaTableAccessor.getMergeRegions(Result data)
Returns the merge regions by reading the corresponding columns of the catalog table
Result.
|
static Pair<RegionInfo,ServerName> |
MetaTableAccessor.getRegion(Connection connection,
byte[] regionName)
Deprecated.
|
static Pair<RegionInfo,RegionInfo> |
MetaTableAccessor.getRegionsFromMergeQualifier(Connection connection,
byte[] regionName)
Get regions from the merge qualifier of the specified merged region
|
static Pair<RegionInfo,RegionInfo> |
MetaTableAccessor.getRegionsFromMergeQualifier(Connection connection,
byte[] regionName)
Get regions from the merge qualifier of the specified merged region
|
static NavigableMap<RegionInfo,Result> |
MetaTableAccessor.getServerUserRegions(Connection connection,
ServerName serverName) |
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.
|
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.
|
Modifier and Type | Method and Description |
---|---|
static Put |
MetaTableAccessor.addDaughtersToPut(Put put,
RegionInfo splitA,
RegionInfo splitB)
Adds split daughters to the Put
|
static Put |
MetaTableAccessor.addRegionInfo(Put p,
RegionInfo hri) |
static void |
MetaTableAccessor.addRegionToMeta(Connection connection,
RegionInfo regionInfo)
Adds a (single) hbase:meta row for the specified new region and its daughters.
|
static void |
MetaTableAccessor.addSplitsToParent(Connection connection,
RegionInfo regionInfo,
RegionInfo splitA,
RegionInfo splitB)
Adds daughter region infos to hbase:meta row for the specified region.
|
static void |
MetaTableAccessor.deleteMergeQualifiers(Connection connection,
RegionInfo mergedRegion)
Deletes merge qualifiers for the specified merged region.
|
static void |
MetaTableAccessor.deleteRegion(Connection connection,
RegionInfo regionInfo)
Deletes the specified region from META.
|
static byte[] |
MetaTableAccessor.getMetaKeyForRegion(RegionInfo regionInfo)
Returns the row key to use for this regionInfo
|
static HRegionLocation |
MetaTableAccessor.getRegionLocation(Connection connection,
RegionInfo regionInfo)
Returns the HRegionLocation from meta for the given region
|
static Put |
MetaTableAccessor.makePutFromRegionInfo(RegionInfo regionInfo,
long ts)
Generates and returns a Put containing the region into for the catalog table
|
static void |
MetaTableAccessor.mergeRegions(Connection connection,
RegionInfo mergedRegion,
RegionInfo regionA,
RegionInfo regionB,
ServerName sn,
int regionReplication)
Merge the two regions into one in an atomic operation.
|
static void |
MetaTableAccessor.splitRegion(Connection connection,
RegionInfo parent,
RegionInfo splitA,
RegionInfo splitB,
ServerName sn,
int regionReplication)
Splits the region into two in an atomic operation.
|
static void |
MetaTableAccessor.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.
|
Modifier and Type | Method and Description |
---|---|
static void |
MetaTableAccessor.addRegionsToMeta(Connection connection,
List<RegionInfo> regionInfos,
int regionReplication)
Adds a hbase:meta row for each of the specified new regions.
|
static void |
MetaTableAccessor.deleteRegions(Connection connection,
List<RegionInfo> regionsInfo)
Deletes the specified regions from META.
|
static void |
MetaTableAccessor.deleteRegions(Connection connection,
List<RegionInfo> regionsInfo,
long ts)
Deletes the specified regions from META.
|
static void |
MetaTableAccessor.overwriteRegions(Connection connection,
List<RegionInfo> regionInfos,
int regionReplication)
Overwrites the specified regions from hbase:meta.
|
Constructor and Description |
---|
HRegionInfo(RegionInfo other)
Deprecated.
Costruct a copy of another HRegionInfo
|
HRegionLocation(RegionInfo regionInfo,
ServerName serverName) |
HRegionLocation(RegionInfo regionInfo,
ServerName serverName,
long seqNum) |
Modifier and Type | Class and Description |
---|---|
class |
ImmutableHRegionInfo
Deprecated.
|
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 . |
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(TableDescriptor tableDescriptor,
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)
|
List<RegionInfo> |
HBaseAdmin.getRegions(ServerName sn) |
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.
|
List<RegionInfo> |
HBaseAdmin.getRegions(TableName tableName) |
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
|
void |
MetaCache.clearCache(RegionInfo hri)
Deletes the cached location of the region if necessary, based on some error from source.
|
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.
|
static boolean |
RegionReplicaUtil.isDefaultReplica(RegionInfo hri) |
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(TableDescriptor tableDescriptor,
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
|
Constructor and Description |
---|
FlushRegionCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
RegionInfo regionInfo,
boolean writeFlushWalMarker) |
ImmutableHRegionInfo(RegionInfo other)
Deprecated.
|
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
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> |
ProtobufUtil.getRegionInfos(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetOnlineRegionResponse proto)
Get the list of region info from a GetOnlineRegionResponse
|
static List<RegionInfo> |
ResponseConverter.getRegionInfos(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetOnlineRegionResponse proto)
Get the list of region info from a GetOnlineRegionResponse
|
Copyright © 2007–2018 The Apache Software Foundation. All rights reserved.