Package | Description |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.client.replication | |
org.apache.hadoop.hbase.replication |
Multi Cluster Replication
|
Modifier and Type | Method and Description |
---|---|
ReplicationPeerConfig |
Admin.getReplicationPeerConfig(String peerId)
Returns the configured ReplicationPeerConfig for the specified peer.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<ReplicationPeerConfig> |
AsyncAdmin.getReplicationPeerConfig(String peerId)
Returns the configured ReplicationPeerConfig for the specified peer
|
Modifier and Type | Method and Description |
---|---|
default CompletableFuture<Void> |
AsyncAdmin.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig)
Add a new replication peer for replicating data to slave cluster
|
default void |
Admin.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig)
Add a new replication peer for replicating data to slave cluster.
|
CompletableFuture<Void> |
AsyncAdmin.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled)
Add a new replication peer for replicating data to slave cluster
|
void |
Admin.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled)
Add a new replication peer for replicating data to slave cluster.
|
CompletableFuture<Void> |
AsyncAdmin.updateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig)
Update the peerConfig for the specified peer
|
void |
Admin.updateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig)
Update the peerConfig for the specified peer.
|
Modifier and Type | Method and Description |
---|---|
ReplicationPeerConfig |
ReplicationAdmin.getPeerConfig(String id)
Deprecated.
use
Admin.getReplicationPeerConfig(String)
instead |
Modifier and Type | Method and Description |
---|---|
Map<String,ReplicationPeerConfig> |
ReplicationAdmin.listPeerConfigs()
Deprecated.
use
Admin.listReplicationPeers() instead |
Modifier and Type | Method and Description |
---|---|
void |
ReplicationAdmin.addPeer(String id,
ReplicationPeerConfig peerConfig)
Deprecated.
|
void |
ReplicationAdmin.addPeer(String id,
ReplicationPeerConfig peerConfig,
Map<TableName,? extends Collection<String>> tableCfs)
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0,
use
ReplicationAdmin.addPeer(String, ReplicationPeerConfig) instead. |
void |
ReplicationAdmin.updatePeerConfig(String id,
ReplicationPeerConfig peerConfig)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
ReplicationPeerConfig |
ReplicationPeerConfigBuilder.build()
Builds the configuration object from the current state of
this . |
ReplicationPeerConfig |
ReplicationPeerDescription.getPeerConfig() |
ReplicationPeerConfig |
ReplicationPeerConfig.setBandwidth(long bandwidth)
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0. Use
ReplicationPeerConfigBuilder.setBandwidth(long) instead. |
ReplicationPeerConfig |
ReplicationPeerConfig.setClusterKey(String clusterKey)
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0. Use
ReplicationPeerConfigBuilder.setClusterKey(String) instead. |
ReplicationPeerConfig |
ReplicationPeerConfig.setExcludeNamespaces(Set<String> namespaces)
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0. Use
ReplicationPeerConfigBuilder.setExcludeNamespaces(Set) instead. |
ReplicationPeerConfig |
ReplicationPeerConfig.setExcludeTableCFsMap(Map<TableName,? extends Collection<String>> tableCFsMap)
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0. Use
ReplicationPeerConfigBuilder.setExcludeTableCFsMap(Map) instead. |
ReplicationPeerConfig |
ReplicationPeerConfig.setNamespaces(Set<String> namespaces)
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0. Use
ReplicationPeerConfigBuilder.setNamespaces(Set) instead. |
ReplicationPeerConfig |
ReplicationPeerConfig.setReplicateAllUserTables(boolean replicateAllUserTables)
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0. Use
ReplicationPeerConfigBuilder.setReplicateAllUserTables(boolean) instead. |
ReplicationPeerConfig |
ReplicationPeerConfig.setReplicationEndpointImpl(String replicationEndpointImpl)
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0. Use
ReplicationPeerConfigBuilder.setReplicationEndpointImpl(String) instead. |
ReplicationPeerConfig |
ReplicationPeerConfig.setTableCFsMap(Map<TableName,? extends Collection<String>> tableCFsMap)
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0. Use
ReplicationPeerConfigBuilder.setTableCFsMap(Map) instead. |
Modifier and Type | Method and Description |
---|---|
static ReplicationPeerConfigBuilder |
ReplicationPeerConfig.newBuilder(ReplicationPeerConfig peerConfig) |
Constructor and Description |
---|
ReplicationPeerDescription(String id,
boolean enabled,
ReplicationPeerConfig config) |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.