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 | 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()
Returns regionInfo
|
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.getRegionInfo(Result r,
byte[] qualifier)
Returns the RegionInfo object from the column
HConstants.CATALOG_FAMILY and
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 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 List<RegionInfo> |
MetaTableAccessor.getMergeRegions(Cell[] cells)
Returns Deserialized regioninfo values taken from column values that match the regex
'info:merge.*' in array of
cells . |
static List<RegionInfo> |
MetaTableAccessor.getMergeRegions(Connection connection,
RegionInfo regionInfo)
Returns Return all regioninfos listed in the 'info:merge*' columns of the
regionInfo
row. |
static Map<String,RegionInfo> |
MetaTableAccessor.getMergeRegionsWithName(Cell[] cells)
Returns Deserialized values of <qualifier,regioninfo> pairs taken from column values that
match the regex 'info:merge.*' in array of
cells . |
static Pair<RegionInfo,ServerName> |
MetaTableAccessor.getRegion(Connection connection,
byte[] regionName)
Deprecated.
|
static NavigableMap<RegionInfo,Result> |
MetaTableAccessor.getServerUserRegions(Connection connection,
ServerName serverName)
Get the user regions a given server is hosting.
|
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.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 mergeRegion)
Deletes merge qualifiers for the specified merge region.
|
static void |
MetaTableAccessor.deleteRegionInfo(Connection connection,
RegionInfo regionInfo)
Deletes the specified region from META.
|
static Result |
MetaTableAccessor.getCatalogFamilyRow(Connection connection,
RegionInfo ri)
Returns Return the
HConstants.CATALOG_FAMILY row from hbase:meta. |
static List<RegionInfo> |
MetaTableAccessor.getMergeRegions(Connection connection,
RegionInfo regionInfo)
Returns Return all regioninfos listed in the 'info:merge*' columns of the
regionInfo
row. |
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 Result |
MetaTableAccessor.getRegionResult(Connection connection,
RegionInfo regionInfo)
Gets the result in hbase:meta for the specified region.
|
static boolean |
MetaTableAccessor.hasMergeRegions(Connection conn,
RegionInfo regionInfo)
Check whether the given
regionInfo has any 'info:merge*' columns. |
static Delete |
MetaTableAccessor.makeDeleteFromRegionInfo(RegionInfo regionInfo,
long ts)
Generates and returns a Delete containing the region info for the catalog table
|
static Put |
MetaTableAccessor.makePutForReplicationBarrier(RegionInfo regionInfo,
long openSeqNum,
long ts) |
static Put |
MetaTableAccessor.makePutFromRegionInfo(RegionInfo regionInfo)
Generates and returns a
Put containing the RegionInfo for the catalog table. |
static Put |
MetaTableAccessor.makePutFromRegionInfo(RegionInfo regionInfo,
long ts)
Generates and returns a
Put containing the RegionInfo for the catalog table. |
static void |
MetaTableAccessor.mergeRegions(Connection connection,
RegionInfo mergedRegion,
Map<RegionInfo,Long> parentSeqNum,
ServerName sn,
int regionReplication)
Merge regions into one in an atomic operation.
|
static void |
MetaTableAccessor.splitRegion(Connection connection,
RegionInfo parent,
long parentOpenSeqNum,
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.
|
static void |
MetaTableAccessor.updateRegionState(Connection connection,
RegionInfo ri,
RegionState.State state)
Update state column in hbase:meta.
|
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.deleteRegionInfos(Connection connection,
List<RegionInfo> regionsInfo)
Deletes the specified regions from META.
|
static byte[] |
MetaTableAccessor.getParentsBytes(List<RegionInfo> parents) |
static void |
MetaTableAccessor.mergeRegions(Connection connection,
RegionInfo mergedRegion,
Map<RegionInfo,Long> parentSeqNum,
ServerName sn,
int regionReplication)
Merge regions into one in an atomic operation.
|
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.
Construct 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 . |
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)
Returns A deserialized
RegionInfo |
static RegionInfo |
RegionInfo.parseFrom(byte[] bytes,
int offset,
int len)
Parse a serialized representation of
RegionInfo |
static RegionInfo |
RegionInfo.parseFrom(DataInputStream in)
Parses an RegionInfo instance from the passed in stream.
|
static RegionInfo |
RegionInfo.parseFromOrNull(byte[] bytes)
Returns A deserialized
RegionInfo or null if we failed deserialize or passed bytes null |
static RegionInfo |
RegionInfo.parseFromOrNull(byte[] bytes,
int offset,
int len)
Returns A deserialized
RegionInfo or null if we failed deserialize or passed bytes null |
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)
|
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; i.e.
|
void |
MetaCache.clearCache(RegionInfo hri)
Deletes the cached location of the region if necessary, based on some error from source.
Synchronized because of calls in cacheLocation which need to be executed atomically |
default int |
RegionInfo.compareTo(RegionInfo other) |
static byte[] |
RegionInfoDisplay.getEndKeyForDisplay(RegionInfo ri,
org.apache.hadoop.conf.Configuration conf)
Get the end key for display.
|
ServiceCaller<S,R> |
NoopPartialResultCoprocessorCallback.getNextCallable(R response,
RegionInfo region) |
ServiceCaller<S,R> |
AsyncTable.PartialResultCoprocessorCallback.getNextCallable(R response,
RegionInfo region)
Subclasses should implement this to tell AsyncTable whether the given response is "final" or
whether the AsyncTable should send another request to the coprocessor to fetch more results
from the given region.
|
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)
Returns a String of short, printable names for
hris (usually encoded name) for us
logging. |
static byte[] |
RegionInfoDisplay.getStartKeyForDisplay(RegionInfo ri,
org.apache.hadoop.conf.Configuration conf)
Get the start key for display.
|
Duration |
NoopPartialResultCoprocessorCallback.getWaitInterval(R response,
RegionInfo region) |
Duration |
AsyncTable.PartialResultCoprocessorCallback.getWaitInterval(R response,
RegionInfo region)
Subclasses should implement this such that, when the above method returns non-null, this
method returns the duration that AsyncTable should wait before sending the next request to
the given region.
|
default boolean |
RegionInfo.isAdjacent(RegionInfo other)
Returns True if region is adjacent, either just before or just after this one.
|
static boolean |
RegionReplicaUtil.isDefaultReplica(RegionInfo hri)
Returns true if this region is a default replica for the region
|
default boolean |
RegionInfo.isNext(RegionInfo after)
Returns True if region is next, adjacent but 'after' this one.
|
default boolean |
RegionInfo.isOverlap(RegionInfo other)
Returns True if an overlap in region range.
|
static boolean |
RegionReplicaUtil.isReplicasForSameRegion(RegionInfo regionInfoA,
RegionInfo regionInfoB) |
static RegionInfoBuilder |
RegionInfoBuilder.newBuilder(RegionInfo regionInfo) |
void |
NoopPartialResultCoprocessorCallback.onRegionComplete(RegionInfo region,
R resp) |
void |
AsyncTable.CoprocessorCallback.onRegionComplete(RegionInfo region,
R resp)
Indicate that the respose of a region is available
|
void |
NoopPartialResultCoprocessorCallback.onRegionError(RegionInfo region,
Throwable error) |
void |
AsyncTable.CoprocessorCallback.onRegionError(RegionInfo region,
Throwable error)
Indicate that the error for a region is available
|
static byte[] |
RegionInfo.toByteArray(RegionInfo ri)
Returns This instance serialized as protobuf w/ a magic pb prefix.
|
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)
Returns a String of short, printable names for
hris (usually encoded name) for us
logging. |
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 |
HBaseRpcControllerImpl.getRegionInfo() |
default RegionInfo |
HBaseRpcController.getRegionInfo()
Returns Target Region's RegionInfo or null if not available or pertinent.
|
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–2020 The Apache Software Foundation. All rights reserved.