Uses of Interface
org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder

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

    Methods in org.apache.hadoop.hbase.replication that return org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
    ReplicationPeerConfig.newBuilder()
     
    static org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
    ReplicationPeerConfig.newBuilder(org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig)
     
    default org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
    ReplicationPeerConfigBuilder.putAllConfiguration(Map<String,String> configuration)
    Adds all of the provided "raw" configuration entries to this.
    default org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
    ReplicationPeerConfigBuilder.putAllPeerData(Map<byte[],byte[]> peerData)
    Sets all of the provided serialized peer configuration data.
    org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
    ReplicationPeerConfigBuilder.putConfiguration(String key, String value)
    Sets a "raw" configuration property for this replication peer.
    org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
    ReplicationPeerConfigBuilder.putPeerData(byte[] key, byte[] value)
    Sets the serialized peer configuration data
    org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
    ReplicationPeerConfigBuilder.removeConfiguration(String key)
    Removes a "raw" configuration property for this replication peer.
    org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
    ReplicationPeerConfigBuilder.setBandwidth(long bandwidth)
    Sets the speed, in bytes per second, for any one RegionServer to replicate data to the peer.
    org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
    ReplicationPeerConfigBuilder.setClusterKey(String clusterKey)
    Set the clusterKey which is the concatenation of the slave cluster's: hbase.zookeeper.quorum:hbase.zookeeper.property.clientPort:zookeeper.znode.parent
    org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
    ReplicationPeerConfigBuilder.setExcludeNamespaces(Set<String> namespaces)
    Sets the collection of namespaces which should not be replicated when all user tables are configured to be replicated.
    org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
    ReplicationPeerConfigBuilder.setExcludeTableCFsMap(Map<org.apache.hadoop.hbase.TableName,List<String>> tableCFsMap)
    Sets the mapping of table name to column families which should not be replicated.
    org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
    ReplicationPeerConfigBuilder.setNamespaces(Set<String> namespaces)
    Sets a unique collection of HBase namespaces that should be replicated to this peer.
    org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
    ReplicationPeerConfigBuilder.setReplicateAllUserTables(boolean replicateAllUserTables)
    Configures HBase to replicate all user tables (not system tables) to the peer.
    org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
    ReplicationPeerConfigBuilder.setReplicationEndpointImpl(String replicationEndpointImpl)
    Sets the ReplicationEndpoint plugin class for this peer.
    org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
    ReplicationPeerConfigBuilder.setSerial(boolean serial)
    Sets whether we should preserve order when replicating, i.e, serial replication.
    org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
    ReplicationPeerConfigBuilder.setTableCFsMap(Map<org.apache.hadoop.hbase.TableName,List<String>> tableCFsMap)
    Sets an explicit map of tables and column families in those tables that should be replicated to the given peer.