@InterfaceAudience.Private public class RegionReplicaReplicationEndpoint extends HBaseReplicationEndpoint
ReplicationEndpoint
endpoint which receives the WAL
edits from the WAL, and sends the edits to replicas of regions.Modifier and Type | Class and Description |
---|---|
(package private) static class |
RegionReplicaReplicationEndpoint.RegionReplicaOutputSink |
(package private) static class |
RegionReplicaReplicationEndpoint.RegionReplicaReplayCallable
Calls replay on the passed edits for the given set of entries belonging to the region.
|
(package private) static class |
RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter |
(package private) static class |
RegionReplicaReplicationEndpoint.RetryingRpcCallable<V> |
HBaseReplicationEndpoint.PeerRegionServerListener
ReplicationEndpoint.Context, ReplicationEndpoint.ReplicateContext
Modifier and Type | Field and Description |
---|---|
private static String |
CLIENT_RETRIES_NUMBER |
private org.apache.hadoop.conf.Configuration |
conf |
private ClusterConnection |
connection |
private WALSplitter.PipelineController |
controller |
private EntryBuffers |
entryBuffers |
private static org.slf4j.Logger |
LOG |
private int |
numWriterThreads |
private int |
operationTimeout |
private RegionReplicaReplicationEndpoint.RegionReplicaOutputSink |
outputSink |
private ExecutorService |
pool |
private TableDescriptors |
tableDescriptors |
ctx, REPLICATION_WALENTRYFILTER_CONFIG_KEY
Constructor and Description |
---|
RegionReplicaReplicationEndpoint() |
Modifier and Type | Method and Description |
---|---|
boolean |
canReplicateToSameCluster()
Whether or not, the replication endpoint can replicate to it's source cluster with the same
UUID
|
protected void |
doStart() |
protected void |
doStop() |
private ExecutorService |
getDefaultThreadPool(org.apache.hadoop.conf.Configuration conf)
Returns a Thread pool for the RPC's to region replicas.
|
protected WALEntryFilter |
getScopeWALEntryFilter()
Returns a WALEntryFilter for checking the scope.
|
void |
init(ReplicationEndpoint.Context context)
Initialize the replication endpoint with the given context.
|
boolean |
replicate(ReplicationEndpoint.ReplicateContext replicateContext)
Replicate the given set of entries (in the context) to the other cluster.
|
abort, disconnect, fetchSlavesAddresses, getLastRegionServerUpdate, getPeerUUID, getRegionServers, getZkw, isAborted, reconnect, setRegionServers, start, stop
getNamespaceTableCfWALEntryFilter, getWALEntryfilter, isStarting, peerConfigUpdated
addListener, awaitRunning, awaitRunning, awaitRunning, awaitTerminated, awaitTerminated, awaitTerminated, doCancelStart, failureCause, isRunning, notifyFailed, notifyStarted, notifyStopped, startAsync, state, stopAsync, toString
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
awaitRunning, awaitRunning, awaitTerminated, awaitTerminated, failureCause, isRunning
private static final org.slf4j.Logger LOG
private static String CLIENT_RETRIES_NUMBER
private org.apache.hadoop.conf.Configuration conf
private ClusterConnection connection
private TableDescriptors tableDescriptors
private WALSplitter.PipelineController controller
private RegionReplicaReplicationEndpoint.RegionReplicaOutputSink outputSink
private EntryBuffers entryBuffers
private int numWriterThreads
private int operationTimeout
private ExecutorService pool
public RegionReplicaReplicationEndpoint()
public void init(ReplicationEndpoint.Context context) throws IOException
ReplicationEndpoint
init
in interface ReplicationEndpoint
init
in class BaseReplicationEndpoint
context
- replication contextIOException
- error occur when initialize the endpoint.protected void doStart()
doStart
in class HBaseReplicationEndpoint
protected void doStop()
doStop
in class HBaseReplicationEndpoint
private ExecutorService getDefaultThreadPool(org.apache.hadoop.conf.Configuration conf)
public boolean replicate(ReplicationEndpoint.ReplicateContext replicateContext)
ReplicationEndpoint
replicateContext
- a context where WAL entries and other parameters can be obtained.public boolean canReplicateToSameCluster()
ReplicationEndpoint
canReplicateToSameCluster
in interface ReplicationEndpoint
canReplicateToSameCluster
in class BaseReplicationEndpoint
protected WALEntryFilter getScopeWALEntryFilter()
BaseReplicationEndpoint
getScopeWALEntryFilter
in class BaseReplicationEndpoint
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.