|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Packages that use HRegionInfo | |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.catalog | |
org.apache.hadoop.hbase.client | Provides HBase Client |
org.apache.hadoop.hbase.master | |
org.apache.hadoop.hbase.protobuf | Holds classes generated from protobuf
src/main/protobuf definition files. |
org.apache.hadoop.hbase.zookeeper |
Uses of HRegionInfo in org.apache.hadoop.hbase |
---|
Fields in org.apache.hadoop.hbase declared as HRegionInfo | |
---|---|
static HRegionInfo |
HRegionInfo.FIRST_META_REGIONINFO
HRegionInfo for first meta region |
Methods in org.apache.hadoop.hbase that return HRegionInfo | |
---|---|
static HRegionInfo |
HRegionInfo.convert(HBaseProtos.RegionInfo proto)
Convert a RegionInfo to a HRegionInfo |
static HRegionInfo |
HRegionInfo.getHRegionInfo(Result data)
Returns HRegionInfo object from the column HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog table Result. |
static HRegionInfo |
HRegionInfo.getHRegionInfo(Result r,
byte[] qualifier)
Returns the HRegionInfo object from the column HConstants.CATALOG_FAMILY and
qualifier of the catalog table result. |
HRegionInfo |
HRegionLocation.getRegionInfo()
|
static HRegionInfo |
HRegionInfo.parseFrom(byte[] bytes)
|
static HRegionInfo |
HRegionInfo.parseFrom(DataInputStream in)
Parses an HRegionInfo instance from the passed in stream. |
static HRegionInfo |
HRegionInfo.parseFromOrNull(byte[] bytes)
|
Methods in org.apache.hadoop.hbase that return types with arguments of type HRegionInfo | |
---|---|
static PairOfSameType<HRegionInfo> |
HRegionInfo.getDaughterRegions(Result data)
Returns the daughter regions by reading the corresponding columns of the catalog table Result. |
static Pair<HRegionInfo,ServerName> |
HRegionInfo.getHRegionInfoAndServerName(Result r)
Extract a HRegionInfo and ServerName from catalog table Result . |
static List<HRegionInfo> |
HRegionInfo.parseDelimitedFrom(byte[] bytes,
int offset,
int length)
Parses all the HRegionInfo instances from the passed in stream until EOF. |
Methods in org.apache.hadoop.hbase with parameters of type HRegionInfo | |
---|---|
static boolean |
HRegionInfo.areAdjacent(HRegionInfo regionA,
HRegionInfo regionB)
Check whether two regions are adjacent |
int |
HRegionInfo.compareTo(HRegionInfo o)
|
static HBaseProtos.RegionInfo |
HRegionInfo.convert(HRegionInfo info)
Convert a HRegionInfo to a RegionInfo |
static byte[] |
HRegionInfo.toDelimitedByteArray(HRegionInfo... infos)
Serializes given HRegionInfo's as a byte array. |
Constructors in org.apache.hadoop.hbase with parameters of type HRegionInfo | |
---|---|
HRegionInfo(HRegionInfo other)
Costruct a copy of another HRegionInfo |
|
HRegionLocation(HRegionInfo regionInfo,
ServerName serverName)
|
|
HRegionLocation(HRegionInfo regionInfo,
ServerName serverName,
long seqNum)
|
Uses of HRegionInfo in org.apache.hadoop.hbase.catalog |
---|
Methods in org.apache.hadoop.hbase.catalog that return types with arguments of type HRegionInfo | |
---|---|
static Map<HRegionInfo,ServerName> |
MetaReader.fullScan(CatalogTracker catalogTracker,
Set<TableName> disabledTables)
Performs a full scan of hbase:meta , skipping regions from any
tables in the specified set of disabled tables. |
static Map<HRegionInfo,ServerName> |
MetaReader.fullScan(CatalogTracker catalogTracker,
Set<TableName> disabledTables,
boolean excludeOfflinedSplitParents)
Performs a full scan of hbase:meta , skipping regions from any
tables in the specified set of disabled tables. |
static Pair<HRegionInfo,ServerName> |
MetaReader.getRegion(CatalogTracker catalogTracker,
byte[] regionName)
Gets the region info and assignment for the specified region. |
static Pair<HRegionInfo,HRegionInfo> |
MetaReader.getRegionsFromMergeQualifier(CatalogTracker catalogTracker,
byte[] regionName)
Get regions from the merge qualifier of the specified merged region |
static Pair<HRegionInfo,HRegionInfo> |
MetaReader.getRegionsFromMergeQualifier(CatalogTracker catalogTracker,
byte[] regionName)
Get regions from the merge qualifier of the specified merged region |
static NavigableMap<HRegionInfo,Result> |
MetaReader.getServerUserRegions(CatalogTracker catalogTracker,
ServerName serverName)
|
static List<HRegionInfo> |
MetaReader.getTableRegions(CatalogTracker catalogTracker,
TableName tableName)
Gets all of the regions of the specified table. |
static List<HRegionInfo> |
MetaReader.getTableRegions(CatalogTracker catalogTracker,
TableName tableName,
boolean excludeOfflinedSplitParents)
Gets all of the regions of the specified table. |
static List<Pair<HRegionInfo,ServerName>> |
MetaReader.getTableRegionsAndLocations(CatalogTracker catalogTracker,
TableName tableName)
|
static List<Pair<HRegionInfo,ServerName>> |
MetaReader.getTableRegionsAndLocations(CatalogTracker catalogTracker,
TableName tableName,
boolean excludeOfflinedSplitParents)
|
Uses of HRegionInfo in org.apache.hadoop.hbase.client |
---|
Fields in org.apache.hadoop.hbase.client declared as HRegionInfo | |
---|---|
protected HRegionInfo |
ClientScanner.currentRegion
|
Methods in org.apache.hadoop.hbase.client that return HRegionInfo | |
---|---|
HRegionInfo |
ScannerCallable.getHRegionInfo()
|
HRegionInfo |
RegionServerCallable.getHRegionInfo()
|
static HRegionInfo |
MetaScanner.getHRegionInfo(Result data)
Returns HRegionInfo object from the column HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog table Result. |
Methods in org.apache.hadoop.hbase.client that return types with arguments of type HRegionInfo | |
---|---|
static NavigableMap<HRegionInfo,ServerName> |
MetaScanner.allTableRegions(org.apache.hadoop.conf.Configuration conf,
HConnection connection,
TableName tableName,
boolean offlined)
Lists all of the table regions currently in META. |
List<HRegionInfo> |
HBaseAdmin.getOnlineRegions(ServerName sn)
Get all the online regions on a region server. |
NavigableMap<HRegionInfo,ServerName> |
HTable.getRegionLocations()
Gets all the regions and their address for this table. |
List<HRegionInfo> |
HBaseAdmin.getTableRegions(byte[] tableName)
|
List<HRegionInfo> |
HBaseAdmin.getTableRegions(TableName tableName)
get the regions of a given table. |
static List<HRegionInfo> |
MetaScanner.listAllRegions(org.apache.hadoop.conf.Configuration conf,
boolean offlined)
Used in tests. |
Methods in org.apache.hadoop.hbase.client with parameters of type HRegionInfo | |
---|---|
void |
HBaseAdmin.closeRegion(ServerName sn,
HRegionInfo hri)
Close a region. |
Uses of HRegionInfo in org.apache.hadoop.hbase.master |
---|
Methods in org.apache.hadoop.hbase.master that return HRegionInfo | |
---|---|
HRegionInfo |
RegionState.getRegion()
|
Constructors in org.apache.hadoop.hbase.master with parameters of type HRegionInfo | |
---|---|
RegionState(HRegionInfo region,
RegionState.State state)
|
|
RegionState(HRegionInfo region,
RegionState.State state,
long stamp,
ServerName serverName)
|
Uses of HRegionInfo in org.apache.hadoop.hbase.protobuf |
---|
Methods in org.apache.hadoop.hbase.protobuf that return HRegionInfo | |
---|---|
static HRegionInfo |
ProtobufUtil.getRegionInfo(AdminProtos.AdminService.BlockingInterface admin,
byte[] regionName)
A helper to retrieve region info given a region name using admin protocol. |
Methods in org.apache.hadoop.hbase.protobuf that return types with arguments of type HRegionInfo | |
---|---|
static List<HRegionInfo> |
ProtobufUtil.getOnlineRegions(AdminProtos.AdminService.BlockingInterface admin)
A helper to get the all the online regions on a region server using admin protocol. |
static List<HRegionInfo> |
ResponseConverter.getRegionInfos(AdminProtos.GetOnlineRegionResponse proto)
Get the list of region info from a GetOnlineRegionResponse |
Methods in org.apache.hadoop.hbase.protobuf with parameters of type HRegionInfo | |
---|---|
static AdminProtos.OpenRegionRequest |
RequestConverter.buildOpenRegionRequest(HRegionInfo region,
int versionOfOfflineNode,
List<ServerName> favoredNodes)
Create a protocol buffer OpenRegionRequest for a given region |
static void |
ProtobufUtil.mergeRegions(AdminProtos.AdminService.BlockingInterface admin,
HRegionInfo region_a,
HRegionInfo region_b,
boolean forcible)
A helper to merge regions using admin protocol. |
static void |
ProtobufUtil.openRegion(AdminProtos.AdminService.BlockingInterface admin,
HRegionInfo region)
A helper to open a region using admin protocol. |
static void |
ProtobufUtil.split(AdminProtos.AdminService.BlockingInterface admin,
HRegionInfo hri,
byte[] splitPoint)
A helper to split a region using admin protocol. |
static WALProtos.CompactionDescriptor |
ProtobufUtil.toCompactionDescriptor(HRegionInfo info,
byte[] family,
List<org.apache.hadoop.fs.Path> inputPaths,
List<org.apache.hadoop.fs.Path> outputPaths,
org.apache.hadoop.fs.Path storeDir)
|
Method parameters in org.apache.hadoop.hbase.protobuf with type arguments of type HRegionInfo | |
---|---|
static AdminProtos.GetOnlineRegionResponse |
ResponseConverter.buildGetOnlineRegionResponse(List<HRegionInfo> regions)
A utility to build a GetOnlineRegionResponse. |
static AdminProtos.OpenRegionRequest |
RequestConverter.buildOpenRegionRequest(List<Triple<HRegionInfo,Integer,List<ServerName>>> regionOpenInfos)
Create a protocol buffer OpenRegionRequest to open a list of regions |
static AdminProtos.UpdateFavoredNodesRequest |
RequestConverter.buildUpdateFavoredNodesRequest(List<Pair<HRegionInfo,List<ServerName>>> updateRegionInfos)
Create a protocol buffer UpdateFavoredNodesRequest to update a list of favorednode mappings |
Uses of HRegionInfo in org.apache.hadoop.hbase.zookeeper |
---|
Methods in org.apache.hadoop.hbase.zookeeper with parameters of type HRegionInfo | |
---|---|
static void |
ZKAssign.asyncCreateNodeOffline(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
org.apache.zookeeper.AsyncCallback.StringCallback cb,
Object ctx)
Creates an unassigned node in the OFFLINE state for the specified region. |
static boolean |
ZKAssign.checkClosingState(ZooKeeperWatcher zkw,
HRegionInfo region,
int expectedVersion)
|
static int |
ZKAssign.createNodeClosing(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName)
Creates a new unassigned node in the CLOSING state for the specified region. |
static void |
ZKAssign.createNodeOffline(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName)
Creates a new unassigned node in the OFFLINE state for the specified region. |
static void |
ZKAssign.createNodeOffline(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
EventType event)
|
static int |
ZKAssign.createOrForceNodeOffline(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName)
Creates or force updates an unassigned node to the OFFLINE state for the specified region. |
static boolean |
ZKAssign.deleteClosingNode(ZooKeeperWatcher zkw,
HRegionInfo region)
Deletes an existing unassigned node that is in the CLOSING state for the specified region. |
static void |
ZKAssign.deleteNodeFailSilent(ZooKeeperWatcher watcher,
HRegionInfo regionInfo)
Delete the assignment node regardless of its current state. |
static int |
ZKAssign.getVersion(ZooKeeperWatcher zkw,
HRegionInfo region)
Get the version of the specified znode |
static int |
ZKAssign.retransitionNodeOpening(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
int expectedVersion,
boolean updateZNode)
Retransitions an existing unassigned node for the specified region which is currently in the OPENING state to be in the OPENING state. |
static int |
ZKAssign.transitionNode(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
EventType beginState,
EventType endState,
int expectedVersion)
Method that actually performs unassigned node transitions. |
static int |
ZKAssign.transitionNode(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
EventType beginState,
EventType endState,
int expectedVersion,
byte[] payload)
|
static int |
ZKAssign.transitionNodeClosed(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
int expectedVersion)
Transitions an existing unassigned node for the specified region which is currently in the CLOSING state to be in the CLOSED state. |
static int |
ZKAssign.transitionNodeOpened(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
int expectedVersion)
Transitions an existing unassigned node for the specified region which is currently in the OPENING state to be in the OPENED state. |
static int |
ZKAssign.transitionNodeOpening(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName)
Transitions an existing unassigned node for the specified region which is currently in the OFFLINE state to be in the OPENING state. |
static int |
ZKAssign.transitionNodeOpening(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
EventType beginState)
|
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |