Modifier and Type | Field and Description |
---|---|
private ServerName |
ClusterMetricsBuilder.masterName |
private ServerName |
ClusterMetricsBuilder.ClusterMetricsImpl.masterName |
private ServerName |
SplitLogTask.originServer
Deprecated.
|
private ServerName |
HRegionLocation.serverName |
private ServerName |
ServerMetricsBuilder.serverName |
private ServerName |
ServerMetricsBuilder.ServerMetricsImpl.serverName |
Modifier and Type | Field and Description |
---|---|
private List<ServerName> |
ClusterMetricsBuilder.backupMasterNames |
private List<ServerName> |
ClusterMetricsBuilder.ClusterMetricsImpl.backupMasterNames |
private List<ServerName> |
ClusterMetricsBuilder.deadServerNames |
private List<ServerName> |
ClusterMetricsBuilder.ClusterMetricsImpl.deadServerNames |
static List<ServerName> |
ServerName.EMPTY_SERVER_LIST |
private static org.apache.hbase.thirdparty.com.google.common.collect.Interner<ServerName> |
ServerName.INTERN_POOL
Intern ServerNames.
|
private Map<ServerName,ServerMetrics> |
ClusterMetricsBuilder.liveServerMetrics |
private Map<ServerName,ServerMetrics> |
ClusterMetricsBuilder.ClusterMetricsImpl.liveServerMetrics |
private List<ServerName> |
ClusterMetricsBuilder.serversName |
private List<ServerName> |
ClusterMetricsBuilder.ClusterMetricsImpl.serversName |
private List<ServerName> |
ClusterMetricsBuilder.unknownServerNames |
private List<ServerName> |
ClusterMetricsBuilder.ClusterMetricsImpl.unknownServerNames |
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 |
ClusterStatus.getMasterName()
Deprecated.
|
ServerName |
ClusterMetrics.getMasterName()
Returns detailed information about the current master
ServerName . |
ServerName |
ClusterMetricsBuilder.ClusterMetricsImpl.getMasterName() |
ServerName |
SplitLogTask.getServerName()
Deprecated.
|
ServerName |
Server.getServerName()
Returns The unique server name for this server.
|
ServerName |
ServerMetrics.getServerName() |
ServerName |
ServerLoad.getServerName()
Deprecated.
|
ServerName |
HRegionLocation.getServerName() |
ServerName |
ServerMetricsBuilder.ServerMetricsImpl.getServerName() |
static ServerName |
MetaTableAccessor.getServerName(Result r,
int replicaId)
Returns a
ServerName from catalog table Result . |
static ServerName |
MetaTableAccessor.getTargetServerName(Result r,
int replicaId)
Returns the
ServerName from catalog table Result where the region is
transitioning on. |
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> |
ClusterStatus.getBackupMasterNames()
Deprecated.
|
List<ServerName> |
ClusterMetrics.getBackupMasterNames()
Returns the names of backup masters
|
List<ServerName> |
ClusterMetricsBuilder.ClusterMetricsImpl.getBackupMasterNames() |
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> |
ClusterStatus.getDeadServerNames()
Deprecated.
Returns the names of region servers on the dead list
|
List<ServerName> |
ClusterMetrics.getDeadServerNames()
Returns the names of region servers on the dead list
|
List<ServerName> |
ClusterMetricsBuilder.ClusterMetricsImpl.getDeadServerNames() |
private Map<ServerName,ServerLoad> |
ClusterStatus.getLiveServerLoads()
Deprecated.
|
Map<ServerName,ServerMetrics> |
ClusterStatus.getLiveServerMetrics()
Deprecated.
|
Map<ServerName,ServerMetrics> |
ClusterMetrics.getLiveServerMetrics()
Returns the names of region servers on the live list
|
Map<ServerName,ServerMetrics> |
ClusterMetricsBuilder.ClusterMetricsImpl.getLiveServerMetrics() |
static Pair<RegionInfo,ServerName> |
MetaTableAccessor.getRegion(Connection connection,
byte[] regionName)
Deprecated.
|
private static Optional<ServerName> |
AsyncMetaTableAccessor.getServerName(Result r,
int replicaId)
Returns a
ServerName from catalog table Result . |
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> |
ClusterStatus.getServersName()
Deprecated.
|
List<ServerName> |
ClusterMetrics.getServersName() |
List<ServerName> |
ClusterMetricsBuilder.ClusterMetricsImpl.getServersName() |
private static CompletableFuture<List<Pair<RegionInfo,ServerName>>> |
AsyncMetaTableAccessor.getTableRegionsAndLocations(AsyncTable<AdvancedScanResultConsumer> metaTable,
TableName tableName,
boolean excludeOfflinedSplitParents)
Used to get table regions' info and server.
|
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.
|
List<ServerName> |
ClusterStatus.getUnknownServerNames()
Deprecated.
|
List<ServerName> |
ClusterMetrics.getUnknownServerNames()
Returns the names of region servers on the unknown list
|
List<ServerName> |
ClusterMetricsBuilder.ClusterMetricsImpl.getUnknownServerNames() |
Modifier and Type | Method and Description |
---|---|
static Put |
MetaTableAccessor.addLocation(Put p,
ServerName sn,
long openSeqNum,
int replicaId) |
int |
ServerName.compareTo(ServerName other) |
Hbck |
SharedConnection.getHbck(ServerName masterServer) |
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 NavigableMap<RegionInfo,Result> |
MetaTableAccessor.getServerUserRegions(Connection connection,
ServerName serverName)
Get the user regions a given server is hosting.
|
boolean |
SplitLogTask.isDone(ServerName sn)
Deprecated.
|
boolean |
SplitLogTask.isErr(ServerName sn)
Deprecated.
|
boolean |
SplitLogTask.isOwned(ServerName sn)
Deprecated.
|
boolean |
SplitLogTask.isResigned(ServerName sn)
Deprecated.
|
static boolean |
ServerName.isSameAddress(ServerName left,
ServerName right)
Compare two addresses
|
boolean |
SplitLogTask.isUnassigned(ServerName sn)
Deprecated.
|
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 ServerMetricsBuilder |
ServerMetricsBuilder.newBuilder(ServerName sn) |
static ServerMetrics |
ServerMetricsBuilder.of(ServerName sn) |
static ServerMetrics |
ServerMetricsBuilder.of(ServerName sn,
int versionNumber,
String version) |
RegionLocations |
RegionLocations.removeByServer(ServerName serverName)
Returns a new RegionLocations with the locations removed (set to null) which have the
destination server as given.
|
ClusterMetricsBuilder |
ClusterMetricsBuilder.setMasterName(ServerName value) |
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 ServerMetrics |
ServerMetricsBuilder.toServerMetrics(ServerName serverName,
org.apache.hadoop.hbase.shaded.protobuf.generated.ClusterStatusProtos.ServerLoad serverLoadPB) |
static ServerMetrics |
ServerMetricsBuilder.toServerMetrics(ServerName serverName,
int versionNumber,
String version,
org.apache.hadoop.hbase.shaded.protobuf.generated.ClusterStatusProtos.ServerLoad serverLoadPB) |
private static void |
MetaTableAccessor.updateLocation(Connection connection,
RegionInfo regionInfo,
ServerName sn,
long openSeqNum,
long masterSystemTime)
Updates the location of the specified region to be the specified server.
|
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.
|
Modifier and Type | Method and Description |
---|---|
private static List<RegionInfo> |
MetaTableAccessor.getListOfRegionInfos(List<Pair<RegionInfo,ServerName>> pairs) |
ClusterMetricsBuilder |
ClusterMetricsBuilder.setBackerMasterNames(List<ServerName> value) |
ClusterMetricsBuilder |
ClusterMetricsBuilder.setDeadServerNames(List<ServerName> value) |
ClusterMetricsBuilder |
ClusterMetricsBuilder.setLiveServerMetrics(Map<ServerName,ServerMetrics> value) |
ClusterMetricsBuilder |
ClusterMetricsBuilder.setServerNames(List<ServerName> serversName) |
ClusterMetricsBuilder |
ClusterMetricsBuilder.setUnknownServerNames(List<ServerName> value) |
Constructor and Description |
---|
ClusterMetricsImpl(String hbaseVersion,
List<ServerName> deadServerNames,
List<ServerName> unknownServerNames,
Map<ServerName,ServerMetrics> liveServerMetrics,
ServerName masterName,
List<ServerName> backupMasterNames,
List<RegionState> regionsInTransition,
String clusterId,
List<String> masterCoprocessorNames,
Boolean balancerOn,
int masterInfoPort,
List<ServerName> serversName,
Map<TableName,RegionStatesCount> tableRegionStatesCount,
List<ServerTask> masterTasks) |
ClusterStatus(String hbaseVersion,
String clusterid,
Map<ServerName,ServerLoad> servers,
Collection<ServerName> deadServers,
ServerName master,
Collection<ServerName> backupMasters,
List<RegionState> rit,
String[] masterCoprocessors,
Boolean balancerOn,
int masterInfoPort)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0
|
Done(ServerName originServer) |
Err(ServerName originServer) |
HRegionLocation(RegionInfo regionInfo,
ServerName serverName) |
HRegionLocation(RegionInfo regionInfo,
ServerName serverName,
long seqNum) |
Owned(ServerName originServer) |
Resigned(ServerName originServer) |
ServerLoad(ServerName name,
org.apache.hadoop.hbase.shaded.protobuf.generated.ClusterStatusProtos.ServerLoad serverLoad)
Deprecated.
|
ServerMetricsBuilder(ServerName serverName) |
ServerMetricsImpl(ServerName serverName,
int versionNumber,
String version,
long requestCountPerSecond,
long requestCount,
Size usedHeapSize,
Size maxHeapSize,
int infoServerPort,
List<ReplicationLoadSource> sources,
ReplicationLoadSink sink,
Map<byte[],RegionMetrics> regionStatus,
Set<String> coprocessorNames,
long reportTimestamp,
long lastReportTimestamp,
Map<byte[],UserMetrics> userMetrics,
List<ServerTask> tasks) |
SplitLogTask(ServerName originServer,
org.apache.hadoop.hbase.shaded.protobuf.generated.ZooKeeperProtos.SplitLogTask.State state)
Deprecated.
|
Unassigned(ServerName originServer) |
Constructor and Description |
---|
ClusterMetricsImpl(String hbaseVersion,
List<ServerName> deadServerNames,
List<ServerName> unknownServerNames,
Map<ServerName,ServerMetrics> liveServerMetrics,
ServerName masterName,
List<ServerName> backupMasterNames,
List<RegionState> regionsInTransition,
String clusterId,
List<String> masterCoprocessorNames,
Boolean balancerOn,
int masterInfoPort,
List<ServerName> serversName,
Map<TableName,RegionStatesCount> tableRegionStatesCount,
List<ServerTask> masterTasks) |
ClusterMetricsImpl(String hbaseVersion,
List<ServerName> deadServerNames,
List<ServerName> unknownServerNames,
Map<ServerName,ServerMetrics> liveServerMetrics,
ServerName masterName,
List<ServerName> backupMasterNames,
List<RegionState> regionsInTransition,
String clusterId,
List<String> masterCoprocessorNames,
Boolean balancerOn,
int masterInfoPort,
List<ServerName> serversName,
Map<TableName,RegionStatesCount> tableRegionStatesCount,
List<ServerTask> masterTasks) |
ClusterMetricsImpl(String hbaseVersion,
List<ServerName> deadServerNames,
List<ServerName> unknownServerNames,
Map<ServerName,ServerMetrics> liveServerMetrics,
ServerName masterName,
List<ServerName> backupMasterNames,
List<RegionState> regionsInTransition,
String clusterId,
List<String> masterCoprocessorNames,
Boolean balancerOn,
int masterInfoPort,
List<ServerName> serversName,
Map<TableName,RegionStatesCount> tableRegionStatesCount,
List<ServerTask> masterTasks) |
ClusterMetricsImpl(String hbaseVersion,
List<ServerName> deadServerNames,
List<ServerName> unknownServerNames,
Map<ServerName,ServerMetrics> liveServerMetrics,
ServerName masterName,
List<ServerName> backupMasterNames,
List<RegionState> regionsInTransition,
String clusterId,
List<String> masterCoprocessorNames,
Boolean balancerOn,
int masterInfoPort,
List<ServerName> serversName,
Map<TableName,RegionStatesCount> tableRegionStatesCount,
List<ServerTask> masterTasks) |
ClusterMetricsImpl(String hbaseVersion,
List<ServerName> deadServerNames,
List<ServerName> unknownServerNames,
Map<ServerName,ServerMetrics> liveServerMetrics,
ServerName masterName,
List<ServerName> backupMasterNames,
List<RegionState> regionsInTransition,
String clusterId,
List<String> masterCoprocessorNames,
Boolean balancerOn,
int masterInfoPort,
List<ServerName> serversName,
Map<TableName,RegionStatesCount> tableRegionStatesCount,
List<ServerTask> masterTasks) |
ClusterStatus(String hbaseVersion,
String clusterid,
Map<ServerName,ServerLoad> servers,
Collection<ServerName> deadServers,
ServerName master,
Collection<ServerName> backupMasters,
List<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<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<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 | Field and Description |
---|---|
private ServerName |
FastFailInterceptorContext.server |
private ServerName |
AsyncRequestFutureImpl.SingleServerRequestRunnable.server |
private ServerName |
ServerConnectionUtils.ShortCircuitingClusterConnection.serverName |
private ServerName |
AsyncServerRequestRpcRetryingCaller.serverName |
private ServerName |
AsyncAdminRequestRetryingCaller.serverName |
private ServerName |
AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder.serverName |
private ServerName |
AsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder.serverName |
Modifier and Type | Field and Description |
---|---|
private org.apache.hbase.thirdparty.com.google.common.collect.ImmutableMap<ServerName,org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.ClientMetaService.Interface> |
AbstractRpcBasedConnectionRegistry.addr2Stub |
private Set<ServerName> |
MetaCache.cachedServers |
private List<ServerName> |
ClusterStatusListener.deadServers |
private ConcurrentMap<ServerName,ConnectionImplementation.ServerErrorTracker.ServerErrors> |
ConnectionImplementation.ServerErrorTracker.errorsByServer |
protected ConcurrentMap<ServerName,FailureInfo> |
PreemptiveFastFailInterceptor.repeatedFailuresMap |
private Map<ServerName,Long> |
SimpleRequestController.RequestHeapSizeChecker.serverRequestSizes |
private Map<ServerName,Long> |
SimpleRequestController.RequestRowsChecker.serverRows |
private Set<ServerName> |
SimpleRequestController.TaskCountChecker.serversIncluded |
protected ConcurrentHashMap<ServerName,ConcurrentMap<byte[],MetricsConnection.RegionStats>> |
MetricsConnection.serverStats |
private ConcurrentHashMap<ServerName,ServerStatistics> |
ServerStatisticTracker.stats |
(package private) ConcurrentMap<ServerName,AtomicInteger> |
SimpleRequestController.taskCounterPerServer |
private Map<ServerName,AtomicInteger> |
SimpleRequestController.TaskCountChecker.taskCounterPerServer |
Modifier and Type | Method and Description |
---|---|
default ServerName |
Admin.getMaster()
Get the current active master.
|
ServerName |
FastFailInterceptorContext.getServer() |
(package private) ServerName |
MultiServerCallable.getServerName() |
Modifier and Type | Method and Description |
---|---|
List<ServerName> |
Admin.clearDeadServers(List<ServerName> servers)
Clear dead region servers from master.
|
CompletableFuture<List<ServerName>> |
AsyncAdmin.clearDeadServers(List<ServerName> servers)
Clear dead region servers from master.
|
CompletableFuture<List<ServerName>> |
RawAsyncHBaseAdmin.clearDeadServers(List<ServerName> servers) |
CompletableFuture<List<ServerName>> |
AsyncHBaseAdmin.clearDeadServers(List<ServerName> servers) |
List<ServerName> |
HBaseAdmin.clearDeadServers(List<ServerName> servers) |
Map<ServerName,Boolean> |
Admin.compactionSwitch(boolean switchState,
List<String> serverNamesList)
Turn the compaction on or off.
|
CompletableFuture<Map<ServerName,Boolean>> |
AsyncAdmin.compactionSwitch(boolean switchState,
List<String> serverNamesList)
Turn the compaction on or off.
|
CompletableFuture<Map<ServerName,Boolean>> |
RawAsyncHBaseAdmin.compactionSwitch(boolean switchState,
List<String> serverNamesList) |
CompletableFuture<Map<ServerName,Boolean>> |
AsyncHBaseAdmin.compactionSwitch(boolean switchState,
List<String> serverNamesList) |
Map<ServerName,Boolean> |
HBaseAdmin.compactionSwitch(boolean switchState,
List<String> serverNamesList) |
protected CompletableFuture<Set<ServerName>> |
MasterRegistry.fetchEndpoints()
Deprecated.
|
protected CompletableFuture<Set<ServerName>> |
RpcConnectionRegistry.fetchEndpoints() |
protected abstract CompletableFuture<Set<ServerName>> |
AbstractRpcBasedConnectionRegistry.fetchEndpoints() |
CompletableFuture<ServerName> |
RegionServerRegistry.getActiveMaster() |
CompletableFuture<ServerName> |
AbstractRpcBasedConnectionRegistry.getActiveMaster() |
CompletableFuture<ServerName> |
ZKConnectionRegistry.getActiveMaster() |
CompletableFuture<ServerName> |
ConnectionRegistry.getActiveMaster()
Get the address of active HMaster.
|
default Collection<ServerName> |
Admin.getBackupMasters()
Get a list of current backup masters.
|
default CompletableFuture<Collection<ServerName>> |
AsyncAdmin.getBackupMasters()
Returns current backup master list wrapped by
CompletableFuture |
private CompletableFuture<Set<ServerName>> |
RpcConnectionRegistry.getBootstrapNodes() |
protected Set<ServerName> |
MasterRegistry.getBootstrapNodes(org.apache.hadoop.conf.Configuration conf)
Deprecated.
|
protected Set<ServerName> |
RpcConnectionRegistry.getBootstrapNodes(org.apache.hadoop.conf.Configuration conf) |
protected abstract Set<ServerName> |
AbstractRpcBasedConnectionRegistry.getBootstrapNodes(org.apache.hadoop.conf.Configuration conf) |
default CompletableFuture<ServerName> |
AsyncAdmin.getMaster()
Returns current master server name wrapped by
CompletableFuture |
(package private) CompletableFuture<Set<ServerName>> |
MasterRegistry.getMasters()
Deprecated.
|
(package private) Set<ServerName> |
AbstractRpcBasedConnectionRegistry.getParsedServers() |
(package private) Pair<RegionInfo,ServerName> |
HBaseAdmin.getRegion(byte[] regionName) |
private CompletableFuture<List<ServerName>> |
RawAsyncHBaseAdmin.getRegionServerList(List<String> serverNamesList) |
default Collection<ServerName> |
Admin.getRegionServers()
Get the live server list.
|
default CompletableFuture<Collection<ServerName>> |
AsyncAdmin.getRegionServers()
Returns current live region servers list wrapped by
CompletableFuture |
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<Collection<ServerName>> |
AsyncAdmin.getRegionServers(boolean excludeDecommissionedRS) |
private Pair<RegionState.State,ServerName> |
ZKConnectionRegistry.getStateAndServerName(org.apache.hadoop.hbase.shaded.protobuf.generated.ZooKeeperProtos.MetaRegionServer proto) |
default List<ServerName> |
Admin.listDeadServers()
List dead region servers.
|
default CompletableFuture<List<ServerName>> |
AsyncAdmin.listDeadServers()
List all the dead region servers.
|
CompletableFuture<List<ServerName>> |
AsyncHBaseAdmin.listDeadServers() |
List<ServerName> |
Admin.listDecommissionedRegionServers()
List region servers marked as decommissioned, which can not be assigned regions.
|
CompletableFuture<List<ServerName>> |
AsyncAdmin.listDecommissionedRegionServers()
List region servers marked as decommissioned, which can not be assigned regions.
|
CompletableFuture<List<ServerName>> |
RawAsyncHBaseAdmin.listDecommissionedRegionServers() |
CompletableFuture<List<ServerName>> |
AsyncHBaseAdmin.listDecommissionedRegionServers() |
List<ServerName> |
HBaseAdmin.listDecommissionedRegionServers() |
default List<ServerName> |
Admin.listUnknownServers()
List unknown region servers.
|
default CompletableFuture<List<ServerName>> |
AsyncAdmin.listUnknownServers()
List all the unknown region servers.
|
CompletableFuture<List<ServerName>> |
AsyncHBaseAdmin.listUnknownServers() |
static Set<ServerName> |
MasterRegistry.parseMasterAddrs(org.apache.hadoop.conf.Configuration conf)
Deprecated.
Parses the list of master addresses from the provided configuration.
|
private static Set<ServerName> |
RpcConnectionRegistry.transformServerNames(org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetBootstrapNodesResponse resp) |
private static Set<ServerName> |
MasterRegistry.transformServerNames(org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetMastersResponse resp)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
BatchErrors.add(Throwable ex,
Row row,
ServerName serverName) |
(package private) static void |
AsyncProcess.addAction(ServerName server,
byte[] regionName,
Action action,
Map<ServerName,MultiAction> actionsByServer,
long nonceGroup)
Helper that is used when grouping the actions per region server.
|
private void |
AsyncBatchRpcRetryingCaller.addError(Action action,
Throwable error,
ServerName serverName) |
private void |
AsyncBatchRpcRetryingCaller.addError(Iterable<Action> actions,
Throwable error,
ServerName serverName) |
void |
MetaCache.cacheLocation(TableName tableName,
ServerName source,
HRegionLocation location)
Put a newly discovered HRegionLocation into the cache.
|
private void |
ConnectionImplementation.cacheLocation(TableName tableName,
ServerName source,
HRegionLocation location)
Put a newly discovered HRegionLocation into the cache.
|
(package private) long |
ConnectionImplementation.ServerErrorTracker.calculateBackoffTime(ServerName server,
long basePause)
Calculates the back-off time for a retrying request to a particular server.
|
private void |
AsyncRequestFutureImpl.cleanServerCache(ServerName server,
Throwable regionException) |
private CompletableFuture<CacheEvictionStats> |
RawAsyncHBaseAdmin.clearBlockCache(ServerName serverName,
List<RegionInfo> hris) |
private CacheEvictionStats |
HBaseAdmin.clearBlockCache(ServerName sn,
List<RegionInfo> hris) |
void |
MetaCache.clearCache(ServerName serverName)
Delete all cached entries of a server.
|
(package private) void |
AsyncNonMetaRegionLocator.clearCache(ServerName serverName) |
(package private) void |
AsyncRegionLocator.clearCache(ServerName serverName) |
(package private) void |
AsyncMetaRegionLocator.clearCache(ServerName serverName) |
void |
MetaCache.clearCache(TableName tableName,
byte[] row,
ServerName serverName)
Delete a cached location for a table, row and server
|
void |
ClusterConnection.clearCaches(ServerName sn)
Clear any caches that pertain to server name
sn . |
void |
ConnectionImplementation.clearCaches(ServerName serverName) |
void |
Admin.clearCompactionQueues(ServerName serverName,
Set<String> queues)
Clear compacting queues on a regionserver.
|
CompletableFuture<Void> |
AsyncAdmin.clearCompactionQueues(ServerName serverName,
Set<String> queues)
Clear compacting queues on a region server.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.clearCompactionQueues(ServerName serverName,
Set<String> queues) |
CompletableFuture<Void> |
AsyncHBaseAdmin.clearCompactionQueues(ServerName serverName,
Set<String> queues) |
void |
HBaseAdmin.clearCompactionQueues(ServerName sn,
Set<String> queues) |
private CompletableFuture<Boolean> |
RawAsyncHBaseAdmin.clearSlowLogsResponses(ServerName serverName) |
private Boolean |
HBaseAdmin.clearSlowLogsResponses(ServerName serverName) |
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) . |
void |
HBaseAdmin.closeRegion(ServerName unused,
HRegionInfo hri)
Deprecated.
|
private CompletableFuture<Void> |
RawAsyncHBaseAdmin.compact(ServerName sn,
RegionInfo hri,
boolean major,
byte[] columnFamily)
Compact the region at specific region server.
|
void |
Admin.compactRegionServer(ServerName serverName)
Compact all regions on the region server.
|
CompletableFuture<Void> |
AsyncAdmin.compactRegionServer(ServerName serverName)
Compact all regions on the region server.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.compactRegionServer(ServerName sn) |
CompletableFuture<Void> |
AsyncHBaseAdmin.compactRegionServer(ServerName serverName) |
void |
HBaseAdmin.compactRegionServer(ServerName serverName) |
default void |
Admin.compactRegionServer(ServerName sn,
boolean major)
Deprecated.
|
private CompletableFuture<Void> |
RawAsyncHBaseAdmin.compactRegionServer(ServerName sn,
boolean major) |
<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.
|
<S,R> CompletableFuture<R> |
RawAsyncHBaseAdmin.coprocessorService(Function<com.google.protobuf.RpcChannel,S> stubMaker,
ServiceCaller<S,R> callable,
ServerName serverName) |
<S,R> CompletableFuture<R> |
AsyncHBaseAdmin.coprocessorService(Function<com.google.protobuf.RpcChannel,S> stubMaker,
ServiceCaller<S,R> callable,
ServerName serverName) |
CoprocessorRpcChannel |
Admin.coprocessorService(ServerName serverName)
Creates and returns a
RpcChannel instance connected to the passed
region server. |
CoprocessorRpcChannel |
HBaseAdmin.coprocessorService(ServerName serverName) |
private org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.Interface |
AsyncConnectionImpl.createAdminServerStub(ServerName serverName) |
private MultiServerCallable |
AsyncRequestFutureImpl.createCallable(ServerName server,
TableName tableName,
MultiAction multi)
Create a callable.
|
private String |
AsyncRequestFutureImpl.createLog(int numAttempt,
int failureCount,
int replaySize,
ServerName sn,
Throwable error,
long backOffTime,
boolean willRetry,
String startTime,
int failed,
int stopped) |
private org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.Interface |
AsyncConnectionImpl.createMasterStub(ServerName serverName) |
private org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface |
AsyncConnectionImpl.createRegionServerStub(ServerName serverName) |
static ClusterConnection |
ServerConnectionUtils.createShortCircuitConnection(org.apache.hadoop.conf.Configuration conf,
User user,
ServerName serverName,
org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface admin,
org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface client,
ConnectionRegistry registry)
Creates a short-circuit connection that can bypass the RPC layer (serialization,
deserialization, networking, etc..) when talking to a local server.
|
(package private) AsyncRequestFutureImpl.SingleServerRequestRunnable |
AsyncRequestFutureImpl.createSingleServerRequest(MultiAction multiAction,
int numAttempt,
ServerName server,
Set<CancellableRegionServerCallable> callsInProgress) |
(package private) void |
AsyncProcess.decTaskCounters(Collection<byte[]> regions,
ServerName sn) |
void |
RequestController.decTaskCounters(Collection<byte[]> regions,
ServerName sn)
Decrement the counter if a task is accomplished.
|
void |
SimpleRequestController.decTaskCounters(Collection<byte[]> regions,
ServerName sn) |
private void |
AsyncBatchRpcRetryingCaller.failAll(Stream<Action> actions,
int tries,
Throwable error,
ServerName serverName) |
private CompletableFuture<Void> |
RawAsyncHBaseAdmin.flush(ServerName serverName,
RegionInfo regionInfo,
byte[] columnFamily) |
void |
Admin.flushRegionServer(ServerName serverName)
Flush all regions on the region server.
|
CompletableFuture<Void> |
AsyncAdmin.flushRegionServer(ServerName serverName)
Flush all region on the region server.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.flushRegionServer(ServerName sn) |
CompletableFuture<Void> |
AsyncHBaseAdmin.flushRegionServer(ServerName sn) |
void |
HBaseAdmin.flushRegionServer(ServerName serverName) |
org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface |
ServerConnectionUtils.ShortCircuitingClusterConnection.getAdmin(ServerName sn) |
org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface |
ClusterConnection.getAdmin(ServerName serverName)
Establishes a connection to the region server at the specified address.
|
org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface |
ConnectionImplementation.getAdmin(ServerName serverName) |
(package private) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.Interface |
AsyncConnectionImpl.getAdminStub(ServerName serverName) |
private Long |
AsyncRequestFutureImpl.getBackoff(ServerName server,
byte[] regionName) |
org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface |
ServerConnectionUtils.ShortCircuitingClusterConnection.getClient(ServerName sn) |
org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface |
ClusterConnection.getClient(ServerName serverName)
Establishes a connection to the region server at the specified address, and returns a region
client protocol.
|
org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface |
ConnectionImplementation.getClient(ServerName serverName) |
private String |
AsyncBatchRpcRetryingCaller.getExtraContextForError(ServerName serverName) |
Hbck |
ConnectionImplementation.getHbck(ServerName masterServer) |
Hbck |
AsyncConnectionImpl.getHbck(ServerName masterServer) |
Hbck |
AsyncConnection.getHbck(ServerName masterServer)
Retrieve an Hbck implementation to fix an HBase cluster.
|
default Hbck |
Connection.getHbck(ServerName masterServer)
Retrieve an Hbck implementation to fix an HBase cluster.
|
private Hbck |
AsyncConnectionImpl.getHbckInternal(ServerName masterServer) |
private Collection<? extends Runnable> |
AsyncRequestFutureImpl.getNewMultiActionRunnable(ServerName server,
MultiAction multiAction,
int numAttempt) |
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) . |
List<HRegionInfo> |
HBaseAdmin.getOnlineRegions(ServerName sn)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use
HBaseAdmin.getRegions(ServerName) . |
private CompletableFuture<List<RegionMetrics>> |
RawAsyncHBaseAdmin.getRegionMetrics(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionLoadRequest request,
ServerName serverName) |
default List<RegionMetrics> |
Admin.getRegionMetrics(ServerName serverName)
Get
RegionMetrics of all regions hosted on a regionserver. |
CompletableFuture<List<RegionMetrics>> |
AsyncAdmin.getRegionMetrics(ServerName serverName)
Get a list of
RegionMetrics of all regions hosted on a region server. |
CompletableFuture<List<RegionMetrics>> |
RawAsyncHBaseAdmin.getRegionMetrics(ServerName serverName) |
CompletableFuture<List<RegionMetrics>> |
AsyncHBaseAdmin.getRegionMetrics(ServerName serverName) |
List<RegionMetrics> |
Admin.getRegionMetrics(ServerName serverName,
TableName tableName)
Get
RegionMetrics of all regions hosted on a regionserver for a table. |
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. |
CompletableFuture<List<RegionMetrics>> |
RawAsyncHBaseAdmin.getRegionMetrics(ServerName serverName,
TableName tableName) |
CompletableFuture<List<RegionMetrics>> |
AsyncHBaseAdmin.getRegionMetrics(ServerName serverName,
TableName tableName) |
List<RegionMetrics> |
HBaseAdmin.getRegionMetrics(ServerName serverName,
TableName tableName) |
List<RegionInfo> |
Admin.getRegions(ServerName serverName)
Get all the online regions on a region server.
|
CompletableFuture<List<RegionInfo>> |
AsyncAdmin.getRegions(ServerName serverName)
Get all the online regions on a region server.
|
CompletableFuture<List<RegionInfo>> |
RawAsyncHBaseAdmin.getRegions(ServerName serverName) |
CompletableFuture<List<RegionInfo>> |
AsyncHBaseAdmin.getRegions(ServerName serverName) |
List<RegionInfo> |
HBaseAdmin.getRegions(ServerName sn) |
Map<TableName,? extends SpaceQuotaSnapshotView> |
Admin.getRegionServerSpaceQuotaSnapshots(ServerName serverName)
Fetches the observed
SpaceQuotaSnapshotView s observed by a RegionServer. |
CompletableFuture<? extends Map<TableName,? extends SpaceQuotaSnapshotView>> |
AsyncAdmin.getRegionServerSpaceQuotaSnapshots(ServerName serverName)
Fetches the observed
SpaceQuotaSnapshotView s observed by a RegionServer. |
CompletableFuture<Map<TableName,SpaceQuotaSnapshot>> |
RawAsyncHBaseAdmin.getRegionServerSpaceQuotaSnapshots(ServerName serverName) |
CompletableFuture<Map<TableName,SpaceQuotaSnapshot>> |
AsyncHBaseAdmin.getRegionServerSpaceQuotaSnapshots(ServerName serverName) |
Map<TableName,SpaceQuotaSnapshot> |
HBaseAdmin.getRegionServerSpaceQuotaSnapshots(ServerName serverName) |
(package private) org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface |
AsyncConnectionImpl.getRegionServerStub(ServerName serverName) |
private CompletableFuture<List<LogEntry>> |
RawAsyncHBaseAdmin.getSlowLogResponseFromServer(ServerName serverName,
Map<String,Object> filterParams,
int limit,
String logType) |
private List<LogEntry> |
HBaseAdmin.getSlowLogResponseFromServer(ServerName serverName,
Map<String,Object> filterParams,
int limit,
String logType) |
ServerStatistics |
ServerStatisticTracker.getStats(ServerName server) |
(package private) static String |
ConnectionUtils.getStubKey(String serviceName,
ServerName serverName)
Get a unique key for the rpc stub to the given server.
|
protected void |
PreemptiveFastFailInterceptor.handleFailureToServer(ServerName serverName,
Throwable t)
Handles failures encountered when communicating with a server.
|
void |
PreemptiveFastFailInterceptor.handleThrowable(Throwable t1,
ServerName serverName,
org.apache.commons.lang3.mutable.MutableBoolean couldNotCommunicateWithServer,
org.apache.commons.lang3.mutable.MutableBoolean guaranteedClientSideOnly) |
(package private) void |
AsyncProcess.incTaskCounters(Collection<byte[]> regions,
ServerName sn) |
void |
RequestController.incTaskCounters(Collection<byte[]> regions,
ServerName sn)
Increment the counter if we build a valid task.
|
void |
SimpleRequestController.incTaskCounters(Collection<byte[]> regions,
ServerName sn) |
private boolean |
PreemptiveFastFailInterceptor.inFastFailMode(ServerName server)
Checks to see if we are in the Fast fail mode for requests to the server.
|
boolean |
ClusterStatusListener.isDeadServer(ServerName sn)
Check if we know if a server is dead.
|
private boolean |
ConnectionImplementation.isDeadServer(ServerName sn) |
protected boolean |
PreemptiveFastFailInterceptor.isServerInFailureMap(ServerName serverName) |
private void |
AsyncBatchRpcRetryingCaller.logException(int tries,
Supplier<Stream<AsyncBatchRpcRetryingCaller.RegionRequest>> regionsSupplier,
Throwable error,
ServerName serverName) |
private void |
AsyncRequestFutureImpl.logNoResubmit(ServerName oldServer,
int numAttempt,
int failureCount,
Throwable throwable,
int failed,
int stopped) |
void |
Admin.majorCompactRegionServer(ServerName serverName)
Major compact all regions on the region server.
|
CompletableFuture<Void> |
AsyncAdmin.majorCompactRegionServer(ServerName serverName)
Compact all regions on the region server.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.majorCompactRegionServer(ServerName sn) |
CompletableFuture<Void> |
AsyncHBaseAdmin.majorCompactRegionServer(ServerName serverName) |
void |
HBaseAdmin.majorCompactRegionServer(ServerName serverName) |
(package private) AsyncRequestFutureImpl.Retry |
AsyncRequestFutureImpl.manageError(int originalIndex,
Row row,
AsyncRequestFutureImpl.Retry canRetry,
Throwable throwable,
ServerName server)
Check that we can retry acts accordingly: logs, set the error status.
|
void |
Admin.move(byte[] encodedRegionName,
ServerName destServerName)
Move the region
rencodedRegionName to destServerName . |
CompletableFuture<Void> |
AsyncAdmin.move(byte[] regionName,
ServerName destServerName)
Move the region
r to dest . |
CompletableFuture<Void> |
RawAsyncHBaseAdmin.move(byte[] regionName,
ServerName destServerName) |
CompletableFuture<Void> |
AsyncHBaseAdmin.move(byte[] regionName,
ServerName destServerName) |
void |
HBaseAdmin.move(byte[] encodedRegionName,
ServerName destServerName) |
void |
ClusterStatusListener.DeadServerHandler.newDead(ServerName sn)
Called when a server is identified as dead.
|
private void |
AsyncBatchRpcRetryingCaller.onComplete(Action action,
AsyncBatchRpcRetryingCaller.RegionRequest regionReq,
int tries,
ServerName serverName,
MultiResponse.RegionResult regionResult,
List<Action> failedActions,
Throwable regionException,
org.apache.commons.lang3.mutable.MutableBoolean retryImmediately) |
private void |
AsyncBatchRpcRetryingCaller.onComplete(Map<byte[],AsyncBatchRpcRetryingCaller.RegionRequest> actionsByRegion,
int tries,
ServerName serverName,
MultiResponse resp) |
private void |
AsyncBatchRpcRetryingCaller.onError(Map<byte[],AsyncBatchRpcRetryingCaller.RegionRequest> actionsByRegion,
int tries,
Throwable t,
ServerName serverName) |
private void |
AsyncRequestFutureImpl.receiveGlobalFailure(MultiAction rsActions,
ServerName server,
int numAttempt,
Throwable t)
Resubmit all the actions from this multiaction after a failure.
|
private void |
AsyncRequestFutureImpl.receiveMultiAction(MultiAction multiAction,
ServerName server,
MultiResponse responses,
int numAttempt)
Called when we receive the result of a server query.
|
void |
Admin.recommissionRegionServer(ServerName server,
List<byte[]> encodedRegionNames)
Remove decommission marker from a region server to allow regions assignments.
|
CompletableFuture<Void> |
AsyncAdmin.recommissionRegionServer(ServerName server,
List<byte[]> encodedRegionNames)
Remove decommission marker from a region server to allow regions assignments.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.recommissionRegionServer(ServerName server,
List<byte[]> encodedRegionNames) |
CompletableFuture<Void> |
AsyncHBaseAdmin.recommissionRegionServer(ServerName server,
List<byte[]> encodedRegionNames) |
void |
HBaseAdmin.recommissionRegionServer(ServerName server,
List<byte[]> encodedRegionNames) |
(package private) void |
ConnectionImplementation.ServerErrorTracker.reportServerError(ServerName server)
Reports that there was an error on the server to do whatever bean-counting necessary.
|
void |
MultiServerCallable.reset(ServerName location,
MultiAction multiAction) |
private void |
AsyncRequestFutureImpl.resubmit(ServerName oldServer,
List<Action> toReplay,
int numAttempt,
int failureCount,
Throwable throwable)
Log as much info as possible, and, if there is something to replay, submit it again after a
back off sleep.
|
void |
Admin.rollWALWriter(ServerName serverName)
Roll the log writer.
|
CompletableFuture<Void> |
AsyncAdmin.rollWALWriter(ServerName serverName)
Roll the log writer.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.rollWALWriter(ServerName serverName) |
CompletableFuture<Void> |
AsyncHBaseAdmin.rollWALWriter(ServerName serverName) |
void |
HBaseAdmin.rollWALWriter(ServerName serverName) |
private org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.RollWALWriterResponse |
HBaseAdmin.rollWALWriterImpl(ServerName sn) |
private void |
AsyncBatchRpcRetryingCaller.sendToServer(ServerName serverName,
AsyncBatchRpcRetryingCaller.ServerRequest serverReq,
int tries) |
AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder<T> |
AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder.serverName(ServerName serverName) |
AsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder<T> |
AsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder.serverName(ServerName serverName) |
private void |
AsyncRequestFutureImpl.setError(int index,
Row row,
Throwable throwable,
ServerName server)
Sets the error from a particular action.
|
void |
FastFailInterceptorContext.setServer(ServerName server) |
protected abstract void |
RegionServerCallable.setStubByServiceName(ServerName serviceName)
Set the RCP client stub
|
protected void |
ClientServiceCallable.setStubByServiceName(ServerName serviceName) |
protected void |
CancellableRegionServerCallable.setStubByServiceName(ServerName serviceName) |
CompletableFuture<Void> |
AsyncAdmin.stopRegionServer(ServerName serverName)
Stop the designated regionserver.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.stopRegionServer(ServerName serverName) |
CompletableFuture<Void> |
AsyncHBaseAdmin.stopRegionServer(ServerName serverName) |
private CompletableFuture<Boolean> |
RawAsyncHBaseAdmin.switchCompact(ServerName serverName,
boolean onOrOff) |
private AsyncRequestFutureImpl.ReplicaResultState |
AsyncRequestFutureImpl.trySetResultSimple(int index,
Row row,
boolean isError,
Object result,
ServerName server,
boolean isFromReplica)
Tries to set the result or error for a particular action as if there were no replica calls.
|
(package private) void |
ConnectionImplementation.updateCachedLocation(RegionInfo hri,
ServerName source,
ServerName serverName,
long seqNum) |
private void |
AsyncRequestFutureImpl.updateCachedLocations(ServerName server,
byte[] regionName,
byte[] row,
Throwable rowException) |
void |
ClusterConnection.updateCachedLocations(TableName tableName,
byte[] regionName,
byte[] rowkey,
Object exception,
ServerName source)
Update the location cache.
|
void |
ConnectionImplementation.updateCachedLocations(TableName tableName,
byte[] regionName,
byte[] rowkey,
Object exception,
ServerName source)
Update the location with the new value (if the exception is a RegionMovedException) or delete
it from the cache.
|
void |
Admin.updateConfiguration(ServerName server)
Update the configuration and trigger an online config change on the regionserver.
|
CompletableFuture<Void> |
AsyncAdmin.updateConfiguration(ServerName serverName)
Update the configuration and trigger an online config change on the regionserver.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.updateConfiguration(ServerName serverName) |
CompletableFuture<Void> |
AsyncHBaseAdmin.updateConfiguration(ServerName serverName) |
void |
HBaseAdmin.updateConfiguration(ServerName server) |
private void |
PreemptiveFastFailInterceptor.updateFailureInfoForServer(ServerName server,
FailureInfo fInfo,
boolean didTry,
boolean couldNotCommunicate,
boolean retryDespiteFastFailMode)
This function updates the Failure info for a particular server after the attempt to nnnn
|
void |
StatisticTrackable.updateRegionStats(ServerName server,
byte[] region,
RegionLoadStats stats)
Update stats per region.
|
void |
ServerStatisticTracker.updateRegionStats(ServerName server,
byte[] region,
RegionLoadStats currentStats) |
void |
MetricsConnection.updateRegionStats(ServerName serverName,
byte[] regionName,
RegionLoadStats stats) |
void |
MetricsConnection.updateServerStats(ServerName serverName,
byte[] regionName,
Object r) |
(package private) static void |
ConnectionUtils.updateStats(Optional<ServerStatisticTracker> optStats,
Optional<MetricsConnection> optMetrics,
ServerName serverName,
MultiResponse resp) |
protected void |
AsyncRequestFutureImpl.updateStats(ServerName server,
MultiResponse resp) |
static void |
ResultStatsUtil.updateStats(StatisticTrackable tracker,
ServerName server,
byte[] regionName,
RegionLoadStats stats)
Update the statistics for the specified region.
|
Modifier and Type | Method and Description |
---|---|
(package private) static void |
AsyncProcess.addAction(ServerName server,
byte[] regionName,
Action action,
Map<ServerName,MultiAction> actionsByServer,
long nonceGroup)
Helper that is used when grouping the actions per region server.
|
private void |
AsyncRequestFutureImpl.ReplicaCallIssuingRunnable.addReplicaActions(int index,
Map<ServerName,MultiAction> actionsByServer,
List<Action> unknownReplicaActions)
Add replica actions to action map by server.
|
private void |
AsyncRequestFutureImpl.ReplicaCallIssuingRunnable.addReplicaActionsAgain(Action action,
Map<ServerName,MultiAction> actionsByServer) |
List<ServerName> |
Admin.clearDeadServers(List<ServerName> servers)
Clear dead region servers from master.
|
CompletableFuture<List<ServerName>> |
AsyncAdmin.clearDeadServers(List<ServerName> servers)
Clear dead region servers from master.
|
CompletableFuture<List<ServerName>> |
RawAsyncHBaseAdmin.clearDeadServers(List<ServerName> servers) |
CompletableFuture<List<ServerName>> |
AsyncHBaseAdmin.clearDeadServers(List<ServerName> servers) |
List<ServerName> |
HBaseAdmin.clearDeadServers(List<ServerName> servers) |
List<Boolean> |
Admin.clearSlowLogResponses(Set<ServerName> serverNames)
Clears online slow/large RPC logs from the provided list of RegionServers
|
CompletableFuture<List<Boolean>> |
AsyncAdmin.clearSlowLogResponses(Set<ServerName> serverNames)
Clears online slow RPC logs from the provided list of RegionServers
|
CompletableFuture<List<Boolean>> |
RawAsyncHBaseAdmin.clearSlowLogResponses(Set<ServerName> serverNames) |
CompletableFuture<List<Boolean>> |
AsyncHBaseAdmin.clearSlowLogResponses(Set<ServerName> serverNames) |
List<Boolean> |
HBaseAdmin.clearSlowLogResponses(Set<ServerName> serverNames) |
void |
Admin.decommissionRegionServers(List<ServerName> servers,
boolean offload)
Mark region server(s) as decommissioned to prevent additional regions from getting assigned to
them.
|
CompletableFuture<Void> |
AsyncAdmin.decommissionRegionServers(List<ServerName> servers,
boolean offload)
Mark region server(s) as decommissioned to prevent additional regions from getting assigned to
them.
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.decommissionRegionServers(List<ServerName> servers,
boolean offload) |
CompletableFuture<Void> |
AsyncHBaseAdmin.decommissionRegionServers(List<ServerName> servers,
boolean offload) |
void |
HBaseAdmin.decommissionRegionServers(List<ServerName> servers,
boolean offload) |
List<LogEntry> |
Admin.getLogEntries(Set<ServerName> serverNames,
String logType,
ServerType serverType,
int limit,
Map<String,Object> filterParams)
Retrieve recent online records from HMaster / RegionServers.
|
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.
|
CompletableFuture<List<LogEntry>> |
RawAsyncHBaseAdmin.getLogEntries(Set<ServerName> serverNames,
String logType,
ServerType serverType,
int limit,
Map<String,Object> filterParams) |
CompletableFuture<List<LogEntry>> |
AsyncHBaseAdmin.getLogEntries(Set<ServerName> serverNames,
String logType,
ServerType serverType,
int limit,
Map<String,Object> filterParams) |
List<LogEntry> |
HBaseAdmin.getLogEntries(Set<ServerName> serverNames,
String logType,
ServerType serverType,
int limit,
Map<String,Object> filterParams) |
private CompletableFuture<List<LogEntry>> |
RawAsyncHBaseAdmin.getSlowLogResponses(Map<String,Object> filterParams,
Set<ServerName> serverNames,
int limit,
String logType) |
private List<LogEntry> |
HBaseAdmin.getSlowLogResponses(Map<String,Object> filterParams,
Set<ServerName> serverNames,
int limit,
String logType) |
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. |
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. |
private <T extends org.apache.hbase.thirdparty.com.google.protobuf.Message> |
AbstractRpcBasedConnectionRegistry.groupCall(CompletableFuture<T> future,
Set<ServerName> servers,
List<org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.ClientMetaService.Interface> stubs,
int startIndexInclusive,
AbstractRpcBasedConnectionRegistry.Callable<T> callable,
Predicate<T> isValidResp,
String debug,
ConcurrentLinkedQueue<Throwable> errors)
send requests concurrently to hedgedReadsFanout end points.
|
private void |
AbstractRpcBasedConnectionRegistry.populateStubs(Set<ServerName> addrs) |
List<Long> |
HBaseHbck.scheduleServerCrashProcedures(List<ServerName> serverNames) |
List<Long> |
Hbck.scheduleServerCrashProcedures(List<ServerName> serverNames) |
(package private) void |
AsyncRequestFutureImpl.sendMultiAction(Map<ServerName,MultiAction> actionsByServer,
int numAttempt,
List<Action> actionsForReplicaThread,
boolean reuseThread)
Send a multi action structure to the servers, after a delay depending on the attempt number.
|
private void |
AsyncBatchRpcRetryingCaller.sendOrDelay(Map<ServerName,AsyncBatchRpcRetryingCaller.ServerRequest> actionsByServer,
int tries) |
(package private) <CResult> AsyncRequestFuture |
AsyncProcess.submitMultiActions(AsyncProcessTask task,
List<Action> retainedActions,
long nonceGroup,
List<Exception> locationErrors,
List<Integer> locationErrorRows,
Map<ServerName,MultiAction> actionsByServer) |
Constructor and Description |
---|
AsyncAdminRequestRetryingCaller(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer,
AsyncConnectionImpl conn,
int priority,
long pauseNs,
long pauseNsForServerOverloaded,
int maxAttempts,
long operationTimeoutNs,
long rpcTimeoutNs,
int startLogErrorsCnt,
ServerName serverName,
AsyncAdminRequestRetryingCaller.Callable<T> callable) |
AsyncServerRequestRpcRetryingCaller(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer,
AsyncConnectionImpl conn,
long pauseNs,
long pauseNsForServerOverloaded,
int maxAttempts,
long operationTimeoutNs,
long rpcTimeoutNs,
int startLogErrorsCnt,
ServerName serverName,
AsyncServerRequestRpcRetryingCaller.Callable<T> callable) |
MultiServerCallable(ClusterConnection connection,
TableName tableName,
ServerName location,
MultiAction multi,
org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController,
int rpcTimeout,
RetryingTimeTracker tracker,
int priority) |
ShortCircuitingClusterConnection(org.apache.hadoop.conf.Configuration conf,
User user,
ServerName serverName,
org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface admin,
org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface client,
ConnectionRegistry registry) |
SingleServerRequestRunnable(MultiAction multiAction,
int numAttempt,
ServerName server,
Set<CancellableRegionServerCallable> callsInProgress) |
Constructor and Description |
---|
TaskCountChecker(int maxTotalConcurrentTasks,
int maxConcurrentTasksPerServer,
int maxConcurrentTasksPerRegion,
AtomicLong tasksInProgress,
Map<ServerName,AtomicInteger> taskCounterPerServer,
Map<byte[],AtomicInteger> taskCounterPerRegion) |
Modifier and Type | Method and Description |
---|---|
long |
ClientBackoffPolicyFactory.NoBackoffPolicy.getBackoffTime(ServerName serverName,
byte[] region,
ServerStatistics stats) |
long |
ClientBackoffPolicy.getBackoffTime(ServerName serverName,
byte[] region,
ServerStatistics stats)
Returns the number of ms to wait on the client based on the
|
long |
ExponentialClientBackoffPolicy.getBackoffTime(ServerName serverName,
byte[] region,
ServerStatistics stats) |
Modifier and Type | Field and Description |
---|---|
private ServerName |
ZkSplitLogWorkerCoordination.serverName |
Modifier and Type | Method and Description |
---|---|
ServerName |
SplitLogManagerCoordination.SplitLogManagerDetails.getServerName()
Returns server name
|
Modifier and Type | Method and Description |
---|---|
protected static int |
ZkSplitLogWorkerCoordination.attemptToOwnTask(boolean isFirstTime,
ZKWatcher zkw,
ServerName server,
String task,
int taskZKVersion)
Try to own the task by transitioning the zk node data from UNASSIGNED to OWNED.
|
ZKSplitLogManagerCoordination.TaskFinisher.Status |
ZKSplitLogManagerCoordination.TaskFinisher.finish(ServerName workerName,
String taskname)
finish the partially done task.
|
private void |
ZKSplitLogManagerCoordination.heartbeat(String path,
int new_version,
ServerName workerName) |
Constructor and Description |
---|
ZkSplitLogWorkerCoordination(ServerName serverName,
ZKWatcher watcher) |
Modifier and Type | Method and Description |
---|---|
ServerName |
MasterCoprocessorEnvironment.getServerName()
Returns Hosting Server's ServerName
|
ServerName |
RegionCoprocessorEnvironment.getServerName()
Returns Hosting Server's ServerName
|
ServerName |
RegionServerCoprocessorEnvironment.getServerName()
Returns Hosting Server's ServerName
|
Modifier and Type | Method and Description |
---|---|
default void |
MasterObserver.postMove(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo region,
ServerName srcServer,
ServerName destServer)
Called after the region move has been requested.
|
default void |
MasterObserver.postRecommissionRegionServer(ObserverContext<MasterCoprocessorEnvironment> ctx,
ServerName server,
List<byte[]> encodedRegionNames)
Called after recommission region server.
|
default void |
MasterObserver.preMove(ObserverContext<MasterCoprocessorEnvironment> ctx,
RegionInfo region,
ServerName srcServer,
ServerName destServer)
Called prior to moving a given region from one region server to another.
|
default void |
MasterObserver.preRecommissionRegionServer(ObserverContext<MasterCoprocessorEnvironment> ctx,
ServerName server,
List<byte[]> encodedRegionNames)
Called before recommission region server.
|
Modifier and Type | Method and Description |
---|---|
default void |
MasterObserver.postClearDeadServers(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<ServerName> servers,
List<ServerName> notClearedServers)
Called after clear dead region servers.
|
default void |
MasterObserver.postClearDeadServers(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<ServerName> servers,
List<ServerName> notClearedServers)
Called after clear dead region servers.
|
default void |
MasterObserver.postDecommissionRegionServers(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<ServerName> servers,
boolean offload)
Called after decommission region servers.
|
default void |
MasterObserver.preDecommissionRegionServers(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<ServerName> servers,
boolean offload)
Called before decommission region servers.
|
Modifier and Type | Method and Description |
---|---|
ServerName |
RegionMovedException.getServerName() |
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.
|
RegionMovedException(ServerName serverName,
long locationSeqNum) |
Constructor and Description |
---|
MasterRegistryFetchException(Set<ServerName> masters,
Throwable failure) |
Modifier and Type | Class and Description |
---|---|
(package private) class |
StartcodeAgnosticServerName
This class differs from ServerName in that start code is always ignored.
|
Modifier and Type | Field and Description |
---|---|
private Map<String,List<ServerName>> |
FavoredNodesPlan.favoredNodesMap
The map between each region name and its favored region server list
|
private Map<ServerName,List<RegionInfo>> |
FavoredNodesManager.primaryRSToRegionMap |
private Map<String,List<ServerName>> |
FavoredNodeAssignmentHelper.rackToRegionServerMap |
private Map<ServerName,List<RegionInfo>> |
FavoredNodesManager.secondaryRSToRegionMap |
private List<ServerName> |
FavoredNodeAssignmentHelper.servers |
private Map<ServerName,List<RegionInfo>> |
FavoredNodesManager.teritiaryRSToRegionMap |
Modifier and Type | Method and Description |
---|---|
private ServerName |
FavoredNodeLoadBalancer.availableServersContains(List<ServerName> servers,
ServerName favoredNode) |
ServerName |
FavoredNodeAssignmentHelper.generateMissingFavoredNode(List<ServerName> favoredNodes) |
ServerName |
FavoredNodeAssignmentHelper.generateMissingFavoredNode(List<ServerName> favoredNodes,
List<ServerName> excludeNodes) |
private ServerName |
FavoredNodeAssignmentHelper.generateMissingFavoredNodeMultiRack(List<ServerName> favoredNodes) |
private ServerName |
FavoredNodeAssignmentHelper.generateMissingFavoredNodeMultiRack(List<ServerName> favoredNodes,
List<ServerName> excludeNodes) |
private ServerName |
FavoredNodeAssignmentHelper.generateMissingFavoredNodeSingleRack(List<ServerName> favoredNodes,
List<ServerName> excludeNodes) |
static ServerName[] |
FavoredNodeAssignmentHelper.getFavoredNodesList(byte[] favoredNodes)
Convert PB bytes to ServerName.
|
private ServerName |
FavoredNodeAssignmentHelper.getOneRandomServer(String rack) |
protected ServerName |
FavoredNodeAssignmentHelper.getOneRandomServer(String rack,
Set<ServerName> skipServerSet)
Gets a random server from the specified rack and skips anything specified.
|
ServerName[] |
FavoredNodeAssignmentHelper.getSecondaryAndTertiary(RegionInfo regionInfo,
ServerName primaryRS) |
private ServerName[] |
FavoredNodeAssignmentHelper.multiRackCase(ServerName primaryRS,
String primaryRack)
Place secondary and tertiary nodes in a multi rack case.
|
private ServerName[] |
FavoredNodeAssignmentHelper.multiRackCaseWithRestrictions(Map<ServerName,Set<RegionInfo>> serverToPrimaries,
Map<RegionInfo,ServerName[]> secondaryAndTertiaryMap,
String primaryRack,
ServerName primaryRS,
RegionInfo regionInfo) |
ServerName |
FavoredNodeLoadBalancer.randomAssignment(RegionInfo regionInfo,
List<ServerName> servers) |
private ServerName[] |
FavoredNodeAssignmentHelper.singleRackCase(RegionInfo regionInfo,
ServerName primaryRS,
String primaryRack) |
Modifier and Type | Method and Description |
---|---|
private Map<RegionInfo,List<ServerName>> |
FavoredNodeAssignmentHelper.generateFavoredNodes(Map<RegionInfo,ServerName> primaryRSMap) |
List<ServerName> |
FavoredNodeAssignmentHelper.generateFavoredNodes(RegionInfo hri) |
Map<RegionInfo,List<ServerName>> |
FavoredNodeAssignmentHelper.generateFavoredNodesRoundRobin(Map<ServerName,List<RegionInfo>> assignmentMap,
List<RegionInfo> regions) |
Map<String,List<ServerName>> |
FavoredNodesPlan.getAssignmentMap()
Return the mapping between each region to its favored region server list.
|
List<ServerName> |
FavoredNodesPlan.getFavoredNodes(RegionInfo region)
Returns the list of favored region server for this region based on the plan
|
List<ServerName> |
FavoredNodeLoadBalancer.getFavoredNodes(RegionInfo regionInfo) |
List<ServerName> |
FavoredNodesManager.getFavoredNodes(RegionInfo regionInfo) |
List<ServerName> |
FavoredNodesManager.getFavoredNodesWithDNPort(RegionInfo regionInfo) |
private Set<ServerName> |
FavoredNodeLoadBalancer.getInheritedFNForDaughter(FavoredNodeAssignmentHelper helper,
List<ServerName> parentFavoredNodes,
FavoredNodesPlan.Position primary,
FavoredNodesPlan.Position secondary) |
Map<ServerName,List<Integer>> |
FavoredNodesManager.getReplicaLoad(List<ServerName> servers) |
private List<ServerName> |
FavoredNodeAssignmentHelper.getServersFromRack(String rack) |
private Map<ServerName,Set<RegionInfo>> |
FavoredNodeAssignmentHelper.mapRSToPrimaries(Map<RegionInfo,ServerName> primaryRSMap) |
(package private) List<ServerName> |
FavoredNodesPlan.removeFavoredNodes(RegionInfo region)
Remove a favored node assignment
|
Map<ServerName,List<RegionInfo>> |
FavoredNodeLoadBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers) |
private Pair<Map<ServerName,List<RegionInfo>>,List<RegionInfo>> |
FavoredNodeLoadBalancer.segregateRegionsAndAssignRegionsWithFavoredNodes(List<RegionInfo> regions,
List<ServerName> availableServers) |
Modifier and Type | Method and Description |
---|---|
private void |
FavoredNodeLoadBalancer.addRegionToMap(Map<ServerName,List<RegionInfo>> assignmentMapForFavoredNodes,
RegionInfo region,
ServerName host) |
private void |
FavoredNodeLoadBalancer.assignRegionToAvailableFavoredNode(Map<ServerName,List<RegionInfo>> assignmentMapForFavoredNodes,
RegionInfo region,
ServerName primaryHost,
ServerName secondaryHost,
ServerName tertiaryHost) |
private ServerName |
FavoredNodeLoadBalancer.availableServersContains(List<ServerName> servers,
ServerName favoredNode) |
int |
StartcodeAgnosticServerName.compareTo(ServerName other) |
static FavoredNodesPlan.Position |
FavoredNodesPlan.getFavoredServerPosition(List<ServerName> favoredNodes,
ServerName server)
Return the position of the server in the favoredNodes list.
|
private String |
FavoredNodeAssignmentHelper.getRackOfServer(ServerName sn) |
Set<RegionInfo> |
FavoredNodesManager.getRegionsOfFavoredNode(ServerName serverName) |
ServerName[] |
FavoredNodeAssignmentHelper.getSecondaryAndTertiary(RegionInfo regionInfo,
ServerName primaryRS) |
private ServerName[] |
FavoredNodeAssignmentHelper.multiRackCase(ServerName primaryRS,
String primaryRack)
Place secondary and tertiary nodes in a multi rack case.
|
private ServerName[] |
FavoredNodeAssignmentHelper.multiRackCaseWithRestrictions(Map<ServerName,Set<RegionInfo>> serverToPrimaries,
Map<RegionInfo,ServerName[]> secondaryAndTertiaryMap,
String primaryRack,
ServerName primaryRS,
RegionInfo regionInfo) |
private ServerName[] |
FavoredNodeAssignmentHelper.singleRackCase(RegionInfo regionInfo,
ServerName primaryRS,
String primaryRack) |
static StartcodeAgnosticServerName |
StartcodeAgnosticServerName.valueOf(ServerName serverName) |
Modifier and Type | Method and Description |
---|---|
private void |
FavoredNodeLoadBalancer.addRegionToMap(Map<ServerName,List<RegionInfo>> assignmentMapForFavoredNodes,
RegionInfo region,
ServerName host) |
private void |
FavoredNodesManager.addToReplicaLoad(RegionInfo hri,
List<ServerName> servers) |
private void |
FavoredNodeLoadBalancer.assignRegionToAvailableFavoredNode(Map<ServerName,List<RegionInfo>> assignmentMapForFavoredNodes,
RegionInfo region,
ServerName primaryHost,
ServerName secondaryHost,
ServerName tertiaryHost) |
private void |
FavoredNodeLoadBalancer.assignSecondaryAndTertiaryNodesForRegion(FavoredNodeAssignmentHelper assignmentHelper,
List<RegionInfo> regions,
Map<RegionInfo,ServerName> primaryRSMap) |
private ServerName |
FavoredNodeLoadBalancer.availableServersContains(List<ServerName> servers,
ServerName favoredNode) |
protected List<RegionPlan> |
FavoredNodeLoadBalancer.balanceTable(TableName tableName,
Map<ServerName,List<RegionInfo>> loadOfOneTable) |
private Map<RegionInfo,List<ServerName>> |
FavoredNodeAssignmentHelper.generateFavoredNodes(Map<RegionInfo,ServerName> primaryRSMap) |
void |
FavoredNodeLoadBalancer.generateFavoredNodesForDaughter(List<ServerName> servers,
RegionInfo parent,
RegionInfo regionA,
RegionInfo regionB) |
void |
FavoredNodesPromoter.generateFavoredNodesForDaughter(List<ServerName> servers,
RegionInfo parent,
RegionInfo hriA,
RegionInfo hriB) |
Map<RegionInfo,List<ServerName>> |
FavoredNodeAssignmentHelper.generateFavoredNodesRoundRobin(Map<ServerName,List<RegionInfo>> assignmentMap,
List<RegionInfo> regions) |
ServerName |
FavoredNodeAssignmentHelper.generateMissingFavoredNode(List<ServerName> favoredNodes) |
ServerName |
FavoredNodeAssignmentHelper.generateMissingFavoredNode(List<ServerName> favoredNodes,
List<ServerName> excludeNodes) |
ServerName |
FavoredNodeAssignmentHelper.generateMissingFavoredNode(List<ServerName> favoredNodes,
List<ServerName> excludeNodes) |
private ServerName |
FavoredNodeAssignmentHelper.generateMissingFavoredNodeMultiRack(List<ServerName> favoredNodes) |
private ServerName |
FavoredNodeAssignmentHelper.generateMissingFavoredNodeMultiRack(List<ServerName> favoredNodes,
List<ServerName> excludeNodes) |
private ServerName |
FavoredNodeAssignmentHelper.generateMissingFavoredNodeMultiRack(List<ServerName> favoredNodes,
List<ServerName> excludeNodes) |
private ServerName |
FavoredNodeAssignmentHelper.generateMissingFavoredNodeSingleRack(List<ServerName> favoredNodes,
List<ServerName> excludeNodes) |
private ServerName |
FavoredNodeAssignmentHelper.generateMissingFavoredNodeSingleRack(List<ServerName> favoredNodes,
List<ServerName> excludeNodes) |
static byte[] |
FavoredNodeAssignmentHelper.getFavoredNodes(List<ServerName> serverAddrList)
n * @return PB'ed bytes of
HBaseProtos.FavoredNodes generated by the server list. |
static String |
FavoredNodeAssignmentHelper.getFavoredNodesAsString(List<ServerName> nodes) |
static FavoredNodesPlan.Position |
FavoredNodesPlan.getFavoredServerPosition(List<ServerName> favoredNodes,
ServerName server)
Return the position of the server in the favoredNodes list.
|
private Set<ServerName> |
FavoredNodeLoadBalancer.getInheritedFNForDaughter(FavoredNodeAssignmentHelper helper,
List<ServerName> parentFavoredNodes,
FavoredNodesPlan.Position primary,
FavoredNodesPlan.Position secondary) |
protected ServerName |
FavoredNodeAssignmentHelper.getOneRandomServer(String rack,
Set<ServerName> skipServerSet)
Gets a random server from the specified rack and skips anything specified.
|
Map<ServerName,List<Integer>> |
FavoredNodesManager.getReplicaLoad(List<ServerName> servers) |
private static Put |
FavoredNodeAssignmentHelper.makePut(RegionInfo regionInfo,
List<ServerName> favoredNodeList) |
private Map<ServerName,Set<RegionInfo>> |
FavoredNodeAssignmentHelper.mapRSToPrimaries(Map<RegionInfo,ServerName> primaryRSMap) |
private ServerName[] |
FavoredNodeAssignmentHelper.multiRackCaseWithRestrictions(Map<ServerName,Set<RegionInfo>> serverToPrimaries,
Map<RegionInfo,ServerName[]> secondaryAndTertiaryMap,
String primaryRack,
ServerName primaryRS,
RegionInfo regionInfo) |
void |
FavoredNodeAssignmentHelper.placePrimaryRSAsRoundRobin(Map<ServerName,List<RegionInfo>> assignmentMap,
Map<RegionInfo,ServerName> primaryRSMap,
List<RegionInfo> regions) |
void |
FavoredNodeAssignmentHelper.placePrimaryRSAsRoundRobin(Map<ServerName,List<RegionInfo>> assignmentMap,
Map<RegionInfo,ServerName> primaryRSMap,
List<RegionInfo> regions) |
Map<RegionInfo,ServerName[]> |
FavoredNodeAssignmentHelper.placeSecondaryAndTertiaryRS(Map<RegionInfo,ServerName> primaryRSMap) |
Map<RegionInfo,ServerName[]> |
FavoredNodeAssignmentHelper.placeSecondaryAndTertiaryWithRestrictions(Map<RegionInfo,ServerName> primaryRSMap)
For regions that share the primary, avoid placing the secondary and tertiary on a same RS.
|
ServerName |
FavoredNodeLoadBalancer.randomAssignment(RegionInfo regionInfo,
List<ServerName> servers) |
Map<ServerName,List<RegionInfo>> |
FavoredNodeLoadBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers) |
private void |
FavoredNodeLoadBalancer.roundRobinAssignmentImpl(FavoredNodeAssignmentHelper assignmentHelper,
Map<ServerName,List<RegionInfo>> assignmentMap,
List<RegionInfo> regions,
List<ServerName> servers) |
private void |
FavoredNodeLoadBalancer.roundRobinAssignmentImpl(FavoredNodeAssignmentHelper assignmentHelper,
Map<ServerName,List<RegionInfo>> assignmentMap,
List<RegionInfo> regions,
List<ServerName> servers) |
private Pair<Map<ServerName,List<RegionInfo>>,List<RegionInfo>> |
FavoredNodeLoadBalancer.segregateRegionsAndAssignRegionsWithFavoredNodes(List<RegionInfo> regions,
List<ServerName> availableServers) |
void |
FavoredNodesManager.updateFavoredNodes(Map<RegionInfo,List<ServerName>> regionFNMap) |
void |
FavoredNodesPlan.updateFavoredNodesMap(RegionInfo region,
List<ServerName> servers)
Update an assignment to the plan
|
static void |
FavoredNodeAssignmentHelper.updateMetaWithFavoredNodesInfo(Map<RegionInfo,List<ServerName>> regionToFavoredNodes,
org.apache.hadoop.conf.Configuration conf)
Update meta table with favored nodes info
|
static void |
FavoredNodeAssignmentHelper.updateMetaWithFavoredNodesInfo(Map<RegionInfo,List<ServerName>> regionToFavoredNodes,
Connection connection)
Update meta table with favored nodes info
|
Constructor and Description |
---|
FavoredNodeAssignmentHelper(List<ServerName> servers,
org.apache.hadoop.conf.Configuration conf) |
FavoredNodeAssignmentHelper(List<ServerName> servers,
RackManager rackManager) |
Modifier and Type | Method and Description |
---|---|
void |
RpcClient.cancelConnections(ServerName sn)
Interrupt the connections to the given server.
|
void |
AbstractRpcClient.cancelConnections(ServerName sn)
Interrupt the connections to the given ip:port server.
|
private static Address |
AbstractRpcClient.createAddr(ServerName sn) |
org.apache.hbase.thirdparty.com.google.protobuf.BlockingRpcChannel |
RpcClient.createBlockingRpcChannel(ServerName sn,
User user,
int rpcTimeout)
Creates a "channel" that can be used by a blocking protobuf service.
|
org.apache.hbase.thirdparty.com.google.protobuf.BlockingRpcChannel |
AbstractRpcClient.createBlockingRpcChannel(ServerName sn,
User ticket,
int rpcTimeout) |
org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel |
RpcClient.createRpcChannel(ServerName sn,
User user,
int rpcTimeout)
Creates a "channel" that can be used by a protobuf service.
|
org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel |
AbstractRpcClient.createRpcChannel(ServerName sn,
User user,
int rpcTimeout) |
Modifier and Type | Method and Description |
---|---|
private Set<ServerName> |
RegionSizeCalculator.getRegionServersOfTable(RegionLocator regionLocator) |
Modifier and Type | Field and Description |
---|---|
(package private) ServerName |
ActiveMasterManager.activeMasterServerName |
static ServerName |
LoadBalancer.BOGUS_SERVER_NAME |
ServerName |
SplitLogManager.Task.cur_worker_name |
private ServerName |
RegionPlan.dest |
private ServerName |
RegionState.serverName |
(package private) ServerName |
ActiveMasterManager.sn |
private ServerName |
RegionPlan.source |
Modifier and Type | Field and Description |
---|---|
private org.apache.hbase.thirdparty.com.google.common.collect.ImmutableList<ServerName> |
ActiveMasterManager.backupMasters |
private Map<ServerName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.currentRSToRegionMap
the regionServer to region map
|
private Map<ServerName,Integer> |
SplitWALManager.SplitWorkerAssigner.currentWorkers |
private Map<ServerName,Long> |
DeadServer.deadServers
Set of known dead servers.
|
private Set<ServerName> |
SplitLogManager.deadWorkers
Deprecated.
|
private ArrayList<ServerName> |
ServerManager.drainingServers
List of region servers that should not get any more new regions.
|
private NavigableSet<ServerName> |
DrainingServerTracker.drainingServers |
private ConcurrentMap<ServerName,Integer> |
ClusterStatusPublisher.lastSent |
private Set<ServerName> |
AssignmentVerificationReport.leastLoadedRSSet |
private Set<ServerName> |
AssignmentVerificationReport.maxDispersionNumServerSet |
private Set<ServerName> |
AssignmentVerificationReport.maxDispersionScoreServerSet |
private Set<ServerName> |
AssignmentVerificationReport.minDispersionNumServerSet |
private Set<ServerName> |
AssignmentVerificationReport.minDispersionScoreServerSet |
private Set<ServerName> |
AssignmentVerificationReport.mostLoadedRSSet |
private ConcurrentNavigableMap<ServerName,ServerMetrics> |
ServerManager.onlineServers
Map of registered servers to their current load
|
private Map<ServerName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.primaryRSToRegionMap |
private Set<ServerName> |
DeadServer.processingServers
Set of dead servers currently being processed by a SCP.
|
private Set<ServerName> |
RegionServerTracker.regionServers |
private Map<RegionInfo,ServerName> |
SnapshotOfRegionAssignmentFromMeta.regionToRegionServerMap
the region to region server map
|
private Map<ServerName,org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface> |
ServerManager.rsAdmins
Map of admin interfaces per registered regionserver; these interfaces we use to control
regionservers out on the cluster
|
private Map<ServerName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.secondaryRSToRegionMap |
private Map<ServerName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.teritiaryRSToRegionMap |
Modifier and Type | Method and Description |
---|---|
ServerName |
SplitWALManager.acquireSplitWALWorker(Procedure<?> procedure)
Acquire a split WAL worker
|
private ServerName |
ServerManager.findServerWithSameHostnamePortWithLock(ServerName serverName)
Assumes onlineServers is locked.
|
ServerName |
RegionPlan.getDestination()
Get the destination server for the plan for this region.
|
ServerName |
MasterCoprocessorHost.MasterEnvironment.getServerName() |
ServerName |
HMaster.getServerName() |
ServerName |
RegionState.getServerName() |
ServerName |
RegionPlan.getSource()
Get the source server for the plan for this region.
|
ServerName |
LoadBalancer.randomAssignment(RegionInfo regionInfo,
List<ServerName> servers)
Get a random region server from the list
|
(package private) ServerName |
ServerManager.regionServerStartup(org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest request,
int versionNumber,
String version,
InetAddress ia)
Let the server manager know a new regionserver has come online
|
Modifier and Type | Method and Description |
---|---|
Optional<ServerName> |
SplitWALManager.SplitWorkerAssigner.acquire() |
(package private) List<Pair<ServerName,Long>> |
DeadServer.copyDeadServersSince(long ts)
Extract all the servers dead since a given time, and sort them.
|
Set<ServerName> |
DeadServer.copyServerNames() |
List<ServerName> |
ServerManager.createDestinationServersList()
Calls
ServerManager.createDestinationServersList(java.util.List<org.apache.hadoop.hbase.ServerName>) without server to exclude. |
List<ServerName> |
ServerManager.createDestinationServersList(List<ServerName> serversToExclude)
Creates a list of possible destinations for a region.
|
protected List<ServerName> |
ClusterStatusPublisher.generateDeadServersListToSend()
Create the dead server to send.
|
Optional<ServerName> |
HMaster.getActiveMaster() |
Optional<ServerName> |
ActiveMasterManager.getActiveMasterServerName() |
Set<ServerName> |
MasterRegionServerList.getAll() |
Set<ServerName> |
RegionServerList.getAll()
Get all live region servers.
|
List<ServerName> |
ActiveMasterManager.getBackupMasters()
Returns list of registered backup masters.
|
List<ServerName> |
HMaster.getBackupMasters() |
protected List<Pair<ServerName,Long>> |
ClusterStatusPublisher.getDeadServers(long since)
Get the servers which died since a given timestamp.
|
List<ServerName> |
ServerManager.getDrainingServersList()
Returns A copy of the internal list of draining servers.
|
Set<ServerName> |
MasterWalManager.getFailedServersFromLogFolders()
Deprecated.
With proc-v2, we can record the crash server with procedure store, so do not need
to scan the wal directory to find out the splitting wal directory any more. Leave
it here only because
RecoverMetaProcedure (which is also deprecated) uses
it. |
static List<ServerName> |
RegionPlacementMaintainer.getFavoredNodeList(String favoredNodesStr) |
Collection<ServerName> |
HMaster.getLiveRegionServers() |
Set<ServerName> |
MasterWalManager.getLiveServersFromWALDir()
Get Servernames that COULD BE 'alive'; excludes those that have a '-splitting' suffix as these
are already being split -- they cannot be 'alive'.
|
private Map<ServerName,ServerMetrics> |
HMaster.getOnlineServers() |
Map<ServerName,ServerMetrics> |
ServerManager.getOnlineServers()
Returns Read-only map of servers to serverinfo
|
List<ServerName> |
ServerManager.getOnlineServersList()
Returns A copy of the internal list of online servers.
|
List<ServerName> |
ServerManager.getOnlineServersListWithPredicator(List<ServerName> keys,
Predicate<ServerMetrics> idleServerPredicator) |
Map<ServerName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.getPrimaryToRegionInfoMap() |
Set<ServerName> |
RegionServerTracker.getRegionServers() |
Iterator<ServerName> |
HMaster.getRegionServers() |
Map<ServerName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.getRegionServerToRegionMap()
Get regionserver to region map
|
Map<RegionInfo,ServerName> |
SnapshotOfRegionAssignmentFromMeta.getRegionToRegionServerMap()
Get region to region server map
|
HashMap<String,List<Pair<ServerName,ReplicationLoadSource>>> |
HMaster.getReplicationLoad(ServerName[] serverNames) |
Map<ServerName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.getSecondaryToRegionInfoMap() |
Set<ServerName> |
MasterWalManager.getServerNamesFromWALDirPath(org.apache.hadoop.fs.PathFilter filter)
Returns listing of ServerNames found by parsing WAL directory paths in FS.
|
Set<ServerName> |
MasterWalManager.getSplittingServersFromWALDir()
Get Servernames which are currently splitting; paths have a '-splitting' suffix.
|
Map<ServerName,List<RegionInfo>> |
SnapshotOfRegionAssignmentFromMeta.getTertiaryToRegionInfoMap() |
private List<ServerName> |
HMaster.getUnknownServers() |
List<ServerName> |
HMaster.listDecommissionedRegionServers()
List region servers marked as decommissioned (previously called 'draining') to not get regions
assigned to them.
|
Map<ServerName,List<RegionInfo>> |
LoadBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers)
Assign regions to the previously hosting region server nn * @return List of plans
|
Map<ServerName,List<RegionInfo>> |
LoadBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers)
Perform a Round Robin assignment of regions.
|
Modifier and Type | Method and Description |
---|---|
private void |
SnapshotOfRegionAssignmentFromMeta.addAssignment(RegionInfo regionInfo,
ServerName server) |
private void |
SnapshotOfRegionAssignmentFromMeta.addPrimaryAssignment(RegionInfo regionInfo,
ServerName server) |
private void |
SnapshotOfRegionAssignmentFromMeta.addSecondaryAssignment(RegionInfo regionInfo,
ServerName server) |
boolean |
ServerManager.addServerToDrainList(ServerName sn)
Add the server to the drain list.
|
private void |
SnapshotOfRegionAssignmentFromMeta.addTeritiaryAssignment(RegionInfo regionInfo,
ServerName server) |
void |
SplitWALManager.addUsedSplitWALWorker(ServerName worker)
When master restart, there will be a new splitWorkerAssigner.
|
void |
SplitWALManager.SplitWorkerAssigner.addUsedWorker(ServerName worker) |
void |
MasterWalManager.archiveMetaLog(ServerName serverName)
The hbase:meta region may OPEN and CLOSE without issue on a server and then move elsewhere.
|
(package private) boolean |
ServerManager.checkAndRecordNewServer(ServerName serverName,
ServerMetrics sl)
Check is a server of same host and port already exists, if not, or the existed one got a
smaller start code, record it.
|
private void |
ServerManager.checkClockSkew(ServerName serverName,
long serverCurrentTime)
Checks if the clock skew between the server and the master.
|
private void |
ServerManager.checkIsDead(ServerName serverName,
String what)
Called when RegionServer first reports in for duty and thereafter each time it heartbeats to
make sure it is has not been figured for dead.
|
(package private) void |
DeadServer.cleanAllPreviousInstances(ServerName newServerName) |
private boolean |
DeadServer.cleanOldServerName(ServerName newServerName,
Iterator<ServerName> deadServerIterator) |
(package private) boolean |
DeadServer.cleanPreviousInstance(ServerName newServerName)
Handles restart of a server.
|
static void |
ServerManager.closeRegionSilentlyAndWait(ClusterConnection connection,
ServerName server,
RegionInfo region,
long timeout)
Contacts a region server and waits up to timeout ms to close the region.
|
private static int |
RegionPlan.compareServerName(ServerName left,
ServerName right) |
private boolean |
MasterRpcServices.containMetaWals(ServerName serverName) |
protected ActiveMasterManager |
HMaster.createActiveMasterManager(ZKWatcher zk,
ServerName sn,
Server server)
Protected to have custom implementations in tests override the default ActiveMaster
implementation.
|
(package private) List<Procedure> |
SplitWALManager.createSplitWALProcedures(List<org.apache.hadoop.fs.FileStatus> splittingWALs,
ServerName crashedServer) |
void |
SplitWALManager.deleteWALDir(ServerName serverName) |
void |
MasterRegionServerList.expired(ServerName sn) |
void |
RegionServerList.expired(ServerName sn)
Called when a region server is dead.
|
long |
ServerManager.expireServer(ServerName serverName)
Expire the passed server.
|
(package private) long |
ServerManager.expireServer(ServerName serverName,
boolean force) |
private ServerName |
ServerManager.findServerWithSameHostnamePortWithLock(ServerName serverName)
Assumes onlineServers is locked.
|
void |
DeadServer.finish(ServerName sn)
Complete processing for this dead server.
|
int |
ActiveMasterManager.getBackupMasterInfoPort(ServerName sn) |
int |
HMaster.getBackupMasterInfoPort(ServerName sn) |
int |
ServerManager.getInfoPort(ServerName serverName) |
ServerMetrics |
ServerManager.getLoad(ServerName serverName)
n * @return ServerMetrics if serverName is known else null
|
String |
RackManager.getRack(ServerName server)
Get the name of the rack containing a server, according to the DNS to switch mapping.
|
int |
HMaster.getRegionServerInfoPort(ServerName sn) |
String |
MasterServices.getRegionServerVersion(ServerName sn) |
String |
HMaster.getRegionServerVersion(ServerName sn) |
HashMap<String,List<Pair<ServerName,ReplicationLoadSource>>> |
HMaster.getReplicationLoad(ServerName[] serverNames) |
org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface |
ServerManager.getRsAdmin(ServerName sn)
n * @return Admin interface for the remote regionserver named
sn n * @throws
RetriesExhaustedException wrapping a ConnectException if failed |
private org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionServerInfo |
RegionServerTracker.getServerInfo(ServerName serverName) |
Date |
DeadServer.getTimeOfDeath(ServerName deadServerName)
Get the time when a server died
|
String |
ServerManager.getVersion(ServerName serverName)
May return "0.0.0" when server is not online
|
int |
ServerManager.getVersionNumber(ServerName serverName)
May return 0 when server is not online.
|
private org.apache.hadoop.fs.Path |
SplitWALManager.getWALSplitDir(ServerName serverName) |
List<org.apache.hadoop.fs.FileStatus> |
SplitWALManager.getWALsToSplit(ServerName serverName,
boolean splitMeta) |
(package private) void |
SplitLogManager.handleDeadWorker(ServerName workerName)
Deprecated.
|
void |
SplitLogManager.Task.heartbeat(long time,
int version,
ServerName worker) |
boolean |
RegionState.isClosingOrClosedOnServer(ServerName sn) |
boolean |
DeadServer.isDeadServer(ServerName serverName) |
boolean |
RegionState.isMergingNewOnServer(ServerName sn) |
boolean |
RegionState.isMergingNewOrOfflineOnServer(ServerName sn) |
boolean |
RegionState.isMergingNewOrOpenedOnServer(ServerName sn) |
boolean |
RegionState.isMergingOnServer(ServerName sn) |
boolean |
RegionState.isOnServer(ServerName sn) |
boolean |
RegionState.isOpenedOnServer(ServerName sn) |
boolean |
RegionState.isOpeningOrFailedOpenOnServer(ServerName sn) |
boolean |
RegionState.isOpeningOrOpenedOnServer(ServerName sn) |
boolean |
ServerManager.isServerDead(ServerName serverName)
Check if a server is known to be dead.
|
ServerManager.ServerLiveState |
ServerManager.isServerKnownAndOnline(ServerName serverName)
Returns whether the server is online, dead, or unknown.
|
boolean |
ServerManager.isServerOnline(ServerName serverName) |
boolean |
ServerManager.isServerUnknown(ServerName serverName)
Check if a server is unknown.
|
boolean |
RegionState.isSplittingNewOnServer(ServerName sn) |
boolean |
RegionState.isSplittingOnServer(ServerName sn) |
boolean |
RegionState.isSplittingOrOpenedOnServer(ServerName sn) |
boolean |
RegionState.isSplittingOrSplitOnServer(ServerName sn) |
void |
ServerManager.moveFromOnlineToDeadServers(ServerName sn)
Called when server has expired.
|
void |
MasterCoprocessorHost.postMove(RegionInfo region,
ServerName srcServer,
ServerName destServer) |
void |
MasterCoprocessorHost.postRecommissionRegionServer(ServerName server,
List<byte[]> encodedRegionNames) |
void |
MasterCoprocessorHost.preMove(RegionInfo region,
ServerName srcServer,
ServerName destServer) |
void |
MasterCoprocessorHost.preRecommissionRegionServer(ServerName server,
List<byte[]> encodedRegionNames) |
void |
DeadServer.processing(ServerName sn)
Add
sn< to set of processing deadservers. |
(package private) void |
DeadServer.putIfAbsent(ServerName sn)
Adds the server to the dead server list if it's not there already.
|
void |
HMaster.recommissionRegionServer(ServerName server,
List<byte[]> encodedRegionNames)
Remove decommission marker (previously called 'draining') from a region server to allow regions
assignments.
|
(package private) void |
ServerManager.recordNewServerWithLock(ServerName serverName,
ServerMetrics sl)
Adds the onlineServers list.
|
void |
LoadBalancer.regionOnline(RegionInfo regionInfo,
ServerName sn)
Marks the region as online at balancer.
|
void |
ServerManager.regionServerReport(ServerName sn,
ServerMetrics sl) |
void |
SplitWALManager.SplitWorkerAssigner.release(ServerName serverName) |
void |
SplitWALManager.releaseSplitWALWorker(ServerName worker,
MasterProcedureScheduler scheduler)
After the worker finished the split WAL task, it will release the worker, and wake up all the
suspend procedures in the ProcedureEvent
|
private void |
DrainingServerTracker.remove(ServerName sn) |
boolean |
DeadServer.removeDeadServer(ServerName deadServerName)
Called from rpc by operator cleaning up deadserver list.
|
boolean |
ServerManager.removeServerFromDrainList(ServerName sn) |
void |
ServerManager.sendRegionWarmup(ServerName server,
RegionInfo region)
Sends a WARMUP RPC to the specified server to warmup the specified region.
|
default void |
ServerListener.serverAdded(ServerName serverName)
The server has joined the cluster.
|
void |
SplitWALManager.SplitWorkerAssigner.serverAdded(ServerName worker) |
default void |
ServerListener.serverRemoved(ServerName serverName)
The server was removed from the cluster.
|
void |
RegionPlan.setDestination(ServerName dest)
Set the destination server for the plan for this region.
|
private boolean |
MasterRpcServices.shouldSubmitSCP(ServerName serverName) |
void |
MasterWalManager.splitLog(ServerName serverName) |
void |
MasterWalManager.splitMetaLog(ServerName serverName)
Specialized method to handle the splitting for meta WAL
|
List<Procedure> |
SplitWALManager.splitWALs(ServerName crashedServer,
boolean splitMeta) |
void |
MasterRegionServerList.started(ServerName sn) |
void |
RegionServerList.started(ServerName sn)
Called when a region server join the cluster.
|
private void |
ServerManager.updateLastFlushedSequenceIds(ServerName sn,
ServerMetrics hsl)
Updates last flushed sequence Ids for the regions on server sn
|
Modifier and Type | Method and Description |
---|---|
List<RegionPlan> |
LoadBalancer.balanceCluster(Map<TableName,Map<ServerName,List<RegionInfo>>> loadOfAllTable)
Perform the major balance operation for cluster.
|
private boolean |
DeadServer.cleanOldServerName(ServerName newServerName,
Iterator<ServerName> deadServerIterator) |
List<ServerName> |
ServerManager.createDestinationServersList(List<ServerName> serversToExclude)
Creates a list of possible destinations for a region.
|
void |
HMaster.decommissionRegionServers(List<ServerName> servers,
boolean offload)
Mark region server(s) as decommissioned (previously called 'draining') to prevent additional
regions from getting assigned to them.
|
(package private) void |
ServerManager.findDeadServersAndProcess(Set<ServerName> deadServersFromPE,
Set<ServerName> liveServersFromWALDir)
Find out the region servers crashed between the crash of the previous master instance and the
current master instance and schedule SCP for them.
|
(package private) void |
ServerManager.findDeadServersAndProcess(Set<ServerName> deadServersFromPE,
Set<ServerName> liveServersFromWALDir)
Find out the region servers crashed between the crash of the previous master instance and the
current master instance and schedule SCP for them.
|
(package private) List<org.apache.hadoop.fs.Path> |
MasterWalManager.getLogDirs(Set<ServerName> serverNames) |
List<ServerName> |
ServerManager.getOnlineServersListWithPredicator(List<ServerName> keys,
Predicate<ServerMetrics> idleServerPredicator) |
List<String> |
RackManager.getRack(List<ServerName> servers)
Same as
RackManager.getRack(ServerName) except that a list is passed |
private Map<TableName,List<byte[]>> |
RegionsRecoveryChore.getTableToRegionsByRefCount(Map<ServerName,ServerMetrics> serverMetricsMap) |
(package private) void |
SplitLogManager.handleDeadWorkers(Set<ServerName> serverNames)
Deprecated.
|
void |
MasterCoprocessorHost.postClearDeadServers(List<ServerName> servers,
List<ServerName> notClearedServers) |
void |
MasterCoprocessorHost.postClearDeadServers(List<ServerName> servers,
List<ServerName> notClearedServers) |
void |
MasterCoprocessorHost.postDecommissionRegionServers(List<ServerName> servers,
boolean offload) |
void |
MasterCoprocessorHost.preDecommissionRegionServers(List<ServerName> servers,
boolean offload) |
private void |
AssignmentVerificationReport.printHServerAddressSet(Set<ServerName> serverSet) |
private void |
RegionServerTracker.processAsActiveMaster(Set<ServerName> newServers) |
ServerName |
LoadBalancer.randomAssignment(RegionInfo regionInfo,
List<ServerName> servers)
Get a random region server from the list
|
Map<ServerName,List<RegionInfo>> |
LoadBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers)
Assign regions to the previously hosting region server nn * @return List of plans
|
Map<ServerName,List<RegionInfo>> |
LoadBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers)
Assign regions to the previously hosting region server nn * @return List of plans
|
Map<ServerName,List<RegionInfo>> |
LoadBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers)
Perform a Round Robin assignment of regions.
|
void |
MasterWalManager.splitLog(Set<ServerName> serverNames) |
void |
MasterWalManager.splitLog(Set<ServerName> serverNames,
org.apache.hadoop.fs.PathFilter filter)
This method is the base split method that splits WAL files matching a filter.
|
long |
SplitLogManager.splitLogDistributed(Set<ServerName> serverNames,
List<org.apache.hadoop.fs.Path> logDirs,
org.apache.hadoop.fs.PathFilter filter)
Deprecated.
The caller will block until all the hbase:meta log files of the given region server have been
processed - successfully split or an error is encountered - by an available worker region
server.
|
void |
MasterWalManager.splitMetaLog(Set<ServerName> serverNames)
Specialized method to handle the splitting for meta WAL
|
default void |
LoadBalancer.updateBalancerLoadInfo(Map<TableName,Map<ServerName,List<RegionInfo>>> loadOfAllTable)
In some scenarios, Balancer needs to update internal status or information according to the
current tables load
|
void |
RegionServerTracker.upgrade(Set<ServerName> deadServersFromPE,
Set<ServerName> liveServersBeforeRestart,
Set<ServerName> splittingServersFromWALDir)
Upgrade to active master mode, where besides tracking the changes of region server set, we will
also started to add new region servers to ServerManager and also schedule SCP if a region
server dies.
|
void |
RegionServerTracker.upgrade(Set<ServerName> deadServersFromPE,
Set<ServerName> liveServersBeforeRestart,
Set<ServerName> splittingServersFromWALDir)
Upgrade to active master mode, where besides tracking the changes of region server set, we will
also started to add new region servers to ServerManager and also schedule SCP if a region
server dies.
|
void |
RegionServerTracker.upgrade(Set<ServerName> deadServersFromPE,
Set<ServerName> liveServersBeforeRestart,
Set<ServerName> splittingServersFromWALDir)
Upgrade to active master mode, where besides tracking the changes of region server set, we will
also started to add new region servers to ServerManager and also schedule SCP if a region
server dies.
|
Constructor and Description |
---|
ActiveMasterManager(ZKWatcher watcher,
ServerName sn,
Server master) |
RegionPlan(RegionInfo hri,
ServerName source,
ServerName dest)
Instantiate a plan for a region move, moving the specified region from the specified source
server to the specified destination server.
|
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 | Field and Description |
---|---|
private ServerName |
CloseRegionProcedure.assignCandidate |
private ServerName |
TransitRegionStateProcedure.assignCandidate |
protected ServerName |
UnassignProcedure.destinationServer
Deprecated.
|
protected ServerName |
UnassignProcedure.hostingServer
Deprecated.
|
private ServerName |
RegionStateNode.lastHost |
private ServerName |
MergeTableRegionsProcedure.regionLocation |
private ServerName |
RegionStateNode.regionLocation |
private ServerName |
ServerStateNode.serverName |
protected ServerName |
AssignProcedure.targetServer
Deprecated.
|
protected ServerName |
RegionRemoteProcedureBase.targetServer |
Modifier and Type | Field and Description |
---|---|
private Map<ServerName,Set<byte[]>> |
AssignmentManager.rsReports |
private ConcurrentHashMap<ServerName,ServerStateNode> |
RegionStates.serverMap |
Modifier and Type | Method and Description |
---|---|
ServerName |
RegionStateNode.getLastHost() |
private ServerName |
SplitTableRegionProcedure.getParentRegionServerName(MasterProcedureEnv env) |
ServerName |
RegionStateNode.getRegionLocation() |
ServerName |
RegionStates.getRegionServerOfRegion(RegionInfo regionInfo) |
ServerName |
ServerStateNode.getServerName() |
private ServerName |
MergeTableRegionsProcedure.getServerName(MasterProcedureEnv env)
The procedure could be restarted from a different machine.
|
ServerName |
RegionStateNode.offline()
Put region into OFFLINE mode (set state and clear location).
|
ServerName |
RegionStateNode.setRegionLocation(ServerName serverName) |
Modifier and Type | Method and Description |
---|---|
Map<TableName,Map<ServerName,List<RegionInfo>>> |
RegionStates.getAssignmentsForBalancer(TableStateManager tableStateManager,
List<ServerName> onlineServers)
This is an EXPENSIVE clone.
|
List<ServerName> |
AssignmentManager.getExcludedServersForSystemTable()
For a given cluster with mixed versions of servers, get a list of servers with lower versions,
where system table regions should not be assigned to.
|
List<ServerName> |
AssignmentManager.getFavoredNodes(RegionInfo regionInfo) |
Map<RegionInfo,ServerName> |
RegionStates.getRegionAssignments() |
Map<ServerName,Set<byte[]>> |
AssignmentManager.getRSReports()
Returns a snapshot of rsReports
|
Map<ServerName,List<RegionInfo>> |
RegionStates.getSnapShotOfAssignment(Collection<RegionInfo> regions) |
Map<ServerName,List<RegionInfo>> |
AssignmentManager.getSnapShotOfAssignment(Collection<RegionInfo> regions) |
List<Pair<RegionInfo,ServerName>> |
AssignmentManager.getTableRegionsAndLocations(TableName tableName,
boolean excludeOfflinedSplitParents) |
Modifier and Type | Method and Description |
---|---|
static TransitRegionStateProcedure |
TransitRegionStateProcedure.assign(MasterProcedureEnv env,
RegionInfo region,
boolean forceNewPlan,
ServerName targetServer) |
static TransitRegionStateProcedure |
TransitRegionStateProcedure.assign(MasterProcedureEnv env,
RegionInfo region,
ServerName targetServer) |
long |
AssignmentManager.assign(RegionInfo regionInfo,
ServerName sn) |
Future<byte[]> |
AssignmentManager.assignAsync(RegionInfo regionInfo,
ServerName sn)
Submits a procedure that assigns a region to a target server without waiting for it to finish
|
private void |
AssignmentManager.closeRegionSilently(ServerName sn,
byte[] regionName)
Close
regionName on sn silently and immediately without using a
Procedure or going via hbase:meta. |
private TransitRegionStateProcedure |
AssignmentManager.createAssignProcedure(RegionInfo regionInfo,
ServerName sn,
boolean override)
Create an assign TransitRegionStateProcedure.
|
private TransitRegionStateProcedure |
AssignmentManager.createAssignProcedure(RegionStateNode regionNode,
ServerName targetServer)
Create an assign TransitRegionStateProcedure.
|
private static TransitRegionStateProcedure[] |
AssignmentManagerUtil.createAssignProcedures(MasterProcedureEnv env,
List<RegionInfo> regions,
int regionReplication,
ServerName targetServer,
boolean ignoreIfInTransition)
Create assign procedures for the give regions, according to the
regionReplication . |
(package private) static TransitRegionStateProcedure[] |
AssignmentManagerUtil.createAssignProceduresForOpeningNewRegions(MasterProcedureEnv env,
List<RegionInfo> regions,
int regionReplication,
ServerName targetServer) |
(package private) static TransitRegionStateProcedure[] |
AssignmentManagerUtil.createAssignProceduresForSplitDaughters(MasterProcedureEnv env,
List<RegionInfo> daughters,
int regionReplication,
ServerName parentServer) |
TransitRegionStateProcedure |
AssignmentManager.createMoveRegionProcedure(RegionInfo regionInfo,
ServerName targetServer) |
ServerStateNode |
RegionStates.getOrCreateServer(ServerName serverName)
Be judicious calling this method.
|
(package private) static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoResponse |
AssignmentManagerUtil.getRegionInfoResponse(MasterProcedureEnv env,
ServerName regionLocation,
RegionInfo hri)
Raw call to remote regionserver to get info on a particular region.
|
(package private) static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoResponse |
AssignmentManagerUtil.getRegionInfoResponse(MasterProcedureEnv env,
ServerName regionLocation,
RegionInfo hri,
boolean includeBestSplitRow) |
List<RegionInfo> |
AssignmentManager.getRegionsOnServer(ServerName serverName)
Returns the regions hosted by the specified server.
|
ServerStateNode |
RegionStates.getServerNode(ServerName serverName)
Returns Pertinent ServerStateNode or NULL if none found (Do not make modifications).
|
private List<RegionInfo> |
AssignmentManager.getSystemTables(ServerName serverName) |
boolean |
AssignmentManager.isCarryingMeta(ServerName serverName) |
private boolean |
AssignmentManager.isCarryingRegion(ServerName serverName,
RegionInfo regionInfo) |
void |
RegionStates.logSplit(ServerName serverName)
Called after we've split all logs on a crashed Server.
|
void |
RegionStates.logSplitting(ServerName serverName)
Call this when we start log splitting for a crashed Server.
|
void |
AssignmentManager.markRegionAsMerged(RegionInfo child,
ServerName serverName,
RegionInfo[] mergeParents)
When called here, the merge has happened.
|
void |
AssignmentManager.markRegionAsSplit(RegionInfo parent,
ServerName serverName,
RegionInfo daughterA,
RegionInfo daughterB) |
void |
RegionStateStore.mergeRegions(RegionInfo child,
RegionInfo[] parents,
ServerName serverName) |
void |
RegionStates.metaLogSplit(ServerName serverName)
Called after we've split the meta logs on a crashed Server.
|
void |
RegionStates.metaLogSplitting(ServerName serverName)
Call this when we start meta log splitting a crashed Server.
|
private void |
RegionStateStore.mirrorMetaLocation(RegionInfo regionInfo,
ServerName serverName,
RegionState.State state) |
static TransitRegionStateProcedure |
TransitRegionStateProcedure.move(MasterProcedureEnv env,
RegionInfo region,
ServerName targetServer) |
void |
AssignmentManager.onlineRegion(RegionInfo regionInfo,
ServerName serverName) |
Optional<RemoteProcedureDispatcher.RemoteOperation> |
UnassignProcedure.remoteCallBuild(MasterProcedureEnv env,
ServerName serverName)
Deprecated.
|
Optional<RemoteProcedureDispatcher.RemoteOperation> |
AssignProcedure.remoteCallBuild(MasterProcedureEnv env,
ServerName serverName)
Deprecated.
|
Optional<RemoteProcedureDispatcher.RemoteOperation> |
RegionRemoteProcedureBase.remoteCallBuild(MasterProcedureEnv env,
ServerName remote) |
abstract Optional<RemoteProcedureDispatcher.RemoteOperation> |
RegionTransitionProcedure.remoteCallBuild(MasterProcedureEnv env,
ServerName serverName)
Deprecated.
|
void |
RegionRemoteProcedureBase.remoteCallFailed(MasterProcedureEnv env,
ServerName remote,
IOException exception) |
void |
RegionTransitionProcedure.remoteCallFailed(MasterProcedureEnv env,
ServerName serverName,
IOException exception)
Deprecated.
|
ServerStateNode |
RegionStates.removeRegionFromServer(ServerName serverName,
RegionStateNode regionNode) |
void |
RegionStates.removeServer(ServerName serverName)
Called by SCP at end of successful processing.
|
(package private) static void |
AssignmentManagerUtil.reopenRegionsForRollback(MasterProcedureEnv env,
List<RegionInfo> regions,
int regionReplication,
ServerName targetServer) |
void |
AssignmentManager.reportOnlineRegions(ServerName serverName,
Set<byte[]> regionNames)
The master will call this method when the RS send the regionServerReport().
|
private void |
AssignmentManager.reportRegionStateTransition(org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse.Builder builder,
ServerName serverName,
List<org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition> transitionList) |
(package private) void |
RegionRemoteProcedureBase.reportTransition(MasterProcedureEnv env,
RegionStateNode regionNode,
ServerName serverName,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode transitionCode,
long seqId) |
void |
TransitRegionStateProcedure.reportTransition(MasterProcedureEnv env,
RegionStateNode regionNode,
ServerName serverName,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode code,
long seqId,
long procId) |
(package private) void |
RegionRemoteProcedureBase.serverCrashed(MasterProcedureEnv env,
RegionStateNode regionNode,
ServerName serverName) |
void |
TransitRegionStateProcedure.serverCrashed(MasterProcedureEnv env,
RegionStateNode regionNode,
ServerName serverName,
boolean forceNewPlan) |
void |
RegionStateNode.setLastHost(ServerName serverName) |
ServerName |
RegionStateNode.setRegionLocation(ServerName serverName) |
private void |
RegionStates.setServerState(ServerName serverName,
ServerState state) |
void |
RegionStateStore.splitRegion(RegionInfo parent,
RegionInfo hriA,
RegionInfo hriB,
ServerName serverName) |
long |
AssignmentManager.submitServerCrash(ServerName serverName,
boolean shouldSplitWal,
boolean force)
Usually run by the Master in reaction to server crash during normal processing.
|
private void |
AssignmentManager.updateRegionMergeTransition(ServerName serverName,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode state,
RegionInfo merged,
RegionInfo hriA,
RegionInfo hriB) |
private void |
AssignmentManager.updateRegionSplitTransition(ServerName serverName,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode state,
RegionInfo parent,
RegionInfo hriA,
RegionInfo hriB) |
private void |
AssignmentManager.updateRegionTransition(ServerName serverName,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode state,
RegionInfo regionInfo,
long seqId,
long procId) |
void |
RegionStateStore.RegionStateVisitor.visitRegionState(Result result,
RegionInfo regionInfo,
RegionState.State state,
ServerName regionLocation,
ServerName lastHost,
long openSeqNum) |
void |
AssignmentManager.RegionMetaLoadingVisitor.visitRegionState(Result result,
RegionInfo regionInfo,
RegionState.State state,
ServerName regionLocation,
ServerName lastHost,
long openSeqNum) |
Modifier and Type | Method and Description |
---|---|
private void |
AssignmentManager.acceptPlan(HashMap<RegionInfo,RegionStateNode> regions,
Map<ServerName,List<RegionInfo>> plan) |
private TransitRegionStateProcedure[] |
AssignmentManager.createAssignProcedures(Map<ServerName,List<RegionInfo>> assignments)
Tied to
AssignmentManager.createAssignProcedures(List) in that it is called if caller is unable to run
this method. |
TransitRegionStateProcedure[] |
AssignmentManager.createRoundRobinAssignProcedures(List<RegionInfo> hris,
List<ServerName> serversToExclude)
Create round-robin assigns.
|
private static TransitRegionStateProcedure[] |
AssignmentManagerUtil.createRoundRobinAssignProcedures(MasterProcedureEnv env,
List<RegionInfo> regions,
int regionReplication,
List<ServerName> serversToExclude,
boolean ignoreIfInTransition)
Create round robin assign procedures for the given regions, according to the
regionReplication . |
private void |
RegionStates.createSnapshot(RegionStateNode node,
Map<ServerName,List<RegionInfo>> result) |
Map<TableName,Map<ServerName,List<RegionInfo>>> |
RegionStates.getAssignmentsForBalancer(TableStateManager tableStateManager,
List<ServerName> onlineServers)
This is an EXPENSIVE clone.
|
private void |
AssignmentManager.processAssignmentPlans(HashMap<RegionInfo,RegionStateNode> regions,
HashMap<RegionInfo,ServerName> retainMap,
List<RegionInfo> hris,
List<ServerName> servers) |
private void |
AssignmentManager.processAssignmentPlans(HashMap<RegionInfo,RegionStateNode> regions,
HashMap<RegionInfo,ServerName> retainMap,
List<RegionInfo> hris,
List<ServerName> servers) |
Constructor and Description |
---|
CloseRegionProcedure(TransitRegionStateProcedure parent,
RegionInfo region,
ServerName targetServer,
ServerName assignCandidate) |
OpenRegionProcedure(TransitRegionStateProcedure parent,
RegionInfo region,
ServerName targetServer) |
RegionRemoteProcedureBase(TransitRegionStateProcedure parent,
RegionInfo region,
ServerName targetServer) |
ServerStateNode(ServerName serverName) |
TransitRegionStateProcedure(MasterProcedureEnv env,
RegionInfo hri,
ServerName assignCandidate,
boolean forceNewPlan,
TransitRegionStateProcedure.TransitionType type) |
Modifier and Type | Field and Description |
---|---|
protected ServerName |
BaseLoadBalancer.masterServerName |
(package private) ServerName[] |
BalancerClusterState.servers |
private ServerName |
ServerAndLoad.sn |
Modifier and Type | Field and Description |
---|---|
(package private) Map<ServerName,List<RegionInfo>> |
BalancerClusterState.clusterState |
private Map<ServerName,List<RegionInfo>> |
ClusterLoadState.clusterState |
private Map<ServerName,Integer> |
HeterogeneousRegionCountCostFunction.limitPerRS
This is a cache, used to not go through all the limitPerRule map when searching for limit
|
Modifier and Type | Method and Description |
---|---|
private ServerName |
FavoredStochasticBalancer.getServerFromFavoredNode(List<ServerName> servers,
ServerName fn) |
(package private) ServerName |
ServerAndLoad.getServerName() |
private ServerName |
BaseLoadBalancer.randomAssignment(BalancerClusterState cluster,
RegionInfo regionInfo,
List<ServerName> servers)
Used to assign a single region to a random server.
|
ServerName |
BaseLoadBalancer.randomAssignment(RegionInfo regionInfo,
List<ServerName> servers)
Used to assign a single region to a random server.
|
ServerName |
FavoredStochasticBalancer.randomAssignment(RegionInfo regionInfo,
List<ServerName> servers) |
ServerName |
MaintenanceLoadBalancer.randomAssignment(RegionInfo regionInfo,
List<ServerName> servers) |
Modifier and Type | Method and Description |
---|---|
private Map<ServerName,List<RegionInfo>> |
MaintenanceLoadBalancer.assign(Collection<RegionInfo> regions,
List<ServerName> servers) |
protected Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.assignMasterSystemRegions(Collection<RegionInfo> regions,
List<ServerName> servers)
Deprecated.
since 2.4.0, will be removed in 3.0.0.
|
private List<ServerName> |
BaseLoadBalancer.findIdleServers(List<ServerName> servers) |
private Map<ServerName,List<RegionInfo>> |
FavoredStochasticBalancer.generateFNForRegionsWithoutFN(FavoredNodeAssignmentHelper helper,
List<RegionInfo> regions) |
(package private) Map<ServerName,List<RegionInfo>> |
ClusterLoadState.getClusterState() |
List<ServerName> |
FavoredStochasticBalancer.getFavoredNodes(RegionInfo regionInfo) |
private Set<ServerName> |
FavoredStochasticBalancer.getInheritedFNForDaughter(FavoredNodeAssignmentHelper helper,
List<ServerName> parentFavoredNodes,
FavoredNodesPlan.Position primary,
FavoredNodesPlan.Position secondary) |
private List<ServerName> |
FavoredStochasticBalancer.getOnlineFavoredNodes(List<ServerName> onlineServers,
List<ServerName> serversWithoutStartCodes) |
private Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.getRegionAssignmentsByServer(Collection<RegionInfo> regions) |
protected List<ServerName> |
RegionLocationFinder.getTopBlockLocations(RegionInfo region) |
protected List<ServerName> |
RegionLocationFinder.getTopBlockLocations(RegionInfo region,
String currentHost)
Returns an ordered list of hosts which have better locality for this region than the current
host.
|
(package private) List<ServerName> |
RegionLocationFinder.mapHostNameToServerName(List<String> hosts)
Map hostname to ServerName, The output ServerName list will have the same order as input hosts.
|
Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers)
Generates a bulk assignment startup plan, attempting to reuse the existing assignment
information from META, but adjusting for the specified list of available/online servers
available for assignment.
|
Map<ServerName,List<RegionInfo>> |
FavoredStochasticBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers) |
Map<ServerName,List<RegionInfo>> |
MaintenanceLoadBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers) |
Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers)
Generates a bulk assignment plan to be used on cluster startup using a simple round-robin
assignment.
|
Map<ServerName,List<RegionInfo>> |
FavoredStochasticBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers) |
Map<ServerName,List<RegionInfo>> |
MaintenanceLoadBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers) |
private Pair<Map<ServerName,List<RegionInfo>>,List<RegionInfo>> |
FavoredStochasticBalancer.segregateRegionsAndAssignRegionsWithFavoredNodes(Collection<RegionInfo> regions,
List<ServerName> onlineServers) |
protected Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.toEnsumbleTableLoad(Map<TableName,Map<ServerName,List<RegionInfo>>> LoadOfAllTable) |
Modifier and Type | Method and Description |
---|---|
private void |
SimpleLoadBalancer.addRegionPlan(org.apache.hbase.thirdparty.com.google.common.collect.MinMaxPriorityQueue<RegionPlan> regionsToMove,
boolean fetchFromTail,
ServerName sn,
List<RegionPlan> regionsToReturn)
Add a region from the head or tail to the List of regions to return.
|
private void |
FavoredStochasticBalancer.addRegionToMap(Map<ServerName,List<RegionInfo>> assignmentMapForFavoredNodes,
RegionInfo region,
ServerName host) |
private void |
FavoredStochasticBalancer.assignRegionToAvailableFavoredNode(Map<ServerName,List<RegionInfo>> assignmentMapForFavoredNodes,
RegionInfo region,
ServerName primaryHost,
ServerName secondaryHost,
ServerName tertiaryHost) |
(package private) void |
BalancerClusterState.doAssignRegion(RegionInfo regionInfo,
ServerName serverName) |
(package private) int |
HeterogeneousRegionCountCostFunction.findLimitForRS(ServerName serverName)
Find the limit for a ServerName.
|
private float |
RegionLocationFinder.getOldLocality(ServerName newServer,
byte[] regionName,
Map<ServerName,ServerMetrics> oldServers) |
String |
BalancerClusterState.DefaultRackManager.getRack(ServerName server) |
private ServerName |
FavoredStochasticBalancer.getServerFromFavoredNode(List<ServerName> servers,
ServerName fn) |
void |
BaseLoadBalancer.regionOnline(RegionInfo regionInfo,
ServerName sn) |
void |
MaintenanceLoadBalancer.regionOnline(RegionInfo regionInfo,
ServerName sn) |
(package private) boolean |
BalancerClusterState.wouldLowerAvailability(RegionInfo regionInfo,
ServerName serverName)
Return true if the placement of region on server would lower the availability of the region in
question
|
Modifier and Type | Method and Description |
---|---|
private void |
FavoredStochasticBalancer.addRegionToMap(Map<ServerName,List<RegionInfo>> assignmentMapForFavoredNodes,
RegionInfo region,
ServerName host) |
private Map<ServerName,List<RegionInfo>> |
MaintenanceLoadBalancer.assign(Collection<RegionInfo> regions,
List<ServerName> servers) |
protected Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.assignMasterSystemRegions(Collection<RegionInfo> regions,
List<ServerName> servers)
Deprecated.
since 2.4.0, will be removed in 3.0.0.
|
private void |
FavoredStochasticBalancer.assignRegionToAvailableFavoredNode(Map<ServerName,List<RegionInfo>> assignmentMapForFavoredNodes,
RegionInfo region,
ServerName primaryHost,
ServerName secondaryHost,
ServerName tertiaryHost) |
List<RegionPlan> |
BaseLoadBalancer.balanceCluster(Map<TableName,Map<ServerName,List<RegionInfo>>> loadOfAllTable)
Perform the major balance operation for cluster, will invoke
BaseLoadBalancer.balanceTable(TableName, Map) to do actual balance. |
List<RegionPlan> |
MaintenanceLoadBalancer.balanceCluster(Map<TableName,Map<ServerName,List<RegionInfo>>> loadOfAllTable) |
protected List<RegionPlan> |
BaseLoadBalancer.balanceMasterRegions(Map<ServerName,List<RegionInfo>> clusterMap)
Deprecated.
since 2.4.0, will be removed in 3.0.0.
|
private void |
SimpleLoadBalancer.balanceOverall(List<RegionPlan> regionsToReturn,
Map<ServerName,SimpleLoadBalancer.BalanceInfo> serverBalanceInfo,
boolean fetchFromTail,
org.apache.hbase.thirdparty.com.google.common.collect.MinMaxPriorityQueue<RegionPlan> regionsToMove,
int max,
int min)
If we need to balanceoverall, we need to add one more round to peel off one region from each
max.
|
protected List<RegionPlan> |
StochasticLoadBalancer.balanceTable(TableName tableName,
Map<ServerName,List<RegionInfo>> loadOfOneTable)
Given the cluster state this will try and approach an optimal balance.
|
protected abstract List<RegionPlan> |
BaseLoadBalancer.balanceTable(TableName tableName,
Map<ServerName,List<RegionInfo>> loadOfOneTable)
Perform the major balance operation for table, all sub classes should override this method.
|
protected List<RegionPlan> |
SimpleLoadBalancer.balanceTable(TableName tableName,
Map<ServerName,List<RegionInfo>> loadOfOneTable)
Generate a global load balancing plan according to the specified map of server information to
the most loaded regions of each server.
|
protected List<RegionPlan> |
FavoredStochasticBalancer.balanceTable(TableName tableName,
Map<ServerName,List<RegionInfo>> loadOfOneTable) |
private BalancerClusterState |
BaseLoadBalancer.createCluster(List<ServerName> servers,
Collection<RegionInfo> regions) |
private List<ServerName> |
BaseLoadBalancer.findIdleServers(List<ServerName> servers) |
void |
FavoredStochasticBalancer.generateFavoredNodesForDaughter(List<ServerName> servers,
RegionInfo parent,
RegionInfo regionA,
RegionInfo regionB) |
private int |
FavoredStochasticBalancer.FavoredNodeLocalityPicker.getDifferentFavoredNode(BalancerClusterState cluster,
List<ServerName> favoredNodes,
int currentServer) |
private Set<ServerName> |
FavoredStochasticBalancer.getInheritedFNForDaughter(FavoredNodeAssignmentHelper helper,
List<ServerName> parentFavoredNodes,
FavoredNodesPlan.Position primary,
FavoredNodesPlan.Position secondary) |
private float |
RegionLocationFinder.getOldLocality(ServerName newServer,
byte[] regionName,
Map<ServerName,ServerMetrics> oldServers) |
private List<ServerName> |
FavoredStochasticBalancer.getOnlineFavoredNodes(List<ServerName> onlineServers,
List<ServerName> serversWithoutStartCodes) |
private List<ServerName> |
FavoredStochasticBalancer.getOnlineFavoredNodes(List<ServerName> onlineServers,
List<ServerName> serversWithoutStartCodes) |
private ServerName |
FavoredStochasticBalancer.getServerFromFavoredNode(List<ServerName> servers,
ServerName fn) |
private void |
FavoredStochasticBalancer.mergeAssignmentMaps(Map<ServerName,List<RegionInfo>> assignmentMap,
Map<ServerName,List<RegionInfo>> otherAssignments) |
private void |
FavoredStochasticBalancer.mergeAssignmentMaps(Map<ServerName,List<RegionInfo>> assignmentMap,
Map<ServerName,List<RegionInfo>> otherAssignments) |
private int |
FavoredStochasticBalancer.FavoredNodeLoadPicker.pickLeastLoadedFNServer(BalancerClusterState cluster,
List<ServerName> favoredNodes,
int currentServerIndex) |
protected void |
BaseLoadBalancer.preBalanceCluster(Map<TableName,Map<ServerName,List<RegionInfo>>> loadOfAllTable)
Called before actually executing balanceCluster.
|
protected void |
SimpleLoadBalancer.preBalanceCluster(Map<TableName,Map<ServerName,List<RegionInfo>>> loadOfAllTable) |
private ServerName |
BaseLoadBalancer.randomAssignment(BalancerClusterState cluster,
RegionInfo regionInfo,
List<ServerName> servers)
Used to assign a single region to a random server.
|
ServerName |
BaseLoadBalancer.randomAssignment(RegionInfo regionInfo,
List<ServerName> servers)
Used to assign a single region to a random server.
|
ServerName |
FavoredStochasticBalancer.randomAssignment(RegionInfo regionInfo,
List<ServerName> servers) |
ServerName |
MaintenanceLoadBalancer.randomAssignment(RegionInfo regionInfo,
List<ServerName> servers) |
Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers)
Generates a bulk assignment startup plan, attempting to reuse the existing assignment
information from META, but adjusting for the specified list of available/online servers
available for assignment.
|
Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers)
Generates a bulk assignment startup plan, attempting to reuse the existing assignment
information from META, but adjusting for the specified list of available/online servers
available for assignment.
|
Map<ServerName,List<RegionInfo>> |
FavoredStochasticBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers) |
Map<ServerName,List<RegionInfo>> |
FavoredStochasticBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers) |
Map<ServerName,List<RegionInfo>> |
MaintenanceLoadBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers) |
Map<ServerName,List<RegionInfo>> |
MaintenanceLoadBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers) |
private void |
BaseLoadBalancer.roundRobinAssignment(BalancerClusterState cluster,
List<RegionInfo> regions,
List<ServerName> servers,
Map<ServerName,List<RegionInfo>> assignments)
Round robin a list of regions to a list of servers
|
private void |
BaseLoadBalancer.roundRobinAssignment(BalancerClusterState cluster,
List<RegionInfo> regions,
List<ServerName> servers,
Map<ServerName,List<RegionInfo>> assignments)
Round robin a list of regions to a list of servers
|
Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers)
Generates a bulk assignment plan to be used on cluster startup using a simple round-robin
assignment.
|
Map<ServerName,List<RegionInfo>> |
FavoredStochasticBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers) |
Map<ServerName,List<RegionInfo>> |
MaintenanceLoadBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers) |
private Pair<Map<ServerName,List<RegionInfo>>,List<RegionInfo>> |
FavoredStochasticBalancer.segregateRegionsAndAssignRegionsWithFavoredNodes(Collection<RegionInfo> regions,
List<ServerName> onlineServers) |
(package private) void |
SimpleLoadBalancer.setClusterLoad(Map<TableName,Map<ServerName,List<RegionInfo>>> clusterLoad)
Pass RegionStates and allow balancer to set the current cluster load.
|
protected Map<ServerName,List<RegionInfo>> |
BaseLoadBalancer.toEnsumbleTableLoad(Map<TableName,Map<ServerName,List<RegionInfo>>> LoadOfAllTable) |
void |
StochasticLoadBalancer.updateBalancerLoadInfo(Map<TableName,Map<ServerName,List<RegionInfo>>> loadOfAllTable) |
private void |
StochasticLoadBalancer.updateBalancerTableLoadInfo(TableName tableName,
Map<ServerName,List<RegionInfo>> loadOfOneTable) |
private void |
FavoredStochasticBalancer.updateFavoredNodesForRegion(RegionInfo regionInfo,
List<ServerName> newFavoredNodes) |
Constructor and Description |
---|
ServerAndLoad(ServerName sn,
int load) |
Constructor and Description |
---|
BalancerClusterState(Collection<RegionInfo> unassignedRegions,
Map<ServerName,List<RegionInfo>> clusterState,
Map<String,Deque<BalancerRegionLoad>> loads,
RegionLocationFinder regionFinder,
RackManager rackManager) |
BalancerClusterState(Map<ServerName,List<RegionInfo>> clusterState,
Map<String,Deque<BalancerRegionLoad>> loads,
RegionLocationFinder regionFinder,
RackManager rackManager) |
ClusterLoadState(Map<ServerName,List<RegionInfo>> clusterState) |
Modifier and Type | Field and Description |
---|---|
private Map<String,Pair<ServerName,List<ServerName>>> |
HbckReport.inconsistentRegions |
private Map<String,Pair<ServerName,List<ServerName>>> |
HbckReport.inconsistentRegions |
private Map<String,ServerName> |
HbckReport.orphanRegionsOnRS |
Modifier and Type | Method and Description |
---|---|
Map<String,Pair<ServerName,List<ServerName>>> |
HbckReport.getInconsistentRegions()
The inconsistent regions.
|
Map<String,Pair<ServerName,List<ServerName>>> |
HbckReport.getInconsistentRegions()
The inconsistent regions.
|
Map<String,ServerName> |
HbckReport.getOrphanRegionsOnRS()
The regions only opened on RegionServers, but no region info in meta.
|
Modifier and Type | Field and Description |
---|---|
private ServerName |
RegionReplicaInfo.serverName |
private ServerName |
RegionVisualizer.RegionDetails.serverName |
private ServerName |
RegionReplicaInfo.targetServerName
|
Modifier and Type | Method and Description |
---|---|
private ServerName |
MasterStatusServlet.getMetaLocationOrNull(HMaster master) |
ServerName |
RegionReplicaInfo.getServerName() |
ServerName |
RegionVisualizer.RegionDetails.getServerName() |
ServerName |
RegionReplicaInfo.getTargetServerName() |
Constructor and Description |
---|
RegionDetails(ServerName serverName,
TableName tableName,
RegionMetrics regionMetrics) |
Modifier and Type | Field and Description |
---|---|
private ServerName |
ClusterMetrics.masterName |
Modifier and Type | Field and Description |
---|---|
private List<ServerName> |
ClusterMetrics.backupMasterNames |
Modifier and Type | Method and Description |
---|---|
ServerName |
ClusterMetrics.getMasterName() |
Modifier and Type | Method and Description |
---|---|
List<ServerName> |
ClusterMetrics.getBackupMasterNames() |
Constructor and Description |
---|
ClusterMetrics(String hbaseVersion,
String clusterId,
ServerName masterName,
List<ServerName> backupMasterNames) |
Constructor and Description |
---|
ClusterMetrics(String hbaseVersion,
String clusterId,
ServerName masterName,
List<ServerName> backupMasterNames) |
Modifier and Type | Method and Description |
---|---|
List<ServerName> |
ClusterMetricsResource.getDeadServers() |
Modifier and Type | Field and Description |
---|---|
(package private) List<Pair<RegionInfo,ServerName>> |
CatalogJanitorReport.unknownServers
TODO: If CatalogJanitor finds an 'Unknown Server', it should 'fix' it by queuing a
HBCKServerCrashProcedure for found server for
it to clean up meta. |
Modifier and Type | Method and Description |
---|---|
List<Pair<RegionInfo,ServerName>> |
CatalogJanitorReport.getUnknownServers() |
Modifier and Type | Field and Description |
---|---|
private ServerName |
SplitWALProcedure.crashedServer |
private ServerName |
SplitWALRemoteProcedure.crashedServer |
private ServerName |
RSProcedureDispatcher.RegionCloseOperation.destinationServer |
private ServerName |
RecoverMetaProcedure.failedMetaServer
Deprecated.
|
private ServerName |
RSProcedureDispatcher.ExecuteProceduresRemoteCall.serverName |
private ServerName |
ServerCrashException.serverName |
private ServerName |
SwitchRpcThrottleProcedure.serverName |
private ServerName |
ServerCrashProcedure.serverName
Name of the crashed server to process.
|
protected ServerName |
ServerRemoteProcedure.targetServer |
private ServerName |
HBCKServerCrashProcedure.UnknownServerVisitor.unknownServerName |
private ServerName |
SplitWALProcedure.worker |
Modifier and Type | Field and Description |
---|---|
private Map<ServerName,LockAndQueue> |
SchemaLocking.serverLocks |
private FairQueue<ServerName> |
MasterProcedureScheduler.serverRunQueue |
Modifier and Type | Method and Description |
---|---|
ServerName |
RSProcedureDispatcher.RegionCloseOperation.getDestinationServer() |
ServerName |
SplitWALProcedure.getServerName() |
ServerName |
ServerProcedureInterface.getServerName()
Returns Name of this server instance.
|
protected ServerName |
RSProcedureDispatcher.ExecuteProceduresRemoteCall.getServerName() |
ServerName |
SwitchRpcThrottleProcedure.getServerName() |
ServerName |
SplitWALRemoteProcedure.getServerName() |
ServerName |
ServerCrashProcedure.getServerName() |
ServerName |
SwitchRpcThrottleRemoteProcedure.getServerName() |
private static ServerName |
MasterProcedureScheduler.getServerName(Procedure<?> proc) |
ServerName |
SplitWALProcedure.getWorker() |
Modifier and Type | Method and Description |
---|---|
protected void |
RSProcedureDispatcher.abortPendingOperations(ServerName serverName,
Set<RemoteProcedureDispatcher.RemoteProcedure> operations) |
org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CloseRegionRequest |
RSProcedureDispatcher.RegionCloseOperation.buildCloseRegionRequest(ServerName serverName) |
private static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.OpenRegionRequest |
RSProcedureDispatcher.buildOpenRegionRequest(MasterProcedureEnv env,
ServerName serverName,
List<RSProcedureDispatcher.RegionOpenOperation> operations) |
(package private) LockAndQueue |
SchemaLocking.getServerLock(ServerName serverName) |
private ServerQueue |
MasterProcedureScheduler.getServerQueue(ServerName serverName,
ServerProcedureInterface proc) |
Optional<RemoteProcedureDispatcher.RemoteOperation> |
SplitWALRemoteProcedure.remoteCallBuild(MasterProcedureEnv env,
ServerName serverName) |
Optional<RemoteProcedureDispatcher.RemoteOperation> |
SwitchRpcThrottleRemoteProcedure.remoteCallBuild(MasterProcedureEnv masterProcedureEnv,
ServerName remote) |
void |
ServerRemoteProcedure.remoteCallFailed(MasterProcedureEnv env,
ServerName serverName,
IOException exception) |
protected void |
RSProcedureDispatcher.remoteDispatch(ServerName serverName,
Set<RemoteProcedureDispatcher.RemoteProcedure> remoteProcedures) |
(package private) LockAndQueue |
SchemaLocking.removeServerLock(ServerName serverName) |
private void |
MasterProcedureScheduler.removeServerQueue(ServerName serverName) |
protected org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ExecuteProceduresResponse |
RSProcedureDispatcher.ExecuteProceduresRemoteCall.sendRequest(ServerName serverName,
org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ExecuteProceduresRequest request) |
void |
RSProcedureDispatcher.serverAdded(ServerName serverName) |
void |
RSProcedureDispatcher.serverRemoved(ServerName serverName) |
void |
RSProcedureDispatcher.splitAndResolveOperation(ServerName serverName,
Set<RemoteProcedureDispatcher.RemoteProcedure> operations,
RSProcedureDispatcher.RemoteProcedureResolver resolver)
Fetches
RemoteProcedureDispatcher.RemoteOperation s
from the given remoteProcedures and groups them by class of the returned operation. |
private void |
MasterProcedureScheduler.tryCleanupServerQueue(ServerName serverName,
Procedure<?> proc) |
boolean |
MasterProcedureScheduler.waitServerExclusiveLock(Procedure<?> procedure,
ServerName serverName)
Try to acquire the exclusive lock on the specified server.
|
void |
MasterProcedureScheduler.wakeServerExclusiveLock(Procedure<?> procedure,
ServerName serverName)
Wake the procedures waiting for the specified server
|
Modifier and Type | Field and Description |
---|---|
private ServerName |
ClaimReplicationQueueRemoteProcedure.crashedServer |
private ServerName |
ClaimReplicationQueuesProcedure.crashedServer |
Modifier and Type | Method and Description |
---|---|
ServerName |
ClaimReplicationQueueRemoteProcedure.getServerName() |
ServerName |
ClaimReplicationQueuesProcedure.getServerName() |
Modifier and Type | Method and Description |
---|---|
Optional<RemoteProcedureDispatcher.RemoteOperation> |
ClaimReplicationQueueRemoteProcedure.remoteCallBuild(MasterProcedureEnv env,
ServerName remote) |
Optional<RemoteProcedureDispatcher.RemoteOperation> |
RefreshPeerProcedure.remoteCallBuild(MasterProcedureEnv env,
ServerName remote) |
Constructor and Description |
---|
ClaimReplicationQueueRemoteProcedure(ServerName crashedServer,
String queue,
ServerName targetServer) |
ClaimReplicationQueuesProcedure(ServerName crashedServer) |
RefreshPeerProcedure(String peerId,
PeerProcedureInterface.PeerOperationType type,
ServerName targetServer) |
Modifier and Type | Method and Description |
---|---|
protected void |
EnabledTableSnapshotHandler.snapshotRegions(List<Pair<RegionInfo,ServerName>> regions)
This method kicks off a snapshot procedure.
|
void |
DisabledTableSnapshotHandler.snapshotRegions(List<Pair<RegionInfo,ServerName>> regionsAndLocations) |
protected abstract void |
TakeSnapshotHandler.snapshotRegions(List<Pair<RegionInfo,ServerName>> regions)
Snapshot the specified regions
|
Modifier and Type | Field and Description |
---|---|
protected ServerName |
HRegionServer.serverName
The server name the Master sees us as.
|
private ServerName |
HRegionServer.MovedRegionInfo.serverName |
Modifier and Type | Method and Description |
---|---|
private ServerName |
HRegionServer.createRegionServerStatusStub()
Get the current master from ZooKeeper and open the RPC connection to it.
|
protected ServerName |
HRegionServer.createRegionServerStatusStub(boolean refresh)
Get the current master from ZooKeeper and open the RPC connection to it.
|
ServerName |
RegionCoprocessorHost.RegionEnvironment.getServerName() |
ServerName |
RegionServerCoprocessorHost.RegionServerEnvironment.getServerName() |
ServerName |
HRegionServer.getServerName() |
ServerName |
HRegionServer.MovedRegionInfo.getServerName() |
Modifier and Type | Method and Description |
---|---|
Optional<ServerName> |
HRegionServer.getActiveMaster() |
List<ServerName> |
HRegionServer.getBackupMasters() |
Iterator<ServerName> |
HRegionServer.getRegionServers() |
Modifier and Type | Method and Description |
---|---|
private void |
HRegionServer.addToMovedRegions(String encodedName,
ServerName destination,
long closeSeqNum,
boolean selfMove) |
protected boolean |
HRegionServer.closeRegion(String encodedName,
boolean abort,
ServerName destination)
Close asynchronously a region, can be called from the master or internally by the regionserver
when stopping.
|
boolean |
MutableOnlineRegions.removeRegion(HRegion r,
ServerName destination)
Removes the given Region from the list of onlineRegions.
|
boolean |
HRegionServer.removeRegion(HRegion r,
ServerName destination) |
Constructor and Description |
---|
MovedRegionInfo(ServerName serverName,
long closeSeqNum) |
ScannerIdGenerator(ServerName serverName) |
Modifier and Type | Field and Description |
---|---|
private ServerName |
CloseRegionHandler.destination |
private ServerName |
UnassignRegionHandler.destination |
private ServerName |
WALSplitterHandler.serverName
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
static UnassignRegionHandler |
UnassignRegionHandler.create(HRegionServer server,
String encodedName,
long closeProcId,
boolean abort,
ServerName destination) |
Constructor and Description |
---|
CloseRegionHandler(Server server,
RegionServerServices rsServices,
RegionInfo regionInfo,
boolean abort,
EventType eventType,
ServerName destination) |
CloseRegionHandler(Server server,
RegionServerServices rsServices,
RegionInfo regionInfo,
boolean abort,
ServerName destination)
This method used internally by the RegionServer to close out regions.
|
UnassignRegionHandler(HRegionServer server,
String encodedName,
long closeProcId,
boolean abort,
ServerName destination,
EventType eventType) |
Modifier and Type | Field and Description |
---|---|
private List<ServerName> |
ReplicationQueueInfo.deadRegionServers |
private List<ServerName> |
HBaseReplicationEndpoint.regionServers |
Modifier and Type | Method and Description |
---|---|
protected static List<ServerName> |
HBaseReplicationEndpoint.fetchSlavesAddresses(ZKWatcher zkw)
Get the list of all the region servers from the specified peer
|
List<ServerName> |
ReplicationQueueInfo.getDeadRegionServers() |
List<ServerName> |
ZKReplicationQueueStorage.getListOfReplicators() |
List<ServerName> |
ReplicationQueueStorage.getListOfReplicators()
Get a list of all region servers that have outstanding replication queues.
|
private List<ServerName> |
ZKReplicationQueueStorage.getListOfReplicators0() |
List<ServerName> |
HBaseReplicationEndpoint.getRegionServers()
Get a list of all the addresses of all the available region servers for this peer cluster, or
an empty list if no region servers available at peer cluster.
|
Modifier and Type | Method and Description |
---|---|
void |
ZKReplicationQueueStorage.addWAL(ServerName serverName,
String queueId,
String fileName) |
void |
ReplicationQueueStorage.addWAL(ServerName serverName,
String queueId,
String fileName)
Add a new WAL file to the given queue for a given regionserver.
|
Pair<String,SortedSet<String>> |
ZKReplicationQueueStorage.claimQueue(ServerName sourceServerName,
String queueId,
ServerName destServerName)
This implement must update the cversion of root
ZKReplicationQueueStorage.queuesZNode . |
Pair<String,SortedSet<String>> |
ReplicationQueueStorage.claimQueue(ServerName sourceServerName,
String queueId,
ServerName destServerName)
Change ownership for the queue identified by queueId and belongs to a dead region server.
|
List<String> |
ZKReplicationQueueStorage.getAllQueues(ServerName serverName) |
List<String> |
ReplicationQueueStorage.getAllQueues(ServerName serverName)
Get a list of all queues for the specified region server.
|
private List<String> |
ZKReplicationQueueStorage.getAllQueues0(ServerName serverName) |
private String |
ZKReplicationQueueStorage.getFileNode(ServerName serverName,
String queueId,
String fileName) |
private String |
ZKReplicationQueueStorage.getQueueNode(ServerName serverName,
String queueId) |
String |
ZKReplicationQueueStorage.getRsNode(ServerName serverName) |
String |
ReplicationQueueStorage.getRsNode(ServerName serverName)
Get full znode name for given region server
|
long |
ZKReplicationQueueStorage.getWALPosition(ServerName serverName,
String queueId,
String fileName) |
long |
ReplicationQueueStorage.getWALPosition(ServerName serverName,
String queueId,
String fileName)
Get the current position for a specific WAL in a given queue for a given regionserver.
|
List<String> |
ZKReplicationQueueStorage.getWALsInQueue(ServerName serverName,
String queueId) |
List<String> |
ReplicationQueueStorage.getWALsInQueue(ServerName serverName,
String queueId)
Get a list of all WALs in the given queue on the given region server.
|
private List<String> |
ZKReplicationQueueStorage.getWALsInQueue0(ServerName serverName,
String queueId) |
void |
ReplicationListener.regionServerRemoved(ServerName regionServer)
A region server has been removed from the local cluster
|
void |
ZKReplicationQueueStorage.removeQueue(ServerName serverName,
String queueId) |
void |
ReplicationQueueStorage.removeQueue(ServerName serverName,
String queueId)
Remove a replication queue for a given regionserver.
|
void |
ZKReplicationQueueStorage.removeReplicatorIfQueueIsEmpty(ServerName serverName) |
void |
ReplicationQueueStorage.removeReplicatorIfQueueIsEmpty(ServerName serverName)
Remove the record of region server if the queue is empty.
|
void |
ZKReplicationQueueStorage.removeWAL(ServerName serverName,
String queueId,
String fileName) |
void |
ReplicationQueueStorage.removeWAL(ServerName serverName,
String queueId,
String fileName)
Remove an WAL file from the given queue for a given regionserver.
|
void |
ZKReplicationQueueStorage.setWALPosition(ServerName serverName,
String queueId,
String fileName,
long position,
Map<String,Long> lastSeqIds) |
void |
ReplicationQueueStorage.setWALPosition(ServerName serverName,
String queueId,
String fileName,
long position,
Map<String,Long> lastSeqIds)
Set the current position for a specific WAL in a given queue for a given regionserver.
|
Modifier and Type | Method and Description |
---|---|
private static void |
ReplicationQueueInfo.extractDeadServersFromZNodeString(String deadServerListStr,
List<ServerName> result)
Parse dead server names from queue id.
|
void |
HBaseReplicationEndpoint.setRegionServers(List<ServerName> regionServers)
Set the list of region servers for that peer
|
Modifier and Type | Field and Description |
---|---|
private ServerName |
ClaimReplicationQueueCallable.crashedServer |
private ServerName |
WALEntryStream.serverName |
private ServerName |
ReplicationSinkManager.SinkPeer.serverName |
Modifier and Type | Field and Description |
---|---|
private Map<ServerName,Integer> |
ReplicationSinkManager.badReportCounts |
private List<ServerName> |
ReplicationSinkManager.sinks |
Modifier and Type | Method and Description |
---|---|
ServerName |
ReplicationSyncUp.DummyServer.getServerName() |
(package private) ServerName |
ReplicationSinkManager.SinkPeer.getServerName() |
ServerName |
RecoveredReplicationSource.getServerWALsBelongTo() |
ServerName |
ReplicationSourceInterface.getServerWALsBelongTo()
The queue of WALs only belong to one region server.
|
ServerName |
ReplicationSource.getServerWALsBelongTo() |
Modifier and Type | Method and Description |
---|---|
List<ServerName> |
NoopReplicationQueueStorage.getListOfReplicators() |
private Set<ServerName> |
ReplicationSyncUp.getLiveRegionServers(ZKWatcher zkw) |
protected List<ServerName> |
ReplicationSinkManager.getSinksForTesting() |
Modifier and Type | Method and Description |
---|---|
void |
NoopReplicationQueueStorage.addWAL(ServerName serverName,
String queueId,
String fileName) |
(package private) void |
ReplicationSourceManager.claimQueue(ServerName deadRS,
String queue) |
Pair<String,SortedSet<String>> |
NoopReplicationQueueStorage.claimQueue(ServerName sourceServerName,
String queueId,
ServerName destServerName) |
void |
PeerProcedureHandler.claimReplicationQueue(ServerName crashedServer,
String queue) |
void |
PeerProcedureHandlerImpl.claimReplicationQueue(ServerName crashedServer,
String queue) |
private String |
DumpReplicationQueues.formatQueue(ServerName regionserver,
ReplicationQueueStorage queueStorage,
ReplicationQueueInfo queueInfo,
String queueId,
List<String> wals,
boolean isDeleted,
boolean hdfs) |
List<String> |
NoopReplicationQueueStorage.getAllQueues(ServerName serverName) |
String |
NoopReplicationQueueStorage.getRsNode(ServerName serverName) |
private long |
DumpReplicationQueues.getTotalWALSize(org.apache.hadoop.fs.FileSystem fs,
List<String> wals,
ServerName server)
return total size in bytes from a list of WALs
|
long |
NoopReplicationQueueStorage.getWALPosition(ServerName serverName,
String queueId,
String fileName) |
List<String> |
NoopReplicationQueueStorage.getWALsInQueue(ServerName serverName,
String queueId) |
void |
NoopReplicationQueueStorage.removeQueue(ServerName serverName,
String queueId) |
void |
NoopReplicationQueueStorage.removeReplicatorIfQueueIsEmpty(ServerName serverName) |
void |
NoopReplicationQueueStorage.removeWAL(ServerName serverName,
String queueId,
String fileName) |
void |
NoopReplicationQueueStorage.setWALPosition(ServerName serverName,
String queueId,
String fileName,
long position,
Map<String,Long> lastSeqIds) |
Constructor and Description |
---|
SinkPeer(ServerName serverName,
org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface regionServer) |
WALEntryStream(ReplicationSourceLogQueue logQueue,
org.apache.hadoop.conf.Configuration conf,
long startPosition,
WALFileLengthProvider walFileLengthProvider,
ServerName serverName,
MetricsSource metrics,
String walGroupId)
Create an entry stream over the given queue at the given start position
|
Modifier and Type | Method and Description |
---|---|
ServerName |
RSGroupBasedLoadBalancer.randomAssignment(RegionInfo region,
List<ServerName> servers) |
Modifier and Type | Method and Description |
---|---|
private Pair<Map<TableName,Map<ServerName,List<RegionInfo>>>,List<RegionPlan>> |
RSGroupBasedLoadBalancer.correctAssignments(Map<TableName,Map<ServerName,List<RegionInfo>>> existingAssignments) |
private List<ServerName> |
RSGroupBasedLoadBalancer.filterOfflineServers(RSGroupInfo RSGroupInfo,
List<ServerName> onlineServers) |
private List<ServerName> |
RSGroupBasedLoadBalancer.filterServers(Set<Address> servers,
List<ServerName> onlineServers)
Filter servers based on the online servers.
|
private List<Pair<List<RegionInfo>,List<ServerName>>> |
RSGroupBasedLoadBalancer.generateGroupAssignments(List<RegionInfo> regions,
List<ServerName> servers) |
private List<ServerName> |
RSGroupBasedLoadBalancer.getFallBackCandidates(List<ServerName> servers) |
private List<ServerName> |
RSGroupInfoManagerImpl.getOnlineRS() |
(package private) Map<TableName,Map<ServerName,List<RegionInfo>>> |
RSGroupAdminServer.getRSGroupAssignmentsByTable(TableStateManager tableStateManager,
String groupName)
This is an EXPENSIVE clone.
|
Map<ServerName,List<RegionInfo>> |
RSGroupBasedLoadBalancer.retainAssignment(Map<RegionInfo,ServerName> regions,
List<ServerName> servers) |
Map<ServerName,List<RegionInfo>> |
RSGroupBasedLoadBalancer.roundRobinAssignment(List<RegionInfo> regions,
List<ServerName> servers) |
Modifier and Type | Method and Description |
---|---|
void |
RSGroupBasedLoadBalancer.regionOnline(RegionInfo regionInfo,
ServerName sn) |
void |
RSGroupInfoManagerImpl.ServerEventsListenerThread.serverAdded(ServerName serverName) |
void |
RSGroupInfoManagerImpl.ServerEventsListenerThread.serverRemoved(ServerName serverName) |
Modifier and Type | Method and Description |
---|---|
void |
AccessController.preMove(ObserverContext<MasterCoprocessorEnvironment> c,
RegionInfo region,
ServerName srcServer,
ServerName destServer) |
void |
AccessController.preRecommissionRegionServer(ObserverContext<MasterCoprocessorEnvironment> ctx,
ServerName server,
List<byte[]> encodedRegionNames) |
Modifier and Type | Method and Description |
---|---|
void |
AccessController.preDecommissionRegionServers(ObserverContext<MasterCoprocessorEnvironment> ctx,
List<ServerName> servers,
boolean offload) |
Modifier and Type | Method and Description |
---|---|
Optional<ServerName> |
TestingHBaseClusterImpl.getActiveMasterAddress() |
Optional<ServerName> |
TestingHBaseCluster.getActiveMasterAddress()
Get the address of active master if there is one.
|
List<ServerName> |
TestingHBaseClusterImpl.getBackupMasterAddresses() |
List<ServerName> |
TestingHBaseCluster.getBackupMasterAddresses()
Get all the backup master addresses.
|
List<ServerName> |
TestingHBaseClusterImpl.getRegionServerAddresses() |
List<ServerName> |
TestingHBaseCluster.getRegionServerAddresses()
Get all the region server addresses.
|
Modifier and Type | Method and Description |
---|---|
private int |
TestingHBaseClusterImpl.getMasterIndex(ServerName serverName) |
Optional<OnlineRegions> |
TestingHBaseClusterImpl.getOnlineRegionsInterface(ServerName serverName) |
Optional<OnlineRegions> |
TestingHBaseCluster.getOnlineRegionsInterface(ServerName serverName)
Get the server side
OnlineRegions interface for the specific region server. |
private int |
TestingHBaseClusterImpl.getRegionServerIndex(ServerName serverName) |
CompletableFuture<Void> |
TestingHBaseClusterImpl.stopMaster(ServerName serverName) |
CompletableFuture<Void> |
TestingHBaseCluster.stopMaster(ServerName serverName)
Stop the given master.
|
CompletableFuture<Void> |
TestingHBaseClusterImpl.stopRegionServer(ServerName serverName) |
CompletableFuture<Void> |
TestingHBaseCluster.stopRegionServer(ServerName serverName)
Stop the given region server.
|
Modifier and Type | Method and Description |
---|---|
static Set<ServerName> |
ThriftUtilities.getServerNamesFromThrift(Set<org.apache.hadoop.hbase.thrift2.generated.TServerName> tServerNames) |
Modifier and Type | Method and Description |
---|---|
static Set<org.apache.hadoop.hbase.thrift2.generated.TServerName> |
ThriftUtilities.getServerNamesFromHBase(Set<ServerName> serverNames) |
Modifier and Type | Method and Description |
---|---|
List<ServerName> |
ThriftAdmin.clearDeadServers(List<ServerName> servers) |
Map<ServerName,Boolean> |
ThriftAdmin.compactionSwitch(boolean switchState,
List<String> serverNamesList) |
List<ServerName> |
ThriftAdmin.listDecommissionedRegionServers() |
Modifier and Type | Method and Description |
---|---|
void |
ThriftAdmin.clearCompactionQueues(ServerName serverName,
Set<String> queues) |
void |
ThriftAdmin.closeRegion(ServerName sn,
HRegionInfo hri) |
void |
ThriftAdmin.compactRegionServer(ServerName serverName) |
CoprocessorRpcChannel |
ThriftAdmin.coprocessorService(ServerName serverName) |
void |
ThriftAdmin.flushRegionServer(ServerName serverName) |
List<HRegionInfo> |
ThriftAdmin.getOnlineRegions(ServerName sn) |
List<RegionMetrics> |
ThriftAdmin.getRegionMetrics(ServerName serverName,
TableName tableName) |
List<RegionInfo> |
ThriftAdmin.getRegions(ServerName serverName) |
Map<TableName,SpaceQuotaSnapshot> |
ThriftAdmin.getRegionServerSpaceQuotaSnapshots(ServerName serverName) |
void |
ThriftAdmin.majorCompactRegionServer(ServerName serverName) |
void |
ThriftAdmin.move(byte[] encodedRegionName,
ServerName destServerName) |
void |
ThriftAdmin.recommissionRegionServer(ServerName server,
List<byte[]> encodedRegionNames) |
void |
ThriftAdmin.rollWALWriter(ServerName serverName) |
void |
ThriftAdmin.updateConfiguration(ServerName server) |
Modifier and Type | Method and Description |
---|---|
List<ServerName> |
ThriftAdmin.clearDeadServers(List<ServerName> servers) |
List<Boolean> |
ThriftAdmin.clearSlowLogResponses(Set<ServerName> serverNames) |
void |
ThriftAdmin.decommissionRegionServers(List<ServerName> servers,
boolean offload) |
List<LogEntry> |
ThriftAdmin.getLogEntries(Set<ServerName> serverNames,
String logType,
ServerType serverType,
int limit,
Map<String,Object> filterParams) |
List<OnlineLogRecord> |
ThriftAdmin.getSlowLogResponses(Set<ServerName> serverNames,
LogQueryFilter logQueryFilter) |
Modifier and Type | Field and Description |
---|---|
private ServerName |
CanaryTool.RegionTask.serverName |
private ServerName |
CanaryTool.RegionTaskResult.serverName |
Modifier and Type | Field and Description |
---|---|
private ConcurrentMap<ServerName,LongAdder> |
CanaryTool.RegionStdOutSink.perServerFailuresCount |
Modifier and Type | Method and Description |
---|---|
ServerName |
CanaryTool.RegionTaskResult.getServerName() |
Modifier and Type | Method and Description |
---|---|
ConcurrentMap<ServerName,LongAdder> |
CanaryTool.RegionStdOutSink.getPerServerFailuresCount() |
Modifier and Type | Method and Description |
---|---|
private void |
CanaryTool.RegionStdOutSink.incFailuresCountDetails(ServerName serverName,
RegionInfo region) |
void |
CanaryTool.RegionStdOutSink.publishReadFailure(ServerName serverName,
RegionInfo region,
ColumnFamilyDescriptor column,
Exception e) |
void |
CanaryTool.RegionStdOutSink.publishReadFailure(ServerName serverName,
RegionInfo region,
Exception e) |
void |
CanaryTool.RegionStdOutSink.publishReadTiming(ServerName serverName,
RegionInfo region,
ColumnFamilyDescriptor column,
long msTime) |
void |
CanaryTool.RegionStdOutSink.publishWriteFailure(ServerName serverName,
RegionInfo region,
ColumnFamilyDescriptor column,
Exception e) |
void |
CanaryTool.RegionStdOutSink.publishWriteFailure(ServerName serverName,
RegionInfo region,
Exception e) |
void |
CanaryTool.RegionStdOutSink.publishWriteTiming(ServerName serverName,
RegionInfo region,
ColumnFamilyDescriptor column,
long msTime) |
Constructor and Description |
---|
RegionTask(Connection connection,
RegionInfo region,
ServerName serverName,
CanaryTool.RegionStdOutSink sink,
CanaryTool.RegionTask.TaskType taskType,
boolean rawScanEnabled,
LongAdder rwLatency,
boolean readAllCF) |
RegionTaskResult(RegionInfo region,
TableName tableName,
ServerName serverName,
ColumnFamilyDescriptor column) |
Modifier and Type | Field and Description |
---|---|
(package private) ServerName |
HbckRegionInfo.MetaEntry.regionServer |
private ServerName |
HBaseFsck.WorkItemRegion.rsinfo |
private ServerName |
HbckRegionInfo.OnlineEntry.serverName |
private ServerName |
MoveWithAck.sourceServer |
private ServerName |
MoveWithoutAck.sourceServer |
private ServerName |
MoveWithAck.targetServer |
private ServerName |
MoveWithoutAck.targetServer |
Modifier and Type | Field and Description |
---|---|
(package private) TreeSet<ServerName> |
HbckTableInfo.deployedOn |
private List<ServerName> |
HbckRegionInfo.deployedOn |
Modifier and Type | Method and Description |
---|---|
ServerName |
HbckRegionInfo.MetaEntry.getRegionServer() |
ServerName |
HbckRegionInfo.OnlineEntry.getServerName() |
(package private) static ServerName |
MoveWithAck.getServerNameForRegion(RegionInfo region,
Admin admin,
Connection conn)
Get servername that is up in hbase:meta hosting the given region.
|
private ServerName |
RegionMover.getTargetServer() |
private ServerName |
RegionMover.stripServer(List<ServerName> regionServers,
String hostname,
int port)
Remove the servername whose hostname and port portion matches from the passed array of servers.
|
Modifier and Type | Method and Description |
---|---|
List<ServerName> |
HbckRegionInfo.getDeployedOn() |
Modifier and Type | Method and Description |
---|---|
void |
HbckRegionInfo.addServer(RegionInfo regionInfo,
ServerName serverName) |
void |
HbckTableInfo.addServer(ServerName server) |
static void |
HBaseFsckRepair.closeRegionSilentlyAndWait(Connection connection,
ServerName server,
RegionInfo region)
Contacts a region server and waits up to hbase.hbck.close.timeout ms (default 120s) to close
the region.
|
private boolean |
MoveWithAck.isSameServer(RegionInfo region,
ServerName serverName)
Returns true if passed region is still on serverName when we look at hbase:meta.
|
private void |
RegionMover.submitRegionMovesWhileUnloading(ServerName server,
List<ServerName> regionServers,
List<RegionInfo> movedRegions,
List<RegionInfo> regionsToMove) |
private void |
RegionMover.unloadRegions(ServerName server,
List<ServerName> regionServers,
List<RegionInfo> movedRegions) |
Modifier and Type | Method and Description |
---|---|
static void |
HBaseFsckRepair.fixMetaHoleOnlineAndAddReplicas(org.apache.hadoop.conf.Configuration conf,
RegionInfo hri,
Collection<ServerName> servers,
int numReplicas)
Puts the specified RegionInfo into META with replica related columns
|
static void |
HBaseFsckRepair.fixMultiAssignment(Connection connection,
RegionInfo region,
List<ServerName> servers)
Fix multiple assignment by doing silent closes on each RS hosting the region and then force ZK
unassigned node to OFFLINE to trigger assignment by master.
|
private void |
RegionMover.includeExcludeRegionServers(String fileName,
List<ServerName> regionServers,
boolean isInclude)
Designates or excludes the servername whose hostname and port portion matches the list given in
the file.
|
(package private) void |
HBaseFsck.processRegionServers(Collection<ServerName> regionServerList)
Deprecated.
Contacts each regionserver and fetches metadata about regions.
|
private void |
RegionMover.stripMaster(List<ServerName> regionServers)
Exclude master from list of RSs to move regions to
|
private ServerName |
RegionMover.stripServer(List<ServerName> regionServers,
String hostname,
int port)
Remove the servername whose hostname and port portion matches from the passed array of servers.
|
private void |
RegionMover.submitRegionMovesWhileUnloading(ServerName server,
List<ServerName> regionServers,
List<RegionInfo> movedRegions,
List<RegionInfo> regionsToMove) |
private void |
RegionMover.unloadRegions(ServerName server,
List<ServerName> regionServers,
List<RegionInfo> movedRegions) |
Constructor and Description |
---|
MetaEntry(RegionInfo rinfo,
ServerName regionServer,
long modTime) |
MetaEntry(RegionInfo rinfo,
ServerName regionServer,
long modTime,
RegionInfo splitA,
RegionInfo splitB) |
MoveWithAck(Connection conn,
RegionInfo regionInfo,
ServerName sourceServer,
ServerName targetServer,
List<RegionInfo> movedRegions) |
MoveWithoutAck(Admin admin,
RegionInfo regionInfo,
ServerName sourceServer,
ServerName targetServer,
List<RegionInfo> movedRegions) |
OnlineEntry(RegionInfo regionInfo,
ServerName serverName) |
WorkItemRegion(HBaseFsck hbck,
ServerName info,
HbckErrorReporter errors,
ClusterConnection connection) |
Modifier and Type | Field and Description |
---|---|
private ServerName |
MajorCompactor.Compact.serverName |
Modifier and Type | Field and Description |
---|---|
private Set<ServerName> |
ClusterCompactionQueues.compactingServers |
private Map<ServerName,List<MajorCompactionRequest>> |
ClusterCompactionQueues.compactionQueues |
Modifier and Type | Method and Description |
---|---|
(package private) Optional<ServerName> |
ClusterCompactionQueues.getLargestQueueFromServersNotCompacting() |
private Map<ServerName,List<RegionInfo>> |
MajorCompactor.getServerRegionsMap() |
private Collection<ServerName> |
MajorCompactor.getServersToCompact(Set<ServerName> snSet) |
Modifier and Type | Method and Description |
---|---|
(package private) void |
ClusterCompactionQueues.addToCompactionQueue(ServerName serverName,
MajorCompactionRequest info) |
(package private) List<MajorCompactionRequest> |
ClusterCompactionQueues.getQueue(ServerName serverName) |
(package private) void |
ClusterCompactionQueues.releaseCompaction(ServerName serverName) |
(package private) MajorCompactionRequest |
ClusterCompactionQueues.reserveForCompaction(ServerName serverName) |
Modifier and Type | Method and Description |
---|---|
private Collection<ServerName> |
MajorCompactor.getServersToCompact(Set<ServerName> snSet) |
Constructor and Description |
---|
Compact(ServerName serverName,
MajorCompactionRequest request) |
Modifier and Type | Field and Description |
---|---|
private Map<ServerName,List<String>> |
ReplicationChecker.undeletedQueueIds |
Modifier and Type | Method and Description |
---|---|
private Map<ServerName,List<String>> |
ReplicationChecker.getUnDeletedQueues() |
Modifier and Type | Method and Description |
---|---|
static ServerName |
AbstractFSWALProvider.getServerNameFromWALDirectoryName(org.apache.hadoop.conf.Configuration conf,
String path)
Pulls a ServerName out of a Path generated according to our layout rules.
|
static ServerName |
AbstractFSWALProvider.getServerNameFromWALDirectoryName(org.apache.hadoop.fs.Path logFile)
This function returns region server name from a log file name which is in one of the following
formats:
hdfs://<name node>/hbase/.logs/<server name>-splitting/...
hdfs://<name node>/hbase/.logs/<server name>/...
|
Modifier and Type | Field and Description |
---|---|
private List<ServerName> |
MasterAddressTracker.backupMasters |
private List<ServerName> |
RegionServerAddressTracker.regionServers |
Modifier and Type | Method and Description |
---|---|
private static ServerName |
MetaTableLocator.blockUntilAvailable(ZKWatcher zkw,
int replicaId,
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(ZKWatcher zkw)
Get master address.
|
static ServerName |
MetaTableLocator.getMetaRegionLocation(ZKWatcher zkw)
Gets the meta region location, if available.
|
static ServerName |
MetaTableLocator.getMetaRegionLocation(ZKWatcher zkw,
int replicaId)
Gets the meta region location, if available.
|
static ServerName[] |
ZKServerTool.readZKNodes(org.apache.hadoop.conf.Configuration conf) |
private static ServerName |
MetaTableLocator.waitMetaRegionLocation(ZKWatcher zkw,
int replicaId,
long timeout)
Gets the meta region location, if available, and waits for up to the specified timeout if not
immediately available.
|
static ServerName |
MetaTableLocator.waitMetaRegionLocation(ZKWatcher 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<ServerName> |
MasterAddressTracker.getBackupMasters() |
static List<ServerName> |
MasterAddressTracker.getBackupMastersAndRenewWatch(ZKWatcher zkw)
Retrieves the list of registered backup masters and renews a watch on the znode for children
updates.
|
List<ServerName> |
RegionServerAddressTracker.getRegionServers() |
Modifier and Type | Method and Description |
---|---|
int |
MasterAddressTracker.getBackupMasterInfoPort(ServerName sn)
Get the info port of the backup master if it is available.
|
static int |
MasterAddressTracker.getBackupMasterInfoPort(ZKWatcher zkw,
ServerName sn)
Get backup master info port.
|
String |
ZNodePaths.getRsPath(ServerName sn) |
static boolean |
MasterAddressTracker.setMasterAddress(ZKWatcher 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(ZKWatcher zookeeper,
ServerName serverName,
int replicaId,
RegionState.State state)
Sets the location of
hbase:meta in ZooKeeper to the specified server address. |
static void |
MetaTableLocator.setMetaLocation(ZKWatcher zookeeper,
ServerName serverName,
RegionState.State state)
Sets the location of
hbase:meta in ZooKeeper to the specified server address. |
(package private) static byte[] |
MasterAddressTracker.toByteArray(ServerName sn,
int infoPort) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.