public static class TestReplicator.ReplicationEndpointForTest extends org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint.PeerRegionServerListener| Modifier and Type | Field and Description |
|---|---|
protected static AtomicInteger |
batchCount |
protected static int |
entriesCount |
private static Object |
latch |
private static AtomicBoolean |
useLatch |
| Constructor and Description |
|---|
ReplicationEndpointForTest() |
| Modifier and Type | Method and Description |
|---|---|
static void |
await() |
protected Callable<Integer> |
createReplicator(List<org.apache.hadoop.hbase.wal.WAL.Entry> entries,
int ordinal) |
static int |
getBatchCount() |
static int |
getEntriesCount() |
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) |
doStop, init, isPeerEnabled, replicateEntries, sleepForRetriesabort, disconnect, doStart, fetchSlavesAddresses, getLastRegionServerUpdate, getPeerUUID, getRegionServers, getZkw, isAborted, reconnect, setRegionServers, start, stopcanReplicateToSameCluster, getNamespaceTableCfWALEntryFilter, getScopeWALEntryFilter, getWALEntryfilter, isStarting, peerConfigUpdatedaddListener, awaitRunning, awaitRunning, awaitTerminated, awaitTerminated, failureCause, isRunning, notifyFailed, notifyStarted, notifyStopped, startAsync, state, stopAsync, toStringprotected static AtomicInteger batchCount
protected static int entriesCount
private static AtomicBoolean useLatch
public ReplicationEndpointForTest()
public static void resume()
public static void pause()
public static void await() throws InterruptedException
InterruptedExceptionpublic static int getBatchCount()
public static void setBatchCount(int i)
public static int getEntriesCount()
public static void setEntriesCount(int i)
public boolean replicate(org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext replicateContext)
replicate in interface org.apache.hadoop.hbase.replication.ReplicationEndpointreplicate in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpointprotected Callable<Integer> createReplicator(List<org.apache.hadoop.hbase.wal.WAL.Entry> entries, int ordinal)
createReplicator in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpointCopyright © 2007–2020 The Apache Software Foundation. All rights reserved.