Uses of Class
org.apache.hadoop.hbase.ServerName

Packages that use ServerName
org.apache.hadoop.hbase   
org.apache.hadoop.hbase.catalog   
org.apache.hadoop.hbase.client Provides HBase Client 
org.apache.hadoop.hbase.client.backoff   
org.apache.hadoop.hbase.exceptions   
org.apache.hadoop.hbase.ipc   
org.apache.hadoop.hbase.master   
org.apache.hadoop.hbase.protobuf Holds classes generated from protobuf src/main/protobuf definition files. 
org.apache.hadoop.hbase.zookeeper   
 

Uses of ServerName in org.apache.hadoop.hbase
 

Fields in org.apache.hadoop.hbase with type parameters of type ServerName
static List<ServerName> ServerName.EMPTY_SERVER_LIST
           
 

Methods in org.apache.hadoop.hbase that return ServerName
 ServerName ClusterStatus.getMaster()
          Returns detailed information about the current master ServerName.
 ServerName RegionTransition.getServerName()
           
 ServerName HRegionLocation.getServerName()
           
 ServerName Server.getServerName()
           
static ServerName HRegionInfo.getServerName(Result r)
          Returns a ServerName from catalog table Result.
static ServerName ServerName.parseFrom(byte[] data)
          Get a ServerName from the passed in data bytes.
static ServerName ServerName.parseServerName(String str)
           
static ServerName ServerName.parseVersionedServerName(byte[] versionedBytes)
          Use this method instantiating a ServerName from bytes gotten from a call to getVersionedBytes().
static ServerName ServerName.valueOf(String serverName)
          Retrieve an instance of ServerName.
static ServerName ServerName.valueOf(String hostname, int port, long startcode)
          Retrieve an instance of ServerName.
static ServerName ServerName.valueOf(String hostAndPort, long startCode)
          Retrieve an instance of ServerName.
 

Methods in org.apache.hadoop.hbase that return types with arguments of type ServerName
 Collection<ServerName> ClusterStatus.getBackupMasters()
           
 Collection<ServerName> ClusterStatus.getDeadServerNames()
           
static Pair<HRegionInfo,ServerName> HRegionInfo.getHRegionInfoAndServerName(Result r)
          Extract a HRegionInfo and ServerName from catalog table Result.
 Collection<ServerName> ClusterStatus.getServerInfo()
          Deprecated. Use ClusterStatus.getServers()
 Collection<ServerName> ClusterStatus.getServers()
           
 

Methods in org.apache.hadoop.hbase with parameters of type ServerName
 int ServerName.compareTo(ServerName other)
           
static RegionTransition RegionTransition.createRegionTransition(EventType type, byte[] regionName, ServerName sn)
           
static RegionTransition RegionTransition.createRegionTransition(EventType type, byte[] regionName, ServerName sn, byte[] payload)
           
 ServerLoad ClusterStatus.getLoad(ServerName sn)
           
static boolean ServerName.isSameHostnameAndPort(ServerName left, ServerName right)
           
 

Constructors in org.apache.hadoop.hbase with parameters of type ServerName
ClusterStatus(String hbaseVersion, String clusterid, Map<ServerName,ServerLoad> servers, Collection<ServerName> deadServers, ServerName master, Collection<ServerName> backupMasters, Map<String,RegionState> rit, String[] masterCoprocessors, Boolean balancerOn)
           
HRegionLocation(HRegionInfo regionInfo, ServerName serverName)
           
HRegionLocation(HRegionInfo regionInfo, ServerName serverName, long seqNum)
           
 

Constructor parameters in org.apache.hadoop.hbase with type arguments of type ServerName
ClusterStatus(String hbaseVersion, String clusterid, Map<ServerName,ServerLoad> servers, Collection<ServerName> deadServers, ServerName master, Collection<ServerName> backupMasters, Map<String,RegionState> rit, String[] masterCoprocessors, Boolean balancerOn)
           
ClusterStatus(String hbaseVersion, String clusterid, Map<ServerName,ServerLoad> servers, Collection<ServerName> deadServers, ServerName master, Collection<ServerName> backupMasters, Map<String,RegionState> rit, String[] masterCoprocessors, Boolean balancerOn)
           
