Uses of Class
org.apache.hadoop.hbase.replication.ReplicationException
Package
Description
Provides HBase Client
Multi Cluster Replication
-
Uses of org.apache.hadoop.hbase.replication.ReplicationException in org.apache.hadoop.hbase.client
Modifier and TypeMethodDescriptiondefault void
Admin.appendReplicationPeerTableCFs
(String id, Map<org.apache.hadoop.hbase.TableName, List<String>> tableCfs) Append the replicable table column family config from the specified peer.default void
Admin.removeReplicationPeerTableCFs
(String id, Map<org.apache.hadoop.hbase.TableName, List<String>> tableCfs) Remove some table-cfs from config of the specified peer. -
Uses of org.apache.hadoop.hbase.replication.ReplicationException in org.apache.hadoop.hbase.client.replication
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerConfigUtil.appendExcludeTableCFsToReplicationPeerConfig
(Map<org.apache.hadoop.hbase.TableName, List<String>> excludeTableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) static org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerConfigUtil.removeExcludeTableCFsFromReplicationPeerConfig
(Map<org.apache.hadoop.hbase.TableName, List<String>> excludeTableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, String id) static org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerConfigUtil.removeTableCFsFromReplicationPeerConfig
(Map<org.apache.hadoop.hbase.TableName, List<String>> tableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, String id) -
Uses of org.apache.hadoop.hbase.replication.ReplicationException in org.apache.hadoop.hbase.master
Modifier and TypeMethodDescriptionlong
HMaster.addReplicationPeer
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled) long
MasterServices.addReplicationPeer
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled) Add a new replication peer for replicating data to slave clusterlong
HMaster.disableReplicationPeer
(String peerId) long
MasterServices.disableReplicationPeer
(String peerId) Stop the replication stream to the specified peerlong
HMaster.enableReplicationPeer
(String peerId) long
MasterServices.enableReplicationPeer
(String peerId) Restart the replication stream to the specified peerorg.apache.hadoop.hbase.replication.ReplicationPeerConfig
HMaster.getReplicationPeerConfig
(String peerId) org.apache.hadoop.hbase.replication.ReplicationPeerConfig
MasterServices.getReplicationPeerConfig
(String peerId) Returns the configured ReplicationPeerConfig for the specified peerList<org.apache.hadoop.hbase.replication.ReplicationPeerDescription>
HMaster.listReplicationPeers
(String regex) List<org.apache.hadoop.hbase.replication.ReplicationPeerDescription>
MasterServices.listReplicationPeers
(String regex) Return a list of replication peers.long
HMaster.removeReplicationPeer
(String peerId) long
MasterServices.removeReplicationPeer
(String peerId) Removes a peer and stops the replicationlong
HMaster.transitReplicationPeerSyncReplicationState
(String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState state) long
MasterServices.transitReplicationPeerSyncReplicationState
(String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState clusterState) Set current cluster state for a synchronous replication peer.long
HMaster.updateReplicationPeerConfig
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) long
MasterServices.updateReplicationPeerConfig
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) Update the peerConfig for the specified peer -
Uses of org.apache.hadoop.hbase.replication.ReplicationException in org.apache.hadoop.hbase.replication
Modifier and TypeMethodDescriptionvoid
ReplicationQueueStorage.addHFileRefs
(String peerId, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.fs.Path, org.apache.hadoop.fs.Path>> pairs) Add new hfile references to the queue.void
TableReplicationQueueStorage.addHFileRefs
(String peerId, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.fs.Path, org.apache.hadoop.fs.Path>> pairs) void
FSReplicationPeerStorage.addPeer
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled, org.apache.hadoop.hbase.replication.SyncReplicationState syncReplicationState) boolean
ReplicationPeers.addPeer
(String peerId) Method called after a peer has been connected.void
ReplicationPeerStorage.addPeer
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled, org.apache.hadoop.hbase.replication.SyncReplicationState syncReplicationState) Add a replication peer.void
ZKReplicationPeerStorage.addPeer
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled, org.apache.hadoop.hbase.replication.SyncReplicationState syncReplicationState) void
Add the given hfile refs to the given peer.void
void
ReplicationQueueStorage.batchUpdateLastSequenceIds
(List<org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration.ZkLastPushedSeqId> lastPushedSeqIds) Update last pushed sequence id for the given regions and peers.void
TableReplicationQueueStorage.batchUpdateLastSequenceIds
(List<org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration.ZkLastPushedSeqId> lastPushedSeqIds) void
ReplicationQueueStorage.batchUpdateQueues
(org.apache.hadoop.hbase.ServerName serverName, List<org.apache.hadoop.hbase.replication.ReplicationQueueData> datas) Update the replication queue datas for a given region server.void
TableReplicationQueueStorage.batchUpdateQueues
(org.apache.hadoop.hbase.ServerName serverName, List<org.apache.hadoop.hbase.replication.ReplicationQueueData> datas) ReplicationQueueStorage.claimQueue
(org.apache.hadoop.hbase.replication.ReplicationQueueId queueId, org.apache.hadoop.hbase.ServerName targetServerName) Change ownership for the queue identified by queueId and belongs to a dead region server.TableReplicationQueueStorage.claimQueue
(org.apache.hadoop.hbase.replication.ReplicationQueueId queueId, org.apache.hadoop.hbase.ServerName targetServerName) ReplicationQueueStorage.getAllHFileRefs()
Load all hfile references in all replication queues.TableReplicationQueueStorage.getAllHFileRefs()
ReplicationQueueStorage.getAllPeersFromHFileRefsQueue()
Get list of all peers from hfile reference queue.TableReplicationQueueStorage.getAllPeersFromHFileRefsQueue()
long
Read the max sequence id of the specific region for a given peer.long
ReplicationQueueStorage.getOffsets
(org.apache.hadoop.hbase.replication.ReplicationQueueId queueId) Get the current offset of all the WAL groups for a queueTableReplicationQueueStorage.getOffsets
(org.apache.hadoop.hbase.replication.ReplicationQueueId queueId) org.apache.hadoop.hbase.replication.ReplicationPeerConfig
FSReplicationPeerStorage.getPeerConfig
(String peerId) org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerStorage.getPeerConfig
(String peerId) Get the peer config of a replication peer.org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ZKReplicationPeerStorage.getPeerConfig
(String peerId) org.apache.hadoop.hbase.replication.SyncReplicationState
FSReplicationPeerStorage.getPeerNewSyncReplicationState
(String peerId) org.apache.hadoop.hbase.replication.SyncReplicationState
ReplicationPeerStorage.getPeerNewSyncReplicationState
(String peerId) Get the new sync replication state.org.apache.hadoop.hbase.replication.SyncReplicationState
ZKReplicationPeerStorage.getPeerNewSyncReplicationState
(String peerId) org.apache.hadoop.hbase.replication.SyncReplicationState
FSReplicationPeerStorage.getPeerSyncReplicationState
(String peerId) org.apache.hadoop.hbase.replication.SyncReplicationState
ReplicationPeerStorage.getPeerSyncReplicationState
(String peerId) Get the sync replication state.org.apache.hadoop.hbase.replication.SyncReplicationState
ZKReplicationPeerStorage.getPeerSyncReplicationState
(String peerId) ReplicationQueueStorage.getReplicableHFiles
(String peerId) Get a list of all hfile references in the given peer.TableReplicationQueueStorage.getReplicableHFiles
(String peerId) boolean
ReplicationQueueStorage.hasData()
Whether the replication queue table exists.boolean
TableReplicationQueueStorage.hasData()
void
ReplicationPeers.init()
boolean
FSReplicationPeerStorage.isPeerEnabled
(String peerId) boolean
ReplicationPeerStorage.isPeerEnabled
(String peerId) Test whether a replication peer is enabled.boolean
ZKReplicationPeerStorage.isPeerEnabled
(String peerId) List<org.apache.hadoop.hbase.replication.ReplicationQueueId>
ReplicationQueueStorage.listAllQueueIds
(String peerId) Get a list of all queues for the specific peer.List<org.apache.hadoop.hbase.replication.ReplicationQueueId>
ReplicationQueueStorage.listAllQueueIds
(String peerId, org.apache.hadoop.hbase.ServerName serverName) Get a list of all queues for the specific region server and the specific peerList<org.apache.hadoop.hbase.replication.ReplicationQueueId>
ReplicationQueueStorage.listAllQueueIds
(org.apache.hadoop.hbase.ServerName serverName) Get a list of all queues for the specific region server.List<org.apache.hadoop.hbase.replication.ReplicationQueueId>
TableReplicationQueueStorage.listAllQueueIds
(String peerId) List<org.apache.hadoop.hbase.replication.ReplicationQueueId>
TableReplicationQueueStorage.listAllQueueIds
(String peerId, org.apache.hadoop.hbase.ServerName serverName) List<org.apache.hadoop.hbase.replication.ReplicationQueueId>
TableReplicationQueueStorage.listAllQueueIds
(org.apache.hadoop.hbase.ServerName serverName) List<org.apache.hadoop.hbase.replication.ReplicationQueueData>
ReplicationQueueStorage.listAllQueues()
Get a list of all queues and the offsets.List<org.apache.hadoop.hbase.replication.ReplicationQueueData>
TableReplicationQueueStorage.listAllQueues()
List<org.apache.hadoop.hbase.ServerName>
ReplicationQueueStorage.listAllReplicators()
Get a list of all region servers that have outstanding replication queues.List<org.apache.hadoop.hbase.ServerName>
TableReplicationQueueStorage.listAllReplicators()
FSReplicationPeerStorage.listPeerIds()
ReplicationPeerStorage.listPeerIds()
Return the peer ids of all replication peers.ZKReplicationPeerStorage.listPeerIds()
org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeers.refreshPeerConfig
(String peerId) org.apache.hadoop.hbase.replication.SyncReplicationState
ReplicationPeers.refreshPeerNewSyncReplicationState
(String peerId) org.apache.hadoop.hbase.replication.ReplicationPeer.PeerState
ReplicationPeers.refreshPeerState
(String peerId) void
ReplicationQueueStorage.removeAllQueues
(String peerId) Remove all the replication queues for the given peer.void
TableReplicationQueueStorage.removeAllQueues
(String peerId) void
Remove hfile references from the queue.void
void
ReplicationQueueStorage.removeLastSequenceIds
(String peerId) Remove all the max sequence id record for the given peer.void
Remove the max sequence id record for the given peer and regions.void
TableReplicationQueueStorage.removeLastSequenceIds
(String peerId) void
void
ReplicationQueueStorage.removeLastSequenceIdsAndHFileRefsBefore
(long ts) Remove all the last sequence ids and hfile references data which are written before the given timestamp.void
TableReplicationQueueStorage.removeLastSequenceIdsAndHFileRefsBefore
(long ts) void
FSReplicationPeerStorage.removePeer
(String peerId) void
ReplicationPeerStorage.removePeer
(String peerId) Remove a replication peer.void
ZKReplicationPeerStorage.removePeer
(String peerId) void
ReplicationQueueStorage.removePeerFromHFileRefs
(String peerId) Remove a peer from hfile reference queue.void
TableReplicationQueueStorage.removePeerFromHFileRefs
(String peerId) void
ReplicationQueueStorage.removeQueue
(org.apache.hadoop.hbase.replication.ReplicationQueueId queueId) Remove a replication queuevoid
TableReplicationQueueStorage.removeQueue
(org.apache.hadoop.hbase.replication.ReplicationQueueId queueId) void
Set the max sequence id of a bunch of regions for a given peer.void
void
ReplicationQueueStorage.setOffset
(org.apache.hadoop.hbase.replication.ReplicationQueueId queueId, String walGroup, org.apache.hadoop.hbase.replication.ReplicationGroupOffset offset, Map<String, Long> lastSeqIds) Set the current offset for a specific WAL group in a given queue.void
TableReplicationQueueStorage.setOffset
(org.apache.hadoop.hbase.replication.ReplicationQueueId queueId, String walGroup, org.apache.hadoop.hbase.replication.ReplicationGroupOffset offset, Map<String, Long> lastSeqIds) void
FSReplicationPeerStorage.setPeerNewSyncReplicationState
(String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState newState) void
ReplicationPeerStorage.setPeerNewSyncReplicationState
(String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState state) Set the new sync replication state that we are going to transit to.void
ZKReplicationPeerStorage.setPeerNewSyncReplicationState
(String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState state) void
FSReplicationPeerStorage.setPeerState
(String peerId, boolean enabled) void
ReplicationPeerStorage.setPeerState
(String peerId, boolean enabled) Set the state of peer,true
toENABLED
, otherwise toDISABLED
.void
ZKReplicationPeerStorage.setPeerState
(String peerId, boolean enabled) void
FSReplicationPeerStorage.transitPeerSyncReplicationState
(String peerId) void
ReplicationPeerStorage.transitPeerSyncReplicationState
(String peerId) Overwrite the sync replication state with the new sync replication state which is set with theReplicationPeerStorage.setPeerNewSyncReplicationState(String, SyncReplicationState)
method above, and clear the new sync replication state.void
ZKReplicationPeerStorage.transitPeerSyncReplicationState
(String peerId) void
FSReplicationPeerStorage.updatePeerConfig
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) void
ReplicationPeerStorage.updatePeerConfig
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) Update the config a replication peer.void
ZKReplicationPeerStorage.updatePeerConfig
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) -
Uses of org.apache.hadoop.hbase.replication.ReplicationException in org.apache.hadoop.hbase.util
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.util.HBaseFsck
HBaseFsck.exec
(ExecutorService exec, String[] args) Deprecated.int
HBaseFsck.onlineHbck()
Deprecated.Contacts the master and prints out cluster-wide information -
Uses of org.apache.hadoop.hbase.replication.ReplicationException in org.apache.hadoop.hbase.util.hbck
Modifier and TypeMethodDescriptionboolean
ReplicationChecker.checkHasDataInQueues()
void
ReplicationChecker.checkUnDeletedQueues()
void
ReplicationChecker.fixUnDeletedQueues()