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.private final ServerName
HRegionLocation.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
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.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 TypeMethodDescriptionClusterStatus.getMaster()
Deprecated.ClusterMetrics.getMasterName()
Returns detailed information about the current masterServerName
.ClusterMetricsBuilder.ClusterMetricsImpl.getMasterName()
ClusterStatus.getMasterName()
Deprecated.HRegionLocation.getServerName()
static ServerName
MetaTableAccessor.getServerName
(Result r, int replicaId) Returns aServerName
from catalog tableResult
.Server.getServerName()
Returns The unique server name for this server.ServerLoad.getServerName()
Deprecated.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()
ClusterStatus.getBackupMasterNames()
Deprecated.ClusterStatus.getBackupMasters()
Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseClusterStatus.getBackupMasterNames()
instead.ClusterMetrics.getDeadServerNames()
Returns the names of region servers on the dead listClusterMetricsBuilder.ClusterMetricsImpl.getDeadServerNames()
ClusterStatus.getDeadServerNames()
Deprecated.Returns the names of region servers on the dead listprivate Map<ServerName,
ServerLoad> ClusterStatus.getLiveServerLoads()
Deprecated.ClusterMetrics.getLiveServerMetrics()
Returns the names of region servers on the live listClusterMetricsBuilder.ClusterMetricsImpl.getLiveServerMetrics()
ClusterStatus.getLiveServerMetrics()
Deprecated.static Pair<RegionInfo,
ServerName> MetaTableAccessor.getRegion
(Connection connection, byte[] regionName) Deprecated.private static Optional<ServerName>
AsyncMetaTableAccessor.getServerName
(Result r, int replicaId) Returns aServerName
from catalog tableResult
.ClusterStatus.getServers()
Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseClusterStatus.getLiveServerMetrics()
instead.ClusterMetrics.getServersName()
ClusterMetricsBuilder.ClusterMetricsImpl.getServersName()
ClusterStatus.getServersName()
Deprecated.private static CompletableFuture<List<Pair<RegionInfo,
ServerName>>> AsyncMetaTableAccessor.getTableRegionsAndLocations
(AsyncTable<AdvancedScanResultConsumer> metaTable, TableName tableName, boolean excludeOfflinedSplitParents) Used to get table regions' info and server.static List<Pair<RegionInfo,
ServerName>> MetaTableAccessor.getTableRegionsAndLocations
(Connection connection, TableName tableName) Do not use this method to get meta table regions, use methods in MetaTableLocator instead.static List<Pair<RegionInfo,
ServerName>> MetaTableAccessor.getTableRegionsAndLocations
(Connection connection, TableName tableName, boolean excludeOfflinedSplitParents) Do not use this method to get meta table regions, use methods in MetaTableLocator instead.ClusterMetrics.getUnknownServerNames()
Returns the names of region servers on the unknown listClusterMetricsBuilder.ClusterMetricsImpl.getUnknownServerNames()
ClusterStatus.getUnknownServerNames()
Deprecated.Modifier and TypeMethodDescriptionstatic Put
MetaTableAccessor.addLocation
(Put p, ServerName sn, long openSeqNum, int replicaId) int
ServerName.compareTo
(ServerName other) SharedConnection.getHbck
(ServerName masterServer) ClusterStatus.getLoad
(ServerName sn) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseClusterStatus.getLiveServerMetrics()
instead.static NavigableMap<RegionInfo,
Result> MetaTableAccessor.getServerUserRegions
(Connection connection, ServerName serverName) Get the user regions a given server is hosting.boolean
SplitLogTask.isDone
(ServerName sn) Deprecated.boolean
SplitLogTask.isErr
(ServerName sn) Deprecated.boolean
SplitLogTask.isOwned
(ServerName sn) Deprecated.boolean
SplitLogTask.isResigned
(ServerName sn) Deprecated.static boolean
ServerName.isSameAddress
(ServerName left, ServerName right) Compare two addressesboolean
SplitLogTask.isUnassigned
(ServerName sn) Deprecated.static void
MetaTableAccessor.mergeRegions
(Connection connection, RegionInfo mergedRegion, Map<RegionInfo, Long> parentSeqNum, ServerName sn, int regionReplication) Merge regions into one in an atomic operation.static ServerMetricsBuilder
ServerMetricsBuilder.newBuilder
(ServerName sn) static ServerMetrics
ServerMetricsBuilder.of
(ServerName sn) static ServerMetrics
ServerMetricsBuilder.of
(ServerName sn, int versionNumber, String version) RegionLocations.removeByServer
(ServerName serverName) Returns a new RegionLocations with the locations removed (set to null) which have the destination server as given.ClusterMetricsBuilder.setMasterName
(ServerName value) static void
MetaTableAccessor.splitRegion
(Connection connection, RegionInfo parent, long parentOpenSeqNum, RegionInfo splitA, RegionInfo splitB, ServerName sn, int regionReplication) Splits the region into two in an atomic operation.static ServerMetrics
ServerMetricsBuilder.toServerMetrics
(ServerName serverName, 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.Modifier and TypeMethodDescriptionprivate static List<RegionInfo>
MetaTableAccessor.getListOfRegionInfos
(List<Pair<RegionInfo, ServerName>> pairs) ClusterMetricsBuilder.setBackerMasterNames
(List<ServerName> value) ClusterMetricsBuilder.setDeadServerNames
(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) ClusterStatus
(String hbaseVersion, String clusterid, Map<ServerName, ServerLoad> servers, Collection<ServerName> deadServers, ServerName master, Collection<ServerName> backupMasters, List<RegionState> rit, String[] masterCoprocessors, Boolean balancerOn, int masterInfoPort) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0Done
(ServerName originServer) Err
(ServerName originServer) HRegionLocation
(RegionInfo regionInfo, ServerName serverName) HRegionLocation
(RegionInfo regionInfo, ServerName serverName, long seqNum) Owned
(ServerName originServer) Resigned
(ServerName originServer) ServerLoad
(ServerName name, org.apache.hadoop.hbase.shaded.protobuf.generated.ClusterStatusProtos.ServerLoad serverLoad) Deprecated.private
ServerMetricsBuilder
(ServerName serverName) (package private)
ServerMetricsImpl
(ServerName serverName, int versionNumber, String version, long requestCountPerSecond, long requestCount, Size usedHeapSize, Size maxHeapSize, int infoServerPort, List<ReplicationLoadSource> sources, ReplicationLoadSink sink, Map<byte[], RegionMetrics> regionStatus, Set<String> coprocessorNames, long reportTimestamp, long lastReportTimestamp, Map<byte[], UserMetrics> userMetrics, List<ServerTask> tasks, 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) (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) ClusterStatus
(String hbaseVersion, String clusterid, Map<ServerName, ServerLoad> servers, Collection<ServerName> deadServers, ServerName master, Collection<ServerName> backupMasters, List<RegionState> rit, String[] masterCoprocessors, Boolean balancerOn, int masterInfoPort) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0ClusterStatus
(String hbaseVersion, String clusterid, Map<ServerName, ServerLoad> servers, Collection<ServerName> deadServers, ServerName master, Collection<ServerName> backupMasters, List<RegionState> rit, String[] masterCoprocessors, Boolean balancerOn, int masterInfoPort) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 -
Uses of ServerName in org.apache.hadoop.hbase.client
Modifier and TypeFieldDescriptionprivate final ServerName
AsyncRequestFutureImpl.SingleServerRequestRunnable.server
private ServerName
FastFailInterceptorContext.server
private ServerName
AsyncAdminRequestRetryingCaller.serverName
private ServerName
AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder.serverName
private ServerName
AsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder.serverName
private ServerName
AsyncServerRequestRpcRetryingCaller.serverName
private final ServerName
ServerConnectionUtils.ShortCircuitingClusterConnection.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 Set<ServerName>
MetaCache.cachedServers
private final List<ServerName>
ClusterStatusListener.deadServers
ConnectionImplementation.ServerErrorTracker.errorsByServer
protected final ConcurrentMap<ServerName,
FailureInfo> PreemptiveFastFailInterceptor.repeatedFailuresMap
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.FastFailInterceptorContext.getServer()
(package private) ServerName
MultiServerCallable.getServerName()
Modifier and TypeMethodDescriptionAdmin.clearDeadServers
(List<ServerName> servers) Clear dead region servers from master.AsyncAdmin.clearDeadServers
(List<ServerName> servers) Clear dead region servers from master.AsyncHBaseAdmin.clearDeadServers
(List<ServerName> servers) HBaseAdmin.clearDeadServers
(List<ServerName> servers) RawAsyncHBaseAdmin.clearDeadServers
(List<ServerName> servers) Admin.compactionSwitch
(boolean switchState, List<String> serverNamesList) Turn the compaction on or off.AsyncAdmin.compactionSwitch
(boolean switchState, List<String> serverNamesList) Turn the compaction on or off.AsyncHBaseAdmin.compactionSwitch
(boolean switchState, List<String> serverNamesList) HBaseAdmin.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<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.RegionServerRegistry.getActiveMaster()
ZKConnectionRegistry.getActiveMaster()
Deprecated.ClusterConnection.getAllBootstrapNodes
(ServerName regionServer) Get the bootstrap node list of another region server.ConnectionImplementation.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
protected abstract Set<ServerName>
AbstractRpcBasedConnectionRegistry.getBootstrapNodes
(org.apache.hadoop.conf.Configuration conf) 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) ClusterConnection.getLiveRegionServers
(Supplier<ServerName> masterAddrTracker, int count) Get live region servers from masters.ConnectionImplementation.getLiveRegionServers
(Supplier<ServerName> 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()
(package private) Pair<RegionInfo,
ServerName> HBaseAdmin.getRegion
(byte[] regionName) private CompletableFuture<List<ServerName>>
RawAsyncHBaseAdmin.getRegionServerList
(List<String> serverNamesList) default Collection<ServerName>
Admin.getRegionServers()
Get the live server list.default 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.AsyncAdmin.listDecommissionedRegionServers()
List region servers marked as decommissioned, which can not be assigned regions.AsyncHBaseAdmin.listDecommissionedRegionServers()
HBaseAdmin.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 TypeMethodDescriptionvoid
BatchErrors.add
(Throwable ex, Row row, ServerName serverName) (package private) static void
AsyncProcess.addAction
(ServerName server, byte[] regionName, Action action, Map<ServerName, MultiAction> actionsByServer, long nonceGroup) Helper that is used when grouping the actions per region server.private void
AsyncBatchRpcRetryingCaller.addError
(Iterable<Action> actions, Throwable error, ServerName serverName) private void
AsyncBatchRpcRetryingCaller.addError
(Action action, Throwable error, ServerName serverName) private void
ConnectionImplementation.cacheLocation
(TableName tableName, ServerName source, HRegionLocation location) Put a newly discovered HRegionLocation into the cache.void
MetaCache.cacheLocation
(TableName tableName, ServerName source, HRegionLocation location) Put a newly discovered HRegionLocation into the cache.(package private) long
ConnectionImplementation.ServerErrorTracker.calculateBackoffTime
(ServerName server, long basePause) Calculates the back-off time for a retrying request to a particular server.private void
AsyncRequestFutureImpl.cleanServerCache
(ServerName server, Throwable regionException) private CacheEvictionStats
HBaseAdmin.clearBlockCache
(ServerName sn, List<RegionInfo> hris) 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
MetaCache.clearCache
(ServerName serverName) Delete all cached entries of a server.void
MetaCache.clearCache
(TableName tableName, byte[] row, ServerName serverName) Delete a cached location for a table, row and server.void
ClusterConnection.clearCaches
(ServerName sn) Clear any caches that pertain to server namesn
.void
ConnectionImplementation.clearCaches
(ServerName serverName) void
Admin.clearCompactionQueues
(ServerName serverName, Set<String> queues) Clear compacting queues on a regionserver.AsyncAdmin.clearCompactionQueues
(ServerName serverName, Set<String> queues) Clear compacting queues on a region server.AsyncHBaseAdmin.clearCompactionQueues
(ServerName serverName, Set<String> queues) void
HBaseAdmin.clearCompactionQueues
(ServerName sn, Set<String> queues) RawAsyncHBaseAdmin.clearCompactionQueues
(ServerName serverName, Set<String> queues) private Boolean
HBaseAdmin.clearSlowLogsResponses
(ServerName serverName) private CompletableFuture<Boolean>
RawAsyncHBaseAdmin.clearSlowLogsResponses
(ServerName serverName) void
Admin.closeRegion
(ServerName sn, HRegionInfo hri) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-18231).void
HBaseAdmin.closeRegion
(ServerName unused, HRegionInfo hri) Deprecated.private CompletableFuture<Void>
RawAsyncHBaseAdmin.compact
(ServerName sn, RegionInfo hri, boolean major, byte[] columnFamily) Compact the region at specific region server.void
Admin.compactRegionServer
(ServerName serverName) Compact all regions on the region server.default void
Admin.compactRegionServer
(ServerName sn, boolean major) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.AsyncAdmin.compactRegionServer
(ServerName serverName) Compact all regions on the region server.AsyncHBaseAdmin.compactRegionServer
(ServerName serverName) void
HBaseAdmin.compactRegionServer
(ServerName serverName) RawAsyncHBaseAdmin.compactRegionServer
(ServerName sn) private CompletableFuture<Void>
RawAsyncHBaseAdmin.compactRegionServer
(ServerName sn, boolean major) Admin.coprocessorService
(ServerName serverName) Creates and returns aRpcChannel
instance connected to the passed region server.<S,
R> CompletableFuture<R> AsyncAdmin.coprocessorService
(Function<com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, ServerName serverName) Execute the given coprocessor call on the given region server.<S,
R> CompletableFuture<R> AsyncHBaseAdmin.coprocessorService
(Function<com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, ServerName serverName) HBaseAdmin.coprocessorService
(ServerName serverName) <S,
R> CompletableFuture<R> RawAsyncHBaseAdmin.coprocessorService
(Function<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 MultiServerCallable
AsyncRequestFutureImpl.createCallable
(ServerName server, TableName tableName, MultiAction multi) Create a callable.private String
AsyncRequestFutureImpl.createLog
(int numAttempt, int failureCount, int replaySize, ServerName sn, Throwable error, long backOffTime, boolean willRetry, String startTime, int failed, int stopped) private org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MasterService.Interface
AsyncConnectionImpl.createMasterStub
(ServerName serverName) private org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface
AsyncConnectionImpl.createRegionServerStub
(ServerName serverName) static ClusterConnection
ServerConnectionUtils.createShortCircuitConnection
(org.apache.hadoop.conf.Configuration conf, User user, ServerName serverName, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface admin, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface client, ConnectionRegistry registry) Creates a short-circuit connection that can bypass the RPC layer (serialization, deserialization, networking, etc..) when talking to a local server.(package private) AsyncRequestFutureImpl<CResult>.SingleServerRequestRunnable
AsyncRequestFutureImpl.createSingleServerRequest
(MultiAction multiAction, int numAttempt, ServerName server, Set<CancellableRegionServerCallable> callsInProgress) (package private) void
AsyncProcess.decTaskCounters
(Collection<byte[]> regions, ServerName sn) void
RequestController.decTaskCounters
(Collection<byte[]> regions, ServerName sn) Decrement the counter if a task is accomplished.void
SimpleRequestController.decTaskCounters
(Collection<byte[]> regions, ServerName sn) private void
AsyncBatchRpcRetryingCaller.failAll
(Stream<Action> actions, int tries, Throwable error, ServerName serverName) private void
AsyncRequestFutureImpl.failAll
(MultiAction actions, ServerName server, int numAttempt, Throwable throwable) Fail all the actions from this multiaction after an OperationTimeoutExceededExceptionprivate CompletableFuture<Void>
RawAsyncHBaseAdmin.flush
(ServerName serverName, RegionInfo regionInfo, byte[] columnFamily) void
Admin.flushRegionServer
(ServerName serverName) Flush all regions on the region server.AsyncAdmin.flushRegionServer
(ServerName serverName) Flush all region on the region server.AsyncHBaseAdmin.flushRegionServer
(ServerName sn) void
HBaseAdmin.flushRegionServer
(ServerName serverName) RawAsyncHBaseAdmin.flushRegionServer
(ServerName sn) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
ClusterConnection.getAdmin
(ServerName serverName) Establishes a connection to the region server at the specified address.org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
ConnectionImplementation.getAdmin
(ServerName serverName) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
ServerConnectionUtils.ShortCircuitingClusterConnection.getAdmin
(ServerName sn) (package private) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.Interface
AsyncConnectionImpl.getAdminStub
(ServerName serverName) ClusterConnection.getAllBootstrapNodes
(ServerName regionServer) Get the bootstrap node list of another region server.ConnectionImplementation.getAllBootstrapNodes
(ServerName regionServer) private Long
AsyncRequestFutureImpl.getBackoff
(ServerName server, byte[] regionName) Admin.getCachedFilesList
(ServerName serverName) Get the list of cached filesAsyncAdmin.getCachedFilesList
(ServerName serverName) Get the list of cached filesAsyncHBaseAdmin.getCachedFilesList
(ServerName serverName) HBaseAdmin.getCachedFilesList
(ServerName serverName) Get the list of cached filesRawAsyncHBaseAdmin.getCachedFilesList
(ServerName serverName) org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface
ClusterConnection.getClient
(ServerName serverName) Establishes a connection to the region server at the specified address, and returns a region client protocol.org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface
ConnectionImplementation.getClient
(ServerName serverName) org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface
ServerConnectionUtils.ShortCircuitingClusterConnection.getClient
(ServerName sn) 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.ConnectionImplementation.getHbck
(ServerName masterServer) private Hbck
AsyncConnectionImpl.getHbckInternal
(ServerName masterServer) private Collection<? extends Runnable>
AsyncRequestFutureImpl.getNewMultiActionRunnable
(ServerName server, MultiAction multiAction, int numAttempt) Admin.getOnlineRegions
(ServerName sn) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-17980).HBaseAdmin.getOnlineRegions
(ServerName sn) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 UseHBaseAdmin.getRegions(ServerName)
.default List<RegionMetrics>
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.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) HBaseAdmin.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.AsyncAdmin.getRegions
(ServerName serverName) Get all the online regions on a region server.AsyncHBaseAdmin.getRegions
(ServerName serverName) HBaseAdmin.getRegions
(ServerName sn) RawAsyncHBaseAdmin.getRegions
(ServerName serverName) Map<TableName,
? extends SpaceQuotaSnapshotView> Admin.getRegionServerSpaceQuotaSnapshots
(ServerName serverName) Fetches the observedSpaceQuotaSnapshotView
s observed by a RegionServer.CompletableFuture<? extends Map<TableName,
? extends SpaceQuotaSnapshotView>> AsyncAdmin.getRegionServerSpaceQuotaSnapshots
(ServerName serverName) Fetches the observedSpaceQuotaSnapshotView
s observed by a RegionServer.AsyncHBaseAdmin.getRegionServerSpaceQuotaSnapshots
(ServerName serverName) HBaseAdmin.getRegionServerSpaceQuotaSnapshots
(ServerName serverName) RawAsyncHBaseAdmin.getRegionServerSpaceQuotaSnapshots
(ServerName serverName) (package private) org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface
AsyncConnectionImpl.getRegionServerStub
(ServerName serverName) HBaseAdmin.getSlowLogResponseFromServer
(ServerName serverName, Map<String, Object> filterParams, int limit, String logType) 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.protected void
PreemptiveFastFailInterceptor.handleFailureToServer
(ServerName serverName, Throwable t) Handles failures encountered when communicating with a server.void
PreemptiveFastFailInterceptor.handleThrowable
(Throwable t1, ServerName serverName, org.apache.commons.lang3.mutable.MutableBoolean couldNotCommunicateWithServer, org.apache.commons.lang3.mutable.MutableBoolean guaranteedClientSideOnly) (package private) void
AsyncProcess.incTaskCounters
(Collection<byte[]> regions, ServerName sn) void
RequestController.incTaskCounters
(Collection<byte[]> regions, ServerName sn) Increment the counter if we build a valid task.void
SimpleRequestController.incTaskCounters
(Collection<byte[]> regions, ServerName sn) private boolean
PreemptiveFastFailInterceptor.inFastFailMode
(ServerName server) Checks to see if we are in the Fast fail mode for requests to the server.boolean
ClusterStatusListener.isDeadServer
(ServerName sn) Check if we know if a server is dead.private boolean
ConnectionImplementation.isDeadServer
(ServerName sn) protected boolean
PreemptiveFastFailInterceptor.isServerInFailureMap
(ServerName serverName) private void
AsyncBatchRpcRetryingCaller.logException
(int tries, Supplier<Stream<AsyncBatchRpcRetryingCaller.RegionRequest>> regionsSupplier, Throwable error, ServerName serverName) private void
AsyncRequestFutureImpl.logNoResubmit
(ServerName oldServer, int numAttempt, int failureCount, Throwable throwable, int failed, int stopped) void
Admin.majorCompactRegionServer
(ServerName serverName) Major compact all regions on the region server.AsyncAdmin.majorCompactRegionServer
(ServerName serverName) Compact all regions on the region server.AsyncHBaseAdmin.majorCompactRegionServer
(ServerName serverName) void
HBaseAdmin.majorCompactRegionServer
(ServerName serverName) RawAsyncHBaseAdmin.majorCompactRegionServer
(ServerName sn) (package private) AsyncRequestFutureImpl.Retry
AsyncRequestFutureImpl.manageError
(int originalIndex, Row row, AsyncRequestFutureImpl.Retry canRetry, Throwable throwable, ServerName server) Check that we can retry acts accordingly: logs, set the error status.void
Admin.move
(byte[] encodedRegionName, ServerName destServerName) Move the regionrencodedRegionName
todestServerName
.AsyncAdmin.move
(byte[] regionName, ServerName destServerName) Move the regionr
todest
.AsyncHBaseAdmin.move
(byte[] regionName, ServerName destServerName) void
HBaseAdmin.move
(byte[] encodedRegionName, 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) private void
AsyncRequestFutureImpl.receiveGlobalFailure
(MultiAction rsActions, ServerName server, int numAttempt, Throwable t, boolean clearServerCache) Resubmit all the actions from this multiaction after a failure.private void
AsyncRequestFutureImpl.receiveMultiAction
(MultiAction multiAction, ServerName server, MultiResponse responses, int numAttempt) Called when we receive the result of a server query.void
Admin.recommissionRegionServer
(ServerName server, List<byte[]> encodedRegionNames) Remove decommission marker from a region server to allow regions assignments.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) void
HBaseAdmin.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.(package private) void
ConnectionImplementation.ServerErrorTracker.reportServerError
(ServerName server) Reports that there was an error on the server to do whatever bean-counting necessary.void
MultiServerCallable.reset
(ServerName location, MultiAction multiAction) private void
AsyncRequestFutureImpl.resubmit
(ServerName oldServer, List<Action> toReplay, int numAttempt, int failureCount, Throwable throwable) Log as much info as possible, and, if there is something to replay, submit it again after a back off sleep.void
Admin.rollWALWriter
(ServerName serverName) Roll the log writer.AsyncAdmin.rollWALWriter
(ServerName serverName) Roll the log writer.AsyncHBaseAdmin.rollWALWriter
(ServerName serverName) void
HBaseAdmin.rollWALWriter
(ServerName serverName) RawAsyncHBaseAdmin.rollWALWriter
(ServerName serverName) private org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.RollWALWriterResponse
HBaseAdmin.rollWALWriterImpl
(ServerName sn) private void
AsyncBatchRpcRetryingCaller.sendToServer
(ServerName serverName, AsyncBatchRpcRetryingCaller.ServerRequest serverReq, int tries) AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder.serverName
(ServerName serverName) AsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder.serverName
(ServerName serverName) private void
AsyncRequestFutureImpl.setError
(int index, Row row, Throwable throwable, ServerName server) Sets the error from a particular action.void
FastFailInterceptorContext.setServer
(ServerName server) protected void
CancellableRegionServerCallable.setStubByServiceName
(ServerName serviceName) protected void
ClientServiceCallable.setStubByServiceName
(ServerName serviceName) protected abstract void
RegionServerCallable.setStubByServiceName
(ServerName serviceName) Set the RCP client stubAsyncAdmin.stopRegionServer
(ServerName serverName) Stop the designated regionserver.AsyncHBaseAdmin.stopRegionServer
(ServerName serverName) RawAsyncHBaseAdmin.stopRegionServer
(ServerName serverName) private CompletableFuture<Boolean>
RawAsyncHBaseAdmin.switchCompact
(ServerName serverName, boolean onOrOff) AsyncRequestFutureImpl.trySetResultSimple
(int index, Row row, boolean isError, Object result, ServerName server, boolean isFromReplica) Tries to set the result or error for a particular action as if there were no replica calls.(package private) void
ConnectionImplementation.updateCachedLocation
(RegionInfo hri, ServerName source, ServerName serverName, long seqNum) private void
AsyncRequestFutureImpl.updateCachedLocations
(ServerName server, byte[] regionName, byte[] row, Throwable rowException) void
ClusterConnection.updateCachedLocations
(TableName tableName, byte[] regionName, byte[] rowkey, Object exception, ServerName source) Update the location cache.void
ConnectionImplementation.updateCachedLocations
(TableName tableName, byte[] regionName, byte[] rowkey, Object exception, ServerName source) Update the location with the new value (if the exception is a RegionMovedException) or delete it from the cache.void
Admin.updateConfiguration
(ServerName server) Update the configuration and trigger an online config change on the regionserver.AsyncAdmin.updateConfiguration
(ServerName serverName) Update the configuration and trigger an online config change on the regionserver.AsyncHBaseAdmin.updateConfiguration
(ServerName serverName) void
HBaseAdmin.updateConfiguration
(ServerName server) RawAsyncHBaseAdmin.updateConfiguration
(ServerName serverName) private void
PreemptiveFastFailInterceptor.updateFailureInfoForServer
(ServerName server, FailureInfo fInfo, boolean didTry, boolean couldNotCommunicate, boolean retryDespiteFastFailMode) This function updates the Failure info for a particular server after the attempt tovoid
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) protected void
AsyncRequestFutureImpl.updateStats
(ServerName server, MultiResponse resp) (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 TypeMethodDescription(package private) static void
AsyncProcess.addAction
(ServerName server, byte[] regionName, Action action, Map<ServerName, MultiAction> actionsByServer, long nonceGroup) Helper that is used when grouping the actions per region server.private void
AsyncRequestFutureImpl.ReplicaCallIssuingRunnable.addReplicaActions
(int index, Map<ServerName, MultiAction> actionsByServer, List<Action> unknownReplicaActions) Add replica actions to action map by server.private void
AsyncRequestFutureImpl.ReplicaCallIssuingRunnable.addReplicaActionsAgain
(Action action, Map<ServerName, MultiAction> actionsByServer) Admin.clearDeadServers
(List<ServerName> servers) Clear dead region servers from master.AsyncAdmin.clearDeadServers
(List<ServerName> servers) Clear dead region servers from master.AsyncHBaseAdmin.clearDeadServers
(List<ServerName> servers) HBaseAdmin.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 RegionServersAsyncAdmin.clearSlowLogResponses
(Set<ServerName> serverNames) Clears online slow RPC logs from the provided list of RegionServersAsyncHBaseAdmin.clearSlowLogResponses
(Set<ServerName> serverNames) HBaseAdmin.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.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) void
HBaseAdmin.decommissionRegionServers
(List<ServerName> servers, boolean offload) RawAsyncHBaseAdmin.decommissionRegionServers
(List<ServerName> servers, boolean offload) ClusterConnection.getLiveRegionServers
(Supplier<ServerName> masterAddrTracker, int count) Get live region servers from masters.ConnectionImplementation.getLiveRegionServers
(Supplier<ServerName> masterAddrTracker, int count) Admin.getLogEntries
(Set<ServerName> serverNames, String logType, ServerType serverType, int limit, Map<String, Object> filterParams) Retrieve recent online records from HMaster / RegionServers.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) HBaseAdmin.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.HBaseAdmin.getSlowLogResponses
(Map<String, Object> filterParams, Set<ServerName> serverNames, int limit, String logType) 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) (package private) void
AsyncRequestFutureImpl.sendMultiAction
(Map<ServerName, MultiAction> actionsByServer, int numAttempt, List<Action> actionsForReplicaThread, boolean reuseThread) Send a multi action structure to the servers, after a delay depending on the attempt number.private void
AsyncBatchRpcRetryingCaller.sendOrDelay
(Map<ServerName, AsyncBatchRpcRetryingCaller.ServerRequest> actionsByServer, int tries) (package private) <CResult> AsyncRequestFuture
AsyncProcess.submitMultiActions
(AsyncProcessTask task, List<Action> retainedActions, long nonceGroup, List<Exception> locationErrors, List<Integer> locationErrorRows, Map<ServerName, MultiAction> actionsByServer) 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) 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) (package private)
MultiServerCallable
(ClusterConnection connection, TableName tableName, ServerName location, MultiAction multi, org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController, int rpcTimeout, RetryingTimeTracker tracker, int priority, Map<String, byte[]> requestAttributes) private
ShortCircuitingClusterConnection
(org.apache.hadoop.conf.Configuration conf, User user, ServerName serverName, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface admin, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface client, ConnectionRegistry registry) (package private)
SingleServerRequestRunnable
(MultiAction multiAction, int numAttempt, ServerName server, Set<CancellableRegionServerCallable> callsInProgress) 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 planFavoredNodesManager.getFavoredNodesWithDNPort
(RegionInfo regionInfo) private Set<ServerName>
FavoredNodeLoadBalancer.getInheritedFNForDaughter
(FavoredNodeAssignmentHelper helper, List<ServerName> parentFavoredNodes, FavoredNodesPlan.Position primary, FavoredNodesPlan.Position secondary) FavoredNodesManager.getReplicaLoad
(List<ServerName> servers) private List<ServerName>
FavoredNodeAssignmentHelper.getServersFromRack
(String rack) private Map<ServerName,
Set<RegionInfo>> FavoredNodeAssignmentHelper.mapRSToPrimaries
(Map<RegionInfo, ServerName> primaryRSMap) (package private) List<ServerName>
FavoredNodesPlan.removeFavoredNodes
(RegionInfo region) Remove a favored node 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) 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) 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, List<ServerName> servers) 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 final Set<ServerName>
DeadServer.processingServers
Set of dead servers currently being processed by a SCP.private Set<ServerName>
RegionServerTracker.regionServers
private Map<RegionInfo,
ServerName> SnapshotOfRegionAssignmentFromMeta.regionToRegionServerMap
the region to region server 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
(ClusterConnection connection, ServerName server, RegionInfo region, long timeout) Contacts a region server and waits up to timeout ms to close the region.private static int
RegionPlan.compareServerName
(ServerName left, ServerName right) private boolean
MasterRpcServices.containMetaWals
(ServerName serverName) protected ActiveMasterManager
HMaster.createActiveMasterManager
(ZKWatcher zk, ServerName sn, Server server) Protected to have custom implementations in tests override the default ActiveMaster implementation.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.void
DeadServer.finish
(ServerName sn) Complete processing for this dead server.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) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface
ServerManager.getRsAdmin
(ServerName sn) 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) void
DeadServer.processing
(ServerName sn) Addsn<
to set of processing deadservers.(package private) void
DeadServer.putIfAbsent
(ServerName sn) Adds the server to the dead server list if it's not there already.void
HMaster.recommissionRegionServer
(ServerName server, List<byte[]> encodedRegionNames) Remove decommission marker (previously called 'draining') from a region server to allow regions assignments.(package private) void
ServerManager.recordNewServerWithLock
(ServerName serverName, ServerMetrics sl) Adds the onlineServers list.void
LoadBalancer.regionOnline
(RegionInfo regionInfo, ServerName sn) Marks the region as online at balancer.void
ServerManager.regionServerReport
(ServerName sn, ServerMetrics sl) void
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) void
ServerManager.sendRegionWarmup
(ServerName server, RegionInfo region) Sends a WARMUP RPC to the specified server to warmup the specified region.default void
ServerListener.serverAdded
(ServerName serverName) The server has joined the cluster.void
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 snModifier 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) 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) 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) 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) void
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 hriA, RegionInfo hriB, ServerName serverName) long
AssignmentManager.submitServerCrash
(ServerName serverName, boolean shouldSplitWal, boolean force) Usually run by the Master in reaction to server crash during normal processing.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 evictCache) 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
Modifier and TypeMethodDescriptionprivate ServerName
FavoredStochasticBalancer.getServerFromFavoredNode
(List<ServerName> servers, ServerName fn) (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) MaintenanceLoadBalancer.randomAssignment
(RegionInfo regionInfo, List<ServerName> servers) Modifier and TypeMethodDescriptionprivate Map<ServerName,
List<RegionInfo>> MaintenanceLoadBalancer.assign
(Collection<RegionInfo> regions, List<ServerName> servers) protected Map<ServerName,
List<RegionInfo>> BaseLoadBalancer.assignMasterSystemRegions
(Collection<RegionInfo> regions, List<ServerName> servers) Deprecated.since 2.4.0, will be removed in 3.0.0.private List<ServerName>
BaseLoadBalancer.findIdleServers
(List<ServerName> servers) private Map<ServerName,
List<RegionInfo>> FavoredStochasticBalancer.generateFNForRegionsWithoutFN
(FavoredNodeAssignmentHelper helper, List<RegionInfo> regions) (package private) Map<ServerName,
List<RegionInfo>> ClusterLoadState.getClusterState()
FavoredStochasticBalancer.getFavoredNodes
(RegionInfo regionInfo) private Set<ServerName>
FavoredStochasticBalancer.getInheritedFNForDaughter
(FavoredNodeAssignmentHelper helper, List<ServerName> parentFavoredNodes, FavoredNodesPlan.Position primary, FavoredNodesPlan.Position secondary) private List<ServerName>
FavoredStochasticBalancer.getOnlineFavoredNodes
(List<ServerName> onlineServers, List<ServerName> serversWithoutStartCodes) private Map<ServerName,
List<RegionInfo>> BaseLoadBalancer.getRegionAssignmentsByServer
(Collection<RegionInfo> regions) protected List<ServerName>
RegionLocationFinder.getTopBlockLocations
(RegionInfo region) protected List<ServerName>
RegionLocationFinder.getTopBlockLocations
(RegionInfo region, String currentHost) Returns an ordered list of hosts which have better locality for this region than the current host.(package private) List<ServerName>
RegionLocationFinder.mapHostNameToServerName
(List<String> hosts) Map hostname to ServerName, The output ServerName list will have the same order as input hosts.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) 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) MaintenanceLoadBalancer.roundRobinAssignment
(List<RegionInfo> regions, List<ServerName> servers) private Pair<Map<ServerName,
List<RegionInfo>>, List<RegionInfo>> FavoredStochasticBalancer.segregateRegionsAndAssignRegionsWithFavoredNodes
(Collection<RegionInfo> regions, List<ServerName> onlineServers) protected 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) (package private) void
BalancerClusterState.doAssignRegion
(RegionInfo regionInfo, ServerName serverName) (package private) int
HeterogeneousRegionCountCostFunction.findLimitForRS
(ServerName serverName) Find the limit for a ServerName.private float
RegionLocationFinder.getOldLocality
(ServerName newServer, byte[] regionName, Map<ServerName, ServerMetrics> oldServers) BalancerClusterState.DefaultRackManager.getRack
(ServerName server) private ServerName
FavoredStochasticBalancer.getServerFromFavoredNode
(List<ServerName> servers, ServerName fn) void
BaseLoadBalancer.regionOnline
(RegionInfo regionInfo, ServerName sn) void
MaintenanceLoadBalancer.regionOnline
(RegionInfo regionInfo, ServerName sn) (package private) boolean
BalancerClusterState.wouldLowerAvailability
(RegionInfo regionInfo, ServerName serverName) Return true if the placement of region on server would lower the availability of the region in 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) protected Map<ServerName,
List<RegionInfo>> BaseLoadBalancer.assignMasterSystemRegions
(Collection<RegionInfo> regions, List<ServerName> servers) Deprecated.since 2.4.0, will be removed in 3.0.0.private void
FavoredStochasticBalancer.assignRegionToAvailableFavoredNode
(Map<ServerName, List<RegionInfo>> assignmentMapForFavoredNodes, RegionInfo region, ServerName primaryHost, ServerName secondaryHost, ServerName tertiaryHost) 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) protected List<RegionPlan>
BaseLoadBalancer.balanceMasterRegions
(Map<ServerName, List<RegionInfo>> clusterMap) Deprecated.since 2.4.0, will be removed in 3.0.0.private void
SimpleLoadBalancer.balanceOverall
(List<RegionPlan> regionsToReturn, Map<ServerName, SimpleLoadBalancer.BalanceInfo> serverBalanceInfo, boolean fetchFromTail, org.apache.hbase.thirdparty.com.google.common.collect.MinMaxPriorityQueue<RegionPlan> regionsToMove, int max, int min) If we need to balanceoverall, we need to add one more round to peel off one region from each max.protected 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) 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) private int
FavoredStochasticBalancer.FavoredNodeLocalityPicker.getDifferentFavoredNode
(BalancerClusterState cluster, List<ServerName> favoredNodes, int currentServer) private Set<ServerName>
FavoredStochasticBalancer.getInheritedFNForDaughter
(FavoredNodeAssignmentHelper helper, List<ServerName> parentFavoredNodes, FavoredNodesPlan.Position primary, FavoredNodesPlan.Position secondary) private float
RegionLocationFinder.getOldLocality
(ServerName newServer, byte[] regionName, Map<ServerName, ServerMetrics> oldServers) private List<ServerName>
FavoredStochasticBalancer.getOnlineFavoredNodes
(List<ServerName> onlineServers, List<ServerName> serversWithoutStartCodes) private ServerName
FavoredStochasticBalancer.getServerFromFavoredNode
(List<ServerName> servers, ServerName fn) 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) 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) FavoredStochasticBalancer.retainAssignment
(Map<RegionInfo, ServerName> regions, List<ServerName> servers) 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) (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, RegionLocationFinder regionFinder, RackManager rackManager, Map<String, Pair<ServerName, Float>> oldRegionServerRegionCacheRatio) (package private)
BalancerClusterState
(Map<ServerName, List<RegionInfo>> clusterState, Map<String, Deque<BalancerRegionLoad>> loads, RegionLocationFinder regionFinder, RackManager rackManager) protected
BalancerClusterState
(Map<ServerName, List<RegionInfo>> clusterState, Map<String, Deque<BalancerRegionLoad>> loads, RegionLocationFinder 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) 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
ClaimReplicationQueueRemoteProcedure.crashedServer
private ServerName
ClaimReplicationQueuesProcedure.crashedServer
Modifier and TypeMethodDescriptionClaimReplicationQueueRemoteProcedure.getServerName()
ClaimReplicationQueuesProcedure.getServerName()
Modifier and TypeMethodDescriptionClaimReplicationQueueRemoteProcedure.remoteCallBuild
(MasterProcedureEnv env, ServerName remote) RefreshPeerProcedure.remoteCallBuild
(MasterProcedureEnv env, ServerName remote) ModifierConstructorDescriptionClaimReplicationQueueRemoteProcedure
(ServerName crashedServer, String queue, ServerName targetServer) ClaimReplicationQueuesProcedure
(ServerName crashedServer) RefreshPeerProcedure
(String peerId, PeerProcedureInterface.PeerOperationType type, 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
protected ServerName
HRegionServer.serverName
The server name the Master sees us as.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.getServerName()
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) 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) UnassignRegionHandler
(HRegionServer server, String encodedName, long closeProcId, boolean abort, ServerName destination, EventType eventType, boolean evictCache) -
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 List<ServerName>
ReplicationQueueInfo.deadRegionServers
private List<ServerName>
HBaseReplicationEndpoint.regionServers
Modifier and TypeMethodDescriptionprotected static List<ServerName>
HBaseReplicationEndpoint.fetchSlavesAddresses
(ZKWatcher zkw) Get the list of all the region servers from the specified peerReplicationQueueInfo.getDeadRegionServers()
ReplicationQueueStorage.getListOfReplicators()
Get a list of all region servers that have outstanding replication queues.ZKReplicationQueueStorage.getListOfReplicators()
private List<ServerName>
ZKReplicationQueueStorage.getListOfReplicators0()
HBaseReplicationEndpoint.getRegionServers()
Get a list of all the addresses of all the available region servers for this peer cluster, or an empty list if no region servers available at peer cluster.Modifier and TypeMethodDescriptionvoid
ReplicationQueueStorage.addWAL
(ServerName serverName, String queueId, String fileName) Add a new WAL file to the given queue for a given regionserver.void
ZKReplicationQueueStorage.addWAL
(ServerName serverName, String queueId, String fileName) ReplicationQueueStorage.claimQueue
(ServerName sourceServerName, String queueId, ServerName destServerName) Change ownership for the queue identified by queueId and belongs to a dead region server.ZKReplicationQueueStorage.claimQueue
(ServerName sourceServerName, String queueId, ServerName destServerName) This implement must update the cversion of rootZKReplicationQueueStorage.queuesZNode
.ReplicationQueueStorage.getAllQueues
(ServerName serverName) Get a list of all queues for the specified region server.ZKReplicationQueueStorage.getAllQueues
(ServerName serverName) ZKReplicationQueueStorage.getAllQueues0
(ServerName serverName) private String
ZKReplicationQueueStorage.getFileNode
(ServerName serverName, String queueId, String fileName) private String
ZKReplicationQueueStorage.getQueueNode
(ServerName serverName, String queueId) ReplicationQueueStorage.getRsNode
(ServerName serverName) Get full znode name for given region serverZKReplicationQueueStorage.getRsNode
(ServerName serverName) long
ReplicationQueueStorage.getWALPosition
(ServerName serverName, String queueId, String fileName) Get the current position for a specific WAL in a given queue for a given regionserver.long
ZKReplicationQueueStorage.getWALPosition
(ServerName serverName, String queueId, String fileName) ReplicationQueueStorage.getWALsInQueue
(ServerName serverName, String queueId) Get a list of all WALs in the given queue on the given region server.ZKReplicationQueueStorage.getWALsInQueue
(ServerName serverName, String queueId) ZKReplicationQueueStorage.getWALsInQueue0
(ServerName serverName, String queueId) void
ReplicationListener.regionServerRemoved
(ServerName regionServer) A region server has been removed from the local clustervoid
ReplicationQueueStorage.removeQueue
(ServerName serverName, String queueId) Remove a replication queue for a given regionserver.void
ZKReplicationQueueStorage.removeQueue
(ServerName serverName, String queueId) void
ReplicationQueueStorage.removeReplicatorIfQueueIsEmpty
(ServerName serverName) Remove the record of region server if the queue is empty.void
ZKReplicationQueueStorage.removeReplicatorIfQueueIsEmpty
(ServerName serverName) void
ReplicationQueueStorage.removeWAL
(ServerName serverName, String queueId, String fileName) Remove an WAL file from the given queue for a given regionserver.void
ZKReplicationQueueStorage.removeWAL
(ServerName serverName, String queueId, String fileName) void
ReplicationQueueStorage.setWALPosition
(ServerName serverName, String queueId, String fileName, long position, Map<String, Long> lastSeqIds) Set the current position for a specific WAL in a given queue for a given regionserver.void
ZKReplicationQueueStorage.setWALPosition
(ServerName serverName, String queueId, String fileName, long position, Map<String, Long> lastSeqIds) Modifier and TypeMethodDescriptionprivate static void
ReplicationQueueInfo.extractDeadServersFromZNodeString
(String deadServerListStr, List<ServerName> result) Parse dead server names from queue id.void
HBaseReplicationEndpoint.setRegionServers
(List<ServerName> regionServers) Set the list of region servers for that peer -
Uses of ServerName in org.apache.hadoop.hbase.replication.regionserver
Modifier and TypeFieldDescriptionprivate ServerName
ClaimReplicationQueueCallable.crashedServer
private ServerName
ReplicationSinkManager.SinkPeer.serverName
Modifier and TypeFieldDescriptionprivate final Map<ServerName,
Integer> ReplicationSinkManager.badReportCounts
private List<ServerName>
ReplicationSinkManager.sinks
Modifier and TypeMethodDescription(package private) ServerName
ReplicationSinkManager.SinkPeer.getServerName()
ReplicationSyncUp.DummyServer.getServerName()
RecoveredReplicationSource.getServerWALsBelongTo()
ReplicationSource.getServerWALsBelongTo()
ReplicationSourceInterface.getServerWALsBelongTo()
The queue of WALs only belong to one region server.Modifier and TypeMethodDescriptionNoopReplicationQueueStorage.getListOfReplicators()
private Set<ServerName>
ReplicationSyncUp.getLiveRegionServers
(ZKWatcher zkw) protected List<ServerName>
ReplicationSinkManager.getSinksForTesting()
Modifier and TypeMethodDescriptionvoid
NoopReplicationQueueStorage.addWAL
(ServerName serverName, String queueId, String fileName) NoopReplicationQueueStorage.claimQueue
(ServerName sourceServerName, String queueId, ServerName destServerName) (package private) void
ReplicationSourceManager.claimQueue
(ServerName deadRS, String queue) void
PeerProcedureHandler.claimReplicationQueue
(ServerName crashedServer, String queue) void
PeerProcedureHandlerImpl.claimReplicationQueue
(ServerName crashedServer, String queue) private String
DumpReplicationQueues.formatQueue
(ServerName regionserver, ReplicationQueueStorage queueStorage, ReplicationQueueInfo queueInfo, String queueId, List<String> wals, boolean isDeleted, boolean hdfs) NoopReplicationQueueStorage.getAllQueues
(ServerName serverName) NoopReplicationQueueStorage.getRsNode
(ServerName serverName) private long
DumpReplicationQueues.getTotalWALSize
(org.apache.hadoop.fs.FileSystem fs, List<String> wals, ServerName server) return total size in bytes from a list of WALslong
NoopReplicationQueueStorage.getWALPosition
(ServerName serverName, String queueId, String fileName) NoopReplicationQueueStorage.getWALsInQueue
(ServerName serverName, String queueId) void
NoopReplicationQueueStorage.removeQueue
(ServerName serverName, String queueId) void
NoopReplicationQueueStorage.removeReplicatorIfQueueIsEmpty
(ServerName serverName) void
NoopReplicationQueueStorage.removeWAL
(ServerName serverName, String queueId, String fileName) void
NoopReplicationQueueStorage.setWALPosition
(ServerName serverName, String queueId, String fileName, long position, Map<String, Long> lastSeqIds) ModifierConstructorDescriptionSinkPeer
(ServerName serverName, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface regionServer) -
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) private List<ServerName>
RSGroupInfoManagerImpl.getOnlineRS()
(package private) Map<TableName,
Map<ServerName, List<RegionInfo>>> RSGroupAdminServer.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) void
RSGroupInfoManagerImpl.ServerEventsListenerThread.serverAdded
(ServerName serverName) void
RSGroupInfoManagerImpl.ServerEventsListenerThread.serverRemoved
(ServerName serverName) 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) void
RSGroupAdminEndpoint.postClearDeadServers
(ObserverContext<MasterCoprocessorEnvironment> ctx, List<ServerName> servers, List<ServerName> notClearedServers) 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.closeRegion
(ServerName sn, HRegionInfo hri) void
ThriftAdmin.compactRegionServer
(ServerName serverName) ThriftAdmin.coprocessorService
(ServerName serverName) void
ThriftAdmin.flushRegionServer
(ServerName serverName) ThriftAdmin.getCachedFilesList
(ServerName serverName) Get the list of cached filesThriftAdmin.getOnlineRegions
(ServerName sn) 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 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 TypeMethodDescriptionstatic 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, ClusterConnection 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<String>> ReplicationChecker.undeletedQueueIds
Modifier and TypeMethodDescriptionprivate Map<ServerName,
List<String>> 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>/... -
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)
ClusterStatus.getMasterName()
instead.