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

Packages that use ServerName
org.apache.hadoop.hbase   
org.apache.hadoop.hbase.avro Provides an HBase Avro service. 
org.apache.hadoop.hbase.catalog   
org.apache.hadoop.hbase.client Provides HBase Client 
org.apache.hadoop.hbase.coprocessor Table of Contents 
org.apache.hadoop.hbase.executor   
org.apache.hadoop.hbase.master   
org.apache.hadoop.hbase.master.handler   
org.apache.hadoop.hbase.master.snapshot   
org.apache.hadoop.hbase.regionserver   
org.apache.hadoop.hbase.replication Multi Cluster Replication 
org.apache.hadoop.hbase.tmpl.master   
org.apache.hadoop.hbase.util   
org.apache.hadoop.hbase.zookeeper   
 

Uses of ServerName in org.apache.hadoop.hbase
 

Fields in org.apache.hadoop.hbase declared as ServerName
static ServerName HConstants.HBCK_CODE_SERVERNAME
           
 

Methods in org.apache.hadoop.hbase that return ServerName
static ServerName ServerName.findServerWithSameHostnamePort(Collection<ServerName> names, ServerName serverName)
           
 ServerName ClusterStatus.getMaster()
          Returns detailed information about the current master ServerName.
 ServerName MasterAddressTracker.getMasterAddress()
          Get the address of the current master if one is available.
 ServerName Server.getServerName()
           
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().
 

Methods in org.apache.hadoop.hbase that return types with arguments of type ServerName
 Collection<ServerName> ClusterStatus.getBackupMasters()
           
 Collection<ServerName> ClusterStatus.getDeadServerNames()
           
 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 ServerName ServerName.findServerWithSameHostnamePort(Collection<ServerName> names, ServerName serverName)
           
 HServerLoad ClusterStatus.getLoad(ServerName sn)
           
static boolean ServerName.isSameHostnameAndPort(ServerName left, ServerName right)
           
 

Method parameters in org.apache.hadoop.hbase with type arguments of type ServerName
static ServerName ServerName.findServerWithSameHostnamePort(Collection<ServerName> names, ServerName serverName)
           
 

Constructors in org.apache.hadoop.hbase with parameters of type ServerName
ClusterStatus(String hbaseVersion, String clusterid, Map<ServerName,HServerLoad> servers, Collection<ServerName> deadServers, ServerName master, Collection<ServerName> backupMasters, Map<String,AssignmentManager.RegionState> rit, String[] masterCoprocessors)
           
 

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

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

Methods in org.apache.hadoop.hbase.avro with parameters of type ServerName
static AServerInfo AvroUtil.hsiToASI(ServerName sn, HServerLoad hsl)
           
 

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

Methods in org.apache.hadoop.hbase.catalog that return ServerName
 ServerName CatalogTracker.getMetaLocation()
           
 ServerName CatalogTracker.getMetaLocationOrReadLocationFromRoot()
          Method used by master on startup trying to figure state of cluster.
 ServerName CatalogTracker.getRootLocation()
          Gets the current location for -ROOT- or null if location is not currently available.
static ServerName MetaReader.getServerNameFromCatalogResult(Result r)
          Extract a ServerName For use on catalog table Result.
static ServerName MetaReader.readMetaLocation(HRegionInterface metaServer)
          Deprecated. Does not retry; use #getMetaRegionLocation(CatalogTracker)
 ServerName CatalogTracker.waitForMeta(long timeout)
          Gets the current location for .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<String> disabledTables)
          Performs a full scan of .META., skipping regions from any tables in the specified set of disabled tables.
static Map<HRegionInfo,ServerName> MetaReader.fullScan(CatalogTracker catalogTracker, Set<String> disabledTables, boolean excludeOfflinedSplitParents)
          Performs a full scan of .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, byte[] tableName, boolean excludeOfflinedSplitParents)
           
static List<Pair<HRegionInfo,ServerName>> MetaReader.getTableRegionsAndLocations(CatalogTracker catalogTracker, String tableName)
           
static Pair<HRegionInfo,ServerName> MetaReader.parseCatalogResult(Result r)
          Extract a HRegionInfo and ServerName.
 

