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 TypeMethodDescriptionstatic org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerConfigUtil.appendExcludeTableCFsToReplicationPeerConfig(Map<org.apache.hadoop.hbase.TableName, List<String>> excludeTableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) 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) 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.transitReplicationPeerSyncReplicationState(String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState state) longMasterServices.transitReplicationPeerSyncReplicationState(String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState clusterState) Set current cluster state for a synchronous replication peer.longHMaster.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.voidTableReplicationQueueStorage.addHFileRefs(String peerId, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.fs.Path, org.apache.hadoop.fs.Path>> pairs) voidFSReplicationPeerStorage.addPeer(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled, org.apache.hadoop.hbase.replication.SyncReplicationState syncReplicationState) 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, org.apache.hadoop.hbase.replication.SyncReplicationState syncReplicationState) Add a replication peer.voidZKReplicationPeerStorage.addPeer(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled, org.apache.hadoop.hbase.replication.SyncReplicationState syncReplicationState) voidAdd the given hfile refs to the given peer.voidvoidReplicationQueueStorage.batchUpdateLastSequenceIds(List<org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration.ZkLastPushedSeqId> lastPushedSeqIds) Update last pushed sequence id for the given regions and peers.voidTableReplicationQueueStorage.batchUpdateLastSequenceIds(List<org.apache.hadoop.hbase.replication.ZKReplicationQueueStorageForMigration.ZkLastPushedSeqId> lastPushedSeqIds) voidReplicationQueueStorage.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.voidTableReplicationQueueStorage.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()longRead the max sequence id of the specific region for a given peer.longReplicationQueueStorage.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.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) org.apache.hadoop.hbase.replication.SyncReplicationStateFSReplicationPeerStorage.getPeerNewSyncReplicationState(String peerId) org.apache.hadoop.hbase.replication.SyncReplicationStateReplicationPeerStorage.getPeerNewSyncReplicationState(String peerId) Get the new sync replication state.org.apache.hadoop.hbase.replication.SyncReplicationStateZKReplicationPeerStorage.getPeerNewSyncReplicationState(String peerId) org.apache.hadoop.hbase.replication.SyncReplicationStateFSReplicationPeerStorage.getPeerSyncReplicationState(String peerId) org.apache.hadoop.hbase.replication.SyncReplicationStateReplicationPeerStorage.getPeerSyncReplicationState(String peerId) Get the sync replication state.org.apache.hadoop.hbase.replication.SyncReplicationStateZKReplicationPeerStorage.getPeerSyncReplicationState(String peerId) ReplicationQueueStorage.getReplicableHFiles(String peerId) Get a list of all hfile references in the given peer.TableReplicationQueueStorage.getReplicableHFiles(String peerId) booleanReplicationQueueStorage.hasData()Whether the replication queue table exists.booleanTableReplicationQueueStorage.hasData()voidReplicationPeers.init()booleanFSReplicationPeerStorage.isPeerEnabled(String peerId) booleanReplicationPeerStorage.isPeerEnabled(String peerId) Test whether a replication peer is enabled.booleanZKReplicationPeerStorage.isPeerEnabled(String peerId) ReplicationQueueStorage.listAllPeerIds()Get a list of all peer ids.TableReplicationQueueStorage.listAllPeerIds()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.ReplicationPeerConfigReplicationPeers.refreshPeerConfig(String peerId) org.apache.hadoop.hbase.replication.SyncReplicationStateReplicationPeers.refreshPeerNewSyncReplicationState(String peerId) org.apache.hadoop.hbase.replication.ReplicationPeer.PeerStateReplicationPeers.refreshPeerState(String peerId) voidReplicationQueueStorage.removeAllQueues(String peerId) Remove all the replication queues for the given peer.voidTableReplicationQueueStorage.removeAllQueues(String peerId) voidRemove hfile references from the queue.voidvoidReplicationQueueStorage.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.voidTableReplicationQueueStorage.removeLastSequenceIds(String peerId) voidvoidReplicationQueueStorage.removeLastSequenceIdsAndHFileRefsBefore(long ts) Remove all the last sequence ids and hfile references data which are written before the given timestamp.voidTableReplicationQueueStorage.removeLastSequenceIdsAndHFileRefsBefore(long ts) 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.voidTableReplicationQueueStorage.removePeerFromHFileRefs(String peerId) voidReplicationQueueStorage.removeQueue(org.apache.hadoop.hbase.replication.ReplicationQueueId queueId) Remove a replication queuevoidTableReplicationQueueStorage.removeQueue(org.apache.hadoop.hbase.replication.ReplicationQueueId queueId) voidSet the max sequence id of a bunch of regions for a given peer.voidvoidReplicationQueueStorage.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.voidTableReplicationQueueStorage.setOffset(org.apache.hadoop.hbase.replication.ReplicationQueueId queueId, String walGroup, org.apache.hadoop.hbase.replication.ReplicationGroupOffset offset, Map<String, Long> lastSeqIds) voidFSReplicationPeerStorage.setPeerNewSyncReplicationState(String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState newState) voidReplicationPeerStorage.setPeerNewSyncReplicationState(String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState state) Set the new sync replication state that we are going to transit to.voidZKReplicationPeerStorage.setPeerNewSyncReplicationState(String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState state) 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) voidFSReplicationPeerStorage.transitPeerSyncReplicationState(String peerId) voidReplicationPeerStorage.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.voidZKReplicationPeerStorage.transitPeerSyncReplicationState(String peerId) 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 information -
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 TypeMethodDescriptionbooleanReplicationChecker.checkHasDataInQueues()voidReplicationChecker.checkUnDeletedQueues()voidReplicationChecker.fixUnDeletedQueues()