Uses of Class
org.apache.hadoop.hbase.zookeeper.ZKWatcher
Packages that use ZKWatcher
Package
Description
The Region Normalizer subsystem is responsible for coaxing all the regions in a table toward
a "normal" size, according to their storefile size.
Multi Cluster Replication
-
Uses of ZKWatcher in org.apache.hadoop.hbase
Fields in org.apache.hadoop.hbase declared as ZKWatcherModifier and TypeFieldDescriptionprivate ZKWatcherMockRegionServerServices.zkwprotected final ZKWatcherHBaseServerBase.zooKeeperprotected ZKWatcherHBaseZKTestingUtility.zooKeeperWatcherDeprecated.Methods in org.apache.hadoop.hbase that return ZKWatcherModifier and TypeMethodDescriptionHBaseServerBase.getZooKeeper()MockRegionServerServices.getZooKeeper()Server.getZooKeeper()Gets the ZooKeeper instance for this server.HBaseZKTestingUtility.getZooKeeperWatcher()Deprecated.Returns a ZKWatcher instance.static ZKWatcherHBaseZKTestingUtility.getZooKeeperWatcher(HBaseZKTestingUtility testUtil) Deprecated.Gets a ZKWatcher.Methods in org.apache.hadoop.hbase with parameters of type ZKWatcherModifier and TypeMethodDescriptionvoidHBaseTestingUtility.expireSession(ZKWatcher nodeZK) Deprecated.voidHBaseTestingUtility.expireSession(ZKWatcher nodeZK, boolean checkStatus) Deprecated.Expire a ZooKeeper session as recommended in ZooKeeper documentation http://hbase.apache.org/book.html#trouble.zookeeper There are issues when doing this: [1] http://www.mail-archive.com/dev@zookeeper.apache.org/msg01942.html [2] https://issues.apache.org/jira/browse/ZOOKEEPER-1105protected final voidHBaseRpcServicesBase.internalStart(ZKWatcher zkWatcher) Constructors in org.apache.hadoop.hbase with parameters of type ZKWatcherModifierConstructorDescriptionMetaRegionLocationCache(ZKWatcher zkWatcher) MockRegionServerServices(ZKWatcher zkw, ServerName serverName) -
Uses of ZKWatcher in org.apache.hadoop.hbase.backup.example
Fields in org.apache.hadoop.hbase.backup.example declared as ZKWatcherMethods in org.apache.hadoop.hbase.backup.example that return ZKWatcherMethods in org.apache.hadoop.hbase.backup.example with parameters of type ZKWatcherModifier and TypeMethodDescriptionprivate static TableHFileArchiveTrackerTableHFileArchiveTracker.create(ZKWatcher zkw, HFileArchiveTableMonitor monitor) Create an archive tracker with the special passed in table monitor.private voidDisable all archiving of files for a given tableprivate voidPerform a best effort enable of hfile retention, which relies on zookeeper communicating the change back to the hfile cleaner.static StringZKTableArchiveClient.getArchiveZNode(org.apache.hadoop.conf.Configuration conf, ZKWatcher zooKeeper) Constructors in org.apache.hadoop.hbase.backup.example with parameters of type ZKWatcherModifierConstructorDescriptionprivateTableHFileArchiveTracker(ZKWatcher watcher, HFileArchiveTableMonitor monitor) -
Uses of ZKWatcher in org.apache.hadoop.hbase.coordination
Fields in org.apache.hadoop.hbase.coordination declared as ZKWatcherModifier and TypeFieldDescriptionprotected ZKWatcherZkCoordinatedStateManager.watcherDeprecated.Methods in org.apache.hadoop.hbase.coordination with parameters of type ZKWatcherModifier and TypeMethodDescriptionprotected static intZkSplitLogWorkerCoordination.attemptToOwnTask(boolean isFirstTime, ZKWatcher zkw, ServerName server, String task, int taskZKVersion) Try to own the task by transitioning the zk node data from UNASSIGNED to OWNED.Constructors in org.apache.hadoop.hbase.coordination with parameters of type ZKWatcherModifierConstructorDescriptionZKSplitLogManagerCoordination(org.apache.hadoop.conf.Configuration conf, ZKWatcher watcher) ZkSplitLogWorkerCoordination(ServerName serverName, ZKWatcher watcher) -
Uses of ZKWatcher in org.apache.hadoop.hbase.master
Methods in org.apache.hadoop.hbase.master with parameters of type ZKWatcherModifier and TypeMethodDescriptionprotected ActiveMasterManagerHMaster.createActiveMasterManager(ZKWatcher zk, ServerName sn, Server server) Protected to have custom implementations in tests override the default ActiveMaster implementation.ServerManager.getRegionServersInZK(ZKWatcher zkw) private byte[](package private) voidprivate voidMasterStateStore.tryMigrate(ZKWatcher watcher, String zkPath) Constructors in org.apache.hadoop.hbase.master with parameters of type ZKWatcherModifierConstructorDescription(package private)ActiveMasterManager(ZKWatcher watcher, ServerName sn, Server master) protectedBooleanStateStore(MasterRegion masterRegion, String stateName, ZKWatcher watcher, String zkPath) DrainingServerTracker(ZKWatcher watcher, Abortable abortable, ServerManager serverManager) protectedMasterStateStore(MasterRegion masterRegion, String stateName, ZKWatcher watcher, String zkPath) RegionServerTracker(ZKWatcher watcher, MasterServices server) SplitOrMergeStateStore(MasterRegion masterRegion, ZKWatcher watcher, org.apache.hadoop.conf.Configuration conf) SwitchStateStore(MasterRegion masterRegion, String stateName, ZKWatcher watcher, String zkPath) -
Uses of ZKWatcher in org.apache.hadoop.hbase.master.balancer
Constructors in org.apache.hadoop.hbase.master.balancer with parameters of type ZKWatcherModifierConstructorDescriptionLoadBalancerStateStore(MasterRegion masterRegion, ZKWatcher watcher) -
Uses of ZKWatcher in org.apache.hadoop.hbase.master.normalizer
Methods in org.apache.hadoop.hbase.master.normalizer with parameters of type ZKWatcherModifier and TypeMethodDescriptionstatic RegionNormalizerManagerRegionNormalizerFactory.createNormalizerManager(org.apache.hadoop.conf.Configuration conf, MasterRegion masterRegion, ZKWatcher zkWatcher, HMaster master) Constructors in org.apache.hadoop.hbase.master.normalizer with parameters of type ZKWatcherModifierConstructorDescriptionRegionNormalizerStateStore(MasterRegion masterRegion, ZKWatcher watcher) -
Uses of ZKWatcher in org.apache.hadoop.hbase.master.replication
Fields in org.apache.hadoop.hbase.master.replication declared as ZKWatcherMethods in org.apache.hadoop.hbase.master.replication with parameters of type ZKWatcherModifier and TypeMethodDescription(package private) CompletableFuture<Void>ReplicationPeerManager.migrateQueuesFromZk(ZKWatcher zookeeper, ExecutorService executor) Submit the migration tasks to the givenexecutor.Constructors in org.apache.hadoop.hbase.master.replication with parameters of type ZKWatcherModifierConstructorDescription(package private)ReplicationPeerManager(org.apache.hadoop.fs.FileSystem fs, ZKWatcher zk, ReplicationPeerStorage peerStorage, ReplicationQueueStorage queueStorage, ConcurrentMap<String, ReplicationPeerDescription> peers, org.apache.hadoop.conf.Configuration conf, String clusterId, ReplicationPeerManager.ReplicationQueueStorageInitializer queueStorageInitializer) -
Uses of ZKWatcher in org.apache.hadoop.hbase.master.snapshot
Constructors in org.apache.hadoop.hbase.master.snapshot with parameters of type ZKWatcherModifierConstructorDescriptionSnapshotCleanupStateStore(MasterRegion masterRegion, ZKWatcher watcher) -
Uses of ZKWatcher in org.apache.hadoop.hbase.master.zksyncer
Fields in org.apache.hadoop.hbase.master.zksyncer declared as ZKWatcherConstructors in org.apache.hadoop.hbase.master.zksyncer with parameters of type ZKWatcherModifierConstructorDescriptionClientZKSyncer(ZKWatcher watcher, ZKWatcher clientZkWatcher, Server server) MasterAddressSyncer(ZKWatcher watcher, ZKWatcher clientZkWatcher, Server server) MetaLocationSyncer(ZKWatcher watcher, ZKWatcher clientZkWatcher, Server server) -
Uses of ZKWatcher in org.apache.hadoop.hbase.procedure
Fields in org.apache.hadoop.hbase.procedure declared as ZKWatcherModifier and TypeFieldDescription(package private) ZKWatcherZKProcedureCoordinationManager.watcher(package private) ZKWatcherZKProcedureCoordinator.watcherMethods in org.apache.hadoop.hbase.procedure that return ZKWatcherConstructors in org.apache.hadoop.hbase.procedure with parameters of type ZKWatcherModifierConstructorDescriptionZKProcedureCoordinator(ZKWatcher watcher, String procedureClass, String coordName) ZKProcedureMemberRpcs(ZKWatcher watcher, String procType) Must callZKProcedureMemberRpcs.start(String, ProcedureMember)before this can be used.ZKProcedureUtil(ZKWatcher watcher, String procDescription) Top-level watcher/controller for procedures across the cluster. -
Uses of ZKWatcher in org.apache.hadoop.hbase.quotas
Fields in org.apache.hadoop.hbase.quotas declared as ZKWatcherConstructors in org.apache.hadoop.hbase.quotas with parameters of type ZKWatcherModifierConstructorDescriptionRpcThrottleStorage(ZKWatcher zookeeper, org.apache.hadoop.conf.Configuration conf) -
Uses of ZKWatcher in org.apache.hadoop.hbase.regionserver
Methods in org.apache.hadoop.hbase.regionserver with parameters of type ZKWatcher -
Uses of ZKWatcher in org.apache.hadoop.hbase.replication
Fields in org.apache.hadoop.hbase.replication declared as ZKWatcherModifier and TypeFieldDescriptionprivate final ZKWatcherReplicationPeers.zookeeperprotected final ZKWatcherZKReplicationStorageBase.zookeeperMethods in org.apache.hadoop.hbase.replication that return ZKWatcherMethods in org.apache.hadoop.hbase.replication with parameters of type ZKWatcherModifier and TypeMethodDescriptionprivate ReplicationPeerStoragestatic ReplicationPeersReplicationFactory.getReplicationPeers(org.apache.hadoop.fs.FileSystem fs, ZKWatcher zk, org.apache.hadoop.conf.Configuration conf) static ReplicationPeerStorageReplicationStorageFactory.getReplicationPeerStorage(org.apache.hadoop.fs.FileSystem fs, ZKWatcher zk, org.apache.hadoop.conf.Configuration conf) Create a newReplicationPeerStorage.Constructors in org.apache.hadoop.hbase.replication with parameters of type ZKWatcherModifierConstructorDescription(package private)ReplicationPeers(org.apache.hadoop.fs.FileSystem fs, ZKWatcher zookeeper, org.apache.hadoop.conf.Configuration conf) ZKReplicationPeerStorage(ZKWatcher zookeeper, org.apache.hadoop.conf.Configuration conf) ZKReplicationQueueStorageForMigration(ZKWatcher zookeeper, org.apache.hadoop.conf.Configuration conf) protectedZKReplicationStorageBase(ZKWatcher zookeeper, org.apache.hadoop.conf.Configuration conf) -
Uses of ZKWatcher in org.apache.hadoop.hbase.replication.regionserver
Fields in org.apache.hadoop.hbase.replication.regionserver declared as ZKWatcherMethods in org.apache.hadoop.hbase.replication.regionserver that return ZKWatcherConstructors in org.apache.hadoop.hbase.replication.regionserver with parameters of type ZKWatcherModifierConstructorDescription(package private)DummyServer(org.apache.hadoop.conf.Configuration conf, ZKWatcher zkw) -
Uses of ZKWatcher in org.apache.hadoop.hbase.rsgroup
Fields in org.apache.hadoop.hbase.rsgroup declared as ZKWatcher -
Uses of ZKWatcher in org.apache.hadoop.hbase.security.access
Constructors in org.apache.hadoop.hbase.security.access with parameters of type ZKWatcherModifierConstructorDescriptionZKPermissionWatcher(ZKWatcher watcher, AuthManager authManager, org.apache.hadoop.conf.Configuration conf) -
Uses of ZKWatcher in org.apache.hadoop.hbase.security.token
Constructors in org.apache.hadoop.hbase.security.token with parameters of type ZKWatcherModifierConstructorDescriptionAuthenticationTokenSecretManager(org.apache.hadoop.conf.Configuration conf, ZKWatcher zk, String serverName, long keyUpdateInterval, long tokenMaxLifetime) Create a new secret manager instance for generating keys.LeaderElector(ZKWatcher watcher, String serverName) ZKSecretWatcher(org.apache.hadoop.conf.Configuration conf, ZKWatcher watcher, AuthenticationTokenSecretManager secretManager) -
Uses of ZKWatcher in org.apache.hadoop.hbase.security.visibility
Methods in org.apache.hadoop.hbase.security.visibility with parameters of type ZKWatcherModifier and TypeMethodDescriptionstatic VisibilityLabelsCacheVisibilityLabelsCache.createAndGet(ZKWatcher 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 ZKWatcherModifierConstructorDescriptionprivateVisibilityLabelsCache(ZKWatcher watcher, org.apache.hadoop.conf.Configuration conf) ZKVisibilityLabelWatcher(ZKWatcher watcher, VisibilityLabelsCache labelsCache, org.apache.hadoop.conf.Configuration conf) -
Uses of ZKWatcher in org.apache.hadoop.hbase.util
Fields in org.apache.hadoop.hbase.util declared as ZKWatcherMethods in org.apache.hadoop.hbase.util that return ZKWatcherModifier and TypeMethodDescriptionprivate ZKWatcherHBaseFsck.createZooKeeperWatcher()Deprecated.Methods in org.apache.hadoop.hbase.util with parameters of type ZKWatcherModifier and TypeMethodDescriptionstatic StringZKStringFormatter.formatZKString(ZKWatcher zookeeper) -
Uses of ZKWatcher in org.apache.hadoop.hbase.util.hbck
Constructors in org.apache.hadoop.hbase.util.hbck with parameters of type ZKWatcherModifierConstructorDescriptionReplicationChecker(org.apache.hadoop.conf.Configuration conf, ZKWatcher zkw, Connection conn, HbckErrorReporter errorReporter) -
Uses of ZKWatcher in org.apache.hadoop.hbase.zookeeper
Fields in org.apache.hadoop.hbase.zookeeper declared as ZKWatcherModifier and TypeFieldDescriptionprivate final ZKWatcherZKClusterId.watcherprotected ZKWatcherZKListener.watcherMethods in org.apache.hadoop.hbase.zookeeper that return ZKWatcherModifier and TypeMethodDescriptionZKListener.getWatcher()Returns The watcher associated with this listenerMethods in org.apache.hadoop.hbase.zookeeper with parameters of type ZKWatcherModifier and TypeMethodDescriptionprivate static voidZKDump.appendHFileRefsZNodes(ZKWatcher zkw, String hFileRefsZNode, StringBuilder sb) private static voidZKDump.appendPeerState(ZKWatcher zkw, String znodeToProcess, StringBuilder sb) private static voidZKDump.appendPeersZnodes(ZKWatcher zkw, String peersZnode, StringBuilder sb) private static voidZKDump.appendRSZnodes(ZKWatcher zkw, String znode, StringBuilder sb) static voidZKUtil.asyncCreate(ZKWatcher zkw, String znode, byte[] data, org.apache.zookeeper.AsyncCallback.StringCallback cb, Object ctx) Async creates the specified node with the specified data.private static ServerNameMetaTableLocator.blockUntilAvailable(ZKWatcher zkw, int replicaId, long timeout) Wait until the meta region is available and is not in transition.static intZKUtil.checkExists(ZKWatcher zkw, String znode) Check if the specified node exists.static voidZKUtil.createAndFailSilent(ZKWatcher zkw, String znode) Creates the specified node, iff the node does not exist.static voidZKUtil.createAndFailSilent(ZKWatcher zkw, String znode, byte[] data) Creates the specified node containing specified data, iff the node does not exist.private static voidZKUtil.createAndFailSilent(ZKWatcher zkw, ZKUtil.ZKUtilOp.CreateAndFailSilent cafs) static intZKUtil.createAndWatch(ZKWatcher zkw, String znode, byte[] data) Creates the specified node with the specified data and watches it.static booleanZKUtil.createEphemeralNodeAndWatch(ZKWatcher zkw, String znode, byte[] data) Set the specified znode to be an ephemeral node carrying the specified data.static booleanZKUtil.createNodeIfNotExistsAndWatch(ZKWatcher zkw, String znode, byte[] data) Creates the specified znode to be a persistent node carrying the specified data.static StringZKUtil.createNodeIfNotExistsNoWatch(ZKWatcher zkw, String znode, byte[] data, org.apache.zookeeper.CreateMode createMode) Creates the specified znode with the specified data but does not watch it.static voidZKUtil.createSetData(ZKWatcher zkw, String znode, byte[] data) Set data into node creating node if it doesn't yet exist.static voidZKUtil.createWithParents(ZKWatcher zkw, String znode) Creates the specified node and all parent nodes required for it to exist.static voidZKUtil.createWithParents(ZKWatcher zkw, String znode, byte[] data) Creates the specified node and all parent nodes required for it to exist.static voidZKUtil.deleteChildrenRecursively(ZKWatcher zkw, String node) Delete all the children of the specified node but not the node itself.static voidZKUtil.deleteChildrenRecursivelyMultiOrSequential(ZKWatcher zkw, boolean runSequentialOnMultiFailure, String... pathRoots) Delete all the children of the specified node but not the node itself.static booleanMasterAddressTracker.deleteIfEquals(ZKWatcher zkw, String content) delete the master znode if its content is same as the parameterstatic voidMetaTableLocator.deleteMetaLocation(ZKWatcher zookeeper) Deletes the location ofhbase:metain ZooKeeper.static voidMetaTableLocator.deleteMetaLocation(ZKWatcher zookeeper, int replicaId) static voidZKUtil.deleteNode(ZKWatcher zkw, String node) Delete the specified node.static booleanZKUtil.deleteNode(ZKWatcher zkw, String node, int version) Delete the specified node with the specified version.static voidZKUtil.deleteNodeFailSilent(ZKWatcher zkw, String node) Deletes the specified node.private static voidZKUtil.deleteNodeFailSilent(ZKWatcher zkw, ZKUtil.ZKUtilOp.DeleteNodeFailSilent dnfs) static voidZKUtil.deleteNodeRecursively(ZKWatcher zkw, String node) Delete the specified node and all of it's children.static voidZKUtil.deleteNodeRecursivelyMultiOrSequential(ZKWatcher zkw, boolean runSequentialOnMultiFailure, String... pathRoots) Delete the specified node and its children.static Stringstatic intMasterAddressTracker.getBackupMasterInfoPort(ZKWatcher zkw, ServerName sn) Get backup master info port.static List<ServerName>MasterAddressTracker.getBackupMastersAndRenewWatch(ZKWatcher zkw) Retrieves the list of registered backup masters and renews a watch on the znode for children updates.static List<ZKUtil.NodeAndData>ZKUtil.getChildDataAndWatchForNewChildren(ZKWatcher zkw, String baseNode) Deprecated.Unusedstatic List<ZKUtil.NodeAndData>ZKUtil.getChildDataAndWatchForNewChildren(ZKWatcher zkw, String baseNode, boolean throwOnInterrupt) Deprecated.Unusedstatic byte[]Get znode data.static byte[]ZKUtil.getDataAndWatch(ZKWatcher zkw, String znode) Get the data at the specified znode and set a watch.static byte[]ZKUtil.getDataAndWatch(ZKWatcher zkw, String znode, boolean throwOnInterrupt) Get the data at the specified znode and set a watch.static byte[]ZKUtil.getDataAndWatch(ZKWatcher zkw, String znode, org.apache.zookeeper.data.Stat stat) Get the data at the specified znode and set a watch.private static byte[]ZKUtil.getDataInternal(ZKWatcher zkw, String znode, org.apache.zookeeper.data.Stat stat, boolean watcherSet, boolean throwOnInterrupt) static byte[]ZKUtil.getDataNoWatch(ZKWatcher zkw, String znode, org.apache.zookeeper.data.Stat stat) Get the data at the specified znode without setting a watch.static StringZKSplitLog.getEncodedNodeName(ZKWatcher zkw, String filename) Deprecated.Gets the full path node name for the log file being split.static ServerNameMasterAddressTracker.getMasterAddress(ZKWatcher zkw) Get master address.static intMasterAddressTracker.getMasterInfoPort(ZKWatcher zkw) Get master info port.static ServerNameMetaTableLocator.getMetaRegionLocation(ZKWatcher zkw) Gets the meta region location, if available.static ServerNameMetaTableLocator.getMetaRegionLocation(ZKWatcher zkw, int replicaId) Gets the meta region location, if available.static RegionStateMetaTableLocator.getMetaRegionState(ZKWatcher zkw) Load the meta region state from the meta server ZNode.static RegionStateMetaTableLocator.getMetaRegionState(ZKWatcher zkw, int replicaId) Load the meta region state from the meta region server ZNode.static intZKUtil.getNumberOfChildren(ZKWatcher zkw, String znode) Get the number of children of the specified node.static StringZKDump.getReplicationZnodesDump(ZKWatcher zkw) Returns a string with replication znodes and position of the replication logprivate static voidZKDump.getReplicationZnodesDump(ZKWatcher zkw, StringBuilder sb) Appends replication znodes to the passed StringBuilder.static StringZKSplitLog.getRescanNode(ZKWatcher zkw) Deprecated.static UUIDZKClusterId.getUUIDForCluster(ZKWatcher zkw) Get the UUID for the provided ZK watcher.static booleanZKSplitLog.isRescanNode(ZKWatcher zkw, String path) Deprecated.Checks if the given path represents a rescan node.ZKUtil.listChildrenAndWatchForNewChildren(ZKWatcher zkw, String znode) Lists the children znodes of the specified znode.ZKUtil.listChildrenAndWatchThem(ZKWatcher 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.ZKUtil.listChildrenBFSNoWatch(ZKWatcher zkw, String znode) BFS Traversal of all the children under path, with the entries in the list, in the same order as that of the traversal.ZKUtil.listChildrenNoWatch(ZKWatcher zkw, String znode) Lists the children of the specified znode without setting any watches.private static voidZKUtil.logRetrievedMsg(ZKWatcher zkw, String znode, byte[] data, boolean watcherSet) static voidRecursively print the current state of ZK (non-transactional)private static voidHelper method to print the current state of the ZK tree.static voidZKUtil.multiOrSequential(ZKWatcher zkw, List<ZKUtil.ZKUtilOp> ops, boolean runSequentialOnMultiFailure) Use ZooKeeper's multi-update functionality.static booleanZKUtil.nodeHasChildren(ZKWatcher zkw, String znode) Checks if the specified znode has any children.private static voidZKUtil.processSequentially(ZKWatcher zkw, List<ZKUtil.ZKUtilOp> ops) static StringZKClusterId.readClusterIdZNode(ZKWatcher watcher) private static voidstatic voidZKClusterId.setClusterId(ZKWatcher watcher, ClusterId id) static voidSets the data of the existing znode to be the specified data.static booleanSets the data of the existing znode to be the specified data.private static voidZKUtil.setData(ZKWatcher zkw, ZKUtil.ZKUtilOp.SetData setData) static booleanMasterAddressTracker.setMasterAddress(ZKWatcher zkw, String znode, ServerName master, int infoPort) Set master address into themasterznode or into the backup subdirectory of backup masters; switch off the passed inznodepath.static voidMetaTableLocator.setMetaLocation(ZKWatcher zookeeper, ServerName serverName, int replicaId, RegionState.State state) Sets the location ofhbase:metain ZooKeeper to the specified server address.static voidMetaTableLocator.setMetaLocation(ZKWatcher zookeeper, ServerName serverName, RegionState.State state) Sets the location ofhbase:metain ZooKeeper to the specified server address.static booleanZKUtil.setWatchIfNodeExists(ZKWatcher zkw, String znode) Watch the specified znode, but only if exists.private static voidZKUtil.submitBatchedMultiOrSequential(ZKWatcher zkw, boolean runSequentialOnMultiFailure, List<ZKUtil.ZKUtilOp> ops) Chunks the providedopswhen their approximate size exceeds the the configured limit.private static org.apache.zookeeper.OpZKUtil.toZooKeeperOp(ZKWatcher zkw, ZKUtil.ZKUtilOp op) Convert from ZKUtilOp to ZKOpstatic voidZKUtil.updateExistingNodeData(ZKWatcher zkw, String znode, byte[] data, int expectedVersion) Deprecated.Unusedprivate static ServerNameMetaTableLocator.waitMetaRegionLocation(ZKWatcher zkw, int replicaId, long timeout) Gets the meta region location, if available, and waits for up to the specified timeout if not immediately available.static ServerNameMetaTableLocator.waitMetaRegionLocation(ZKWatcher zkw, long timeout) Gets the meta region location, if available, and waits for up to the specified timeout if not immediately available.static booleanZKUtil.watchAndCheckExists(ZKWatcher zkw, String znode) Watch the specified znode for delete/create/change events.Constructors in org.apache.hadoop.hbase.zookeeper with parameters of type ZKWatcherModifierConstructorDescriptionClusterStatusTracker(ZKWatcher watcher, Abortable abortable) Creates a cluster status tracker.DeletionListener(ZKWatcher zkWatcher, String pathToWatch, CountDownLatch deletedLatch) Create a new instance of the deletion watcher.MasterAddressTracker(ZKWatcher watcher, Abortable abortable) Construct a master address listener with the specifiedzookeeperreference.MasterMaintenanceModeTracker(ZKWatcher watcher) ZKClusterId(ZKWatcher watcher, Abortable abortable) ZKLeaderManager(ZKWatcher watcher, String leaderZNode, byte[] identifier, Stoppable candidate) Deprecated.ZKListener(ZKWatcher watcher) Construct a ZooKeeper event listener.ZKNodeTracker(ZKWatcher watcher, String node, Abortable abortable) Constructs a new ZK node tracker.