Methods in org.apache.hadoop.hbase.catalog with parameters of type ServerName
static void MetaEditor.addDaughter(CatalogTracker catalogTracker, HRegionInfo regionInfo, ServerName sn)
           
static NavigableMap<HRegionInfo,Result> MetaReader.getServerUserRegions(CatalogTracker catalogTracker, ServerName serverName)
           
static void RootLocationEditor.setRootLocation(ZooKeeperWatcher zookeeper, ServerName location)
          Sets the location of -ROOT- in ZooKeeper to the specified server address.
static void MetaEditor.updateMetaLocation(CatalogTracker catalogTracker, HRegionInfo regionInfo, ServerName sn)
          Updates the location of the specified META region in ROOT to be the specified server hostname and startcode.
static void MetaEditor.updateRegionLocation(CatalogTracker catalogTracker, HRegionInfo regionInfo, ServerName sn)
          Updates the location of the specified region in META to be the specified server hostname and startcode.
 

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, byte[] 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 HBaseAdmin.closeRegion(ServerName sn, HRegionInfo hri)
          Close a region.
 

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

Methods in org.apache.hadoop.hbase.coprocessor with parameters of type ServerName
 void MasterObserver.postMove(ObserverContext<MasterCoprocessorEnvironment> ctx, HRegionInfo region, ServerName srcServer, ServerName destServer)
          Called after the region move has been requested.
 void BaseMasterObserver.postMove(ObserverContext<MasterCoprocessorEnvironment> ctx, HRegionInfo region, ServerName srcServer, ServerName destServer)
           
 void MasterObserver.preMove(ObserverContext<MasterCoprocessorEnvironment> ctx, HRegionInfo region, ServerName srcServer, ServerName destServer)
          Called prior to moving a given region from one region server to another.
 void BaseMasterObserver.preMove(ObserverContext<MasterCoprocessorEnvironment> ctx, HRegionInfo region, ServerName srcServer, ServerName destServer)
           
 

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

Methods in org.apache.hadoop.hbase.executor that return ServerName
 ServerName RegionTransitionData.getOrigin()
          Gets the server the event originated from.
 

Constructors in org.apache.hadoop.hbase.executor with parameters of type ServerName
RegionTransitionData(EventHandler.EventType eventType, byte[] regionName, ServerName origin)
          Construct data for a new region transition event with the specified event type, region name, and server name.
RegionTransitionData(EventHandler.EventType eventType, byte[] regionName, ServerName serverName, byte[] payload)
          Construct data for a new region transition event with the specified event type, region name, and server name.
 

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

Methods in org.apache.hadoop.hbase.master that return ServerName
 ServerName RegionPlan.getDestination()
          Get the destination server for the plan for this region.
 ServerName AssignmentManager.getRegionServerOfRegion(HRegionInfo hri)
          Returns the RegionServer to which hri is assigned.
 ServerName HMaster.getServerName()
           
 ServerName AssignmentManager.RegionState.getServerName()
           
 ServerName RegionPlan.getSource()
          Get the source server for the plan for this region.
 ServerName DefaultLoadBalancer.randomAssignment(List<ServerName> servers)
           
 ServerName LoadBalancer.randomAssignment(List<ServerName> servers)
          Get a random region server from the list
 

