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

Packages that use HRegionInfo
org.apache.hadoop.hbase   
org.apache.hadoop.hbase.catalog   
org.apache.hadoop.hbase.client Provides HBase Client 
org.apache.hadoop.hbase.ipc Tools to help define network clients and servers. 
org.apache.hadoop.hbase.master   
org.apache.hadoop.hbase.master.handler   
org.apache.hadoop.hbase.regionserver   
org.apache.hadoop.hbase.regionserver.handler   
org.apache.hadoop.hbase.regionserver.wal   
org.apache.hadoop.hbase.replication.regionserver   
org.apache.hadoop.hbase.util   
org.apache.hadoop.hbase.zookeeper   
 

Uses of HRegionInfo in org.apache.hadoop.hbase
 

Fields in org.apache.hadoop.hbase declared as HRegionInfo
static HRegionInfo HRegionInfo.FIRST_META_REGIONINFO
          HRegionInfo for first meta region
static HRegionInfo HRegionInfo.ROOT_REGIONINFO
          HRegionInfo for root region
 

Methods in org.apache.hadoop.hbase that return HRegionInfo
 HRegionInfo HMsg.getDaughterA()
           
 HRegionInfo HMsg.getDaughterB()
           
 HRegionInfo HMsg.getRegionInfo()
           
 HRegionInfo HRegionLocation.getRegionInfo()
           
 

Methods in org.apache.hadoop.hbase with parameters of type HRegionInfo
 int HRegionInfo.compareTo(HRegionInfo o)
           
 

Constructors in org.apache.hadoop.hbase with parameters of type HRegionInfo
HMsg(HMsg.Type type, HRegionInfo hri)
          Construct a message with the specified message and HRegionInfo
HMsg(HMsg.Type type, HRegionInfo hri, byte[] msg)
          Construct a message with the specified message and HRegionInfo
HMsg(HMsg.Type type, HRegionInfo hri, HRegionInfo daughterA, HRegionInfo daughterB, byte[] msg)
          Construct a message with the specified message and HRegionInfo
HRegionInfo(HRegionInfo other)
          Costruct a copy of another HRegionInfo
HRegionLocation(HRegionInfo regionInfo, HServerAddress serverAddress)
          Constructor
 

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

Methods in org.apache.hadoop.hbase.catalog that return types with arguments of type HRegionInfo
static Map<HRegionInfo,HServerAddress> MetaReader.fullScan(CatalogTracker catalogTracker)
          Performs a full scan of .META..
static Map<HRegionInfo,HServerAddress> 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,HServerAddress> 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,HServerAddress> MetaReader.getRegion(CatalogTracker catalogTracker, byte[] regionName)
          Gets the region info and assignment for the specified region from META.
static NavigableMap<HRegionInfo,Result> MetaReader.getServerUserRegions(CatalogTracker catalogTracker, HServerInfo hsi)
           
static List<HRegionInfo> MetaReader.getTableRegions(CatalogTracker catalogTracker, byte[] tableName)
          Gets all of the regions of the specified table.
static List<HRegionInfo> MetaReader.getTableRegions(CatalogTracker catalogTracker, byte[] tableName, boolean excludeOfflinedSplitParents)
          Gets all of the regions of the specified table.
static List<Pair<HRegionInfo,HServerAddress>> MetaReader.getTableRegionsAndLocations(CatalogTracker catalogTracker, String tableName)
           
static Pair<HRegionInfo,HServerAddress> MetaReader.metaRowToRegionPair(Result data)
           
static Pair<HRegionInfo,HServerInfo> MetaReader.metaRowToRegionPairWithInfo(Result data)
           
 

Methods in org.apache.hadoop.hbase.catalog with parameters of type HRegionInfo
static void MetaEditor.addDaughter(CatalogTracker catalogTracker, HRegionInfo regionInfo, HServerInfo serverInfo)
           
static void MetaEditor.addRegionToMeta(CatalogTracker catalogTracker, HRegionInfo regionInfo)
          Adds a META row for the specified new region.
static void MetaEditor.deleteDaughterReferenceInParent(CatalogTracker catalogTracker, HRegionInfo parent, byte[] qualifier, HRegionInfo daughter)
          Deletes daughter reference in offlined split parent.