ClusterStatus(String hbaseVersion, String clusterid, Map<ServerName,ServerLoad> servers, Collection<ServerName> deadServers, ServerName master, Collection<ServerName> backupMasters, Map<String,RegionState> rit, String[] masterCoprocessors, Boolean balancerOn)
           
 

Uses of ServerName in org.apache.hadoop.hbase.catalog
 

Methods in org.apache.hadoop.hbase.catalog that return ServerName
 ServerName CatalogTracker.getMetaLocation()
          Gets the current location for hbase:meta or null if location is not currently available.
 ServerName CatalogTracker.waitForMeta(long timeout)
          Gets the current location for hbase:meta if available and waits for up to the specified timeout if not immediately available.
 

Methods in org.apache.hadoop.hbase.catalog that return types with arguments of type ServerName
static Map<HRegionInfo,ServerName> MetaReader.fullScan(CatalogTracker catalogTracker, Set<TableName> disabledTables)
          Performs a full scan of hbase:meta, skipping regions from any tables in the specified set of disabled tables.
static Map<HRegionInfo,ServerName> MetaReader.fullScan(CatalogTracker catalogTracker, Set<TableName> disabledTables, boolean excludeOfflinedSplitParents)
          Performs a full scan of hbase:meta, skipping regions from any tables in the specified set of disabled tables.
static Pair<HRegionInfo,ServerName> MetaReader.getRegion(CatalogTracker catalogTracker, byte[] regionName)
          Gets the region info and assignment for the specified region.
static List<Pair<HRegionInfo,ServerName>> MetaReader.getTableRegionsAndLocations(CatalogTracker catalogTracker, TableName tableName)
           
static List<Pair<HRegionInfo,ServerName>> MetaReader.getTableRegionsAndLocations(CatalogTracker catalogTracker, TableName tableName, boolean excludeOfflinedSplitParents)
           
 

Methods in org.apache.hadoop.hbase.catalog with parameters of type ServerName
static NavigableMap<HRegionInfo,Result> MetaReader.getServerUserRegions(CatalogTracker catalogTracker, ServerName serverName)
           
 

Uses of ServerName in org.apache.hadoop.hbase.client
 

Methods in org.apache.hadoop.hbase.client that return types with arguments of type ServerName
static NavigableMap<HRegionInfo,ServerName> MetaScanner.allTableRegions(org.apache.hadoop.conf.Configuration conf, HConnection connection, TableName tableName, boolean offlined)
          Lists all of the table regions currently in META.
 NavigableMap<HRegionInfo,ServerName> HTable.getRegionLocations()
          Gets all the regions and their address for this table.
 

Methods in org.apache.hadoop.hbase.client with parameters of type ServerName
 void HConnection.clearCaches(ServerName sn)
          Clear any caches that pertain to server name sn.
 void HConnectionManager.HConnectionImplementation.clearCaches(ServerName serverName)
           
 void HBaseAdmin.closeRegion(ServerName sn, HRegionInfo hri)
          Close a region.
 void HBaseAdmin.compactRegionServer(ServerName sn, boolean major)
          Compact all regions on the region server
 CoprocessorRpcChannel HBaseAdmin.coprocessorService(ServerName sn)
          Creates and returns a RpcChannel instance connected to the passed region server.
 AdminProtos.AdminService.BlockingInterface HConnection.getAdmin(ServerName serverName)
          Establishes a connection to the region server at the specified address.
 AdminProtos.AdminService.BlockingInterface HConnectionManager.HConnectionImplementation.getAdmin(ServerName serverName)
           
 AdminProtos.AdminService.BlockingInterface HConnection.getAdmin(ServerName serverName, boolean getMaster)
          Deprecated. You can pass master flag but nothing special is done.
 AdminProtos.AdminService.BlockingInterface HConnectionManager.HConnectionImplementation.getAdmin(ServerName serverName, boolean master)
           
 ClientProtos.ClientService.BlockingInterface HConnection.getClient(ServerName serverName)
          Establishes a connection to the region server at the specified address, and returns a region client protocol.
 ClientProtos.ClientService.BlockingInterface HConnectionManager.HConnectionImplementation.getClient(ServerName sn)
           
 List<HRegionInfo> HBaseAdmin.getOnlineRegions(ServerName sn)
          Get all the online regions on a region server.
 ServerStatistics ServerStatisticTracker.getStats(ServerName server)
           
 boolean HConnection.isDeadServer(ServerName serverName)
           
 boolean HConnectionManager.HConnectionImplementation.isDeadServer(ServerName sn)
           
 void ServerStatisticTracker.updateRegionStats(ServerName server, byte[] region, ClientProtos.RegionLoadStats currentStats)
           
static
<T> T
ResultStatsUtil.updateStats(T r, ServerStatisticTracker serverStats, ServerName server, byte[] regionName)
          Update the stats for the specified region if the result is an instance of ResultStatsUtil
 

Uses of ServerName in org.apache.hadoop.hbase.client.backoff
 

Methods in org.apache.hadoop.hbase.client.backoff with parameters of type ServerName
 long ClientBackoffPolicyFactory.NoBackoffPolicy.getBackoffTime(ServerName serverName, byte[] region, ServerStatistics stats)
           
 long ExponentialClientBackoffPolicy.getBackoffTime(ServerName serverName, byte[] region, ServerStatistics stats)
           
 long ClientBackoffPolicy.getBackoffTime(ServerName serverName, byte[] region, ServerStatistics stats)
           
 

Uses of ServerName in org.apache.hadoop.hbase.exceptions
 

Methods in org.apache.hadoop.hbase.exceptions that return ServerName
 ServerName RegionMovedException.getServerName()
           
 

Constructors in org.apache.hadoop.hbase.exceptions with parameters of type ServerName
RegionMovedException(ServerName serverName, long locationSeqNum)
           
 

Uses of ServerName in org.apache.hadoop.hbase.ipc
 

Methods in org.apache.hadoop.hbase.ipc with parameters of type ServerName
 BlockingRpcChannel RpcClient.createBlockingRpcChannel(ServerName sn, User ticket, int rpcTimeout)
          Creates a "channel" that can be used by a blocking protobuf service.
 

Constructors in org.apache.hadoop.hbase.ipc with parameters of type ServerName
RegionServerCoprocessorRpcChannel(HConnection conn, ServerName serverName)
           
RpcClient.BlockingRpcChannelImplementation(RpcClient rpcClient, ServerName sn, User ticket, int rpcTimeout)
           
 

Uses of ServerName in org.apache.hadoop.hbase.master
 

Methods in org.apache.hadoop.hbase.master that return ServerName
 ServerName RegionState.getServerName()
           
 

Methods in org.apache.hadoop.hbase.master with parameters of type ServerName
 boolean RegionState.isOnServer(ServerName sn)
           
 boolean RegionState.isOpenOrMergingNewOnServer(ServerName sn)
           
 boolean RegionState.isOpenOrMergingOnServer(ServerName sn)
           
 boolean RegionState.isOpenOrSplittingNewOnServer(ServerName sn)
           
 boolean RegionState.isOpenOrSplittingOnServer(ServerName sn)
           
 boolean RegionState.isPendingCloseOrClosingOnServer(ServerName sn)
           
 boolean RegionState.isPendingOpenOrOpeningOnServer(ServerName sn)
           
 

Constructors in org.apache.hadoop.hbase.master with parameters of type ServerName
RegionState(HRegionInfo region, RegionState.State state, long stamp, ServerName serverName)
           
RegionState(HRegionInfo region, RegionState.State state, ServerName serverName)
           
 

Uses of ServerName in org.apache.hadoop.hbase.protobuf
 

Methods in org.apache.hadoop.hbase.protobuf that return ServerName
static ServerName ProtobufUtil.toServerName(HBaseProtos.ServerName proto)
          Convert a protocol buffer ServerName to a ServerName
 

Methods in org.apache.hadoop.hbase.protobuf with parameters of type ServerName
static AdminProtos.CloseRegionRequest RequestConverter.buildCloseRegionRequest(ServerName server, byte[] regionName, boolean transitionInZK)
          Create a CloseRegionRequest for a given region name
