Uses of Class
org.apache.hadoop.hbase.replication.ReplicationException
Packages that use ReplicationException
Package
Description
Provides HBase Client
Multi Cluster Replication
-
Uses of ReplicationException in org.apache.hadoop.hbase.client
Methods in org.apache.hadoop.hbase.client that throw ReplicationExceptionModifier and TypeMethodDescriptiondefault voidAppend the replicable table column family config from the specified peer.default voidRemove some table-cfs from config of the specified peer. -
Uses of ReplicationException in org.apache.hadoop.hbase.client.replication
Methods in org.apache.hadoop.hbase.client.replication that throw ReplicationExceptionModifier and TypeMethodDescriptionvoidReplicationAdmin.addPeer(String id, ReplicationPeerConfig peerConfig) Deprecated.voidReplicationAdmin.addPeer(String id, ReplicationPeerConfig peerConfig, Map<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 ReplicationPeerConfigReplicationPeerConfigUtil.appendExcludeTableCFsToReplicationPeerConfig(Map<TableName, List<String>> excludeTableCfs, ReplicationPeerConfig peerConfig) voidReplicationAdmin.appendPeerTableCFs(String id, String tableCfs) Deprecated.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<TableName, ? extends Collection<String>> tableCfs) Deprecated.booleanReplicationAdmin.getPeerState(String id) Deprecated.static ReplicationPeerConfigReplicationPeerConfigUtil.removeExcludeTableCFsFromReplicationPeerConfig(Map<TableName, List<String>> excludeTableCfs, ReplicationPeerConfig peerConfig, String id) voidReplicationAdmin.removePeerTableCFs(String id, String tableCf) Deprecated.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<TableName, ? extends Collection<String>> tableCfs) Deprecated.static ReplicationPeerConfigReplicationPeerConfigUtil.removeTableCFsFromReplicationPeerConfig(Map<TableName, List<String>> tableCfs, ReplicationPeerConfig peerConfig, String id) -
Uses of ReplicationException in org.apache.hadoop.hbase.master
Methods in org.apache.hadoop.hbase.master that throw ReplicationExceptionModifier and TypeMethodDescriptionlongHMaster.addReplicationPeer(String peerId, ReplicationPeerConfig peerConfig, boolean enabled) longMasterServices.addReplicationPeer(String peerId, 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 peerprivate voidHMaster.finishActiveMasterInitialization()Finish initialization of HMaster after becoming the primary master.HMaster.getReplicationPeerConfig(String peerId) MasterServices.getReplicationPeerConfig(String peerId) Returns the configured ReplicationPeerConfig for the specified peerprivate voidHMaster.initializeZKBasedSystemTrackers()Initialize all ZK based system trackers.HMaster.listReplicationPeers(String regex) 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, ReplicationPeerConfig peerConfig) longMasterServices.updateReplicationPeerConfig(String peerId, ReplicationPeerConfig peerConfig) Update the peerConfig for the specified peer -
Uses of ReplicationException in org.apache.hadoop.hbase.master.replication
Methods in org.apache.hadoop.hbase.master.replication that throw ReplicationExceptionModifier and TypeMethodDescriptionvoidReplicationPeerManager.addPeer(String peerId, ReplicationPeerConfig peerConfig, boolean enabled) private voidUpdatePeerConfigProcedure.addToList(List<String> encodedRegionNames, String encodedRegionName, ReplicationQueueStorage queueStorage) private voidModifyPeerProcedure.addToMap(Map<String, Long> lastSeqIds, String encodedRegionName, long barrier, ReplicationQueueStorage queueStorage) private voidReplicationPeerManager.checkQueuesDeleted(String peerId) static ReplicationPeerManagerReplicationPeerManager.create(org.apache.hadoop.fs.FileSystem fs, ZKWatcher zk, org.apache.hadoop.conf.Configuration conf, String clusterId) voidReplicationPeerManager.disablePeer(String peerId) protected voidModifyPeerProcedure.enablePeer(MasterProcedureEnv env) voidReplicationPeerManager.enablePeer(String peerId) booleanReplicationPeerManager.getPeerState(String peerId) protected voidAddPeerProcedure.postPeerModification(MasterProcedureEnv env) protected abstract voidModifyPeerProcedure.postPeerModification(MasterProcedureEnv env) Called before we finish the procedure.protected voidRemovePeerProcedure.postPeerModification(MasterProcedureEnv env) protected voidUpdatePeerConfigProcedure.postPeerModification(MasterProcedureEnv env) (package private) voidReplicationPeerManager.preAddPeer(String peerId, ReplicationPeerConfig peerConfig) protected voidAddPeerProcedure.prePeerModification(MasterProcedureEnv env) protected abstract voidModifyPeerProcedure.prePeerModification(MasterProcedureEnv env) Called before we start the actual processing.(package private) voidReplicationPeerManager.removeAllLastPushedSeqIds(String peerId) (package private) voidReplicationPeerManager.removeAllQueuesAndHFileRefs(String peerId) voidReplicationPeerManager.removePeer(String peerId) protected final voidModifyPeerProcedure.setLastPushedSequenceId(MasterProcedureEnv env, ReplicationPeerConfig peerConfig) protected final voidModifyPeerProcedure.setLastPushedSequenceIdForTable(MasterProcedureEnv env, TableName tableName, Map<String, Long> lastSeqIds) private voidReplicationPeerManager.setPeerState(String peerId, boolean enabled) protected voidAddPeerProcedure.updateLastPushedSequenceIdForSerialPeer(MasterProcedureEnv env) protected voidModifyPeerProcedure.updateLastPushedSequenceIdForSerialPeer(MasterProcedureEnv env) protected voidUpdatePeerConfigProcedure.updateLastPushedSequenceIdForSerialPeer(MasterProcedureEnv env) voidReplicationPeerManager.updatePeerConfig(String peerId, ReplicationPeerConfig peerConfig) protected voidAddPeerProcedure.updatePeerStorage(MasterProcedureEnv env) protected voidDisablePeerProcedure.updatePeerStorage(MasterProcedureEnv env) protected voidEnablePeerProcedure.updatePeerStorage(MasterProcedureEnv env) protected abstract voidModifyPeerProcedure.updatePeerStorage(MasterProcedureEnv env) protected voidRemovePeerProcedure.updatePeerStorage(MasterProcedureEnv env) protected voidUpdatePeerConfigProcedure.updatePeerStorage(MasterProcedureEnv env) -
Uses of ReplicationException in org.apache.hadoop.hbase.replication
Methods in org.apache.hadoop.hbase.replication that throw ReplicationExceptionModifier and TypeMethodDescriptionvoidReplicationQueueStorage.addHFileRefs(String peerId, List<Pair<org.apache.hadoop.fs.Path, org.apache.hadoop.fs.Path>> pairs) Add new hfile references to the queue.voidZKReplicationQueueStorage.addHFileRefs(String peerId, List<Pair<org.apache.hadoop.fs.Path, org.apache.hadoop.fs.Path>> pairs) private voidZKReplicationQueueStorage.addLastSeqIdsToOps(String queueId, Map<String, Long> lastSeqIds, List<ZKUtil.ZKUtilOp> listOfOps) voidFSReplicationPeerStorage.addPeer(String peerId, ReplicationPeerConfig peerConfig, boolean enabled) booleanMethod called after a peer has been connected.voidReplicationPeerStorage.addPeer(String peerId, ReplicationPeerConfig peerConfig, boolean enabled) Add a replication peer.voidZKReplicationPeerStorage.addPeer(String peerId, ReplicationPeerConfig peerConfig, boolean enabled) voidReplicationQueueStorage.addPeerToHFileRefs(String peerId) Add a peer to hfile reference queue if peer does not exist.voidZKReplicationQueueStorage.addPeerToHFileRefs(String peerId) voidReplicationQueueStorage.addWAL(ServerName serverName, String queueId, String fileName) Add a new WAL file to the given queue for a given regionserver.voidZKReplicationQueueStorage.addWAL(ServerName serverName, String queueId, String fileName) ReplicationQueueStorage.claimQueue(ServerName sourceServerName, String queueId, ServerName destServerName) Change ownership for the queue identified by queueId and belongs to a dead region server.ZKReplicationQueueStorage.claimQueue(ServerName sourceServerName, String queueId, ServerName destServerName) This implement must update the cversion of rootZKReplicationQueueStorage.queuesZNode.private ReplicationPeerImplReplicationPeers.createPeer(String peerId) Helper method to connect to a peerReplicationQueueStorage.getAllHFileRefs()Load all hfile references in all replication queues.ZKReplicationQueueStorage.getAllHFileRefs()ReplicationQueueStorage.getAllPeersFromHFileRefsQueue()Get list of all peers from hfile reference queue.ZKReplicationQueueStorage.getAllPeersFromHFileRefsQueue()ReplicationQueueStorage.getAllQueues(ServerName serverName) Get a list of all queues for the specified region server.ZKReplicationQueueStorage.getAllQueues(ServerName serverName) ReplicationQueueStorage.getAllWALs()Load all wals in all replication queues.ZKReplicationQueueStorage.getAllWALs()The optimistic lock of this implement is based on the cversion of rootZKReplicationQueueStorage.queuesZNode.protected intZKReplicationQueueStorage.getHFileRefsZNodeCversion()longReplicationQueueStorage.getLastSequenceId(String encodedRegionName, String peerId) Read the max sequence id of the specific region for a given peer.longZKReplicationQueueStorage.getLastSequenceId(String encodedRegionName, String peerId) ReplicationQueueStorage.getListOfReplicators()Get a list of all region servers that have outstanding replication queues.ZKReplicationQueueStorage.getListOfReplicators()static org.apache.hadoop.conf.ConfigurationReplicationUtils.getPeerClusterConfiguration(ReplicationPeerConfig peerConfig, org.apache.hadoop.conf.Configuration baseConf) FSReplicationPeerStorage.getPeerConfig(String peerId) ReplicationPeerStorage.getPeerConfig(String peerId) Get the peer config of a replication peer.ZKReplicationPeerStorage.getPeerConfig(String peerId) ReplicationQueueStorage.getReplicableHFiles(String peerId) Get a list of all hfile references in the given peer.ZKReplicationQueueStorage.getReplicableHFiles(String peerId) longReplicationQueueStorage.getWALPosition(ServerName serverName, String queueId, String fileName) Get the current position for a specific WAL in a given queue for a given regionserver.longZKReplicationQueueStorage.getWALPosition(ServerName serverName, String queueId, String fileName) ReplicationQueueStorage.getWALsInQueue(ServerName serverName, String queueId) Get a list of all WALs in the given queue on the given region server.ZKReplicationQueueStorage.getWALsInQueue(ServerName serverName, String queueId) 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()private voidCopyReplicationPeers.migrate(ReplicationPeerStorage src, ReplicationPeerStorage dst) ReplicationPeers.refreshPeerConfig(String peerId) ReplicationPeers.refreshPeerState(String peerId) static voidReplicationUtils.removeAllQueues(ReplicationQueueStorage queueStorage, String peerId) voidReplicationQueueStorage.removeHFileRefs(String peerId, List<String> files) Remove hfile references from the queue.voidZKReplicationQueueStorage.removeHFileRefs(String peerId, List<String> files) voidReplicationQueueStorage.removeLastSequenceIds(String peerId) Remove all the max sequence id record for the given peer.voidReplicationQueueStorage.removeLastSequenceIds(String peerId, List<String> encodedRegionNames) Remove the max sequence id record for the given peer and regions.voidZKReplicationQueueStorage.removeLastSequenceIds(String peerId) voidZKReplicationQueueStorage.removeLastSequenceIds(String peerId, List<String> encodedRegionNames) 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.voidZKReplicationQueueStorage.removePeerFromHFileRefs(String peerId) voidReplicationQueueStorage.removeQueue(ServerName serverName, String queueId) Remove a replication queue for a given regionserver.voidZKReplicationQueueStorage.removeQueue(ServerName serverName, String queueId) voidReplicationQueueStorage.removeReplicatorIfQueueIsEmpty(ServerName serverName) Remove the record of region server if the queue is empty.voidZKReplicationQueueStorage.removeReplicatorIfQueueIsEmpty(ServerName serverName) voidReplicationQueueStorage.removeWAL(ServerName serverName, String queueId, String fileName) Remove an WAL file from the given queue for a given regionserver.voidZKReplicationQueueStorage.removeWAL(ServerName serverName, String queueId, String fileName) voidReplicationQueueStorage.setLastSequenceIds(String peerId, Map<String, Long> lastSeqIds) Set the max sequence id of a bunch of regions for a given peer.voidZKReplicationQueueStorage.setLastSequenceIds(String peerId, Map<String, Long> lastSeqIds) 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(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.voidZKReplicationQueueStorage.setWALPosition(ServerName serverName, String queueId, String fileName, long position, Map<String, Long> lastSeqIds) voidFSReplicationPeerStorage.updatePeerConfig(String peerId, ReplicationPeerConfig peerConfig) voidReplicationPeerStorage.updatePeerConfig(String peerId, ReplicationPeerConfig peerConfig) Update the config a replication peer.voidZKReplicationPeerStorage.updatePeerConfig(String peerId, ReplicationPeerConfig peerConfig) -
Uses of ReplicationException in org.apache.hadoop.hbase.replication.master
Methods in org.apache.hadoop.hbase.replication.master that throw ReplicationExceptionModifier and TypeMethodDescriptionvoidReplicationPeerConfigUpgrader.copyTableCFs()booleanReplicationPeerConfigUpgrader.copyTableCFs(String peerId) -
Uses of ReplicationException in org.apache.hadoop.hbase.replication.regionserver
Methods in org.apache.hadoop.hbase.replication.regionserver that throw ReplicationExceptionModifier and TypeMethodDescriptionvoidNoopReplicationQueueStorage.addHFileRefs(String peerId, List<Pair<org.apache.hadoop.fs.Path, org.apache.hadoop.fs.Path>> pairs) voidReplicationSource.addHFileRefs(TableName tableName, byte[] family, List<Pair<org.apache.hadoop.fs.Path, org.apache.hadoop.fs.Path>> pairs) voidReplicationSourceInterface.addHFileRefs(TableName tableName, byte[] family, List<Pair<org.apache.hadoop.fs.Path, org.apache.hadoop.fs.Path>> pairs) Add hfile names to the queue to be replicated.voidvoidNoopReplicationQueueStorage.addPeerToHFileRefs(String peerId) voidNoopReplicationQueueStorage.addWAL(ServerName serverName, String queueId, String fileName) NoopReplicationQueueStorage.claimQueue(ServerName sourceServerName, String queueId, ServerName destServerName) voidPeerProcedureHandler.claimReplicationQueue(ServerName crashedServer, String queue) voidPeerProcedureHandlerImpl.claimReplicationQueue(ServerName crashedServer, String queue) private voidReplicationSyncUp.claimReplicationQueues(ZKWatcher zkw, ReplicationSourceManager mgr) voidPeerProcedureHandler.disablePeer(String peerId) voidPeerProcedureHandlerImpl.disablePeer(String peerId) voidPeerProcedureHandler.enablePeer(String peerId) voidPeerProcedureHandlerImpl.enablePeer(String peerId) voidReplicationSourceManager.ReplicationQueueOperation.exec()NoopReplicationQueueStorage.getAllHFileRefs()NoopReplicationQueueStorage.getAllPeersFromHFileRefsQueue()NoopReplicationQueueStorage.getAllQueues(ServerName serverName) NoopReplicationQueueStorage.getAllWALs()longNoopReplicationQueueStorage.getLastSequenceId(String encodedRegionName, String peerId) NoopReplicationQueueStorage.getListOfReplicators()NoopReplicationQueueStorage.getReplicableHFiles(String peerId) longNoopReplicationQueueStorage.getWALPosition(ServerName serverName, String queueId, String fileName) NoopReplicationQueueStorage.getWALsInQueue(ServerName serverName, String queueId) private voidPeerProcedureHandlerImpl.refreshPeerState(String peerId) voidNoopReplicationQueueStorage.removeHFileRefs(String peerId, List<String> files) voidNoopReplicationQueueStorage.removeLastSequenceIds(String peerId) voidNoopReplicationQueueStorage.removeLastSequenceIds(String peerId, List<String> encodedRegionNames) voidPeerProcedureHandler.removePeer(String peerId) voidNoopReplicationQueueStorage.removePeerFromHFileRefs(String peerId) voidNoopReplicationQueueStorage.removeQueue(ServerName serverName, String queueId) voidNoopReplicationQueueStorage.removeReplicatorIfQueueIsEmpty(ServerName serverName) voidNoopReplicationQueueStorage.removeWAL(ServerName serverName, String queueId, String fileName) voidNoopReplicationQueueStorage.setLastSequenceIds(String peerId, Map<String, Long> lastSeqIds) voidNoopReplicationQueueStorage.setWALPosition(ServerName serverName, String queueId, String fileName, long position, Map<String, Long> lastSeqIds) voidPeerProcedureHandler.updatePeerConfig(String peerId) voidPeerProcedureHandlerImpl.updatePeerConfig(String peerId) -
Uses of ReplicationException in org.apache.hadoop.hbase.util
Methods in org.apache.hadoop.hbase.util that throw ReplicationExceptionModifier and TypeMethodDescriptionprivate voidHBaseFsck.checkAndFixReplication()Deprecated.HBaseFsck.exec(ExecutorService exec, String[] args) Deprecated.intHBaseFsck.onlineHbck()Deprecated.Contacts the master and prints out cluster-wide informationstatic voidServerRegionReplicaUtil.setupRegionReplicaReplication(MasterServices services) Create replication peer for replicating user-space Region Read Replicas. -
Uses of ReplicationException in org.apache.hadoop.hbase.util.hbck
Methods in org.apache.hadoop.hbase.util.hbck that throw ReplicationExceptionModifier and TypeMethodDescriptionvoidReplicationChecker.checkUnDeletedQueues()voidReplicationChecker.fixUnDeletedQueues()ReplicationChecker.getUndeletedHFileRefsPeers()private Map<ServerName,List<String>> ReplicationChecker.getUnDeletedQueues()
Admin.addReplicationPeer(String, ReplicationPeerConfig)instead