Uses of Class
org.apache.hadoop.hbase.ServerName
Package
Description
Provides HBase Client
Table of Contents
Tools to help define network clients and servers.
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Multi Cluster Replication
HBase REST
Provides an HBase Thrift
service.
-
Uses of ServerName in org.apache.hadoop.hbase
Modifier and TypeFieldDescriptionprivate final ServerName
ClusterMetricsBuilder.ClusterMetricsImpl.masterName
private ServerName
ClusterMetricsBuilder.masterName
private final ServerName
SplitLogTask.originServer
Deprecated.protected ServerName
HBaseServerBase.serverName
The server name the Master sees us as.private final ServerName
HRegionLocation.serverName
private ServerName
MockRegionServerServices.serverName
private final ServerName
ServerMetricsBuilder.ServerMetricsImpl.serverName
private final ServerName
ServerMetricsBuilder.serverName
Modifier and TypeFieldDescriptionprivate List<ServerName>
ClusterMetricsBuilder.backupMasterNames
private final List<ServerName>
ClusterMetricsBuilder.ClusterMetricsImpl.backupMasterNames
private final List<ServerName>
ClusterMetricsBuilder.ClusterMetricsImpl.deadServerNames
private List<ServerName>
ClusterMetricsBuilder.deadServerNames
private final List<ServerName>
ClusterMetricsBuilder.ClusterMetricsImpl.decommissionedServerNames
private List<ServerName>
ClusterMetricsBuilder.decommissionedServerNames
static final List<ServerName>
ServerName.EMPTY_SERVER_LIST
private static final org.apache.hbase.thirdparty.com.google.common.collect.Interner<ServerName>
ServerName.INTERN_POOL
Intern ServerNames.(package private) static Set<ServerName>
MiniHBaseCluster.MiniHBaseClusterRegionServer.killedServers
List of RegionServers killed so far.private final Map<ServerName,
ServerMetrics> ClusterMetricsBuilder.ClusterMetricsImpl.liveServerMetrics
private Map<ServerName,
ServerMetrics> ClusterMetricsBuilder.liveServerMetrics
private final List<ServerName>
ClusterMetricsBuilder.ClusterMetricsImpl.serversName
private List<ServerName>
ClusterMetricsBuilder.serversName
private final List<ServerName>
ClusterMetricsBuilder.ClusterMetricsImpl.unknownServerNames
private List<ServerName>
ClusterMetricsBuilder.unknownServerNames
Modifier and TypeMethodDescriptionClusterMetrics.getMasterName()
Returns detailed information about the current masterServerName
.ClusterMetricsBuilder.ClusterMetricsImpl.getMasterName()
HBaseCluster.getServerHoldingMeta()
Deprecated.Get the ServerName of region server serving the first hbase:meta regionabstract ServerName
HBaseCluster.getServerHoldingRegion
(TableName tn, byte[] regionName) Deprecated.Get the ServerName of region server serving the specified regionMiniHBaseCluster.getServerHoldingRegion
(TableName tn, byte[] regionName) Deprecated.static ServerName
CatalogFamilyFormat.getServerName
(Result r, int replicaId) Returns aServerName
from catalog tableResult
.HBaseServerBase.getServerName()
HRegionLocation.getServerName()
MockRegionServerServices.getServerName()
Server.getServerName()
Returns The unique server name for this server.ServerMetrics.getServerName()
ServerMetricsBuilder.ServerMetricsImpl.getServerName()
SplitLogTask.getServerName()
Deprecated.static ServerName
MetaTableAccessor.getTargetServerName
(Result r, int replicaId) Returns theServerName
from catalog tableResult
where the region is transitioning on.static ServerName
ServerName.parseServerName
(String str) Parse a ServerName from a stringstatic ServerName
ServerName.parseVersionedServerName
(byte[] versionedBytes) Use this method instantiating aServerName
from bytes gotten from a call togetVersionedBytes()
.static ServerName
Retrieve an instance of ServerName.static ServerName
Retrieve an instance of ServerName.static ServerName
Retrieve an instance of ServerName.static ServerName
Retrieve an instance ofServerName
.Modifier and TypeMethodDescriptionClusterMetrics.getBackupMasterNames()
Returns the names of backup mastersClusterMetricsBuilder.ClusterMetricsImpl.getBackupMasterNames()
ClusterMetrics.getDeadServerNames()
Returns the names of region servers on the dead listClusterMetricsBuilder.ClusterMetricsImpl.getDeadServerNames()
ClusterMetrics.getDecommissionedServerNames()
Returns the names of region servers on the decommissioned listClusterMetricsBuilder.ClusterMetricsImpl.getDecommissionedServerNames()
ClusterMetrics.getLiveServerMetrics()
Returns the names of region servers on the live listClusterMetricsBuilder.ClusterMetricsImpl.getLiveServerMetrics()
static Pair<RegionInfo,
ServerName> MetaTableAccessor.getRegion
(Connection connection, byte[] regionName) Deprecated.ClusterMetrics.getServersName()
ClusterMetricsBuilder.ClusterMetricsImpl.getServersName()
private static CompletableFuture<List<Pair<RegionInfo,
ServerName>>> ClientMetaTableAccessor.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.ClusterMetrics.getUnknownServerNames()
Returns the names of region servers on the unknown listClusterMetricsBuilder.ClusterMetricsImpl.getUnknownServerNames()
Modifier and TypeMethodDescriptionstatic Put
MetaTableAccessor.addLocation
(Put p, ServerName sn, long openSeqNum, int replicaId) void
HBaseTestingUtility.assertRegionOnlyOnServer
(RegionInfo hri, ServerName server, long timeout) Deprecated.Check to make sure the region is open on the specified region server, but not on any other one.void
HBaseTestingUtility.assertRegionOnServer
(RegionInfo hri, ServerName server, long timeout) Deprecated.Due to async racing issue, a region may not be in the online region list of a region server yet, after the assignment znode is deleted and the new assignment is recorded in master.int
ServerName.compareTo
(ServerName other) HBaseTestingUtility.createMockRegionServerService
(ServerName name) Deprecated.Create a stubbed out RegionServerService, mainly for getting FS.protected int
MiniHBaseCluster.getMasterIndex
(ServerName serverName) Deprecated.MiniHBaseCluster.getRegionServer
(ServerName serverName) Deprecated.protected int
MiniHBaseCluster.getRegionServerIndex
(ServerName serverName) Deprecated.boolean
SplitLogTask.isDone
(ServerName sn) Deprecated.boolean
SplitLogTask.isErr
(ServerName sn) Deprecated.abstract boolean
HBaseCluster.isKilledRS
(ServerName serverName) Deprecated.Keeping track of killed servers and being able to check if a particular server was killed makes it possible to do fault tolerance testing for dead servers in a deterministic way.boolean
MiniHBaseCluster.isKilledRS
(ServerName serverName) Deprecated.boolean
SplitLogTask.isOwned
(ServerName sn) Deprecated.boolean
SplitLogTask.isResigned
(ServerName sn) Deprecated.static boolean
ServerName.isSameAddress
(ServerName left, ServerName right) Compare two addressesboolean
SplitLogTask.isUnassigned
(ServerName sn) Deprecated.abstract void
HBaseCluster.killDataNode
(ServerName serverName) Deprecated.Kills the datanode process if this is a distributed cluster, otherwise, this causes master to exit doing basic clean up only.void
MiniHBaseCluster.killDataNode
(ServerName serverName) Deprecated.abstract void
HBaseCluster.killMaster
(ServerName serverName) Deprecated.Kills the master process if this is a distributed cluster, otherwise, this causes master to exit doing basic clean up only.void
MiniHBaseCluster.killMaster
(ServerName serverName) Deprecated.abstract void
HBaseCluster.killNameNode
(ServerName serverName) Deprecated.Kills the namenode process if this is a distributed cluster, otherwise, this causes master to exit doing basic clean up only.void
MiniHBaseCluster.killNameNode
(ServerName serverName) Deprecated.abstract void
HBaseCluster.killRegionServer
(ServerName serverName) Deprecated.Kills the region server process if this is a distributed cluster, otherwise this causes the region server to exit doing basic clean up only.void
MiniHBaseCluster.killRegionServer
(ServerName serverName) Deprecated.abstract void
HBaseCluster.killZkNode
(ServerName serverName) Deprecated.Kills the zookeeper node process if this is a distributed cluster, otherwise, this causes master to exit doing basic clean up only.void
MiniHBaseCluster.killZkNode
(ServerName serverName) Deprecated.void
HBaseTestingUtility.moveRegionAndWait
(RegionInfo destRegion, ServerName destServer) Deprecated.Move region to destination server and wait till region is completely moved and onlinestatic ServerMetricsBuilder
ServerMetricsBuilder.newBuilder
(ServerName sn) static ServerMetrics
ServerMetricsBuilder.of
(ServerName sn) static ServerMetrics
ServerMetricsBuilder.of
(ServerName sn, int versionNumber, String version) RegionLocations.removeByServer
(ServerName serverName) Returns a new RegionLocations with the locations removed (set to null) which have the destination server as given.boolean
MockRegionServerServices.removeRegion
(HRegion r, ServerName destination) abstract void
HBaseCluster.resumeRegionServer
(ServerName serverName) Deprecated.Resume the region servervoid
MiniHBaseCluster.resumeRegionServer
(ServerName serverName) Deprecated.ClusterMetricsBuilder.setMasterName
(ServerName value) abstract void
HBaseCluster.startDataNode
(ServerName serverName) Deprecated.Starts a new datanode on the given hostname or if this is a mini/local cluster, silently logs warning message.void
MiniHBaseCluster.startDataNode
(ServerName serverName) Deprecated.abstract void
HBaseCluster.startNameNode
(ServerName serverName) Deprecated.Starts a new namenode on the given hostname or if this is a mini/local cluster, silently logs warning message.void
MiniHBaseCluster.startNameNode
(ServerName serverName) Deprecated.abstract void
HBaseCluster.stopDataNode
(ServerName serverName) Deprecated.Stops the datanode if this is a distributed cluster, otherwise silently logs warning message.void
MiniHBaseCluster.stopDataNode
(ServerName serverName) Deprecated.abstract void
HBaseCluster.stopMaster
(ServerName serverName) Deprecated.Stops the given master, by attempting a gradual stop.void
MiniHBaseCluster.stopMaster
(ServerName serverName) Deprecated.abstract void
HBaseCluster.stopNameNode
(ServerName serverName) Deprecated.Stops the namenode if this is a distributed cluster, otherwise silently logs warning message.void
MiniHBaseCluster.stopNameNode
(ServerName serverName) Deprecated.abstract void
HBaseCluster.stopRegionServer
(ServerName serverName) Deprecated.Stops the given region server, by attempting a gradual stop.void
MiniHBaseCluster.stopRegionServer
(ServerName serverName) Deprecated.abstract void
HBaseCluster.stopZkNode
(ServerName serverName) Deprecated.Stops the region zookeeper if this is a distributed cluster, otherwise silently logs warning message.void
MiniHBaseCluster.stopZkNode
(ServerName serverName) Deprecated.abstract void
HBaseCluster.suspendRegionServer
(ServerName serverName) Deprecated.Suspend the region servervoid
MiniHBaseCluster.suspendRegionServer
(ServerName serverName) Deprecated.static ServerMetrics
ServerMetricsBuilder.toServerMetrics
(ServerName serverName, int versionNumber, String version, org.apache.hadoop.hbase.shaded.protobuf.generated.ClusterStatusProtos.ServerLoad serverLoadPB) static ServerMetrics
ServerMetricsBuilder.toServerMetrics
(ServerName serverName, 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.abstract void
HBaseCluster.waitForDataNodeToStart
(ServerName serverName, long timeout) Deprecated.Wait for the specified datanode to join the clustervoid
MiniHBaseCluster.waitForDataNodeToStart
(ServerName serverName, long timeout) Deprecated.abstract void
HBaseCluster.waitForDataNodeToStop
(ServerName serverName, long timeout) Deprecated.Wait for the specified datanode to stop the thread / process.void
MiniHBaseCluster.waitForDataNodeToStop
(ServerName serverName, long timeout) Deprecated.abstract void
HBaseCluster.waitForMasterToStop
(ServerName serverName, long timeout) Deprecated.Wait for the specified master to stop the thread / process.void
MiniHBaseCluster.waitForMasterToStop
(ServerName serverName, long timeout) Deprecated.abstract void
HBaseCluster.waitForNameNodeToStart
(ServerName serverName, long timeout) Deprecated.Wait for the specified namenode to join the clustervoid
MiniHBaseCluster.waitForNameNodeToStart
(ServerName serverName, long timeout) Deprecated.abstract void
HBaseCluster.waitForNameNodeToStop
(ServerName serverName, long timeout) Deprecated.Wait for the specified namenode to stopvoid
MiniHBaseCluster.waitForNameNodeToStop
(ServerName serverName, long timeout) Deprecated.abstract void
HBaseCluster.waitForRegionServerToStop
(ServerName serverName, long timeout) Deprecated.Wait for the specified region server to stop the thread / process.void
MiniHBaseCluster.waitForRegionServerToStop
(ServerName serverName, long timeout) Deprecated.abstract void
HBaseCluster.waitForZkNodeToStart
(ServerName serverName, long timeout) Deprecated.Wait for the specified zookeeper node to join the clustervoid
MiniHBaseCluster.waitForZkNodeToStart
(ServerName serverName, long timeout) Deprecated.abstract void
HBaseCluster.waitForZkNodeToStop
(ServerName serverName, long timeout) Deprecated.Wait for the specified zookeeper node to stop the thread / process.void
MiniHBaseCluster.waitForZkNodeToStop
(ServerName serverName, long timeout) Deprecated.Modifier and TypeMethodDescriptionprivate static List<RegionInfo>
MetaTableAccessor.getListOfRegionInfos
(List<Pair<RegionInfo, ServerName>> pairs) ClusterMetricsBuilder.setBackerMasterNames
(List<ServerName> value) ClusterMetricsBuilder.setDeadServerNames
(List<ServerName> value) ClusterMetricsBuilder.setDecommissionedServerNames
(List<ServerName> value) ClusterMetricsBuilder.setLiveServerMetrics
(Map<ServerName, ServerMetrics> value) ClusterMetricsBuilder.setServerNames
(List<ServerName> serversName) ClusterMetricsBuilder.setUnknownServerNames
(List<ServerName> value) ModifierConstructorDescription(package private)
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, List<ServerName> decommissionedServerNames) Done
(ServerName originServer) Err
(ServerName originServer) HRegionLocation
(RegionInfo regionInfo, ServerName serverName) HRegionLocation
(RegionInfo regionInfo, ServerName serverName, long seqNum) MockRegionServerServices
(ZKWatcher zkw, ServerName serverName) Owned
(ServerName originServer) Resigned
(ServerName originServer) private
ServerMetricsBuilder
(ServerName serverName) (package private)
ServerMetricsImpl
(ServerName serverName, int versionNumber, String version, long requestCountPerSecond, long requestCount, long readRequestsCount, long writeRequestsCount, 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, Map<String, Integer> regionCachedInfo) (package private)
SplitLogTask
(ServerName originServer, org.apache.hadoop.hbase.shaded.protobuf.generated.ZooKeeperProtos.SplitLogTask.State state) Deprecated.Unassigned
(ServerName originServer) ModifierConstructorDescription(package private)
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, List<ServerName> decommissionedServerNames) (package private)
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, List<ServerName> decommissionedServerNames) -
Uses of ServerName in org.apache.hadoop.hbase.client
Modifier and TypeFieldDescriptionprivate final ServerName
AsyncRegionServerAdmin.server
private ServerName
AsyncAdminRequestRetryingCaller.serverName
private ServerName
AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder.serverName
private ServerName
AsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder.serverName
private ServerName
AsyncServerRequestRpcRetryingCaller.serverName
Modifier and TypeFieldDescriptionprivate org.apache.hbase.thirdparty.com.google.common.collect.ImmutableMap<ServerName,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.ClientMetaService.Interface> ConnectionRegistryRpcStubHolder.addr2Stub
private CompletableFuture<org.apache.hbase.thirdparty.com.google.common.collect.ImmutableMap<ServerName,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.ClientMetaService.Interface>> ConnectionRegistryRpcStubHolder.addr2StubFuture
private final Set<ServerName>
ConnectionRegistryRpcStubHolder.bootstrapNodes
private final List<ServerName>
ClusterIdFetcher.bootstrapServers
private final List<ServerName>
ClusterStatusListener.deadServers
private final Map<ServerName,
Long> SimpleRequestController.RequestHeapSizeChecker.serverRequestSizes
private final Map<ServerName,
Long> SimpleRequestController.RequestRowsChecker.serverRows
private final Set<ServerName>
SimpleRequestController.TaskCountChecker.serversIncluded
private ConcurrentHashMap<ServerName,
ConcurrentMap<byte[], MetricsConnection.RegionStats>> MetricsConnection.serverStats
private final ConcurrentHashMap<ServerName,
ServerStatistics> ServerStatisticTracker.stats
private final Map<ServerName,
AtomicInteger> SimpleRequestController.TaskCountChecker.taskCounterPerServer
(package private) final ConcurrentMap<ServerName,
AtomicInteger> SimpleRequestController.taskCounterPerServer
Modifier and TypeMethodDescriptiondefault ServerName
Admin.getMaster()
Get the current active master.Modifier and TypeMethodDescriptionAdmin.clearDeadServers
(List<ServerName> servers) Clear dead region servers from master.AdminOverAsyncAdmin.clearDeadServers
(List<ServerName> servers) AsyncAdmin.clearDeadServers
(List<ServerName> servers) Clear dead region servers from master.AsyncHBaseAdmin.clearDeadServers
(List<ServerName> servers) RawAsyncHBaseAdmin.clearDeadServers
(List<ServerName> servers) Admin.compactionSwitch
(boolean switchState, List<String> serverNamesList) Turn the compaction on or off.AdminOverAsyncAdmin.compactionSwitch
(boolean switchState, List<String> serverNamesList) AsyncAdmin.compactionSwitch
(boolean switchState, List<String> serverNamesList) Turn the compaction on or off.AsyncHBaseAdmin.compactionSwitch
(boolean switchState, List<String> serverNamesList) RawAsyncHBaseAdmin.compactionSwitch
(boolean switchState, List<String> serverNamesList) static <S,
R> CompletableFuture<Map<ServerName, Object>> AsyncAdminClientUtils.coprocessorServiceOnAllRegionServers
(AsyncAdmin asyncAdmin, Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable) Execute the given coprocessor call on all region servers.private org.apache.hbase.thirdparty.com.google.common.collect.ImmutableMap<ServerName,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.ClientMetaService.Interface> ConnectionRegistryRpcStubHolder.createStubs
(RpcClient rpcClient, Collection<ServerName> addrs) private CompletableFuture<org.apache.hbase.thirdparty.com.google.common.collect.ImmutableMap<ServerName,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.ClientMetaService.Interface>> ConnectionRegistryRpcStubHolder.fetchClusterIdAndCreateStubs()
protected abstract CompletableFuture<Set<ServerName>>
AbstractRpcBasedConnectionRegistry.fetchEndpoints()
protected CompletableFuture<Set<ServerName>>
MasterRegistry.fetchEndpoints()
Deprecated.protected CompletableFuture<Set<ServerName>>
RpcConnectionRegistry.fetchEndpoints()
AbstractRpcBasedConnectionRegistry.getActiveMaster()
ConnectionRegistry.getActiveMaster()
Get the address of active HMaster.ConnectionRegistryEndpoint.getActiveMaster()
Get active master address.ShortCircuitConnectionRegistry.getActiveMaster()
ZKConnectionRegistry.getActiveMaster()
Deprecated.AsyncClusterConnection.getAllBootstrapNodes
(ServerName regionServer) Get the bootstrap node list of another region server.AsyncClusterConnectionImpl.getAllBootstrapNodes
(ServerName regionServer) default Collection<ServerName>
Admin.getBackupMasters()
Get a list of current backup masters.default CompletableFuture<Collection<ServerName>>
AsyncAdmin.getBackupMasters()
Returns current backup master list wrapped byCompletableFuture
ConnectionRegistryEndpoint.getBackupMasters()
Get backup masters address.protected abstract Set<ServerName>
AbstractRpcBasedConnectionRegistry.getBootstrapNodes
(org.apache.hadoop.conf.Configuration conf) ConnectionRegistryEndpoint.getBootstrapNodes()
Get a iterator of the available bootstrap nodes.protected Set<ServerName>
MasterRegistry.getBootstrapNodes
(org.apache.hadoop.conf.Configuration conf) Deprecated.private CompletableFuture<Set<ServerName>>
RpcConnectionRegistry.getBootstrapNodes()
protected Set<ServerName>
RpcConnectionRegistry.getBootstrapNodes
(org.apache.hadoop.conf.Configuration conf) AsyncClusterConnection.getLiveRegionServers
(MasterAddressTracker masterAddrTracker, int count) Get live region servers from masters.AsyncClusterConnectionImpl.getLiveRegionServers
(MasterAddressTracker masterAddrTracker, int count) default CompletableFuture<ServerName>
AsyncAdmin.getMaster()
Returns current master server name wrapped byCompletableFuture
(package private) CompletableFuture<Set<ServerName>>
MasterRegistry.getMasters()
Deprecated.(package private) Set<ServerName>
AbstractRpcBasedConnectionRegistry.getParsedServers()
private CompletableFuture<List<ServerName>>
RawAsyncHBaseAdmin.getRegionServerList
(List<String> serverNamesList) default Collection<ServerName>
Admin.getRegionServers()
Get the live server list.default Collection<ServerName>
Admin.getRegionServers
(boolean excludeDecommissionedRS) Retrieve all current live region servers including decommissioned if excludeDecommissionedRS is false, else non-decommissioned ones onlydefault CompletableFuture<Collection<ServerName>>
AsyncAdmin.getRegionServers()
Returns current live region servers list wrapped byCompletableFuture
default CompletableFuture<Collection<ServerName>>
AsyncAdmin.getRegionServers
(boolean excludeDecommissionedRS) MetricsConnection.getServerStats()
serverStats metricprivate Pair<RegionState.State,
ServerName> ZKConnectionRegistry.getStateAndServerName
(org.apache.hadoop.hbase.shaded.protobuf.generated.ZooKeeperProtos.MetaRegionServer proto) Deprecated.(package private) CompletableFuture<org.apache.hbase.thirdparty.com.google.common.collect.ImmutableMap<ServerName,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.ClientMetaService.Interface>> ConnectionRegistryRpcStubHolder.getStubs()
default List<ServerName>
Admin.listDeadServers()
List dead region servers.default CompletableFuture<List<ServerName>>
AsyncAdmin.listDeadServers()
List all the dead region servers.AsyncHBaseAdmin.listDeadServers()
Admin.listDecommissionedRegionServers()
List region servers marked as decommissioned, which can not be assigned regions.AdminOverAsyncAdmin.listDecommissionedRegionServers()
AsyncAdmin.listDecommissionedRegionServers()
List region servers marked as decommissioned, which can not be assigned regions.AsyncHBaseAdmin.listDecommissionedRegionServers()
RawAsyncHBaseAdmin.listDecommissionedRegionServers()
default List<ServerName>
Admin.listUnknownServers()
List unknown region servers.default CompletableFuture<List<ServerName>>
AsyncAdmin.listUnknownServers()
List all the unknown region servers.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>
MasterRegistry.transformServerNames
(org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetMastersResponse resp) Deprecated.private static Set<ServerName>
RpcConnectionRegistry.transformServerNames
(org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetBootstrapNodesResponse resp) Modifier and TypeMethodDescriptionprivate void
AsyncBatchRpcRetryingCaller.addError
(Iterable<Action> actions, Throwable error, ServerName serverName) private void
AsyncBatchRpcRetryingCaller.addError
(Action action, Throwable error, ServerName serverName) private CompletableFuture<CacheEvictionStats>
RawAsyncHBaseAdmin.clearBlockCache
(ServerName serverName, List<RegionInfo> hris) (package private) void
AsyncMetaRegionLocator.clearCache
(ServerName serverName) (package private) void
AsyncNonMetaRegionLocator.clearCache
(ServerName serverName) (package private) void
AsyncRegionLocator.clearCache
(ServerName serverName) void
Admin.clearCompactionQueues
(ServerName serverName, Set<String> queues) Clear compacting queues on a regionserver.void
AdminOverAsyncAdmin.clearCompactionQueues
(ServerName serverName, Set<String> queues) AsyncAdmin.clearCompactionQueues
(ServerName serverName, Set<String> queues) Clear compacting queues on a region server.AsyncHBaseAdmin.clearCompactionQueues
(ServerName serverName, Set<String> queues) RawAsyncHBaseAdmin.clearCompactionQueues
(ServerName serverName, Set<String> queues) private CompletableFuture<Boolean>
RawAsyncHBaseAdmin.clearSlowLogsResponses
(ServerName serverName) 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.void
AdminOverAsyncAdmin.compactRegionServer
(ServerName serverName) AsyncAdmin.compactRegionServer
(ServerName serverName) Compact all regions on the region server.AsyncHBaseAdmin.compactRegionServer
(ServerName serverName) RawAsyncHBaseAdmin.compactRegionServer
(ServerName sn) private CompletableFuture<Void>
RawAsyncHBaseAdmin.compactRegionServer
(ServerName sn, boolean major) Admin.coprocessorService
(ServerName serverName) Deprecated.since 3.0.0, will removed in 4.0.0.AdminOverAsyncAdmin.coprocessorService
(ServerName serverName) <S,
R> CompletableFuture<R> AsyncAdmin.coprocessorService
(Function<org.apache.hbase.thirdparty.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> AsyncHBaseAdmin.coprocessorService
(Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, ServerName serverName) <S,
R> CompletableFuture<R> RawAsyncHBaseAdmin.coprocessorService
(Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, ServerName serverName) private org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.Interface
AsyncConnectionImpl.createAdminServerStub
(ServerName serverName) 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) 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<org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.FlushRegionResponse>
RawAsyncHBaseAdmin.flush
(ServerName serverName, RegionInfo regionInfo, byte[] columnFamily, boolean writeFlushWALMarker) void
Admin.flushRegionServer
(ServerName serverName) Flush all regions on the region server.void
AdminOverAsyncAdmin.flushRegionServer
(ServerName serverName) AsyncAdmin.flushRegionServer
(ServerName serverName) Flush all region on the region server.AsyncHBaseAdmin.flushRegionServer
(ServerName sn) RawAsyncHBaseAdmin.flushRegionServer
(ServerName sn) (package private) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.Interface
AsyncConnectionImpl.getAdminStub
(ServerName serverName) AsyncClusterConnection.getAllBootstrapNodes
(ServerName regionServer) Get the bootstrap node list of another region server.AsyncClusterConnectionImpl.getAllBootstrapNodes
(ServerName regionServer) Admin.getCachedFilesList
(ServerName serverName) Get the list of cached filesAdminOverAsyncAdmin.getCachedFilesList
(ServerName serverName) AsyncAdmin.getCachedFilesList
(ServerName serverName) Get the list of cached filesAsyncHBaseAdmin.getCachedFilesList
(ServerName serverName) RawAsyncHBaseAdmin.getCachedFilesList
(ServerName serverName) private String
AsyncBatchRpcRetryingCaller.getExtraContextForError
(ServerName serverName) AsyncConnection.getHbck
(ServerName masterServer) Retrieve an Hbck implementation to fix an HBase cluster.AsyncConnectionImpl.getHbck
(ServerName masterServer) default Hbck
Connection.getHbck
(ServerName masterServer) Retrieve an Hbck implementation to fix an HBase cluster.ConnectionOverAsyncConnection.getHbck
(ServerName masterServer) SharedAsyncConnection.getHbck
(ServerName masterServer) SharedConnection.getHbck
(ServerName masterServer) private Hbck
AsyncConnectionImpl.getHbckInternal
(ServerName masterServer) Admin.getRegionMetrics
(ServerName serverName) GetRegionMetrics
of all regions hosted on a regionserver.Admin.getRegionMetrics
(ServerName serverName, TableName tableName) GetRegionMetrics
of all regions hosted on a regionserver for a table.AdminOverAsyncAdmin.getRegionMetrics
(ServerName serverName) AdminOverAsyncAdmin.getRegionMetrics
(ServerName serverName, TableName tableName) AsyncAdmin.getRegionMetrics
(ServerName serverName) Get a list ofRegionMetrics
of all regions hosted on a region server.AsyncAdmin.getRegionMetrics
(ServerName serverName, TableName tableName) Get a list ofRegionMetrics
of all regions hosted on a region server for a table.AsyncHBaseAdmin.getRegionMetrics
(ServerName serverName) AsyncHBaseAdmin.getRegionMetrics
(ServerName serverName, TableName tableName) RawAsyncHBaseAdmin.getRegionMetrics
(ServerName serverName) RawAsyncHBaseAdmin.getRegionMetrics
(ServerName serverName, TableName tableName) private CompletableFuture<List<RegionMetrics>>
RawAsyncHBaseAdmin.getRegionMetrics
(org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionLoadRequest request, ServerName serverName) Admin.getRegions
(ServerName serverName) Get all the online regions on a region server.AdminOverAsyncAdmin.getRegions
(ServerName serverName) AsyncAdmin.getRegions
(ServerName serverName) Get all the online regions on a region server.AsyncHBaseAdmin.getRegions
(ServerName serverName) RawAsyncHBaseAdmin.getRegions
(ServerName serverName) AsyncClusterConnection.getRegionServerAdmin
(ServerName serverName) Get the admin service for the given region server.AsyncClusterConnectionImpl.getRegionServerAdmin
(ServerName serverName) Map<TableName,
? extends SpaceQuotaSnapshotView> Admin.getRegionServerSpaceQuotaSnapshots
(ServerName serverName) Fetches the observedSpaceQuotaSnapshotView
s observed by a RegionServer.Map<TableName,
? extends SpaceQuotaSnapshotView> AdminOverAsyncAdmin.getRegionServerSpaceQuotaSnapshots
(ServerName serverName) CompletableFuture<? extends Map<TableName,
? extends SpaceQuotaSnapshotView>> AsyncAdmin.getRegionServerSpaceQuotaSnapshots
(ServerName serverName) Fetches the observedSpaceQuotaSnapshotView
s observed by a RegionServer.AsyncHBaseAdmin.getRegionServerSpaceQuotaSnapshots
(ServerName serverName) RawAsyncHBaseAdmin.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) 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.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) boolean
ClusterStatusListener.isDeadServer
(ServerName sn) Check if we know if a server is dead.private void
AsyncBatchRpcRetryingCaller.logException
(int tries, Supplier<Stream<AsyncBatchRpcRetryingCaller.RegionRequest>> regionsSupplier, Throwable error, ServerName serverName) void
Admin.majorCompactRegionServer
(ServerName serverName) Major compact all regions on the region server.void
AdminOverAsyncAdmin.majorCompactRegionServer
(ServerName serverName) AsyncAdmin.majorCompactRegionServer
(ServerName serverName) Compact all regions on the region server.AsyncHBaseAdmin.majorCompactRegionServer
(ServerName serverName) RawAsyncHBaseAdmin.majorCompactRegionServer
(ServerName sn) void
Admin.move
(byte[] encodedRegionName, ServerName destServerName) Move the regionencodedRegionName
todestServerName
.void
AdminOverAsyncAdmin.move
(byte[] encodedRegionName, ServerName destServerName) AsyncAdmin.move
(byte[] regionName, ServerName destServerName) Move the regionr
todest
.AsyncHBaseAdmin.move
(byte[] regionName, ServerName destServerName) RawAsyncHBaseAdmin.move
(byte[] regionName, ServerName destServerName) void
ClusterStatusListener.DeadServerHandler.newDead
(ServerName sn) Called when a server is identified as dead.private void
AsyncBatchRpcRetryingCaller.onComplete
(Map<byte[], AsyncBatchRpcRetryingCaller.RegionRequest> actionsByRegion, int tries, ServerName serverName, MultiResponse resp) 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.onError
(Map<byte[], AsyncBatchRpcRetryingCaller.RegionRequest> actionsByRegion, int tries, Throwable t, ServerName serverName) void
Admin.recommissionRegionServer
(ServerName server, List<byte[]> encodedRegionNames) Remove decommission marker from a region server to allow regions assignments.void
AdminOverAsyncAdmin.recommissionRegionServer
(ServerName server, List<byte[]> encodedRegionNames) AsyncAdmin.recommissionRegionServer
(ServerName server, List<byte[]> encodedRegionNames) Remove decommission marker from a region server to allow regions assignments.AsyncHBaseAdmin.recommissionRegionServer
(ServerName server, List<byte[]> encodedRegionNames) RawAsyncHBaseAdmin.recommissionRegionServer
(ServerName server, List<byte[]> encodedRegionNames) void
AsyncRegionLocationCache.removeForServer
(ServerName serverName) Removes serverName from all locations in the cache, fully removing any RegionLocations which are empty after removing the server from it.void
Admin.rollWALWriter
(ServerName serverName) Roll the log writer.void
AdminOverAsyncAdmin.rollWALWriter
(ServerName serverName) AsyncAdmin.rollWALWriter
(ServerName serverName) Roll the log writer.AsyncHBaseAdmin.rollWALWriter
(ServerName serverName) RawAsyncHBaseAdmin.rollWALWriter
(ServerName serverName) private void
AsyncBatchRpcRetryingCaller.sendToServer
(ServerName serverName, AsyncBatchRpcRetryingCaller.ServerRequest serverReq, int tries) AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder.serverName
(ServerName serverName) AsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder.serverName
(ServerName serverName) AsyncAdmin.stopRegionServer
(ServerName serverName) Stop the designated regionserver.AsyncHBaseAdmin.stopRegionServer
(ServerName serverName) RawAsyncHBaseAdmin.stopRegionServer
(ServerName serverName) private CompletableFuture<Boolean>
RawAsyncHBaseAdmin.switchCompact
(ServerName serverName, boolean onOrOff) void
Admin.updateConfiguration
(ServerName server) Update the configuration and trigger an online config change on the regionserver.void
AdminOverAsyncAdmin.updateConfiguration
(ServerName server) AsyncAdmin.updateConfiguration
(ServerName serverName) Update the configuration and trigger an online config change on the regionserver.AsyncHBaseAdmin.updateConfiguration
(ServerName serverName) RawAsyncHBaseAdmin.updateConfiguration
(ServerName serverName) void
MetricsConnection.updateRegionStats
(ServerName serverName, byte[] regionName, RegionLoadStats stats) void
ServerStatisticTracker.updateRegionStats
(ServerName server, byte[] region, RegionLoadStats currentStats) void
StatisticTrackable.updateRegionStats
(ServerName server, byte[] region, RegionLoadStats stats) Update stats per region.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) static void
ResultStatsUtil.updateStats
(StatisticTrackable tracker, ServerName server, byte[] regionName, RegionLoadStats stats) Update the statistics for the specified region.Modifier and TypeMethodDescriptionAdmin.clearDeadServers
(List<ServerName> servers) Clear dead region servers from master.AdminOverAsyncAdmin.clearDeadServers
(List<ServerName> servers) AsyncAdmin.clearDeadServers
(List<ServerName> servers) Clear dead region servers from master.AsyncHBaseAdmin.clearDeadServers
(List<ServerName> servers) RawAsyncHBaseAdmin.clearDeadServers
(List<ServerName> servers) Admin.clearSlowLogResponses
(Set<ServerName> serverNames) Clears online slow/large RPC logs from the provided list of RegionServersAdminOverAsyncAdmin.clearSlowLogResponses
(Set<ServerName> serverNames) AsyncAdmin.clearSlowLogResponses
(Set<ServerName> serverNames) Clears online slow RPC logs from the provided list of RegionServersAsyncHBaseAdmin.clearSlowLogResponses
(Set<ServerName> serverNames) RawAsyncHBaseAdmin.clearSlowLogResponses
(Set<ServerName> serverNames) private org.apache.hbase.thirdparty.com.google.common.collect.ImmutableMap<ServerName,
org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.ClientMetaService.Interface> ConnectionRegistryRpcStubHolder.createStubs
(RpcClient rpcClient, Collection<ServerName> addrs) void
Admin.decommissionRegionServers
(List<ServerName> servers, boolean offload) Mark region server(s) as decommissioned to prevent additional regions from getting assigned to them.void
AdminOverAsyncAdmin.decommissionRegionServers
(List<ServerName> servers, boolean offload) AsyncAdmin.decommissionRegionServers
(List<ServerName> servers, boolean offload) Mark region server(s) as decommissioned to prevent additional regions from getting assigned to them.AsyncHBaseAdmin.decommissionRegionServers
(List<ServerName> servers, boolean offload) RawAsyncHBaseAdmin.decommissionRegionServers
(List<ServerName> servers, boolean offload) Admin.getLogEntries
(Set<ServerName> serverNames, String logType, ServerType serverType, int limit, Map<String, Object> filterParams) Retrieve recent online records from HMaster / RegionServers.AdminOverAsyncAdmin.getLogEntries
(Set<ServerName> serverNames, String logType, ServerType serverType, int limit, Map<String, Object> filterParams) AsyncAdmin.getLogEntries
(Set<ServerName> serverNames, String logType, ServerType serverType, int limit, Map<String, Object> filterParams) Retrieve recent online records from HMaster / RegionServers.AsyncHBaseAdmin.getLogEntries
(Set<ServerName> serverNames, String logType, ServerType serverType, int limit, Map<String, Object> filterParams) RawAsyncHBaseAdmin.getLogEntries
(Set<ServerName> serverNames, String logType, ServerType serverType, int limit, Map<String, Object> filterParams) default List<OnlineLogRecord>
Admin.getSlowLogResponses
(Set<ServerName> serverNames, LogQueryFilter logQueryFilter) Deprecated.since 2.4.0 and will be removed in 4.0.0.default CompletableFuture<List<OnlineLogRecord>>
AsyncAdmin.getSlowLogResponses
(Set<ServerName> serverNames, LogQueryFilter logQueryFilter) Deprecated.since 2.4.0 and will be removed in 4.0.0.private CompletableFuture<List<LogEntry>>
RawAsyncHBaseAdmin.getSlowLogResponses
(Map<String, Object> filterParams, Set<ServerName> serverNames, int limit, String logType) private <T extends org.apache.hbase.thirdparty.com.google.protobuf.Message>
voidAbstractRpcBasedConnectionRegistry.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.(package private) void
ConnectionRegistryRpcStubHolder.refreshStubs
(IOExceptionSupplier<Collection<ServerName>> fetchEndpoints) HBaseHbck.scheduleServerCrashProcedures
(List<ServerName> serverNames) Hbck.scheduleServerCrashProcedures
(List<ServerName> serverNames) private void
AsyncBatchRpcRetryingCaller.sendOrDelay
(Map<ServerName, AsyncBatchRpcRetryingCaller.ServerRequest> actionsByServer, int tries) ModifierConstructorDescriptionAsyncAdminRequestRetryingCaller
(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) (package private)
AsyncRegionServerAdmin
(ServerName server, AsyncConnectionImpl conn) 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) ModifierConstructorDescription(package private)
ClusterIdFetcher
(org.apache.hadoop.conf.Configuration conf, User user, RpcControllerFactory rpcControllerFactory, Set<ServerName> bootstrapServers) (package private)
ConnectionRegistryRpcStubHolder
(org.apache.hadoop.conf.Configuration conf, User user, RpcControllerFactory rpcControllerFactory, Set<ServerName> bootstrapNodes) (package private)
TaskCountChecker
(int maxTotalConcurrentTasks, int maxConcurrentTasksPerServer, int maxConcurrentTasksPerRegion, AtomicLong tasksInProgress, Map<ServerName, AtomicInteger> taskCounterPerServer, Map<byte[], AtomicInteger> taskCounterPerRegion) -
Uses of ServerName in org.apache.hadoop.hbase.client.backoff
Modifier and TypeMethodDescriptionlong
ClientBackoffPolicy.getBackoffTime
(ServerName serverName, byte[] region, ServerStatistics stats) Returns the number of ms to wait on the client based on thelong
ClientBackoffPolicyFactory.NoBackoffPolicy.getBackoffTime
(ServerName serverName, byte[] region, ServerStatistics stats) long
ExponentialClientBackoffPolicy.getBackoffTime
(ServerName serverName, byte[] region, ServerStatistics stats) -
Uses of ServerName in org.apache.hadoop.hbase.coordination
Modifier and TypeFieldDescriptionprivate final ServerName
ZkSplitLogWorkerCoordination.serverName
Modifier and TypeMethodDescriptionSplitLogManagerCoordination.SplitLogManagerDetails.getServerName()
Returns server nameModifier and TypeMethodDescriptionprotected 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.finish
(ServerName workerName, String taskname) finish the partially done task.private void
ZKSplitLogManagerCoordination.heartbeat
(String path, int new_version, ServerName workerName) ModifierConstructorDescriptionZkSplitLogWorkerCoordination
(ServerName serverName, ZKWatcher watcher) -
Uses of ServerName in org.apache.hadoop.hbase.coprocessor
Modifier and TypeMethodDescriptionMasterCoprocessorEnvironment.getServerName()
Returns Hosting Server's ServerNameRegionCoprocessorEnvironment.getServerName()
Returns Hosting Server's ServerNameRegionServerCoprocessorEnvironment.getServerName()
Returns Hosting Server's ServerNameModifier and TypeMethodDescriptiondefault 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 TypeMethodDescriptiondefault 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. -
Uses of ServerName in org.apache.hadoop.hbase.exceptions
ModifierConstructorDescriptionPreemptiveFastFailException
(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) ModifierConstructorDescriptionMasterRegistryFetchException
(Set<ServerName> masters, Throwable failure) -
Uses of ServerName in org.apache.hadoop.hbase.favored
Modifier and TypeClassDescription(package private) class
This class differs from ServerName in that start code is always ignored.Modifier and TypeFieldDescriptionprivate final Map<String,
List<ServerName>> FavoredNodesPlan.favoredNodesMap
The map between each region name and its favored region server listprivate final Map<ServerName,
List<RegionInfo>> FavoredNodesManager.primaryRSToRegionMap
private Map<String,
List<ServerName>> FavoredNodeAssignmentHelper.rackToRegionServerMap
private final Map<ServerName,
List<RegionInfo>> FavoredNodesManager.secondaryRSToRegionMap
private List<ServerName>
FavoredNodeAssignmentHelper.servers
private final Map<ServerName,
List<RegionInfo>> FavoredNodesManager.teritiaryRSToRegionMap
Modifier and TypeMethodDescriptionprivate ServerName
FavoredNodeLoadBalancer.availableServersContains
(List<ServerName> servers, ServerName favoredNode) FavoredNodeAssignmentHelper.generateMissingFavoredNode
(List<ServerName> favoredNodes) 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.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) FavoredNodeLoadBalancer.randomAssignment
(RegionInfo regionInfo, List<ServerName> servers) private ServerName[]
FavoredNodeAssignmentHelper.singleRackCase
(RegionInfo regionInfo, ServerName primaryRS, String primaryRack) Modifier and TypeMethodDescriptionprivate Map<RegionInfo,
List<ServerName>> FavoredNodeAssignmentHelper.generateFavoredNodes
(Map<RegionInfo, ServerName> primaryRSMap) FavoredNodeAssignmentHelper.generateFavoredNodes
(RegionInfo hri) FavoredNodeAssignmentHelper.generateFavoredNodesRoundRobin
(Map<ServerName, List<RegionInfo>> assignmentMap, List<RegionInfo> regions) FavoredNodesPlan.getAssignmentMap()
Return the mapping between each region to its favored region server list.FavoredNodeLoadBalancer.getFavoredNodes
(RegionInfo regionInfo) FavoredNodesManager.getFavoredNodes
(RegionInfo regionInfo) FavoredNodesPlan.getFavoredNodes
(RegionInfo region) Returns the list of favored region server for this region based on the planFavoredNodesPromoter.getFavoredNodes
(RegionInfo regionInfo) FavoredNodesManager.getFavoredNodesWithDNPort
(RegionInfo regionInfo) This should only be used when sending FN information to the region servers.private Set<ServerName>
FavoredNodeLoadBalancer.getInheritedFNForDaughter
(FavoredNodeAssignmentHelper helper, List<ServerName> parentFavoredNodes, FavoredNodesPlan.Position primary, FavoredNodesPlan.Position secondary) FavoredNodesManager.getReplicaLoad
(List<ServerName> servers) Get the replica count for the servers provided.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 assignmentFavoredNodeLoadBalancer.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 TypeMethodDescriptionprivate 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) Get the rack of server from local mapping when present, saves lookup by the RackManager.FavoredNodesManager.getRegionsOfFavoredNode
(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 TypeMethodDescriptionprivate 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) FavoredNodeAssignmentHelper.generateFavoredNodesRoundRobin
(Map<ServerName, List<RegionInfo>> assignmentMap, List<RegionInfo> regions) FavoredNodeAssignmentHelper.generateMissingFavoredNode
(List<ServerName> favoredNodes) 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 byte[]
FavoredNodeAssignmentHelper.getFavoredNodes
(List<ServerName> serverAddrList) Returns PB'ed bytes ofHBaseProtos.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.FavoredNodesManager.getReplicaLoad
(List<ServerName> servers) Get the replica count for the servers provided.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) FavoredNodeAssignmentHelper.placeSecondaryAndTertiaryRS
(Map<RegionInfo, ServerName> primaryRSMap) FavoredNodeAssignmentHelper.placeSecondaryAndTertiaryWithRestrictions
(Map<RegionInfo, ServerName> primaryRSMap) For regions that share the primary, avoid placing the secondary and tertiary on a same RS.FavoredNodeLoadBalancer.randomAssignment
(RegionInfo regionInfo, List<ServerName> servers) private void
FavoredNodeLoadBalancer.roundRobinAssignmentImpl
(FavoredNodeAssignmentHelper assignmentHelper, Map<ServerName, List<RegionInfo>> assignmentMap, List<RegionInfo> regions) void
FavoredNodesManager.updateFavoredNodes
(Map<RegionInfo, List<ServerName>> regionFNMap) void
FavoredNodesPlan.updateFavoredNodesMap
(RegionInfo region, List<ServerName> servers) Update an assignment to the planstatic void
FavoredNodeAssignmentHelper.updateMetaWithFavoredNodesInfo
(Map<RegionInfo, List<ServerName>> regionToFavoredNodes, org.apache.hadoop.conf.Configuration conf) Update meta table with favored nodes infostatic void
FavoredNodeAssignmentHelper.updateMetaWithFavoredNodesInfo
(Map<RegionInfo, List<ServerName>> regionToFavoredNodes, Connection connection) Update meta table with favored nodes infoModifierConstructorDescriptionFavoredNodeAssignmentHelper
(List<ServerName> servers, org.apache.hadoop.conf.Configuration conf) FavoredNodeAssignmentHelper
(List<ServerName> servers, RackManager rackManager) -
Uses of ServerName in org.apache.hadoop.hbase.ipc
Modifier and TypeMethodDescriptionvoid
AbstractRpcClient.cancelConnections
(ServerName sn) Interrupt the connections to the given ip:port server.void
RpcClient.cancelConnections
(ServerName sn) Interrupt the connections to the given server.(package private) static Address
AbstractRpcClient.createAddr
(ServerName sn) org.apache.hbase.thirdparty.com.google.protobuf.BlockingRpcChannel
AbstractRpcClient.createBlockingRpcChannel
(ServerName sn, User ticket, int rpcTimeout) 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.RpcChannel
AbstractRpcClient.createRpcChannel
(ServerName sn, User user, 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. -
Uses of ServerName in org.apache.hadoop.hbase.mapreduce
Modifier and TypeMethodDescriptionprivate Set<ServerName>
RegionSizeCalculator.getRegionServersOfTable
(RegionLocator regionLocator) -
Uses of ServerName in org.apache.hadoop.hbase.master
Modifier and TypeFieldDescription(package private) ServerName
ActiveMasterManager.activeMasterServerName
static final ServerName
LoadBalancer.BOGUS_SERVER_NAME
SplitLogManager.Task.cur_worker_name
private ServerName
RegionPlan.dest
private final ServerName
RegionState.serverName
(package private) final ServerName
ActiveMasterManager.sn
private final ServerName
RegionPlan.source
Modifier and TypeFieldDescriptionprivate org.apache.hbase.thirdparty.com.google.common.collect.ImmutableList<ServerName>
ActiveMasterManager.backupMasters
private final Map<ServerName,
List<RegionInfo>> SnapshotOfRegionAssignmentFromMeta.currentRSToRegionMap
the regionServer to region mapprivate final Map<ServerName,
Integer> WorkerAssigner.currentWorkers
private final Map<ServerName,
Long> DeadServer.deadServers
Set of known dead servers.private Set<ServerName>
SplitLogManager.deadWorkers
Deprecated.private final NavigableSet<ServerName>
DrainingServerTracker.drainingServers
private final ArrayList<ServerName>
ServerManager.drainingServers
List of region servers that should not get any more new regions.private final 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 final ConcurrentNavigableMap<ServerName,
ServerMetrics> ServerManager.onlineServers
Map of registered servers to their current loadprivate final Map<ServerName,
List<RegionInfo>> SnapshotOfRegionAssignmentFromMeta.primaryRSToRegionMap
private Set<ServerName>
RegionServerTracker.regionServers
private Map<RegionInfo,
ServerName> SnapshotOfRegionAssignmentFromMeta.regionToRegionServerMap
the region to region server mapprivate final Map<ServerName,
List<RegionInfo>> SnapshotOfRegionAssignmentFromMeta.secondaryRSToRegionMap
private final Map<ServerName,
List<RegionInfo>> SnapshotOfRegionAssignmentFromMeta.teritiaryRSToRegionMap
Modifier and TypeMethodDescriptionSplitWALManager.acquireSplitWALWorker
(Procedure<?> procedure) Acquire a split WAL workerServerManager.findServerWithSameHostnamePortWithLock
(ServerName serverName) Assumes onlineServers is locked.RegionPlan.getDestination()
Get the destination server for the plan for this region.HMaster.getServerName()
MasterCoprocessorHost.MasterEnvironment.getServerName()
RegionState.getServerName()
RegionPlan.getSource()
Get the source server for the plan for this region.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 onlineModifier and TypeMethodDescriptionWorkerAssigner.acquire()
(package private) List<Pair<ServerName,
Long>> DeadServer.copyDeadServersSince
(long ts) Extract all the servers dead since a given time, and sort them.DeadServer.copyServerNames()
ServerManager.createDestinationServersList()
CallsServerManager.createDestinationServersList(java.util.List<org.apache.hadoop.hbase.ServerName>)
without server to exclude.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.HMaster.getActiveMaster()
ActiveMasterManager.getActiveMasterServerName()
MasterRegionServerList.getAll()
RegionServerList.getAll()
Get all live region servers.ActiveMasterManager.getBackupMasters()
Returns list of registered backup masters.HMaster.getBackupMasters()
HMaster.getBootstrapNodes()
protected List<Pair<ServerName,
Long>> ClusterStatusPublisher.getDeadServers
(long since) Get the servers which died since a given timestamp.ServerManager.getDrainingServersList()
Returns A copy of the internal list of draining servers.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.static List<ServerName>
RegionPlacementMaintainer.getFavoredNodeList
(String favoredNodesStr) HMaster.getLiveRegionServers()
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()
ServerManager.getOnlineServers()
Returns Read-only map of servers to serverinfoServerManager.getOnlineServersList()
Returns A copy of the internal list of online servers.ServerManager.getOnlineServersListWithPredicator
(List<ServerName> keys, Predicate<ServerMetrics> idleServerPredicator) SnapshotOfRegionAssignmentFromMeta.getPrimaryToRegionInfoMap()
RegionServerTracker.getRegionServers()
SnapshotOfRegionAssignmentFromMeta.getRegionServerToRegionMap()
Get regionserver to region mapSnapshotOfRegionAssignmentFromMeta.getRegionToRegionServerMap()
Get region to region server mapHMaster.getReplicationLoad
(ServerName[] serverNames) SnapshotOfRegionAssignmentFromMeta.getSecondaryToRegionInfoMap()
MasterWalManager.getServerNamesFromWALDirPath
(org.apache.hadoop.fs.PathFilter filter) Returns listing of ServerNames found by parsing WAL directory paths in FS.MasterWalManager.getSplittingServersFromWALDir()
Get Servernames which are currently splitting; paths have a '-splitting' suffix.SnapshotOfRegionAssignmentFromMeta.getTertiaryToRegionInfoMap()
private List<ServerName>
HMaster.getUnknownServers()
HMaster.listDecommissionedRegionServers()
List region servers marked as decommissioned (previously called 'draining') to not get regions assigned to them.LoadBalancer.retainAssignment
(Map<RegionInfo, ServerName> regions, List<ServerName> servers) Assign regions to the previously hosting region serverLoadBalancer.roundRobinAssignment
(List<RegionInfo> regions, List<ServerName> servers) Perform a Round Robin assignment of regions.Modifier and TypeMethodDescriptionprivate 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
WorkerAssigner.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.private void
ServerManager.checkRejectableDecommissionedStatus
(ServerName sn) Checks if the Master is configured to reject decommissioned hosts or not.(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
(AsyncClusterConnection 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) protected ActiveMasterManager
HMaster.createActiveMasterManager
(ZKWatcher zk, ServerName sn, Server server) Protected to have custom implementations in tests override the default ActiveMaster implementation.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) ServerManager.findServerWithSameHostnamePortWithLock
(ServerName serverName) Assumes onlineServers is locked.WorkerAssigner.getAvailableWorker
(ServerName serverName) int
ActiveMasterManager.getBackupMasterInfoPort
(ServerName sn) int
HMaster.getBackupMasterInfoPort
(ServerName sn) int
ServerManager.getInfoPort
(ServerName serverName) ServerManager.getLoad
(ServerName serverName) Returns ServerMetrics if serverName is known else nullRackManager.getRack
(ServerName server) Get the name of the rack containing a server, according to the DNS to switch mapping.int
HMaster.getRegionServerInfoPort
(ServerName sn) HMaster.getRegionServerVersion
(ServerName sn) MasterServices.getRegionServerVersion
(ServerName sn) HMaster.getReplicationLoad
(ServerName[] serverNames) private org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionServerInfo
RegionServerTracker.getServerInfo
(ServerName serverName) DeadServer.getTimeOfDeath
(ServerName deadServerName) Get the time when a server diedServerManager.getVersion
(ServerName serverName) May return "0.0.0" when server is not onlineint
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.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) (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
WorkerAssigner.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 ProcedureEventprivate void
DrainingServerTracker.remove
(ServerName sn) boolean
DeadServer.removeDeadServer
(ServerName deadServerName) Called from rpc by operator cleaning up deadserver list.boolean
ServerManager.removeServerFromDrainList
(ServerName sn) default void
ServerListener.serverAdded
(ServerName serverName) The server has joined the cluster.void
WorkerAssigner.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 WALSplitWALManager.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 snprivate void
HMaster.warmUpRegion
(ServerName server, RegionInfo region) Modifier and TypeMethodDescriptionLoadBalancer.balanceCluster
(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) Perform the major balance operation for cluster.private boolean
DeadServer.cleanOldServerName
(ServerName newServerName, Iterator<ServerName> deadServerIterator) 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) List<org.apache.hadoop.fs.Path>
MasterWalManager.getLogDirs
(Set<ServerName> serverNames) ServerManager.getOnlineServersListWithPredicator
(List<ServerName> keys, Predicate<ServerMetrics> idleServerPredicator) RackManager.getRack
(List<ServerName> servers) Same asRackManager.getRack(ServerName)
except that a list is passedRegionsRecoveryChore.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.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) LoadBalancer.randomAssignment
(RegionInfo regionInfo, List<ServerName> servers) Get a random region server from the listLoadBalancer.retainAssignment
(Map<RegionInfo, ServerName> regions, List<ServerName> servers) Assign regions to the previously hosting region serverLoadBalancer.retainAssignment
(Map<RegionInfo, ServerName> regions, List<ServerName> servers) Assign regions to the previously hosting region servervoid
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 WALdefault 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 loadvoid
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.ModifierConstructorDescription(package private)
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) -
Uses of ServerName in org.apache.hadoop.hbase.master.assignment
Modifier and TypeFieldDescriptionprivate 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 final ServerName
ServerStateNode.serverName
protected ServerName
AssignProcedure.targetServer
Deprecated.protected ServerName
RegionRemoteProcedureBase.targetServer
Modifier and TypeFieldDescriptionprivate final Map<ServerName,
Set<byte[]>> AssignmentManager.rsReports
private final ConcurrentHashMap<ServerName,
ServerStateNode> RegionStates.serverMap
Modifier and TypeMethodDescriptionRegionStateNode.getLastHost()
private ServerName
SplitTableRegionProcedure.getParentRegionServerName
(MasterProcedureEnv env) RegionStateNode.getRegionLocation()
RegionStates.getRegionServerOfRegion
(RegionInfo regionInfo) private ServerName
MergeTableRegionsProcedure.getServerName
(MasterProcedureEnv env) The procedure could be restarted from a different machine.ServerStateNode.getServerName()
RegionStateNode.offline()
Put region into OFFLINE mode (set state and clear location).RegionStateNode.setRegionLocation
(ServerName serverName) Modifier and TypeMethodDescriptionRegionStates.getAssignmentsForBalancer
(TableStateManager tableStateManager, List<ServerName> onlineServers) This is an EXPENSIVE clone.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.AssignmentManager.getFavoredNodes
(RegionInfo regionInfo) RegionStates.getRegionAssignments()
Map<ServerName,
Set<byte[]>> AssignmentManager.getRSReports()
Returns a snapshot of rsReportsAssignmentManager.getSnapShotOfAssignment
(Collection<RegionInfo> regions) RegionStates.getSnapShotOfAssignment
(Collection<RegionInfo> regions) AssignmentManager.getTableRegionsAndLocations
(TableName tableName, boolean excludeOfflinedSplitParents) Modifier and TypeMethodDescriptionlong
AssignmentManager.assign
(RegionInfo regionInfo, ServerName sn) static TransitRegionStateProcedure
TransitRegionStateProcedure.assign
(MasterProcedureEnv env, RegionInfo region, boolean forceNewPlan, ServerName targetServer) static TransitRegionStateProcedure
TransitRegionStateProcedure.assign
(MasterProcedureEnv env, RegionInfo region, ServerName targetServer) Future<byte[]>
AssignmentManager.assignAsync
(RegionInfo regionInfo, ServerName sn) Submits a procedure that assigns a region to a target server without waiting for it to finishprivate void
TransitRegionStateProcedure.checkAndWaitForOriginalServer
(MasterProcedureEnv env, ServerName lastHost) private void
AssignmentManager.closeRegionSilently
(ServerName sn, byte[] regionName) CloseregionName
onsn
silently and immediately without using a Procedure or going via hbase:meta.private TransitRegionStateProcedure
AssignmentManager.createAssignProcedure
(RegionInfo regionInfo, ServerName sn, boolean override, boolean force) 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 theregionReplication
.(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) AssignmentManager.createMoveRegionProcedure
(RegionInfo regionInfo, ServerName targetServer) void
RegionStates.createServer
(ServerName serverName) Create the ServerStateNode when registering a new region server(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) AssignmentManager.getRegionsOnServer
(ServerName serverName) Returns the regions hosted by the specified server.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, TableDescriptor htd) 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) private void
TransitRegionStateProcedure.openRegionAfterUpdatingMeta
(ServerName loc) AssignProcedure.remoteCallBuild
(MasterProcedureEnv env, ServerName serverName) Deprecated.RegionRemoteProcedureBase.remoteCallBuild
(MasterProcedureEnv env, ServerName remote) RegionTransitionProcedure.remoteCallBuild
(MasterProcedureEnv env, ServerName serverName) Deprecated.UnassignProcedure.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.void
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().(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) TransitRegionStateProcedure.serverCrashed
(MasterProcedureEnv env, RegionStateNode regionNode, ServerName serverName, boolean forceNewPlan) void
RegionStateNode.setLastHost
(ServerName serverName) RegionStateNode.setRegionLocation
(ServerName serverName) private void
RegionStates.setServerState
(ServerName serverName, ServerState state) void
RegionStateStore.splitRegion
(RegionInfo parent, RegionInfo splitA, RegionInfo splitB, ServerName serverName, TableDescriptor htd) Splits the region into two in an atomic operation.long
AssignmentManager.submitServerCrash
(ServerName serverName, boolean shouldSplitWal, boolean force) Usually run by the Master in reaction to server crash during normal processing.void
AssignmentManager.RegionMetaLoadingVisitor.visitRegionState
(Result result, RegionInfo regionInfo, RegionState.State state, ServerName regionLocation, ServerName lastHost, long openSeqNum) void
RegionStateStore.RegionStateVisitor.visitRegionState
(Result result, RegionInfo regionInfo, RegionState.State state, ServerName regionLocation, ServerName lastHost, long openSeqNum) Modifier and TypeMethodDescriptionprivate void
AssignmentManager.acceptPlan
(HashMap<RegionInfo, RegionStateNode> regions, Map<ServerName, List<RegionInfo>> plan) private TransitRegionStateProcedure[]
AssignmentManager.createAssignProcedures
(Map<ServerName, List<RegionInfo>> assignments) Tied toAssignmentManager.createAssignProcedures(List)
in that it is called if caller is unable to run this method.private void
RegionStates.createSnapshot
(RegionStateNode node, Map<ServerName, List<RegionInfo>> result) RegionStates.getAssignmentsForBalancer
(TableStateManager tableStateManager, List<ServerName> onlineServers) This is an EXPENSIVE clone.ModifierConstructorDescriptionCloseRegionProcedure
(TransitRegionStateProcedure parent, RegionInfo region, ServerName targetServer, ServerName assignCandidate, boolean isSplit) OpenRegionProcedure
(TransitRegionStateProcedure parent, RegionInfo region, ServerName targetServer) protected
RegionRemoteProcedureBase
(TransitRegionStateProcedure parent, RegionInfo region, ServerName targetServer) ServerStateNode
(ServerName serverName) protected
TransitRegionStateProcedure
(MasterProcedureEnv env, RegionInfo hri, ServerName assignCandidate, boolean forceNewPlan, TransitRegionStateProcedure.TransitionType type) protected
TransitRegionStateProcedure
(MasterProcedureEnv env, RegionInfo hri, ServerName assignCandidate, boolean forceNewPlan, TransitRegionStateProcedure.TransitionType type, boolean isSplit) -
Uses of ServerName in org.apache.hadoop.hbase.master.balancer
Modifier and TypeFieldDescriptionprotected ServerName
BaseLoadBalancer.masterServerName
(package private) ServerName[]
BalancerClusterState.servers
private final ServerName
ServerAndLoad.sn
Modifier and TypeFieldDescription(package private) Map<ServerName,
List<RegionInfo>> BalancerClusterState.clusterState
private final Map<ServerName,
List<RegionInfo>> ClusterLoadState.clusterState
private final Map<ServerName,
Integer> HeterogeneousRegionCountCostFunction.limitPerRS
This is a cache, used to not go through all the limitPerRule map when searching for limit(package private) Map<String,
Pair<ServerName, Float>> BalancerClusterState.regionCacheRatioOnOldServerMap
(package private) Map<String,
Pair<ServerName, Float>> StochasticLoadBalancer.regionCacheRatioOnOldServerMap
private Map<RegionInfo,
ServerName> LoadBalancerPerformanceEvaluation.regionServerMap
private List<ServerName>
LoadBalancerPerformanceEvaluation.servers
private Map<TableName,
Map<ServerName, List<RegionInfo>>> LoadBalancerPerformanceEvaluation.tableServerRegionMap
Modifier and TypeMethodDescriptionprivate ServerName
FavoredStochasticBalancer.getServerFromFavoredNode
(List<ServerName> servers, ServerName fn) Get the ServerName for the FavoredNode.(package private) ServerName
ServerAndLoad.getServerName()
BaseLoadBalancer.randomAssignment
(RegionInfo regionInfo, List<ServerName> servers) Used to assign a single region to a random server.private ServerName
BaseLoadBalancer.randomAssignment
(BalancerClusterState cluster, RegionInfo regionInfo, List<ServerName> servers) Used to assign a single region to a random server.FavoredStochasticBalancer.randomAssignment
(RegionInfo regionInfo, List<ServerName> servers) If we have favored nodes for a region, we will return one of the FN as destination.MaintenanceLoadBalancer.randomAssignment
(RegionInfo regionInfo, List<ServerName> servers) Modifier and TypeMethodDescriptionprivate Map<ServerName,
List<RegionInfo>> MaintenanceLoadBalancer.assign
(Collection<RegionInfo> regions, List<ServerName> servers) 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()
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) Return list of favored nodes that are online.ClusterInfoProvider.getOnlineServersList()
Returns a copy of the internal list of online servers.MasterClusterInfoProvider.getOnlineServersList()
ClusterInfoProvider.getOnlineServersListWithPredicator
(List<ServerName> servers, Predicate<ServerMetrics> filter) Returns a copy of the internal list of online servers matched by the givenfilter
.MasterClusterInfoProvider.getOnlineServersListWithPredicator
(List<ServerName> servers, Predicate<ServerMetrics> filter) private Map<ServerName,
List<RegionInfo>> BaseLoadBalancer.getRegionAssignmentsByServer
(Collection<RegionInfo> regions) ClusterInfoProvider.getSnapShotOfAssignment
(Collection<RegionInfo> regions) Get a snapshot of the current assignment status.MasterClusterInfoProvider.getSnapShotOfAssignment
(Collection<RegionInfo> regions) (package private) List<ServerName>
RegionHDFSBlockLocationFinder.getTopBlockLocations
(RegionInfo region) (package private) List<ServerName>
RegionHDFSBlockLocationFinder.mapHostNameToServerName
(List<String> hosts) Map hostname to ServerName, The output ServerName list will have the same order as input hosts.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.FavoredStochasticBalancer.retainAssignment
(Map<RegionInfo, ServerName> regions, List<ServerName> servers) Reuse BaseLoadBalancer's retainAssignment, but generate favored nodes when its missing.MaintenanceLoadBalancer.retainAssignment
(Map<RegionInfo, ServerName> regions, List<ServerName> servers) 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.FavoredStochasticBalancer.roundRobinAssignment
(List<RegionInfo> regions, List<ServerName> servers) Round robin assignment: Segregate the regions into two types: 1.MaintenanceLoadBalancer.roundRobinAssignment
(List<RegionInfo> regions, List<ServerName> servers) private Pair<Map<ServerName,
List<RegionInfo>>, List<RegionInfo>> FavoredStochasticBalancer.segregateRegionsAndAssignRegionsWithFavoredNodes
(Collection<RegionInfo> regions, List<ServerName> onlineServers) Return a pair - one with assignments when favored nodes are present and another with regions without favored nodes.protected final Map<ServerName,
List<RegionInfo>> BaseLoadBalancer.toEnsumbleTableLoad
(Map<TableName, Map<ServerName, List<RegionInfo>>> LoadOfAllTable) Modifier and TypeMethodDescriptionprivate 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) Assign the region to primary if its available.(package private) void
BalancerClusterState.doAssignRegion
(RegionInfo regionInfo, ServerName serverName) (package private) int
HeterogeneousRegionCountCostFunction.findLimitForRS
(ServerName serverName) Find the limit for a ServerName.ClusterInfoProvider.getLoad
(ServerName serverName) Returns server metrics of the given server if serverName is known else nullMasterClusterInfoProvider.getLoad
(ServerName serverName) private float
RegionHDFSBlockLocationFinder.getOldLocality
(ServerName newServer, byte[] regionName, Map<ServerName, ServerMetrics> oldServers) BalancerClusterState.DefaultRackManager.getRack
(ServerName server) private ServerName
FavoredStochasticBalancer.getServerFromFavoredNode
(List<ServerName> servers, ServerName fn) Get the ServerName for the FavoredNode.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 questionModifier and TypeMethodDescriptionprivate 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) private void
FavoredStochasticBalancer.assignRegionToAvailableFavoredNode
(Map<ServerName, List<RegionInfo>> assignmentMapForFavoredNodes, RegionInfo region, ServerName primaryHost, ServerName secondaryHost, ServerName tertiaryHost) Assign the region to primary if its available.final List<RegionPlan>
BaseLoadBalancer.balanceCluster
(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) Perform the major balance operation for cluster, will invokeBaseLoadBalancer.balanceTable(TableName, Map)
to do actual balance.MaintenanceLoadBalancer.balanceCluster
(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) 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 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>
FavoredStochasticBalancer.balanceTable
(TableName tableName, Map<ServerName, List<RegionInfo>> loadOfOneTable) For all regions correctly assigned to favored nodes, we just use the stochastic balancer implementation.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>
StochasticLoadBalancer.balanceTable
(TableName tableName, Map<ServerName, List<RegionInfo>> loadOfOneTable) Given the cluster state this will try and approach an optimal balance.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) Generate Favored Nodes for daughters during region split.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
RegionHDFSBlockLocationFinder.getOldLocality
(ServerName newServer, byte[] regionName, Map<ServerName, ServerMetrics> oldServers) private List<ServerName>
FavoredStochasticBalancer.getOnlineFavoredNodes
(List<ServerName> onlineServers, List<ServerName> serversWithoutStartCodes) Return list of favored nodes that are online.ClusterInfoProvider.getOnlineServersListWithPredicator
(List<ServerName> servers, Predicate<ServerMetrics> filter) Returns a copy of the internal list of online servers matched by the givenfilter
.MasterClusterInfoProvider.getOnlineServersListWithPredicator
(List<ServerName> servers, Predicate<ServerMetrics> filter) private ServerName
FavoredStochasticBalancer.getServerFromFavoredNode
(List<ServerName> servers, ServerName fn) Get the ServerName for the FavoredNode.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) BaseLoadBalancer.randomAssignment
(RegionInfo regionInfo, List<ServerName> servers) Used to assign a single region to a random server.private ServerName
BaseLoadBalancer.randomAssignment
(BalancerClusterState cluster, RegionInfo regionInfo, List<ServerName> servers) Used to assign a single region to a random server.FavoredStochasticBalancer.randomAssignment
(RegionInfo regionInfo, List<ServerName> servers) If we have favored nodes for a region, we will return one of the FN as destination.MaintenanceLoadBalancer.randomAssignment
(RegionInfo regionInfo, List<ServerName> servers) 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.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.FavoredStochasticBalancer.retainAssignment
(Map<RegionInfo, ServerName> regions, List<ServerName> servers) Reuse BaseLoadBalancer's retainAssignment, but generate favored nodes when its missing.FavoredStochasticBalancer.retainAssignment
(Map<RegionInfo, ServerName> regions, List<ServerName> servers) Reuse BaseLoadBalancer's retainAssignment, but generate favored nodes when its missing.MaintenanceLoadBalancer.retainAssignment
(Map<RegionInfo, ServerName> regions, List<ServerName> servers) 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 serversprivate Pair<Map<ServerName,
List<RegionInfo>>, List<RegionInfo>> FavoredStochasticBalancer.segregateRegionsAndAssignRegionsWithFavoredNodes
(Collection<RegionInfo> regions, List<ServerName> onlineServers) Return a pair - one with assignments when favored nodes are present and another with regions without favored nodes.(package private) void
SimpleLoadBalancer.setClusterLoad
(Map<TableName, Map<ServerName, List<RegionInfo>>> clusterLoad) Pass RegionStates and allow balancer to set the current cluster load.protected final 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) ModifierConstructorDescription(package private)
BalancerClusterState
(Collection<RegionInfo> unassignedRegions, Map<ServerName, List<RegionInfo>> clusterState, Map<String, Deque<BalancerRegionLoad>> loads, RegionHDFSBlockLocationFinder regionFinder, RackManager rackManager, Map<String, Pair<ServerName, Float>> oldRegionServerRegionCacheRatio) (package private)
BalancerClusterState
(Map<ServerName, List<RegionInfo>> clusterState, Map<String, Deque<BalancerRegionLoad>> loads, RegionHDFSBlockLocationFinder regionFinder, RackManager rackManager) protected
BalancerClusterState
(Map<ServerName, List<RegionInfo>> clusterState, Map<String, Deque<BalancerRegionLoad>> loads, RegionHDFSBlockLocationFinder regionFinder, RackManager rackManager, Map<String, Pair<ServerName, Float>> oldRegionServerRegionCacheRatio) ClusterLoadState
(Map<ServerName, List<RegionInfo>> clusterState) -
Uses of ServerName in org.apache.hadoop.hbase.master.hbck
Modifier and TypeFieldDescriptionprivate final Map<String,
Pair<ServerName, List<ServerName>>> HbckReport.inconsistentRegions
private final Map<String,
Pair<ServerName, List<ServerName>>> HbckReport.inconsistentRegions
private final Map<String,
ServerName> HbckReport.orphanRegionsOnRS
Modifier and TypeMethodDescriptionHbckReport.getInconsistentRegions()
The inconsistent regions.HbckReport.getInconsistentRegions()
The inconsistent regions.HbckReport.getOrphanRegionsOnRS()
The regions only opened on RegionServers, but no region info in meta. -
Uses of ServerName in org.apache.hadoop.hbase.master.http
Modifier and TypeFieldDescriptionprivate final ServerName
RegionReplicaInfo.serverName
private final ServerName
RegionVisualizer.RegionDetails.serverName
private final ServerName
RegionReplicaInfo.targetServerName
Modifier and TypeMethodDescriptionprivate ServerName
MasterStatusServlet.getMetaLocationOrNull
(HMaster master) RegionReplicaInfo.getServerName()
RegionVisualizer.RegionDetails.getServerName()
RegionReplicaInfo.getTargetServerName()
ModifierConstructorDescription(package private)
RegionDetails
(ServerName serverName, TableName tableName, RegionMetrics regionMetrics) -
Uses of ServerName in org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.model
ModifierConstructorDescriptionprivate
ClusterMetrics
(String hbaseVersion, String clusterId, ServerName masterName, List<ServerName> backupMasterNames) ModifierConstructorDescriptionprivate
ClusterMetrics
(String hbaseVersion, String clusterId, ServerName masterName, List<ServerName> backupMasterNames) -
Uses of ServerName in org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.resource
-
Uses of ServerName in org.apache.hadoop.hbase.master.http.hbck.resource
-
Uses of ServerName in org.apache.hadoop.hbase.master.janitor
Modifier and TypeFieldDescription(package private) final List<Pair<RegionInfo,
ServerName>> CatalogJanitorReport.unknownServers
TODO: If CatalogJanitor finds an 'Unknown Server', it should 'fix' it by queuing aHBCKServerCrashProcedure
for found server for it to clean up meta. -
Uses of ServerName in org.apache.hadoop.hbase.master.procedure
Modifier and TypeFieldDescriptionprivate ServerName
SplitWALProcedure.crashedServer
private ServerName
SplitWALRemoteProcedure.crashedServer
private final ServerName
RSProcedureDispatcher.RegionCloseOperation.destinationServer
private ServerName
RecoverMetaProcedure.failedMetaServer
Deprecated.private final ServerName
RSProcedureDispatcher.ExecuteProceduresRemoteCall.serverName
private final ServerName
ServerCrashException.serverName
private ServerName
ServerCrashProcedure.serverName
Name of the crashed server to process.private ServerName
SwitchRpcThrottleProcedure.serverName
protected ServerName
ServerRemoteProcedure.targetServer
private final ServerName
HBCKServerCrashProcedure.UnknownServerVisitor.unknownServerName
private ServerName
SplitWALProcedure.worker
Modifier and TypeFieldDescriptionprivate final Map<ServerName,
LockAndQueue> SchemaLocking.serverLocks
private final FairQueue<ServerName>
MasterProcedureScheduler.serverRunQueue
Modifier and TypeMethodDescriptionRSProcedureDispatcher.RegionCloseOperation.getDestinationServer()
private static ServerName
MasterProcedureScheduler.getServerName
(Procedure<?> proc) protected final ServerName
RSProcedureDispatcher.ExecuteProceduresRemoteCall.getServerName()
ServerCrashProcedure.getServerName()
ServerProcedureInterface.getServerName()
Returns Name of this server instance.SnapshotVerifyProcedure.getServerName()
SplitWALProcedure.getServerName()
SplitWALRemoteProcedure.getServerName()
SwitchRpcThrottleProcedure.getServerName()
SwitchRpcThrottleRemoteProcedure.getServerName()
SplitWALProcedure.getWorker()
Modifier and TypeMethodDescriptionprotected 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) FlushRegionProcedure.remoteCallBuild
(MasterProcedureEnv env, ServerName serverName) SnapshotRegionProcedure.remoteCallBuild
(MasterProcedureEnv env, ServerName serverName) SnapshotVerifyProcedure.remoteCallBuild
(MasterProcedureEnv env, ServerName serverName) SplitWALRemoteProcedure.remoteCallBuild
(MasterProcedureEnv env, ServerName serverName) SwitchRpcThrottleRemoteProcedure.remoteCallBuild
(MasterProcedureEnv masterProcedureEnv, ServerName remote) void
FlushRegionProcedure.remoteCallFailed
(MasterProcedureEnv env, ServerName serverName, IOException e) void
ServerRemoteProcedure.remoteCallFailed
(MasterProcedureEnv env, ServerName serverName, IOException exception) void
SnapshotRegionProcedure.remoteCallFailed
(MasterProcedureEnv env, ServerName serverName, IOException e) 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) FetchesRemoteProcedureDispatcher.RemoteOperation
s from the givenremoteProcedures
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 serverModifierConstructorDescriptionDeadRSRemoteCall
(ServerName serverName, Set<RemoteProcedureDispatcher.RemoteProcedure> remoteProcedures) ExecuteProceduresRemoteCall
(ServerName serverName, Set<RemoteProcedureDispatcher.RemoteProcedure> remoteProcedures) HBCKServerCrashProcedure
(MasterProcedureEnv env, ServerName serverName, boolean shouldSplitWal, boolean carryingMeta) RegionCloseOperation
(RemoteProcedureDispatcher.RemoteProcedure remoteProcedure, RegionInfo regionInfo, long procId, ServerName destinationServer, boolean evictCache, long initiatingMasterActiveTime) ServerCrashException
(long procId, ServerName serverName) ServerCrashProcedure
(MasterProcedureEnv env, ServerName serverName, boolean shouldSplitWal, boolean carryingMeta) Call this constructor queuing up a Procedure.ServerQueue
(ServerName serverName, int priority, LockStatus serverLock) SplitWALProcedure
(String walPath, ServerName crashedServer) SplitWALRemoteProcedure
(ServerName worker, ServerName crashedServer, String wal) SwitchRpcThrottleProcedure
(RpcThrottleStorage rpcThrottleStorage, boolean rpcThrottleEnabled, ServerName serverName, ProcedurePrepareLatch syncLatch) SwitchRpcThrottleRemoteProcedure
(ServerName serverName, boolean rpcThrottleEnabled) private
UnknownServerVisitor
(Connection connection, ServerName unknownServerName) -
Uses of ServerName in org.apache.hadoop.hbase.master.replication
Modifier and TypeFieldDescriptionprivate ServerName
AssignReplicationQueuesProcedure.crashedServer
private ServerName
ClaimReplicationQueuesProcedure.crashedServer
Deprecated.private ServerName
SyncReplicationReplayWALProcedure.worker
Modifier and TypeFieldDescriptionprivate final Set<ServerName>
SyncReplicationReplayWALManager.UsedReplayWorkersForPeer.usedWorkers
Modifier and TypeMethodDescriptionSyncReplicationReplayWALManager.acquirePeerWorker
(String peerId, Procedure<?> proc) Get a worker for replaying remote wal for a give peer.AssignReplicationQueuesProcedure.getServerName()
ClaimReplicationQueueRemoteProcedure.getServerName()
ClaimReplicationQueuesProcedure.getServerName()
Deprecated.Modifier and TypeMethodDescriptionSyncReplicationReplayWALManager.UsedReplayWorkersForPeer.acquire
(ServerManager serverManager) OfflineTableReplicationQueueStorage.listAllReplicators()
Modifier and TypeMethodDescriptionvoid
SyncReplicationReplayWALManager.addUsedPeerWorker
(String peerId, ServerName worker) Will only be called when loading procedures, where we need to construct the used worker set for each peer.void
OfflineTableReplicationQueueStorage.batchUpdateQueues
(ServerName serverName, List<ReplicationQueueData> datas) OfflineTableReplicationQueueStorage.claimQueue
(ReplicationQueueId queueId, ServerName targetServerName) OfflineTableReplicationQueueStorage.listAllQueueIds
(String peerId, ServerName serverName) OfflineTableReplicationQueueStorage.listAllQueueIds
(ServerName serverName) void
SyncReplicationReplayWALManager.UsedReplayWorkersForPeer.release
(ServerName worker) void
SyncReplicationReplayWALManager.releasePeerWorker
(String peerId, ServerName worker, MasterProcedureScheduler scheduler) ClaimReplicationQueueRemoteProcedure.remoteCallBuild
(MasterProcedureEnv env, ServerName remote) RefreshPeerProcedure.remoteCallBuild
(MasterProcedureEnv env, ServerName remote) SyncReplicationReplayWALRemoteProcedure.remoteCallBuild
(MasterProcedureEnv env, ServerName remote) void
SyncReplicationReplayWALManager.UsedReplayWorkersForPeer.used
(ServerName worker) ModifierConstructorDescriptionAssignReplicationQueuesProcedure
(ServerName crashedServer) ClaimReplicationQueueRemoteProcedure
(ReplicationQueueId queueId, ServerName targetServer) ClaimReplicationQueuesProcedure
(ServerName crashedServer) Deprecated.RefreshPeerProcedure
(String peerId, PeerProcedureInterface.PeerOperationType type, ServerName targetServer) RefreshPeerProcedure
(String peerId, PeerProcedureInterface.PeerOperationType type, ServerName targetServer, int stage) SyncReplicationReplayWALRemoteProcedure
(String peerId, List<String> wals, ServerName targetServer) -
Uses of ServerName in org.apache.hadoop.hbase.master.snapshot
Modifier and TypeMethodDescriptionSnapshotManager.acquireSnapshotVerifyWorker
(SnapshotVerifyProcedure procedure) Modifier and TypeMethodDescriptionSnapshotManager.getAvailableWorker
(ServerName serverName) void
SnapshotManager.releaseSnapshotVerifyWorker
(SnapshotVerifyProcedure procedure, ServerName worker, MasterProcedureScheduler scheduler) Modifier and TypeMethodDescriptionvoid
DisabledTableSnapshotHandler.snapshotRegions
(List<Pair<RegionInfo, ServerName>> regionsAndLocations) protected void
EnabledTableSnapshotHandler.snapshotRegions
(List<Pair<RegionInfo, ServerName>> regions) This method kicks off a snapshot procedure.protected abstract void
TakeSnapshotHandler.snapshotRegions
(List<Pair<RegionInfo, ServerName>> regions) Snapshot the specified regions -
Uses of ServerName in org.apache.hadoop.hbase.regionserver
Modifier and TypeFieldDescriptionprivate final ServerName
HRegionServer.MovedRegionInfo.serverName
Modifier and TypeMethodDescriptionprivate 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.HRegionServer.MovedRegionInfo.getServerName()
RegionCoprocessorHost.RegionEnvironment.getServerName()
RegionServerCoprocessorHost.RegionServerEnvironment.getServerName()
Modifier and TypeMethodDescriptionHRegionServer.getActiveMaster()
HRegionServer.getBackupMasters()
BootstrapNodeManager.getBootstrapNodes()
HRegionServer.getBootstrapNodes()
Modifier and TypeMethodDescriptionprivate 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
HRegionServer.removeRegion
(HRegion r, ServerName destination) boolean
MutableOnlineRegions.removeRegion
(HRegion r, ServerName destination) Removes the given Region from the list of onlineRegions.ModifierConstructorDescription(package private)
MovedRegionInfo
(ServerName serverName, long closeSeqNum) ScannerIdGenerator
(ServerName serverName) -
Uses of ServerName in org.apache.hadoop.hbase.regionserver.handler
Modifier and TypeFieldDescriptionprivate ServerName
CloseRegionHandler.destination
private final ServerName
UnassignRegionHandler.destination
private final ServerName
WALSplitterHandler.serverName
Deprecated.Modifier and TypeMethodDescriptionstatic UnassignRegionHandler
UnassignRegionHandler.create
(HRegionServer server, String encodedName, long closeProcId, boolean abort, ServerName destination, boolean evictCache, long initiatingMasterActiveTime) ModifierConstructorDescriptionprotected
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, long initiatingMasterActiveTime, boolean isSplit) -
Uses of ServerName in org.apache.hadoop.hbase.regionserver.wal
ModifierConstructorDescriptionWALEventTrackerListener
(org.apache.hadoop.conf.Configuration conf, NamedQueueRecorder namedQueueRecorder, ServerName serverName) -
Uses of ServerName in org.apache.hadoop.hbase.replication
Modifier and TypeFieldDescriptionprivate ServerName
HBaseReplicationEndpoint.SinkPeer.serverName
private final ServerName
ReplicationQueueId.serverName
Modifier and TypeFieldDescriptionprivate Map<ServerName,
Integer> HBaseReplicationEndpoint.badReportCounts
private List<ServerName>
ReplicationQueueInfo.deadRegionServers
private List<ServerName>
HBaseReplicationEndpoint.sinkServers
private final Optional<ServerName>
ReplicationQueueId.sourceServerName
Modifier and TypeMethodDescription(package private) ServerName
HBaseReplicationEndpoint.SinkPeer.getServerName()
ReplicationQueueId.getServerName()
ReplicationQueueId.getServerWALsBelongTo()
Modifier and TypeMethodDescriptionprotected Collection<ServerName>
HBaseReplicationEndpoint.fetchPeerAddresses()
Get the list of all the region servers from the specified peerReplicationQueueInfo.getDeadRegionServers()
(package private) List<ServerName>
HBaseReplicationEndpoint.getSinkServers()
ReplicationQueueId.getSourceServerName()
ZKReplicationQueueStorageForMigration.MigrationIterator<Pair<ServerName,
List<ZKReplicationQueueStorageForMigration.ZkReplicationQueueData>>> ZKReplicationQueueStorageForMigration.listAllQueues()
ReplicationQueueStorage.listAllReplicators()
Get a list of all region servers that have outstanding replication queues.TableReplicationQueueStorage.listAllReplicators()
Modifier and TypeMethodDescriptionvoid
ReplicationQueueStorage.batchUpdateQueues
(ServerName serverName, List<ReplicationQueueData> datas) Update the replication queue datas for a given region server.void
TableReplicationQueueStorage.batchUpdateQueues
(ServerName serverName, List<ReplicationQueueData> datas) ReplicationQueueId.claim
(ServerName targetServerName) ReplicationQueueStorage.claimQueue
(ReplicationQueueId queueId, ServerName targetServerName) Change ownership for the queue identified by queueId and belongs to a dead region server.TableReplicationQueueStorage.claimQueue
(ReplicationQueueId queueId, ServerName targetServerName) private String
ZKReplicationQueueStorageForMigration.getFileNode
(ServerName serverName, String queueId, String fileName) private String
ZKReplicationQueueStorageForMigration.getQueueNode
(ServerName serverName, String queueId) private String
ZKReplicationQueueStorageForMigration.getRsNode
(ServerName serverName) static byte[]
ReplicationQueueId.getScanPrefix
(ServerName serverName, String peerId) ReplicationQueueStorage.listAllQueueIds
(String peerId, ServerName serverName) Get a list of all queues for the specific region server and the specific peerReplicationQueueStorage.listAllQueueIds
(ServerName serverName) Get a list of all queues for the specific region server.TableReplicationQueueStorage.listAllQueueIds
(String peerId, ServerName serverName) private void
TableReplicationQueueStorage.listAllQueueIds
(Table table, String peerId, ServerName serverName, List<ReplicationQueueId> queueIds) TableReplicationQueueStorage.listAllQueueIds
(ServerName serverName) void
ReplicationListener.regionServerRemoved
(ServerName regionServer) A region server has been removed from the local clusterModifier and TypeMethodDescriptionprivate static void
ReplicationQueueInfo.extractDeadServersFromZNodeString
(String deadServerListStr, List<ServerName> result) Parse dead server names from queue id.ModifierConstructorDescriptionReplicationQueueId
(ServerName serverName, String peerId) ReplicationQueueId
(ServerName serverName, String peerId, ServerName sourceServerName) SinkPeer
(ServerName serverName, AsyncRegionServerAdmin regionServer) -
Uses of ServerName in org.apache.hadoop.hbase.replication.master
Modifier and TypeFieldDescriptionprivate Supplier<Set<ServerName>>
ReplicationLogCleaner.getNotFullyDeadServers
private Set<ServerName>
ReplicationLogCleaner.notFullyDeadServers
private Map<ServerName,
Map<String, Map<String, ReplicationGroupOffset>>> ReplicationLogCleaner.replicationOffsets
Modifier and TypeMethodDescriptionprivate Set<ServerName>
ReplicationLogCleaner.getNotFullyDeadServers
(MasterServices services) Modifier and TypeMethodDescriptionprivate boolean
ReplicationLogCleaner.filterForDeadRegionServer
(ServerName serverName, org.apache.hadoop.fs.FileStatus file) private boolean
ReplicationLogCleaner.filterForLiveRegionServer
(ServerName serverName, org.apache.hadoop.fs.FileStatus file) -
Uses of ServerName in org.apache.hadoop.hbase.replication.regionserver
Modifier and TypeMethodDescriptionReplicationSyncUp.DummyServer.getServerName()
ReplicationSource.getServerWALsBelongTo()
ReplicationSourceInterface.getServerWALsBelongTo()
The queue of WALs only belong to one region server.Modifier and TypeMethodDescriptionprivate Set<ServerName>
ReplicationSyncUp.listRegionServers
(org.apache.hadoop.fs.FileSystem walFs, org.apache.hadoop.fs.Path walDir) Modifier and TypeMethodDescriptionprivate void
ReplicationSyncUp.addMissingReplicationQueues
(ReplicationQueueStorage storage, ServerName regionServer, Set<String> peerIds) private String
DumpReplicationQueues.formatQueue
(ServerName regionServer, Map<String, ReplicationGroupOffset> offsets, List<String> wals, ReplicationQueueId queueId, boolean isDeleted, boolean hdfs) private long
DumpReplicationQueues.getTotalWALSize
(org.apache.hadoop.fs.FileSystem fs, List<String> wals, ServerName server) return total size in bytes from a list of WALsprivate PriorityQueue<org.apache.hadoop.fs.Path>
ReplicationSourceManager.getWALFilesToReplicate
(ServerName sourceRS, boolean syncUp, Map<String, ReplicationGroupOffset> offsets) Modifier and TypeMethodDescriptionprivate void
ReplicationSyncUp.addMissingReplicationQueues
(ReplicationQueueStorage storage, Set<ServerName> regionServers, Set<String> peerIds) private void
ReplicationSyncUp.claimReplicationQueues
(ReplicationSourceManager mgr, Set<ServerName> regionServers) -
Uses of ServerName in org.apache.hadoop.hbase.rest
-
Uses of ServerName in org.apache.hadoop.hbase.rsgroup
Modifier and TypeMethodDescriptionRSGroupBasedLoadBalancer.randomAssignment
(RegionInfo region, List<ServerName> servers) Modifier and TypeMethodDescriptionprivate 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) (package private) Map<TableName,
Map<ServerName, List<RegionInfo>>> RSGroupInfoManagerImpl.getRSGroupAssignmentsByTable
(TableStateManager tableStateManager, String groupName) This is an EXPENSIVE clone.RSGroupBasedLoadBalancer.retainAssignment
(Map<RegionInfo, ServerName> regions, List<ServerName> servers) RSGroupBasedLoadBalancer.roundRobinAssignment
(List<RegionInfo> regions, List<ServerName> servers) Modifier and TypeMethodDescriptionvoid
RSGroupBasedLoadBalancer.regionOnline
(RegionInfo regionInfo, ServerName sn) Modifier and TypeMethodDescriptionRSGroupBasedLoadBalancer.balanceCluster
(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) Balance by RSGroup.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<ServerName>
RSGroupBasedLoadBalancer.getFallBackCandidates
(List<ServerName> servers) RSGroupBasedLoadBalancer.randomAssignment
(RegionInfo region, List<ServerName> servers) RSGroupBasedLoadBalancer.retainAssignment
(Map<RegionInfo, ServerName> regions, List<ServerName> servers) RSGroupBasedLoadBalancer.retainAssignment
(Map<RegionInfo, ServerName> regions, List<ServerName> servers) void
RSGroupBasedLoadBalancer.updateBalancerLoadInfo
(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) -
Uses of ServerName in org.apache.hadoop.hbase.security.access
Modifier and TypeMethodDescriptionvoid
AccessController.preMove
(ObserverContext<MasterCoprocessorEnvironment> c, RegionInfo region, ServerName srcServer, ServerName destServer) void
AccessController.preRecommissionRegionServer
(ObserverContext<MasterCoprocessorEnvironment> ctx, ServerName server, List<byte[]> encodedRegionNames) Modifier and TypeMethodDescriptionvoid
AccessController.preDecommissionRegionServers
(ObserverContext<MasterCoprocessorEnvironment> ctx, List<ServerName> servers, boolean offload) -
Uses of ServerName in org.apache.hadoop.hbase.testing
Modifier and TypeMethodDescriptionTestingHBaseCluster.getActiveMasterAddress()
Get the address of active master if there is one.TestingHBaseClusterImpl.getActiveMasterAddress()
TestingHBaseCluster.getBackupMasterAddresses()
Get all the backup master addresses.TestingHBaseClusterImpl.getBackupMasterAddresses()
TestingHBaseCluster.getRegionServerAddresses()
Get all the region server addresses.TestingHBaseClusterImpl.getRegionServerAddresses()
Modifier and TypeMethodDescriptionprivate int
TestingHBaseClusterImpl.getMasterIndex
(ServerName serverName) TestingHBaseCluster.getOnlineRegionsInterface
(ServerName serverName) Get the server sideOnlineRegions
interface for the specific region server.TestingHBaseClusterImpl.getOnlineRegionsInterface
(ServerName serverName) private int
TestingHBaseClusterImpl.getRegionServerIndex
(ServerName serverName) TestingHBaseCluster.stopMaster
(ServerName serverName) Stop the given master.TestingHBaseClusterImpl.stopMaster
(ServerName serverName) TestingHBaseCluster.stopRegionServer
(ServerName serverName) Stop the given region server.TestingHBaseClusterImpl.stopRegionServer
(ServerName serverName) -
Uses of ServerName in org.apache.hadoop.hbase.thrift2
Modifier and TypeMethodDescriptionstatic Set<ServerName>
ThriftUtilities.getServerNamesFromThrift
(Set<org.apache.hadoop.hbase.thrift2.generated.TServerName> tServerNames) Modifier and TypeMethodDescriptionstatic Set<org.apache.hadoop.hbase.thrift2.generated.TServerName>
ThriftUtilities.getServerNamesFromHBase
(Set<ServerName> serverNames) -
Uses of ServerName in org.apache.hadoop.hbase.thrift2.client
Modifier and TypeMethodDescriptionThriftAdmin.clearDeadServers
(List<ServerName> servers) ThriftAdmin.compactionSwitch
(boolean switchState, List<String> serverNamesList) ThriftAdmin.listDecommissionedRegionServers()
Modifier and TypeMethodDescriptionvoid
ThriftAdmin.clearCompactionQueues
(ServerName serverName, Set<String> queues) void
ThriftAdmin.compactRegionServer
(ServerName serverName) ThriftAdmin.coprocessorService
(ServerName serverName) void
ThriftAdmin.flushRegionServer
(ServerName serverName) ThriftAdmin.getCachedFilesList
(ServerName serverName) ThriftAdmin.getRegionMetrics
(ServerName serverName) ThriftAdmin.getRegionMetrics
(ServerName serverName, TableName tableName) ThriftAdmin.getRegions
(ServerName serverName) 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 TypeMethodDescriptionThriftAdmin.clearDeadServers
(List<ServerName> servers) ThriftAdmin.clearSlowLogResponses
(Set<ServerName> serverNames) void
ThriftAdmin.decommissionRegionServers
(List<ServerName> servers, boolean offload) ThriftAdmin.getLogEntries
(Set<ServerName> serverNames, String logType, ServerType serverType, int limit, Map<String, Object> filterParams) ThriftAdmin.getSlowLogResponses
(Set<ServerName> serverNames, LogQueryFilter logQueryFilter) -
Uses of ServerName in org.apache.hadoop.hbase.tool
Modifier and TypeFieldDescriptionprivate ServerName
CanaryTool.RegionTask.serverName
private ServerName
CanaryTool.RegionTaskResult.serverName
Modifier and TypeFieldDescriptionprivate ConcurrentMap<ServerName,
LongAdder> CanaryTool.RegionStdOutSink.perServerFailuresCount
Modifier and TypeMethodDescriptionprivate void
CanaryTool.RegionStdOutSink.incFailuresCountDetails
(ServerName serverName, RegionInfo region) void
CanaryTool.RegionStdOutSink.publishReadFailure
(ServerName serverName, RegionInfo region, Exception e) void
CanaryTool.RegionStdOutSink.publishReadFailure
(ServerName serverName, RegionInfo region, ColumnFamilyDescriptor column, Exception e) void
CanaryTool.RegionStdOutSink.publishReadTiming
(ServerName serverName, RegionInfo region, ColumnFamilyDescriptor column, long msTime) void
CanaryTool.RegionStdOutSink.publishWriteFailure
(ServerName serverName, RegionInfo region, Exception e) void
CanaryTool.RegionStdOutSink.publishWriteFailure
(ServerName serverName, RegionInfo region, ColumnFamilyDescriptor column, Exception e) void
CanaryTool.RegionStdOutSink.publishWriteTiming
(ServerName serverName, RegionInfo region, ColumnFamilyDescriptor column, long msTime) ModifierConstructorDescription(package private)
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) -
Uses of ServerName in org.apache.hadoop.hbase.util
Modifier and TypeFieldDescription(package private) ServerName
HbckRegionInfo.MetaEntry.regionServer
private final ServerName
HBaseFsck.WorkItemRegion.rsinfo
private ServerName
HbckRegionInfo.OnlineEntry.serverName
private final ServerName
MoveWithAck.sourceServer
private final ServerName
MoveWithoutAck.sourceServer
private final ServerName
MoveWithAck.targetServer
private final ServerName
MoveWithoutAck.targetServer
Modifier and TypeFieldDescriptionprivate List<ServerName>
HbckRegionInfo.deployedOn
(package private) TreeSet<ServerName>
HbckTableInfo.deployedOn
Modifier and TypeMethodDescriptionHbckRegionInfo.MetaEntry.getRegionServer()
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 TypeMethodDescription(package private) Collection<ServerName>
RegionMover.filterRSGroupServers
(RSGroupInfo rsgroup, Collection<ServerName> onlineServers) HbckRegionInfo.getDeployedOn()
Modifier and TypeMethodDescriptionvoid
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, boolean forceMoveRegionByAck) private void
RegionMover.unloadRegions
(ServerName server, List<ServerName> regionServers, List<RegionInfo> movedRegions, List<String> isolateRegionIdArray) Modifier and TypeMethodDescription(package private) Collection<ServerName>
RegionMover.filterRSGroupServers
(RSGroupInfo rsgroup, Collection<ServerName> onlineServers) 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 columnsstatic 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 toprivate 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, boolean forceMoveRegionByAck) private void
RegionMover.unloadRegions
(ServerName server, List<ServerName> regionServers, List<RegionInfo> movedRegions, List<String> isolateRegionIdArray) ModifierConstructorDescriptionMetaEntry
(RegionInfo rinfo, ServerName regionServer, long modTime) MetaEntry
(RegionInfo rinfo, ServerName regionServer, long modTime, RegionInfo splitA, RegionInfo splitB) (package private)
MoveWithAck
(Connection conn, RegionInfo regionInfo, ServerName sourceServer, ServerName targetServer, List<RegionInfo> movedRegions) (package private)
MoveWithoutAck
(Admin admin, RegionInfo regionInfo, ServerName sourceServer, ServerName targetServer, List<RegionInfo> movedRegions) (package private)
OnlineEntry
(RegionInfo regionInfo, ServerName serverName) (package private)
WorkItemRegion
(HBaseFsck hbck, ServerName info, HbckErrorReporter errors, Connection connection) -
Uses of ServerName in org.apache.hadoop.hbase.util.compaction
Modifier and TypeFieldDescriptionprivate final Set<ServerName>
ClusterCompactionQueues.compactingServers
private final Map<ServerName,
List<MajorCompactionRequest>> ClusterCompactionQueues.compactionQueues
Modifier and TypeMethodDescription(package private) Optional<ServerName>
ClusterCompactionQueues.getLargestQueueFromServersNotCompacting()
private Map<ServerName,
List<RegionInfo>> MajorCompactor.getServerRegionsMap()
private Collection<ServerName>
MajorCompactor.getServersToCompact
(Set<ServerName> snSet) Modifier and TypeMethodDescription(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 TypeMethodDescriptionprivate Collection<ServerName>
MajorCompactor.getServersToCompact
(Set<ServerName> snSet) ModifierConstructorDescription(package private)
Compact
(ServerName serverName, MajorCompactionRequest request) -
Uses of ServerName in org.apache.hadoop.hbase.util.hbck
Modifier and TypeFieldDescriptionprivate Map<ServerName,
List<ReplicationQueueId>> ReplicationChecker.undeletedQueueIds
Modifier and TypeMethodDescriptionprivate Map<ServerName,
List<ReplicationQueueId>> ReplicationChecker.getUnDeletedQueues()
-
Uses of ServerName in org.apache.hadoop.hbase.wal
Modifier and TypeMethodDescriptionstatic 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>/...static ServerName
AbstractFSWALProvider.parseServerNameFromWALName
(String name) Parse the server name from wal prefix.Modifier and TypeMethodDescriptionstatic List<org.apache.hadoop.fs.Path>
AbstractFSWALProvider.getArchivedWALFiles
(org.apache.hadoop.conf.Configuration conf, ServerName serverName, String logPrefix) List all the old wal files for a dead region server.static List<org.apache.hadoop.fs.Path>
AbstractFSWALProvider.getWALFiles
(org.apache.hadoop.conf.Configuration c, ServerName serverName) List all the wal files for a logPrefix.ModifierConstructorDescriptionWALFactory
(org.apache.hadoop.conf.Configuration conf, ServerName serverName, Abortable abortable) Create a WALFactory. -
Uses of ServerName in org.apache.hadoop.hbase.zookeeper
Modifier and TypeMethodDescriptionprivate static ServerName
MetaTableLocator.blockUntilAvailable
(ZKWatcher zkw, int replicaId, long timeout) Wait until the meta region is available and is not in transition.MasterAddressTracker.getMasterAddress()
Get the address of the current master if one is available.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 TypeMethodDescriptionMasterAddressTracker.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.Modifier and TypeMethodDescriptionint
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.ZNodePaths.getRsPath
(ServerName sn) static boolean
MasterAddressTracker.setMasterAddress
(ZKWatcher zkw, String znode, ServerName master, int infoPort) Set master address into themaster
znode or into the backup subdirectory of backup masters; switch off the passed inznode
path.static void
MetaTableLocator.setMetaLocation
(ZKWatcher zookeeper, ServerName serverName, int replicaId, RegionState.State state) Sets the location ofhbase:meta
in ZooKeeper to the specified server address.static void
MetaTableLocator.setMetaLocation
(ZKWatcher zookeeper, ServerName serverName, RegionState.State state) Sets the location ofhbase:meta
in ZooKeeper to the specified server address.(package private) static byte[]
MasterAddressTracker.toByteArray
(ServerName sn, int infoPort)
MetaTableAccessor.getRegionLocation(Connection, byte[])
instead