Uses of Class
org.apache.hadoop.hbase.ServerName
Packages that use 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
Fields in org.apache.hadoop.hbase declared as ServerNameModifier and TypeFieldDescriptionprivate final ServerNameClusterMetricsBuilder.ClusterMetricsImpl.masterNameprivate ServerNameClusterMetricsBuilder.masterNameprivate final ServerNameSplitLogTask.originServerDeprecated.private final ServerNameHRegionLocation.serverNameprivate final ServerNameServerMetricsBuilder.ServerMetricsImpl.serverNameprivate final ServerNameServerMetricsBuilder.serverNameFields in org.apache.hadoop.hbase with type parameters of type ServerNameModifier and TypeFieldDescriptionprivate List<ServerName>ClusterMetricsBuilder.backupMasterNamesprivate final List<ServerName>ClusterMetricsBuilder.ClusterMetricsImpl.backupMasterNamesprivate final List<ServerName>ClusterMetricsBuilder.ClusterMetricsImpl.deadServerNamesprivate List<ServerName>ClusterMetricsBuilder.deadServerNamesstatic final List<ServerName>ServerName.EMPTY_SERVER_LISTprivate static final org.apache.hbase.thirdparty.com.google.common.collect.Interner<ServerName>ServerName.INTERN_POOLIntern ServerNames.private final Map<ServerName,ServerMetrics> ClusterMetricsBuilder.ClusterMetricsImpl.liveServerMetricsprivate Map<ServerName,ServerMetrics> ClusterMetricsBuilder.liveServerMetricsprivate final List<ServerName>ClusterMetricsBuilder.ClusterMetricsImpl.serversNameprivate List<ServerName>ClusterMetricsBuilder.serversNameprivate final List<ServerName>ClusterMetricsBuilder.ClusterMetricsImpl.unknownServerNamesprivate List<ServerName>ClusterMetricsBuilder.unknownServerNamesMethods in org.apache.hadoop.hbase that return ServerNameModifier and TypeMethodDescriptionClusterStatus.getMaster()Deprecated.ClusterMetrics.getMasterName()Returns detailed information about the current masterServerName.ClusterMetricsBuilder.ClusterMetricsImpl.getMasterName()ClusterStatus.getMasterName()Deprecated.HRegionLocation.getServerName()static ServerNameMetaTableAccessor.getServerName(Result r, int replicaId) Returns aServerNamefrom catalog tableResult.Server.getServerName()Returns The unique server name for this server.ServerLoad.getServerName()Deprecated.ServerMetrics.getServerName()ServerMetricsBuilder.ServerMetricsImpl.getServerName()SplitLogTask.getServerName()Deprecated.static ServerNameMetaTableAccessor.getTargetServerName(Result r, int replicaId) Returns theServerNamefrom catalog tableResultwhere the region is transitioning on.static ServerNameServerName.parseServerName(String str) Parse a ServerName from a stringstatic ServerNameServerName.parseVersionedServerName(byte[] versionedBytes) Use this method instantiating aServerNamefrom bytes gotten from a call togetVersionedBytes().static ServerNameRetrieve an instance of ServerName.static ServerNameRetrieve an instance of ServerName.static ServerNameRetrieve an instance of ServerName.static ServerNameRetrieve an instance ofServerName.Methods in org.apache.hadoop.hbase that return types with arguments of type ServerNameModifier 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 aServerNamefrom 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.Methods in org.apache.hadoop.hbase with parameters of type ServerNameModifier and TypeMethodDescriptionstatic PutMetaTableAccessor.addLocation(Put p, ServerName sn, long openSeqNum, int replicaId) intServerName.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.booleanSplitLogTask.isDone(ServerName sn) Deprecated.booleanSplitLogTask.isErr(ServerName sn) Deprecated.booleanSplitLogTask.isOwned(ServerName sn) Deprecated.booleanSplitLogTask.isResigned(ServerName sn) Deprecated.static booleanServerName.isSameAddress(ServerName left, ServerName right) Compare two addressesbooleanSplitLogTask.isUnassigned(ServerName sn) Deprecated.static voidMetaTableAccessor.mergeRegions(Connection connection, RegionInfo mergedRegion, Map<RegionInfo, Long> parentSeqNum, ServerName sn, int regionReplication) Merge regions into one in an atomic operation.static ServerMetricsBuilderServerMetricsBuilder.newBuilder(ServerName sn) static ServerMetricsServerMetricsBuilder.of(ServerName sn) static ServerMetricsServerMetricsBuilder.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 voidMetaTableAccessor.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 ServerMetricsServerMetricsBuilder.toServerMetrics(ServerName serverName, int versionNumber, String version, org.apache.hadoop.hbase.shaded.protobuf.generated.ClusterStatusProtos.ServerLoad serverLoadPB) static ServerMetricsServerMetricsBuilder.toServerMetrics(ServerName serverName, org.apache.hadoop.hbase.shaded.protobuf.generated.ClusterStatusProtos.ServerLoad serverLoadPB) private static voidMetaTableAccessor.updateLocation(Connection connection, RegionInfo regionInfo, ServerName sn, long openSeqNum, long masterSystemTime) Updates the location of the specified region to be the specified server.static voidMetaTableAccessor.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.Method parameters in org.apache.hadoop.hbase with type arguments of type ServerNameModifier 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) Constructors in org.apache.hadoop.hbase with parameters of type ServerNameModifierConstructorDescription(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.privateServerMetricsBuilder(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) Constructor parameters in org.apache.hadoop.hbase with type arguments of type ServerNameModifierConstructorDescription(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
Fields in org.apache.hadoop.hbase.client declared as ServerNameModifier and TypeFieldDescriptionprivate final ServerNameAsyncRequestFutureImpl.SingleServerRequestRunnable.serverprivate ServerNameFastFailInterceptorContext.serverprivate ServerNameAsyncAdminRequestRetryingCaller.serverNameprivate ServerNameAsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder.serverNameprivate ServerNameAsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder.serverNameprivate ServerNameAsyncServerRequestRpcRetryingCaller.serverNameprivate final ServerNameServerConnectionUtils.ShortCircuitingClusterConnection.serverNameFields in org.apache.hadoop.hbase.client with type parameters of type ServerNameModifier and TypeFieldDescriptionprivate org.apache.hbase.thirdparty.com.google.common.collect.ImmutableMap<ServerName,org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.ClientMetaService.Interface> ConnectionRegistryRpcStubHolder.addr2Stubprivate CompletableFuture<org.apache.hbase.thirdparty.com.google.common.collect.ImmutableMap<ServerName,org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.ClientMetaService.Interface>> ConnectionRegistryRpcStubHolder.addr2StubFutureprivate final Set<ServerName>ConnectionRegistryRpcStubHolder.bootstrapNodesprivate final List<ServerName>ClusterIdFetcher.bootstrapServersprivate final Set<ServerName>MetaCache.cachedServersprivate final List<ServerName>ClusterStatusListener.deadServersConnectionImplementation.ServerErrorTracker.errorsByServerprotected final ConcurrentMap<ServerName,FailureInfo> PreemptiveFastFailInterceptor.repeatedFailuresMapprivate final Map<ServerName,Long> SimpleRequestController.RequestHeapSizeChecker.serverRequestSizesprivate final Map<ServerName,Long> SimpleRequestController.RequestRowsChecker.serverRowsprivate final Set<ServerName>SimpleRequestController.TaskCountChecker.serversIncludedprivate ConcurrentHashMap<ServerName,ConcurrentMap<byte[], MetricsConnection.RegionStats>> MetricsConnection.serverStatsprivate final ConcurrentHashMap<ServerName,ServerStatistics> ServerStatisticTracker.statsprivate final Map<ServerName,AtomicInteger> SimpleRequestController.TaskCountChecker.taskCounterPerServer(package private) final ConcurrentMap<ServerName,AtomicInteger> SimpleRequestController.taskCounterPerServerMethods in org.apache.hadoop.hbase.client that return ServerNameModifier and TypeMethodDescriptiondefault ServerNameAdmin.getMaster()Get the current active master.FastFailInterceptorContext.getServer()(package private) ServerNameMultiServerCallable.getServerName()Methods in org.apache.hadoop.hbase.client that return types with arguments of type ServerNameModifier 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 byCompletableFutureprotected 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 byCompletableFuturedefault 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) Methods in org.apache.hadoop.hbase.client with parameters of type ServerNameModifier and TypeMethodDescriptionvoidBatchErrors.add(Throwable ex, Row row, ServerName serverName) (package private) static voidAsyncProcess.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 voidAsyncBatchRpcRetryingCaller.addError(Iterable<Action> actions, Throwable error, ServerName serverName) private voidAsyncBatchRpcRetryingCaller.addError(Action action, Throwable error, ServerName serverName) private voidConnectionImplementation.cacheLocation(TableName tableName, ServerName source, HRegionLocation location) Put a newly discovered HRegionLocation into the cache.voidMetaCache.cacheLocation(TableName tableName, ServerName source, HRegionLocation location) Put a newly discovered HRegionLocation into the cache.(package private) longConnectionImplementation.ServerErrorTracker.calculateBackoffTime(ServerName server, long basePause) Calculates the back-off time for a retrying request to a particular server.private voidAsyncRequestFutureImpl.cleanServerCache(ServerName server, Throwable regionException) private CacheEvictionStatsHBaseAdmin.clearBlockCache(ServerName sn, List<RegionInfo> hris) private CompletableFuture<CacheEvictionStats>RawAsyncHBaseAdmin.clearBlockCache(ServerName serverName, List<RegionInfo> hris) (package private) voidAsyncMetaRegionLocator.clearCache(ServerName serverName) (package private) voidAsyncNonMetaRegionLocator.clearCache(ServerName serverName) (package private) voidAsyncRegionLocator.clearCache(ServerName serverName) voidMetaCache.clearCache(ServerName serverName) Delete all cached entries of a server.voidMetaCache.clearCache(TableName tableName, byte[] row, ServerName serverName) Delete a cached location for a table, row and server.voidClusterConnection.clearCaches(ServerName sn) Clear any caches that pertain to server namesn.voidConnectionImplementation.clearCaches(ServerName serverName) voidAdmin.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) voidHBaseAdmin.clearCompactionQueues(ServerName sn, Set<String> queues) RawAsyncHBaseAdmin.clearCompactionQueues(ServerName serverName, Set<String> queues) private BooleanHBaseAdmin.clearSlowLogsResponses(ServerName serverName) private CompletableFuture<Boolean>RawAsyncHBaseAdmin.clearSlowLogsResponses(ServerName serverName) voidAdmin.closeRegion(ServerName sn, HRegionInfo hri) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0 (HBASE-18231).voidHBaseAdmin.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.voidAdmin.compactRegionServer(ServerName serverName) Compact all regions on the region server.default voidAdmin.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) voidHBaseAdmin.compactRegionServer(ServerName serverName) RawAsyncHBaseAdmin.compactRegionServer(ServerName sn) private CompletableFuture<Void>RawAsyncHBaseAdmin.compactRegionServer(ServerName sn, boolean major) Admin.coprocessorService(ServerName serverName) Creates and returns aRpcChannelinstance 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.InterfaceAsyncConnectionImpl.createAdminServerStub(ServerName serverName) private MultiServerCallableAsyncRequestFutureImpl.createCallable(ServerName server, TableName tableName, MultiAction multi) Create a callable.private StringAsyncRequestFutureImpl.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.InterfaceAsyncConnectionImpl.createMasterStub(ServerName serverName) private org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.InterfaceAsyncConnectionImpl.createRegionServerStub(ServerName serverName) static ClusterConnectionServerConnectionUtils.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>.SingleServerRequestRunnableAsyncRequestFutureImpl.createSingleServerRequest(MultiAction multiAction, int numAttempt, ServerName server, Set<CancellableRegionServerCallable> callsInProgress) (package private) voidAsyncProcess.decTaskCounters(Collection<byte[]> regions, ServerName sn) voidRequestController.decTaskCounters(Collection<byte[]> regions, ServerName sn) Decrement the counter if a task is accomplished.voidSimpleRequestController.decTaskCounters(Collection<byte[]> regions, ServerName sn) private voidAsyncBatchRpcRetryingCaller.failAll(Stream<Action> actions, int tries, Throwable error, ServerName serverName) private voidAsyncRequestFutureImpl.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) voidAdmin.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) voidHBaseAdmin.flushRegionServer(ServerName serverName) RawAsyncHBaseAdmin.flushRegionServer(ServerName sn) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterfaceClusterConnection.getAdmin(ServerName serverName) Establishes a connection to the region server at the specified address.org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterfaceConnectionImplementation.getAdmin(ServerName serverName) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterfaceServerConnectionUtils.ShortCircuitingClusterConnection.getAdmin(ServerName sn) (package private) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.InterfaceAsyncConnectionImpl.getAdminStub(ServerName serverName) ClusterConnection.getAllBootstrapNodes(ServerName regionServer) Get the bootstrap node list of another region server.ConnectionImplementation.getAllBootstrapNodes(ServerName regionServer) private LongAsyncRequestFutureImpl.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.BlockingInterfaceClusterConnection.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.BlockingInterfaceConnectionImplementation.getClient(ServerName serverName) org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterfaceServerConnectionUtils.ShortCircuitingClusterConnection.getClient(ServerName sn) private StringAsyncBatchRpcRetryingCaller.getExtraContextForError(ServerName serverName) AsyncConnection.getHbck(ServerName masterServer) Retrieve an Hbck implementation to fix an HBase cluster.AsyncConnectionImpl.getHbck(ServerName masterServer) default HbckConnection.getHbck(ServerName masterServer) Retrieve an Hbck implementation to fix an HBase cluster.ConnectionImplementation.getHbck(ServerName masterServer) private HbckAsyncConnectionImpl.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) GetRegionMetricsof all regions hosted on a regionserver.Admin.getRegionMetrics(ServerName serverName, TableName tableName) GetRegionMetricsof all regions hosted on a regionserver for a table.AsyncAdmin.getRegionMetrics(ServerName serverName) Get a list ofRegionMetricsof all regions hosted on a region server.AsyncAdmin.getRegionMetrics(ServerName serverName, TableName tableName) Get a list ofRegionMetricsof 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 observedSpaceQuotaSnapshotViews observed by a RegionServer.CompletableFuture<? extends Map<TableName,? extends SpaceQuotaSnapshotView>> AsyncAdmin.getRegionServerSpaceQuotaSnapshots(ServerName serverName) Fetches the observedSpaceQuotaSnapshotViews 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.InterfaceAsyncConnectionImpl.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 StringConnectionUtils.getStubKey(String serviceName, ServerName serverName) Get a unique key for the rpc stub to the given server.protected voidPreemptiveFastFailInterceptor.handleFailureToServer(ServerName serverName, Throwable t) Handles failures encountered when communicating with a server.voidPreemptiveFastFailInterceptor.handleThrowable(Throwable t1, ServerName serverName, org.apache.commons.lang3.mutable.MutableBoolean couldNotCommunicateWithServer, org.apache.commons.lang3.mutable.MutableBoolean guaranteedClientSideOnly) (package private) voidAsyncProcess.incTaskCounters(Collection<byte[]> regions, ServerName sn) voidRequestController.incTaskCounters(Collection<byte[]> regions, ServerName sn) Increment the counter if we build a valid task.voidSimpleRequestController.incTaskCounters(Collection<byte[]> regions, ServerName sn) private booleanPreemptiveFastFailInterceptor.inFastFailMode(ServerName server) Checks to see if we are in the Fast fail mode for requests to the server.booleanClusterStatusListener.isDeadServer(ServerName sn) Check if we know if a server is dead.private booleanConnectionImplementation.isDeadServer(ServerName sn) protected booleanPreemptiveFastFailInterceptor.isServerInFailureMap(ServerName serverName) private voidAsyncBatchRpcRetryingCaller.logException(int tries, Supplier<Stream<AsyncBatchRpcRetryingCaller.RegionRequest>> regionsSupplier, Throwable error, ServerName serverName) private voidAsyncRequestFutureImpl.logNoResubmit(ServerName oldServer, int numAttempt, int failureCount, Throwable throwable, int failed, int stopped) voidAdmin.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) voidHBaseAdmin.majorCompactRegionServer(ServerName serverName) RawAsyncHBaseAdmin.majorCompactRegionServer(ServerName sn) (package private) AsyncRequestFutureImpl.RetryAsyncRequestFutureImpl.manageError(int originalIndex, Row row, AsyncRequestFutureImpl.Retry canRetry, Throwable throwable, ServerName server) Check that we can retry acts accordingly: logs, set the error status.voidAdmin.move(byte[] encodedRegionName, ServerName destServerName) Move the regionrencodedRegionNametodestServerName.AsyncAdmin.move(byte[] regionName, ServerName destServerName) Move the regionrtodest.AsyncHBaseAdmin.move(byte[] regionName, ServerName destServerName) voidHBaseAdmin.move(byte[] encodedRegionName, ServerName destServerName) RawAsyncHBaseAdmin.move(byte[] regionName, ServerName destServerName) voidClusterStatusListener.DeadServerHandler.newDead(ServerName sn) Called when a server is identified as dead.private voidAsyncBatchRpcRetryingCaller.onComplete(Map<byte[], AsyncBatchRpcRetryingCaller.RegionRequest> actionsByRegion, int tries, ServerName serverName, MultiResponse resp) private voidAsyncBatchRpcRetryingCaller.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 voidAsyncBatchRpcRetryingCaller.onError(Map<byte[], AsyncBatchRpcRetryingCaller.RegionRequest> actionsByRegion, int tries, Throwable t, ServerName serverName) private voidAsyncRequestFutureImpl.receiveGlobalFailure(MultiAction rsActions, ServerName server, int numAttempt, Throwable t, boolean clearServerCache) Resubmit all the actions from this multiaction after a failure.private voidAsyncRequestFutureImpl.receiveMultiAction(MultiAction multiAction, ServerName server, MultiResponse responses, int numAttempt) Called when we receive the result of a server query.voidAdmin.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) voidHBaseAdmin.recommissionRegionServer(ServerName server, List<byte[]> encodedRegionNames) RawAsyncHBaseAdmin.recommissionRegionServer(ServerName server, List<byte[]> encodedRegionNames) voidAsyncRegionLocationCache.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) voidConnectionImplementation.ServerErrorTracker.reportServerError(ServerName server) Reports that there was an error on the server to do whatever bean-counting necessary.voidMultiServerCallable.reset(ServerName location, MultiAction multiAction) private voidAsyncRequestFutureImpl.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.voidAdmin.rollWALWriter(ServerName serverName) Roll the log writer.AsyncAdmin.rollWALWriter(ServerName serverName) Roll the log writer.AsyncHBaseAdmin.rollWALWriter(ServerName serverName) voidHBaseAdmin.rollWALWriter(ServerName serverName) RawAsyncHBaseAdmin.rollWALWriter(ServerName serverName) private org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.RollWALWriterResponseHBaseAdmin.rollWALWriterImpl(ServerName sn) private voidAsyncBatchRpcRetryingCaller.sendToServer(ServerName serverName, AsyncBatchRpcRetryingCaller.ServerRequest serverReq, int tries) AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder.serverName(ServerName serverName) AsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder.serverName(ServerName serverName) private voidAsyncRequestFutureImpl.setError(int index, Row row, Throwable throwable, ServerName server) Sets the error from a particular action.voidFastFailInterceptorContext.setServer(ServerName server) protected voidCancellableRegionServerCallable.setStubByServiceName(ServerName serviceName) protected voidClientServiceCallable.setStubByServiceName(ServerName serviceName) protected abstract voidRegionServerCallable.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) voidConnectionImplementation.updateCachedLocation(RegionInfo hri, ServerName source, ServerName serverName, long seqNum) private voidAsyncRequestFutureImpl.updateCachedLocations(ServerName server, byte[] regionName, byte[] row, Throwable rowException) voidClusterConnection.updateCachedLocations(TableName tableName, byte[] regionName, byte[] rowkey, Object exception, ServerName source) Update the location cache.voidConnectionImplementation.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.voidAdmin.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) voidHBaseAdmin.updateConfiguration(ServerName server) RawAsyncHBaseAdmin.updateConfiguration(ServerName serverName) private voidPreemptiveFastFailInterceptor.updateFailureInfoForServer(ServerName server, FailureInfo fInfo, boolean didTry, boolean couldNotCommunicate, boolean retryDespiteFastFailMode) This function updates the Failure info for a particular server after the attempt tovoidMetricsConnection.updateRegionStats(ServerName serverName, byte[] regionName, RegionLoadStats stats) voidServerStatisticTracker.updateRegionStats(ServerName server, byte[] region, RegionLoadStats currentStats) voidStatisticTrackable.updateRegionStats(ServerName server, byte[] region, RegionLoadStats stats) Update stats per region.voidMetricsConnection.updateServerStats(ServerName serverName, byte[] regionName, Object r) protected voidAsyncRequestFutureImpl.updateStats(ServerName server, MultiResponse resp) (package private) static voidConnectionUtils.updateStats(Optional<ServerStatisticTracker> optStats, Optional<MetricsConnection> optMetrics, ServerName serverName, MultiResponse resp) static voidResultStatsUtil.updateStats(StatisticTrackable tracker, ServerName server, byte[] regionName, RegionLoadStats stats) Update the statistics for the specified region.Method parameters in org.apache.hadoop.hbase.client with type arguments of type ServerNameModifier and TypeMethodDescription(package private) static voidAsyncProcess.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 voidAsyncRequestFutureImpl.ReplicaCallIssuingRunnable.addReplicaActions(int index, Map<ServerName, MultiAction> actionsByServer, List<Action> unknownReplicaActions) Add replica actions to action map by server.private voidAsyncRequestFutureImpl.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) voidAdmin.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) voidHBaseAdmin.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) voidConnectionRegistryRpcStubHolder.refreshStubs(IOExceptionSupplier<Collection<ServerName>> fetchEndpoints) HBaseHbck.scheduleServerCrashProcedures(List<ServerName> serverNames) Hbck.scheduleServerCrashProcedures(List<ServerName> serverNames) (package private) voidAsyncRequestFutureImpl.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 voidAsyncBatchRpcRetryingCaller.sendOrDelay(Map<ServerName, AsyncBatchRpcRetryingCaller.ServerRequest> actionsByServer, int tries) (package private) <CResult> AsyncRequestFutureAsyncProcess.submitMultiActions(AsyncProcessTask task, List<Action> retainedActions, long nonceGroup, List<Exception> locationErrors, List<Integer> locationErrorRows, Map<ServerName, MultiAction> actionsByServer) Constructors in org.apache.hadoop.hbase.client with parameters of type ServerNameModifierConstructorDescriptionAsyncAdminRequestRetryingCaller(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) privateShortCircuitingClusterConnection(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) Constructor parameters in org.apache.hadoop.hbase.client with type arguments of type ServerNameModifierConstructorDescription(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
Methods in org.apache.hadoop.hbase.client.backoff with parameters of type ServerNameModifier and TypeMethodDescriptionlongClientBackoffPolicy.getBackoffTime(ServerName serverName, byte[] region, ServerStatistics stats) Returns the number of ms to wait on the client based on thelongClientBackoffPolicyFactory.NoBackoffPolicy.getBackoffTime(ServerName serverName, byte[] region, ServerStatistics stats) longExponentialClientBackoffPolicy.getBackoffTime(ServerName serverName, byte[] region, ServerStatistics stats) -
Uses of ServerName in org.apache.hadoop.hbase.coordination
Fields in org.apache.hadoop.hbase.coordination declared as ServerNameModifier and TypeFieldDescriptionprivate final ServerNameZkSplitLogWorkerCoordination.serverNameMethods in org.apache.hadoop.hbase.coordination that return ServerNameModifier and TypeMethodDescriptionSplitLogManagerCoordination.SplitLogManagerDetails.getServerName()Returns server nameMethods in org.apache.hadoop.hbase.coordination with parameters of type ServerNameModifier and TypeMethodDescriptionprotected static intZkSplitLogWorkerCoordination.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 voidZKSplitLogManagerCoordination.heartbeat(String path, int new_version, ServerName workerName) Constructors in org.apache.hadoop.hbase.coordination with parameters of type ServerNameModifierConstructorDescriptionZkSplitLogWorkerCoordination(ServerName serverName, ZKWatcher watcher) -
Uses of ServerName in org.apache.hadoop.hbase.coprocessor
Methods in org.apache.hadoop.hbase.coprocessor that return ServerNameModifier and TypeMethodDescriptionMasterCoprocessorEnvironment.getServerName()Returns Hosting Server's ServerNameRegionCoprocessorEnvironment.getServerName()Returns Hosting Server's ServerNameRegionServerCoprocessorEnvironment.getServerName()Returns Hosting Server's ServerNameMethods in org.apache.hadoop.hbase.coprocessor with parameters of type ServerNameModifier and TypeMethodDescriptiondefault voidMasterObserver.postMove(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo region, ServerName srcServer, ServerName destServer) Called after the region move has been requested.default voidMasterObserver.postRecommissionRegionServer(ObserverContext<MasterCoprocessorEnvironment> ctx, ServerName server, List<byte[]> encodedRegionNames) Called after recommission region server.default voidMasterObserver.preMove(ObserverContext<MasterCoprocessorEnvironment> ctx, RegionInfo region, ServerName srcServer, ServerName destServer) Called prior to moving a given region from one region server to another.default voidMasterObserver.preRecommissionRegionServer(ObserverContext<MasterCoprocessorEnvironment> ctx, ServerName server, List<byte[]> encodedRegionNames) Called before recommission region server.Method parameters in org.apache.hadoop.hbase.coprocessor with type arguments of type ServerNameModifier and TypeMethodDescriptiondefault voidMasterObserver.postClearDeadServers(ObserverContext<MasterCoprocessorEnvironment> ctx, List<ServerName> servers, List<ServerName> notClearedServers) Called after clear dead region servers.default voidMasterObserver.postDecommissionRegionServers(ObserverContext<MasterCoprocessorEnvironment> ctx, List<ServerName> servers, boolean offload) Called after decommission region servers.default voidMasterObserver.preDecommissionRegionServers(ObserverContext<MasterCoprocessorEnvironment> ctx, List<ServerName> servers, boolean offload) Called before decommission region servers. -
Uses of ServerName in org.apache.hadoop.hbase.exceptions
Methods in org.apache.hadoop.hbase.exceptions that return ServerNameConstructors in org.apache.hadoop.hbase.exceptions with parameters of type ServerNameModifierConstructorDescriptionPreemptiveFastFailException(long count, long timeOfFirstFailureMilliSec, long timeOfLatestAttemptMilliSec, ServerName serverName) Deprecated.PreemptiveFastFailException(long count, long timeOfFirstFailureMilliSec, long timeOfLatestAttemptMilliSec, ServerName serverName, boolean guaranteedClientSideOnly) Deprecated.RegionMovedException(ServerName serverName, long locationSeqNum) Constructor parameters in org.apache.hadoop.hbase.exceptions with type arguments of type ServerNameModifierConstructorDescriptionMasterRegistryFetchException(Set<ServerName> masters, Throwable failure) -
Uses of ServerName in org.apache.hadoop.hbase.favored
Subclasses of ServerName in org.apache.hadoop.hbase.favoredModifier and TypeClassDescription(package private) classThis class differs from ServerName in that start code is always ignored.Fields in org.apache.hadoop.hbase.favored with type parameters of type ServerNameModifier and TypeFieldDescriptionprivate final Map<String,List<ServerName>> FavoredNodesPlan.favoredNodesMapThe map between each region name and its favored region server listprivate final Map<ServerName,List<RegionInfo>> FavoredNodesManager.primaryRSToRegionMapprivate Map<String,List<ServerName>> FavoredNodeAssignmentHelper.rackToRegionServerMapprivate final Map<ServerName,List<RegionInfo>> FavoredNodesManager.secondaryRSToRegionMapprivate List<ServerName>FavoredNodeAssignmentHelper.serversprivate final Map<ServerName,List<RegionInfo>> FavoredNodesManager.teritiaryRSToRegionMapMethods in org.apache.hadoop.hbase.favored that return ServerNameModifier and TypeMethodDescriptionprivate ServerNameFavoredNodeLoadBalancer.availableServersContains(List<ServerName> servers, ServerName favoredNode) FavoredNodeAssignmentHelper.generateMissingFavoredNode(List<ServerName> favoredNodes) FavoredNodeAssignmentHelper.generateMissingFavoredNode(List<ServerName> favoredNodes, List<ServerName> excludeNodes) private ServerNameFavoredNodeAssignmentHelper.generateMissingFavoredNodeMultiRack(List<ServerName> favoredNodes) private ServerNameFavoredNodeAssignmentHelper.generateMissingFavoredNodeMultiRack(List<ServerName> favoredNodes, List<ServerName> excludeNodes) private ServerNameFavoredNodeAssignmentHelper.generateMissingFavoredNodeSingleRack(List<ServerName> favoredNodes, List<ServerName> excludeNodes) static ServerName[]FavoredNodeAssignmentHelper.getFavoredNodesList(byte[] favoredNodes) Convert PB bytes to ServerName.private ServerNameFavoredNodeAssignmentHelper.getOneRandomServer(String rack) protected ServerNameFavoredNodeAssignmentHelper.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) Methods in org.apache.hadoop.hbase.favored that return types with arguments of type ServerNameModifier 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) Methods in org.apache.hadoop.hbase.favored with parameters of type ServerNameModifier and TypeMethodDescriptionprivate voidFavoredNodeLoadBalancer.addRegionToMap(Map<ServerName, List<RegionInfo>> assignmentMapForFavoredNodes, RegionInfo region, ServerName host) private voidFavoredNodeLoadBalancer.assignRegionToAvailableFavoredNode(Map<ServerName, List<RegionInfo>> assignmentMapForFavoredNodes, RegionInfo region, ServerName primaryHost, ServerName secondaryHost, ServerName tertiaryHost) private ServerNameFavoredNodeLoadBalancer.availableServersContains(List<ServerName> servers, ServerName favoredNode) intStartcodeAgnosticServerName.compareTo(ServerName other) static FavoredNodesPlan.PositionFavoredNodesPlan.getFavoredServerPosition(List<ServerName> favoredNodes, ServerName server) Return the position of the server in the favoredNodes list.private StringFavoredNodeAssignmentHelper.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 StartcodeAgnosticServerNameStartcodeAgnosticServerName.valueOf(ServerName serverName) Method parameters in org.apache.hadoop.hbase.favored with type arguments of type ServerNameModifier and TypeMethodDescriptionprivate voidFavoredNodeLoadBalancer.addRegionToMap(Map<ServerName, List<RegionInfo>> assignmentMapForFavoredNodes, RegionInfo region, ServerName host) private voidFavoredNodesManager.addToReplicaLoad(RegionInfo hri, List<ServerName> servers) private voidFavoredNodeLoadBalancer.assignRegionToAvailableFavoredNode(Map<ServerName, List<RegionInfo>> assignmentMapForFavoredNodes, RegionInfo region, ServerName primaryHost, ServerName secondaryHost, ServerName tertiaryHost) private voidFavoredNodeLoadBalancer.assignSecondaryAndTertiaryNodesForRegion(FavoredNodeAssignmentHelper assignmentHelper, List<RegionInfo> regions, Map<RegionInfo, ServerName> primaryRSMap) private ServerNameFavoredNodeLoadBalancer.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) voidFavoredNodeLoadBalancer.generateFavoredNodesForDaughter(List<ServerName> servers, RegionInfo parent, RegionInfo regionA, RegionInfo regionB) voidFavoredNodesPromoter.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 ServerNameFavoredNodeAssignmentHelper.generateMissingFavoredNodeMultiRack(List<ServerName> favoredNodes) private ServerNameFavoredNodeAssignmentHelper.generateMissingFavoredNodeMultiRack(List<ServerName> favoredNodes, List<ServerName> excludeNodes) private ServerNameFavoredNodeAssignmentHelper.generateMissingFavoredNodeSingleRack(List<ServerName> favoredNodes, List<ServerName> excludeNodes) static byte[]FavoredNodeAssignmentHelper.getFavoredNodes(List<ServerName> serverAddrList) Returns PB'ed bytes ofHBaseProtos.FavoredNodesgenerated by the server list.static StringFavoredNodeAssignmentHelper.getFavoredNodesAsString(List<ServerName> nodes) static FavoredNodesPlan.PositionFavoredNodesPlan.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 ServerNameFavoredNodeAssignmentHelper.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 PutFavoredNodeAssignmentHelper.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) voidFavoredNodeAssignmentHelper.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 voidFavoredNodeLoadBalancer.roundRobinAssignmentImpl(FavoredNodeAssignmentHelper assignmentHelper, Map<ServerName, List<RegionInfo>> assignmentMap, List<RegionInfo> regions, List<ServerName> servers) voidFavoredNodesManager.updateFavoredNodes(Map<RegionInfo, List<ServerName>> regionFNMap) voidFavoredNodesPlan.updateFavoredNodesMap(RegionInfo region, List<ServerName> servers) Update an assignment to the planstatic voidFavoredNodeAssignmentHelper.updateMetaWithFavoredNodesInfo(Map<RegionInfo, List<ServerName>> regionToFavoredNodes, org.apache.hadoop.conf.Configuration conf) Update meta table with favored nodes infostatic voidFavoredNodeAssignmentHelper.updateMetaWithFavoredNodesInfo(Map<RegionInfo, List<ServerName>> regionToFavoredNodes, Connection connection) Update meta table with favored nodes infoConstructor parameters in org.apache.hadoop.hbase.favored with type arguments of type ServerNameModifierConstructorDescriptionFavoredNodeAssignmentHelper(List<ServerName> servers, org.apache.hadoop.conf.Configuration conf) FavoredNodeAssignmentHelper(List<ServerName> servers, RackManager rackManager) -
Uses of ServerName in org.apache.hadoop.hbase.ipc
Methods in org.apache.hadoop.hbase.ipc with parameters of type ServerNameModifier and TypeMethodDescriptionvoidAbstractRpcClient.cancelConnections(ServerName sn) Interrupt the connections to the given ip:port server.voidRpcClient.cancelConnections(ServerName sn) Interrupt the connections to the given server.(package private) static AddressAbstractRpcClient.createAddr(ServerName sn) org.apache.hbase.thirdparty.com.google.protobuf.BlockingRpcChannelAbstractRpcClient.createBlockingRpcChannel(ServerName sn, User ticket, int rpcTimeout) org.apache.hbase.thirdparty.com.google.protobuf.BlockingRpcChannelRpcClient.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.RpcChannelAbstractRpcClient.createRpcChannel(ServerName sn, User user, int rpcTimeout) org.apache.hbase.thirdparty.com.google.protobuf.RpcChannelRpcClient.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
Methods in org.apache.hadoop.hbase.mapreduce that return types with arguments of type ServerNameModifier and TypeMethodDescriptionprivate Set<ServerName>RegionSizeCalculator.getRegionServersOfTable(RegionLocator regionLocator) -
Uses of ServerName in org.apache.hadoop.hbase.master
Fields in org.apache.hadoop.hbase.master declared as ServerNameModifier and TypeFieldDescription(package private) ServerNameActiveMasterManager.activeMasterServerNamestatic final ServerNameLoadBalancer.BOGUS_SERVER_NAMESplitLogManager.Task.cur_worker_nameprivate ServerNameRegionPlan.destprivate final ServerNameRegionState.serverName(package private) final ServerNameActiveMasterManager.snprivate final ServerNameRegionPlan.sourceFields in org.apache.hadoop.hbase.master with type parameters of type ServerNameModifier and TypeFieldDescriptionprivate org.apache.hbase.thirdparty.com.google.common.collect.ImmutableList<ServerName>ActiveMasterManager.backupMastersprivate final Map<ServerName,List<RegionInfo>> SnapshotOfRegionAssignmentFromMeta.currentRSToRegionMapthe regionServer to region mapprivate final Map<ServerName,Integer> WorkerAssigner.currentWorkersprivate final Map<ServerName,Long> DeadServer.deadServersSet of known dead servers.private Set<ServerName>SplitLogManager.deadWorkersDeprecated.private final NavigableSet<ServerName>DrainingServerTracker.drainingServersprivate final ArrayList<ServerName>ServerManager.drainingServersList of region servers that should not get any more new regions.private final ConcurrentMap<ServerName,Integer> ClusterStatusPublisher.lastSentprivate Set<ServerName>AssignmentVerificationReport.leastLoadedRSSetprivate Set<ServerName>AssignmentVerificationReport.maxDispersionNumServerSetprivate Set<ServerName>AssignmentVerificationReport.maxDispersionScoreServerSetprivate Set<ServerName>AssignmentVerificationReport.minDispersionNumServerSetprivate Set<ServerName>AssignmentVerificationReport.minDispersionScoreServerSetprivate Set<ServerName>AssignmentVerificationReport.mostLoadedRSSetprivate final ConcurrentNavigableMap<ServerName,ServerMetrics> ServerManager.onlineServersMap of registered servers to their current loadprivate final Map<ServerName,List<RegionInfo>> SnapshotOfRegionAssignmentFromMeta.primaryRSToRegionMapprivate final Set<ServerName>DeadServer.processingServersSet of dead servers currently being processed by a SCP.private Set<ServerName>RegionServerTracker.regionServersprivate Map<RegionInfo,ServerName> SnapshotOfRegionAssignmentFromMeta.regionToRegionServerMapthe region to region server mapprivate final Map<ServerName,List<RegionInfo>> SnapshotOfRegionAssignmentFromMeta.secondaryRSToRegionMapprivate final Map<ServerName,List<RegionInfo>> SnapshotOfRegionAssignmentFromMeta.teritiaryRSToRegionMapMethods in org.apache.hadoop.hbase.master that return ServerNameModifier 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) ServerNameServerManager.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 onlineMethods in org.apache.hadoop.hbase.master that return types with arguments of type ServerNameModifier 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.Methods in org.apache.hadoop.hbase.master with parameters of type ServerNameModifier and TypeMethodDescriptionprivate voidSnapshotOfRegionAssignmentFromMeta.addAssignment(RegionInfo regionInfo, ServerName server) private voidSnapshotOfRegionAssignmentFromMeta.addPrimaryAssignment(RegionInfo regionInfo, ServerName server) private voidSnapshotOfRegionAssignmentFromMeta.addSecondaryAssignment(RegionInfo regionInfo, ServerName server) booleanServerManager.addServerToDrainList(ServerName sn) Add the server to the drain list.private voidSnapshotOfRegionAssignmentFromMeta.addTeritiaryAssignment(RegionInfo regionInfo, ServerName server) voidSplitWALManager.addUsedSplitWALWorker(ServerName worker) When master restart, there will be a new splitWorkerAssigner.voidWorkerAssigner.addUsedWorker(ServerName worker) voidMasterWalManager.archiveMetaLog(ServerName serverName) The hbase:meta region may OPEN and CLOSE without issue on a server and then move elsewhere.(package private) booleanServerManager.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 voidServerManager.checkClockSkew(ServerName serverName, long serverCurrentTime) Checks if the clock skew between the server and the master.private voidServerManager.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 voidServerManager.checkRejectableDecommissionedStatus(ServerName sn) Checks if the Master is configured to reject decommissioned hosts or not.(package private) voidDeadServer.cleanAllPreviousInstances(ServerName newServerName) private booleanDeadServer.cleanOldServerName(ServerName newServerName, Iterator<ServerName> deadServerIterator) (package private) booleanDeadServer.cleanPreviousInstance(ServerName newServerName) Handles restart of a server.static voidServerManager.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 intRegionPlan.compareServerName(ServerName left, ServerName right) private booleanMasterRpcServices.containMetaWals(ServerName serverName) protected ActiveMasterManagerHMaster.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) voidSplitWALManager.deleteWALDir(ServerName serverName) voidMasterRegionServerList.expired(ServerName sn) voidRegionServerList.expired(ServerName sn) Called when a region server is dead.longServerManager.expireServer(ServerName serverName) Expire the passed server.(package private) longServerManager.expireServer(ServerName serverName, boolean force) ServerManager.findServerWithSameHostnamePortWithLock(ServerName serverName) Assumes onlineServers is locked.voidDeadServer.finish(ServerName sn) Complete processing for this dead server.WorkerAssigner.getAvailableWorker(ServerName serverName) intActiveMasterManager.getBackupMasterInfoPort(ServerName sn) intHMaster.getBackupMasterInfoPort(ServerName sn) intServerManager.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.intHMaster.getRegionServerInfoPort(ServerName sn) HMaster.getRegionServerVersion(ServerName sn) MasterServices.getRegionServerVersion(ServerName sn) HMaster.getReplicationLoad(ServerName[] serverNames) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterfaceServerManager.getRsAdmin(ServerName sn) private org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionServerInfoRegionServerTracker.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 onlineintServerManager.getVersionNumber(ServerName serverName) May return 0 when server is not online.private org.apache.hadoop.fs.PathSplitWALManager.getWALSplitDir(ServerName serverName) List<org.apache.hadoop.fs.FileStatus>SplitWALManager.getWALsToSplit(ServerName serverName, boolean splitMeta) (package private) voidSplitLogManager.handleDeadWorker(ServerName workerName) Deprecated.voidSplitLogManager.Task.heartbeat(long time, int version, ServerName worker) booleanRegionState.isClosingOrClosedOnServer(ServerName sn) booleanDeadServer.isDeadServer(ServerName serverName) booleanRegionState.isMergingNewOnServer(ServerName sn) booleanRegionState.isMergingNewOrOfflineOnServer(ServerName sn) booleanRegionState.isMergingNewOrOpenedOnServer(ServerName sn) booleanRegionState.isMergingOnServer(ServerName sn) booleanRegionState.isOnServer(ServerName sn) booleanRegionState.isOpenedOnServer(ServerName sn) booleanRegionState.isOpeningOrFailedOpenOnServer(ServerName sn) booleanRegionState.isOpeningOrOpenedOnServer(ServerName sn) booleanServerManager.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.booleanServerManager.isServerOnline(ServerName serverName) booleanServerManager.isServerUnknown(ServerName serverName) Check if a server is unknown.booleanRegionState.isSplittingNewOnServer(ServerName sn) booleanRegionState.isSplittingOnServer(ServerName sn) booleanRegionState.isSplittingOrOpenedOnServer(ServerName sn) booleanRegionState.isSplittingOrSplitOnServer(ServerName sn) voidServerManager.moveFromOnlineToDeadServers(ServerName sn) Called when server has expired.voidMasterCoprocessorHost.postMove(RegionInfo region, ServerName srcServer, ServerName destServer) voidMasterCoprocessorHost.postRecommissionRegionServer(ServerName server, List<byte[]> encodedRegionNames) voidMasterCoprocessorHost.preMove(RegionInfo region, ServerName srcServer, ServerName destServer) voidMasterCoprocessorHost.preRecommissionRegionServer(ServerName server, List<byte[]> encodedRegionNames) voidDeadServer.processing(ServerName sn) Addsn<to set of processing deadservers.(package private) voidDeadServer.putIfAbsent(ServerName sn) Adds the server to the dead server list if it's not there already.voidHMaster.recommissionRegionServer(ServerName server, List<byte[]> encodedRegionNames) Remove decommission marker (previously called 'draining') from a region server to allow regions assignments.(package private) voidServerManager.recordNewServerWithLock(ServerName serverName, ServerMetrics sl) Adds the onlineServers list.voidLoadBalancer.regionOnline(RegionInfo regionInfo, ServerName sn) Marks the region as online at balancer.voidServerManager.regionServerReport(ServerName sn, ServerMetrics sl) voidWorkerAssigner.release(ServerName serverName) voidSplitWALManager.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 voidDrainingServerTracker.remove(ServerName sn) booleanDeadServer.removeDeadServer(ServerName deadServerName) Called from rpc by operator cleaning up deadserver list.booleanServerManager.removeServerFromDrainList(ServerName sn) voidServerManager.sendRegionWarmup(ServerName server, RegionInfo region) Sends a WARMUP RPC to the specified server to warmup the specified region.default voidServerListener.serverAdded(ServerName serverName) The server has joined the cluster.voidWorkerAssigner.serverAdded(ServerName worker) default voidServerListener.serverRemoved(ServerName serverName) The server was removed from the cluster.voidRegionPlan.setDestination(ServerName dest) Set the destination server for the plan for this region.private booleanMasterRpcServices.shouldSubmitSCP(ServerName serverName) voidMasterWalManager.splitLog(ServerName serverName) voidMasterWalManager.splitMetaLog(ServerName serverName) Specialized method to handle the splitting for meta WALSplitWALManager.splitWALs(ServerName crashedServer, boolean splitMeta) voidMasterRegionServerList.started(ServerName sn) voidRegionServerList.started(ServerName sn) Called when a region server join the cluster.private voidServerManager.updateLastFlushedSequenceIds(ServerName sn, ServerMetrics hsl) Updates last flushed sequence Ids for the regions on server snMethod parameters in org.apache.hadoop.hbase.master with type arguments of type ServerNameModifier and TypeMethodDescriptionLoadBalancer.balanceCluster(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) Perform the major balance operation for cluster.private booleanDeadServer.cleanOldServerName(ServerName newServerName, Iterator<ServerName> deadServerIterator) ServerManager.createDestinationServersList(List<ServerName> serversToExclude) Creates a list of possible destinations for a region.voidHMaster.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) voidServerManager.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) voidSplitLogManager.handleDeadWorkers(Set<ServerName> serverNames) Deprecated.voidMasterCoprocessorHost.postClearDeadServers(List<ServerName> servers, List<ServerName> notClearedServers) voidMasterCoprocessorHost.postDecommissionRegionServers(List<ServerName> servers, boolean offload) voidMasterCoprocessorHost.preDecommissionRegionServers(List<ServerName> servers, boolean offload) private voidAssignmentVerificationReport.printHServerAddressSet(Set<ServerName> serverSet) private voidRegionServerTracker.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 servervoidMasterWalManager.splitLog(Set<ServerName> serverNames) voidMasterWalManager.splitLog(Set<ServerName> serverNames, org.apache.hadoop.fs.PathFilter filter) This method is the base split method that splits WAL files matching a filter.longSplitLogManager.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.voidMasterWalManager.splitMetaLog(Set<ServerName> serverNames) Specialized method to handle the splitting for meta WALdefault voidLoadBalancer.updateBalancerLoadInfo(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) In some scenarios, Balancer needs to update internal status or information according to the current tables loadvoidRegionServerTracker.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.Constructors in org.apache.hadoop.hbase.master with parameters of type ServerNameModifierConstructorDescription(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
Fields in org.apache.hadoop.hbase.master.assignment declared as ServerNameModifier and TypeFieldDescriptionprivate ServerNameCloseRegionProcedure.assignCandidateprivate ServerNameTransitRegionStateProcedure.assignCandidateprotected ServerNameUnassignProcedure.destinationServerDeprecated.protected ServerNameUnassignProcedure.hostingServerDeprecated.private ServerNameRegionStateNode.lastHostprivate ServerNameMergeTableRegionsProcedure.regionLocationprivate ServerNameRegionStateNode.regionLocationprivate final ServerNameServerStateNode.serverNameprotected ServerNameAssignProcedure.targetServerDeprecated.protected ServerNameRegionRemoteProcedureBase.targetServerFields in org.apache.hadoop.hbase.master.assignment with type parameters of type ServerNameModifier and TypeFieldDescriptionprivate final Map<ServerName,Set<byte[]>> AssignmentManager.rsReportsprivate final ConcurrentHashMap<ServerName,ServerStateNode> RegionStates.serverMapMethods in org.apache.hadoop.hbase.master.assignment that return ServerNameModifier and TypeMethodDescriptionRegionStateNode.getLastHost()private ServerNameSplitTableRegionProcedure.getParentRegionServerName(MasterProcedureEnv env) RegionStateNode.getRegionLocation()RegionStates.getRegionServerOfRegion(RegionInfo regionInfo) private ServerNameMergeTableRegionsProcedure.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) Methods in org.apache.hadoop.hbase.master.assignment that return types with arguments of type ServerNameModifier 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) Methods in org.apache.hadoop.hbase.master.assignment with parameters of type ServerNameModifier and TypeMethodDescriptionlongAssignmentManager.assign(RegionInfo regionInfo, ServerName sn) static TransitRegionStateProcedureTransitRegionStateProcedure.assign(MasterProcedureEnv env, RegionInfo region, boolean forceNewPlan, ServerName targetServer) static TransitRegionStateProcedureTransitRegionStateProcedure.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 voidTransitRegionStateProcedure.checkAndWaitForOriginalServer(MasterProcedureEnv env, ServerName lastHost) private voidAssignmentManager.closeRegionSilently(ServerName sn, byte[] regionName) CloseregionNameonsnsilently and immediately without using a Procedure or going via hbase:meta.private TransitRegionStateProcedureAssignmentManager.createAssignProcedure(RegionInfo regionInfo, ServerName sn, boolean override) Create an assign TransitRegionStateProcedure.private TransitRegionStateProcedureAssignmentManager.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) voidRegionStates.createServer(ServerName serverName) Create the ServerStateNode when registering a new region server(package private) static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.GetRegionInfoResponseAssignmentManagerUtil.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.GetRegionInfoResponseAssignmentManagerUtil.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) booleanAssignmentManager.isCarryingMeta(ServerName serverName) private booleanAssignmentManager.isCarryingRegion(ServerName serverName, RegionInfo regionInfo) voidRegionStates.logSplit(ServerName serverName) Called after we've split all logs on a crashed Server.voidRegionStates.logSplitting(ServerName serverName) Call this when we start log splitting for a crashed Server.voidAssignmentManager.markRegionAsMerged(RegionInfo child, ServerName serverName, RegionInfo[] mergeParents) When called here, the merge has happened.voidAssignmentManager.markRegionAsSplit(RegionInfo parent, ServerName serverName, RegionInfo daughterA, RegionInfo daughterB) voidRegionStateStore.mergeRegions(RegionInfo child, RegionInfo[] parents, ServerName serverName) voidRegionStates.metaLogSplit(ServerName serverName) Called after we've split the meta logs on a crashed Server.voidRegionStates.metaLogSplitting(ServerName serverName) Call this when we start meta log splitting a crashed Server.private voidRegionStateStore.mirrorMetaLocation(RegionInfo regionInfo, ServerName serverName, RegionState.State state) static TransitRegionStateProcedureTransitRegionStateProcedure.move(MasterProcedureEnv env, RegionInfo region, ServerName targetServer) voidAssignmentManager.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.voidRegionRemoteProcedureBase.remoteCallFailed(MasterProcedureEnv env, ServerName remote, IOException exception) voidRegionTransitionProcedure.remoteCallFailed(MasterProcedureEnv env, ServerName serverName, IOException exception) Deprecated.voidRegionStates.removeRegionFromServer(ServerName serverName, RegionStateNode regionNode) voidRegionStates.removeServer(ServerName serverName) Called by SCP at end of successful processing.(package private) static voidAssignmentManagerUtil.reopenRegionsForRollback(MasterProcedureEnv env, List<RegionInfo> regions, int regionReplication, ServerName targetServer) voidAssignmentManager.reportOnlineRegions(ServerName serverName, Set<byte[]> regionNames) The master will call this method when the RS send the regionServerReport().(package private) voidRegionRemoteProcedureBase.reportTransition(MasterProcedureEnv env, RegionStateNode regionNode, ServerName serverName, org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode transitionCode, long seqId) voidTransitRegionStateProcedure.reportTransition(MasterProcedureEnv env, RegionStateNode regionNode, ServerName serverName, org.apache.hadoop.hbase.shaded.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode code, long seqId, long procId) (package private) voidRegionRemoteProcedureBase.serverCrashed(MasterProcedureEnv env, RegionStateNode regionNode, ServerName serverName) voidTransitRegionStateProcedure.serverCrashed(MasterProcedureEnv env, RegionStateNode regionNode, ServerName serverName, boolean forceNewPlan) voidRegionStateNode.setLastHost(ServerName serverName) RegionStateNode.setRegionLocation(ServerName serverName) private voidRegionStates.setServerState(ServerName serverName, ServerState state) voidRegionStateStore.splitRegion(RegionInfo parent, RegionInfo hriA, RegionInfo hriB, ServerName serverName) longAssignmentManager.submitServerCrash(ServerName serverName, boolean shouldSplitWal, boolean force) Usually run by the Master in reaction to server crash during normal processing.voidAssignmentManager.RegionMetaLoadingVisitor.visitRegionState(Result result, RegionInfo regionInfo, RegionState.State state, ServerName regionLocation, ServerName lastHost, long openSeqNum) voidRegionStateStore.RegionStateVisitor.visitRegionState(Result result, RegionInfo regionInfo, RegionState.State state, ServerName regionLocation, ServerName lastHost, long openSeqNum) Method parameters in org.apache.hadoop.hbase.master.assignment with type arguments of type ServerNameModifier and TypeMethodDescriptionprivate voidAssignmentManager.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 voidRegionStates.createSnapshot(RegionStateNode node, Map<ServerName, List<RegionInfo>> result) RegionStates.getAssignmentsForBalancer(TableStateManager tableStateManager, List<ServerName> onlineServers) This is an EXPENSIVE clone.Constructors in org.apache.hadoop.hbase.master.assignment with parameters of type ServerNameModifierConstructorDescriptionCloseRegionProcedure(TransitRegionStateProcedure parent, RegionInfo region, ServerName targetServer, ServerName assignCandidate, boolean evictCache) OpenRegionProcedure(TransitRegionStateProcedure parent, RegionInfo region, ServerName targetServer) protectedRegionRemoteProcedureBase(TransitRegionStateProcedure parent, RegionInfo region, ServerName targetServer) ServerStateNode(ServerName serverName) protectedTransitRegionStateProcedure(MasterProcedureEnv env, RegionInfo hri, ServerName assignCandidate, boolean forceNewPlan, TransitRegionStateProcedure.TransitionType type) protectedTransitRegionStateProcedure(MasterProcedureEnv env, RegionInfo hri, ServerName assignCandidate, boolean forceNewPlan, TransitRegionStateProcedure.TransitionType type, boolean isSplit) -
Uses of ServerName in org.apache.hadoop.hbase.master.balancer
Fields in org.apache.hadoop.hbase.master.balancer declared as ServerNameModifier and TypeFieldDescriptionprotected ServerNameBaseLoadBalancer.masterServerName(package private) ServerName[]BalancerClusterState.serversprivate final ServerNameServerAndLoad.snFields in org.apache.hadoop.hbase.master.balancer with type parameters of type ServerNameModifier and TypeFieldDescription(package private) Map<ServerName,List<RegionInfo>> BalancerClusterState.clusterStateprivate final Map<ServerName,List<RegionInfo>> ClusterLoadState.clusterStateprivate final Map<ServerName,Integer> HeterogeneousRegionCountCostFunction.limitPerRSThis 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.regionCacheRatioOnOldServerMapMethods in org.apache.hadoop.hbase.master.balancer that return ServerNameModifier and TypeMethodDescriptionprivate ServerNameFavoredStochasticBalancer.getServerFromFavoredNode(List<ServerName> servers, ServerName fn) (package private) ServerNameServerAndLoad.getServerName()BaseLoadBalancer.randomAssignment(RegionInfo regionInfo, List<ServerName> servers) Used to assign a single region to a random server.private ServerNameBaseLoadBalancer.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) Methods in org.apache.hadoop.hbase.master.balancer that return types with arguments of type ServerNameModifier 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) Methods in org.apache.hadoop.hbase.master.balancer with parameters of type ServerNameModifier and TypeMethodDescriptionprivate voidSimpleLoadBalancer.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 voidFavoredStochasticBalancer.addRegionToMap(Map<ServerName, List<RegionInfo>> assignmentMapForFavoredNodes, RegionInfo region, ServerName host) private voidFavoredStochasticBalancer.assignRegionToAvailableFavoredNode(Map<ServerName, List<RegionInfo>> assignmentMapForFavoredNodes, RegionInfo region, ServerName primaryHost, ServerName secondaryHost, ServerName tertiaryHost) (package private) voidBalancerClusterState.doAssignRegion(RegionInfo regionInfo, ServerName serverName) (package private) intHeterogeneousRegionCountCostFunction.findLimitForRS(ServerName serverName) Find the limit for a ServerName.private floatRegionLocationFinder.getOldLocality(ServerName newServer, byte[] regionName, Map<ServerName, ServerMetrics> oldServers) BalancerClusterState.DefaultRackManager.getRack(ServerName server) private ServerNameFavoredStochasticBalancer.getServerFromFavoredNode(List<ServerName> servers, ServerName fn) voidBaseLoadBalancer.regionOnline(RegionInfo regionInfo, ServerName sn) voidMaintenanceLoadBalancer.regionOnline(RegionInfo regionInfo, ServerName sn) (package private) booleanBalancerClusterState.wouldLowerAvailability(RegionInfo regionInfo, ServerName serverName) Return true if the placement of region on server would lower the availability of the region in questionMethod parameters in org.apache.hadoop.hbase.master.balancer with type arguments of type ServerNameModifier and TypeMethodDescriptionprivate voidFavoredStochasticBalancer.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 voidFavoredStochasticBalancer.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 voidSimpleLoadBalancer.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 BalancerClusterStateBaseLoadBalancer.createCluster(List<ServerName> servers, Collection<RegionInfo> regions) private List<ServerName>BaseLoadBalancer.findIdleServers(List<ServerName> servers) voidFavoredStochasticBalancer.generateFavoredNodesForDaughter(List<ServerName> servers, RegionInfo parent, RegionInfo regionA, RegionInfo regionB) private intFavoredStochasticBalancer.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 floatRegionLocationFinder.getOldLocality(ServerName newServer, byte[] regionName, Map<ServerName, ServerMetrics> oldServers) private List<ServerName>FavoredStochasticBalancer.getOnlineFavoredNodes(List<ServerName> onlineServers, List<ServerName> serversWithoutStartCodes) private ServerNameFavoredStochasticBalancer.getServerFromFavoredNode(List<ServerName> servers, ServerName fn) private voidFavoredStochasticBalancer.mergeAssignmentMaps(Map<ServerName, List<RegionInfo>> assignmentMap, Map<ServerName, List<RegionInfo>> otherAssignments) private intFavoredStochasticBalancer.FavoredNodeLoadPicker.pickLeastLoadedFNServer(BalancerClusterState cluster, List<ServerName> favoredNodes, int currentServerIndex) protected voidBaseLoadBalancer.preBalanceCluster(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) Called before actually executing balanceCluster.protected voidSimpleLoadBalancer.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 ServerNameBaseLoadBalancer.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 voidBaseLoadBalancer.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) voidSimpleLoadBalancer.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) voidStochasticLoadBalancer.updateBalancerLoadInfo(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) private voidStochasticLoadBalancer.updateBalancerTableLoadInfo(TableName tableName, Map<ServerName, List<RegionInfo>> loadOfOneTable) private voidFavoredStochasticBalancer.updateFavoredNodesForRegion(RegionInfo regionInfo, List<ServerName> newFavoredNodes) Constructors in org.apache.hadoop.hbase.master.balancer with parameters of type ServerNameConstructor parameters in org.apache.hadoop.hbase.master.balancer with type arguments of type ServerNameModifierConstructorDescription(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) protectedBalancerClusterState(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
Fields in org.apache.hadoop.hbase.master.hbck with type parameters of type ServerNameModifier and TypeFieldDescriptionprivate final Map<String,Pair<ServerName, List<ServerName>>> HbckReport.inconsistentRegionsprivate final Map<String,Pair<ServerName, List<ServerName>>> HbckReport.inconsistentRegionsprivate final Map<String,ServerName> HbckReport.orphanRegionsOnRSMethods in org.apache.hadoop.hbase.master.hbck that return types with arguments of type ServerNameModifier 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
Fields in org.apache.hadoop.hbase.master.http declared as ServerNameModifier and TypeFieldDescriptionprivate final ServerNameRegionReplicaInfo.serverNameprivate final ServerNameRegionVisualizer.RegionDetails.serverNameprivate final ServerNameRegionReplicaInfo.targetServerNameMethods in org.apache.hadoop.hbase.master.http that return ServerNameModifier and TypeMethodDescriptionprivate ServerNameMasterStatusServlet.getMetaLocationOrNull(HMaster master) RegionReplicaInfo.getServerName()RegionVisualizer.RegionDetails.getServerName()RegionReplicaInfo.getTargetServerName()Constructors in org.apache.hadoop.hbase.master.http with parameters of type ServerNameModifierConstructorDescription(package private)RegionDetails(ServerName serverName, TableName tableName, RegionMetrics regionMetrics) -
Uses of ServerName in org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.model
Fields in org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.model declared as ServerNameFields in org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.model with type parameters of type ServerNameMethods in org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.model that return ServerNameMethods in org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.model that return types with arguments of type ServerNameConstructors in org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.model with parameters of type ServerNameModifierConstructorDescriptionprivateClusterMetrics(String hbaseVersion, String clusterId, ServerName masterName, List<ServerName> backupMasterNames) Constructor parameters in org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.model with type arguments of type ServerNameModifierConstructorDescriptionprivateClusterMetrics(String hbaseVersion, String clusterId, ServerName masterName, List<ServerName> backupMasterNames) -
Uses of ServerName in org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.resource
Methods in org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.resource that return types with arguments of type ServerName -
Uses of ServerName in org.apache.hadoop.hbase.master.http.hbck.resource
Methods in org.apache.hadoop.hbase.master.http.hbck.resource with parameters of type ServerName -
Uses of ServerName in org.apache.hadoop.hbase.master.janitor
Fields in org.apache.hadoop.hbase.master.janitor with type parameters of type ServerNameModifier and TypeFieldDescription(package private) final List<Pair<RegionInfo,ServerName>> CatalogJanitorReport.unknownServersTODO: If CatalogJanitor finds an 'Unknown Server', it should 'fix' it by queuing aHBCKServerCrashProcedurefor found server for it to clean up meta.Methods in org.apache.hadoop.hbase.master.janitor that return types with arguments of type ServerName -
Uses of ServerName in org.apache.hadoop.hbase.master.procedure
Fields in org.apache.hadoop.hbase.master.procedure declared as ServerNameModifier and TypeFieldDescriptionprivate ServerNameSplitWALProcedure.crashedServerprivate ServerNameSplitWALRemoteProcedure.crashedServerprivate final ServerNameRSProcedureDispatcher.RegionCloseOperation.destinationServerprivate ServerNameRecoverMetaProcedure.failedMetaServerDeprecated.private final ServerNameRSProcedureDispatcher.ExecuteProceduresRemoteCall.serverNameprivate final ServerNameServerCrashException.serverNameprivate ServerNameServerCrashProcedure.serverNameName of the crashed server to process.private ServerNameSwitchRpcThrottleProcedure.serverNameprotected ServerNameServerRemoteProcedure.targetServerprivate final ServerNameHBCKServerCrashProcedure.UnknownServerVisitor.unknownServerNameprivate ServerNameSplitWALProcedure.workerFields in org.apache.hadoop.hbase.master.procedure with type parameters of type ServerNameModifier and TypeFieldDescriptionprivate final Map<ServerName,LockAndQueue> SchemaLocking.serverLocksprivate final FairQueue<ServerName>MasterProcedureScheduler.serverRunQueueMethods in org.apache.hadoop.hbase.master.procedure that return ServerNameModifier and TypeMethodDescriptionRSProcedureDispatcher.RegionCloseOperation.getDestinationServer()private static ServerNameMasterProcedureScheduler.getServerName(Procedure<?> proc) protected final ServerNameRSProcedureDispatcher.ExecuteProceduresRemoteCall.getServerName()ServerCrashProcedure.getServerName()ServerProcedureInterface.getServerName()Returns Name of this server instance.SnapshotVerifyProcedure.getServerName()SplitWALProcedure.getServerName()SplitWALRemoteProcedure.getServerName()SwitchRpcThrottleProcedure.getServerName()SwitchRpcThrottleRemoteProcedure.getServerName()SplitWALProcedure.getWorker()Methods in org.apache.hadoop.hbase.master.procedure with parameters of type ServerNameModifier and TypeMethodDescriptionprotected voidRSProcedureDispatcher.abortPendingOperations(ServerName serverName, Set<RemoteProcedureDispatcher.RemoteProcedure> operations) org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.CloseRegionRequestRSProcedureDispatcher.RegionCloseOperation.buildCloseRegionRequest(ServerName serverName) private static org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.OpenRegionRequestRSProcedureDispatcher.buildOpenRegionRequest(MasterProcedureEnv env, ServerName serverName, List<RSProcedureDispatcher.RegionOpenOperation> operations) (package private) LockAndQueueSchemaLocking.getServerLock(ServerName serverName) private ServerQueueMasterProcedureScheduler.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) voidFlushRegionProcedure.remoteCallFailed(MasterProcedureEnv env, ServerName serverName, IOException e) voidServerRemoteProcedure.remoteCallFailed(MasterProcedureEnv env, ServerName serverName, IOException exception) voidSnapshotRegionProcedure.remoteCallFailed(MasterProcedureEnv env, ServerName serverName, IOException e) protected voidRSProcedureDispatcher.remoteDispatch(ServerName serverName, Set<RemoteProcedureDispatcher.RemoteProcedure> remoteProcedures) (package private) LockAndQueueSchemaLocking.removeServerLock(ServerName serverName) private voidMasterProcedureScheduler.removeServerQueue(ServerName serverName) protected org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ExecuteProceduresResponseRSProcedureDispatcher.ExecuteProceduresRemoteCall.sendRequest(ServerName serverName, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.ExecuteProceduresRequest request) voidRSProcedureDispatcher.serverAdded(ServerName serverName) voidRSProcedureDispatcher.serverRemoved(ServerName serverName) voidRSProcedureDispatcher.splitAndResolveOperation(ServerName serverName, Set<RemoteProcedureDispatcher.RemoteProcedure> operations, RSProcedureDispatcher.RemoteProcedureResolver resolver) FetchesRemoteProcedureDispatcher.RemoteOperations from the givenremoteProceduresand groups them by class of the returned operation.private voidMasterProcedureScheduler.tryCleanupServerQueue(ServerName serverName, Procedure<?> proc) booleanMasterProcedureScheduler.waitServerExclusiveLock(Procedure<?> procedure, ServerName serverName) Try to acquire the exclusive lock on the specified server.voidMasterProcedureScheduler.wakeServerExclusiveLock(Procedure<?> procedure, ServerName serverName) Wake the procedures waiting for the specified serverConstructors in org.apache.hadoop.hbase.master.procedure with parameters of type ServerNameModifierConstructorDescriptionDeadRSRemoteCall(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) privateUnknownServerVisitor(Connection connection, ServerName unknownServerName) -
Uses of ServerName in org.apache.hadoop.hbase.master.replication
Fields in org.apache.hadoop.hbase.master.replication declared as ServerNameModifier and TypeFieldDescriptionprivate ServerNameClaimReplicationQueueRemoteProcedure.crashedServerprivate ServerNameClaimReplicationQueuesProcedure.crashedServerMethods in org.apache.hadoop.hbase.master.replication that return ServerNameModifier and TypeMethodDescriptionClaimReplicationQueueRemoteProcedure.getServerName()ClaimReplicationQueuesProcedure.getServerName()Methods in org.apache.hadoop.hbase.master.replication with parameters of type ServerNameModifier and TypeMethodDescriptionClaimReplicationQueueRemoteProcedure.remoteCallBuild(MasterProcedureEnv env, ServerName remote) RefreshPeerProcedure.remoteCallBuild(MasterProcedureEnv env, ServerName remote) Constructors in org.apache.hadoop.hbase.master.replication with parameters of type ServerNameModifierConstructorDescriptionClaimReplicationQueueRemoteProcedure(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
Methods in org.apache.hadoop.hbase.master.snapshot that return ServerNameModifier and TypeMethodDescriptionSnapshotManager.acquireSnapshotVerifyWorker(SnapshotVerifyProcedure procedure) Methods in org.apache.hadoop.hbase.master.snapshot with parameters of type ServerNameModifier and TypeMethodDescriptionSnapshotManager.getAvailableWorker(ServerName serverName) voidSnapshotManager.releaseSnapshotVerifyWorker(SnapshotVerifyProcedure procedure, ServerName worker, MasterProcedureScheduler scheduler) Method parameters in org.apache.hadoop.hbase.master.snapshot with type arguments of type ServerNameModifier and TypeMethodDescriptionvoidDisabledTableSnapshotHandler.snapshotRegions(List<Pair<RegionInfo, ServerName>> regionsAndLocations) protected voidEnabledTableSnapshotHandler.snapshotRegions(List<Pair<RegionInfo, ServerName>> regions) This method kicks off a snapshot procedure.protected abstract voidTakeSnapshotHandler.snapshotRegions(List<Pair<RegionInfo, ServerName>> regions) Snapshot the specified regions -
Uses of ServerName in org.apache.hadoop.hbase.regionserver
Fields in org.apache.hadoop.hbase.regionserver declared as ServerNameModifier and TypeFieldDescriptionprivate final ServerNameHRegionServer.MovedRegionInfo.serverNameprotected ServerNameHRegionServer.serverNameThe server name the Master sees us as.Fields in org.apache.hadoop.hbase.regionserver with type parameters of type ServerNameMethods in org.apache.hadoop.hbase.regionserver that return ServerNameModifier and TypeMethodDescriptionprivate ServerNameHRegionServer.createRegionServerStatusStub()Get the current master from ZooKeeper and open the RPC connection to it.protected ServerNameHRegionServer.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()Methods in org.apache.hadoop.hbase.regionserver that return types with arguments of type ServerNameModifier and TypeMethodDescriptionHRegionServer.getActiveMaster()HRegionServer.getBackupMasters()BootstrapNodeManager.getBootstrapNodes()HRegionServer.getBootstrapNodes()Methods in org.apache.hadoop.hbase.regionserver with parameters of type ServerNameModifier and TypeMethodDescriptionprivate voidHRegionServer.addToMovedRegions(String encodedName, ServerName destination, long closeSeqNum, boolean selfMove) protected booleanHRegionServer.closeRegion(String encodedName, boolean abort, ServerName destination) Close asynchronously a region, can be called from the master or internally by the regionserver when stopping.booleanHRegionServer.removeRegion(HRegion r, ServerName destination) booleanMutableOnlineRegions.removeRegion(HRegion r, ServerName destination) Removes the given Region from the list of onlineRegions.Constructors in org.apache.hadoop.hbase.regionserver with parameters of type ServerNameModifierConstructorDescription(package private)MovedRegionInfo(ServerName serverName, long closeSeqNum) ScannerIdGenerator(ServerName serverName) -
Uses of ServerName in org.apache.hadoop.hbase.regionserver.handler
Fields in org.apache.hadoop.hbase.regionserver.handler declared as ServerNameModifier and TypeFieldDescriptionprivate ServerNameCloseRegionHandler.destinationprivate final ServerNameUnassignRegionHandler.destinationprivate final ServerNameWALSplitterHandler.serverNameDeprecated.Methods in org.apache.hadoop.hbase.regionserver.handler with parameters of type ServerNameModifier and TypeMethodDescriptionstatic UnassignRegionHandlerUnassignRegionHandler.create(HRegionServer server, String encodedName, long closeProcId, boolean abort, ServerName destination, boolean evictCache) Constructors in org.apache.hadoop.hbase.regionserver.handler with parameters of type ServerNameModifierConstructorDescriptionprotectedCloseRegionHandler(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
Constructors in org.apache.hadoop.hbase.regionserver.wal with parameters of type ServerNameModifierConstructorDescriptionWALEventTrackerListener(org.apache.hadoop.conf.Configuration conf, NamedQueueRecorder namedQueueRecorder, ServerName serverName) -
Uses of ServerName in org.apache.hadoop.hbase.replication
Fields in org.apache.hadoop.hbase.replication with type parameters of type ServerNameModifier and TypeFieldDescriptionprivate List<ServerName>ReplicationQueueInfo.deadRegionServersprivate List<ServerName>HBaseReplicationEndpoint.regionServersMethods in org.apache.hadoop.hbase.replication that return types with arguments of type ServerNameModifier 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.Methods in org.apache.hadoop.hbase.replication with parameters of type ServerNameModifier and TypeMethodDescriptionvoidReplicationQueueStorage.addWAL(ServerName serverName, String queueId, String fileName) Add a new WAL file to the given queue for a given regionserver.voidZKReplicationQueueStorage.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 StringZKReplicationQueueStorage.getFileNode(ServerName serverName, String queueId, String fileName) private StringZKReplicationQueueStorage.getQueueNode(ServerName serverName, String queueId) ReplicationQueueStorage.getRsNode(ServerName serverName) Get full znode name for given region serverZKReplicationQueueStorage.getRsNode(ServerName serverName) longReplicationQueueStorage.getWALPosition(ServerName serverName, String queueId, String fileName) Get the current position for a specific WAL in a given queue for a given regionserver.longZKReplicationQueueStorage.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) voidReplicationListener.regionServerRemoved(ServerName regionServer) A region server has been removed from the local clustervoidReplicationQueueStorage.removeQueue(ServerName serverName, String queueId) Remove a replication queue for a given regionserver.voidZKReplicationQueueStorage.removeQueue(ServerName serverName, String queueId) voidReplicationQueueStorage.removeReplicatorIfQueueIsEmpty(ServerName serverName) Remove the record of region server if the queue is empty.voidZKReplicationQueueStorage.removeReplicatorIfQueueIsEmpty(ServerName serverName) voidReplicationQueueStorage.removeWAL(ServerName serverName, String queueId, String fileName) Remove an WAL file from the given queue for a given regionserver.voidZKReplicationQueueStorage.removeWAL(ServerName serverName, String queueId, String fileName) voidReplicationQueueStorage.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.voidZKReplicationQueueStorage.setWALPosition(ServerName serverName, String queueId, String fileName, long position, Map<String, Long> lastSeqIds) Method parameters in org.apache.hadoop.hbase.replication with type arguments of type ServerNameModifier and TypeMethodDescriptionprivate static voidReplicationQueueInfo.extractDeadServersFromZNodeString(String deadServerListStr, List<ServerName> result) Parse dead server names from queue id.voidHBaseReplicationEndpoint.setRegionServers(List<ServerName> regionServers) Set the list of region servers for that peer -
Uses of ServerName in org.apache.hadoop.hbase.replication.regionserver
Fields in org.apache.hadoop.hbase.replication.regionserver declared as ServerNameModifier and TypeFieldDescriptionprivate ServerNameClaimReplicationQueueCallable.crashedServerprivate ServerNameReplicationSinkManager.SinkPeer.serverNameFields in org.apache.hadoop.hbase.replication.regionserver with type parameters of type ServerNameModifier and TypeFieldDescriptionprivate final Map<ServerName,Integer> ReplicationSinkManager.badReportCountsprivate List<ServerName>ReplicationSinkManager.sinksMethods in org.apache.hadoop.hbase.replication.regionserver that return ServerNameModifier and TypeMethodDescription(package private) ServerNameReplicationSinkManager.SinkPeer.getServerName()ReplicationSyncUp.DummyServer.getServerName()RecoveredReplicationSource.getServerWALsBelongTo()ReplicationSource.getServerWALsBelongTo()ReplicationSourceInterface.getServerWALsBelongTo()The queue of WALs only belong to one region server.Methods in org.apache.hadoop.hbase.replication.regionserver that return types with arguments of type ServerNameModifier and TypeMethodDescriptionNoopReplicationQueueStorage.getListOfReplicators()private Set<ServerName>ReplicationSyncUp.getLiveRegionServers(ZKWatcher zkw) protected List<ServerName>ReplicationSinkManager.getSinksForTesting()Methods in org.apache.hadoop.hbase.replication.regionserver with parameters of type ServerNameModifier and TypeMethodDescriptionvoidNoopReplicationQueueStorage.addWAL(ServerName serverName, String queueId, String fileName) NoopReplicationQueueStorage.claimQueue(ServerName sourceServerName, String queueId, ServerName destServerName) (package private) voidReplicationSourceManager.claimQueue(ServerName deadRS, String queue) voidPeerProcedureHandler.claimReplicationQueue(ServerName crashedServer, String queue) voidPeerProcedureHandlerImpl.claimReplicationQueue(ServerName crashedServer, String queue) private StringDumpReplicationQueues.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 longDumpReplicationQueues.getTotalWALSize(org.apache.hadoop.fs.FileSystem fs, List<String> wals, ServerName server) return total size in bytes from a list of WALslongNoopReplicationQueueStorage.getWALPosition(ServerName serverName, String queueId, String fileName) NoopReplicationQueueStorage.getWALsInQueue(ServerName serverName, String queueId) voidNoopReplicationQueueStorage.removeQueue(ServerName serverName, String queueId) voidNoopReplicationQueueStorage.removeReplicatorIfQueueIsEmpty(ServerName serverName) voidNoopReplicationQueueStorage.removeWAL(ServerName serverName, String queueId, String fileName) voidNoopReplicationQueueStorage.setWALPosition(ServerName serverName, String queueId, String fileName, long position, Map<String, Long> lastSeqIds) Constructors in org.apache.hadoop.hbase.replication.regionserver with parameters of type ServerNameModifierConstructorDescriptionSinkPeer(ServerName serverName, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface regionServer) -
Uses of ServerName in org.apache.hadoop.hbase.rest
Fields in org.apache.hadoop.hbase.rest declared as ServerNameMethods in org.apache.hadoop.hbase.rest that return ServerName -
Uses of ServerName in org.apache.hadoop.hbase.rsgroup
Methods in org.apache.hadoop.hbase.rsgroup that return ServerNameModifier and TypeMethodDescriptionRSGroupBasedLoadBalancer.randomAssignment(RegionInfo region, List<ServerName> servers) Methods in org.apache.hadoop.hbase.rsgroup that return types with arguments of type ServerNameModifier 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) Methods in org.apache.hadoop.hbase.rsgroup with parameters of type ServerNameModifier and TypeMethodDescriptionvoidRSGroupBasedLoadBalancer.regionOnline(RegionInfo regionInfo, ServerName sn) voidRSGroupInfoManagerImpl.ServerEventsListenerThread.serverAdded(ServerName serverName) voidRSGroupInfoManagerImpl.ServerEventsListenerThread.serverRemoved(ServerName serverName) Method parameters in org.apache.hadoop.hbase.rsgroup with type arguments of type ServerNameModifier 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) voidRSGroupAdminEndpoint.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) voidRSGroupBasedLoadBalancer.updateBalancerLoadInfo(Map<TableName, Map<ServerName, List<RegionInfo>>> loadOfAllTable) -
Uses of ServerName in org.apache.hadoop.hbase.security.access
Methods in org.apache.hadoop.hbase.security.access with parameters of type ServerNameModifier and TypeMethodDescriptionvoidAccessController.preMove(ObserverContext<MasterCoprocessorEnvironment> c, RegionInfo region, ServerName srcServer, ServerName destServer) voidAccessController.preRecommissionRegionServer(ObserverContext<MasterCoprocessorEnvironment> ctx, ServerName server, List<byte[]> encodedRegionNames) Method parameters in org.apache.hadoop.hbase.security.access with type arguments of type ServerNameModifier and TypeMethodDescriptionvoidAccessController.preDecommissionRegionServers(ObserverContext<MasterCoprocessorEnvironment> ctx, List<ServerName> servers, boolean offload) -
Uses of ServerName in org.apache.hadoop.hbase.testing
Methods in org.apache.hadoop.hbase.testing that return types with arguments of type ServerNameModifier 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()Methods in org.apache.hadoop.hbase.testing with parameters of type ServerNameModifier and TypeMethodDescriptionprivate intTestingHBaseClusterImpl.getMasterIndex(ServerName serverName) TestingHBaseCluster.getOnlineRegionsInterface(ServerName serverName) Get the server sideOnlineRegionsinterface for the specific region server.TestingHBaseClusterImpl.getOnlineRegionsInterface(ServerName serverName) private intTestingHBaseClusterImpl.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
Methods in org.apache.hadoop.hbase.thrift2 that return types with arguments of type ServerNameModifier and TypeMethodDescriptionstatic Set<ServerName>ThriftUtilities.getServerNamesFromThrift(Set<org.apache.hadoop.hbase.thrift2.generated.TServerName> tServerNames) Method parameters in org.apache.hadoop.hbase.thrift2 with type arguments of type ServerNameModifier 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
Methods in org.apache.hadoop.hbase.thrift2.client that return types with arguments of type ServerNameModifier and TypeMethodDescriptionThriftAdmin.clearDeadServers(List<ServerName> servers) ThriftAdmin.compactionSwitch(boolean switchState, List<String> serverNamesList) ThriftAdmin.listDecommissionedRegionServers()Methods in org.apache.hadoop.hbase.thrift2.client with parameters of type ServerNameModifier and TypeMethodDescriptionvoidThriftAdmin.clearCompactionQueues(ServerName serverName, Set<String> queues) voidThriftAdmin.closeRegion(ServerName sn, HRegionInfo hri) voidThriftAdmin.compactRegionServer(ServerName serverName) ThriftAdmin.coprocessorService(ServerName serverName) voidThriftAdmin.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) voidThriftAdmin.majorCompactRegionServer(ServerName serverName) voidThriftAdmin.move(byte[] encodedRegionName, ServerName destServerName) voidThriftAdmin.recommissionRegionServer(ServerName server, List<byte[]> encodedRegionNames) voidThriftAdmin.rollWALWriter(ServerName serverName) voidThriftAdmin.updateConfiguration(ServerName server) Method parameters in org.apache.hadoop.hbase.thrift2.client with type arguments of type ServerNameModifier and TypeMethodDescriptionThriftAdmin.clearDeadServers(List<ServerName> servers) ThriftAdmin.clearSlowLogResponses(Set<ServerName> serverNames) voidThriftAdmin.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
Fields in org.apache.hadoop.hbase.tool declared as ServerNameModifier and TypeFieldDescriptionprivate ServerNameCanaryTool.RegionTask.serverNameprivate ServerNameCanaryTool.RegionTaskResult.serverNameFields in org.apache.hadoop.hbase.tool with type parameters of type ServerNameModifier and TypeFieldDescriptionprivate ConcurrentMap<ServerName,LongAdder> CanaryTool.RegionStdOutSink.perServerFailuresCountMethods in org.apache.hadoop.hbase.tool that return ServerNameMethods in org.apache.hadoop.hbase.tool that return types with arguments of type ServerNameMethods in org.apache.hadoop.hbase.tool with parameters of type ServerNameModifier and TypeMethodDescriptionprivate voidCanaryTool.RegionStdOutSink.incFailuresCountDetails(ServerName serverName, RegionInfo region) voidCanaryTool.RegionStdOutSink.publishReadFailure(ServerName serverName, RegionInfo region, Exception e) voidCanaryTool.RegionStdOutSink.publishReadFailure(ServerName serverName, RegionInfo region, ColumnFamilyDescriptor column, Exception e) voidCanaryTool.RegionStdOutSink.publishReadTiming(ServerName serverName, RegionInfo region, ColumnFamilyDescriptor column, long msTime) voidCanaryTool.RegionStdOutSink.publishWriteFailure(ServerName serverName, RegionInfo region, Exception e) voidCanaryTool.RegionStdOutSink.publishWriteFailure(ServerName serverName, RegionInfo region, ColumnFamilyDescriptor column, Exception e) voidCanaryTool.RegionStdOutSink.publishWriteTiming(ServerName serverName, RegionInfo region, ColumnFamilyDescriptor column, long msTime) Constructors in org.apache.hadoop.hbase.tool with parameters of type ServerNameModifierConstructorDescription(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
Fields in org.apache.hadoop.hbase.util declared as ServerNameModifier and TypeFieldDescription(package private) ServerNameHbckRegionInfo.MetaEntry.regionServerprivate final ServerNameHBaseFsck.WorkItemRegion.rsinfoprivate ServerNameHbckRegionInfo.OnlineEntry.serverNameprivate final ServerNameMoveWithAck.sourceServerprivate final ServerNameMoveWithoutAck.sourceServerprivate final ServerNameMoveWithAck.targetServerprivate final ServerNameMoveWithoutAck.targetServerFields in org.apache.hadoop.hbase.util with type parameters of type ServerNameModifier and TypeFieldDescriptionprivate List<ServerName>HbckRegionInfo.deployedOn(package private) TreeSet<ServerName>HbckTableInfo.deployedOnMethods in org.apache.hadoop.hbase.util that return ServerNameModifier and TypeMethodDescriptionHbckRegionInfo.MetaEntry.getRegionServer()HbckRegionInfo.OnlineEntry.getServerName()(package private) static ServerNameMoveWithAck.getServerNameForRegion(RegionInfo region, Admin admin, Connection conn) Get servername that is up in hbase:meta hosting the given region.private ServerNameRegionMover.getTargetServer()private ServerNameRegionMover.stripServer(List<ServerName> regionServers, String hostname, int port) Remove the servername whose hostname and port portion matches from the passed array of servers.Methods in org.apache.hadoop.hbase.util that return types with arguments of type ServerNameMethods in org.apache.hadoop.hbase.util with parameters of type ServerNameModifier and TypeMethodDescriptionvoidHbckRegionInfo.addServer(RegionInfo regionInfo, ServerName serverName) voidHbckTableInfo.addServer(ServerName server) static voidHBaseFsckRepair.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 booleanMoveWithAck.isSameServer(RegionInfo region, ServerName serverName) Returns true if passed region is still on serverName when we look at hbase:meta.private voidRegionMover.submitRegionMovesWhileUnloading(ServerName server, List<ServerName> regionServers, List<RegionInfo> movedRegions, List<RegionInfo> regionsToMove, boolean forceMoveRegionByAck) private voidRegionMover.unloadRegions(ServerName server, List<ServerName> regionServers, List<RegionInfo> movedRegions, List<String> isolateRegionIdArray) Method parameters in org.apache.hadoop.hbase.util with type arguments of type ServerNameModifier and TypeMethodDescriptionstatic voidHBaseFsckRepair.fixMetaHoleOnlineAndAddReplicas(org.apache.hadoop.conf.Configuration conf, RegionInfo hri, Collection<ServerName> servers, int numReplicas) Puts the specified RegionInfo into META with replica related columnsstatic voidHBaseFsckRepair.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 voidRegionMover.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) voidHBaseFsck.processRegionServers(Collection<ServerName> regionServerList) Deprecated.Contacts each regionserver and fetches metadata about regions.private voidRegionMover.stripMaster(List<ServerName> regionServers) Exclude master from list of RSs to move regions toprivate ServerNameRegionMover.stripServer(List<ServerName> regionServers, String hostname, int port) Remove the servername whose hostname and port portion matches from the passed array of servers.private voidRegionMover.submitRegionMovesWhileUnloading(ServerName server, List<ServerName> regionServers, List<RegionInfo> movedRegions, List<RegionInfo> regionsToMove, boolean forceMoveRegionByAck) private voidRegionMover.unloadRegions(ServerName server, List<ServerName> regionServers, List<RegionInfo> movedRegions, List<String> isolateRegionIdArray) Constructors in org.apache.hadoop.hbase.util with parameters of type ServerNameModifierConstructorDescriptionMetaEntry(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
Fields in org.apache.hadoop.hbase.util.compaction declared as ServerNameFields in org.apache.hadoop.hbase.util.compaction with type parameters of type ServerNameModifier and TypeFieldDescriptionprivate final Set<ServerName>ClusterCompactionQueues.compactingServersprivate final Map<ServerName,List<MajorCompactionRequest>> ClusterCompactionQueues.compactionQueuesMethods in org.apache.hadoop.hbase.util.compaction that return types with arguments of type ServerNameModifier and TypeMethodDescription(package private) Optional<ServerName>ClusterCompactionQueues.getLargestQueueFromServersNotCompacting()private Map<ServerName,List<RegionInfo>> MajorCompactor.getServerRegionsMap()private Collection<ServerName>MajorCompactor.getServersToCompact(Set<ServerName> snSet) Methods in org.apache.hadoop.hbase.util.compaction with parameters of type ServerNameModifier and TypeMethodDescription(package private) voidClusterCompactionQueues.addToCompactionQueue(ServerName serverName, MajorCompactionRequest info) (package private) List<MajorCompactionRequest>ClusterCompactionQueues.getQueue(ServerName serverName) (package private) voidClusterCompactionQueues.releaseCompaction(ServerName serverName) (package private) MajorCompactionRequestClusterCompactionQueues.reserveForCompaction(ServerName serverName) Method parameters in org.apache.hadoop.hbase.util.compaction with type arguments of type ServerNameModifier and TypeMethodDescriptionprivate Collection<ServerName>MajorCompactor.getServersToCompact(Set<ServerName> snSet) Constructors in org.apache.hadoop.hbase.util.compaction with parameters of type ServerNameModifierConstructorDescription(package private)Compact(ServerName serverName, MajorCompactionRequest request) -
Uses of ServerName in org.apache.hadoop.hbase.util.hbck
Fields in org.apache.hadoop.hbase.util.hbck with type parameters of type ServerNameModifier and TypeFieldDescriptionprivate Map<ServerName,List<String>> ReplicationChecker.undeletedQueueIdsMethods in org.apache.hadoop.hbase.util.hbck that return types with arguments of type ServerNameModifier and TypeMethodDescriptionprivate Map<ServerName,List<String>> ReplicationChecker.getUnDeletedQueues() -
Uses of ServerName in org.apache.hadoop.hbase.wal
Methods in org.apache.hadoop.hbase.wal that return ServerNameModifier and TypeMethodDescriptionstatic ServerNameAbstractFSWALProvider.getServerNameFromWALDirectoryName(org.apache.hadoop.conf.Configuration conf, String path) Pulls a ServerName out of a Path generated according to our layout rules.static ServerNameAbstractFSWALProvider.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
Fields in org.apache.hadoop.hbase.zookeeper with type parameters of type ServerNameMethods in org.apache.hadoop.hbase.zookeeper that return ServerNameModifier and TypeMethodDescriptionprivate static ServerNameMetaTableLocator.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 ServerNameMasterAddressTracker.getMasterAddress(ZKWatcher zkw) Get master address.static ServerNameMetaTableLocator.getMetaRegionLocation(ZKWatcher zkw) Gets the meta region location, if available.static ServerNameMetaTableLocator.getMetaRegionLocation(ZKWatcher zkw, int replicaId) Gets the meta region location, if available.static ServerName[]ZKServerTool.readZKNodes(org.apache.hadoop.conf.Configuration conf) private static ServerNameMetaTableLocator.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 ServerNameMetaTableLocator.waitMetaRegionLocation(ZKWatcher zkw, long timeout) Gets the meta region location, if available, and waits for up to the specified timeout if not immediately available.Methods in org.apache.hadoop.hbase.zookeeper that return types with arguments of type ServerNameModifier 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.Methods in org.apache.hadoop.hbase.zookeeper with parameters of type ServerNameModifier and TypeMethodDescriptionintMasterAddressTracker.getBackupMasterInfoPort(ServerName sn) Get the info port of the backup master if it is available.static intMasterAddressTracker.getBackupMasterInfoPort(ZKWatcher zkw, ServerName sn) Get backup master info port.ZNodePaths.getRsPath(ServerName sn) static booleanMasterAddressTracker.setMasterAddress(ZKWatcher zkw, String znode, ServerName master, int infoPort) Set master address into themasterznode or into the backup subdirectory of backup masters; switch off the passed inznodepath.static voidMetaTableLocator.setMetaLocation(ZKWatcher zookeeper, ServerName serverName, int replicaId, RegionState.State state) Sets the location ofhbase:metain ZooKeeper to the specified server address.static voidMetaTableLocator.setMetaLocation(ZKWatcher zookeeper, ServerName serverName, RegionState.State state) Sets the location ofhbase:metain ZooKeeper to the specified server address.(package private) static byte[]MasterAddressTracker.toByteArray(ServerName sn, int infoPort)
ClusterStatus.getMasterName()instead.