| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.client | Provides HBase Client | 
| org.apache.hadoop.hbase.client.replication | |
| org.apache.hadoop.hbase.master | |
| org.apache.hadoop.hbase.master.replication | |
| org.apache.hadoop.hbase.replication | Multi Cluster Replication | 
| org.apache.hadoop.hbase.replication.master | |
| org.apache.hadoop.hbase.replication.regionserver | |
| org.apache.hadoop.hbase.util | |
| org.apache.hadoop.hbase.util.hbck | 
| Modifier and Type | Method and Description | 
|---|---|
| default void | Admin. appendReplicationPeerTableCFs(String id,
                             Map<TableName,List<String>> tableCfs)Append the replicable table column family config from the specified peer. | 
| default void | Admin. removeReplicationPeerTableCFs(String id,
                             Map<TableName,List<String>> tableCfs)Remove some table-cfs from config of the specified peer. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ReplicationAdmin. addPeer(String id,
       ReplicationPeerConfig peerConfig)Deprecated. 
 | 
| void | ReplicationAdmin. 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,
 use  ReplicationAdmin.addPeer(String, ReplicationPeerConfig)instead. | 
| static ReplicationPeerConfig | ReplicationPeerConfigUtil. appendExcludeTableCFsToReplicationPeerConfig(Map<TableName,List<String>> excludeTableCfs,
                                            ReplicationPeerConfig peerConfig) | 
| void | ReplicationAdmin. appendPeerTableCFs(String id,
                  Map<TableName,? extends Collection<String>> tableCfs)Deprecated.  | 
| void | ReplicationAdmin. appendPeerTableCFs(String id,
                  String tableCfs)Deprecated. 
 as release of 2.0.0, and it will be removed in 3.0.0,
 use  ReplicationAdmin.appendPeerTableCFs(String, Map)instead. | 
| boolean | ReplicationAdmin. getPeerState(String id)Deprecated.  | 
| static ReplicationPeerConfig | ReplicationPeerConfigUtil. removeExcludeTableCFsFromReplicationPeerConfig(Map<TableName,List<String>> excludeTableCfs,
                                              ReplicationPeerConfig peerConfig,
                                              String id) | 
| void | ReplicationAdmin. removePeerTableCFs(String id,
                  Map<TableName,? extends Collection<String>> tableCfs)Deprecated.  | 
| void | ReplicationAdmin. removePeerTableCFs(String id,
                  String tableCf)Deprecated. 
 as release of 2.0.0, and it will be removed in 3.0.0,
 use  ReplicationAdmin.removePeerTableCFs(String, Map)instead. | 
| static ReplicationPeerConfig | ReplicationPeerConfigUtil. removeTableCFsFromReplicationPeerConfig(Map<TableName,List<String>> tableCfs,
                                       ReplicationPeerConfig peerConfig,
                                       String id) | 
| Modifier and Type | Method and Description | 
|---|---|
| long | MasterServices. addReplicationPeer(String peerId,
                  ReplicationPeerConfig peerConfig,
                  boolean enabled)Add a new replication peer for replicating data to slave cluster | 
| long | HMaster. addReplicationPeer(String peerId,
                  ReplicationPeerConfig peerConfig,
                  boolean enabled) | 
| long | MasterServices. disableReplicationPeer(String peerId)Stop the replication stream to the specified peer | 
| long | HMaster. disableReplicationPeer(String peerId) | 
| long | MasterServices. enableReplicationPeer(String peerId)Restart the replication stream to the specified peer | 
| long | HMaster. enableReplicationPeer(String peerId) | 
| private void | HMaster. finishActiveMasterInitialization(MonitoredTask status)Finish initialization of HMaster after becoming the primary master. | 
| ReplicationPeerConfig | MasterServices. getReplicationPeerConfig(String peerId)Returns the configured ReplicationPeerConfig for the specified peer | 
| ReplicationPeerConfig | HMaster. getReplicationPeerConfig(String peerId) | 
| protected void | HMaster. initializeZKBasedSystemTrackers()Initialize all ZK based system trackers. | 
| List<ReplicationPeerDescription> | MasterServices. listReplicationPeers(String regex)Return a list of replication peers. | 
| List<ReplicationPeerDescription> | HMaster. listReplicationPeers(String regex) | 
| long | MasterServices. removeReplicationPeer(String peerId)Removes a peer and stops the replication | 
| long | HMaster. removeReplicationPeer(String peerId) | 
| long | MasterServices. updateReplicationPeerConfig(String peerId,
                           ReplicationPeerConfig peerConfig)Update the peerConfig for the specified peer | 
| long | HMaster. updateReplicationPeerConfig(String peerId,
                           ReplicationPeerConfig peerConfig) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ReplicationPeerManager. addPeer(String peerId,
       ReplicationPeerConfig peerConfig,
       boolean enabled) | 
| private void | UpdatePeerConfigProcedure. addToList(List<String> encodedRegionNames,
         String encodedRegionName,
         ReplicationQueueStorage queueStorage) | 
| private void | ModifyPeerProcedure. addToMap(Map<String,Long> lastSeqIds,
        String encodedRegionName,
        long barrier,
        ReplicationQueueStorage queueStorage) | 
| private void | ReplicationPeerManager. checkQueuesDeleted(String peerId) | 
| static ReplicationPeerManager | ReplicationPeerManager. create(ZKWatcher zk,
      org.apache.hadoop.conf.Configuration conf,
      String clusterId) | 
| void | ReplicationPeerManager. disablePeer(String peerId) | 
| protected void | ModifyPeerProcedure. enablePeer(MasterProcedureEnv env) | 
| void | ReplicationPeerManager. enablePeer(String peerId) | 
| protected abstract void | ModifyPeerProcedure. postPeerModification(MasterProcedureEnv env)Called before we finish the procedure. | 
| protected void | UpdatePeerConfigProcedure. postPeerModification(MasterProcedureEnv env) | 
| protected void | RemovePeerProcedure. postPeerModification(MasterProcedureEnv env) | 
| protected void | AddPeerProcedure. postPeerModification(MasterProcedureEnv env) | 
| (package private) void | ReplicationPeerManager. preAddPeer(String peerId,
          ReplicationPeerConfig peerConfig) | 
| protected abstract void | ModifyPeerProcedure. prePeerModification(MasterProcedureEnv env)Called before we start the actual processing. | 
| protected void | AddPeerProcedure. prePeerModification(MasterProcedureEnv env) | 
| (package private) void | ReplicationPeerManager. removeAllLastPushedSeqIds(String peerId) | 
| (package private) void | ReplicationPeerManager. removeAllQueuesAndHFileRefs(String peerId) | 
| void | ReplicationPeerManager. removePeer(String peerId) | 
| protected void | ModifyPeerProcedure. setLastPushedSequenceId(MasterProcedureEnv env,
                       ReplicationPeerConfig peerConfig) | 
| protected void | ModifyPeerProcedure. setLastPushedSequenceIdForTable(MasterProcedureEnv env,
                               TableName tableName,
                               Map<String,Long> lastSeqIds) | 
| private void | ReplicationPeerManager. setPeerState(String peerId,
            boolean enabled) | 
| protected void | ModifyPeerProcedure. updateLastPushedSequenceIdForSerialPeer(MasterProcedureEnv env) | 
| protected void | UpdatePeerConfigProcedure. updateLastPushedSequenceIdForSerialPeer(MasterProcedureEnv env) | 
| protected void | AddPeerProcedure. updateLastPushedSequenceIdForSerialPeer(MasterProcedureEnv env) | 
| void | ReplicationPeerManager. updatePeerConfig(String peerId,
                ReplicationPeerConfig peerConfig) | 
| protected void | EnablePeerProcedure. updatePeerStorage(MasterProcedureEnv env) | 
| protected abstract void | ModifyPeerProcedure. updatePeerStorage(MasterProcedureEnv env) | 
| protected void | UpdatePeerConfigProcedure. updatePeerStorage(MasterProcedureEnv env) | 
| protected void | RemovePeerProcedure. updatePeerStorage(MasterProcedureEnv env) | 
| protected void | AddPeerProcedure. updatePeerStorage(MasterProcedureEnv env) | 
| protected void | DisablePeerProcedure. updatePeerStorage(MasterProcedureEnv env) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ZKReplicationQueueStorage. addHFileRefs(String peerId,
            List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs) | 
