public static class TestReplicator.ReplicationEndpointForTest extends org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
Modifier and Type | Class and Description |
---|---|
class |
TestReplicator.ReplicationEndpointForTest.ReplicatorForTest |
org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint.Replicator
org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint.PeerRegionServerListener
Modifier and Type | Field and Description |
---|---|
private static AtomicInteger |
batchCount |
private 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 org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint.Replicator |
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, sleepForRetries
abort, disconnect, doStart, fetchSlavesAddresses, getLastRegionServerUpdate, getPeerUUID, getRegionServers, getZkw, isAborted, reconnect, setRegionServers, start, stop
canReplicateToSameCluster, getNamespaceTableCfWALEntryFilter, getScopeWALEntryFilter, getWALEntryfilter, isStarting, peerConfigUpdated
addListener, awaitRunning, awaitRunning, awaitTerminated, awaitTerminated, failureCause, isRunning, notifyFailed, notifyStarted, notifyStopped, startAsync, state, stopAsync, toString
private static AtomicInteger batchCount
private static int entriesCount
private static AtomicBoolean useLatch
public ReplicationEndpointForTest()
public static void resume()
public static void pause()
public static void await() throws InterruptedException
InterruptedException
public 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.ReplicationEndpoint
replicate
in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
protected org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint.Replicator createReplicator(List<org.apache.hadoop.hbase.wal.WAL.Entry> entries, int ordinal)
createReplicator
in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.