Uses of Class
org.apache.hadoop.hbase.zookeeper.ZKWatcher
Package
Description
Multi Cluster Replication
-
Uses of org.apache.hadoop.hbase.zookeeper.ZKWatcher in org.apache.hadoop.hbase
Modifier and TypeFieldDescriptionprotected final org.apache.hadoop.hbase.zookeeper.ZKWatcher
HBaseServerBase.zooKeeper
protected org.apache.hadoop.hbase.zookeeper.ZKWatcher
HBaseZKTestingUtility.zooKeeperWatcher
Deprecated.Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.zookeeper.ZKWatcher
HBaseServerBase.getZooKeeper()
org.apache.hadoop.hbase.zookeeper.ZKWatcher
MockRegionServerServices.getZooKeeper()
org.apache.hadoop.hbase.zookeeper.ZKWatcher
Server.getZooKeeper()
Gets the ZooKeeper instance for this server.org.apache.hadoop.hbase.zookeeper.ZKWatcher
HBaseZKTestingUtility.getZooKeeperWatcher()
Deprecated.Returns a ZKWatcher instance.static org.apache.hadoop.hbase.zookeeper.ZKWatcher
HBaseZKTestingUtility.getZooKeeperWatcher
(org.apache.hadoop.hbase.HBaseZKTestingUtility testUtil) Deprecated.Gets a ZKWatcher.Modifier and TypeMethodDescriptionvoid
HBaseTestingUtility.expireSession
(org.apache.hadoop.hbase.zookeeper.ZKWatcher nodeZK) Deprecated.void
HBaseTestingUtility.expireSession
(org.apache.hadoop.hbase.zookeeper.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
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkWatcher) ModifierConstructorDescriptionMetaRegionLocationCache
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkWatcher) MockRegionServerServices
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw) MockRegionServerServices
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, org.apache.hadoop.hbase.ServerName serverName) -
Uses of org.apache.hadoop.hbase.zookeeper.ZKWatcher in org.apache.hadoop.hbase.coordination
Modifier and TypeFieldDescriptionprotected org.apache.hadoop.hbase.zookeeper.ZKWatcher
ZkCoordinatedStateManager.watcher
Deprecated.Modifier and TypeMethodDescriptionprotected static int
ZkSplitLogWorkerCoordination.attemptToOwnTask
(boolean isFirstTime, org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.zookeeper.ZKWatcher watcher) ZkSplitLogWorkerCoordination
(org.apache.hadoop.hbase.ServerName serverName, org.apache.hadoop.hbase.zookeeper.ZKWatcher watcher) -
Uses of org.apache.hadoop.hbase.zookeeper.ZKWatcher in org.apache.hadoop.hbase.master
Modifier and TypeMethodDescriptionprotected org.apache.hadoop.hbase.master.ActiveMasterManager
HMaster.createActiveMasterManager
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zk, org.apache.hadoop.hbase.ServerName sn, org.apache.hadoop.hbase.Server server) Protected to have custom implementations in tests override the default ActiveMaster implementation.ModifierConstructorDescriptionprotected
BooleanStateStore
(org.apache.hadoop.hbase.master.region.MasterRegion masterRegion, String stateName, org.apache.hadoop.hbase.zookeeper.ZKWatcher watcher, String zkPath) DrainingServerTracker
(org.apache.hadoop.hbase.zookeeper.ZKWatcher watcher, org.apache.hadoop.hbase.Abortable abortable, org.apache.hadoop.hbase.master.ServerManager serverManager) protected
MasterStateStore
(org.apache.hadoop.hbase.master.region.MasterRegion masterRegion, String stateName, org.apache.hadoop.hbase.zookeeper.ZKWatcher watcher, String zkPath) RegionServerTracker
(org.apache.hadoop.hbase.zookeeper.ZKWatcher watcher, org.apache.hadoop.hbase.master.MasterServices server) SplitOrMergeStateStore
(org.apache.hadoop.hbase.master.region.MasterRegion masterRegion, org.apache.hadoop.hbase.zookeeper.ZKWatcher watcher, org.apache.hadoop.conf.Configuration conf) -
Uses of org.apache.hadoop.hbase.zookeeper.ZKWatcher in org.apache.hadoop.hbase.quotas
ModifierConstructorDescriptionRpcThrottleStorage
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zookeeper, org.apache.hadoop.conf.Configuration conf) -
Uses of org.apache.hadoop.hbase.zookeeper.ZKWatcher in org.apache.hadoop.hbase.replication
Modifier and TypeFieldDescriptionprotected final org.apache.hadoop.hbase.zookeeper.ZKWatcher
ZKReplicationStorageBase.zookeeper
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.replication.ReplicationPeers
ReplicationFactory.getReplicationPeers
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.zookeeper.ZKWatcher zk, org.apache.hadoop.conf.Configuration conf) static org.apache.hadoop.hbase.replication.ReplicationPeerStorage
ReplicationStorageFactory.getReplicationPeerStorage
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.hbase.zookeeper.ZKWatcher zk, org.apache.hadoop.conf.Configuration conf) Create a newReplicationPeerStorage
.ModifierConstructorDescriptionZKReplicationPeerStorage
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zookeeper, org.apache.hadoop.conf.Configuration conf) ZKReplicationQueueStorageForMigration
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zookeeper, org.apache.hadoop.conf.Configuration conf) protected
ZKReplicationStorageBase
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zookeeper, org.apache.hadoop.conf.Configuration conf) -
Uses of org.apache.hadoop.hbase.zookeeper.ZKWatcher in org.apache.hadoop.hbase.util.hbck
ModifierConstructorDescriptionReplicationChecker
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, org.apache.hadoop.hbase.client.Connection conn, org.apache.hadoop.hbase.util.HbckErrorReporter errorReporter) -
Uses of org.apache.hadoop.hbase.zookeeper.ZKWatcher in org.apache.hadoop.hbase.zookeeper
Modifier and TypeFieldDescriptionprotected org.apache.hadoop.hbase.zookeeper.ZKWatcher
ZKListener.watcher
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.zookeeper.ZKWatcher
ZKListener.getWatcher()
Returns The watcher associated with this listenerModifier and TypeMethodDescriptionstatic void
ZKUtil.asyncCreate
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String znode, byte[] data, org.apache.zookeeper.AsyncCallback.StringCallback cb, Object ctx) Async creates the specified node with the specified data.static int
ZKUtil.checkExists
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String znode) Check if the specified node exists.static void
ZKUtil.createAndFailSilent
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String znode) Creates the specified node, iff the node does not exist.static void
ZKUtil.createAndFailSilent
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String znode, byte[] data) Creates the specified node containing specified data, iff the node does not exist.static int
ZKUtil.createAndWatch
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String znode, byte[] data) Creates the specified node with the specified data and watches it.static boolean
ZKUtil.createEphemeralNodeAndWatch
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String znode, byte[] data) Set the specified znode to be an ephemeral node carrying the specified data.static boolean
ZKUtil.createNodeIfNotExistsAndWatch
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String znode, byte[] data) Creates the specified znode to be a persistent node carrying the specified data.static String
ZKUtil.createNodeIfNotExistsNoWatch
(org.apache.hadoop.hbase.zookeeper.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
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String znode, byte[] data) Set data into node creating node if it doesn't yet exist.static void
ZKUtil.createWithParents
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String znode) Creates the specified node and all parent nodes required for it to exist.static void
ZKUtil.createWithParents
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String znode, byte[] data) Creates the specified node and all parent nodes required for it to exist.static void
ZKUtil.deleteChildrenRecursively
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String node) Delete all the children of the specified node but not the node itself.static void
ZKUtil.deleteChildrenRecursivelyMultiOrSequential
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, boolean runSequentialOnMultiFailure, String... pathRoots) Delete all the children of the specified node but not the node itself.static boolean
MasterAddressTracker.deleteIfEquals
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String content) delete the master znode if its content is same as the parameterstatic void
MetaTableLocator.deleteMetaLocation
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zookeeper) Deletes the location ofhbase:meta
in ZooKeeper.static void
MetaTableLocator.deleteMetaLocation
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zookeeper, int replicaId) static void
ZKUtil.deleteNode
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String node) Delete the specified node.static boolean
ZKUtil.deleteNode
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String node, int version) Delete the specified node with the specified version.static void
ZKUtil.deleteNodeFailSilent
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String node) Deletes the specified node.static void
ZKUtil.deleteNodeRecursively
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String node) Delete the specified node and all of it's children.static void
ZKUtil.deleteNodeRecursivelyMultiOrSequential
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, boolean runSequentialOnMultiFailure, String... pathRoots) Delete the specified node and its children.static String
ZKDump.dump
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkWatcher) static int
MasterAddressTracker.getBackupMasterInfoPort
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, org.apache.hadoop.hbase.ServerName sn) Get backup master info port.static List<org.apache.hadoop.hbase.ServerName>
MasterAddressTracker.getBackupMastersAndRenewWatch
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw) Retrieves the list of registered backup masters and renews a watch on the znode for children updates.static List<org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData>
ZKUtil.getChildDataAndWatchForNewChildren
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String baseNode) Deprecated.Unusedstatic List<org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData>
ZKUtil.getChildDataAndWatchForNewChildren
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String baseNode, boolean throwOnInterrupt) Deprecated.Unusedstatic byte[]
ZKUtil.getData
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String znode) Get znode data.static byte[]
ZKUtil.getDataAndWatch
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String znode) Get the data at the specified znode and set a watch.static byte[]
ZKUtil.getDataAndWatch
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String znode, boolean throwOnInterrupt) Get the data at the specified znode and set a watch.static byte[]
ZKUtil.getDataAndWatch
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String znode, org.apache.zookeeper.data.Stat stat) Get the data at the specified znode and set a watch.static byte[]
ZKUtil.getDataNoWatch
(org.apache.hadoop.hbase.zookeeper.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
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String filename) Deprecated.Gets the full path node name for the log file being split.static org.apache.hadoop.hbase.ServerName
MasterAddressTracker.getMasterAddress
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw) Get master address.static int
MasterAddressTracker.getMasterInfoPort
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw) Get master info port.static org.apache.hadoop.hbase.ServerName
MetaTableLocator.getMetaRegionLocation
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw) Gets the meta region location, if available.static org.apache.hadoop.hbase.ServerName
MetaTableLocator.getMetaRegionLocation
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, int replicaId) Gets the meta region location, if available.static org.apache.hadoop.hbase.master.RegionState
MetaTableLocator.getMetaRegionState
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw) Load the meta region state from the meta server ZNode.static org.apache.hadoop.hbase.master.RegionState
MetaTableLocator.getMetaRegionState
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, int replicaId) Load the meta region state from the meta region server ZNode.static int
ZKUtil.getNumberOfChildren
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String znode) Get the number of children of the specified node.static String
ZKDump.getReplicationZnodesDump
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw) Returns a string with replication znodes and position of the replication logstatic String
ZKSplitLog.getRescanNode
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw) Deprecated.static UUID
ZKClusterId.getUUIDForCluster
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw) Get the UUID for the provided ZK watcher.static boolean
ZKSplitLog.isRescanNode
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String path) Deprecated.Checks if the given path represents a rescan node.ZKUtil.listChildrenAndWatchForNewChildren
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String znode) Lists the children znodes of the specified znode.ZKUtil.listChildrenAndWatchThem
(org.apache.hadoop.hbase.zookeeper.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.listChildrenNoWatch
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String znode) Lists the children of the specified znode without setting any watches.static void
ZKUtil.logZKTree
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String root) Recursively print the current state of ZK (non-transactional)static void
ZKUtil.multiOrSequential
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, List<org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp> ops, boolean runSequentialOnMultiFailure) Use ZooKeeper's multi-update functionality.static boolean
ZKUtil.nodeHasChildren
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String znode) Checks if the specified znode has any children.static String
ZKClusterId.readClusterIdZNode
(org.apache.hadoop.hbase.zookeeper.ZKWatcher watcher) static void
ZKClusterId.setClusterId
(org.apache.hadoop.hbase.zookeeper.ZKWatcher watcher, org.apache.hadoop.hbase.ClusterId id) static void
ZKUtil.setData
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String znode, byte[] data) Sets the data of the existing znode to be the specified data.static boolean
ZKUtil.setData
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String znode, byte[] data, int expectedVersion) Sets the data of the existing znode to be the specified data.static boolean
MasterAddressTracker.setMasterAddress
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String znode, org.apache.hadoop.hbase.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
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zookeeper, org.apache.hadoop.hbase.ServerName serverName, int replicaId, org.apache.hadoop.hbase.master.RegionState.State state) Sets the location ofhbase:meta
in ZooKeeper to the specified server address.static void
MetaTableLocator.setMetaLocation
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zookeeper, org.apache.hadoop.hbase.ServerName serverName, org.apache.hadoop.hbase.master.RegionState.State state) Sets the location ofhbase:meta
in ZooKeeper to the specified server address.static boolean
ZKUtil.setWatchIfNodeExists
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String znode) Watch the specified znode, but only if exists.static void
ZKUtil.updateExistingNodeData
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String znode, byte[] data, int expectedVersion) Deprecated.Unusedstatic org.apache.hadoop.hbase.ServerName
MetaTableLocator.waitMetaRegionLocation
(org.apache.hadoop.hbase.zookeeper.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
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkw, String znode) Watch the specified znode for delete/create/change events.ModifierConstructorDescriptionClusterStatusTracker
(org.apache.hadoop.hbase.zookeeper.ZKWatcher watcher, org.apache.hadoop.hbase.Abortable abortable) Creates a cluster status tracker.DeletionListener
(org.apache.hadoop.hbase.zookeeper.ZKWatcher zkWatcher, String pathToWatch, CountDownLatch deletedLatch) Create a new instance of the deletion watcher.MasterAddressTracker
(org.apache.hadoop.hbase.zookeeper.ZKWatcher watcher, org.apache.hadoop.hbase.Abortable abortable) Construct a master address listener with the specifiedzookeeper
reference.MasterMaintenanceModeTracker
(org.apache.hadoop.hbase.zookeeper.ZKWatcher watcher) ZKClusterId
(org.apache.hadoop.hbase.zookeeper.ZKWatcher watcher, org.apache.hadoop.hbase.Abortable abortable) ZKLeaderManager
(org.apache.hadoop.hbase.zookeeper.ZKWatcher watcher, String leaderZNode, byte[] identifier, org.apache.hadoop.hbase.Stoppable candidate) Deprecated.ZKListener
(org.apache.hadoop.hbase.zookeeper.ZKWatcher watcher) Construct a ZooKeeper event listener.ZKNodeTracker
(org.apache.hadoop.hbase.zookeeper.ZKWatcher watcher, String node, org.apache.hadoop.hbase.Abortable abortable) Constructs a new ZK node tracker.