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.regionserver |
Modifier and Type | Method and Description |
---|---|
void |
Admin.appendReplicationPeerTableCFs(String id,
Map<TableName,List<String>> tableCfs)
Append the replicable table column family config from the specified peer.
|
void |
HBaseAdmin.appendReplicationPeerTableCFs(String id,
Map<TableName,List<String>> tableCfs) |
void |
Admin.removeReplicationPeerTableCFs(String id,
Map<TableName,List<String>> tableCfs)
Remove some table-cfs from config of the specified peer.
|
void |
HBaseAdmin.removeReplicationPeerTableCFs(String id,
Map<TableName,List<String>> tableCfs) |
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 |
---|---|
void |
MasterServices.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled)
Add a new replication peer for replicating data to slave cluster
|
void |
HMaster.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled) |
void |
MasterServices.disableReplicationPeer(String peerId)
Stop the replication stream to the specified peer
|
void |
HMaster.disableReplicationPeer(String peerId) |
void |
MasterServices.enableReplicationPeer(String peerId)
Restart the replication stream to the specified peer
|
void |
HMaster.enableReplicationPeer(String peerId) |
ReplicationPeerConfig |
MasterServices.getReplicationPeerConfig(String peerId)
Returns the configured ReplicationPeerConfig for the specified peer
|
ReplicationPeerConfig |
HMaster.getReplicationPeerConfig(String peerId) |
List<ReplicationPeerDescription> |
MasterServices.listReplicationPeers(String regex)
Return a list of replication peers.
|
List<ReplicationPeerDescription> |
HMaster.listReplicationPeers(String regex) |
void |
MasterServices.removeReplicationPeer(String peerId)
Removes a peer and stops the replication
|
void |
HMaster.removeReplicationPeer(String peerId) |
void |
MasterServices.updateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig)
Update the peerConfig for the specified peer
|
void |
HMaster.updateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig) |
Modifier and Type | Method and Description |
---|---|
void |
ReplicationManager.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled) |
private void |
ReplicationManager.checkNamespacesAndTableCfsConfigConflict(Set<String> namespaces,
Map<TableName,? extends Collection<String>> tableCfs)
Set a namespace in the peer config means that all tables in this namespace will be replicated
to the peer cluster.
|
private void |
ReplicationManager.checkPeerConfig(ReplicationPeerConfig peerConfig)
If replicate_all flag is true, it means all user tables will be replicated to peer cluster.
|
void |
ReplicationManager.disableReplicationPeer(String peerId) |
void |
ReplicationManager.enableReplicationPeer(String peerId) |
ReplicationPeerConfig |
ReplicationManager.getPeerConfig(String peerId) |
List<ReplicationPeerDescription> |
ReplicationManager.listReplicationPeers(Pattern pattern) |
void |
ReplicationManager.removeReplicationPeer(String peerId) |
void |
ReplicationManager.updatePeerConfig(String peerId,
ReplicationPeerConfig peerConfig) |
Modifier and Type | Method and Description |
---|---|
private void |
ReplicationPeersZKImpl.addExistingPeers()
A private method used during initialization.
|
void |
ReplicationQueuesZKImpl.addHFileRefs(String peerId,
List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs) |
void |
ReplicationQueues.addHFileRefs(String peerId,
List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs)
Add new hfile references to the queue.
|
void |
ReplicationQueuesZKImpl.addLog(String queueId,
String filename) |
void |
ReplicationQueues.addLog(String queueId,
String filename)
Add a new WAL file to the given queue.
|
void |
ReplicationQueuesZKImpl.addPeerToHFileRefs(String peerId) |
void |
ReplicationQueues.addPeerToHFileRefs(String peerId)
Add a peer to hfile reference queue if peer does not exist.
|
private void |
ReplicationPeersZKImpl.changePeerState(String id,
org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.ReplicationState.State state)
Update the state znode of a peer cluster.
|
private void |
ReplicationPeersZKImpl.checkQueuesDeleted(String peerId) |
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) |
Map<TableName,List<String>> |
ReplicationPeers.getPeerTableCFsConfig(String peerId)
Get the table and column-family list string of the peer from the underlying storage.
|
Map<TableName,List<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.peerConnected(String peerId)
Method called after a peer has been connected.
|
boolean |
ReplicationPeersZKImpl.peerConnected(String peerId) |
default void |
ReplicationPeers.registerPeer(String peerId,
ReplicationPeerConfig peerConfig)
Add a new remote slave cluster for replication.
|
void |
ReplicationPeers.registerPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled)
Add a new remote slave cluster for replication.
|
void |
ReplicationPeersZKImpl.registerPeer(String id,
ReplicationPeerConfig peerConfig,
boolean enabled) |
void |
ReplicationPeers.setPeerTableCFsConfig(String peerId,
Map<TableName,? extends Collection<String>> tableCFs)
Set the table and column-family list string of the peer to the underlying storage.
|
void |
ReplicationPeersZKImpl.setPeerTableCFsConfig(String id,
Map<TableName,? extends Collection<String>> tableCFs) |
void |
ReplicationPeers.unregisterPeer(String peerId)
Removes a remote slave cluster and stops the replication to it.
|
void |
ReplicationPeersZKImpl.unregisterPeer(String id) |
void |
ReplicationPeers.updatePeerConfig(String id,
ReplicationPeerConfig peerConfig)
Update the peerConfig for the a given peer cluster
|
void |
ReplicationPeersZKImpl.updatePeerConfig(String id,
ReplicationPeerConfig newConfig) |
Constructor and Description |
---|
ReplicationPeerZKImpl(ZKWatcher 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 |
---|---|
void |
ReplicationSourceManager.addHFileRefs(TableName tableName,
byte[] family,
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) |
(package private) ReplicationSourceInterface |
ReplicationSourceManager.addSource(String id)
Add sources for the given peer cluster on this region server.
|
(package private) 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.