|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Packages that use ZooKeeperWatcher | |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.catalog | |
org.apache.hadoop.hbase.client | Provides HBase Client |
org.apache.hadoop.hbase.replication | |
org.apache.hadoop.hbase.zookeeper |
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. |
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.client |
---|
Methods in org.apache.hadoop.hbase.client that return ZooKeeperWatcher | |
---|---|
ZooKeeperWatcher |
HConnection.getZooKeeperWatcher()
Deprecated. Removed because it was a mistake exposing zookeeper in this interface (ZooKeeper is an implementation detail). Deprecated in HBase 0.94 |
Uses of ZooKeeperWatcher in org.apache.hadoop.hbase.replication |
---|
Methods in org.apache.hadoop.hbase.replication that return ZooKeeperWatcher | |
---|---|
ZooKeeperWatcher |
ReplicationPeer.getZkw()
Get the ZK connection to this peer |
ZooKeeperWatcher |
ReplicationZookeeper.getZookeeperWatcher()
Get this cluster's zk connection |
Methods in org.apache.hadoop.hbase.replication with parameters of type ZooKeeperWatcher | |
---|---|
UUID |
ReplicationZookeeper.getUUIDForCluster(ZooKeeperWatcher zkw)
Get the UUID for the provided ZK watcher. |
static List<ServerName> |
ReplicationZookeeper.listChildrenAndGetAsServerNames(ZooKeeperWatcher zkw,
String znode)
Lists the children of the specified znode, retrieving the data of each child as a server address. |
void |
ReplicationPeer.startStateTracker(ZooKeeperWatcher zookeeper,
String peerStateNode)
start a state tracker to check whether this peer is enabled or not |
Constructors in org.apache.hadoop.hbase.replication with parameters of type ZooKeeperWatcher | |
---|---|
ReplicationPeer.PeerStateTracker(String peerStateZNode,
ZooKeeperWatcher watcher,
Abortable abortable)
|
|
ReplicationStateImpl(ZooKeeperWatcher zk,
String stateZnode,
Abortable abortable,
AtomicBoolean replicating)
|
|
ReplicationZookeeper(Abortable abortable,
org.apache.hadoop.conf.Configuration conf,
ZooKeeperWatcher zk)
Constructor used by clients of replication (like master and HBase clients) |
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 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 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 boolean |
ZKAssign.deleteClosedNode(ZooKeeperWatcher zkw,
String encodedRegionName)
Deletes an existing unassigned node that is in the CLOSED state for the specified region. |
static boolean |
ZKAssign.deleteClosingNode(ZooKeeperWatcher zkw,
HRegionInfo region)
Deletes an existing unassigned node that is in the CLOSING state for the specified region. |
static 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 .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)
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,
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 boolean |
ZKAssign.deleteOfflineNode(ZooKeeperWatcher zkw,
String encodedRegionName)
Deletes an existing unassigned node that is in the OFFLINE state for the specified region. |
static boolean |
ZKAssign.deleteOpenedNode(ZooKeeperWatcher zkw,
String encodedRegionName)
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[] |
ZKUtil.getData(ZooKeeperWatcher zkw,
String znode)
Get znode data. |
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.getDataAndWatch(ZooKeeperWatcher zkw,
String znode)
Get the data at the specified znode and set a watch. |
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.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.getDataNoWatch(ZooKeeperWatcher zkw,
String znode,
org.apache.zookeeper.data.Stat stat)
Get the data at the specified znode without setting 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 Set<String> |
ZKTableReadOnly.getDisabledOrDisablingTables(ZooKeeperWatcher zkw)
Gets a list of all the tables set as disabled in zookeeper. |
static Set<String> |
ZKTable.getDisabledOrDisablingTables(ZooKeeperWatcher zkw)
Gets a list of all the tables set as disabled in zookeeper. |
static Set<String> |
ZKTableReadOnly.getDisabledTables(ZooKeeperWatcher zkw)
Gets a list of all the tables set as disabled in zookeeper. |
static Set<String> |
ZKTable.getDisabledTables(ZooKeeperWatcher zkw)
Gets a list of all the tables set as disabled in zookeeper. |
static Set<String> |
ZKTable.getDisablingTables(ZooKeeperWatcher zkw)
Gets a list of all the tables set as disabling in zookeeper. |
static Set<String> |
ZKTable.getEnablingTables(ZooKeeperWatcher zkw)
Gets a list of all the tables set as enabling in zookeeper. |
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 int |
ZKAssign.getVersion(ZooKeeperWatcher zkw,
HRegionInfo region)
Get the version of the specified znode |
static boolean |
ZKTableReadOnly.isDisabledTable(ZooKeeperWatcher zkw,
String tableName)
Go to zookeeper and see if state of table is ZooKeeperProtos.Table.State#DISABLED . |
static boolean |
ZKTableReadOnly.isDisablingOrDisabledTable(ZooKeeperWatcher zkw,
String 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,
String tableName)
Go to zookeeper and see if state of table is ZooKeeperProtos.Table.State#ENABLED . |
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)
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)
Sets the location of .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 | |
---|---|
MasterAddressTracker(ZooKeeperWatcher watcher,
Abortable abortable)
Construct a master address listener with the specified zookeeper reference. |
|
MetaNodeTracker(ZooKeeperWatcher watcher,
Abortable abortable)
Creates a meta node tracker. |
|
MetaRegionTracker(ZooKeeperWatcher watcher,
Abortable abortable)
Creates a meta region location tracker. |
|
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. |
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |