Class TestSerialReplicationEndpoint.TestEndpoint
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.TestSerialReplicationEndpoint.TestEndpoint
- 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
- Enclosing class:
- TestSerialReplicationEndpoint
public static class TestSerialReplicationEndpoint.TestEndpoint
extends org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
- 
Nested Class SummaryNested classes/interfaces inherited from class org.apache.hadoop.hbase.replication.HBaseReplicationEndpointorg.apache.hadoop.hbase.replication.HBaseReplicationEndpoint.SinkPeerNested classes/interfaces inherited from interface org.apache.hadoop.hbase.replication.ReplicationEndpointorg.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.Serviceorg.apache.hbase.thirdparty.com.google.common.util.concurrent.Service.Listener, org.apache.hbase.thirdparty.com.google.common.util.concurrent.Service.State
- 
Field SummaryFieldsModifier and TypeFieldDescriptionprivate static final BlockingQueue<org.apache.hadoop.hbase.wal.WAL.Entry>Fields inherited from class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpointREPLICATION_DROP_ON_DELETED_COLUMN_FAMILY_KEY, REPLICATION_DROP_ON_DELETED_TABLE_KEYFields inherited from class org.apache.hadoop.hbase.replication.HBaseReplicationEndpointconf, DEFAULT_BAD_SINK_THRESHOLD, DEFAULT_REPLICATION_SOURCE_RATIOFields inherited from class org.apache.hadoop.hbase.replication.BaseReplicationEndpointctx, REPLICATION_WALENTRYFILTER_CONFIG_KEY
- 
Constructor SummaryConstructors
- 
Method SummaryModifier and TypeMethodDescriptionprotected CompletableFuture<Integer>asyncReplicate(List<org.apache.hadoop.hbase.wal.WAL.Entry> entries, int ordinal, int timeout) booleanstatic List<org.apache.hadoop.hbase.wal.WAL.Entry>intstatic voidreset()Methods inherited from class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpointfilterNotExistColumnFamilyEdits, filterNotExistTableEdits, init, isNoSuchColumnFamilyException, isPeerEnabled, isTableNotFoundException, replicate, replicateEntriesMethods inherited from class org.apache.hadoop.hbase.replication.HBaseReplicationEndpointabort, chooseSinks, createConnection, doStart, doStop, fetchPeerAddresses, getPeerUUID, getReplicationSink, isAborted, reportBadSink, reportSinkSuccess, start, stopMethods inherited from class org.apache.hadoop.hbase.replication.BaseReplicationEndpointgetNamespaceTableCfWALEntryFilter, getScopeWALEntryFilter, getWALEntryfilter, isStarting, peerConfigUpdatedMethods inherited from class org.apache.hbase.thirdparty.com.google.common.util.concurrent.AbstractServiceaddListener, awaitRunning, awaitRunning, awaitRunning, awaitTerminated, awaitTerminated, awaitTerminated, doCancelStart, failureCause, isRunning, notifyFailed, notifyStarted, notifyStopped, startAsync, state, stopAsync, toStringMethods inherited from class java.lang.Objectclone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, waitMethods inherited from interface org.apache.hadoop.hbase.AbortableabortMethods inherited from interface org.apache.hadoop.hbase.replication.ReplicationEndpointawaitRunning, awaitRunning, awaitTerminated, awaitTerminated, failureCause, isRunning
- 
Field Details- 
entryQueue
 
- 
- 
Constructor Details- 
TestEndpointpublic TestEndpoint()
 
- 
- 
Method Details- 
reset
- 
getEntries
- 
canReplicateToSameCluster- Specified by:
- canReplicateToSameClusterin interface- org.apache.hadoop.hbase.replication.ReplicationEndpoint
- Overrides:
- canReplicateToSameClusterin class- org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
 
- 
asyncReplicateprotected CompletableFuture<Integer> asyncReplicate(List<org.apache.hadoop.hbase.wal.WAL.Entry> entries, int ordinal, int timeout) - Overrides:
- asyncReplicatein class- org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
 
- 
getNumSinks- Overrides:
- getNumSinksin class- org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
 
 
-