Package | Description |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.client.replication | |
org.apache.hadoop.hbase.replication |
Modifier and Type | Method and Description |
---|---|
void |
HBaseAdmin.appendReplicationPeerTableCFs(String id,
Map<TableName,? extends Collection<String>> tableCfs) |
default void |
Admin.appendReplicationPeerTableCFs(String id,
Map<TableName,? extends Collection<String>> tableCfs)
Append the replicable table-cf config of the specified peer
|
void |
HBaseAdmin.removeReplicationPeerTableCFs(String id,
Map<TableName,? extends Collection<String>> tableCfs) |
default void |
Admin.removeReplicationPeerTableCFs(String id,
Map<TableName,? extends Collection<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. |
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.
|
void |
ReplicationAdmin.peerAdded(String id)
Deprecated.
|
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 void |
ReplicationSerDeHelper.removeTableCFsFromReplicationPeerConfig(Map<TableName,? extends Collection<String>> tableCfs,
ReplicationPeerConfig peerConfig,
String id) |
Modifier and Type | Method and Description |
---|---|
void |
TableBasedReplicationQueuesImpl.addHFileRefs(String peerId,
List<Pair<org.apache.hadoop.fs.Path,org.apache.hadoop.fs.Path>> pairs) |
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 |
TableBasedReplicationQueuesImpl.addLog(String queueId,
String filename) |
void |
ReplicationQueuesZKImpl.addLog(String queueId,
String filename) |
void |
ReplicationQueues.addLog(String queueId,
String filename)
Add a new WAL file to the given queue.
|
void |
TableBasedReplicationQueuesImpl.addPeerToHFileRefs(String peerId) |
void |
ReplicationQueuesZKImpl.addPeerToHFileRefs(String peerId) |
void |
ReplicationQueues.addPeerToHFileRefs(String peerId)
Add a peer to hfile reference queue if peer does not exist.
|
boolean |
ReplicationPeersZKImpl.createAndAddPeer(String peerId)
Attempt to connect to a new remote slave cluster.
|
void |
ReplicationPeersZKImpl.disablePeer(String id) |
void |
ReplicationPeers.disablePeer(String peerId)
Stop the replication to the specified remote slave cluster.
|
void |
ReplicationPeersZKImpl.enablePeer(String id) |
void |
ReplicationPeers.enablePeer(String peerId)
Restart the replication to the specified remote slave cluster.
|
long |
TableBasedReplicationQueuesImpl.getLogPosition(String queueId,
String filename) |
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> |
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.
|
Map<TableName,List<String>> |
ReplicationPeersZKImpl.getPeerTableCFsConfig(String id) |
Map<TableName,List<String>> |
ReplicationPeers.getPeerTableCFsConfig(String peerId)
Get the table and column-family list string of the peer from the underlying storage.
|
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
|
boolean |
ReplicationPeersZKImpl.getStatusOfPeerFromBackingStore(String id) |
boolean |
ReplicationPeers.getStatusOfPeerFromBackingStore(String peerId)
Get the replication status for the specified remote slave cluster, which doesn't
have to be connected.
|
void |
TableBasedReplicationQueuesClientImpl.init() |
void |
ReplicationQueuesClientZKImpl.init() |
void |
ReplicationQueuesClient.init()
Initialize the replication queue client interface.
|
void |
ReplicationPeersZKImpl.init() |
void |
ReplicationPeers.init()
Initialize the ReplicationPeers interface.
|
void |
TableBasedReplicationQueuesImpl.init(String serverName) |
void |
ReplicationQueuesZKImpl.init(String serverName) |
void |
ReplicationQueues.init(String serverName)
Initialize the region server replication queue interface.
|
boolean |
ReplicationPeersZKImpl.peerConnected(String peerId) |
boolean |
ReplicationPeers.peerConnected(String peerId)
Method called after a peer has been connected.
|
void |
ReplicationPeersZKImpl.registerPeer(String id,
ReplicationPeerConfig peerConfig) |
void |
ReplicationPeers.registerPeer(String peerId,
ReplicationPeerConfig peerConfig)
Add a new remote slave cluster for replication.
|
void |
ReplicationPeersZKImpl.setPeerTableCFsConfig(String id,
Map<TableName,? extends Collection<String>> tableCFs) |
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.unregisterPeer(String id) |
void |
ReplicationPeers.unregisterPeer(String peerId)
Removes a remote slave cluster and stops the replication to it.
|
void |
ReplicationPeersZKImpl.updatePeerConfig(String id,
ReplicationPeerConfig newConfig) |
void |
ReplicationPeers.updatePeerConfig(String id,
ReplicationPeerConfig peerConfig)
Update the peerConfig for the a given peer cluster
|
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.
|
Copyright © 2007–2017 The Apache Software Foundation. All rights reserved.