| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.client.replication | |
| org.apache.hadoop.hbase.replication | Multi Cluster Replication | 
| org.apache.hadoop.hbase.replication.regionserver | |
| org.apache.hadoop.hbase.security.visibility | 
| Modifier and Type | Method and Description | 
|---|---|
| ReplicationPeerConfig | ReplicationAdmin. getPeerConfig(String id) | 
| Modifier and Type | Method and Description | 
|---|---|
| Map<String,ReplicationPeerConfig> | ReplicationAdmin. listPeerConfigs() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ReplicationAdmin. addPeer(String id,
       ReplicationPeerConfig peerConfig)Add a new remote slave cluster for replication. | 
| void | ReplicationAdmin. addPeer(String id,
       ReplicationPeerConfig peerConfig,
       Map<TableName,? extends Collection<String>> tableCfs)Add a new remote slave cluster for replication. | 
| void | ReplicationAdmin. updatePeerConfig(String id,
                ReplicationPeerConfig peerConfig) | 
| Modifier and Type | Method and Description | 
|---|---|
| ReplicationPeerConfig | ReplicationEndpoint.Context. getPeerConfig() | 
| ReplicationPeerConfig | ReplicationPeerZKImpl. getPeerConfig()Get the peer config object | 
| ReplicationPeerConfig | ReplicationPeer. getPeerConfig()Get the peer config object | 
| ReplicationPeerConfig | ReplicationPeersZKImpl. getReplicationPeerConfig(String peerId)Returns a ReplicationPeerConfig from the znode or null for the given peerId. | 
| ReplicationPeerConfig | ReplicationPeers. getReplicationPeerConfig(String peerId)Returns the configured ReplicationPeerConfig for this peerId | 
| static ReplicationPeerConfig | ReplicationSerDeHelper. parsePeerFrom(byte[] bytes) | 
| ReplicationPeerConfig | ReplicationPeerConfig. setBandwidth(long bandwidth) | 
| ReplicationPeerConfig | ReplicationPeerConfig. setClusterKey(String clusterKey)Set the clusterKey which is the concatenation of the slave cluster's:
          hbase.zookeeper.quorum:hbase.zookeeper.property.clientPort:zookeeper.znode.parent | 
| ReplicationPeerConfig | ReplicationPeerConfig. setReplicationEndpointImpl(String replicationEndpointImpl)Sets the ReplicationEndpoint plugin class for this peer. | 
| Modifier and Type | Method and Description | 
|---|---|
| Map<String,ReplicationPeerConfig> | ReplicationPeersZKImpl. getAllPeerConfigs() | 
| Map<String,ReplicationPeerConfig> | ReplicationPeers. getAllPeerConfigs()List the cluster replication configs of all remote slave clusters (whether they are
 enabled/disabled or connected/disconnected). | 
| Pair<ReplicationPeerConfig,org.apache.hadoop.conf.Configuration> | ReplicationPeersZKImpl. getPeerConf(String peerId) | 
| Pair<ReplicationPeerConfig,org.apache.hadoop.conf.Configuration> | ReplicationPeers. getPeerConf(String peerId)Returns the configuration needed to talk to the remote slave cluster. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ReplicationPeersZKImpl. addPeer(String id,
       ReplicationPeerConfig peerConfig) | 
| void | ReplicationPeers. addPeer(String peerId,
       ReplicationPeerConfig peerConfig)Add a new remote slave cluster for replication. | 
| void | BaseReplicationEndpoint. peerConfigUpdated(ReplicationPeerConfig rpc) | 
| void | ReplicationPeerConfigListener. peerConfigUpdated(ReplicationPeerConfig rpc)Callback method for when users update the ReplicationPeerConfig for this peer | 
| static byte[] | ReplicationSerDeHelper. toByteArray(ReplicationPeerConfig peerConfig) | 
| void | ReplicationPeersZKImpl. updatePeerConfig(String id,
                ReplicationPeerConfig newConfig) | 
| void | ReplicationPeers. updatePeerConfig(String id,
                ReplicationPeerConfig peerConfig)Updates replication peer configuration and/or peer data | 
| Constructor and Description | 
|---|
| ReplicationPeerZKImpl(ZooKeeperWatcher zkWatcher,
                     org.apache.hadoop.conf.Configuration conf,
                     String id,
                     ReplicationPeerConfig peerConfig,
                     Abortable abortable)Constructor that takes all the objects required to communicate with the specified peer, except
 for the region server addresses. | 
| Modifier and Type | Method and Description | 
|---|---|
| protected ReplicationSourceInterface | ReplicationSourceManager. getReplicationSource(org.apache.hadoop.conf.Configuration conf,
                    org.apache.hadoop.fs.FileSystem fs,
                    ReplicationSourceManager manager,
                    ReplicationQueues replicationQueues,
                    ReplicationPeers replicationPeers,
                    Server server,
                    String peerId,
                    UUID clusterId,
                    ReplicationPeerConfig peerConfig,
                    ReplicationPeer replicationPeer)Factory method to create a replication source | 
| Modifier and Type | Method and Description | 
|---|---|
| String | DumpReplicationQueues. dumpPeersState(ReplicationAdmin replicationAdmin,
              Map<String,ReplicationPeerConfig> peerConfigs) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | VisibilityReplicationEndpoint. peerConfigUpdated(ReplicationPeerConfig rpc) | 
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.