@InterfaceAudience.Private public class ReplicationQueuesClientZKImpl extends ReplicationStateZKBase implements ReplicationQueuesClient
abortable, conf, DISABLED_ZNODE_BYTES, ENABLED_ZNODE_BYTES, hfileRefsZNode, ourClusterKey, peerStateNodeName, peersZNode, queuesZNode, replicationZNode, tableCFsNodeName, zookeeper, ZOOKEEPER_ZNODE_REPLICATION_HFILE_REFS_DEFAULT, ZOOKEEPER_ZNODE_REPLICATION_HFILE_REFS_KEY
Constructor and Description |
---|
ReplicationQueuesClientZKImpl(ZooKeeperWatcher zk,
org.apache.hadoop.conf.Configuration conf,
Abortable abortable) |
Modifier and Type | Method and Description |
---|---|
List<String> |
getAllPeersFromHFileRefsQueue()
Get list of all peers from hfile reference queue.
|
List<String> |
getAllQueues(String serverName)
Get a list of all queues for the specified region server.
|
int |
getHFileRefsNodeChangeVersion()
Get the change version number of replication hfile references node.
|
List<String> |
getListOfReplicators()
Get a list of all region servers that have outstanding replication queues.
|
List<String> |
getLogsInQueue(String serverName,
String queueId)
Get a list of all WALs in the given queue on the given region server.
|
int |
getQueuesZNodeCversion()
Get the cversion of replication rs node.
|
List<String> |
getReplicableHFiles(String peerId)
Get a list of all hfile references in the given peer.
|
void |
init()
Initialize the replication queue client interface.
|
getListOfReplicatorsZK, getPeerNode, getPeerStateNode, getTableCFsNode, isPeerPath, peerExists, toByteArray
public ReplicationQueuesClientZKImpl(ZooKeeperWatcher zk, org.apache.hadoop.conf.Configuration conf, Abortable abortable)
public void init() throws ReplicationException
ReplicationQueuesClient
init
in interface ReplicationQueuesClient
ReplicationException
public List<String> getListOfReplicators() throws org.apache.zookeeper.KeeperException
ReplicationQueuesClient
getListOfReplicators
in interface ReplicationQueuesClient
org.apache.zookeeper.KeeperException
- zookeeper exceptionpublic List<String> getLogsInQueue(String serverName, String queueId) throws org.apache.zookeeper.KeeperException
ReplicationQueuesClient
getLogsInQueue
in interface ReplicationQueuesClient
serverName
- the server name of the region server that owns the queuequeueId
- a String that identifies the queueorg.apache.zookeeper.KeeperException
- zookeeper exceptionpublic List<String> getAllQueues(String serverName) throws org.apache.zookeeper.KeeperException
ReplicationQueuesClient
getAllQueues
in interface ReplicationQueuesClient
serverName
- the server name of the region server that owns the set of queuesorg.apache.zookeeper.KeeperException
public int getQueuesZNodeCversion() throws org.apache.zookeeper.KeeperException
ReplicationQueuesClient
getQueuesZNodeCversion
in interface ReplicationQueuesClient
org.apache.zookeeper.KeeperException
public int getHFileRefsNodeChangeVersion() throws org.apache.zookeeper.KeeperException
ReplicationQueuesClient
getHFileRefsNodeChangeVersion
in interface ReplicationQueuesClient
org.apache.zookeeper.KeeperException
public List<String> getAllPeersFromHFileRefsQueue() throws org.apache.zookeeper.KeeperException
ReplicationQueuesClient
getAllPeersFromHFileRefsQueue
in interface ReplicationQueuesClient
org.apache.zookeeper.KeeperException
- zookeeper exceptionpublic List<String> getReplicableHFiles(String peerId) throws org.apache.zookeeper.KeeperException
ReplicationQueuesClient
getReplicableHFiles
in interface ReplicationQueuesClient
peerId
- a String that identifies the peerorg.apache.zookeeper.KeeperException
- zookeeper exceptionCopyright © 2007–2019 The Apache Software Foundation. All rights reserved.