Uses of Class
org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher

Packages that use ZooKeeperWatcher
org.apache.hadoop.hbase   
org.apache.hadoop.hbase.backup.example   
org.apache.hadoop.hbase.catalog   
org.apache.hadoop.hbase.master   
org.apache.hadoop.hbase.procedure   
org.apache.hadoop.hbase.regionserver   
org.apache.hadoop.hbase.regionserver.handler   
org.apache.hadoop.hbase.regionserver.wal   
org.apache.hadoop.hbase.replication Multi Cluster Replication 
org.apache.hadoop.hbase.security.access   
org.apache.hadoop.hbase.security.token   
org.apache.hadoop.hbase.security.visibility   
org.apache.hadoop.hbase.util.hbck   
org.apache.hadoop.hbase.zookeeper   
org.apache.hadoop.hbase.zookeeper.lock   
 

Uses of ZooKeeperWatcher in org.apache.hadoop.hbase
 

Methods in org.apache.hadoop.hbase that return ZooKeeperWatcher
 ZooKeeperWatcher Server.getZooKeeper()
          Gets the ZooKeeper instance for this server.
 

Constructors in org.apache.hadoop.hbase with parameters of type ZooKeeperWatcher
ZKNamespaceManager(ZooKeeperWatcher zkw)
           
 

Uses of ZooKeeperWatcher in org.apache.hadoop.hbase.backup.example
 

Methods in org.apache.hadoop.hbase.backup.example that return ZooKeeperWatcher
 ZooKeeperWatcher TableHFileArchiveTracker.getZooKeeperWatcher()
           
 

Methods in org.apache.hadoop.hbase.backup.example with parameters of type ZooKeeperWatcher
static String ZKTableArchiveClient.getArchiveZNode(org.apache.hadoop.conf.Configuration conf, ZooKeeperWatcher zooKeeper)
           
 

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

Constructors in org.apache.hadoop.hbase.catalog with parameters of type ZooKeeperWatcher
CatalogTracker(ZooKeeperWatcher zk, org.apache.hadoop.conf.Configuration conf, Abortable abortable)
          Constructs the catalog tracker.
CatalogTracker(ZooKeeperWatcher zk, org.apache.hadoop.conf.Configuration conf, HConnection connection, Abortable abortable)
           
 

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

Methods in org.apache.hadoop.hbase.master that return ZooKeeperWatcher
 ZooKeeperWatcher HMaster.getZooKeeper()
           
 ZooKeeperWatcher HMaster.getZooKeeperWatcher()
          Get the ZK wrapper object - needed by master_jsp.java
 

Methods in org.apache.hadoop.hbase.master with parameters of type ZooKeeperWatcher
static TableLockManager TableLockManager.createTableLockManager(org.apache.hadoop.conf.Configuration conf, ZooKeeperWatcher zkWatcher, ServerName serverName)
          Creates and returns a TableLockManager according to the configuration
static void SplitLogManager.deleteRecoveringRegionZNodes(ZooKeeperWatcher watcher, List<String> regions)
           
static ZooKeeperProtos.RegionStoreSequenceIds SplitLogManager.getRegionFlushedSequenceId(ZooKeeperWatcher zkw, String serverName, String encodedRegionName)
          This function is used in distributedLogReplay to fetch last flushed sequence id from ZK
static boolean SplitLogManager.isRegionMarkedRecoveringInZK(ZooKeeperWatcher zkw, String regionEncodedName)
          check if /hbase/recovering-regions/ exists.
 List<HRegionInfo> RegionStates.serverOffline(ZooKeeperWatcher watcher, ServerName sn)
          A server is offline, all regions on it are dead.
 

Constructors in org.apache.hadoop.hbase.master with parameters of type ZooKeeperWatcher
SplitLogManager(ZooKeeperWatcher zkw, org.apache.hadoop.conf.Configuration conf, Stoppable stopper, MasterServices master, ServerName serverName, boolean masterRecovery)
          Wrapper around SplitLogManager.SplitLogManager(ZooKeeperWatcher zkw, Configuration conf, Stoppable stopper, MasterServices master, ServerName serverName, boolean masterRecovery, TaskFinisher tf) that provides a task finisher for copying recovered edits to their final destination.
SplitLogManager(ZooKeeperWatcher zkw, org.apache.hadoop.conf.Configuration conf, Stoppable stopper, MasterServices master, ServerName serverName, boolean masterRecovery, SplitLogManager.TaskFinisher tf)
          Its OK to construct this object even when region-servers are not online.
 

Uses of ZooKeeperWatcher in org.apache.hadoop.hbase.procedure
 

Methods in org.apache.hadoop.hbase.procedure that return ZooKeeperWatcher
 ZooKeeperWatcher ZKProcedureUtil.getWatcher()
           
 

Constructors in org.apache.hadoop.hbase.procedure with parameters of type ZooKeeperWatcher
ZKProcedureCoordinatorRpcs(ZooKeeperWatcher watcher, String procedureClass, String coordName)
           
ZKProcedureMemberRpcs(ZooKeeperWatcher watcher, String procType)
          Must call ZKProcedureMemberRpcs.start(String, ProcedureMember) before this can be used.
ZKProcedureUtil(ZooKeeperWatcher watcher, String procDescription)
          Top-level watcher/controller for procedures across the cluster.
 

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

Methods in org.apache.hadoop.hbase.regionserver that return ZooKeeperWatcher
 ZooKeeperWatcher HRegionServer.getZooKeeper()
           
 ZooKeeperWatcher HRegionServer.getZooKeeperWatcher()
           
 

Methods in org.apache.hadoop.hbase.regionserver with parameters of type ZooKeeperWatcher
protected static int SplitLogWorker.attemptToOwnTask(boolean isFirstTime, ZooKeeperWatcher zkw, ServerName server, String task, ZooKeeperProtos.SplitLogTask.RecoveryMode mode, int taskZKVersion)
          Try to own the task by transitioning the zk node data from UNASSIGNED to OWNED.
static void RegionMergeTransaction.createNodeMerging(ZooKeeperWatcher zkw, HRegionInfo region, ServerName serverName, HRegionInfo a, HRegionInfo b)
          Creates a new ephemeral node in the PENDING_MERGE state for the merged region.
static void SplitTransaction.createNodeSplitting(ZooKeeperWatcher zkw, HRegionInfo region, ServerName serverName, HRegionInfo a, HRegionInfo b)
          Creates a new ephemeral node in the PENDING_SPLIT state for the specified region.
static int RegionMergeTransaction.transitionMergingNode(ZooKeeperWatcher zkw, HRegionInfo merged, HRegionInfo a, HRegionInfo b, ServerName serverName, int znodeVersion, EventType beginState, EventType endState)
          Transitions an existing ephemeral node for the specified region which is currently in the begin state to be in the end state.
static int SplitTransaction.transitionSplittingNode(ZooKeeperWatcher zkw, HRegionInfo parent, HRegionInfo a, HRegionInfo b, ServerName serverName, int znodeVersion, EventType beginState, EventType endState)
          Transitions an existing ephemeral node for the specified region which is currently in the begin state to be in the end state.
 

Constructors in org.apache.hadoop.hbase.regionserver with parameters of type ZooKeeperWatcher
SplitLogWorker(ZooKeeperWatcher watcher, org.apache.hadoop.conf.Configuration conf, RegionServerServices server, LastSequenceId sequenceIdChecker)
           
SplitLogWorker(ZooKeeperWatcher watcher, org.apache.hadoop.conf.Configuration conf, RegionServerServices server, SplitLogWorker.TaskExecutor splitTaskExecutor)
           
 

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

Methods in org.apache.hadoop.hbase.regionserver.handler with parameters of type ZooKeeperWatcher
static void HLogSplitterHandler.endTask(ZooKeeperWatcher zkw, SplitLogTask slt, AtomicLong ctr, String task, int taskZKVersion)
          endTask() can fail and the only way to recover out of it is for the SplitLogManager to timeout the task node.
 

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

Methods in org.apache.hadoop.hbase.regionserver.wal with parameters of type ZooKeeperWatcher
static boolean HLogSplitter.splitLogFile(org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.fs.FileStatus logfile, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, CancelableProgressable reporter, LastSequenceId idChecker, ZooKeeperWatcher zkw, ZooKeeperProtos.SplitLogTask.RecoveryMode mode)
          Splits a HLog file into region's recovered-edits directory.
 

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

Fields in org.apache.hadoop.hbase.replication declared as ZooKeeperWatcher
protected  ZooKeeperWatcher ReplicationStateZKBase.zookeeper
           
 

Methods in org.apache.hadoop.hbase.replication that return ZooKeeperWatcher
protected  ZooKeeperWatcher HBaseReplicationEndpoint.getZkw()
          Get the ZK connection to this peer
 

Methods in org.apache.hadoop.hbase.replication with parameters of type ZooKeeperWatcher
protected static List<ServerName> HBaseReplicationEndpoint.fetchSlavesAddresses(ZooKeeperWatcher zkw)
          Get the list of all the region servers from the specified peer
static ReplicationPeers ReplicationFactory.getReplicationPeers(ZooKeeperWatcher zk, org.apache.hadoop.conf.Configuration conf, Abortable abortable)
           
static ReplicationQueues ReplicationFactory.getReplicationQueues(ZooKeeperWatcher zk, org.apache.hadoop.conf.Configuration conf, Abortable abortable)
           
static ReplicationQueuesClient ReplicationFactory.getReplicationQueuesClient(ZooKeeperWatcher zk, org.apache.hadoop.conf.Configuration conf, Abortable abortable)
           
static ReplicationTracker ReplicationFactory.getReplicationTracker(ZooKeeperWatcher zookeeper, ReplicationPeers replicationPeers, org.apache.hadoop.conf.Configuration conf, Abortable abortable, Stoppable stopper)
           
 void ReplicationPeerZKImpl.startStateTracker(ZooKeeperWatcher zookeeper, String peerStateNode)
          start a state tracker to check whether this peer is enabled or not
 void ReplicationPeerZKImpl.startTableCFsTracker(ZooKeeperWatcher zookeeper, String tableCFsNode)
          start a table-cfs tracker to listen the (table, cf-list) map change
 

Constructors in org.apache.hadoop.hbase.replication with parameters of type ZooKeeperWatcher
ReplicationPeersZKImpl(ZooKeeperWatcher zk, org.apache.hadoop.conf.Configuration conf, Abortable abortable)
           
ReplicationPeerZKImpl.PeerStateTracker(String peerStateZNode, ZooKeeperWatcher watcher, Abortable abortable)
           
ReplicationPeerZKImpl.TableCFsTracker(String tableCFsZNode, ZooKeeperWatcher watcher, Abortable abortable)
           
ReplicationQueuesClientZKImpl(ZooKeeperWatcher zk, org.apache.hadoop.conf.Configuration conf, Abortable abortable)
           
ReplicationQueuesZKImpl(ZooKeeperWatcher zk, org.apache.hadoop.conf.Configuration conf, Abortable abortable)
           
ReplicationStateZKBase(ZooKeeperWatcher zookeeper, org.apache.hadoop.conf.Configuration conf, Abortable abortable)
           
ReplicationTrackerZKImpl.OtherRegionServerWatcher(ZooKeeperWatcher watcher)
          Construct a ZooKeeper event listener.
ReplicationTrackerZKImpl.PeersWatcher(ZooKeeperWatcher watcher)
          Construct a ZooKeeper event listener.
ReplicationTrackerZKImpl(ZooKeeperWatcher zookeeper, ReplicationPeers replicationPeers, org.apache.hadoop.conf.Configuration conf, Abortable abortable, Stoppable stopper)
           
 

Uses of ZooKeeperWatcher in org.apache.hadoop.hbase.security.access
 

Methods in org.apache.hadoop.hbase.security.access with parameters of type ZooKeeperWatcher
static TableAuthManager TableAuthManager.getOrCreate(ZooKeeperWatcher watcher, org.apache.hadoop.conf.Configuration conf)
          Returns a TableAuthManager from the cache.
 

Constructors in org.apache.hadoop.hbase.security.access with parameters of type ZooKeeperWatcher
ZKPermissionWatcher(ZooKeeperWatcher watcher, TableAuthManager authManager, org.apache.hadoop.conf.Configuration conf)
           
 

Uses of ZooKeeperWatcher in org.apache.hadoop.hbase.security.token
 

