Class TestReplicationSource.DoNothingReplicationEndpoint

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.TestReplicationSource.DoNothingReplicationEndpoint
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:
TestReplicationSource.BadReplicationEndpoint, TestReplicationSource.FaultyReplicationEndpoint, TestReplicationSource.FlakyReplicationEndpoint
Enclosing class:
TestReplicationSource

public static class TestReplicationSource.DoNothingReplicationEndpoint extends org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
Deadend Endpoint. Does nothing.
  • 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

    Fields
    Modifier and Type
    Field
    Description
    private final UUID
     

    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

    Constructors
    Constructor
    Description
     
  • Method Summary

    Modifier and Type
    Method
    Description
    boolean
     
    protected void
     
    protected void
     
     
    org.apache.hadoop.hbase.replication.WALEntryFilter
     
    void
    init(org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context context)
     

    Methods inherited from class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint

    asyncReplicate, filterNotExistColumnFamilyEdits, filterNotExistTableEdits, isNoSuchColumnFamilyException, isPeerEnabled, isTableNotFoundException, replicate, replicateEntries

    Methods inherited from class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint

    abort, chooseSinks, createConnection, fetchPeerAddresses, getNumSinks, getReplicationSink, isAborted, reportBadSink, reportSinkSuccess, start, stop

    Methods inherited from class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint

    getNamespaceTableCfWALEntryFilter, getScopeWALEntryFilter, 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

  • Constructor Details

  • Method Details

    • init

      public void init(org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context context) throws IOException
      Specified by:
      init in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
      Overrides:
      init in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
      Throws:
      IOException
    • getWALEntryfilter

      public org.apache.hadoop.hbase.replication.WALEntryFilter getWALEntryfilter()
      Specified by:
      getWALEntryfilter in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
      Overrides:
      getWALEntryfilter in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
    • getPeerUUID

      public UUID getPeerUUID()
      Specified by:
      getPeerUUID in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
      Overrides:
      getPeerUUID in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
    • doStart

      protected void doStart()
      Overrides:
      doStart in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
    • doStop

      protected void doStop()
      Overrides:
      doStop in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
    • canReplicateToSameCluster

      public boolean canReplicateToSameCluster()
      Specified by:
      canReplicateToSameCluster in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
      Overrides:
      canReplicateToSameCluster in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint