@InterfaceAudience.Private public class VisibilityReplicationEndpoint extends Object implements ReplicationEndpoint
ReplicationEndpoint.Context, ReplicationEndpoint.ReplicateContext| Modifier and Type | Field and Description |
|---|---|
private ReplicationEndpoint |
delegator |
private static org.apache.commons.logging.Log |
LOG |
private VisibilityLabelService |
visibilityLabelsService |
| Constructor and Description |
|---|
VisibilityReplicationEndpoint(ReplicationEndpoint endpoint,
VisibilityLabelService visibilityLabelsService) |
| 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
|
UUID |
getPeerUUID()
Returns a UUID of the provided peer id.
|
WALEntryFilter |
getWALEntryfilter()
Returns a WALEntryFilter to use for filtering out WALEntries from the log.
|
void |
init(ReplicationEndpoint.Context context)
Initialize the replication endpoint with the given context.
|
boolean |
isRunning() |
boolean |
replicate(ReplicationEndpoint.ReplicateContext replicateContext)
Replicate the given set of entries (in the context) to the other cluster.
|
com.google.common.util.concurrent.ListenableFuture<com.google.common.util.concurrent.Service.State> |
start() |
com.google.common.util.concurrent.Service.State |
startAndWait() |
com.google.common.util.concurrent.Service.State |
state() |
com.google.common.util.concurrent.ListenableFuture<com.google.common.util.concurrent.Service.State> |
stop() |
com.google.common.util.concurrent.Service.State |
stopAndWait() |
private static final org.apache.commons.logging.Log LOG
private ReplicationEndpoint delegator
private VisibilityLabelService visibilityLabelsService
public VisibilityReplicationEndpoint(ReplicationEndpoint endpoint, VisibilityLabelService visibilityLabelsService)
public void init(ReplicationEndpoint.Context context) throws IOException
ReplicationEndpointinit in interface ReplicationEndpointcontext - replication contextIOExceptionpublic boolean replicate(ReplicationEndpoint.ReplicateContext replicateContext)
ReplicationEndpointreplicate in interface ReplicationEndpointreplicateContext - a context where WAL entries and other
parameters can be obtained.public UUID getPeerUUID()
ReplicationEndpointgetPeerUUID in interface ReplicationEndpointpublic boolean canReplicateToSameCluster()
ReplicationEndpointcanReplicateToSameCluster in interface ReplicationEndpointpublic WALEntryFilter getWALEntryfilter()
ReplicationEndpointgetWALEntryfilter in interface ReplicationEndpointWALEntryFilter or null.public boolean isRunning()
isRunning in interface com.google.common.util.concurrent.Servicepublic com.google.common.util.concurrent.ListenableFuture<com.google.common.util.concurrent.Service.State> start()
start in interface com.google.common.util.concurrent.Servicepublic com.google.common.util.concurrent.Service.State startAndWait()
startAndWait in interface com.google.common.util.concurrent.Servicepublic com.google.common.util.concurrent.Service.State state()
state in interface com.google.common.util.concurrent.Servicepublic com.google.common.util.concurrent.ListenableFuture<com.google.common.util.concurrent.Service.State> stop()
stop in interface com.google.common.util.concurrent.Servicepublic com.google.common.util.concurrent.Service.State stopAndWait()
stopAndWait in interface com.google.common.util.concurrent.ServiceCopyright © 2007–2019 The Apache Software Foundation. All rights reserved.