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.testing |
Modifier and Type | Field and Description |
---|---|
static List<ServerName> |
ServerName.EMPTY_SERVER_LIST |
Modifier and Type | Method and Description |
---|---|
ServerName |
ClusterStatus.getMaster()
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
ClusterStatus.getMasterName()
instead. |
ServerName |
ClusterMetrics.getMasterName()
Returns detailed information about the current master
ServerName . |
ServerName |
ClusterStatus.getMasterName()
Deprecated.
|
ServerName |
ServerLoad.getServerName()
Deprecated.
|
ServerName |
HRegionLocation.getServerName() |
ServerName |
ServerMetrics.getServerName() |
static ServerName |
ServerName.parseServerName(String str)
Parse a ServerName from a string
|
static ServerName |
ServerName.parseVersionedServerName(byte[] versionedBytes)
Use this method instantiating a
ServerName from bytes gotten from a call to
getVersionedBytes() . |
static ServerName |
ServerName.valueOf(Address address,
long startCode)
Retrieve an instance of
ServerName . |
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 |
---|---|
List<ServerName> |
ClusterMetrics.getBackupMasterNames()
Returns the names of backup masters
|
List<ServerName> |
ClusterStatus.getBackupMasterNames()
Deprecated.
|
List<ServerName> |
ClusterStatus.getBackupMasters()
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
ClusterStatus.getBackupMasterNames() instead. |
List<ServerName> |
ClusterMetrics.getDeadServerNames()
Returns the names of region servers on the dead list
|
List<ServerName> |
ClusterStatus.getDeadServerNames()
Deprecated.
Returns the names of region servers on the dead list
|
Map<ServerName,ServerMetrics> |
ClusterMetrics.getLiveServerMetrics()
Returns the names of region servers on the live list
|
Map<ServerName,ServerMetrics> |
ClusterStatus.getLiveServerMetrics()
Deprecated.
|
Collection<ServerName> |
ClusterStatus.getServers()
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
ClusterStatus.getLiveServerMetrics() instead. |
List<ServerName> |
ClusterMetrics.getServersName() |
List<ServerName> |
ClusterStatus.getServersName()
Deprecated.
|
List<ServerName> |
ClusterMetrics.getUnknownServerNames()
Returns the names of region servers on the unknown list
|
List<ServerName> |
ClusterStatus.getUnknownServerNames()
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
int |
ServerName.compareTo(ServerName other) |
ServerLoad |
ClusterStatus.getLoad(ServerName sn)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
ClusterStatus.getLiveServerMetrics() instead. |
static boolean |
ServerName.isSameAddress(ServerName left,
ServerName right)
Compare two addresses
|
Constructor and Description |
---|
ClusterStatus(String hbaseVersion,
String clusterid,
Map<ServerName,ServerLoad> servers,
Collection<ServerName> deadServers,
ServerName master,
Collection<ServerName> backupMasters,
List<org.apache.hadoop.hbase.master.RegionState> rit,
String[] masterCoprocessors,
Boolean balancerOn,
int masterInfoPort)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
|
HRegionLocation(RegionInfo regionInfo,
ServerName serverName) |
HRegionLocation(RegionInfo regionInfo,
ServerName serverName,
long seqNum) |
ServerLoad(ServerName name,
org.apache.hadoop.hbase.shaded.protobuf.generated.ClusterStatusProtos.ServerLoad serverLoad)
Deprecated.
|
Constructor and Description |
---|
ClusterStatus(String hbaseVersion,
String clusterid,
Map<ServerName,ServerLoad> servers,
Collection<ServerName> deadServers,
ServerName master,
Collection<ServerName> backupMasters,
List<org.apache.hadoop.hbase.master.RegionState> rit,
String[] masterCoprocessors,
Boolean balancerOn,
int masterInfoPort)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
|
ClusterStatus(String hbaseVersion,
String clusterid,
Map<ServerName,ServerLoad> servers,
Collection<ServerName> deadServers,
ServerName master,
Collection<ServerName> backupMasters,
List<org.apache.hadoop.hbase.master.RegionState> rit,
String[] masterCoprocessors,
Boolean balancerOn,
int masterInfoPort)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
|
ClusterStatus(String hbaseVersion,
String clusterid,
Map<ServerName,ServerLoad> servers,
Collection<ServerName> deadServers,
ServerName master,
Collection<ServerName> backupMasters,
List<org.apache.hadoop.hbase.master.RegionState> rit,
String[] masterCoprocessors,
Boolean balancerOn,
int masterInfoPort)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
|
Modifier and Type | Method and Description |
---|---|
default ServerName |
Admin.getMaster()
Get the current active master.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<List<ServerName>> |
AsyncAdmin.clearDeadServers(List<ServerName> servers)
Clear dead region servers from master.
|
List<ServerName> |
Admin.clearDeadServers(List<ServerName> servers)
Clear dead region servers from master.
|
CompletableFuture<Map<ServerName,Boolean>> |
AsyncAdmin.compactionSwitch(boolean switchState,
List<String> serverNamesList)
Turn the compaction on or off.
|
Map<ServerName,Boolean> |
Admin.compactionSwitch(boolean switchState,
List<String> serverNamesList)
Turn the compaction on or off.
|
default CompletableFuture<Collection<ServerName>> |
AsyncAdmin.getBackupMasters()
Returns current backup master list wrapped by
CompletableFuture |
default Collection<ServerName> |
Admin.getBackupMasters()
Get a list of current backup masters.
|
default CompletableFuture<ServerName> |
AsyncAdmin.getMaster()
Returns current master server name wrapped by
CompletableFuture |
default CompletableFuture<Collection<ServerName>> |
AsyncAdmin.getRegionServers()
Returns current live region servers list wrapped by
CompletableFuture |
default Collection<ServerName> |
Admin.getRegionServers()
Get the live server list.
|
default CompletableFuture<Collection<ServerName>> |
AsyncAdmin.getRegionServers(boolean excludeDecommissionedRS) |
default Collection<ServerName> |
Admin.getRegionServers(boolean excludeDecommissionedRS)
Retrieve all current live region servers including decommissioned if excludeDecommissionedRS is
false, else non-decommissioned ones only
|
default CompletableFuture<List<ServerName>> |
AsyncAdmin.listDeadServers()
List all the dead region servers.
|
default List<ServerName> |
Admin.listDeadServers()
List dead region servers.
|
CompletableFuture<List<ServerName>> |
AsyncAdmin.listDecommissionedRegionServers()
List region servers marked as decommissioned, which can not be assigned regions.
|
List<ServerName> |
Admin.listDecommissionedRegionServers()
List region servers marked as decommissioned, which can not be assigned regions.
|
default CompletableFuture<List<ServerName>> |
AsyncAdmin.listUnknownServers()
List all the unknown region servers.
|
default List<ServerName> |
Admin.listUnknownServers()
List unknown region servers.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Void> |
AsyncAdmin.clearCompactionQueues(ServerName serverName,
Set<String> queues)
Clear compacting queues on a region server.
|
void |
Admin.clearCompactionQueues(ServerName serverName,
Set<String> queues)
Clear compacting queues on a regionserver.
|
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) . |
CompletableFuture<Void> |
AsyncAdmin.compactRegionServer(ServerName serverName)
Compact all regions on the region server.
|
void |
Admin.compactRegionServer(ServerName serverName)
Compact all regions on the region server.
|
default void |
Admin.compactRegionServer(ServerName sn,
boolean major)
Deprecated.
|
<S,R> CompletableFuture<R> |
AsyncAdmin.coprocessorService(Function<com.google.protobuf.RpcChannel,S> stubMaker,
ServiceCaller<S,R> callable,
ServerName serverName)
Execute the given coprocessor call on the given region server.
|
CoprocessorRpcChannel |
Admin.coprocessorService(ServerName serverName)
Creates and returns a
RpcChannel instance connected to the passed
region server. |
void |
RequestController.decTaskCounters(Collection<byte[]> regions,
ServerName sn)
Decrement the counter if a task is accomplished.
|
CompletableFuture<Void> |
AsyncAdmin.flushRegionServer(ServerName serverName)
Flush all region on the region server.
|
void |
Admin.flushRegionServer(ServerName serverName)
Flush all regions on the region server.
|
default org.apache.hadoop.hbase.client.Hbck |
Connection.getHbck(ServerName masterServer)
Retrieve an Hbck implementation to fix an HBase cluster.
|
org.apache.hadoop.hbase.client.Hbck |
AsyncConnection.getHbck(ServerName masterServer)
Retrieve an Hbck implementation to fix an HBase cluster.
|
List<HRegionInfo> |
Admin.getOnlineRegions(ServerName sn)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
(HBASE-17980). Use
Admin.getRegions(ServerName sn) . |
CompletableFuture<List<RegionMetrics>> |
AsyncAdmin.getRegionMetrics(ServerName serverName)
Get a list of
RegionMetrics of all regions hosted on a region server. |
default List<RegionMetrics> |
Admin.getRegionMetrics(ServerName serverName)
Get
RegionMetrics of all regions hosted on a regionserver. |
CompletableFuture<List<RegionMetrics>> |
AsyncAdmin.getRegionMetrics(ServerName serverName,
TableName tableName)
Get a list of
RegionMetrics of all regions hosted on a region server for a table. |
List<RegionMetrics> |
Admin.getRegionMetrics(ServerName serverName,
TableName tableName)
Get
RegionMetrics of all regions hosted on a regionserver for a table. |
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.
|
CompletableFuture<? extends Map<TableName,? extends SpaceQuotaSnapshotView>> |
AsyncAdmin.getRegionServerSpaceQuotaSnapshots(ServerName serverName)
Fetches the observed
SpaceQuotaSnapshotView s observed by a RegionServer. |
Map<TableName,? extends SpaceQuotaSnapshotView> |
Admin.getRegionServerSpaceQuotaSnapshots(ServerName serverName)
Fetches the observed
SpaceQuotaSnapshotView s observed by a RegionServer. |
void |
RequestController.incTaskCounters(Collection<byte[]> regions,
ServerName sn)
Increment the counter if we build a valid task.
|
CompletableFuture<Void> |
AsyncAdmin.majorCompactRegionServer(ServerName serverName)
Compact all regions on the region server.
|
void |
Admin.majorCompactRegionServer(ServerName serverName)
Major compact all regions on the region server.
|
CompletableFuture<Void> |
AsyncAdmin.move(byte[] regionName,
ServerName destServerName)
Move the region
r to dest . |
void |
Admin.move(byte[] encodedRegionName,
ServerName destServerName)
Move the region
rencodedRegionName to destServerName . |
CompletableFuture<Void> |
AsyncAdmin.recommissionRegionServer(ServerName server,
List<byte[]> encodedRegionNames)
Remove decommission marker from a region server to allow regions assignments.
|
void |
Admin.recommissionRegionServer(ServerName server,
List<byte[]> encodedRegionNames)
Remove decommission marker from a region server to allow regions assignments.
|
CompletableFuture<Void> |
AsyncAdmin.rollWALWriter(ServerName serverName)
Roll the log writer.
|
void |
Admin.rollWALWriter(ServerName serverName)
Roll the log writer.
|
CompletableFuture<Void> |
AsyncAdmin.stopRegionServer(ServerName serverName)
Stop the designated regionserver.
|
CompletableFuture<Void> |
AsyncAdmin.updateConfiguration(ServerName serverName)
Update the configuration and trigger an online config change on the regionserver.
|
void |
Admin.updateConfiguration(ServerName server)
Update the configuration and trigger an online config change on the regionserver.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<List<ServerName>> |
AsyncAdmin.clearDeadServers(List<ServerName> servers)
Clear dead region servers from master.
|
List<ServerName> |
Admin.clearDeadServers(List<ServerName> servers)
Clear dead region servers from master.
|
CompletableFuture<List<Boolean>> |
AsyncAdmin.clearSlowLogResponses(Set<ServerName> serverNames)
Clears online slow RPC logs from the provided list of RegionServers
|
List<Boolean> |
Admin.clearSlowLogResponses(Set<ServerName> serverNames)
Clears online slow/large RPC logs from the provided list of RegionServers
|
CompletableFuture<Void> |
AsyncAdmin.decommissionRegionServers(List<ServerName> servers,
boolean offload)
Mark region server(s) as decommissioned to prevent additional regions from getting assigned to
them.
|
void |
Admin.decommissionRegionServers(List<ServerName> servers,
boolean offload)
Mark region server(s) as decommissioned to prevent additional regions from getting assigned to
them.
|
CompletableFuture<List<LogEntry>> |
AsyncAdmin.getLogEntries(Set<ServerName> serverNames,
String logType,
ServerType serverType,
int limit,
Map<String,Object> filterParams)
Retrieve recent online records from HMaster / RegionServers.
|
List<LogEntry> |
Admin.getLogEntries(Set<ServerName> serverNames,
String logType,
ServerType serverType,
int limit,
Map<String,Object> filterParams)
Retrieve recent online records from HMaster / RegionServers.
|
default CompletableFuture<List<OnlineLogRecord>> |
AsyncAdmin.getSlowLogResponses(Set<ServerName> serverNames,
LogQueryFilter logQueryFilter)
Deprecated.
since 2.4.0 and will be removed in 4.0.0. Use
AsyncAdmin.getLogEntries(Set, String, ServerType, int, Map) instead. |
default List<OnlineLogRecord> |
Admin.getSlowLogResponses(Set<ServerName> serverNames,
LogQueryFilter logQueryFilter)
Deprecated.
since 2.4.0 and will be removed in 4.0.0. Use
Admin.getLogEntries(Set, String, ServerType, int, Map) instead. |
Modifier and Type | Method and Description |
---|---|
long |
ExponentialClientBackoffPolicy.getBackoffTime(ServerName serverName,
byte[] region,
org.apache.hadoop.hbase.client.backoff.ServerStatistics stats) |
long |
ClientBackoffPolicy.getBackoffTime(ServerName serverName,
byte[] region,
org.apache.hadoop.hbase.client.backoff.ServerStatistics stats)
Returns the number of ms to wait on the client based on the
|
Constructor and Description |
---|
PreemptiveFastFailException(long count,
long timeOfFirstFailureMilliSec,
long timeOfLatestAttemptMilliSec,
ServerName serverName)
Deprecated.
|
PreemptiveFastFailException(long count,
long timeOfFirstFailureMilliSec,
long timeOfLatestAttemptMilliSec,
ServerName serverName,
boolean guaranteedClientSideOnly)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
Optional<ServerName> |
TestingHBaseCluster.getActiveMasterAddress()
Get the address of active master if there is one.
|
List<ServerName> |
TestingHBaseCluster.getBackupMasterAddresses()
Get all the backup master addresses.
|
List<ServerName> |
TestingHBaseCluster.getRegionServerAddresses()
Get all the region server addresses.
|
Modifier and Type | Method and Description |
---|---|
Optional<org.apache.hadoop.hbase.regionserver.OnlineRegions> |
TestingHBaseCluster.getOnlineRegionsInterface(ServerName serverName)
Get the server side
OnlineRegions interface for the specific region server. |
CompletableFuture<Void> |
TestingHBaseCluster.stopMaster(ServerName serverName)
Stop the given master.
|
CompletableFuture<Void> |
TestingHBaseCluster.stopRegionServer(ServerName serverName)
Stop the given region server.
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.