| void | ReplicationQueueStorage. addHFileRefs(String peerId,
            List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs)Add new hfile references to the queue. | 
| private void | ZKReplicationQueueStorage. addLastSeqIdsToOps(String queueId,
                  Map<String,Long> lastSeqIds,
                  List<ZKUtil.ZKUtilOp> listOfOps) | 
| boolean | ReplicationPeers. addPeer(String peerId)Method called after a peer has been connected. | 
| void | ReplicationPeerStorage. addPeer(String peerId,
       ReplicationPeerConfig peerConfig,
       boolean enabled)Add a replication peer. | 
| void | ZKReplicationPeerStorage. addPeer(String peerId,
       ReplicationPeerConfig peerConfig,
       boolean enabled) | 
| void | ZKReplicationQueueStorage. addPeerToHFileRefs(String peerId) | 
| void | ReplicationQueueStorage. addPeerToHFileRefs(String peerId)Add a peer to hfile reference queue if peer does not exist. | 
| void | ZKReplicationQueueStorage. addWAL(ServerName serverName,
      String queueId,
      String fileName) | 
| void | ReplicationQueueStorage. addWAL(ServerName serverName,
      String queueId,
      String fileName)Add a new WAL file to the given queue for a given regionserver. | 
| Pair<String,SortedSet<String>> | ZKReplicationQueueStorage. claimQueue(ServerName sourceServerName,
          String queueId,
          ServerName destServerName) | 
| Pair<String,SortedSet<String>> | ReplicationQueueStorage. claimQueue(ServerName sourceServerName,
          String queueId,
          ServerName destServerName)Change ownership for the queue identified by queueId and belongs to a dead region server. | 
| private ReplicationPeerImpl | ReplicationPeers. createPeer(String peerId)Helper method to connect to a peer | 
| Set<String> | ZKReplicationQueueStorage. getAllHFileRefs() | 
| Set<String> | ReplicationQueueStorage. getAllHFileRefs()Load all hfile references in all replication queues. | 
| List<String> | ZKReplicationQueueStorage. getAllPeersFromHFileRefsQueue() | 
| List<String> | ReplicationQueueStorage. getAllPeersFromHFileRefsQueue()Get list of all peers from hfile reference queue. | 
| List<String> | ZKReplicationQueueStorage. getAllQueues(ServerName serverName) | 
| List<String> | ReplicationQueueStorage. getAllQueues(ServerName serverName)Get a list of all queues for the specified region server. | 
| Set<String> | ZKReplicationQueueStorage. getAllWALs() | 
| Set<String> | ReplicationQueueStorage. getAllWALs()Load all wals in all replication queues. | 
| protected int | ZKReplicationQueueStorage. getHFileRefsZNodeCversion() | 
| long | ZKReplicationQueueStorage. getLastSequenceId(String encodedRegionName,
                 String peerId) | 
| long | ReplicationQueueStorage. getLastSequenceId(String encodedRegionName,
                 String peerId)Read the max sequence id of the specific region for a given peer. | 
| List<ServerName> | ZKReplicationQueueStorage. getListOfReplicators() | 
| List<ServerName> | ReplicationQueueStorage. getListOfReplicators()Get a list of all region servers that have outstanding replication queues. | 
| static org.apache.hadoop.conf.Configuration | ReplicationUtils. getPeerClusterConfiguration(ReplicationPeerConfig peerConfig,
                           org.apache.hadoop.conf.Configuration baseConf) | 
| ReplicationPeerConfig | ReplicationPeerStorage. getPeerConfig(String peerId)Get the peer config of a replication peer. | 
| ReplicationPeerConfig | ZKReplicationPeerStorage. getPeerConfig(String peerId) | 
| List<String> | ZKReplicationQueueStorage. getReplicableHFiles(String peerId) | 
| List<String> | ReplicationQueueStorage. getReplicableHFiles(String peerId)Get a list of all hfile references in the given peer. | 
| long | ZKReplicationQueueStorage. getWALPosition(ServerName serverName,
              String queueId,
              String fileName) | 
| long | ReplicationQueueStorage. getWALPosition(ServerName serverName,
              String queueId,
              String fileName)Get the current position for a specific WAL in a given queue for a given regionserver. | 
| List<String> | ZKReplicationQueueStorage. getWALsInQueue(ServerName serverName,
              String queueId) | 
| List<String> | ReplicationQueueStorage. getWALsInQueue(ServerName serverName,
              String queueId)Get a list of all WALs in the given queue on the given region server. | 
| void | ReplicationPeers. init() | 
| boolean | ReplicationPeerStorage. isPeerEnabled(String peerId)Test whether a replication peer is enabled. | 
| boolean | ZKReplicationPeerStorage. isPeerEnabled(String peerId) | 
| List<String> | ReplicationPeerStorage. listPeerIds()Return the peer ids of all replication peers. | 
| List<String> | ZKReplicationPeerStorage. listPeerIds() | 
| ReplicationPeerConfig | ReplicationPeers. refreshPeerConfig(String peerId) | 
| ReplicationPeer.PeerState | ReplicationPeers. refreshPeerState(String peerId) | 
| static void | ReplicationUtils. removeAllQueues(ReplicationQueueStorage queueStorage,
               String peerId) | 
| void | ZKReplicationQueueStorage. removeHFileRefs(String peerId,
               List<String> files) | 
| void | ReplicationQueueStorage. removeHFileRefs(String peerId,
               List<String> files)Remove hfile references from the queue. | 
| void | ZKReplicationQueueStorage. removeLastSequenceIds(String peerId) | 
| void | ReplicationQueueStorage. removeLastSequenceIds(String peerId)Remove all the max sequence id record for the given peer. | 
| void | ZKReplicationQueueStorage. removeLastSequenceIds(String peerId,
                     List<String> encodedRegionNames) | 
| void | ReplicationQueueStorage. removeLastSequenceIds(String peerId,
                     List<String> encodedRegionNames)Remove the max sequence id record for the given peer and regions. | 
| void | ReplicationPeerStorage. removePeer(String peerId)Remove a replication peer. | 
| void | ZKReplicationPeerStorage. removePeer(String peerId) | 
| void | ZKReplicationQueueStorage. removePeerFromHFileRefs(String peerId) | 
| void | ReplicationQueueStorage. removePeerFromHFileRefs(String peerId)Remove a peer from hfile reference queue. | 
| void | ZKReplicationQueueStorage. removeQueue(ServerName serverName,
           String queueId) | 
| void | ReplicationQueueStorage. removeQueue(ServerName serverName,
           String queueId)Remove a replication queue for a given regionserver. | 
| void | ZKReplicationQueueStorage. removeReplicatorIfQueueIsEmpty(ServerName serverName) | 
| void | ReplicationQueueStorage. removeReplicatorIfQueueIsEmpty(ServerName serverName)Remove the record of region server if the queue is empty. | 
| void | ZKReplicationQueueStorage. removeWAL(ServerName serverName,
         String queueId,
         String fileName) | 
| void | ReplicationQueueStorage. removeWAL(ServerName serverName,
         String queueId,
         String fileName)Remove an WAL file from the given queue for a given regionserver. | 
| void | ZKReplicationQueueStorage. setLastSequenceIds(String peerId,
                  Map<String,Long> lastSeqIds) | 
| void | ReplicationQueueStorage. setLastSequenceIds(String peerId,
                  Map<String,Long> lastSeqIds)Set the max sequence id of a bunch of regions for a given peer. | 
| void | ReplicationPeerStorage. setPeerState(String peerId,
            boolean enabled)Set the state of peer,  truetoENABLED, otherwise toDISABLED. | 
| void | ZKReplicationPeerStorage. setPeerState(String peerId,
            boolean enabled) | 
| void | ZKReplicationQueueStorage. setWALPosition(ServerName serverName,
              String queueId,
              String fileName,
              long position,
              Map<String,Long> lastSeqIds) | 
| void | ReplicationQueueStorage. 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. | 
| void | ReplicationPeerStorage. updatePeerConfig(String peerId,
                ReplicationPeerConfig peerConfig)Update the config a replication peer. | 
| void | ZKReplicationPeerStorage. updatePeerConfig(String peerId,
                ReplicationPeerConfig peerConfig) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ReplicationPeerConfigUpgrader. copyTableCFs() | 
| boolean | ReplicationPeerConfigUpgrader. copyTableCFs(String peerId) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | NoopReplicationQueueStorage. addHFileRefs(String peerId,
            List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs) | 