Constructors in org.apache.hadoop.hbase.security.token with parameters of type ZooKeeperWatcher
AuthenticationTokenSecretManager(org.apache.hadoop.conf.Configuration conf, ZooKeeperWatcher zk, String serverName, long keyUpdateInterval, long tokenMaxLifetime)
          Create a new secret manager instance for generating keys.
ZKSecretWatcher(org.apache.hadoop.conf.Configuration conf, ZooKeeperWatcher watcher, AuthenticationTokenSecretManager secretManager)
           
 

Uses of ZooKeeperWatcher in org.apache.hadoop.hbase.security.visibility
 

Methods in org.apache.hadoop.hbase.security.visibility with parameters of type ZooKeeperWatcher
static VisibilityLabelsCache VisibilityLabelsCache.createAndGet(ZooKeeperWatcher watcher, org.apache.hadoop.conf.Configuration conf)
          Creates the singleton instance, if not yet present, and returns the same.
 

Constructors in org.apache.hadoop.hbase.security.visibility with parameters of type ZooKeeperWatcher
ZKVisibilityLabelWatcher(ZooKeeperWatcher watcher, VisibilityLabelsCache labelsCache, org.apache.hadoop.conf.Configuration conf)
           
 

Uses of ZooKeeperWatcher in org.apache.hadoop.hbase.util.hbck
 

Constructors in org.apache.hadoop.hbase.util.hbck with parameters of type ZooKeeperWatcher
TableLockChecker(ZooKeeperWatcher zkWatcher, HBaseFsck.ErrorReporter errorReporter)
           
 

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

Fields in org.apache.hadoop.hbase.zookeeper declared as ZooKeeperWatcher
protected  ZooKeeperWatcher ZooKeeperListener.watcher
           
 

Methods in org.apache.hadoop.hbase.zookeeper that return ZooKeeperWatcher
 ZooKeeperWatcher ZooKeeperListener.getWatcher()
           
 

Methods in org.apache.hadoop.hbase.zookeeper with parameters of type ZooKeeperWatcher
static void ZKUtil.asyncCreate(ZooKeeperWatcher zkw, String znode, byte[] data, org.apache.zookeeper.AsyncCallback.StringCallback cb, Object ctx)
          Async creates the specified node with the specified data.
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 ServerName MetaRegionTracker.blockUntilAvailable(ZooKeeperWatcher zkw, long timeout)
          Wait until the meta region is available.
static byte[] ZKUtil.blockUntilAvailable(ZooKeeperWatcher zkw, String znode, long timeout)
           
static void ZKAssign.blockUntilNoRIT(ZooKeeperWatcher zkw)
          Blocks until there are no node in regions in transition.
static void ZKAssign.blockUntilRIT(ZooKeeperWatcher zkw)
          Blocks until there is at least one node in regions in transition.
static boolean ZKAssign.checkClosingState(ZooKeeperWatcher zkw, HRegionInfo region, int expectedVersion)
           
static int ZKUtil.checkExists(ZooKeeperWatcher zkw, String znode)
          Check if the specified node exists.
static ArrayList<org.apache.zookeeper.data.ACL> ZKUtil.createACL(ZooKeeperWatcher zkw, String node, boolean isSecureZooKeeper)
           
static void ZKUtil.createAndFailSilent(ZooKeeperWatcher zkw, String znode)
          Creates the specified node, iff the node does not exist.
static void ZKUtil.createAndFailSilent(ZooKeeperWatcher zkw, String znode, byte[] data)
          Creates the specified node containing specified data, iff the node does not exist.
static int ZKUtil.createAndWatch(ZooKeeperWatcher zkw, String znode, byte[] data)
          Creates the specified node with the specified data and watches it.
static boolean ZKUtil.createEphemeralNodeAndWatch(ZooKeeperWatcher zkw, String znode, byte[] data)
          Set the specified znode to be an ephemeral node carrying the specified data.
static int ZKAssign.createNodeClosing(ZooKeeperWatcher zkw, HRegionInfo region, ServerName serverName)
          Creates a new unassigned node in the CLOSING state for the specified region.
static boolean ZKUtil.createNodeIfNotExistsAndWatch(ZooKeeperWatcher zkw, String znode, byte[] data)
          Creates the specified znode to be a persistent node carrying the specified data.