static void MetaEditor.deleteRegion(CatalogTracker catalogTracker, HRegionInfo regionInfo)
          Deletes the specified region from META.
static void MetaEditor.offlineParentInMeta(CatalogTracker catalogTracker, HRegionInfo parent, HRegionInfo a, HRegionInfo b)
          Offline parent in meta.
static void MetaEditor.updateMetaLocation(CatalogTracker catalogTracker, HRegionInfo regionInfo, HServerInfo serverInfo)
          Updates the location of the specified META region in ROOT to be the specified server hostname and startcode.
static void MetaEditor.updateRegionInfo(CatalogTracker catalogTracker, HRegionInfo regionInfo)
          Updates the region information for the specified region in META.
static void MetaEditor.updateRegionLocation(CatalogTracker catalogTracker, HRegionInfo regionInfo, HServerInfo serverInfo)
          Updates the location of the specified region in META to be the specified server hostname and startcode.
 

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

Methods in org.apache.hadoop.hbase.client that return HRegionInfo
 HRegionInfo ScannerCallable.getHRegionInfo()
           
 

Methods in org.apache.hadoop.hbase.client that return types with arguments of type HRegionInfo
 Map<HRegionInfo,HServerAddress> HTable.deserializeRegionInfo(DataInput in)
          Read from in and deserialize the regions information.
 Map<HRegionInfo,HServerAddress> HTable.getRegionsInfo()
          Gets all the regions and their address for this table.
static List<HRegionInfo> MetaScanner.listAllRegions(org.apache.hadoop.conf.Configuration conf)
          Lists all of the regions currently in META.
static List<HRegionInfo> MetaScanner.listAllRegions(org.apache.hadoop.conf.Configuration conf, boolean offlined)
          Lists all of the regions currently in META.
 

Methods in org.apache.hadoop.hbase.client with parameters of type HRegionInfo
 void HBaseAdmin.closeRegion(HServerAddress hsa, HRegionInfo hri)
           
 

Method parameters in org.apache.hadoop.hbase.client with type arguments of type HRegionInfo
 void HConnection.prewarmRegionCache(byte[] tableName, Map<HRegionInfo,HServerAddress> regions)
          Load the region map and warm up the global region cache for the table.
 void HTable.prewarmRegionCache(Map<HRegionInfo,HServerAddress> regionMap)
          Save the passed region information and the table's regions cache.
 

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

Methods in org.apache.hadoop.hbase.ipc that return HRegionInfo
 HRegionInfo HRegionInterface.getRegionInfo(byte[] regionName)
          Get metainfo about an HRegion
 

Methods in org.apache.hadoop.hbase.ipc that return types with arguments of type HRegionInfo
 List<HRegionInfo> HRegionInterface.getOnlineRegions()
           
 

Methods in org.apache.hadoop.hbase.ipc with parameters of type HRegionInfo
 boolean HRegionInterface.closeRegion(HRegionInfo region)
          Closes the specified region.
 boolean HRegionInterface.closeRegion(HRegionInfo region, boolean zk)
          Closes the specified region and will use or not use ZK during the close according to the specified flag.
 void HRegionInterface.compactRegion(HRegionInfo regionInfo, boolean major)
          Compacts the specified region.
 void HRegionInterface.flushRegion(HRegionInfo regionInfo)
          Flushes the MemStore of the specified region.
 void HRegionInterface.openRegion(HRegionInfo region)
          Opens the specified region.
 HMsg[] HMasterRegionInterface.regionServerReport(HServerInfo info, HMsg[] msgs, HRegionInfo[] mostLoadedRegions)
          Called to renew lease, tell master what the region server is doing and to receive new instructions from the master
 void HRegionInterface.splitRegion(HRegionInfo regionInfo)
          Splits the specified region.
 void HRegionInterface.splitRegion(HRegionInfo regionInfo, byte[] splitPoint)
          Splits the specified region.
 

Method parameters in org.apache.hadoop.hbase.ipc with type arguments of type HRegionInfo
 void HRegionInterface.openRegions(List<HRegionInfo> regions)
          Opens the specified regions.
 

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

