Package | Description |
---|---|
org.apache.hadoop.hbase.master.cleaner | |
org.apache.hadoop.hbase.master.replication | |
org.apache.hadoop.hbase.replication |
Multi Cluster Replication
|
org.apache.hadoop.hbase.replication.regionserver |
Modifier and Type | Field and Description |
---|---|
private ReplicationPeers |
ReplicationZKNodeCleaner.replicationPeers |
Modifier and Type | Field and Description |
---|---|
private ReplicationPeers |
ReplicationManager.replicationPeers |
Modifier and Type | Class and Description |
---|---|
class |
ReplicationPeersZKImpl
This class provides an implementation of the ReplicationPeers interface using ZooKeeper.
|
Modifier and Type | Field and Description |
---|---|
private ReplicationPeers |
ReplicationTrackerZKImpl.replicationPeers |
Modifier and Type | Method and Description |
---|---|
static ReplicationPeers |
ReplicationFactory.getReplicationPeers(ZKWatcher zk,
org.apache.hadoop.conf.Configuration conf,
Abortable abortable) |
static ReplicationPeers |
ReplicationFactory.getReplicationPeers(ZKWatcher zk,
org.apache.hadoop.conf.Configuration conf,
ReplicationQueuesClient queuesClient,
Abortable abortable) |
Modifier and Type | Method and Description |
---|---|
static ReplicationTracker |
ReplicationFactory.getReplicationTracker(ZKWatcher zookeeper,
ReplicationPeers replicationPeers,
org.apache.hadoop.conf.Configuration conf,
Abortable abortable,
Stoppable stopper) |
Constructor and Description |
---|
ReplicationTrackerZKImpl(ZKWatcher zookeeper,
ReplicationPeers replicationPeers,
org.apache.hadoop.conf.Configuration conf,
Abortable abortable,
Stoppable stopper) |
Modifier and Type | Field and Description |
---|---|
private ReplicationPeers |
ReplicationSourceManager.replicationPeers |
private ReplicationPeers |
Replication.replicationPeers |
private ReplicationPeers |
ReplicationSource.replicationPeers |
private ReplicationPeers |
ReplicationSourceManager.NodeFailoverWorker.rp |
Modifier and Type | Method and Description |
---|---|
ReplicationPeers |
ReplicationSourceManager.getReplicationPeers()
Get the ReplicationPeers used by this ReplicationSourceManager
|
Modifier and Type | Method and Description |
---|---|
private 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,
WALFileLengthProvider walFileLengthProvider)
Factory method to create a replication source
|
void |
RecoveredReplicationSource.init(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ReplicationSourceManager manager,
ReplicationQueues replicationQueues,
ReplicationPeers replicationPeers,
Server server,
String peerClusterZnode,
UUID clusterId,
ReplicationEndpoint replicationEndpoint,
WALFileLengthProvider walFileLengthProvider,
MetricsSource metrics) |
void |
ReplicationSourceInterface.init(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ReplicationSourceManager manager,
ReplicationQueues replicationQueues,
ReplicationPeers replicationPeers,
Server server,
String peerClusterZnode,
UUID clusterId,
ReplicationEndpoint replicationEndpoint,
WALFileLengthProvider walFileLengthProvider,
MetricsSource metrics)
Initializer for the source
|
void |
ReplicationSource.init(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ReplicationSourceManager manager,
ReplicationQueues replicationQueues,
ReplicationPeers replicationPeers,
Server server,
String peerClusterZnode,
UUID clusterId,
ReplicationEndpoint replicationEndpoint,
WALFileLengthProvider walFileLengthProvider,
MetricsSource metrics)
Instantiation method used by region servers
|
Constructor and Description |
---|
NodeFailoverWorker(String rsZnode,
ReplicationQueues replicationQueues,
ReplicationPeers replicationPeers,
UUID clusterId) |
ReplicationSourceManager(ReplicationQueues replicationQueues,
ReplicationPeers replicationPeers,
ReplicationTracker replicationTracker,
org.apache.hadoop.conf.Configuration conf,
Server server,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path logDir,
org.apache.hadoop.fs.Path oldLogDir,
UUID clusterId,
WALFileLengthProvider walFileLengthProvider)
Creates a replication manager and sets the watch on all the other registered region servers
|
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.