@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> |
private static class |
RegionReplicaReplicationEndpoint.SkipReplayedEditsFilter
Skips the entries which has original seqId.
|
HBaseReplicationEndpoint.PeerRegionServerListenerReplicationEndpoint.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 WALSplitter.EntryBuffers |
entryBuffers |
private static org.apache.commons.logging.Log |
LOG |
private int |
numWriterThreads |
private int |
operationTimeout |
private RegionReplicaReplicationEndpoint.RegionReplicaOutputSink |
outputSink |
private ExecutorService |
pool |
private TableDescriptors |
tableDescriptors |
ctx| 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.
|
protected WALEntryFilter |
getSkipReplayedEditsFilter() |
WALEntryFilter |
getWALEntryfilter()
Returns a default set of filters
|
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, setRegionServersgetTableCfWALEntryFilterisRunning, notifyFailed, notifyStarted, notifyStopped, start, startAndWait, state, stop, stopAndWait, toStringprivate static final org.apache.commons.logging.Log 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 WALSplitter.EntryBuffers entryBuffers
private int numWriterThreads
private int operationTimeout
private ExecutorService pool
public WALEntryFilter getWALEntryfilter()
BaseReplicationEndpointgetWALEntryfilter in interface ReplicationEndpointgetWALEntryfilter in class BaseReplicationEndpointWALEntryFilter or null.protected WALEntryFilter getSkipReplayedEditsFilter()
public void init(ReplicationEndpoint.Context context) throws IOException
ReplicationEndpointinit in interface ReplicationEndpointinit in class BaseReplicationEndpointcontext - replication contextIOExceptionprotected void doStart()
doStart in class HBaseReplicationEndpointprotected void doStop()
doStop in class HBaseReplicationEndpointprivate ExecutorService getDefaultThreadPool(org.apache.hadoop.conf.Configuration conf)
public boolean replicate(ReplicationEndpoint.ReplicateContext replicateContext)
ReplicationEndpointreplicateContext - a context where WAL entries and other
parameters can be obtained.public boolean canReplicateToSameCluster()
ReplicationEndpointcanReplicateToSameCluster in interface ReplicationEndpointcanReplicateToSameCluster in class BaseReplicationEndpointprotected WALEntryFilter getScopeWALEntryFilter()
BaseReplicationEndpointgetScopeWALEntryFilter in class BaseReplicationEndpointCopyright © 2007–2019 The Apache Software Foundation. All rights reserved.