@InterfaceAudience.Private class NoopReplicationQueueStorage extends Object implements ReplicationQueueStorage
Constructor and Description |
---|
NoopReplicationQueueStorage() |
Modifier and Type | Method and Description |
---|---|
void |
addHFileRefs(String peerId,
List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs)
Add new hfile references to the queue.
|
void |
addPeerToHFileRefs(String peerId)
Add a peer to hfile reference queue if peer does not exist.
|
void |
addWAL(ServerName serverName,
String queueId,
String fileName)
Add a new WAL file to the given queue for a given regionserver.
|
Pair<String,SortedSet<String>> |
claimQueue(ServerName sourceServerName,
String queueId,
ServerName destServerName)
Change ownership for the queue identified by queueId and belongs to a dead region server.
|
Set<String> |
getAllHFileRefs()
Load all hfile references in all replication queues.
|
List<String> |
getAllPeersFromHFileRefsQueue()
Get list of all peers from hfile reference queue.
|
List<String> |
getAllQueues(ServerName serverName)
Get a list of all queues for the specified region server.
|
Set<String> |
getAllWALs()
Load all wals in all replication queues.
|
long |
getLastSequenceId(String encodedRegionName,
String peerId)
Read the max sequence id of the specific region for a given peer.
|
List<ServerName> |
getListOfReplicators()
Get a list of all region servers that have outstanding replication queues.
|
List<String> |
getReplicableHFiles(String peerId)
Get a list of all hfile references in the given peer.
|
String |
getRsNode(ServerName serverName)
Get full znode name for given region server
|
long |
getWALPosition(ServerName serverName,
String queueId,
String fileName)
Get the current position for a specific WAL in a given queue for a given regionserver.
|
List<String> |
getWALsInQueue(ServerName serverName,
String queueId)
Get a list of all WALs in the given queue on the given region server.
|
void |
removeHFileRefs(String peerId,
List<String> files)
Remove hfile references from the queue.
|
void |
removeLastSequenceIds(String peerId)
Remove all the max sequence id record for the given peer.
|
void |
removeLastSequenceIds(String peerId,
List<String> encodedRegionNames)
Remove the max sequence id record for the given peer and regions.
|
void |
removePeerFromHFileRefs(String peerId)
Remove a peer from hfile reference queue.
|
void |
removeQueue(ServerName serverName,
String queueId)
Remove a replication queue for a given regionserver.
|
void |
removeReplicatorIfQueueIsEmpty(ServerName serverName)
Remove the record of region server if the queue is empty.
|
void |
removeWAL(ServerName serverName,
String queueId,
String fileName)
Remove an WAL file from the given queue for a given regionserver.
|
void |
setLastSequenceIds(String peerId,
Map<String,Long> lastSeqIds)
Set the max sequence id of a bunch of regions for a given peer.
|
void |
setWALPosition(ServerName serverName,
String queueId,
String fileName,
long position,
Map<String,Long> lastSeqIds)
Set the current position for a specific WAL in a given queue for a given regionserver.
|
NoopReplicationQueueStorage()
public void removeQueue(ServerName serverName, String queueId) throws ReplicationException
ReplicationQueueStorage
removeQueue
in interface ReplicationQueueStorage
serverName
- the name of the regionserverqueueId
- a String that identifies the queue.ReplicationException
public void addWAL(ServerName serverName, String queueId, String fileName) throws ReplicationException
ReplicationQueueStorage
addWAL
in interface ReplicationQueueStorage
serverName
- the name of the regionserverqueueId
- a String that identifies the queue.fileName
- name of the WALReplicationException
public void removeWAL(ServerName serverName, String queueId, String fileName) throws ReplicationException
ReplicationQueueStorage
removeWAL
in interface ReplicationQueueStorage
serverName
- the name of the regionserverqueueId
- a String that identifies the queue.fileName
- name of the WALReplicationException
public void setWALPosition(ServerName serverName, String queueId, String fileName, long position, Map<String,Long> lastSeqIds) throws ReplicationException
ReplicationQueueStorage
setWALPosition
in interface ReplicationQueueStorage
serverName
- the name of the regionserverqueueId
- a String that identifies the queuefileName
- name of the WALposition
- the current position in the file. Will ignore if less than or equal to 0.lastSeqIds
- map with {encodedRegionName, sequenceId} pairs for serial replication.ReplicationException
public long getLastSequenceId(String encodedRegionName, String peerId) throws ReplicationException
ReplicationQueueStorage
getLastSequenceId
in interface ReplicationQueueStorage
encodedRegionName
- the encoded region namepeerId
- peer idReplicationException
public void setLastSequenceIds(String peerId, Map<String,Long> lastSeqIds) throws ReplicationException
ReplicationQueueStorage
setLastSequenceIds
in interface ReplicationQueueStorage
peerId
- peer idlastSeqIds
- map with {encodedRegionName, sequenceId} pairs for serial replication.ReplicationException
public void removeLastSequenceIds(String peerId) throws ReplicationException
ReplicationQueueStorage
removeLastSequenceIds
in interface ReplicationQueueStorage
peerId
- peer idReplicationException
public void removeLastSequenceIds(String peerId, List<String> encodedRegionNames) throws ReplicationException
ReplicationQueueStorage
removeLastSequenceIds
in interface ReplicationQueueStorage
peerId
- peer idencodedRegionNames
- the encoded region namesReplicationException
public long getWALPosition(ServerName serverName, String queueId, String fileName) throws ReplicationException
ReplicationQueueStorage
getWALPosition
in interface ReplicationQueueStorage
serverName
- the name of the regionserverqueueId
- a String that identifies the queuefileName
- name of the WALReplicationException
public List<String> getWALsInQueue(ServerName serverName, String queueId) throws ReplicationException
ReplicationQueueStorage
getWALsInQueue
in interface ReplicationQueueStorage
serverName
- the server name of the region server that owns the queuequeueId
- a String that identifies the queueReplicationException
public List<String> getAllQueues(ServerName serverName) throws ReplicationException
ReplicationQueueStorage
getAllQueues
in interface ReplicationQueueStorage
serverName
- the server name of the region server that owns the set of queuesReplicationException
public Pair<String,SortedSet<String>> claimQueue(ServerName sourceServerName, String queueId, ServerName destServerName) throws ReplicationException
ReplicationQueueStorage
claimQueue
in interface ReplicationQueueStorage
sourceServerName
- the name of the dead region serverqueueId
- the id of the queuedestServerName
- the name of the target region serverReplicationException
public void removeReplicatorIfQueueIsEmpty(ServerName serverName) throws ReplicationException
ReplicationQueueStorage
removeReplicatorIfQueueIsEmpty
in interface ReplicationQueueStorage
ReplicationException
public List<ServerName> getListOfReplicators() throws ReplicationException
ReplicationQueueStorage
getListOfReplicators
in interface ReplicationQueueStorage
ReplicationException
public Set<String> getAllWALs() throws ReplicationException
ReplicationQueueStorage
getAllWALs
in interface ReplicationQueueStorage
ReplicationException
public void addPeerToHFileRefs(String peerId) throws ReplicationException
ReplicationQueueStorage
addPeerToHFileRefs
in interface ReplicationQueueStorage
peerId
- peer cluster id to be addedReplicationException
- if fails to add a peer id to hfile reference queuepublic void removePeerFromHFileRefs(String peerId) throws ReplicationException
ReplicationQueueStorage
removePeerFromHFileRefs
in interface ReplicationQueueStorage
peerId
- peer cluster id to be removedReplicationException
public void addHFileRefs(String peerId, List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs) throws ReplicationException
ReplicationQueueStorage
addHFileRefs
in interface ReplicationQueueStorage
peerId
- peer cluster id to which the hfiles need to be replicatedpairs
- list of pairs of { HFile location in staging dir, HFile path in region dir which
will be added in the queue }ReplicationException
- if fails to add a hfile referencepublic void removeHFileRefs(String peerId, List<String> files) throws ReplicationException
ReplicationQueueStorage
removeHFileRefs
in interface ReplicationQueueStorage
peerId
- peer cluster id from which this hfile references needs to be removedfiles
- list of hfile references to be removedReplicationException
public List<String> getAllPeersFromHFileRefsQueue() throws ReplicationException
ReplicationQueueStorage
getAllPeersFromHFileRefsQueue
in interface ReplicationQueueStorage
ReplicationException
public List<String> getReplicableHFiles(String peerId) throws ReplicationException
ReplicationQueueStorage
getReplicableHFiles
in interface ReplicationQueueStorage
peerId
- a String that identifies the peerReplicationException
public Set<String> getAllHFileRefs() throws ReplicationException
ReplicationQueueStorage
getAllHFileRefs
in interface ReplicationQueueStorage
ReplicationException
public String getRsNode(ServerName serverName)
ReplicationQueueStorage
getRsNode
in interface ReplicationQueueStorage
serverName
- the name of the region serverCopyright © 2007–2020 The Apache Software Foundation. All rights reserved.