Methods in org.apache.hadoop.hbase.master that return types with arguments of type ServerName
 Set<ServerName> DeadServer.clone()
           
 Set<ServerName> ServerManager.getDeadServers()
           
 List<ServerName> ServerManager.getDrainingServersList()
           
 Map<ServerName,HServerLoad> ServerManager.getOnlineServers()
           
 List<ServerName> ServerManager.getOnlineServersList()
           
 Map<HRegionInfo,ServerName> DefaultLoadBalancer.immediateAssignment(List<HRegionInfo> regions, List<ServerName> servers)
          Generates an immediate assignment plan to be used by a new master for regions in transition that do not have an already known destination.
 Map<HRegionInfo,ServerName> LoadBalancer.immediateAssignment(List<HRegionInfo> regions, List<ServerName> servers)
          Sync assign a region
 Iterator<ServerName> DeadServer.iterator()
           
 Map<ServerName,List<HRegionInfo>> DefaultLoadBalancer.retainAssignment(Map<HRegionInfo,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.
 Map<ServerName,List<HRegionInfo>> LoadBalancer.retainAssignment(Map<HRegionInfo,ServerName> regions, List<ServerName> servers)
          Assign regions to the previously hosting region server
 Map<ServerName,List<HRegionInfo>> DefaultLoadBalancer.roundRobinAssignment(List<HRegionInfo> regions, List<ServerName> servers)
          Generates a bulk assignment plan to be used on cluster startup using a simple round-robin assignment.
 Map<ServerName,List<HRegionInfo>> LoadBalancer.roundRobinAssignment(List<HRegionInfo> regions, List<ServerName> servers)
          Perform a Round Robin assignment of regions.
 

Methods in org.apache.hadoop.hbase.master with parameters of type ServerName
 boolean DeadServer.add(ServerName e)
           
 boolean ServerManager.addServerToDrainList(ServerName sn)
           
 boolean DeadServer.cleanPreviousInstance(ServerName newServerName)
          A dead server that comes back alive has a different start code.
 void ServerManager.expireServer(ServerName serverName)
           
 void DeadServer.finish(ServerName e)
           
 HServerLoad ServerManager.getLoad(ServerName serverName)
           
 void AssignmentManager.handleSplitReport(ServerName sn, HRegionInfo parent, HRegionInfo a, HRegionInfo b)
          Update inmemory structures.
 boolean AssignmentManager.isCarryingMeta(ServerName serverName)
           
 boolean AssignmentManager.isCarryingRegion(ServerName serverName, HRegionInfo hri)
          Check if the shutdown server carries the specific region.
 boolean AssignmentManager.isCarryingRoot(ServerName serverName)
           
 boolean AssignmentManager.isServerOnline(ServerName serverName)
          Check whether the RegionServer is online.
 boolean ServerManager.isServerOnline(ServerName serverName)
           
 Pair<Set<HRegionInfo>,List<AssignmentManager.RegionState>> AssignmentManager.processServerShutdown(ServerName sn)
          Start processing of shutdown server.
 boolean ServerManager.removeServerFromDrainList(ServerName sn)
           
 boolean ServerManager.sendRegionClose(ServerName server, HRegionInfo region, int versionOfClosingNode)
          Sends an CLOSE RPC to the specified server to close the specified region.
 RegionOpeningState ServerManager.sendRegionOpen(ServerName server, HRegionInfo region, int versionOfOfflineNode)
          Sends an OPEN RPC to the specified server to open the specified region.
 void ServerManager.sendRegionOpen(ServerName server, List<HRegionInfo> regions)
          Sends an OPEN RPC to the specified server to open the specified region.
 void RegionPlan.setDestination(ServerName dest)
          Set the destination server for the plan for this region.
 void MasterFileSystem.splitLog(ServerName serverName)
           
 void AssignmentManager.RegionState.update(AssignmentManager.RegionState.State state, long stamp, ServerName serverName)
           
 

Method parameters in org.apache.hadoop.hbase.master with type arguments of type ServerName
 boolean DeadServer.addAll(Collection<? extends ServerName> c)
           
 void AssignmentManager.assignUserRegions(List<HRegionInfo> regions, List<ServerName> servers)
          Assigns all user regions, if any.
 List<RegionPlan> DefaultLoadBalancer.balanceCluster(Map<ServerName,List<HRegionInfo>> clusterState)
          Generate a global load balancing plan according to the specified map of server information to the most loaded regions of each server.
 List<RegionPlan> LoadBalancer.balanceCluster(Map<ServerName,List<HRegionInfo>> clusterState)
          Perform the major balance operation
 Map<HRegionInfo,ServerName> DefaultLoadBalancer.immediateAssignment(List<HRegionInfo> regions, List<ServerName> servers)
          Generates an immediate assignment plan to be used by a new master for regions in transition that do not have an already known destination.
 Map<HRegionInfo,ServerName> LoadBalancer.immediateAssignment(List<HRegionInfo> regions, List<ServerName> servers)
          Sync assign a region
 ServerName DefaultLoadBalancer.randomAssignment(List<ServerName> servers)
           
 ServerName LoadBalancer.randomAssignment(List<ServerName> servers)
          Get a random region server from the list
 void AssignmentManager.removeDeadNotExpiredServers(List<ServerName> servers)
          Loop through the deadNotExpired server list and remove them from the servers.
 Map<ServerName,List<HRegionInfo>> DefaultLoadBalancer.retainAssignment(Map<HRegionInfo,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.
 Map<ServerName,List<HRegionInfo>> DefaultLoadBalancer.retainAssignment(Map<HRegionInfo,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.
 Map<ServerName,List<HRegionInfo>> LoadBalancer.retainAssignment(Map<HRegionInfo,ServerName> regions, List<ServerName> servers)
          Assign regions to the previously hosting region server
 Map<ServerName,List<HRegionInfo>> LoadBalancer.retainAssignment(Map<HRegionInfo,ServerName> regions, List<ServerName> servers)
          Assign regions to the previously hosting region server
 Map<ServerName,List<HRegionInfo>> DefaultLoadBalancer.roundRobinAssignment(List<HRegionInfo> regions, List<ServerName> servers)
          Generates a bulk assignment plan to be used on cluster startup using a simple round-robin assignment.
 Map<ServerName,List<HRegionInfo>> LoadBalancer.roundRobinAssignment(List<HRegionInfo> regions, List<ServerName> servers)
          Perform a Round Robin assignment of regions.
 void MasterFileSystem.splitLog(List<ServerName> serverNames)
           
 

Constructors in org.apache.hadoop.hbase.master with parameters of type ServerName
RegionPlan(HRegionInfo 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.
 

Constructor parameters in org.apache.hadoop.hbase.master with type arguments of type ServerName
BulkReOpen(Server server, Map<ServerName,List<HRegionInfo>> serverToRegions, AssignmentManager am)
           
 

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

Constructors in org.apache.hadoop.hbase.master.handler with parameters of type ServerName
MetaServerShutdownHandler(Server server, MasterServices services, DeadServer deadServers, ServerName serverName, boolean carryingRoot, boolean carryingMeta)
           
OpenedRegionHandler(Server server, AssignmentManager assignmentManager, HRegionInfo regionInfo, ServerName sn, int expectedVersion)
           
ServerShutdownHandler(Server server, MasterServices services, DeadServer deadServers, ServerName serverName, boolean shouldSplitHlog)
           
SplitRegionHandler(Server server, AssignmentManager assignmentManager, HRegionInfo regionInfo, ServerName sn, List<HRegionInfo> daughters)
           
 

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

Method parameters in org.apache.hadoop.hbase.master.snapshot with type arguments of type ServerName
protected  void EnabledTableSnapshotHandler.snapshotRegions(List<Pair<HRegionInfo,ServerName>> regions)
          This method kicks off a snapshot procedure.
 void DisabledTableSnapshotHandler.snapshotRegions(List<Pair<HRegionInfo,ServerName>> regionsAndLocations)
           
protected abstract  void TakeSnapshotHandler.snapshotRegions(List<Pair<HRegionInfo,ServerName>> regions)
          Snapshot the specified regions
 

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

Methods in org.apache.hadoop.hbase.regionserver that return ServerName
 ServerName HRegionServer.getServerName()
           
 

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

Methods in org.apache.hadoop.hbase.replication that return types with arguments of type ServerName
 List<ServerName> ReplicationPeer.getRegionServers()
          Get a list of all the addresses of all the region servers for this peer cluster
 List<ServerName> ReplicationZookeeper.getSlavesAddresses(String peerClusterId)
          Returns all region servers from given peer
static List<ServerName> ReplicationZookeeper.listChildrenAndGetAsServerNames(ZooKeeperWatcher zkw, String znode)
          Lists the children of the specified znode, retrieving the data of each child as a server address.
 

Method parameters in org.apache.hadoop.hbase.replication with type arguments of type ServerName
 void ReplicationPeer.setRegionServers(List<ServerName> regionServers)
          Set the list of region servers for that peer
 

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

Fields in org.apache.hadoop.hbase.tmpl.master declared as ServerName
protected  ServerName MasterStatusTmpl.metaLocation
           
protected  ServerName MasterStatusTmpl.rootLocation
           
 

Fields in org.apache.hadoop.hbase.tmpl.master with type parameters of type ServerName
protected  Set<ServerName> MasterStatusTmpl.deadServers
           
protected  List<ServerName> MasterStatusTmpl.servers
           
 

Methods in org.apache.hadoop.hbase.tmpl.master that return ServerName
 ServerName MasterStatusTmpl.ImplData.getMetaLocation()
           
 ServerName MasterStatusTmpl.ImplData.getRootLocation()
           
 

Methods in org.apache.hadoop.hbase.tmpl.master that return types with arguments of type ServerName
 Set<ServerName> MasterStatusTmpl.ImplData.getDeadServers()
           
 List<ServerName> MasterStatusTmpl.ImplData.getServers()
           
 

Methods in org.apache.hadoop.hbase.tmpl.master with parameters of type ServerName
 MasterStatusTmpl MasterStatusTmpl.setMetaLocation(ServerName p_metaLocation)
           
 void MasterStatusTmpl.ImplData.setMetaLocation(ServerName metaLocation)
           
 MasterStatusTmpl MasterStatusTmpl.setRootLocation(ServerName p_rootLocation)
           
 void MasterStatusTmpl.ImplData.setRootLocation(ServerName rootLocation)
           
 

Method parameters in org.apache.hadoop.hbase.tmpl.master with type arguments of type ServerName
 MasterStatusTmpl MasterStatusTmpl.setDeadServers(Set<ServerName> p_deadServers)
           
 void MasterStatusTmpl.ImplData.setDeadServers(Set<ServerName> deadServers)
           
 MasterStatusTmpl MasterStatusTmpl.setServers(List<ServerName> p_servers)
           
 void MasterStatusTmpl.ImplData.setServers(List<ServerName> servers)
           
 

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

Methods in org.apache.hadoop.hbase.util with parameters of type ServerName
 void HBaseFsck.HbckInfo.addServer(HRegionInfo hri, ServerName server)
           
 void HBaseFsck.TableInfo.addServer(ServerName server)
           
static void HBaseFsckRepair.closeRegionSilentlyAndWait(HBaseAdmin admin, ServerName server, HRegionInfo region)
          Contacts a region server and waits up to hbase.hbck.close.timeout ms (default 120s) to close the region.
 

Method parameters in org.apache.hadoop.hbase.util with type arguments of type ServerName
static void HBaseFsckRepair.fixMultiAssignment(HBaseAdmin admin, HRegionInfo 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.
 

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

Methods in org.apache.hadoop.hbase.zookeeper that return ServerName
 ServerName RootRegionTracker.getRootRegionLocation()
          Gets the root region location, if available.
 ServerName RootRegionTracker.waitRootRegionLocation(long timeout)
          Gets the root 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 ServerName
 List<ServerName> RegionServerTracker.getOnlineServers()
          Gets the online servers.
 

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, EventHandler.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 int ZKAssign.createOrForceNodeOffline(ZooKeeperWatcher zkw, HRegionInfo region, ServerName serverName, boolean hijack, boolean allowCreation)
          Creates or force updates an unassigned node to the OFFLINE state for the specified region.
static void ZKAssign.forceNodeOffline(ZooKeeperWatcher zkw, HRegionInfo region, ServerName serverName)
          Forces an existing unassigned node to the OFFLINE state for the specified region.
static int ZKAssign.retransitionNodeOpening(ZooKeeperWatcher zkw, HRegionInfo region, ServerName serverName, int expectedVersion)
          Retransitions an existing unassigned node for the specified region which is currently in the OPENING state to be in the OPENING state.
static int ZKAssign.transitionNode(ZooKeeperWatcher zkw, HRegionInfo region, ServerName serverName, EventHandler.EventType beginState, EventHandler.EventType endState, int expectedVersion)
          Method that actually performs unassigned node transitions.
static int ZKAssign.transitionNode(ZooKeeperWatcher zkw, HRegionInfo region, ServerName serverName, EventHandler.EventType beginState, EventHandler.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, EventHandler.EventType beginState)
           
 



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