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.SinkPeer
Nested classes/interfaces inherited from interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context, org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
Nested 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
Modifier and TypeFieldDescriptionprotected static AtomicInteger
protected static int
private static final Object
private static AtomicBoolean
Fields inherited from class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
REPLICATION_DROP_ON_DELETED_COLUMN_FAMILY_KEY, REPLICATION_DROP_ON_DELETED_TABLE_KEY
Fields inherited from class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
conf, DEFAULT_BAD_SINK_THRESHOLD, DEFAULT_REPLICATION_SOURCE_RATIO
Fields inherited from class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
ctx, REPLICATION_WALENTRYFILTER_CONFIG_KEY
-
Constructor Summary
-
Method Summary
Modifier and TypeMethodDescriptionprotected CompletableFuture<Integer>
asyncReplicate
(List<org.apache.hadoop.hbase.wal.WAL.Entry> entries, int ordinal, int timeout) static void
await()
static int
static int
static void
pause()
boolean
replicate
(org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext replicateContext) static void
resume()
static void
setBatchCount
(int i) static void
setEntriesCount
(int i) Methods inherited from class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
filterNotExistColumnFamilyEdits, filterNotExistTableEdits, init, isNoSuchColumnFamilyException, isPeerEnabled, isTableNotFoundException, replicateEntries
Methods inherited from class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
abort, chooseSinks, createConnection, doStart, doStop, fetchPeerAddresses, getNumSinks, getPeerUUID, getReplicationSink, isAborted, reportBadSink, reportSinkSuccess, start, stop
Methods inherited from class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
canReplicateToSameCluster, getNamespaceTableCfWALEntryFilter, getScopeWALEntryFilter, getWALEntryfilter, isStarting, peerConfigUpdated
Methods 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, toString
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
Methods inherited from interface org.apache.hadoop.hbase.Abortable
abort
Methods 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:
replicate
in interfaceorg.apache.hadoop.hbase.replication.ReplicationEndpoint
- Overrides:
replicate
in 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:
asyncReplicate
in classorg.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-