Uses of Class
org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext

Packages that use org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
Package
Description
Multi Cluster Replication
  • Uses of org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext in org.apache.hadoop.hbase.replication

    Methods in org.apache.hadoop.hbase.replication that return org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
    ReplicationEndpoint.ReplicateContext.setEntries(List<org.apache.hadoop.hbase.wal.WAL.Entry> entries)
     
    org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
    ReplicationEndpoint.ReplicateContext.setSize(int size)
     
    org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
    ReplicationEndpoint.ReplicateContext.setWalGroupId(String walGroupId)
     
    Methods in org.apache.hadoop.hbase.replication with parameters of type org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext in in
    Modifier and Type
    Method
    Description
    boolean
    ReplicationEndpoint.replicate(org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext replicateContext)
    Replicate the given set of entries (in the context) to the other cluster.
    boolean
    VerifyWALEntriesReplicationEndpoint.replicate(org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext replicateContext)