static String ZKUtil.createNodeIfNotExistsNoWatch(ZooKeeperWatcher zkw, String znode, byte[] data, org.apache.zookeeper.CreateMode createMode)
          Creates the specified znode with the specified data but does not watch it.
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 void ZKUtil.createSetData(ZooKeeperWatcher zkw, String znode, byte[] data)
          Set data into node creating node if it doesn't yet exist.
static void ZKUtil.createWithParents(ZooKeeperWatcher zkw, String znode)
          Creates the specified node and all parent nodes required for it to exist.
static void ZKUtil.createWithParents(ZooKeeperWatcher zkw, String znode, byte[] data)
          Creates the specified node and all parent nodes required for it to exist.
static void ZKAssign.deleteAllNodes(ZooKeeperWatcher zkw)
          Deletes all unassigned nodes regardless of their state.
static void ZKUtil.deleteChildrenRecursively(ZooKeeperWatcher zkw, String node)
          Delete all the children of the specified node but not the node itself.
static void ZKUtil.deleteChildrenRecursivelyMultiOrSequential(ZooKeeperWatcher zkw, boolean runSequentialOnMultiFailure, String... pathRoots)
          Delete all the children of the specified node but not the node itself.
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 MasterAddressTracker.deleteIfEquals(ZooKeeperWatcher zkw, String content)
          delete the master znode if its content is same as the parameter
static void MetaRegionTracker.deleteMetaLocation(ZooKeeperWatcher zookeeper)
          Deletes the location of hbase:meta in ZooKeeper.
static void ZKUtil.deleteNode(ZooKeeperWatcher zkw, String node)
          Delete the specified node.
static boolean ZKAssign.deleteNode(ZooKeeperWatcher zkw, String encodedRegionName, EventType expectedState, int expectedVersion)
          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 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 ZKUtil.deleteNode(ZooKeeperWatcher zkw, String node, int version)
          Delete the specified node with the specified version.
static void ZKAssign.deleteNodeFailSilent(ZooKeeperWatcher watcher, HRegionInfo regionInfo)
          Delete the assignment node regardless of its current state.
static void ZKUtil.deleteNodeFailSilent(ZooKeeperWatcher zkw, String node)
          Deletes the specified node.
static void ZKUtil.deleteNodeRecursively(ZooKeeperWatcher zkw, String node)
          Delete the specified node and all of it's children.
static void ZKUtil.deleteNodeRecursivelyMultiOrSequential(ZooKeeperWatcher zkw, boolean runSequentialOnMultiFailure, String... pathRoots)
          Delete the specified node and its children.
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 String ZKUtil.dump(ZooKeeperWatcher zkw)
           
static List<ZKUtil.NodeAndData> ZKUtil.getChildDataAndWatchForNewChildren(ZooKeeperWatcher zkw, String baseNode)
          Deprecated. Unused
static byte[] ZKAssign.getData(ZooKeeperWatcher zkw, String pathOrRegionName)
          Gets the current data in the unassigned node for the specified region name or fully-qualified path.
static byte[] ZKUtil.getData(ZooKeeperWatcher zkw, String znode)
          Get znode data.
static byte[] ZKUtil.getDataAndWatch(ZooKeeperWatcher zkw, String znode)
          Get the data at the specified znode and set a watch.
static byte[] ZKAssign.getDataAndWatch(ZooKeeperWatcher zkw, String pathOrRegionName, org.apache.zookeeper.data.Stat stat)
          Gets the current data in the unassigned node for the specified region name or fully-qualified path.
static byte[] ZKUtil.getDataAndWatch(ZooKeeperWatcher zkw, String znode, org.apache.zookeeper.data.Stat stat)
          Get the data at the specified znode and set a watch.
static byte[] ZKAssign.getDataNoWatch(ZooKeeperWatcher zkw, String pathOrRegionName, org.apache.zookeeper.data.Stat stat)
          Gets the current data in the unassigned node for the specified region name or fully-qualified path.
static byte[] ZKUtil.getDataNoWatch(ZooKeeperWatcher zkw, String znode, org.apache.zookeeper.data.Stat stat)
          Get the data at the specified znode without setting a watch.
