Package | Description |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.client.replication | |
org.apache.hadoop.hbase.replication | |
org.apache.hadoop.hbase.shaded.protobuf |
Modifier and Type | Method and Description |
---|---|
default ReplicationPeerConfig |
Admin.getReplicationPeerConfig(String peerId)
Returns the configured ReplicationPeerConfig for the specified peer.
|
ReplicationPeerConfig |
HBaseAdmin.getReplicationPeerConfig(String peerId) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<ReplicationPeerConfig> |
AsyncAdmin.getReplicationPeerConfig(String peerId)
Returns the configured ReplicationPeerConfig for the specified peer
|
CompletableFuture<ReplicationPeerConfig> |
RawAsyncHBaseAdmin.getReplicationPeerConfig(String peerId) |
CompletableFuture<ReplicationPeerConfig> |
AsyncHBaseAdmin.getReplicationPeerConfig(String peerId) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Void> |
AsyncAdmin.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig)
Add a new replication peer for replicating data to slave cluster
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig) |
default void |
Admin.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig)
Add a new replication peer for replicating data to slave cluster.
|
void |
HBaseAdmin.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig) |
CompletableFuture<Void> |
AsyncHBaseAdmin.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig) |
CompletableFuture<Void> |
AsyncAdmin.updateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig)
Update the peerConfig for the specified peer
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.updateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig) |
default void |
Admin.updateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig)
Update the peerConfig for the specified peer.
|
void |
HBaseAdmin.updateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig) |
CompletableFuture<Void> |
AsyncHBaseAdmin.updateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig) |
Modifier and Type | Method and Description |
---|---|
static ReplicationPeerConfig |
ReplicationSerDeHelper.convert(org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.ReplicationPeer peer) |
ReplicationPeerConfig |
ReplicationAdmin.getPeerConfig(String id)
Deprecated.
use
Admin.getReplicationPeerConfig(String)
instead |
static ReplicationPeerConfig |
ReplicationSerDeHelper.parsePeerFrom(byte[] bytes) |
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. |
static void |
ReplicationSerDeHelper.appendTableCFsToReplicationPeerConfig(Map<TableName,? extends Collection<String>> tableCfs,
ReplicationPeerConfig peerConfig) |
static org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.ReplicationPeer |
ReplicationSerDeHelper.convert(ReplicationPeerConfig peerConfig) |
static void |
ReplicationSerDeHelper.removeTableCFsFromReplicationPeerConfig(Map<TableName,? extends Collection<String>> tableCfs,
ReplicationPeerConfig peerConfig,
String id) |
static byte[] |
ReplicationSerDeHelper.toByteArray(ReplicationPeerConfig peerConfig) |
void |
ReplicationAdmin.updatePeerConfig(String id,
ReplicationPeerConfig peerConfig)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
ReplicationPeerConfig |
ReplicationPeerDescription.getPeerConfig() |
ReplicationPeerConfig |
ReplicationPeerConfig.setBandwidth(long bandwidth) |
ReplicationPeerConfig |
ReplicationPeerConfig.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
|
ReplicationPeerConfig |
ReplicationPeerConfig.setNamespaces(Set<String> namespaces) |
ReplicationPeerConfig |
ReplicationPeerConfig.setReplicationEndpointImpl(String replicationEndpointImpl)
Sets the ReplicationEndpoint plugin class for this peer.
|
ReplicationPeerConfig |
ReplicationPeerConfig.setTableCFsMap(Map<TableName,? extends Collection<String>> tableCFsMap) |
Constructor and Description |
---|
ReplicationPeerDescription(String id,
boolean enabled,
ReplicationPeerConfig config) |
Modifier and Type | Method and Description |
---|---|
static org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.AddReplicationPeerRequest |
RequestConverter.buildAddReplicationPeerRequest(String peerId,
ReplicationPeerConfig peerConfig) |
static org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.UpdateReplicationPeerConfigRequest |
RequestConverter.buildUpdateReplicationPeerConfigRequest(String peerId,
ReplicationPeerConfig peerConfig) |
Copyright © 2007–2017 The Apache Software Foundation. All rights reserved.