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 |
---|---|
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
|
default void |
Admin.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled)
Add a new replication peer for replicating data to slave cluster.
|
default Future<Void> |
Admin.addReplicationPeerAsync(String peerId,
ReplicationPeerConfig peerConfig)
Add a new replication peer but does not block and wait for it.
|
Future<Void> |
Admin.addReplicationPeerAsync(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled)
Add a new replication peer but does not block and wait for it.
|
CompletableFuture<Void> |
AsyncAdmin.updateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig)
Update the peerConfig for the specified peer
|
default void |
Admin.updateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig)
Update the peerConfig for the specified peer.
|
Future<Void> |
Admin.updateReplicationPeerConfigAsync(String peerId,
ReplicationPeerConfig peerConfig)
Update the peerConfig for the specified peer but does not block and wait for it.
|
Modifier and Type | Method and Description |
---|---|
static ReplicationPeerConfig |
ReplicationPeerConfigUtil.appendExcludeTableCFsToReplicationPeerConfig(Map<TableName,List<String>> excludeTableCfs,
ReplicationPeerConfig peerConfig) |
static ReplicationPeerConfig |
ReplicationPeerConfigUtil.appendTableCFsToReplicationPeerConfig(Map<TableName,List<String>> tableCfs,
ReplicationPeerConfig peerConfig) |
static ReplicationPeerConfig |
ReplicationPeerConfigUtil.convert(org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.ReplicationPeer peer) |
static ReplicationPeerConfig |
ReplicationPeerConfigUtil.parsePeerFrom(byte[] bytes) |
static ReplicationPeerConfig |
ReplicationPeerConfigUtil.removeExcludeTableCFsFromReplicationPeerConfig(Map<TableName,List<String>> excludeTableCfs,
ReplicationPeerConfig peerConfig,
String id) |
static ReplicationPeerConfig |
ReplicationPeerConfigUtil.removeTableCFsFromReplicationPeerConfig(Map<TableName,List<String>> tableCfs,
ReplicationPeerConfig peerConfig,
String id) |
static ReplicationPeerConfig |
ReplicationPeerConfigUtil.updateReplicationBasePeerConfigs(org.apache.hadoop.conf.Configuration conf,
ReplicationPeerConfig receivedPeerConfig)
Helper method to add/removev base peer configs from Configuration to ReplicationPeerConfig
This merges the user supplied peer configuration
ReplicationPeerConfig with peer configs
provided as property hbase.replication.peer.base.configs in hbase configuration. |
Modifier and Type | Method and Description |
---|---|
static ReplicationPeerConfig |
ReplicationPeerConfigUtil.appendExcludeTableCFsToReplicationPeerConfig(Map<TableName,List<String>> excludeTableCfs,
ReplicationPeerConfig peerConfig) |
static ReplicationPeerConfig |
ReplicationPeerConfigUtil.appendTableCFsToReplicationPeerConfig(Map<TableName,List<String>> tableCfs,
ReplicationPeerConfig peerConfig) |
static org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.ReplicationPeer |
ReplicationPeerConfigUtil.convert(ReplicationPeerConfig peerConfig) |
static ReplicationPeerConfig |
ReplicationPeerConfigUtil.removeExcludeTableCFsFromReplicationPeerConfig(Map<TableName,List<String>> excludeTableCfs,
ReplicationPeerConfig peerConfig,
String id) |
static ReplicationPeerConfig |
ReplicationPeerConfigUtil.removeTableCFsFromReplicationPeerConfig(Map<TableName,List<String>> tableCfs,
ReplicationPeerConfig peerConfig,
String id) |
static byte[] |
ReplicationPeerConfigUtil.toByteArray(ReplicationPeerConfig peerConfig) |
static ReplicationPeerConfig |
ReplicationPeerConfigUtil.updateReplicationBasePeerConfigs(org.apache.hadoop.conf.Configuration conf,
ReplicationPeerConfig receivedPeerConfig)
Helper method to add/removev base peer configs from Configuration to ReplicationPeerConfig
This merges the user supplied peer configuration
ReplicationPeerConfig with peer configs
provided as property hbase.replication.peer.base.configs in hbase configuration. |
Modifier and Type | Method and Description |
---|---|
ReplicationPeerConfig |
ReplicationPeerConfigBuilder.build()
Builds the configuration object from the current state of
this . |
ReplicationPeerConfig |
ReplicationPeerDescription.getPeerConfig() |
Modifier and Type | Method and Description |
---|---|
static ReplicationPeerConfigBuilder |
ReplicationPeerConfig.newBuilder(ReplicationPeerConfig peerConfig) |
Constructor and Description |
---|
ReplicationPeerDescription(String id,
boolean enabled,
ReplicationPeerConfig config,
SyncReplicationState syncReplicationState) |
Modifier and Type | Method and Description |
---|---|
static org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.AddReplicationPeerRequest |
RequestConverter.buildAddReplicationPeerRequest(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled) |
static org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.UpdateReplicationPeerConfigRequest |
RequestConverter.buildUpdateReplicationPeerConfigRequest(String peerId,
ReplicationPeerConfig peerConfig) |
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.