Methods in org.apache.hadoop.hbase.master that return HRegionInfo
 HRegionInfo AssignmentManager.RegionState.getRegion()
           
 HRegionInfo LoadBalancer.RegionPlan.getRegionInfo()
           
 

Methods in org.apache.hadoop.hbase.master that return types with arguments of type HRegionInfo
 List<HRegionInfo> AssignmentManager.getRegionsOfTable(byte[] tableName)
          Gets the online regions of the specified table.
static Map<HRegionInfo,HServerInfo> LoadBalancer.immediateAssignment(List<HRegionInfo> regions, List<HServerInfo> 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.
static Map<HServerInfo,List<HRegionInfo>> LoadBalancer.retainAssignment(Map<HRegionInfo,HServerAddress> regions, List<HServerInfo> 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.
static Map<HServerInfo,List<HRegionInfo>> LoadBalancer.roundRobinAssignment(List<HRegionInfo> regions, List<HServerInfo> servers)
          Generates a bulk assignment plan to be used on cluster startup using a simple round-robin assignment.
 

Methods in org.apache.hadoop.hbase.master with parameters of type HRegionInfo
 void AssignmentManager.assign(HRegionInfo region, boolean setOfflineInZK)
          Assigns the specified region.
 void AssignmentManager.assign(HRegionInfo region, boolean setOfflineInZK, boolean forceNewPlan)
           
 void HMaster.assignRegion(HRegionInfo hri)
           
 void HMaster.clearFromTransition(HRegionInfo hri)
           
 void AssignmentManager.clearRegionFromTransition(HRegionInfo hri)
          Clears the specified region from being in transition.
 void MasterFileSystem.deleteFamily(HRegionInfo region, byte[] familyName)
           
 void MasterFileSystem.deleteRegion(HRegionInfo region)
           
 void AssignmentManager.handleSplitReport(HServerInfo hsi, HRegionInfo parent, HRegionInfo a, HRegionInfo b)
          Update inmemory structures.
 AssignmentManager.RegionState AssignmentManager.isRegionInTransition(HRegionInfo hri)
           
 void AssignmentManager.offlineDisabledRegion(HRegionInfo regionInfo)
           
 void AssignmentManager.regionOffline(HRegionInfo regionInfo)
          Marks the region as offline.
 void AssignmentManager.regionOnline(HRegionInfo regionInfo, HServerInfo serverInfo)
          Marks the region as online.
 HMsg[] HMaster.regionServerReport(HServerInfo serverInfo, HMsg[] msgs, HRegionInfo[] mostLoadedRegions)
           
 boolean ServerManager.sendRegionClose(HServerInfo server, HRegionInfo region)
          Sends an CLOSE RPC to the specified server to close the specified region.
 void ServerManager.sendRegionOpen(HServerInfo server, HRegionInfo region)
          Sends an OPEN RPC to the specified server to open the specified region.
 void AssignmentManager.setOffline(HRegionInfo regionInfo)
          Sets the region as offline by removing in-memory assignment information but retaining transition information.
 void AssignmentManager.unassign(HRegionInfo region)
          Unassigns the specified region.
 void AssignmentManager.unassign(HRegionInfo region, boolean force)
          Unassigns the specified region.
 void MasterFileSystem.updateRegionInfo(HRegionInfo region)
           
 void AssignmentManager.waitForAssignment(HRegionInfo regionInfo)
          Waits until the specified region has completed assignment.
 void AssignmentManager.waitOnRegionToClearRegionsInTransition(HRegionInfo hri)
          Wait on region to clear regions-in-transition.
 

Method parameters in org.apache.hadoop.hbase.master with type arguments of type HRegionInfo
 List<LoadBalancer.RegionPlan> LoadBalancer.balanceCluster(Map<HServerInfo,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.
static Map<HRegionInfo,HServerInfo> LoadBalancer.immediateAssignment(List<HRegionInfo> regions, List<HServerInfo> 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.
static Map<HServerInfo,List<HRegionInfo>> LoadBalancer.retainAssignment(Map<HRegionInfo,HServerAddress> regions, List<HServerInfo> 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.
static Map<HServerInfo,List<HRegionInfo>> LoadBalancer.roundRobinAssignment(List<HRegionInfo> regions, List<HServerInfo> servers)
          Generates a bulk assignment plan to be used on cluster startup using a simple round-robin assignment.
 void ServerManager.sendRegionOpen(HServerInfo server, List<HRegionInfo> regions)
          Sends an OPEN RPC to the specified server to open the specified region.
 

Constructors in org.apache.hadoop.hbase.master with parameters of type HRegionInfo
LoadBalancer.RegionPlan(HRegionInfo hri, HServerInfo source, HServerInfo dest)
          Instantiate a plan for a region move, moving the specified region from the specified source server to the specified destination server.
 

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

Methods in org.apache.hadoop.hbase.master.handler that return HRegionInfo
 HRegionInfo TotesHRegionInfo.getHRegionInfo()
           
 HRegionInfo OpenedRegionHandler.getHRegionInfo()
           
 HRegionInfo ClosedRegionHandler.getHRegionInfo()
           
 

Methods in org.apache.hadoop.hbase.master.handler with parameters of type HRegionInfo
static boolean ServerShutdownHandler.processDeadRegion(HRegionInfo hri, Result result, AssignmentManager assignmentManager, CatalogTracker catalogTracker)
          Process a dead region from a dead RS.
 

Method parameters in org.apache.hadoop.hbase.master.handler with type arguments of type HRegionInfo
protected  void TableAddFamilyHandler.handleTableOperation(List<HRegionInfo> hris)
           
protected abstract  void TableEventHandler.handleTableOperation(List<HRegionInfo> regions)
           
protected  void TableDeleteFamilyHandler.handleTableOperation(List<HRegionInfo> hris)
           
protected  void DeleteTableHandler.handleTableOperation(List<HRegionInfo> regions)
           
protected  void TableModifyFamilyHandler.handleTableOperation(List<HRegionInfo> regions)
           
protected  void ModifyTableHandler.handleTableOperation(List<HRegionInfo> hris)
           
 

Constructors in org.apache.hadoop.hbase.master.handler with parameters of type HRegionInfo
ClosedRegionHandler(Server server, AssignmentManager assignmentManager, HRegionInfo regionInfo)
           
OpenedRegionHandler(Server server, AssignmentManager assignmentManager, HRegionInfo regionInfo, HServerInfo serverInfo)
           
 

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

Methods in org.apache.hadoop.hbase.regionserver that return HRegionInfo
protected  HRegionInfo[] HRegionServer.getMostLoadedRegions()
          Get the top N most loaded regions this server is serving so we can tell the master which regions it can reallocate if we're overloaded.
 HRegionInfo HRegion.getRegionInfo()
           
 HRegionInfo HRegionServer.getRegionInfo(byte[] regionName)
           
 

Methods in org.apache.hadoop.hbase.regionserver that return types with arguments of type HRegionInfo
 List<HRegionInfo> HRegionServer.getOnlineRegions()
           
 

Methods in org.apache.hadoop.hbase.regionserver with parameters of type HRegionInfo
 boolean HRegionServer.closeRegion(HRegionInfo region)
           
 boolean HRegionServer.closeRegion(HRegionInfo region, boolean zk)
           
protected  boolean HRegionServer.closeRegion(HRegionInfo region, boolean abort, boolean zk)
           
 void HRegionServer.compactRegion(HRegionInfo regionInfo, boolean major)
           
static HRegion HRegion.createHRegion(HRegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf)
          Convenience method creating new HRegions.
static void HRegion.deleteRegion(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path rootdir, HRegionInfo info)
          Deletes all the files for a HRegion
 void HRegionServer.flushRegion(HRegionInfo regionInfo)
           
static org.apache.hadoop.fs.Path HRegion.getRegionDir(org.apache.hadoop.fs.Path rootdir, HRegionInfo info)
          Computes the Path of the HRegion
static void HRegion.makeColumnFamilyDirs(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path tabledir, HRegionInfo hri, byte[] colFamily)
          Make the directories for a specific column family
static HRegion HRegion.newHRegion(org.apache.hadoop.fs.Path tableDir, HLog log, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, HRegionInfo regionInfo, FlushRequester flushListener)
          A utility method to create new instances of HRegion based on the HConstants.REGION_IMPL configuration property.
static HRegion HRegion.openHRegion(HRegionInfo info, HLog wal, org.apache.hadoop.conf.Configuration conf)
          Open a Region.
static HRegion HRegion.openHRegion(HRegionInfo info, HLog wal, org.apache.hadoop.conf.Configuration conf, FlushRequester flusher, CancelableProgressable reporter)
          Open a Region.
 void HRegionServer.openRegion(HRegionInfo region)
           
static boolean HRegion.rowIsInRange(HRegionInfo info, byte[] row)
          Determines if the specified row is within the row range specified by the specified HRegionInfo
 void HRegionServer.splitRegion(HRegionInfo regionInfo)
           
 void HRegionServer.splitRegion(HRegionInfo regionInfo, byte[] splitPoint)
           
 

Method parameters in org.apache.hadoop.hbase.regionserver with type arguments of type HRegionInfo
 void HRegionServer.openRegions(List<HRegionInfo> regions)
           
 

Constructors in org.apache.hadoop.hbase.regionserver with parameters of type HRegionInfo
HRegion(org.apache.hadoop.fs.Path tableDir, HLog log, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, HRegionInfo regionInfo, FlushRequester flushRequester)
          HRegion constructor.
 

Uses of HRegionInfo in org.apache.hadoop.hbase.regionserver.handler
 

Methods in org.apache.hadoop.hbase.regionserver.handler that return HRegionInfo
 HRegionInfo OpenRegionHandler.getRegionInfo()
           
 HRegionInfo CloseRegionHandler.getRegionInfo()
           
 

Constructors in org.apache.hadoop.hbase.regionserver.handler with parameters of type HRegionInfo
CloseMetaHandler(Server server, RegionServerServices rsServices, HRegionInfo regionInfo)
           
CloseMetaHandler(Server server, RegionServerServices rsServices, HRegionInfo regionInfo, boolean abort, boolean zk)
           
CloseRegionHandler(Server server, RegionServerServices rsServices, HRegionInfo regionInfo)
           
CloseRegionHandler(Server server, RegionServerServices rsServices, HRegionInfo regionInfo, boolean abort, boolean zk)
          This method used internally by the RegionServer to close out regions.
CloseRegionHandler(Server server, RegionServerServices rsServices, HRegionInfo regionInfo, boolean abort, boolean zk, EventHandler.EventType eventType)
           
CloseRootHandler(Server server, RegionServerServices rsServices, HRegionInfo regionInfo)
           
CloseRootHandler(Server server, RegionServerServices rsServices, HRegionInfo regionInfo, boolean abort, boolean zk)
           
OpenMetaHandler(Server server, RegionServerServices rsServices, HRegionInfo regionInfo)
           
OpenRegionHandler(Server server, RegionServerServices rsServices, HRegionInfo regionInfo)
           
OpenRegionHandler(Server server, RegionServerServices rsServices, HRegionInfo regionInfo, EventHandler.EventType eventType)
           
OpenRootHandler(Server server, RegionServerServices rsServices, HRegionInfo regionInfo)
           
 

Uses of HRegionInfo in org.apache.hadoop.hbase.regionserver.wal
 

Methods in org.apache.hadoop.hbase.regionserver.wal with parameters of type HRegionInfo
 void HLog.append(HRegionInfo info, byte[] tableName, WALEdit edits, long now)
          Append a set of edits to the log.
 void HLog.append(HRegionInfo regionInfo, HLogKey logKey, WALEdit logEdit)
          Append an entry to the log.
 void HLog.append(HRegionInfo regionInfo, WALEdit logEdit, long now, boolean isMetaRegion)
          Append an entry to the log.
protected  void HLog.doWrite(HRegionInfo info, HLogKey logKey, WALEdit logEdit)
           
 void WALObserver.visitLogEntryBeforeWrite(HRegionInfo info, HLogKey logKey, WALEdit logEdit)
          Called before each write.
 

Uses of HRegionInfo in org.apache.hadoop.hbase.replication.regionserver
 

Methods in org.apache.hadoop.hbase.replication.regionserver with parameters of type HRegionInfo
 void Replication.visitLogEntryBeforeWrite(HRegionInfo info, HLogKey logKey, WALEdit logEdit)
           
 

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

Methods in org.apache.hadoop.hbase.util that return HRegionInfo
static HRegionInfo Writables.getHRegionInfo(byte[] bytes)
           
static HRegionInfo Writables.getHRegionInfoOrNull(byte[] bytes)
           
 

Methods in org.apache.hadoop.hbase.util that return types with arguments of type HRegionInfo
 List<HRegionInfo> MetaUtils.getMETARows(byte[] tableName)
           
 

Methods in org.apache.hadoop.hbase.util with parameters of type HRegionInfo
protected static void HBaseFsckRepair.closeRegionSilentlyAndWait(org.apache.hadoop.conf.Configuration conf, HServerAddress server, HRegionInfo region)
           
static void HBaseFsckRepair.fixDupeAssignment(org.apache.hadoop.conf.Configuration conf, HRegionInfo region, List<HServerAddress> servers)
          Fix dupe assignment by doing silent closes on each RS hosting the region and then force ZK unassigned node to OFFLINE to trigger assignment by master.
static void HBaseFsckRepair.fixUnassigned(org.apache.hadoop.conf.Configuration conf, HRegionInfo region)
          Fix unassigned by creating/transition the unassigned ZK node for this region to OFFLINE state with a special flag to tell the master that this is a forced operation by HBCK.
 HRegion MetaUtils.getMetaRegion(HRegionInfo metaInfo)
          Open or return cached opened meta region
 boolean MetaUtils.ScannerListener.processRow(HRegionInfo info)
          Callback so client of scanner can process row contents
 void MetaUtils.scanMetaRegion(HRegionInfo metaRegionInfo, MetaUtils.ScannerListener listener)
          Scans a meta region.
 void MetaUtils.updateMETARegionInfo(HRegion r, HRegionInfo hri)
          Update COL_REGIONINFO in meta region r with HRegionInfo hri
 

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

Methods in org.apache.hadoop.hbase.zookeeper with parameters of type HRegionInfo
static void ZKAssign.asyncCreateNodeOffline(ZooKeeperWatcher zkw, HRegionInfo region, String 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, String serverName)
          Creates a new unassigned node in the CLOSING state for the specified region.
static void ZKAssign.createNodeOffline(ZooKeeperWatcher zkw, HRegionInfo region, String serverName)
          Creates a new unassigned node in the OFFLINE state for the specified region.
static void ZKAssign.createNodeOffline(ZooKeeperWatcher zkw, HRegionInfo region, String serverName, EventHandler.EventType event)
           
static boolean ZKAssign.createOrForceNodeOffline(ZooKeeperWatcher zkw, HRegionInfo region, String serverName)
          Creates or force updates an unassigned node to the OFFLINE state for the specified region.
static boolean ZKAssign.deleteClosingNode(ZooKeeperWatcher zkw, HRegionInfo region)
          Deletes an existing unassigned node that is in the CLOSING state for the specified region.
static void ZKAssign.deleteNodeFailSilent(ZooKeeperWatcher watcher, HRegionInfo regionInfo)
          Delete the assignment node regardless of its current state.
static void ZKAssign.forceNodeOffline(ZooKeeperWatcher zkw, HRegionInfo region, String serverName)
          Forces an existing unassigned node to the OFFLINE state for the specified region.
static int ZKAssign.retransitionNodeOpening(ZooKeeperWatcher zkw, HRegionInfo region, String 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, String serverName, EventHandler.EventType beginState, EventHandler.EventType endState, int expectedVersion)
          Private method that actually performs unassigned node transitions.
static int ZKAssign.transitionNodeClosed(ZooKeeperWatcher zkw, HRegionInfo region, String 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, String 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, String 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, String serverName, EventHandler.EventType beginState)
           
static boolean ZKAssign.verifyRegionState(ZooKeeperWatcher zkw, HRegionInfo region, EventHandler.EventType expectedState)
          Verifies that the specified region is in the specified state in ZooKeeper.
 



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