Class TestReplicator.ReplicationEndpointForTest
java.lang.Object
org.apache.hbase.thirdparty.com.google.common.util.concurrent.AbstractService
org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
org.apache.hadoop.hbase.replication.regionserver.TestReplicator.ReplicationEndpointForTest
- All Implemented Interfaces:
org.apache.hadoop.hbase.Abortable,org.apache.hadoop.hbase.replication.ReplicationEndpoint,org.apache.hadoop.hbase.replication.ReplicationPeerConfigListener,org.apache.hbase.thirdparty.com.google.common.util.concurrent.Service
- Direct Known Subclasses:
TestReplicator.FailureInjectingReplicationEndpointForTest
- Enclosing class:
- TestReplicator
public static class TestReplicator.ReplicationEndpointForTest
extends org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
Nested Class Summary
Nested classes/interfaces inherited from class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint.SinkPeerNested classes/interfaces inherited from interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context, org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContextNested classes/interfaces inherited from interface org.apache.hbase.thirdparty.com.google.common.util.concurrent.Service
org.apache.hbase.thirdparty.com.google.common.util.concurrent.Service.Listener, org.apache.hbase.thirdparty.com.google.common.util.concurrent.Service.State -
Field Summary
FieldsModifier and TypeFieldDescriptionprotected static AtomicIntegerprotected static intprivate static final Objectprivate static AtomicBooleanFields inherited from class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
REPLICATION_DROP_ON_DELETED_COLUMN_FAMILY_KEY, REPLICATION_DROP_ON_DELETED_TABLE_KEYFields inherited from class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
conf, DEFAULT_BAD_SINK_THRESHOLD, DEFAULT_REPLICATION_SOURCE_RATIOFields inherited from class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
ctx, REPLICATION_WALENTRYFILTER_CONFIG_KEY -
Constructor Summary
Constructors -
Method Summary
Modifier and TypeMethodDescriptionprotected CompletableFuture<Integer>asyncReplicate(List<org.apache.hadoop.hbase.wal.WAL.Entry> entries, int ordinal, int timeout) static voidawait()static intstatic intstatic voidpause()booleanreplicate(org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext replicateContext) static voidresume()static voidsetBatchCount(int i) static voidsetEntriesCount(int i) Methods inherited from class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
filterNotExistColumnFamilyEdits, filterNotExistTableEdits, init, isNoSuchColumnFamilyException, isPeerEnabled, isTableNotFoundException, replicateEntriesMethods inherited from class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
abort, chooseSinks, createConnection, doStart, doStop, fetchPeerAddresses, getNumSinks, getPeerUUID, getReplicationSink, isAborted, reportBadSink, reportSinkSuccess, start, stopMethods inherited from class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
canReplicateToSameCluster, getNamespaceTableCfWALEntryFilter, getScopeWALEntryFilter, getWALEntryfilter, isStarting, peerConfigUpdatedMethods inherited from class org.apache.hbase.thirdparty.com.google.common.util.concurrent.AbstractService
addListener, awaitRunning, awaitRunning, awaitRunning, awaitTerminated, awaitTerminated, awaitTerminated, doCancelStart, failureCause, isRunning, notifyFailed, notifyStarted, notifyStopped, startAsync, state, stopAsync, toStringMethods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, waitMethods inherited from interface org.apache.hadoop.hbase.Abortable
abortMethods inherited from interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
awaitRunning, awaitRunning, awaitTerminated, awaitTerminated, failureCause, isRunning
-
Field Details
-
batchCount
-
entriesCount
-
latch
-
useLatch
-
-
Constructor Details
-
ReplicationEndpointForTest
public ReplicationEndpointForTest()
-
-
Method Details
-
resume
-
pause
-
await
- Throws:
InterruptedException
-
getBatchCount
-
setBatchCount
-
getEntriesCount
-
setEntriesCount
-
replicate
public boolean replicate(org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext replicateContext) - Specified by:
replicatein interfaceorg.apache.hadoop.hbase.replication.ReplicationEndpoint- Overrides:
replicatein classorg.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
asyncReplicate
protected CompletableFuture<Integer> asyncReplicate(List<org.apache.hadoop.hbase.wal.WAL.Entry> entries, int ordinal, int timeout) - Overrides:
asyncReplicatein classorg.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-