Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.client.backoff | |
org.apache.hadoop.hbase.exceptions | |
org.apache.hadoop.hbase.ipc | |
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 |
Modifier and Type | Field and Description |
---|---|
static List<ServerName> |
ServerName.EMPTY_SERVER_LIST |
Modifier and Type | Method and Description |
---|---|
ServerName |
ClusterStatus.getMaster()
Returns detailed information about the current master
ServerName . |
ServerName |
RegionTransition.getServerName() |
ServerName |
HRegionLocation.getServerName() |
static ServerName |
HRegionInfo.getServerName(Result r)
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
|
static ServerName |
ServerName.parseFrom(byte[] data)
Get a ServerName from the passed in data bytes.
|
static ServerName |
ServerName.parseServerName(String str) |
static ServerName |
ServerName.parseVersionedServerName(byte[] versionedBytes)
Use this method instantiating a
ServerName from bytes
gotten from a call to getVersionedBytes() . |
static ServerName |
ServerName.valueOf(String serverName)
Retrieve an instance of ServerName.
|
static ServerName |
ServerName.valueOf(String hostname,
int port,
long startcode)
Retrieve an instance of ServerName.
|
static ServerName |
ServerName.valueOf(String hostAndPort,
long startCode)
Retrieve an instance of ServerName.
|
Modifier and Type | Method and Description |
---|---|
Collection<ServerName> |
ClusterStatus.getBackupMasters() |
Collection<ServerName> |
ClusterStatus.getDeadServerNames() |
static Pair<HRegionInfo,ServerName> |
HRegionInfo.getHRegionInfoAndServerName(Result r)
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
|
static Pair<HRegionInfo,ServerName> |
MetaTableAccessor.getRegion(Connection connection,
byte[] regionName)
Deprecated.
|
Collection<ServerName> |
ClusterStatus.getServerInfo()
Deprecated.
|
Collection<ServerName> |
ClusterStatus.getServers() |
static List<Pair<HRegionInfo,ServerName>> |
MetaTableAccessor.getTableRegionsAndLocations(ZooKeeperWatcher zkw,
Connection connection,
TableName tableName) |
static List<Pair<HRegionInfo,ServerName>> |
MetaTableAccessor.getTableRegionsAndLocations(ZooKeeperWatcher zkw,
Connection connection,
TableName tableName,
boolean excludeOfflinedSplitParents) |
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.addLocation(Put p,
ServerName sn,
long openSeqNum,
int replicaId) |
int |
ServerName.compareTo(ServerName other) |
static RegionTransition |
RegionTransition.createRegionTransition(EventType type,
byte[] regionName,
ServerName sn) |
static RegionTransition |
RegionTransition.createRegionTransition(EventType type,
byte[] regionName,
ServerName sn,
byte[] payload) |
ServerLoad |
ClusterStatus.getLoad(ServerName sn) |
static NavigableMap<HRegionInfo,Result> |
MetaTableAccessor.getServerUserRegions(Connection connection,
ServerName serverName) |
static boolean |
ServerName.isSameHostnameAndPort(ServerName left,
ServerName right) |
static void |
MetaTableAccessor.mergeRegions(Connection connection,
HRegionInfo mergedRegion,
HRegionInfo regionA,
HRegionInfo regionB,
ServerName sn)
Merge the two regions into one in an atomic operation.
|
RegionLocations |
RegionLocations.removeByServer(ServerName serverName)
Returns a new RegionLocations with the locations removed (set to null)
which have the destination server as given.
|
static void |
MetaTableAccessor.splitRegion(Connection connection,
HRegionInfo parent,
HRegionInfo splitA,
HRegionInfo splitB,
ServerName sn)
Splits the region into two in an atomic operation.
|
static void |
MetaTableAccessor.updateRegionLocation(Connection connection,
HRegionInfo regionInfo,
ServerName sn,
long updateSeqNum)
Updates the location of the specified region in hbase:meta to be the specified
server hostname and startcode.
|
Constructor and Description |
---|
ClusterStatus(String hbaseVersion,
String clusterid,
Map<ServerName,ServerLoad> servers,
Collection<ServerName> deadServers,
ServerName master,
Collection<ServerName> backupMasters,
Map<String,RegionState> rit,
String[] masterCoprocessors,
Boolean balancerOn) |
HRegionLocation(HRegionInfo regionInfo,
ServerName serverName) |
HRegionLocation(HRegionInfo regionInfo,
ServerName serverName,
long seqNum) |
Constructor and Description |
---|
ClusterStatus(String hbaseVersion,
String clusterid,
Map<ServerName,ServerLoad> servers,
Collection<ServerName> deadServers,
ServerName master,
Collection<ServerName> backupMasters,
Map<String,RegionState> rit,
String[] masterCoprocessors,
Boolean balancerOn) |
ClusterStatus(String hbaseVersion,
String clusterid,
Map<ServerName,ServerLoad> servers,
Collection<ServerName> deadServers,
ServerName master,
Collection<ServerName> backupMasters,
Map<String,RegionState> rit,
String[] masterCoprocessors,
Boolean balancerOn) |
ClusterStatus(String hbaseVersion,
String clusterid,
Map<ServerName,ServerLoad> servers,
Collection<ServerName> deadServers,
ServerName master,
Collection<ServerName> backupMasters,
Map<String,RegionState> rit,
String[] masterCoprocessors,
Boolean balancerOn) |
Modifier and Type | Method and Description |
---|---|
static NavigableMap<HRegionInfo,ServerName> |
MetaScanner.allTableRegions(org.apache.hadoop.conf.Configuration conf,
Connection connection,
TableName tableName,
boolean offlined)
Deprecated.
|
static NavigableMap<HRegionInfo,ServerName> |
MetaScanner.allTableRegions(Connection connection,
TableName tableName)
Lists all of the table regions currently in META.
|
NavigableMap<HRegionInfo,ServerName> |
HTable.getRegionLocations()
Deprecated.
This is no longer a public API. Use
HTable.getAllRegionLocations() instead. |
Modifier and Type | Method and Description |
---|---|
void |
MetaCache.cacheLocation(TableName tableName,
ServerName source,
HRegionLocation location)
Put a newly discovered HRegionLocation into the cache.
|
void |
MetaCache.clearCache(ServerName serverName)
Delete all cached entries of a server.
|
void |
MetaCache.clearCache(TableName tableName,
byte[] row,
ServerName serverName)
Delete a cached location for a table, row and server
|
void |
HConnection.clearCaches(ServerName sn)
Deprecated.
internal method, do not use thru HConnection
|
void |
ClusterConnection.clearCaches(ServerName sn)
Clear any caches that pertain to server name
sn . |
void |
HBaseAdmin.closeRegion(ServerName sn,
HRegionInfo hri)
Close a region.
|
void |
Admin.closeRegion(ServerName sn,
HRegionInfo hri)
Close a region.
|
void |
HBaseAdmin.compactRegionServer(ServerName sn,
boolean major)
Compact all regions on the region server
|
void |
Admin.compactRegionServer(ServerName sn,
boolean major)
Compact all regions on the region server
|
CoprocessorRpcChannel |
HBaseAdmin.coprocessorService(ServerName sn)
Creates and returns a
RpcChannel instance
connected to the passed region server. |
CoprocessorRpcChannel |
Admin.coprocessorService(ServerName sn)
Creates and returns a
RpcChannel instance
connected to the passed region server. |
static ClusterConnection |
ConnectionUtils.createShortCircuitHConnection(Connection conn,
ServerName serverName,
AdminProtos.AdminService.BlockingInterface admin,
ClientProtos.ClientService.BlockingInterface client)
Adapt a HConnection so that it can bypass the RPC layer (serialization,
deserialization, networking, etc..) -- i.e.
|
AdminProtos.AdminService.BlockingInterface |
HConnection.getAdmin(ServerName serverName)
Deprecated.
internal method, do not use thru HConnection
|
AdminProtos.AdminService.BlockingInterface |
ClusterConnection.getAdmin(ServerName serverName)
Establishes a connection to the region server at the specified address.
|
AdminProtos.AdminService.BlockingInterface |
HConnection.getAdmin(ServerName serverName,
boolean getMaster)
Deprecated.
You can pass master flag but nothing special is done.
|
ClientProtos.ClientService.BlockingInterface |
HConnection.getClient(ServerName serverName)
Deprecated.
internal method, do not use thru HConnection
|
ClientProtos.ClientService.BlockingInterface |
ClusterConnection.getClient(ServerName serverName)
Establishes a connection to the region server at the specified address, and returns
a region client protocol.
|
List<HRegionInfo> |
HBaseAdmin.getOnlineRegions(ServerName sn)
Get all the online regions on a region server.
|
List<HRegionInfo> |
Admin.getOnlineRegions(ServerName sn)
Get all the online regions on a region server.
|
ServerStatistics |
ServerStatisticTracker.getStats(ServerName server) |
boolean |
HConnection.isDeadServer(ServerName serverName)
Deprecated.
internal method, do not use thru HConnection
|
boolean |
ClusterConnection.isDeadServer(ServerName serverName)
Deprecated.
internal method, do not use thru HConnection
|
void |
HBaseAdmin.rollWALWriter(ServerName serverName) |
void |
Admin.rollWALWriter(ServerName serverName)
Roll the log writer.
|
void |
HConnection.updateCachedLocations(TableName tableName,
byte[] regionName,
byte[] rowkey,
Object exception,
ServerName source)
Deprecated.
internal method, do not use thru HConnection
|
void |
ClusterConnection.updateCachedLocations(TableName tableName,
byte[] regionName,
byte[] rowkey,
Object exception,
ServerName source)
Update the location cache.
|
void |
HBaseAdmin.updateConfiguration(ServerName server) |
void |
Admin.updateConfiguration(ServerName server)
Update the configuration and trigger an online config change
on the regionserver
|
void |
ServerStatisticTracker.updateRegionStats(ServerName server,
byte[] region,
ClientProtos.RegionLoadStats currentStats) |
static <T> T |
ResultStatsUtil.updateStats(T r,
ServerStatisticTracker serverStats,
ServerName server,
byte[] regionName)
Update the stats for the specified region if the result is an instance of
ResultStatsUtil |
Modifier and Type | Method and Description |
---|---|
long |
ExponentialClientBackoffPolicy.getBackoffTime(ServerName serverName,
byte[] region,
ServerStatistics stats) |
long |
ClientBackoffPolicyFactory.NoBackoffPolicy.getBackoffTime(ServerName serverName,
byte[] region,
ServerStatistics stats) |
long |
ClientBackoffPolicy.getBackoffTime(ServerName serverName,
byte[] region,
ServerStatistics stats) |
Modifier and Type | Method and Description |
---|---|
ServerName |
RegionMovedException.getServerName() |
Constructor and Description |
---|
PreemptiveFastFailException(long count,
long timeOfFirstFailureMilliSec,
long timeOfLatestAttemptMilliSec,
ServerName serverName) |
RegionMovedException(ServerName serverName,
long locationSeqNum) |
Modifier and Type | Method and Description |
---|---|
void |
RpcClientImpl.cancelConnections(ServerName sn)
Interrupt the connections to the given ip:port server.
|
void |
RpcClient.cancelConnections(ServerName sn)
Interrupt the connections to the given server.
|
BlockingRpcChannel |
RpcClient.createBlockingRpcChannel(ServerName sn,
User user,
int rpcTimeout)
Creates a "channel" that can be used by a blocking protobuf service.
|
BlockingRpcChannel |
AbstractRpcClient.createBlockingRpcChannel(ServerName sn,
User ticket,
int defaultOperationTimeout)
Creates a "channel" that can be used by a blocking protobuf service.
|
Constructor and Description |
---|
AbstractRpcClient.BlockingRpcChannelImplementation(AbstractRpcClient rpcClient,
ServerName sn,
User ticket,
int defaultOperationTimeout) |
RegionServerCoprocessorRpcChannel(ClusterConnection conn,
ServerName serverName) |
Modifier and Type | Method and Description |
---|---|
ServerName |
RegionState.getServerName() |
Modifier and Type | Method and Description |
---|---|
boolean |
RegionState.isOnServer(ServerName sn) |
boolean |
RegionState.isOpenOrMergingNewOnServer(ServerName sn) |
boolean |
RegionState.isOpenOrMergingOnServer(ServerName sn) |
boolean |
RegionState.isOpenOrSplittingNewOnServer(ServerName sn) |
boolean |
RegionState.isOpenOrSplittingOnServer(ServerName sn) |
boolean |
RegionState.isPendingCloseOrClosingOnServer(ServerName sn) |
boolean |
RegionState.isPendingOpenOrOpeningOnServer(ServerName sn) |
Constructor and Description |
---|
RegionState(HRegionInfo region,
RegionState.State state,
long stamp,
ServerName serverName) |
RegionState(HRegionInfo region,
RegionState.State state,
ServerName serverName) |
Modifier and Type | Method and Description |
---|---|
static ServerName |
ProtobufUtil.toServerName(HBaseProtos.ServerName proto)
Convert a protocol buffer ServerName to a ServerName
|
Modifier and Type | Method and Description |
---|---|
static AdminProtos.CloseRegionRequest |
RequestConverter.buildCloseRegionRequest(ServerName server,
byte[] regionName,
boolean transitionInZK)
Create a CloseRegionRequest for a given region name
|
static AdminProtos.CloseRegionRequest |
RequestConverter.buildCloseRegionRequest(ServerName server,
byte[] regionName,
int versionOfClosingNode,
ServerName destinationServer,
boolean transitionInZK) |
static AdminProtos.CloseRegionRequest |
RequestConverter.buildCloseRegionRequest(ServerName server,
String encodedRegionName,
boolean transitionInZK)
Create a CloseRegionRequest for a given encoded region name
|
static AdminProtos.GetServerInfoResponse |
ResponseConverter.buildGetServerInfoResponse(ServerName serverName,
int webuiPort)
A utility to build a GetServerInfoResponse.
|
static AdminProtos.OpenRegionRequest |
RequestConverter.buildOpenRegionRequest(ServerName server,
HRegionInfo region,
int versionOfOfflineNode,
List<ServerName> favoredNodes,
Boolean openForReplay)
Create a protocol buffer OpenRegionRequest for a given region
|
static AdminProtos.OpenRegionRequest |
RequestConverter.buildOpenRegionRequest(ServerName server,
List<Triple<HRegionInfo,Integer,List<ServerName>>> regionOpenInfos,
Boolean openForReplay)
Create a protocol buffer OpenRegionRequest to open a list of regions
|
static void |
ProtobufUtil.closeRegion(AdminProtos.AdminService.BlockingInterface admin,
ServerName server,
byte[] regionName,
boolean transitionInZK)
A helper to close a region given a region name
using admin protocol.
|
static boolean |
ProtobufUtil.closeRegion(AdminProtos.AdminService.BlockingInterface admin,
ServerName server,
byte[] regionName,
int versionOfClosingNode,
ServerName destinationServer,
boolean transitionInZK)
A helper to close a region given a region name
using admin protocol.
|
static void |
ProtobufUtil.openRegion(AdminProtos.AdminService.BlockingInterface admin,
ServerName server,
HRegionInfo region)
A helper to open a region using admin protocol.
|
static WALProtos.RegionEventDescriptor |
ProtobufUtil.toRegionEventDescriptor(WALProtos.RegionEventDescriptor.EventType eventType,
HRegionInfo hri,
long seqId,
ServerName server,
Map<byte[],List<org.apache.hadoop.fs.Path>> storeFiles) |
static HBaseProtos.ServerName |
ProtobufUtil.toServerName(ServerName serverName)
Convert a ServerName to a protocol buffer ServerName
|
Modifier and Type | Method and Description |
---|---|
static AdminProtos.OpenRegionRequest |
RequestConverter.buildOpenRegionRequest(ServerName server,
HRegionInfo region,
int versionOfOfflineNode,
List<ServerName> favoredNodes,
Boolean openForReplay)
Create a protocol buffer OpenRegionRequest for a given region
|
static AdminProtos.OpenRegionRequest |
RequestConverter.buildOpenRegionRequest(ServerName server,
List<Triple<HRegionInfo,Integer,List<ServerName>>> regionOpenInfos,
Boolean openForReplay)
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
|
Modifier and Type | Method and Description |
---|---|
ServerName |
MetaTableLocator.blockUntilAvailable(ZooKeeperWatcher zkw,
long timeout)
Wait until the meta region is available and is not in transition.
|
ServerName |
MasterAddressTracker.getMasterAddress()
Get the address of the current master if one is available.
|
ServerName |
MasterAddressTracker.getMasterAddress(boolean refresh)
Get the address of the current master if one is available.
|
static ServerName |
MasterAddressTracker.getMasterAddress(ZooKeeperWatcher zkw)
Get master address.
|
ServerName |
MetaTableLocator.getMetaRegionLocation(ZooKeeperWatcher zkw)
Gets the meta region location, if available.
|
ServerName |
MetaTableLocator.waitMetaRegionLocation(ZooKeeperWatcher zkw,
long timeout)
Gets the meta region location, if available, and waits for up to the
specified timeout if not immediately available.
|
Modifier and Type | Method and Description |
---|---|
List<Pair<HRegionInfo,ServerName>> |
MetaTableLocator.getMetaRegionsAndLocations(ZooKeeperWatcher zkw) |
Modifier and Type | Method and Description |
---|---|
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 int |
ZKAssign.confirmNodeOpening(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
int expectedVersion)
Confirm an existing unassigned node for the specified region which is
currently in the OPENING state to be still in the OPENING state on
the specified server.
|
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.deleteClosedNode(ZooKeeperWatcher zkw,
String encodedRegionName,
ServerName sn)
Deletes an existing unassigned node that is in the CLOSED state for the
specified region.
|
static boolean |
ZKAssign.deleteClosingNode(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName sn)
Deletes an existing unassigned node that is in the CLOSING state for the
specified region.
|
static boolean |
ZKAssign.deleteNode(ZooKeeperWatcher zkw,
String encodedRegionName,
EventType expectedState,
ServerName sn)
Deletes an existing unassigned node that is in the specified state for the
specified region.
|
static boolean |
ZKAssign.deleteNode(ZooKeeperWatcher zkw,
String encodedRegionName,
EventType expectedState,
ServerName serverName,
int expectedVersion)
Deletes an existing unassigned node that is in the specified state for the
specified region.
|
static boolean |
ZKAssign.deleteOfflineNode(ZooKeeperWatcher zkw,
String encodedRegionName,
ServerName sn)
Deletes an existing unassigned node that is in the OFFLINE state for the
specified region.
|
static boolean |
ZKAssign.deleteOpenedNode(ZooKeeperWatcher zkw,
String encodedRegionName,
ServerName sn)
Deletes an existing unassigned node that is in the OPENED state for the
specified region.
|
int |
MasterAddressTracker.getBackupMasterInfoPort(ServerName sn)
Get the info port of the backup master if it is available.
|
static boolean |
MasterAddressTracker.setMasterAddress(ZooKeeperWatcher zkw,
String znode,
ServerName master,
int infoPort)
Set master address into the
master znode or into the backup
subdirectory of backup masters; switch off the passed in znode
path. |
static void |
MetaTableLocator.setMetaLocation(ZooKeeperWatcher zookeeper,
ServerName serverName,
RegionState.State state)
Sets the location of
hbase:meta in ZooKeeper to the
specified server address. |
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) |
Copyright © 2015 The Apache Software Foundation. All Rights Reserved.