@InterfaceAudience.Private public class ReplicationQueuesZKImpl extends ReplicationStateZKBase implements ReplicationQueues
abortable, conf, DISABLED_ZNODE_BYTES, ENABLED_ZNODE_BYTES, ourClusterKey, peerStateNodeName, peersZNode, queuesZNode, replicationZNode, zookeeper| Constructor and Description | 
|---|
| ReplicationQueuesZKImpl(ZooKeeperWatcher zk,
                       org.apache.hadoop.conf.Configuration conf,
                       Abortable abortable) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | addLog(String queueId,
      String filename)Add a new WAL file to the given queue. | 
| boolean | checkLockExists(String znode) | 
| SortedMap<String,SortedSet<String>> | claimQueues(String regionserverZnode)Take ownership for the set of queues belonging to a dead region server. | 
| List<String> | getAllQueues()Get a list of all queues for this region server. | 
| String | getLockZNode(String znode) | 
| long | getLogPosition(String queueId,
              String filename)Get the current position for a specific WAL in a given queue. | 
| List<String> | getLogsInQueue(String queueId)Get a list of all WALs in the given queue. | 
| void | init(String serverName)Initialize the region server replication queue interface. | 
| boolean | isThisOurZnode(String znode)Checks if the provided znode is the same as this region server's | 
| boolean | lockOtherRS(String znode)Try to set a lock in another region server's znode. | 
| void | removeAllQueues()Remove all replication queues for this region server. | 
| void | removeLog(String queueId,
         String filename)Remove an WAL file from the given queue. | 
| void | removeQueue(String queueId)Remove a replication queue. | 
| void | setLogPosition(String queueId,
              String filename,
              long position)Set the current position for a specific WAL in a given queue. | 
getListOfReplicators, isPeerPath, peerExists, toByteArrayclone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitgetListOfReplicatorspublic ReplicationQueuesZKImpl(ZooKeeperWatcher zk, org.apache.hadoop.conf.Configuration conf, Abortable abortable)
public void init(String serverName) throws ReplicationException
ReplicationQueuesinit in interface ReplicationQueuesserverName - The server name of the region server that owns the replication queues this
          interface manages.ReplicationExceptionpublic void removeQueue(String queueId)
ReplicationQueuesremoveQueue in interface ReplicationQueuesqueueId - a String that identifies the queue.public void addLog(String queueId, String filename) throws ReplicationException
ReplicationQueuesaddLog in interface ReplicationQueuesqueueId - a String that identifies the queue.filename - name of the WALReplicationExceptionpublic void removeLog(String queueId, String filename)
ReplicationQueuesremoveLog in interface ReplicationQueuesqueueId - a String that identifies the queue.filename - name of the WALpublic void setLogPosition(String queueId, String filename, long position)
ReplicationQueuessetLogPosition in interface ReplicationQueuesqueueId - a String that identifies the queuefilename - name of the WALposition - the current position in the filepublic long getLogPosition(String queueId, String filename) throws ReplicationException
ReplicationQueuesgetLogPosition in interface ReplicationQueuesqueueId - a String that identifies the queuefilename - name of the WALReplicationExceptionpublic boolean isThisOurZnode(String znode)
ReplicationQueuesisThisOurZnode in interface ReplicationQueuesznode - to checkpublic SortedMap<String,SortedSet<String>> claimQueues(String regionserverZnode)
ReplicationQueuesclaimQueues in interface ReplicationQueuesregionserverZnode - the id of the dead region serverpublic void removeAllQueues()
ReplicationQueuesremoveAllQueues in interface ReplicationQueuespublic List<String> getLogsInQueue(String queueId)
ReplicationQueuesgetLogsInQueue in interface ReplicationQueuesqueueId - a String that identifies the queuepublic List<String> getAllQueues()
ReplicationQueuesgetAllQueues in interface ReplicationQueuespublic boolean lockOtherRS(String znode)
znode - the server names of the other serverpublic boolean checkLockExists(String znode) throws org.apache.zookeeper.KeeperException
org.apache.zookeeper.KeeperExceptionCopyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.