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 | |
org.apache.hadoop.hbase.zookeeper |
Modifier and Type | Field and Description |
---|---|
static HRegionInfo |
HRegionInfo.FIRST_META_REGIONINFO
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)
Convert a RegionInfo to a HRegionInfo
|
static HRegionInfo |
MetaTableAccessor.getClosestRegionInfo(Connection connection,
TableName tableName,
byte[] row) |
static HRegionInfo |
MetaTableAccessor.getHRegionInfo(Result data)
Returns HRegionInfo object from the column
HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog
table Result.
|
HRegionInfo |
HRegionLocation.getRegionInfo() |
static HRegionInfo |
HRegionInfo.parseFrom(byte[] bytes) |
static HRegionInfo |
HRegionInfo.parseFrom(byte[] bytes,
int offset,
int len) |
static HRegionInfo |
HRegionInfo.parseFrom(DataInputStream in)
Parses an HRegionInfo instance from the passed in stream.
|
static HRegionInfo |
HRegionInfo.parseFromOrNull(byte[] bytes) |
static HRegionInfo |
HRegionInfo.parseFromOrNull(byte[] bytes,
int offset,
int len) |
static HRegionInfo |
MetaTableAccessor.parseRegionInfoFromRegionName(byte[] regionName)
Returns an HRI parsed from this regionName.
|
Modifier and Type | Method and Description |
---|---|
static NavigableMap<HRegionInfo,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<HRegionInfo> |
MetaTableAccessor.getAllRegions(Connection connection,
boolean excludeOfflinedSplitParents)
Lists all of the regions currently in META.
|
static PairOfSameType<HRegionInfo> |
MetaTableAccessor.getDaughterRegions(Result data)
Returns the daughter regions by reading the corresponding columns of the catalog table
Result.
|
static PairOfSameType<HRegionInfo> |
MetaTableAccessor.getMergeRegions(Result data)
Returns the merge regions by reading the corresponding columns of the catalog table
Result.
|
static Pair<HRegionInfo,ServerName> |
MetaTableAccessor.getRegion(Connection connection,
byte[] regionName)
Deprecated.
|
static Pair<HRegionInfo,HRegionInfo> |
MetaTableAccessor.getRegionsFromMergeQualifier(Connection connection,
byte[] regionName)
Get regions from the merge qualifier of the specified merged region
|
static Pair<HRegionInfo,HRegionInfo> |
MetaTableAccessor.getRegionsFromMergeQualifier(Connection connection,
byte[] regionName)
Get regions from the merge qualifier of the specified merged region
|
static NavigableMap<HRegionInfo,Result> |
MetaTableAccessor.getServerUserRegions(Connection connection,
ServerName serverName) |
static List<HRegionInfo> |
MetaTableAccessor.getTableRegions(Connection connection,
TableName tableName)
Gets all of the regions of the specified table.
|
static List<HRegionInfo> |
MetaTableAccessor.getTableRegions(Connection connection,
TableName tableName,
boolean excludeOfflinedSplitParents)
Gets all of the regions of the specified table.
|
static List<Pair<HRegionInfo,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<HRegionInfo,ServerName>> |
MetaTableAccessor.getTableRegionsAndLocations(Connection connection,
TableName tableName,
boolean excludeOfflinedSplitParents)
Do not use this method to get meta table regions, use methods in MetaTableLocator instead.
|
static List<HRegionInfo> |
HRegionInfo.parseDelimitedFrom(byte[] bytes,
int offset,
int length)
Parses all the HRegionInfo instances from the passed in stream until EOF.
|
Modifier and Type | Method and Description |
---|---|
static void |
MetaTableAccessor.addDaughter(Connection connection,
HRegionInfo regionInfo,
ServerName sn,
long openSeqNum)
Adds a daughter region entry to meta.
|
static Put |
MetaTableAccessor.addDaughtersToPut(Put put,
HRegionInfo splitA,
HRegionInfo splitB)
Adds split daughters to the Put
|
static Put |
MetaTableAccessor.addRegionInfo(Put p,
HRegionInfo hri) |
static void |
MetaTableAccessor.addRegionToMeta(Connection connection,
HRegionInfo regionInfo)
Adds a hbase:meta row for the specified new region.
|
static void |
MetaTableAccessor.addRegionToMeta(Connection connection,
HRegionInfo regionInfo,
HRegionInfo splitA,
HRegionInfo splitB)
Adds a (single) hbase:meta row for the specified new region and its daughters.
|
static void |
MetaTableAccessor.addRegionToMeta(Table meta,
HRegionInfo regionInfo)
Adds a hbase:meta row for the specified new region to the given catalog table.
|
static void |
MetaTableAccessor.addRegionToMeta(Table meta,
HRegionInfo regionInfo,
HRegionInfo splitA,
HRegionInfo splitB)
Adds a (single) hbase:meta row for the specified new region and its daughters.
|
static boolean |
HRegionInfo.areAdjacent(HRegionInfo regionA,
HRegionInfo regionB)
Check whether two regions are adjacent
|
int |
HRegionInfo.compareTo(HRegionInfo o) |
static org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionInfo |
HRegionInfo.convert(HRegionInfo info)
Convert a HRegionInfo to a RegionInfo
|
static void |
MetaTableAccessor.deleteMergeQualifiers(Connection connection,
HRegionInfo mergedRegion)
Deletes merge qualifiers for the specified merged region.
|
static void |
MetaTableAccessor.deleteRegion(Connection connection,
HRegionInfo regionInfo)
Deletes the specified region from META.
|
static byte[] |
HRegionInfo.getEndKeyForDisplay(HRegionInfo hri,
org.apache.hadoop.conf.Configuration conf)
Get the end key for display.
|
static byte[] |
MetaTableAccessor.getMetaKeyForRegion(HRegionInfo regionInfo)
Returns the row key to use for this regionInfo
|
static HRegionLocation |
MetaTableAccessor.getRegionLocation(Connection connection,
HRegionInfo regionInfo)
Returns the HRegionLocation from meta for the given region
|
static String |
HRegionInfo.getRegionNameAsStringForDisplay(HRegionInfo hri,
org.apache.hadoop.conf.Configuration conf)
Get the region name for display.
|
static byte[] |
HRegionInfo.getRegionNameForDisplay(HRegionInfo hri,
org.apache.hadoop.conf.Configuration conf)
Get the region name for display.
|
static String |
HRegionInfo.getShortNameToLog(HRegionInfo... hris) |
static byte[] |
HRegionInfo.getStartKeyForDisplay(HRegionInfo hri,
org.apache.hadoop.conf.Configuration conf)
Get the start key for display.
|
static Delete |
MetaTableAccessor.makeDeleteFromRegionInfo(HRegionInfo regionInfo)
Generates and returns a Delete containing the region info for the catalog
table
|
static Delete |
MetaTableAccessor.makeDeleteFromRegionInfo(HRegionInfo regionInfo,
long ts)
Generates and returns a Delete containing the region info for the catalog
table
|
static Put |
MetaTableAccessor.makePutFromRegionInfo(HRegionInfo regionInfo)
Generates and returns a Put containing the region into for the catalog table
|
static Put |
MetaTableAccessor.makePutFromRegionInfo(HRegionInfo regionInfo,
long ts)
Generates and returns a Put containing the region into for the catalog table
|
static void |
MetaTableAccessor.mergeRegions(Connection connection,
HRegionInfo mergedRegion,
HRegionInfo regionA,
HRegionInfo regionB,
ServerName sn,
int regionReplication,
long masterSystemTime,
boolean saveBarrier)
Merge the two regions into one in an atomic operation.
|
static void |
MetaTableAccessor.splitRegion(Connection connection,
HRegionInfo parent,
HRegionInfo splitA,
HRegionInfo splitB,
ServerName sn,
int regionReplication,
boolean saveBarrier)
Splits the region into two in an atomic operation.
|
static byte[] |
HRegionInfo.toDelimitedByteArray(HRegionInfo... infos)
Serializes given HRegionInfo's as a byte array.
|
static void |
MetaTableAccessor.updateRegionLocation(Connection connection,
HRegionInfo 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<HRegionInfo> regionInfos,
int regionReplication)
Adds a hbase:meta row for each of the specified new regions.
|
static void |
MetaTableAccessor.addRegionsToMeta(Connection connection,
List<HRegionInfo> regionInfos,
int regionReplication,
long ts)
Adds a hbase:meta row for each of the specified new regions.
|
static void |
MetaTableAccessor.deleteRegions(Connection connection,
List<HRegionInfo> regionsInfo)
Deletes the specified regions from META.
|
static void |
MetaTableAccessor.deleteRegions(Connection connection,
List<HRegionInfo> regionsInfo,
long ts)
Deletes the specified regions from META.
|
static String |
HRegionInfo.getShortNameToLog(List<HRegionInfo> hris) |
static void |
MetaTableAccessor.mutateRegions(Connection connection,
List<HRegionInfo> regionsToRemove,
List<HRegionInfo> regionsToAdd)
Adds and Removes the specified regions from hbase:meta
|
static void |
MetaTableAccessor.mutateRegions(Connection connection,
List<HRegionInfo> regionsToRemove,
List<HRegionInfo> regionsToAdd)
Adds and Removes the specified regions from hbase:meta
|
static void |
MetaTableAccessor.overwriteRegions(Connection connection,
List<HRegionInfo> regionInfos,
int regionReplication)
Overwrites the specified regions from hbase:meta
|
Constructor and Description |
---|
HRegionInfo(HRegionInfo other)
Costruct a copy of another HRegionInfo
|
HRegionInfo(HRegionInfo other,
int replicaId) |
HRegionLocation(HRegionInfo regionInfo,
ServerName serverName) |
HRegionLocation(HRegionInfo regionInfo,
ServerName serverName,
long seqNum) |
Modifier and Type | Field and Description |
---|---|
protected HRegionInfo |
ClientScanner.currentRegion |
Modifier and Type | Method and Description |
---|---|
HRegionInfo |
ScannerCallable.getHRegionInfo() |
HRegionInfo |
RegionServerCallable.getHRegionInfo() |
static HRegionInfo |
RegionReplicaUtil.getRegionInfoForDefaultReplica(HRegionInfo regionInfo)
Returns the HRegionInfo for the default replicaId (0).
|
static HRegionInfo |
RegionReplicaUtil.getRegionInfoForReplica(HRegionInfo regionInfo,
int replicaId)
Returns the HRegionInfo for the given replicaId.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<List<HRegionInfo>> |
RawAsyncHBaseAdmin.getOnlineRegions(ServerName serverName) |
List<HRegionInfo> |
HBaseAdmin.getOnlineRegions(ServerName sn) |
CompletableFuture<List<HRegionInfo>> |
AsyncHBaseAdmin.getOnlineRegions(ServerName serverName) |
CompletableFuture<List<HRegionInfo>> |
AsyncAdmin.getOnlineRegions(ServerName serverName)
Get all the online regions on a region server.
|
List<HRegionInfo> |
Admin.getOnlineRegions(ServerName sn)
Get all the online regions on a region server.
|
CompletableFuture<List<HRegionInfo>> |
RawAsyncHBaseAdmin.getTableRegions(TableName tableName) |
List<HRegionInfo> |
HBaseAdmin.getTableRegions(TableName tableName) |
CompletableFuture<List<HRegionInfo>> |
AsyncHBaseAdmin.getTableRegions(TableName tableName) |
CompletableFuture<List<HRegionInfo>> |
AsyncAdmin.getTableRegions(TableName tableName)
Get the regions of a given table.
|
List<HRegionInfo> |
Admin.getTableRegions(TableName tableName)
Get the regions of a given table.
|
Modifier and Type | Method and Description |
---|---|
void |
MetaCache.clearCache(HRegionInfo hri)
Deletes the cached location of the region if necessary, based on some error from source.
|
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) . |
static HRegionInfo |
RegionReplicaUtil.getRegionInfoForDefaultReplica(HRegionInfo regionInfo)
Returns the HRegionInfo for the default replicaId (0).
|
static HRegionInfo |
RegionReplicaUtil.getRegionInfoForReplica(HRegionInfo regionInfo,
int replicaId)
Returns the HRegionInfo for the given replicaId.
|
static boolean |
RegionReplicaUtil.isDefaultReplica(HRegionInfo hri) |
static boolean |
RegionReplicaUtil.isReplicasForSameRegion(HRegionInfo regionInfoA,
HRegionInfo regionInfoB) |
void |
RawAsyncTable.CoprocessorCallback.onRegionComplete(HRegionInfo region,
R resp) |
void |
RawAsyncTable.CoprocessorCallback.onRegionError(HRegionInfo region,
Throwable error) |
Modifier and Type | Method and Description |
---|---|
static void |
RegionReplicaUtil.removeNonDefaultRegions(Collection<HRegionInfo> regions)
Removes the non-default replicas from the passed regions collection
|
Constructor and Description |
---|
FlushRegionCallable(ClusterConnection connection,
RpcControllerFactory rpcControllerFactory,
HRegionInfo regionInfo,
boolean writeFlushWalMarker) |
Modifier and Type | Method and Description |
---|---|
HRegionInfo |
RegionState.getRegion() |
Constructor and Description |
---|
RegionState(HRegionInfo region,
RegionState.State state) |
RegionState(HRegionInfo region,
RegionState.State state,
long stamp,
ServerName serverName) |
RegionState(HRegionInfo region,
RegionState.State state,
long stamp,
ServerName serverName,
long ritDuration) |
RegionState(HRegionInfo region,
RegionState.State state,
ServerName serverName) |
Modifier and Type | Method and Description |
---|---|
static HRegionInfo |
ProtobufUtil.getRegionInfo(org.apache.hadoop.hbase.shaded.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.
|
Modifier and Type | Method and Description |
---|---|
static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetOnlineRegionResponse |
ResponseConverter.buildGetOnlineRegionResponse(List<HRegionInfo> regions)
A utility to build a GetOnlineRegionResponse.
|
static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.OpenRegionRequest |
RequestConverter.buildOpenRegionRequest(ServerName server,
List<Pair<HRegionInfo,List<ServerName>>> regionOpenInfos,
Boolean openForReplay)
Create a protocol buffer OpenRegionRequest to open a list of regions
|
static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest |
RequestConverter.buildUpdateFavoredNodesRequest(List<Pair<HRegionInfo,List<ServerName>>> updateRegionInfos)
Create a protocol buffer UpdateFavoredNodesRequest to update a list of favorednode mappings
|
Modifier and Type | Method and Description |
---|---|
List<HRegionInfo> |
MetaTableLocator.getMetaRegions(ZooKeeperWatcher zkw) |
List<HRegionInfo> |
MetaTableLocator.getMetaRegions(ZooKeeperWatcher zkw,
int replicaId) |
List<Pair<HRegionInfo,ServerName>> |
MetaTableLocator.getMetaRegionsAndLocations(ZooKeeperWatcher zkw) |
List<Pair<HRegionInfo,ServerName>> |
MetaTableLocator.getMetaRegionsAndLocations(ZooKeeperWatcher zkw,
int replicaId) |
Copyright © 2007–2017 The Apache Software Foundation. All rights reserved.