| void | ReplicationSourceInterface. 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. | 
| void | ReplicationSource. addHFileRefs(TableName tableName,
            byte[] family,
            List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs) | 
| void | PeerProcedureHandler. addPeer(String peerId) | 
| void | NoopReplicationQueueStorage. addPeerToHFileRefs(String peerId) | 
| void | NoopReplicationQueueStorage. addWAL(ServerName serverName,
      String queueId,
      String fileName) | 
| Pair<String,SortedSet<String>> | NoopReplicationQueueStorage. claimQueue(ServerName sourceServerName,
          String queueId,
          ServerName destServerName) | 
| void | PeerProcedureHandler. disablePeer(String peerId) | 
| void | PeerProcedureHandlerImpl. disablePeer(String peerId) | 
| void | PeerProcedureHandler. enablePeer(String peerId) | 
| void | PeerProcedureHandlerImpl. enablePeer(String peerId) | 
| void | ReplicationSourceManager.ReplicationQueueOperation. exec() | 
| Set<String> | NoopReplicationQueueStorage. getAllHFileRefs() | 
| List<String> | NoopReplicationQueueStorage. getAllPeersFromHFileRefsQueue() | 
| List<String> | NoopReplicationQueueStorage. getAllQueues(ServerName serverName) | 
| Set<String> | NoopReplicationQueueStorage. getAllWALs() | 
| long | NoopReplicationQueueStorage. getLastSequenceId(String encodedRegionName,
                 String peerId) | 
| List<ServerName> | NoopReplicationQueueStorage. getListOfReplicators() | 
| List<String> | NoopReplicationQueueStorage. getReplicableHFiles(String peerId) | 
| long | NoopReplicationQueueStorage. getWALPosition(ServerName serverName,
              String queueId,
              String fileName) | 
| List<String> | NoopReplicationQueueStorage. getWALsInQueue(ServerName serverName,
              String queueId) | 
| private void | PeerProcedureHandlerImpl. refreshPeerState(String peerId) | 
| void | NoopReplicationQueueStorage. removeHFileRefs(String peerId,
               List<String> files) | 
| void | NoopReplicationQueueStorage. removeLastSequenceIds(String peerId) | 
| void | NoopReplicationQueueStorage. removeLastSequenceIds(String peerId,
                     List<String> encodedRegionNames) | 
| void | PeerProcedureHandler. removePeer(String peerId) | 
| void | NoopReplicationQueueStorage. removePeerFromHFileRefs(String peerId) | 
| void | NoopReplicationQueueStorage. removeQueue(ServerName serverName,
           String queueId) | 
| void | NoopReplicationQueueStorage. removeReplicatorIfQueueIsEmpty(ServerName serverName) | 
| void | NoopReplicationQueueStorage. removeWAL(ServerName serverName,
         String queueId,
         String fileName) | 
| void | NoopReplicationQueueStorage. setLastSequenceIds(String peerId,
                  Map<String,Long> lastSeqIds) | 
| void | NoopReplicationQueueStorage. setWALPosition(ServerName serverName,
              String queueId,
              String fileName,
              long position,
              Map<String,Long> lastSeqIds) | 
| void | PeerProcedureHandler. updatePeerConfig(String peerId) | 
| void | PeerProcedureHandlerImpl. updatePeerConfig(String peerId) | 
| Modifier and Type | Method and Description | 
|---|---|
| private void | HBaseFsck. checkAndFixReplication()Deprecated.  | 
| HBaseFsck | HBaseFsck. exec(ExecutorService exec,
    String[] args)Deprecated.  | 
| int | HBaseFsck. onlineHbck()Deprecated.  Contacts the master and prints out cluster-wide information | 
| static void | ServerRegionReplicaUtil. setupRegionReplicaReplication(MasterServices services)Create replication peer for replicating user-space Region Read Replicas. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ReplicationChecker. checkUnDeletedQueues() | 
| void | ReplicationChecker. fixUnDeletedQueues() | 
| private Set<String> | ReplicationChecker. getUndeletedHFileRefsPeers() | 
| private Map<ServerName,List<String>> | ReplicationChecker. getUnDeletedQueues() | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.