Uses of Class
org.apache.hadoop.hbase.net.Address
Package
Description
Provides HBase Client
Table of Contents
Tools to help define network clients and servers.
-
Uses of Address in org.apache.hadoop.hbase
-
Uses of Address in org.apache.hadoop.hbase.backup.master
Modifier and TypeMethodDescriptionBackupLogCleaner.serverToPreservationBoundaryTs
(List<BackupInfo> backups) Calculates the timestamp boundary up to which all backup roots have already included the WAL.Modifier and TypeMethodDescriptionprotected static boolean
BackupLogCleaner.canDeleteFile
(Map<Address, Long> addressToBoundaryTs, org.apache.hadoop.fs.Path path) -
Uses of Address in org.apache.hadoop.hbase.client
Modifier and TypeMethodDescriptionAdmin.getRSGroup
(Address hostPort) Get group info for the given hostPortAdminOverAsyncAdmin.getRSGroup
(Address hostPort) AsyncAdmin.getRSGroup
(Address hostPort) Get group info for the given hostPortAsyncHBaseAdmin.getRSGroup
(Address hostPort) RawAsyncHBaseAdmin.getRSGroup
(Address hostPort) Modifier and TypeMethodDescriptionvoid
Admin.moveServersToRSGroup
(Set<Address> servers, String targetGroup) Move given set of servers to the specified target RegionServer groupvoid
AdminOverAsyncAdmin.moveServersToRSGroup
(Set<Address> servers, String groupName) AsyncAdmin.moveServersToRSGroup
(Set<Address> servers, String groupName) Move given set of servers to the specified target RegionServer groupAsyncHBaseAdmin.moveServersToRSGroup
(Set<Address> servers, String groupName) RawAsyncHBaseAdmin.moveServersToRSGroup
(Set<Address> servers, String groupName) void
Admin.removeServersFromRSGroup
(Set<Address> servers) Remove decommissioned servers from group 1.void
AdminOverAsyncAdmin.removeServersFromRSGroup
(Set<Address> servers) AsyncAdmin.removeServersFromRSGroup
(Set<Address> servers) Remove decommissioned servers from group 1.AsyncHBaseAdmin.removeServersFromRSGroup
(Set<Address> servers) RawAsyncHBaseAdmin.removeServersFromRSGroup
(Set<Address> servers) -
Uses of Address in org.apache.hadoop.hbase.client.trace
-
Uses of Address in org.apache.hadoop.hbase.coprocessor
Modifier and TypeMethodDescriptiondefault void
MasterObserver.postGetRSGroupInfoOfServer
(ObserverContext<MasterCoprocessorEnvironment> ctx, Address server) Called after getting region server group info of the passed server.default void
MasterObserver.preGetRSGroupInfoOfServer
(ObserverContext<MasterCoprocessorEnvironment> ctx, Address server) Called before getting region server group info of the passed server.Modifier and TypeMethodDescriptiondefault void
MasterObserver.postMoveServers
(ObserverContext<MasterCoprocessorEnvironment> ctx, Set<Address> servers, String targetGroup) Called after servers are moved to target region server groupdefault void
MasterObserver.postMoveServersAndTables
(ObserverContext<MasterCoprocessorEnvironment> ctx, Set<Address> servers, Set<TableName> tables, String targetGroup) Called after servers are moved to target region server groupdefault void
MasterObserver.postRemoveServers
(ObserverContext<MasterCoprocessorEnvironment> ctx, Set<Address> servers) Called after servers are removed from rsgroupdefault void
MasterObserver.preMoveServers
(ObserverContext<MasterCoprocessorEnvironment> ctx, Set<Address> servers, String targetGroup) Called before servers are moved to target region server groupdefault void
MasterObserver.preMoveServersAndTables
(ObserverContext<MasterCoprocessorEnvironment> ctx, Set<Address> servers, Set<TableName> tables, String targetGroup) Called before servers are moved to target region server groupdefault void
MasterObserver.preRemoveServers
(ObserverContext<MasterCoprocessorEnvironment> ctx, Set<Address> servers) Called before servers are removed from rsgroup -
Uses of Address in org.apache.hadoop.hbase.ipc
Modifier and TypeFieldDescriptionprotected final Address
AbstractRpcClient.AbstractRpcChannel.addr
(package private) final Address
ConnectionId.address
Modifier and TypeFieldDescriptionprivate static final org.apache.hbase.thirdparty.com.google.common.cache.LoadingCache<Address,
AtomicInteger> AbstractRpcClient.concurrentCounterCache
FailedServers.failedServers
Modifier and TypeMethodDescription(package private) static Address
AbstractRpcClient.createAddr
(ServerName sn) ConnectionId.getAddress()
Modifier and TypeMethodDescriptionvoid
FailedServers.addToFailedServers
(Address address, Throwable throwable) Add an address to the list of the failed servers list.private org.apache.hbase.thirdparty.com.google.protobuf.Message
AbstractRpcClient.callBlockingMethod
(org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md, HBaseRpcController hrc, org.apache.hbase.thirdparty.com.google.protobuf.Message param, org.apache.hbase.thirdparty.com.google.protobuf.Message returnType, User ticket, Address isa) Make a blocking call.private Call
AbstractRpcClient.callMethod
(org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor md, HBaseRpcController hrc, org.apache.hbase.thirdparty.com.google.protobuf.Message param, org.apache.hbase.thirdparty.com.google.protobuf.Message returnType, User ticket, Address addr, org.apache.hbase.thirdparty.com.google.protobuf.RpcCallback<org.apache.hbase.thirdparty.com.google.protobuf.Message> callback) private static String
IPCUtil.getCallTarget
(Address addr, RegionInfo regionInfo) static int
boolean
FailedServers.isFailedServer
(Address address) Check if the server should be considered as bad.private void
AbstractRpcClient.onCallFinished
(Call call, HBaseRpcController hrc, Address addr, org.apache.hbase.thirdparty.com.google.protobuf.RpcCallback<org.apache.hbase.thirdparty.com.google.protobuf.Message> callback) (package private) static IOException
IPCUtil.wrapException
(Address addr, RegionInfo regionInfo, Throwable error) Takes an Exception, the address, and if pertinent, the RegionInfo for the Region we were trying to connect to and returns an IOException with the input exception as the cause.ModifierConstructorDescriptionprotected
AbstractRpcChannel
(AbstractRpcClient<?> rpcClient, Address addr, User ticket, int rpcTimeout) protected
BlockingRpcChannelImplementation
(AbstractRpcClient<?> rpcClient, Address addr, User ticket, int rpcTimeout) ConnectionId
(User ticket, String serviceName, Address address) protected
RpcChannelImplementation
(AbstractRpcClient<?> rpcClient, Address addr, User ticket, int rpcTimeout) ServerTooBusyException
(Address address, long count) -
Uses of Address in org.apache.hadoop.hbase.master
Modifier and TypeMethodDescriptionvoid
MasterCoprocessorHost.postGetRSGroupInfoOfServer
(Address server) void
MasterCoprocessorHost.preGetRSGroupInfoOfServer
(Address server) Modifier and TypeMethodDescriptionvoid
MasterCoprocessorHost.postMoveServers
(Set<Address> servers, String targetGroup) void
MasterCoprocessorHost.postMoveServersAndTables
(Set<Address> servers, Set<TableName> tables, String targetGroup) void
MasterCoprocessorHost.postRemoveServers
(Set<Address> servers) void
MasterCoprocessorHost.preMoveServers
(Set<Address> servers, String targetGroup) void
MasterCoprocessorHost.preMoveServersAndTables
(Set<Address> servers, Set<TableName> tables, String targetGroup) void
MasterCoprocessorHost.preRemoveServers
(Set<Address> servers) -
Uses of Address in org.apache.hadoop.hbase.master.balancer
-
Uses of Address in org.apache.hadoop.hbase.net
Modifier and TypeMethodDescriptionstatic Address
static Address
Address.fromSocketAddress
(InetSocketAddress addr) static Address
Address.fromString
(String hostnameAndPort) Modifier and TypeMethodDescriptionint
static InetSocketAddress
Address.toSocketAddress
(Address addr) static InetSocketAddress[]
Address.toSocketAddress
(Address[] addrs) -
Uses of Address in org.apache.hadoop.hbase.rsgroup
Modifier and TypeMethodDescriptionRSGroupInfoManagerImpl.getDefaultServers()
RSGroupInfoManagerImpl.getDefaultServers
(List<RSGroupInfo> rsGroupInfoList) DisabledRSGroupInfoManager.getOnlineServers()
RSGroupInfoManagerImpl.getOnlineServers()
Returns Set of online Servers named for their hostname and port (not ServerName).RSGroupInfo.getServers()
Get list of servers.RSGroupInfoManagerImpl.moveServers
(Set<Address> servers, String srcGroup, String dstGroup) Modifier and TypeMethodDescriptionvoid
Adds the given server to the group.boolean
RSGroupInfo.containsServer
(Address hostPort) Returns true if a server with hostPort is foundprivate List<RegionInfo>
RSGroupInfoManagerImpl.getRegions
(Address server) Returns List of Regions associated with thisserver
.DisabledRSGroupInfoManager.getRSGroupOfServer
(Address serverHostPort) RSGroupAdminClient.getRSGroupOfServer
(Address hostPort) Deprecated.Retrieve the RSGroupInfo a server is affiliated toRSGroupInfoManager.getRSGroupOfServer
(Address serverHostPort) Gets the group info of server.RSGroupInfoManagerImpl.getRSGroupOfServer
(Address serverHostPort) boolean
RSGroupInfo.removeServer
(Address hostPort) Remove given server from the group.Modifier and TypeMethodDescriptionvoid
RSGroupInfo.addAllServers
(Collection<Address> hostPort) Adds the given servers to the group.private void
RSGroupInfoManagerImpl.checkForDeadOrOnlineServers
(Set<Address> servers) Check if the set of servers are belong to dead servers list or online servers list.private void
RSGroupInfoManagerImpl.checkOnlineServersOnly
(Set<Address> servers) private List<ServerName>
RSGroupBasedLoadBalancer.filterServers
(Set<Address> servers, List<ServerName> onlineServers) Filter servers based on the online servers.private void
RSGroupInfoManagerImpl.moveServerRegionsFromGroup
(Set<Address> movedServers, Set<Address> srcGrpServers, String targetGroupName, String sourceGroupName) Move every region from servers which are currently located on these servers, but should not be located there.void
DisabledRSGroupInfoManager.moveServers
(Set<Address> servers, String targetGroupName) void
RSGroupAdminClient.moveServers
(Set<Address> servers, String targetGroup) Deprecated.Move given set of servers to the specified target RegionServer group.void
RSGroupInfoManager.moveServers
(Set<Address> servers, String targetGroupName) Move servers to a new group.void
RSGroupInfoManagerImpl.moveServers
(Set<Address> servers, String targetGroupName) RSGroupInfoManagerImpl.moveServers
(Set<Address> servers, String srcGroup, String dstGroup) void
RSGroupAdminClient.moveServersAndTables
(Set<Address> servers, Set<TableName> tables, String targetGroup) Deprecated.Move given set of servers and tables to the specified target RegionServer group.void
DisabledRSGroupInfoManager.removeServers
(Set<Address> servers) void
RSGroupAdminClient.removeServers
(Set<Address> servers) Deprecated.Remove decommissioned servers from rsgroup.void
RSGroupInfoManager.removeServers
(Set<Address> servers) Remove decommissioned servers from rsgroupvoid
RSGroupInfoManagerImpl.removeServers
(Set<Address> servers) ModifierConstructorDescription(package private)
RSGroupInfo
(String name, Set<Address> servers) (package private)
Deprecated.Since 3.0.0, will be removed in 4.0.0. -
Uses of Address in org.apache.hadoop.hbase.security.access
Modifier and TypeMethodDescriptionvoid
AccessController.preGetRSGroupInfoOfServer
(ObserverContext<MasterCoprocessorEnvironment> ctx, Address server) Modifier and TypeMethodDescriptionvoid
AccessController.preMoveServers
(ObserverContext<MasterCoprocessorEnvironment> ctx, Set<Address> servers, String targetGroup) void
AccessController.preMoveServersAndTables
(ObserverContext<MasterCoprocessorEnvironment> ctx, Set<Address> servers, Set<TableName> tables, String targetGroup) void
AccessController.preRemoveServers
(ObserverContext<MasterCoprocessorEnvironment> ctx, Set<Address> servers) -
Uses of Address in org.apache.hadoop.hbase.thrift2.client
Modifier and TypeMethodDescriptionvoid
ThriftAdmin.moveServersToRSGroup
(Set<Address> servers, String targetGroup) void
ThriftAdmin.removeServersFromRSGroup
(Set<Address> servers) -
Uses of Address in org.apache.hadoop.hbase.zookeeper
Modifier and TypeMethodDescriptionMiniZooKeeperCluster.getAddress()
Returns Address for this cluster instance.