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 TypeMethodDescriptionvoid
ReplicationAdmin.addPeer
(String id, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) Deprecated.void
ReplicationAdmin.addPeer
(String id, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, Map<org.apache.hadoop.hbase.TableName, ? extends Collection<String>> tableCfs) Deprecated.as release of 2.0.0, and it will be removed in 3.0.0, useReplicationAdmin.addPeer(String, ReplicationPeerConfig)
instead.static org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerConfigUtil.appendExcludeTableCFsToReplicationPeerConfig
(Map<org.apache.hadoop.hbase.TableName, List<String>> excludeTableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) void
Deprecated.as release of 2.0.0, and it will be removed in 3.0.0, useReplicationAdmin.appendPeerTableCFs(String, Map)
instead.void
ReplicationAdmin.appendPeerTableCFs
(String id, Map<org.apache.hadoop.hbase.TableName, ? extends Collection<String>> tableCfs) Deprecated.boolean
ReplicationAdmin.getPeerState
(String id) Deprecated.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) void
Deprecated.as release of 2.0.0, and it will be removed in 3.0.0, useReplicationAdmin.removePeerTableCFs(String, Map)
instead.void
ReplicationAdmin.removePeerTableCFs
(String id, Map<org.apache.hadoop.hbase.TableName, ? extends Collection<String>> tableCfs) Deprecated.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.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
FSReplicationPeerStorage.addPeer
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled) 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) Add a replication peer.void
ZKReplicationPeerStorage.addPeer
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled) void
ReplicationQueueStorage.addPeerToHFileRefs
(String peerId) Add a peer to hfile reference queue if peer does not exist.void
ReplicationQueueStorage.addWAL
(org.apache.hadoop.hbase.ServerName serverName, String queueId, String fileName) Add a new WAL file to the given queue for a given regionserver.ReplicationQueueStorage.claimQueue
(org.apache.hadoop.hbase.ServerName sourceServerName, String queueId, org.apache.hadoop.hbase.ServerName destServerName) Change ownership for the queue identified by queueId and belongs to a dead region server.ReplicationQueueStorage.getAllHFileRefs()
Load all hfile references in all replication queues.ReplicationQueueStorage.getAllPeersFromHFileRefsQueue()
Get list of all peers from hfile reference queue.ReplicationQueueStorage.getAllQueues
(org.apache.hadoop.hbase.ServerName serverName) Get a list of all queues for the specified region server.ReplicationQueueStorage.getAllWALs()
Load all wals in all replication queues.long
Read the max sequence id of the specific region for a given peer.List<org.apache.hadoop.hbase.ServerName>
ReplicationQueueStorage.getListOfReplicators()
Get a list of all region servers that have outstanding replication queues.static org.apache.hadoop.conf.Configuration
ReplicationUtils.getPeerClusterConfiguration
(org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, org.apache.hadoop.conf.Configuration baseConf) 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) ReplicationQueueStorage.getReplicableHFiles
(String peerId) Get a list of all hfile references in the given peer.long
ReplicationQueueStorage.getWALPosition
(org.apache.hadoop.hbase.ServerName serverName, String queueId, String fileName) Get the current position for a specific WAL in a given queue for a given regionserver.ReplicationQueueStorage.getWALsInQueue
(org.apache.hadoop.hbase.ServerName serverName, String queueId) Get a list of all WALs in the given queue on the given region server.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) 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.ReplicationPeer.PeerState
ReplicationPeers.refreshPeerState
(String peerId) static void
ReplicationUtils.removeAllQueues
(org.apache.hadoop.hbase.replication.ReplicationQueueStorage queueStorage, String peerId) void
Remove hfile references from the queue.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
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
ReplicationQueueStorage.removeQueue
(org.apache.hadoop.hbase.ServerName serverName, String queueId) Remove a replication queue for a given regionserver.void
ReplicationQueueStorage.removeReplicatorIfQueueIsEmpty
(org.apache.hadoop.hbase.ServerName serverName) Remove the record of region server if the queue is empty.void
ReplicationQueueStorage.removeWAL
(org.apache.hadoop.hbase.ServerName serverName, String queueId, String fileName) Remove an WAL file from the given queue for a given regionserver.void
Set the max sequence id of a bunch of regions for a given peer.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
ReplicationQueueStorage.setWALPosition
(org.apache.hadoop.hbase.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.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 informationstatic void
ServerRegionReplicaUtil.setupRegionReplicaReplication
(org.apache.hadoop.hbase.master.MasterServices services) Create replication peer for replicating user-space Region Read Replicas. -
Uses of org.apache.hadoop.hbase.replication.ReplicationException in org.apache.hadoop.hbase.util.hbck
Modifier and TypeMethodDescriptionvoid
ReplicationChecker.checkUnDeletedQueues()
void
ReplicationChecker.fixUnDeletedQueues()
Admin.addReplicationPeer(String, ReplicationPeerConfig)
instead