Package | Description |
---|---|
org.apache.hadoop.hbase.client.replication | |
org.apache.hadoop.hbase.mapreduce.replication | |
org.apache.hadoop.hbase.replication |
Multi Cluster Replication
|
org.apache.hadoop.hbase.replication.regionserver |
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,
Map<TableName,? extends Collection<String>> tableCfs)
Add a new remote slave cluster for replication.
|
Modifier and Type | Method and Description |
---|---|
private static Pair<ReplicationPeerConfig,org.apache.hadoop.conf.Configuration> |
VerifyReplication.getPeerQuorumConfig(org.apache.hadoop.conf.Configuration conf) |
Modifier and Type | Field and Description |
---|---|
private ReplicationPeerConfig |
ReplicationPeerZKImpl.peerConfig |
private ReplicationPeerConfig |
ReplicationEndpoint.Context.peerConfig |
Modifier and Type | Method and Description |
---|---|
private static ReplicationPeerConfig |
ReplicationPeersZKImpl.convert(org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer peer) |
ReplicationPeerConfig |
ReplicationPeerZKImpl.getPeerConfig()
Get the peer config object
|
ReplicationPeerConfig |
ReplicationPeer.getPeerConfig()
Get the peer config object
|
ReplicationPeerConfig |
ReplicationEndpoint.Context.getPeerConfig() |
ReplicationPeerConfig |
ReplicationPeers.getReplicationPeerConfig(String peerId)
Returns the configured ReplicationPeerConfig for this peerId
|
ReplicationPeerConfig |
ReplicationPeersZKImpl.getReplicationPeerConfig(String peerId)
Returns a ReplicationPeerConfig from the znode or null for the given peerId.
|
private static ReplicationPeerConfig |
ReplicationPeersZKImpl.parsePeerFrom(byte[] bytes) |
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> |
ReplicationPeers.getAllPeerConfigs()
List the cluster replication configs of all remote slave clusters (whether they are
enabled/disabled or connected/disconnected).
|
Map<String,ReplicationPeerConfig> |
ReplicationPeersZKImpl.getAllPeerConfigs() |
Pair<ReplicationPeerConfig,org.apache.hadoop.conf.Configuration> |
ReplicationPeers.getPeerConf(String peerId)
Returns the configuration needed to talk to the remote slave cluster.
|
Pair<ReplicationPeerConfig,org.apache.hadoop.conf.Configuration> |
ReplicationPeersZKImpl.getPeerConf(String peerId) |
Modifier and Type | Method and Description |
---|---|
void |
ReplicationPeers.addPeer(String peerId,
ReplicationPeerConfig peerConfig,
String tableCFs)
Add a new remote slave cluster for replication.
|
void |
ReplicationPeersZKImpl.addPeer(String id,
ReplicationPeerConfig peerConfig,
String tableCFs) |
private static org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer |
ReplicationPeersZKImpl.convert(ReplicationPeerConfig peerConfig) |
private static byte[] |
ReplicationPeersZKImpl.toByteArray(ReplicationPeerConfig peerConfig) |
Constructor and Description |
---|
ReplicationEndpoint.Context(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ReplicationPeerConfig peerConfig,
String peerId,
UUID clusterId,
ReplicationPeer replicationPeer,
MetricsSource metrics,
TableDescriptors tableDescriptors) |
ReplicationPeerZKImpl(org.apache.hadoop.conf.Configuration conf,
String id,
ReplicationPeerConfig peerConfig)
Constructor that takes all the objects required to communicate with the specified peer, except
for the region server addresses.
|
ReplicationPeerZKImpl(org.apache.hadoop.conf.Configuration conf,
String id,
ReplicationPeerConfig peerConfig,
Map<TableName,List<String>> tableCFs)
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
|
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.