Uses of Class
org.apache.hadoop.hbase.replication.ReplicationException
Packages that use 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
Methods in org.apache.hadoop.hbase.client that throw org.apache.hadoop.hbase.replication.ReplicationException in inModifier and TypeMethodDescriptiondefault voidAdmin.appendReplicationPeerTableCFs(String id, Map<org.apache.hadoop.hbase.TableName, List<String>> tableCfs) Append the replicable table column family config from the specified peer.default voidAdmin.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
Methods in org.apache.hadoop.hbase.client.replication that throw org.apache.hadoop.hbase.replication.ReplicationException in inModifier and TypeMethodDescriptionvoidReplicationAdmin.addPeer(String id, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) Deprecated.voidReplicationAdmin.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.ReplicationPeerConfigReplicationPeerConfigUtil.appendExcludeTableCFsToReplicationPeerConfig(Map<org.apache.hadoop.hbase.TableName, List<String>> excludeTableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) voidDeprecated.as release of 2.0.0, and it will be removed in 3.0.0, useReplicationAdmin.appendPeerTableCFs(String, Map)instead.voidReplicationAdmin.appendPeerTableCFs(String id, Map<org.apache.hadoop.hbase.TableName, ? extends Collection<String>> tableCfs) Deprecated.booleanReplicationAdmin.getPeerState(String id) Deprecated.static org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerConfigUtil.removeExcludeTableCFsFromReplicationPeerConfig(Map<org.apache.hadoop.hbase.TableName, List<String>> excludeTableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, String id) voidDeprecated.as release of 2.0.0, and it will be removed in 3.0.0, useReplicationAdmin.removePeerTableCFs(String, Map)instead.voidReplicationAdmin.removePeerTableCFs(String id, Map<org.apache.hadoop.hbase.TableName, ? extends Collection<String>> tableCfs) Deprecated.static org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerConfigUtil.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
Methods in org.apache.hadoop.hbase.master that throw org.apache.hadoop.hbase.replication.ReplicationException in inModifier and TypeMethodDescriptionlongHMaster.addReplicationPeer(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled) longMasterServices.addReplicationPeer(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled) Add a new replication peer for replicating data to slave clusterlongHMaster.disableReplicationPeer(String peerId) longMasterServices.disableReplicationPeer(String peerId) Stop the replication stream to the specified peerlongHMaster.enableReplicationPeer(String peerId) longMasterServices.enableReplicationPeer(String peerId) Restart the replication stream to the specified peerorg.apache.hadoop.hbase.replication.ReplicationPeerConfigHMaster.getReplicationPeerConfig(String peerId) org.apache.hadoop.hbase.replication.ReplicationPeerConfigMasterServices.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.longHMaster.removeReplicationPeer(String peerId) longMasterServices.removeReplicationPeer(String peerId) Removes a peer and stops the replicationlongHMaster.updateReplicationPeerConfig(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) longMasterServices.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
Methods in org.apache.hadoop.hbase.replication that throw org.apache.hadoop.hbase.replication.ReplicationException in inModifier and TypeMethodDescriptionvoidReplicationQueueStorage.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.voidFSReplicationPeerStorage.addPeer(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled) booleanReplicationPeers.addPeer(String peerId) Method called after a peer has been connected.voidReplicationPeerStorage.addPeer(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled) Add a replication peer.voidZKReplicationPeerStorage.addPeer(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled) voidReplicationQueueStorage.addPeerToHFileRefs(String peerId) Add a peer to hfile reference queue if peer does not exist.voidReplicationQueueStorage.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.longRead 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.ConfigurationReplicationUtils.getPeerClusterConfiguration(org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, org.apache.hadoop.conf.Configuration baseConf) org.apache.hadoop.hbase.replication.ReplicationPeerConfigFSReplicationPeerStorage.getPeerConfig(String peerId) org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerStorage.getPeerConfig(String peerId) Get the peer config of a replication peer.org.apache.hadoop.hbase.replication.ReplicationPeerConfigZKReplicationPeerStorage.getPeerConfig(String peerId) ReplicationQueueStorage.getReplicableHFiles(String peerId) Get a list of all hfile references in the given peer.longReplicationQueueStorage.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.voidReplicationPeers.init()booleanFSReplicationPeerStorage.isPeerEnabled(String peerId) booleanReplicationPeerStorage.isPeerEnabled(String peerId) Test whether a replication peer is enabled.booleanZKReplicationPeerStorage.isPeerEnabled(String peerId) FSReplicationPeerStorage.listPeerIds()ReplicationPeerStorage.listPeerIds()Return the peer ids of all replication peers.ZKReplicationPeerStorage.listPeerIds()org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeers.refreshPeerConfig(String peerId) org.apache.hadoop.hbase.replication.ReplicationPeer.PeerStateReplicationPeers.refreshPeerState(String peerId) static voidReplicationUtils.removeAllQueues(org.apache.hadoop.hbase.replication.ReplicationQueueStorage queueStorage, String peerId) voidRemove hfile references from the queue.voidReplicationQueueStorage.removeLastSequenceIds(String peerId) Remove all the max sequence id record for the given peer.voidRemove the max sequence id record for the given peer and regions.voidFSReplicationPeerStorage.removePeer(String peerId) voidReplicationPeerStorage.removePeer(String peerId) Remove a replication peer.voidZKReplicationPeerStorage.removePeer(String peerId) voidReplicationQueueStorage.removePeerFromHFileRefs(String peerId) Remove a peer from hfile reference queue.voidReplicationQueueStorage.removeQueue(org.apache.hadoop.hbase.ServerName serverName, String queueId) Remove a replication queue for a given regionserver.voidReplicationQueueStorage.removeReplicatorIfQueueIsEmpty(org.apache.hadoop.hbase.ServerName serverName) Remove the record of region server if the queue is empty.voidReplicationQueueStorage.removeWAL(org.apache.hadoop.hbase.ServerName serverName, String queueId, String fileName) Remove an WAL file from the given queue for a given regionserver.voidSet the max sequence id of a bunch of regions for a given peer.voidFSReplicationPeerStorage.setPeerState(String peerId, boolean enabled) voidReplicationPeerStorage.setPeerState(String peerId, boolean enabled) Set the state of peer,truetoENABLED, otherwise toDISABLED.voidZKReplicationPeerStorage.setPeerState(String peerId, boolean enabled) voidReplicationQueueStorage.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.voidFSReplicationPeerStorage.updatePeerConfig(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) voidReplicationPeerStorage.updatePeerConfig(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) Update the config a replication peer.voidZKReplicationPeerStorage.updatePeerConfig(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) -
Uses of org.apache.hadoop.hbase.replication.ReplicationException in org.apache.hadoop.hbase.util
Methods in org.apache.hadoop.hbase.util that throw org.apache.hadoop.hbase.replication.ReplicationException in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.util.HBaseFsckHBaseFsck.exec(ExecutorService exec, String[] args) Deprecated.intHBaseFsck.onlineHbck()Deprecated.Contacts the master and prints out cluster-wide informationstatic voidServerRegionReplicaUtil.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
Methods in org.apache.hadoop.hbase.util.hbck that throw org.apache.hadoop.hbase.replication.ReplicationException in inModifier and TypeMethodDescriptionvoidReplicationChecker.checkUnDeletedQueues()voidReplicationChecker.fixUnDeletedQueues()
Admin.addReplicationPeer(String, ReplicationPeerConfig)instead