Modifier and Type | Method and Description |
---|---|
ZooKeeperWatcher |
Server.getZooKeeper()
Gets the ZooKeeper instance for this server.
|
Modifier and Type | Method and Description |
---|---|
static List<HRegionInfo> |
MetaTableAccessor.getTableRegions(ZooKeeperWatcher zkw,
Connection connection,
TableName tableName)
Gets all of the regions of the specified table.
|
static List<HRegionInfo> |
MetaTableAccessor.getTableRegions(ZooKeeperWatcher zkw,
Connection connection,
TableName tableName,
boolean excludeOfflinedSplitParents)
Gets all of the regions of the specified table.
|
static List<HRegionInfo> |
MetaTableAccessor.getTableRegions(ZooKeeperWatcher zkw,
Connection connection,
TableName tableName,
boolean excludeOfflinedSplitParents,
boolean excludeReplicaRegions)
Gets all of the regions of the specified table.
|
static List<Pair<HRegionInfo,ServerName>> |
MetaTableAccessor.getTableRegionsAndLocations(ZooKeeperWatcher zkw,
Connection connection,
TableName tableName) |
static List<Pair<HRegionInfo,ServerName>> |
MetaTableAccessor.getTableRegionsAndLocations(ZooKeeperWatcher zkw,
Connection connection,
TableName tableName,
boolean excludeOfflinedSplitParents) |
static List<Pair<HRegionInfo,ServerName>> |
MetaTableAccessor.getTableRegionsAndLocations(ZooKeeperWatcher zkw,
Connection connection,
TableName tableName,
boolean excludeOfflinedSplitParents,
boolean excludeReplicaRegions) |
Constructor and Description |
---|
ZKNamespaceManager(ZooKeeperWatcher zkw) |
Modifier and Type | Method and Description |
---|---|
ZooKeeperWatcher |
TableHFileArchiveTracker.getZooKeeperWatcher() |
Modifier and Type | Method and Description |
---|---|
static String |
ZKTableArchiveClient.getArchiveZNode(org.apache.hadoop.conf.Configuration conf,
ZooKeeperWatcher zooKeeper) |
Modifier and Type | Field and Description |
---|---|
protected ZooKeeperWatcher |
ZkCoordinatedStateManager.watcher |
Modifier and Type | Method and Description |
---|---|
protected static int |
ZkSplitLogWorkerCoordination.attemptToOwnTask(boolean isFirstTime,
ZooKeeperWatcher zkw,
ServerName server,
String task,
org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.RecoveryMode mode,
int taskZKVersion)
Try to own the task by transitioning the zk node data from UNASSIGNED to OWNED.
|
Constructor and Description |
---|
ZkCloseRegionCoordination(CoordinatedStateManager csm,
ZooKeeperWatcher watcher) |
ZkOpenRegionCoordination(CoordinatedStateManager coordination,
ZooKeeperWatcher watcher) |
ZkRegionMergeCoordination(CoordinatedStateManager manager,
ZooKeeperWatcher watcher) |
ZKSplitLogManagerCoordination(CoordinatedStateManager manager,
ZooKeeperWatcher watcher) |
ZkSplitLogWorkerCoordination(ZkCoordinatedStateManager zkCoordinatedStateManager,
ZooKeeperWatcher watcher) |
ZKSplitTransactionCoordination(CoordinatedStateManager coordinationProvider,
ZooKeeperWatcher watcher) |
Modifier and Type | Method and Description |
---|---|
ZooKeeperWatcher |
HMaster.getZooKeeper() |
Modifier and Type | Method and Description |
---|---|
static TableLockManager |
TableLockManager.createTableLockManager(org.apache.hadoop.conf.Configuration conf,
ZooKeeperWatcher zkWatcher,
ServerName serverName)
Creates and returns a TableLockManager according to the configuration
|
List<HRegionInfo> |
RegionStates.serverOffline(ZooKeeperWatcher watcher,
ServerName sn)
A server is offline, all regions on it are dead.
|
Constructor and Description |
---|
ReplicationZKLockCleanerChore(Stoppable stopper,
Abortable abortable,
int period,
ZooKeeperWatcher zk,
org.apache.hadoop.conf.Configuration conf) |
ReplicationZKNodeCleaner(org.apache.hadoop.conf.Configuration conf,
ZooKeeperWatcher zkw,
Abortable abortable) |
Modifier and Type | Method and Description |
---|---|
ZooKeeperWatcher |
ZKProcedureUtil.getWatcher() |
Constructor and Description |
---|
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.
|
Modifier and Type | Field and Description |
---|---|
protected ZooKeeperWatcher |
HRegionServer.zooKeeper |
Modifier and Type | Method and Description |
---|---|
ZooKeeperWatcher |
HRegionServer.getZooKeeper() |
Modifier and Type | Field and Description |
---|---|
protected ZooKeeperWatcher |
ReplicationStateZKBase.zookeeper |
Modifier and Type | Method and Description |
---|---|
protected ZooKeeperWatcher |
HBaseReplicationEndpoint.getZkw()
Get the ZK connection to this peer
|
Modifier and Type | Method and Description |
---|---|
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 ReplicationPeers |
ReplicationFactory.getReplicationPeers(ZooKeeperWatcher zk,
org.apache.hadoop.conf.Configuration conf,
ReplicationQueuesClient queuesClient,
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.startPeerConfigTracker(ZooKeeperWatcher zookeeper,
String peerConfigNode)
start a table-cfs tracker to listen the (table, cf-list) map change
|
Constructor and Description |
---|
ReplicationPeersZKImpl(ZooKeeperWatcher zk,
org.apache.hadoop.conf.Configuration conf,
ReplicationQueuesClient queuesClient,
Abortable abortable) |
ReplicationPeerZKImpl.PeerConfigTracker(String peerConfigNode,
ZooKeeperWatcher watcher,
Abortable abortable) |
ReplicationPeerZKImpl.PeerStateTracker(String peerStateZNode,
ZooKeeperWatcher watcher,
Abortable abortable) |
ReplicationPeerZKImpl(ZooKeeperWatcher zkWatcher,
org.apache.hadoop.conf.Configuration conf,
String id,
ReplicationPeerConfig peerConfig,
Abortable abortable)
Constructor that takes all the objects required to communicate with the specified peer, except
for the region server addresses.
|
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) |
Modifier and Type | Method and Description |
---|---|
void |
ReplicationLogCleaner.setConf(org.apache.hadoop.conf.Configuration conf,
ZooKeeperWatcher zk) |
void |
ReplicationHFileCleaner.setConf(org.apache.hadoop.conf.Configuration conf,
ZooKeeperWatcher zk) |
void |
ReplicationLogCleaner.setConf(org.apache.hadoop.conf.Configuration conf,
ZooKeeperWatcher zk,
ReplicationQueuesClient replicationQueuesClient) |
Constructor and Description |
---|
TableCFsUpdater(ZooKeeperWatcher zookeeper,
org.apache.hadoop.conf.Configuration conf,
Abortable abortable) |
Modifier and Type | Method and Description |
---|---|
String |
DumpReplicationQueues.dumpQueues(ClusterConnection connection,
Set<String> peerIds,
ZooKeeperWatcher zkw,
boolean hdfs) |
Modifier and Type | Method and Description |
---|---|
List<RSGroupInfo> |
RSGroupSerDe.retrieveGroupList(ZooKeeperWatcher watcher,
String groupBasePath) |
Modifier and Type | Method and Description |
---|---|
static TableAuthManager |
TableAuthManager.getOrCreate(ZooKeeperWatcher watcher,
org.apache.hadoop.conf.Configuration conf)
Returns a TableAuthManager from the cache.
|
Constructor and Description |
---|
AccessChecker(org.apache.hadoop.conf.Configuration conf,
ZooKeeperWatcher zkw)
Constructor with existing configuration
|
ZKPermissionWatcher(ZooKeeperWatcher watcher,
TableAuthManager authManager,
org.apache.hadoop.conf.Configuration conf) |
Constructor and Description |
---|
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) |
Modifier and Type | Method and Description |
---|---|
static VisibilityLabelsCache |
VisibilityLabelsCache.createAndGet(ZooKeeperWatcher watcher,
org.apache.hadoop.conf.Configuration conf)
Creates the singleton instance, if not yet present, and returns the same.
|
Constructor and Description |
---|
ZKVisibilityLabelWatcher(ZooKeeperWatcher watcher,
VisibilityLabelsCache labelsCache,
org.apache.hadoop.conf.Configuration conf) |
Constructor and Description |
---|
ReplicationChecker(org.apache.hadoop.conf.Configuration conf,
ZooKeeperWatcher zkw,
HConnection connection,
HBaseFsck.ErrorReporter errorReporter) |
TableLockChecker(ZooKeeperWatcher zkWatcher,
HBaseFsck.ErrorReporter errorReporter) |
Modifier and Type | Field and Description |
---|---|
protected ZooKeeperWatcher |
ZooKeeperListener.watcher |
Modifier and Type | Method and Description |
---|---|
ZooKeeperWatcher |
ZooKeeperListener.getWatcher() |
Modifier and Type | Method and Description |
---|---|
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.
|
ServerName |
MetaTableLocator.blockUntilAvailable(ZooKeeperWatcher zkw,
int replicaId,
long timeout)
Wait until the meta region is available and is not in transition.
|
ServerName |
MetaTableLocator.blockUntilAvailable(ZooKeeperWatcher zkw,
long timeout)
Wait until the meta region is available and is not in transition.
|
List<ServerName> |
MetaTableLocator.blockUntilAvailable(ZooKeeperWatcher zkw,
long timeout,
org.apache.hadoop.conf.Configuration conf)
Wait until the primary 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 int |
ZKAssign.confirmNodeOpening(ZooKeeperWatcher zkw,
HRegionInfo region,
ServerName serverName,
int expectedVersion)
Confirm an existing unassigned node for the specified region which is
currently in the OPENING state to be still in the OPENING state on
the specified server.
|
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
|
void |
MetaTableLocator.deleteMetaLocation(ZooKeeperWatcher zookeeper)
Deletes the location of
hbase:meta in ZooKeeper. |
void |
MetaTableLocator.deleteMetaLocation(ZooKeeperWatcher zookeeper,
int replicaId) |
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 void |
ZKSplitLog.deleteRecoveringRegionZNodes(ZooKeeperWatcher watcher,
List<String> regions) |
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<TableName> |
ZKTableStateClientSideReader.getDisabledOrDisablingTables(ZooKeeperWatcher zkw)
Gets a list of all the tables set as disabled in zookeeper.
|
static Set<TableName> |
ZKTableStateClientSideReader.getDisabledTables(ZooKeeperWatcher zkw)
Gets a list of all the tables set as disabled in zookeeper.
|
static Set<TableName> |
ZKTableStateClientSideReader.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 int |
MasterAddressTracker.getMasterInfoPort(ZooKeeperWatcher zkw)
Get master info port.
|
ServerName |
MetaTableLocator.getMetaRegionLocation(ZooKeeperWatcher zkw)
Gets the meta region location, if available.
|
ServerName |
MetaTableLocator.getMetaRegionLocation(ZooKeeperWatcher zkw,
int replicaId)
Gets the meta region location, if available.
|
List<HRegionInfo> |
MetaTableLocator.getMetaRegions(ZooKeeperWatcher zkw) |
List<HRegionInfo> |
MetaTableLocator.getMetaRegions(ZooKeeperWatcher zkw,
int replicaId) |
List<Pair<HRegionInfo,ServerName>> |
MetaTableLocator.getMetaRegionsAndLocations(ZooKeeperWatcher zkw) |
List<Pair<HRegionInfo,ServerName>> |
MetaTableLocator.getMetaRegionsAndLocations(ZooKeeperWatcher zkw,
int replicaId) |
static RegionState |
MetaTableLocator.getMetaRegionState(ZooKeeperWatcher zkw)
Load the meta region state from the meta server ZNode.
|
static RegionState |
MetaTableLocator.getMetaRegionState(ZooKeeperWatcher zkw,
int replicaId)
Load the meta region state from the meta server ZNode.
|
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 org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds |
ZKSplitLog.getRegionFlushedSequenceId(ZooKeeperWatcher zkw,
String serverName,
String encodedRegionName)
This function is used in distributedLogReplay to fetch last flushed sequence id from ZK
|
static String |
ZKAssign.getRegionName(ZooKeeperWatcher zkw,
String path)
Gets the region name from the full path node name of an unassigned node.
|
static String |
ZKUtil.getReplicationZnodesDump(ZooKeeperWatcher zkw)
Returns a string with replication znodes and position of the replication log
|
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 |
ZKTableStateClientSideReader.isDisabledTable(ZooKeeperWatcher zkw,
TableName tableName)
Go to zookeeper and see if state of table is
ZooKeeperProtos.Table.State#DISABLED . |
static boolean |
ZKTableStateClientSideReader.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 |
ZKTableStateClientSideReader.isEnabledTable(ZooKeeperWatcher zkw,
TableName tableName)
Go to zookeeper and see if state of table is
ZooKeeperProtos.Table.State#ENABLED . |
boolean |
MetaTableLocator.isLocationAvailable(ZooKeeperWatcher zkw)
Checks if the meta region location is available.
|
static boolean |
ZKSplitLog.isRegionMarkedRecoveringInZK(ZooKeeperWatcher zkw,
String regionEncodedName)
check if /hbase/recovering-regions/<current region encoded name>
exists.
|
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 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,
int infoPort)
Set master address into the
master znode or into the backup
subdirectory of backup masters; switch off the passed in znode
path. |
static void |
MetaTableLocator.setMetaLocation(ZooKeeperWatcher zookeeper,
ServerName serverName,
int replicaId,
RegionState.State state)
Sets the location of
hbase:meta in ZooKeeper to the
specified server address. |
static void |
MetaTableLocator.setMetaLocation(ZooKeeperWatcher zookeeper,
ServerName serverName,
RegionState.State state)
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
|
boolean |
MetaTableLocator.verifyMetaRegionLocation(HConnection hConnection,
ZooKeeperWatcher zkw,
long timeout)
Verify
hbase:meta is deployed and accessible. |
boolean |
MetaTableLocator.verifyMetaRegionLocation(HConnection hConnection,
ZooKeeperWatcher zkw,
long timeout,
int replicaId)
Verify
hbase:meta is deployed and accessible. |
void |
MetaTableLocator.waitMetaRegionLocation(ZooKeeperWatcher zkw)
Waits indefinitely for availability of
hbase:meta . |
ServerName |
MetaTableLocator.waitMetaRegionLocation(ZooKeeperWatcher zkw,
int replicaId,
long timeout)
Gets the meta region location, if available, and waits for up to the
specified timeout if not immediately available.
|
ServerName |
MetaTableLocator.waitMetaRegionLocation(ZooKeeperWatcher 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(ZooKeeperWatcher zkw,
String znode)
Watch the specified znode for delete/create/change events.
|
Constructor and Description |
---|
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. |
MasterMaintenanceModeTracker(ZooKeeperWatcher watcher) |
RecoveringRegionWatcher(ZooKeeperWatcher watcher,
HRegionServer server)
Construct a ZooKeeper event listener.
|
RegionNormalizerTracker(ZooKeeperWatcher watcher,
Abortable abortable) |
RegionServerTracker(ZooKeeperWatcher watcher,
MasterServices server,
ServerManager serverManager) |
SplitOrMergeTracker(ZooKeeperWatcher watcher,
org.apache.hadoop.conf.Configuration conf,
Abortable abortable) |
ZKClusterId(ZooKeeperWatcher watcher,
Abortable abortable) |
ZKLeaderManager(ZooKeeperWatcher watcher,
String leaderZNode,
byte[] identifier,
Stoppable candidate)
Deprecated.
|
ZKTableStateManager(ZooKeeperWatcher zkw) |
ZooKeeperListener(ZooKeeperWatcher watcher)
Construct a ZooKeeper event listener.
|
ZooKeeperNodeTracker(ZooKeeperWatcher watcher,
String node,
Abortable abortable)
Constructs a new ZK node tracker.
|
Modifier and Type | Field and Description |
---|---|
protected ZooKeeperWatcher |
ZKInterProcessLockBase.zkWatcher |
Constructor and Description |
---|
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–2019 The Apache Software Foundation. All rights reserved.