static AdminProtos.CloseRegionRequest RequestConverter.buildCloseRegionRequest(ServerName server, byte[] regionName, int versionOfClosingNode, ServerName destinationServer, boolean transitionInZK)
           
static AdminProtos.CloseRegionRequest RequestConverter.buildCloseRegionRequest(ServerName server, String encodedRegionName, boolean transitionInZK)
          Create a CloseRegionRequest for a given encoded region name
static AdminProtos.GetServerInfoResponse ResponseConverter.buildGetServerInfoResponse(ServerName serverName, int webuiPort)
          A utility to build a GetServerInfoResponse.
static AdminProtos.OpenRegionRequest RequestConverter.buildOpenRegionRequest(ServerName server, HRegionInfo region, int versionOfOfflineNode, List<ServerName> favoredNodes, Boolean openForReplay)
          Create a protocol buffer OpenRegionRequest for a given region
static AdminProtos.OpenRegionRequest RequestConverter.buildOpenRegionRequest(ServerName server, List<Triple<HRegionInfo,Integer,List<ServerName>>> regionOpenInfos, Boolean openForReplay)
          Create a protocol buffer OpenRegionRequest to open a list of regions
static void ProtobufUtil.closeRegion(AdminProtos.AdminService.BlockingInterface admin, ServerName server, byte[] regionName, boolean transitionInZK)
          A helper to close a region given a region name using admin protocol.
static boolean ProtobufUtil.closeRegion(AdminProtos.AdminService.BlockingInterface admin, ServerName server, byte[] regionName, int versionOfClosingNode, ServerName destinationServer, boolean transitionInZK)
          A helper to close a region given a region name using admin protocol.
static void ProtobufUtil.openRegion(AdminProtos.AdminService.BlockingInterface admin, ServerName server, HRegionInfo region)
          A helper to open a region using admin protocol.
static HBaseProtos.ServerName ProtobufUtil.toServerName(ServerName serverName)
          Convert a ServerName to a protocol buffer ServerName
 

Method parameters in org.apache.hadoop.hbase.protobuf with type arguments of type ServerName
static AdminProtos.OpenRegionRequest RequestConverter.buildOpenRegionRequest(ServerName server, HRegionInfo region, int versionOfOfflineNode, List<ServerName> favoredNodes, Boolean openForReplay)
          Create a protocol buffer OpenRegionRequest for a given region
static AdminProtos.OpenRegionRequest RequestConverter.buildOpenRegionRequest(ServerName server, List<Triple<HRegionInfo,Integer,List<ServerName>>> regionOpenInfos, Boolean openForReplay)
          Create a protocol buffer OpenRegionRequest to open a list of regions
static AdminProtos.UpdateFavoredNodesRequest RequestConverter.buildUpdateFavoredNodesRequest(List<Pair<HRegionInfo,List<ServerName>>> updateRegionInfos)
          Create a protocol buffer UpdateFavoredNodesRequest to update a list of favorednode mappings
 

Uses of ServerName in org.apache.hadoop.hbase.zookeeper
 

Methods in org.apache.hadoop.hbase.zookeeper that return ServerName
static ServerName MetaRegionTracker.blockUntilAvailable(ZooKeeperWatcher zkw, long timeout)
          Wait until the meta region is available.
 ServerName MasterAddressTracker.getMasterAddress()
          Get the address of the current master if one is available.
 ServerName MasterAddressTracker.getMasterAddress(boolean refresh)
          Get the address of the current master if one is available.
static ServerName MasterAddressTracker.getMasterAddress(ZooKeeperWatcher zkw)
          Get master address.
 ServerName MetaRegionTracker.getMetaRegionLocation()
          Gets the meta region location, if available.
static ServerName MetaRegionTracker.getMetaRegionLocation(ZooKeeperWatcher zkw)
          Gets the meta region location, if available.
 ServerName MetaRegionTracker.waitMetaRegionLocation(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 with parameters of type ServerName
static void ZKAssign.asyncCreateNodeOffline(ZooKeeperWatcher zkw, HRegionInfo region, ServerName serverName, org.apache.zookeeper.AsyncCallback.StringCallback cb, Object ctx)
          Creates an unassigned node in the OFFLINE state for the specified region.
static int ZKAssign.createNodeClosing(ZooKeeperWatcher zkw, HRegionInfo region, ServerName serverName)
          Creates a new unassigned node in the CLOSING state for the specified region.
static void ZKAssign.createNodeOffline(ZooKeeperWatcher zkw, HRegionInfo region, ServerName serverName)
          Creates a new unassigned node in the OFFLINE state for the specified region.
static void ZKAssign.createNodeOffline(ZooKeeperWatcher zkw, HRegionInfo region, ServerName serverName, EventType event)
           
static int ZKAssign.createOrForceNodeOffline(ZooKeeperWatcher zkw, HRegionInfo region, ServerName serverName)
          Creates or force updates an unassigned node to the OFFLINE state for the specified region.
static boolean ZKAssign.deleteClosedNode(ZooKeeperWatcher zkw, String encodedRegionName, ServerName sn)
          Deletes an existing unassigned node that is in the CLOSED state for the specified region.
static boolean ZKAssign.deleteClosingNode(ZooKeeperWatcher zkw, HRegionInfo region, ServerName sn)
          Deletes an existing unassigned node that is in the CLOSING state for the specified region.
static boolean ZKAssign.deleteNode(ZooKeeperWatcher zkw, String encodedRegionName, EventType expectedState, ServerName sn)
          Deletes an existing unassigned node that is in the specified state for the specified region.
static boolean ZKAssign.deleteNode(ZooKeeperWatcher zkw, String encodedRegionName, EventType expectedState, ServerName serverName, int expectedVersion)
          Deletes an existing unassigned node that is in the specified state for the specified region.
static boolean ZKAssign.deleteOfflineNode(ZooKeeperWatcher zkw, String encodedRegionName, ServerName sn)
          Deletes an existing unassigned node that is in the OFFLINE state for the specified region.
static boolean ZKAssign.deleteOpenedNode(ZooKeeperWatcher zkw, String encodedRegionName, ServerName sn)
          Deletes an existing unassigned node that is in the OPENED state for the specified region.
static int ZKAssign.retransitionNodeOpening(ZooKeeperWatcher zkw, HRegionInfo region, ServerName serverName, int expectedVersion, boolean updateZNode)
          Retransitions an existing unassigned node for the specified region which is currently in the OPENING state to be in the OPENING state.
static boolean MasterAddressTracker.setMasterAddress(ZooKeeperWatcher zkw, String znode, ServerName master)
          Set master address into the master znode or into the backup subdirectory of backup masters; switch off the passed in znode path.
static void MetaRegionTracker.setMetaLocation(ZooKeeperWatcher zookeeper, ServerName location, RegionState.State regionState)
          Sets the location of hbase:meta in ZooKeeper to the specified server address.
static int ZKAssign.transitionNode(ZooKeeperWatcher zkw, HRegionInfo region, ServerName serverName, EventType beginState, EventType endState, int expectedVersion)
          Method that actually performs unassigned node transitions.
static int ZKAssign.transitionNode(ZooKeeperWatcher zkw, HRegionInfo region, ServerName serverName, EventType beginState, EventType endState, int expectedVersion, byte[] payload)
           
static int ZKAssign.transitionNodeClosed(ZooKeeperWatcher zkw, HRegionInfo region, ServerName serverName, int expectedVersion)
          Transitions an existing unassigned node for the specified region which is currently in the CLOSING state to be in the CLOSED state.
static int ZKAssign.transitionNodeOpened(ZooKeeperWatcher zkw, HRegionInfo region, ServerName serverName, int expectedVersion)
          Transitions an existing unassigned node for the specified region which is currently in the OPENING state to be in the OPENED state.
static int ZKAssign.transitionNodeOpening(ZooKeeperWatcher zkw, HRegionInfo region, ServerName serverName)
          Transitions an existing unassigned node for the specified region which is currently in the OFFLINE state to be in the OPENING state.
static int ZKAssign.transitionNodeOpening(ZooKeeperWatcher zkw, HRegionInfo region, ServerName serverName, EventType beginState)
           
 



Copyright © 2015 The Apache Software Foundation. All Rights Reserved.