Uses of Class
org.apache.hadoop.hbase.zookeeper.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
Modifier and TypeFieldDescriptionprivate ZKWatcher
MockRegionServerServices.zkw
protected final ZKWatcher
HBaseServerBase.zooKeeper
protected ZKWatcher
HBaseZKTestingUtility.zooKeeperWatcher
Deprecated.Modifier and TypeMethodDescriptionHBaseServerBase.getZooKeeper()
MockRegionServerServices.getZooKeeper()
Server.getZooKeeper()
Gets the ZooKeeper instance for this server.HBaseZKTestingUtility.getZooKeeperWatcher()
Deprecated.Returns a ZKWatcher instance.static ZKWatcher
HBaseZKTestingUtility.getZooKeeperWatcher
(HBaseZKTestingUtility testUtil) Deprecated.Gets a ZKWatcher.Modifier and TypeMethodDescriptionvoid
HBaseTestingUtility.expireSession
(ZKWatcher nodeZK) Deprecated.void
HBaseTestingUtility.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 void
HBaseRpcServicesBase.internalStart
(ZKWatcher zkWatcher) ModifierConstructorDescriptionMetaRegionLocationCache
(ZKWatcher zkWatcher) MockRegionServerServices
(ZKWatcher zkw, ServerName serverName) -
Uses of ZKWatcher in org.apache.hadoop.hbase.backup.example
Modifier and TypeMethodDescriptionprivate static TableHFileArchiveTracker
TableHFileArchiveTracker.create
(ZKWatcher zkw, HFileArchiveTableMonitor monitor) Create an archive tracker with the special passed in table monitor.private void
Disable all archiving of files for a given tableprivate void
Perform a best effort enable of hfile retention, which relies on zookeeper communicating the change back to the hfile cleaner.static String
ZKTableArchiveClient.getArchiveZNode
(org.apache.hadoop.conf.Configuration conf, ZKWatcher zooKeeper) ModifierConstructorDescriptionprivate
TableHFileArchiveTracker
(ZKWatcher watcher, HFileArchiveTableMonitor monitor) -
Uses of ZKWatcher in org.apache.hadoop.hbase.coordination
Modifier and TypeFieldDescriptionprotected ZKWatcher
ZkCoordinatedStateManager.watcher
Deprecated.Modifier and TypeMethodDescriptionprotected static int
ZkSplitLogWorkerCoordination.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.ModifierConstructorDescriptionZKSplitLogManagerCoordination
(org.apache.hadoop.conf.Configuration conf, ZKWatcher watcher) ZkSplitLogWorkerCoordination
(ServerName serverName, ZKWatcher watcher) -
Uses of ZKWatcher in org.apache.hadoop.hbase.master
Modifier and TypeMethodDescriptionprotected ActiveMasterManager
HMaster.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) void
private void
MasterStateStore.tryMigrate
(ZKWatcher watcher, String zkPath) ModifierConstructorDescription(package private)
ActiveMasterManager
(ZKWatcher watcher, ServerName sn, Server master) protected
BooleanStateStore
(MasterRegion masterRegion, String stateName, ZKWatcher watcher, String zkPath) DrainingServerTracker
(ZKWatcher watcher, Abortable abortable, ServerManager serverManager) protected
MasterStateStore
(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
ModifierConstructorDescriptionLoadBalancerStateStore
(MasterRegion masterRegion, ZKWatcher watcher) -
Uses of ZKWatcher in org.apache.hadoop.hbase.master.normalizer
Modifier and TypeMethodDescriptionstatic RegionNormalizerManager
RegionNormalizerFactory.createNormalizerManager
(org.apache.hadoop.conf.Configuration conf, MasterRegion masterRegion, ZKWatcher zkWatcher, HMaster master) ModifierConstructorDescriptionRegionNormalizerStateStore
(MasterRegion masterRegion, ZKWatcher watcher) -
Uses of ZKWatcher in org.apache.hadoop.hbase.master.replication
Modifier and TypeMethodDescription(package private) CompletableFuture<Void>
ReplicationPeerManager.migrateQueuesFromZk
(ZKWatcher zookeeper, ExecutorService executor) Submit the migration tasks to the givenexecutor
.ModifierConstructorDescription(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
ModifierConstructorDescriptionSnapshotCleanupStateStore
(MasterRegion masterRegion, ZKWatcher watcher) -
Uses of ZKWatcher in org.apache.hadoop.hbase.master.zksyncer
ModifierConstructorDescriptionClientZKSyncer
(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
Modifier and TypeFieldDescription(package private) ZKWatcher
ZKProcedureCoordinationManager.watcher
(package private) ZKWatcher
ZKProcedureCoordinator.watcher
ModifierConstructorDescriptionZKProcedureCoordinator
(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
ModifierConstructorDescriptionRpcThrottleStorage
(ZKWatcher zookeeper, org.apache.hadoop.conf.Configuration conf) -
Uses of ZKWatcher in org.apache.hadoop.hbase.regionserver
-
Uses of ZKWatcher in org.apache.hadoop.hbase.replication
Modifier and TypeFieldDescriptionprivate final ZKWatcher
ReplicationPeers.zookeeper
protected final ZKWatcher
ZKReplicationStorageBase.zookeeper
Modifier and TypeMethodDescriptionprivate ReplicationPeerStorage
static ReplicationPeers
ReplicationFactory.getReplicationPeers
(org.apache.hadoop.fs.FileSystem fs, ZKWatcher zk, org.apache.hadoop.conf.Configuration conf) static ReplicationPeerStorage
ReplicationStorageFactory.getReplicationPeerStorage
(org.apache.hadoop.fs.FileSystem fs, ZKWatcher zk, org.apache.hadoop.conf.Configuration conf) Create a newReplicationPeerStorage
.ModifierConstructorDescription(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) protected
ZKReplicationStorageBase
(ZKWatcher zookeeper, org.apache.hadoop.conf.Configuration conf) -
Uses of ZKWatcher in org.apache.hadoop.hbase.replication.regionserver
ModifierConstructorDescription(package private)
DummyServer
(org.apache.hadoop.conf.Configuration conf, ZKWatcher zkw) -
Uses of ZKWatcher in org.apache.hadoop.hbase.rsgroup
-
Uses of ZKWatcher in org.apache.hadoop.hbase.security.access
ModifierConstructorDescriptionZKPermissionWatcher
(ZKWatcher watcher, AuthManager authManager, org.apache.hadoop.conf.Configuration conf) -
Uses of ZKWatcher in org.apache.hadoop.hbase.security.token
ModifierConstructorDescriptionAuthenticationTokenSecretManager
(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
Modifier and TypeMethodDescriptionstatic VisibilityLabelsCache
VisibilityLabelsCache.createAndGet
(ZKWatcher watcher, org.apache.hadoop.conf.Configuration conf) Creates the singleton instance, if not yet present, and returns the same.ModifierConstructorDescriptionprivate
VisibilityLabelsCache
(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
Modifier and TypeMethodDescriptionprivate ZKWatcher
HBaseFsck.createZooKeeperWatcher()
Deprecated. -
Uses of ZKWatcher in org.apache.hadoop.hbase.util.hbck
ModifierConstructorDescriptionReplicationChecker
(org.apache.hadoop.conf.Configuration conf, ZKWatcher zkw, Connection conn, HbckErrorReporter errorReporter) -
Uses of ZKWatcher in org.apache.hadoop.hbase.zookeeper
Modifier and TypeFieldDescriptionprivate final ZKWatcher
ZKClusterId.watcher
protected ZKWatcher
ZKListener.watcher
Modifier and TypeMethodDescriptionZKListener.getWatcher()
Returns The watcher associated with this listenerModifier and TypeMethodDescriptionprivate static void
ZKDump.appendHFileRefsZNodes
(ZKWatcher zkw, String hFileRefsZNode, StringBuilder sb) private static void
ZKDump.appendPeerState
(ZKWatcher zkw, String znodeToProcess, StringBuilder sb) private static void
ZKDump.appendPeersZnodes
(ZKWatcher zkw, String peersZnode, StringBuilder sb) private static void
ZKDump.appendRSZnodes
(ZKWatcher zkw, String znode, StringBuilder sb) static void
ZKUtil.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 ServerName
MetaTableLocator.blockUntilAvailable
(ZKWatcher zkw, int replicaId, long timeout) Wait until the meta region is available and is not in transition.static int
ZKUtil.checkExists
(ZKWatcher zkw, String znode) Check if the specified node exists.static void
ZKUtil.createAndFailSilent
(ZKWatcher zkw, String znode) Creates the specified node, iff the node does not exist.static void
ZKUtil.createAndFailSilent
(ZKWatcher zkw, String znode, byte[] data) Creates the specified node containing specified data, iff the node does not exist.private static void
ZKUtil.createAndFailSilent
(ZKWatcher zkw, ZKUtil.ZKUtilOp.CreateAndFailSilent cafs) static int
ZKUtil.createAndWatch
(ZKWatcher zkw, String znode, byte[] data) Creates the specified node with the specified data and watches it.static boolean
ZKUtil.createEphemeralNodeAndWatch
(ZKWatcher zkw, String znode, byte[] data) Set the specified znode to be an ephemeral node carrying the specified data.static boolean
ZKUtil.createNodeIfNotExistsAndWatch
(ZKWatcher zkw, String znode, byte[] data) Creates the specified znode to be a persistent node carrying the specified data.static String
ZKUtil.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 void
ZKUtil.createSetData
(ZKWatcher zkw, String znode, byte[] data) Set data into node creating node if it doesn't yet exist.static void
ZKUtil.createWithParents
(ZKWatcher zkw, String znode) Creates the specified node and all parent nodes required for it to exist.static void
ZKUtil.createWithParents
(ZKWatcher zkw, String znode, byte[] data) Creates the specified node and all parent nodes required for it to exist.static void
ZKUtil.deleteChildrenRecursively
(ZKWatcher zkw, String node) Delete all the children of the specified node but not the node itself.static void
ZKUtil.deleteChildrenRecursivelyMultiOrSequential
(ZKWatcher zkw, boolean runSequentialOnMultiFailure, String... pathRoots) Delete all the children of the specified node but not the node itself.static boolean
MasterAddressTracker.deleteIfEquals
(ZKWatcher zkw, String content) delete the master znode if its content is same as the parameterstatic void
MetaTableLocator.deleteMetaLocation
(ZKWatcher zookeeper) Deletes the location ofhbase:meta
in ZooKeeper.static void
MetaTableLocator.deleteMetaLocation
(ZKWatcher zookeeper, int replicaId) static void
ZKUtil.deleteNode
(ZKWatcher zkw, String node) Delete the specified node.static boolean
ZKUtil.deleteNode
(ZKWatcher zkw, String node, int version) Delete the specified node with the specified version.static void
ZKUtil.deleteNodeFailSilent
(ZKWatcher zkw, String node) Deletes the specified node.private static void
ZKUtil.deleteNodeFailSilent
(ZKWatcher zkw, ZKUtil.ZKUtilOp.DeleteNodeFailSilent dnfs) static void
ZKUtil.deleteNodeRecursively
(ZKWatcher zkw, String node) Delete the specified node and all of it's children.static void
ZKUtil.deleteNodeRecursivelyMultiOrSequential
(ZKWatcher zkw, boolean runSequentialOnMultiFailure, String... pathRoots) Delete the specified node and its children.static String
static int
MasterAddressTracker.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 String
ZKSplitLog.getEncodedNodeName
(ZKWatcher zkw, String filename) Deprecated.Gets the full path node name for the log file being split.static ServerName
MasterAddressTracker.getMasterAddress
(ZKWatcher zkw) Get master address.static int
MasterAddressTracker.getMasterInfoPort
(ZKWatcher zkw) Get master info port.static ServerName
MetaTableLocator.getMetaRegionLocation
(ZKWatcher zkw) Gets the meta region location, if available.static ServerName
MetaTableLocator.getMetaRegionLocation
(ZKWatcher zkw, int replicaId) Gets the meta region location, if available.static RegionState
MetaTableLocator.getMetaRegionState
(ZKWatcher zkw) Load the meta region state from the meta server ZNode.static RegionState
MetaTableLocator.getMetaRegionState
(ZKWatcher zkw, int replicaId) Load the meta region state from the meta region server ZNode.static int
ZKUtil.getNumberOfChildren
(ZKWatcher zkw, String znode) Get the number of children of the specified node.static String
ZKDump.getReplicationZnodesDump
(ZKWatcher zkw) Returns a string with replication znodes and position of the replication logprivate static void
ZKDump.getReplicationZnodesDump
(ZKWatcher zkw, StringBuilder sb) Appends replication znodes to the passed StringBuilder.static String
ZKSplitLog.getRescanNode
(ZKWatcher zkw) Deprecated.static UUID
ZKClusterId.getUUIDForCluster
(ZKWatcher zkw) Get the UUID for the provided ZK watcher.static boolean
ZKSplitLog.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.listChildrenBFSAndWatchThem
(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.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 void
ZKUtil.logRetrievedMsg
(ZKWatcher zkw, String znode, byte[] data, boolean watcherSet) static void
Recursively print the current state of ZK (non-transactional)private static void
Helper method to print the current state of the ZK tree.static void
ZKUtil.multiOrSequential
(ZKWatcher zkw, List<ZKUtil.ZKUtilOp> ops, boolean runSequentialOnMultiFailure) Use ZooKeeper's multi-update functionality.static boolean
ZKUtil.nodeHasChildren
(ZKWatcher zkw, String znode) Checks if the specified znode has any children.private static void
ZKUtil.processSequentially
(ZKWatcher zkw, List<ZKUtil.ZKUtilOp> ops) static String
ZKClusterId.readClusterIdZNode
(ZKWatcher watcher) private static void
static void
ZKClusterId.setClusterId
(ZKWatcher watcher, ClusterId id) static void
Sets the data of the existing znode to be the specified data.static boolean
Sets the data of the existing znode to be the specified data.private static void
ZKUtil.setData
(ZKWatcher zkw, ZKUtil.ZKUtilOp.SetData setData) static boolean
MasterAddressTracker.setMasterAddress
(ZKWatcher zkw, String znode, ServerName master, int infoPort) Set master address into themaster
znode or into the backup subdirectory of backup masters; switch off the passed inznode
path.static void
MetaTableLocator.setMetaLocation
(ZKWatcher zookeeper, ServerName serverName, int replicaId, RegionState.State state) Sets the location ofhbase:meta
in ZooKeeper to the specified server address.static void
MetaTableLocator.setMetaLocation
(ZKWatcher zookeeper, ServerName serverName, RegionState.State state) Sets the location ofhbase:meta
in ZooKeeper to the specified server address.static boolean
ZKUtil.setWatchIfNodeExists
(ZKWatcher zkw, String znode) Watch the specified znode, but only if exists.private static void
ZKUtil.submitBatchedMultiOrSequential
(ZKWatcher zkw, boolean runSequentialOnMultiFailure, List<ZKUtil.ZKUtilOp> ops) Chunks the providedops
when their approximate size exceeds the the configured limit.private static org.apache.zookeeper.Op
ZKUtil.toZooKeeperOp
(ZKWatcher zkw, ZKUtil.ZKUtilOp op) Convert from ZKUtilOp to ZKOpstatic void
ZKUtil.updateExistingNodeData
(ZKWatcher zkw, String znode, byte[] data, int expectedVersion) Deprecated.Unusedprivate static ServerName
MetaTableLocator.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 ServerName
MetaTableLocator.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 boolean
ZKUtil.watchAndCheckExists
(ZKWatcher zkw, String znode) Watch the specified znode for delete/create/change events.ModifierConstructorDescriptionClusterStatusTracker
(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 specifiedzookeeper
reference.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.