Uses of Class
org.apache.hadoop.hbase.replication.ReplicationQueueId
Package
Description
Multi Cluster Replication
-
Uses of ReplicationQueueId in org.apache.hadoop.hbase.master.replication
Modifier and TypeFieldDescriptionprivate ReplicationQueueId
ClaimReplicationQueueRemoteProcedure.queueId
Modifier and TypeFieldDescriptionprivate final Map<ReplicationQueueId,
Map<String, ReplicationGroupOffset>> OfflineTableReplicationQueueStorage.offsets
Modifier and TypeMethodDescriptionOfflineTableReplicationQueueStorage.listAllQueueIds
(String peerId) OfflineTableReplicationQueueStorage.listAllQueueIds
(String peerId, ServerName serverName) OfflineTableReplicationQueueStorage.listAllQueueIds
(ServerName serverName) Modifier and TypeMethodDescriptionOfflineTableReplicationQueueStorage.claimQueue
(ReplicationQueueId queueId, ServerName targetServerName) OfflineTableReplicationQueueStorage.getOffsets
(ReplicationQueueId queueId) void
OfflineTableReplicationQueueStorage.removeQueue
(ReplicationQueueId queueId) void
OfflineTableReplicationQueueStorage.setOffset
(ReplicationQueueId queueId, String walGroup, ReplicationGroupOffset offset, Map<String, Long> lastSeqIds) ModifierConstructorDescriptionClaimReplicationQueueRemoteProcedure
(ReplicationQueueId queueId, ServerName targetServer) -
Uses of ReplicationQueueId in org.apache.hadoop.hbase.replication
Modifier and TypeFieldDescriptionprivate final ReplicationQueueId
ReplicationQueueData.id
private final ReplicationQueueId
ZKReplicationQueueStorageForMigration.ZkReplicationQueueData.queueId
Modifier and TypeMethodDescriptionReplicationQueueId.claim
(ServerName targetServerName) ReplicationQueueData.getId()
ZKReplicationQueueStorageForMigration.ZkReplicationQueueData.getQueueId()
static ReplicationQueueId
Modifier and TypeMethodDescriptionReplicationQueueStorage.listAllQueueIds
(String peerId) Get a list of all queues for the specific peer.ReplicationQueueStorage.listAllQueueIds
(String peerId, ServerName serverName) Get a list of all queues for the specific region server and the specific peerReplicationQueueStorage.listAllQueueIds
(ServerName serverName) Get a list of all queues for the specific region server.TableReplicationQueueStorage.listAllQueueIds
(String peerId) TableReplicationQueueStorage.listAllQueueIds
(String peerId, ServerName serverName) TableReplicationQueueStorage.listAllQueueIds
(ServerName serverName) Modifier and TypeMethodDescriptionReplicationQueueStorage.claimQueue
(ReplicationQueueId queueId, ServerName targetServerName) Change ownership for the queue identified by queueId and belongs to a dead region server.TableReplicationQueueStorage.claimQueue
(ReplicationQueueId queueId, ServerName targetServerName) ReplicationQueueStorage.getOffsets
(ReplicationQueueId queueId) Get the current offset of all the WAL groups for a queueTableReplicationQueueStorage.getOffsets
(ReplicationQueueId queueId) private Map<String,
ReplicationGroupOffset> TableReplicationQueueStorage.getOffsets0
(Table table, ReplicationQueueId queueId) void
ReplicationQueueStorage.removeQueue
(ReplicationQueueId queueId) Remove a replication queuevoid
TableReplicationQueueStorage.removeQueue
(ReplicationQueueId queueId) void
ReplicationQueueStorage.setOffset
(ReplicationQueueId queueId, String walGroup, ReplicationGroupOffset offset, Map<String, Long> lastSeqIds) Set the current offset for a specific WAL group in a given queue.void
TableReplicationQueueStorage.setOffset
(ReplicationQueueId queueId, String walGroup, ReplicationGroupOffset offset, Map<String, Long> lastSeqIds) Modifier and TypeMethodDescriptionprivate void
TableReplicationQueueStorage.listAllQueueIds
(Table table, String peerId, ServerName serverName, List<ReplicationQueueId> queueIds) private void
TableReplicationQueueStorage.listAllQueueIds
(Table table, Scan scan, List<ReplicationQueueId> queueIds) ModifierConstructorDescriptionReplicationQueueData
(ReplicationQueueId id, org.apache.hbase.thirdparty.com.google.common.collect.ImmutableMap<String, ReplicationGroupOffset> offsets) ZkReplicationQueueData
(ReplicationQueueId queueId, Map<String, Long> walOffsets) -
Uses of ReplicationQueueId in org.apache.hadoop.hbase.replication.regionserver
Modifier and TypeFieldDescriptionprivate ReplicationQueueId
ClaimReplicationQueueCallable.queueId
protected ReplicationQueueId
ReplicationSource.queueId
Modifier and TypeFieldDescriptionprivate final ConcurrentMap<ReplicationQueueId,
Map<String, NavigableSet<String>>> ReplicationSourceManager.walsById
private final ConcurrentMap<ReplicationQueueId,
Map<String, NavigableSet<org.apache.hadoop.fs.Path>>> ReplicationSourceManager.walsByIdRecoveredQueues
Modifier and TypeMethodDescriptionReplicationSource.getQueueId()
ReplicationSourceInterface.getQueueId()
Get the queue id that the source is replicating toModifier and TypeMethodDescriptionReplicationSourceManager.getWALs()
Get a copy of the wals of the normal sources on this rsModifier and TypeMethodDescriptionprivate void
ReplicationSourceManager.addRecoveredSource
(ReplicationSourceInterface src, ReplicationPeerImpl oldPeer, ReplicationQueueId claimedQueueId, PriorityQueue<org.apache.hadoop.fs.Path> walFiles) (package private) void
ReplicationSourceManager.claimQueue
(ReplicationQueueId queueId) (package private) void
ReplicationSourceManager.claimQueue
(ReplicationQueueId queueId, boolean syncUp) Claim a replication queue.void
PeerProcedureHandler.claimReplicationQueue
(ReplicationQueueId queueId) void
PeerProcedureHandlerImpl.claimReplicationQueue
(ReplicationQueueId queueId) (package private) static ReplicationSourceInterface
ReplicationSourceFactory.create
(org.apache.hadoop.conf.Configuration conf, ReplicationQueueId queueId) private ReplicationSourceInterface
ReplicationSourceManager.createRefreshedSource
(ReplicationQueueId queueId, ReplicationPeer peer) private void
ReplicationSourceManager.deleteQueue
(ReplicationQueueId queueId) Delete a complete queue of wals associated with a replication sourceprivate String
DumpReplicationQueues.formatQueue
(ServerName regionServer, Map<String, ReplicationGroupOffset> offsets, List<String> wals, ReplicationQueueId queueId, boolean isDeleted, boolean hdfs) -
Uses of ReplicationQueueId in org.apache.hadoop.hbase.util.hbck
Modifier and TypeFieldDescriptionprivate Map<ServerName,
List<ReplicationQueueId>> ReplicationChecker.undeletedQueueIds
Modifier and TypeMethodDescriptionprivate Map<ServerName,
List<ReplicationQueueId>> ReplicationChecker.getUnDeletedQueues()