static Set<TableName> ZKTableReadOnly.getDisabledOrDisablingTables(ZooKeeperWatcher zkw)
          Gets a list of all the tables set as disabled in zookeeper.
static Set<TableName> ZKTable.getDisabledOrDisablingTables(ZooKeeperWatcher zkw)
          Gets a list of all the tables set as disabled in zookeeper.
static Set<TableName> ZKTableReadOnly.getDisabledTables(ZooKeeperWatcher zkw)
          Gets a list of all the tables set as disabled in zookeeper.
static Set<TableName> ZKTable.getDisabledTables(ZooKeeperWatcher zkw)
          Gets a list of all the tables set as disabled in zookeeper.
static Set<TableName> ZKTable.getDisablingTables(ZooKeeperWatcher zkw)
          Gets a list of all the tables set as disabling in zookeeper.
static Set<TableName> ZKTable.getEnablingTables(ZooKeeperWatcher zkw)
          Gets a list of all the tables set as enabling in zookeeper.
static String ZKSplitLog.getEncodedNodeName(ZooKeeperWatcher zkw, String filename)
          Gets the full path node name for the log file being split.
static ServerName MasterAddressTracker.getMasterAddress(ZooKeeperWatcher zkw)
          Get master address.
static ServerName MetaRegionTracker.getMetaRegionLocation(ZooKeeperWatcher zkw)
          Gets the meta region location, if available.
static String ZKAssign.getNodeName(ZooKeeperWatcher zkw, String regionName)
          Gets the full path node name for the unassigned node for the specified region.
static int ZKUtil.getNumberOfChildren(ZooKeeperWatcher zkw, String znode)
          Get the number of children of the specified node.
static String ZKAssign.getPath(ZooKeeperWatcher zkw, String pathOrRegionName)
           
static String ZKAssign.getRegionName(ZooKeeperWatcher zkw, String path)
          Gets the region name from the full path node name of an unassigned node.
static String ZKSplitLog.getRescanNode(ZooKeeperWatcher zkw)
           
static UUID ZKClusterId.getUUIDForCluster(ZooKeeperWatcher zkw)
          Get the UUID for the provided ZK watcher.
static int ZKAssign.getVersion(ZooKeeperWatcher zkw, HRegionInfo region)
          Get the version of the specified znode
static boolean ZKTableReadOnly.isDisabledTable(ZooKeeperWatcher zkw, TableName tableName)
          Go to zookeeper and see if state of table is ZooKeeperProtos.Table.State#DISABLED.
static boolean ZKTableReadOnly.isDisablingOrDisabledTable(ZooKeeperWatcher zkw, TableName tableName)
          Go to zookeeper and see if state of table is ZooKeeperProtos.Table.State#DISABLING of ZooKeeperProtos.Table.State#DISABLED.
static boolean ZKTableReadOnly.isEnabledTable(ZooKeeperWatcher zkw, TableName tableName)
          Go to zookeeper and see if state of table is ZooKeeperProtos.Table.State#ENABLED.
static boolean ZKSplitLog.isRescanNode(ZooKeeperWatcher zkw, String path)
           
static boolean ZKSplitLog.isTaskPath(ZooKeeperWatcher zkw, String path)
           
static List<String> ZKUtil.listChildrenAndWatchForNewChildren(ZooKeeperWatcher zkw, String znode)
          Lists the children znodes of the specified znode.
static List<String> ZKUtil.listChildrenAndWatchThem(ZooKeeperWatcher zkw, String znode)
          List all the children of the specified znode, setting a watch for children changes and also setting a watch on every individual child in order to get the NodeCreated and NodeDeleted events.
static List<String> ZKUtil.listChildrenNoWatch(ZooKeeperWatcher zkw, String znode)
          Lists the children of the specified znode without setting any watches.
static void ZKUtil.logZKTree(ZooKeeperWatcher zkw, String root)
          Recursively print the current state of ZK (non-transactional)
protected static void ZKUtil.logZKTree(ZooKeeperWatcher zkw, String root, String prefix)
          Helper method to print the current state of the ZK tree.
