Package | Description |
---|---|
org.apache.hadoop.hbase.client.replication | |
org.apache.hadoop.hbase.replication |
Multi Cluster Replication
|
org.apache.hadoop.hbase.replication.regionserver |
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.
|
void |
ReplicationAdmin.addPeer(String id,
String clusterKey)
Deprecated.
Use addPeer(String, ReplicationPeerConfig, Map) instead.
|
void |
ReplicationAdmin.addPeer(String id,
String clusterKey,
String tableCFs)
Deprecated.
|
void |
ReplicationAdmin.appendPeerTableCFs(String id,
Map<TableName,? extends Collection<String>> tableCfs)
Append the replicable table-cf config of the specified peer
|
void |
ReplicationAdmin.appendPeerTableCFs(String id,
String tableCfs)
Append the replicable table-cf config of the specified peer
|
void |
ReplicationAdmin.disablePeer(String id)
Stop the replication stream to the specified peer.
|
void |
ReplicationAdmin.enablePeer(String id)
Restart the replication stream to the specified peer.
|
ReplicationPeerConfig |
ReplicationAdmin.getPeerConfig(String id) |
boolean |
ReplicationAdmin.getPeerState(String id)
Get the state of the specified peer cluster
|
String |
ReplicationAdmin.getPeerTableCFs(String id)
Get the replicable table-cf config of the specified peer.
|
void |
ReplicationAdmin.removePeer(String id)
Removes a peer cluster and stops the replication to it.
|
void |
ReplicationAdmin.removePeerTableCFs(String id,
Map<TableName,? extends Collection<String>> tableCfs)
Remove some table-cfs from config of the specified peer
|
void |
ReplicationAdmin.removePeerTableCFs(String id,
String tableCf)
Remove some table-cfs from table-cfs config of the specified peer
|
void |
ReplicationAdmin.setPeerTableCFs(String id,
Map<TableName,? extends Collection<String>> tableCfs)
Set the replicable table-cf config of the specified peer
|
void |
ReplicationAdmin.setPeerTableCFs(String id,
String tableCFs)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
private void |
ReplicationPeersZKImpl.addExistingPeers()
A private method used during initialization.
|
void |
ReplicationQueuesZKImpl.addLog(String queueId,
String filename) |
void |
ReplicationQueues.addLog(String queueId,
String filename)
Add a new WAL file to the given queue.
|
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 void |
ReplicationPeersZKImpl.changePeerState(String id,
org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.State state)
Update the state znode of a peer cluster.
|
boolean |
ReplicationPeersZKImpl.createAndAddPeer(String peerId)
Attempt to connect to a new remote slave cluster.
|
private ReplicationPeerZKImpl |
ReplicationPeersZKImpl.createPeer(String peerId)
Helper method to connect to a peer
|
void |
ReplicationPeers.disablePeer(String peerId)
Stop the replication to the specified remote slave cluster.
|
void |
ReplicationPeersZKImpl.disablePeer(String id) |
void |
ReplicationPeers.enablePeer(String peerId)
Restart the replication to the specified remote slave cluster.
|
void |
ReplicationPeersZKImpl.enablePeer(String id) |
List<String> |
ReplicationQueuesZKImpl.getListOfReplicators() |
List<String> |
ReplicationQueues.getListOfReplicators()
Get a list of all region servers that have outstanding replication queues.
|
long |
ReplicationQueuesZKImpl.getLogPosition(String queueId,
String filename) |
long |
ReplicationQueues.getLogPosition(String queueId,
String filename)
Get the current position for a specific WAL in a given queue.
|
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) |
String |
ReplicationPeers.getPeerTableCFsConfig(String peerId)
Get the table and column-family list string of the peer from ZK.
|
String |
ReplicationPeersZKImpl.getPeerTableCFsConfig(String id) |
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.
|
boolean |
ReplicationPeers.getStatusOfPeerFromBackingStore(String peerId)
Get the replication status for the specified remote slave cluster, which doesn't
have to be connected.
|
boolean |
ReplicationPeersZKImpl.getStatusOfPeerFromBackingStore(String id) |
void |
ReplicationQueuesClient.init()
Initialize the replication queue client interface.
|
void |
ReplicationPeers.init()
Initialize the ReplicationPeers interface.
|
void |
ReplicationPeersZKImpl.init() |
void |
ReplicationQueuesClientZKImpl.init() |
void |
ReplicationQueuesZKImpl.init(String serverName) |
void |
ReplicationQueues.init(String serverName)
Initialize the region server replication queue interface.
|
boolean |
ReplicationPeers.peerAdded(String peerId) |
boolean |
ReplicationPeersZKImpl.peerAdded(String peerId) |
void |
ReplicationPeers.removePeer(String peerId)
Removes a remote slave cluster and stops the replication to it.
|
void |
ReplicationPeersZKImpl.removePeer(String id) |
void |
ReplicationPeers.setPeerTableCFsConfig(String peerId,
String tableCFs)
Set the table and column-family list string of the peer to ZK.
|
void |
ReplicationPeersZKImpl.setPeerTableCFsConfig(String id,
String tableCFsStr) |
Constructor and Description |
---|
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.addSource(String id)
Add sources for the given peer cluster on this region server.
|
protected void |
ReplicationSourceManager.init()
Adds a normal source per registered peer cluster and tries to process all
old region server wal queues
|
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.