static void ZKUtil.multiOrSequential(ZooKeeperWatcher zkw, List<ZKUtil.ZKUtilOp> ops, boolean runSequentialOnMultiFailure)
          If hbase.zookeeper.useMulti is true, use ZooKeeper's multi-update functionality.
static boolean ZKUtil.nodeHasChildren(ZooKeeperWatcher zkw, String znode)
          Checks if the specified znode has any children.
static String ZKClusterId.readClusterIdZNode(ZooKeeperWatcher watcher)
           
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 void ZKClusterId.setClusterId(ZooKeeperWatcher watcher, ClusterId id)
           
static void ZKUtil.setData(ZooKeeperWatcher zkw, String znode, byte[] data)
          Sets the data of the existing znode to be the specified data.
static boolean ZKUtil.setData(ZooKeeperWatcher zkw, String znode, byte[] data, int expectedVersion)
          Sets the data of the existing znode to be the specified data.
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 boolean ZKUtil.setWatchIfNodeExists(ZooKeeperWatcher zkw, String znode)
          Watch the specified znode, but only if exists.
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)
           
static void ZKUtil.updateExistingNodeData(ZooKeeperWatcher zkw, String znode, byte[] data, int expectedVersion)
          Deprecated. Unused
static boolean ZKUtil.watchAndCheckExists(ZooKeeperWatcher zkw, String znode)
          Watch the specified znode for delete/create/change events.
 

Constructors in org.apache.hadoop.hbase.zookeeper with parameters of type ZooKeeperWatcher
ClusterStatusTracker(ZooKeeperWatcher watcher, Abortable abortable)
          Creates a cluster status tracker.
DeletionListener(ZooKeeperWatcher zkWatcher, String pathToWatch, CountDownLatch deletedLatch)
          Create a new instance of the deletion watcher.
DrainingServerTracker(ZooKeeperWatcher watcher, Abortable abortable, ServerManager serverManager)
           
LoadBalancerTracker(ZooKeeperWatcher watcher, Abortable abortable)
           
MasterAddressTracker(ZooKeeperWatcher watcher, Abortable abortable)
          Construct a master address listener with the specified zookeeper reference.
MetaRegionTracker(ZooKeeperWatcher watcher, Abortable abortable)
          Creates a meta region location tracker.
RecoveringRegionWatcher(ZooKeeperWatcher watcher, HRegionServer server)
          Construct a ZooKeeper event listener.
RegionServerTracker(ZooKeeperWatcher watcher, Abortable abortable, ServerManager serverManager)
           
ZKClusterId(ZooKeeperWatcher watcher, Abortable abortable)
           
ZKLeaderManager(ZooKeeperWatcher watcher, String leaderZNode, byte[] identifier, Stoppable candidate)
          Deprecated.  
ZKTable(ZooKeeperWatcher zkw)
           
ZooKeeperListener(ZooKeeperWatcher watcher)
          Construct a ZooKeeper event listener.
ZooKeeperNodeTracker(ZooKeeperWatcher watcher, String node, Abortable abortable)
          Constructs a new ZK node tracker.
 

Uses of ZooKeeperWatcher in org.apache.hadoop.hbase.zookeeper.lock
 

Fields in org.apache.hadoop.hbase.zookeeper.lock declared as ZooKeeperWatcher
protected  ZooKeeperWatcher ZKInterProcessLockBase.zkWatcher
           
 

Constructors in org.apache.hadoop.hbase.zookeeper.lock with parameters of type ZooKeeperWatcher
ZKInterProcessLockBase(ZooKeeperWatcher zkWatcher, String parentLockNode, byte[] metadata, InterProcessLock.MetadataHandler handler, String childNode)
          Called by implementing classes.
ZKInterProcessReadLock(ZooKeeperWatcher zooKeeperWatcher, String znode, byte[] metadata, InterProcessLock.MetadataHandler handler)
           
ZKInterProcessReadWriteLock(ZooKeeperWatcher zkWatcher, String znode, InterProcessLock.MetadataHandler handler)
          Creates a DistributedReadWriteLock instance.
ZKInterProcessWriteLock(ZooKeeperWatcher zooKeeperWatcher, String znode, byte[] metadata, InterProcessLock.MetadataHandler handler)
           
 



Copyright © 2007–2015 The Apache Software Foundation. All rights reserved.