Package | Description |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.client.replication | |
org.apache.hadoop.hbase.coprocessor |
Table of Contents
|
org.apache.hadoop.hbase.mapreduce.replication | |
org.apache.hadoop.hbase.master | |
org.apache.hadoop.hbase.master.replication | |
org.apache.hadoop.hbase.replication |
Multi Cluster Replication
|
org.apache.hadoop.hbase.security.access | |
org.apache.hadoop.hbase.security.visibility | |
org.apache.hadoop.hbase.thrift2.client |
Modifier and Type | Method and Description |
---|---|
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 |
---|---|
default void |
Admin.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig)
Add a new replication peer for replicating data to slave cluster.
|
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,
boolean enabled)
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
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled) |
CompletableFuture<Void> |
AsyncHBaseAdmin.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled) |
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.
|
Future<Void> |
HBaseAdmin.addReplicationPeerAsync(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled) |
default void |
Admin.updateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig)
Update the peerConfig for the specified peer.
|
CompletableFuture<Void> |
AsyncAdmin.updateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig)
Update the peerConfig for the specified peer
|
CompletableFuture<Void> |
RawAsyncHBaseAdmin.updateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig) |
CompletableFuture<Void> |
AsyncHBaseAdmin.updateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig) |
Future<Void> |
Admin.updateReplicationPeerConfigAsync(String peerId,
ReplicationPeerConfig peerConfig)
Update the peerConfig for the specified peer but does not block and wait for it.
|
Future<Void> |
HBaseAdmin.updateReplicationPeerConfigAsync(String peerId,
ReplicationPeerConfig peerConfig) |
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) |
ReplicationPeerConfig |
ReplicationAdmin.getPeerConfig(String id)
Deprecated.
use
Admin.getReplicationPeerConfig(String)
instead |
static ReplicationPeerConfig |
ReplicationPeerConfigUtil.parsePeerFrom(byte[] bytes)
Parse the serialized representation of a peer configuration.
|
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 |
---|---|
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 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)
Returns Serialized protobuf of
peerConfig with pb magic prefix prepended suitable
for use as content of a this.peersZNode; i.e. |
void |
ReplicationAdmin.updatePeerConfig(String id,
ReplicationPeerConfig peerConfig)
Deprecated.
|
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 |
---|---|
default void |
MasterObserver.postAddReplicationPeer(ObserverContext<MasterCoprocessorEnvironment> ctx,
String peerId,
ReplicationPeerConfig peerConfig)
Called after add a replication peer
|
default void |
MasterObserver.postUpdateReplicationPeerConfig(ObserverContext<MasterCoprocessorEnvironment> ctx,
String peerId,
ReplicationPeerConfig peerConfig)
Called after update peerConfig for the specified peer
|
default void |
MasterObserver.preAddReplicationPeer(ObserverContext<MasterCoprocessorEnvironment> ctx,
String peerId,
ReplicationPeerConfig peerConfig)
Called before add a replication peer
|
default void |
MasterObserver.preUpdateReplicationPeerConfig(ObserverContext<MasterCoprocessorEnvironment> ctx,
String peerId,
ReplicationPeerConfig peerConfig)
Called before update peerConfig for the specified peer n * @param peerId a short name that
identifies the peer
|
Modifier and Type | Method and Description |
---|---|
private static Pair<ReplicationPeerConfig,org.apache.hadoop.conf.Configuration> |
VerifyReplication.getPeerQuorumConfig(org.apache.hadoop.conf.Configuration conf,
String peerId) |
Modifier and Type | Method and Description |
---|---|
ReplicationPeerConfig |
MasterServices.getReplicationPeerConfig(String peerId)
Returns the configured ReplicationPeerConfig for the specified peer
|
ReplicationPeerConfig |
HMaster.getReplicationPeerConfig(String peerId) |
Modifier and Type | Method and Description |
---|---|
long |
MasterServices.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled)
Add a new replication peer for replicating data to slave cluster
|
long |
HMaster.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled) |
void |
MasterCoprocessorHost.postAddReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig) |
void |
MasterCoprocessorHost.postUpdateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig) |
void |
MasterCoprocessorHost.preAddReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig) |
void |
MasterCoprocessorHost.preUpdateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig) |
long |
MasterServices.updateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig)
Update the peerConfig for the specified peer
|
long |
HMaster.updateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig) |
Modifier and Type | Field and Description |
---|---|
private ReplicationPeerConfig |
UpdatePeerConfigProcedure.oldPeerConfig |
private ReplicationPeerConfig |
UpdatePeerConfigProcedure.peerConfig |
private ReplicationPeerConfig |
RemovePeerProcedure.peerConfig |
private ReplicationPeerConfig |
AddPeerProcedure.peerConfig |
Modifier and Type | Method and Description |
---|---|
protected ReplicationPeerConfig |
ModifyPeerProcedure.getNewPeerConfig() |
protected ReplicationPeerConfig |
UpdatePeerConfigProcedure.getNewPeerConfig() |
protected ReplicationPeerConfig |
AddPeerProcedure.getNewPeerConfig() |
protected ReplicationPeerConfig |
ModifyPeerProcedure.getOldPeerConfig() |
protected ReplicationPeerConfig |
UpdatePeerConfigProcedure.getOldPeerConfig() |
(package private) ReplicationPeerConfig |
ReplicationPeerManager.preRemovePeer(String peerId) |
Modifier and Type | Method and Description |
---|---|
Optional<ReplicationPeerConfig> |
ReplicationPeerManager.getPeerConfig(String peerId) |
Modifier and Type | Method and Description |
---|---|
void |
ReplicationPeerManager.addPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled) |
private void |
ReplicationPeerManager.checkConfiguredWALEntryFilters(ReplicationPeerConfig peerConfig) |
private void |
ReplicationPeerManager.checkPeerConfig(ReplicationPeerConfig peerConfig) |
(package private) void |
ReplicationPeerManager.preAddPeer(String peerId,
ReplicationPeerConfig peerConfig) |
(package private) ReplicationPeerDescription |
ReplicationPeerManager.preUpdatePeerConfig(String peerId,
ReplicationPeerConfig peerConfig)
Return the old peer description.
|
protected void |
ModifyPeerProcedure.setLastPushedSequenceId(MasterProcedureEnv env,
ReplicationPeerConfig peerConfig) |
void |
ReplicationPeerManager.updatePeerConfig(String peerId,
ReplicationPeerConfig peerConfig) |
Constructor and Description |
---|
AddPeerProcedure(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled) |
UpdatePeerConfigProcedure(String peerId,
ReplicationPeerConfig peerConfig) |
Modifier and Type | Field and Description |
---|---|
private ReplicationPeerConfig |
ReplicationPeerDescription.config |
private ReplicationPeerConfig |
ReplicationPeerImpl.peerConfig |
Modifier and Type | Method and Description |
---|---|
ReplicationPeerConfig |
ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl.build() |
ReplicationPeerConfig |
ReplicationPeerConfigBuilder.build()
Builds the configuration object from the current state of
this . |
ReplicationPeerConfig |
ReplicationPeerImpl.getPeerConfig()
Get the peer config object
|
ReplicationPeerConfig |
ReplicationPeer.getPeerConfig()
Get the peer config object
|
ReplicationPeerConfig |
ReplicationEndpoint.Context.getPeerConfig() |
ReplicationPeerConfig |
ReplicationPeerDescription.getPeerConfig() |
ReplicationPeerConfig |
ReplicationPeerStorage.getPeerConfig(String peerId)
Get the peer config of a replication peer.
|
ReplicationPeerConfig |
ZKReplicationPeerStorage.getPeerConfig(String peerId) |
ReplicationPeerConfig |
ReplicationPeers.refreshPeerConfig(String peerId) |
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 |
---|---|
void |
ReplicationPeerStorage.addPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled)
Add a replication peer.
|
void |
ZKReplicationPeerStorage.addPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled) |
static boolean |
ReplicationUtils.contains(ReplicationPeerConfig peerConfig,
TableName tableName)
Deprecated.
Will be removed in HBase 3. Use
needToReplicate(TableName) instead. |
static org.apache.hadoop.conf.Configuration |
ReplicationUtils.getPeerClusterConfiguration(ReplicationPeerConfig peerConfig,
org.apache.hadoop.conf.Configuration baseConf) |
static boolean |
ReplicationUtils.isNamespacesAndTableCFsEqual(ReplicationPeerConfig rpc1,
ReplicationPeerConfig rpc2) |
static ReplicationPeerConfigBuilder |
ReplicationPeerConfig.newBuilder(ReplicationPeerConfig peerConfig) |
void |
ReplicationPeerConfigListener.peerConfigUpdated(ReplicationPeerConfig rpc)
Callback method for when users update the ReplicationPeerConfig for this peer
|
void |
BaseReplicationEndpoint.peerConfigUpdated(ReplicationPeerConfig rpc) |
void |
ReplicationPeerImpl.setPeerConfig(ReplicationPeerConfig peerConfig) |
void |
ReplicationPeerStorage.updatePeerConfig(String peerId,
ReplicationPeerConfig peerConfig)
Update the config a replication peer.
|
void |
ZKReplicationPeerStorage.updatePeerConfig(String peerId,
ReplicationPeerConfig peerConfig) |
Constructor and Description |
---|
ReplicationPeerDescription(String id,
boolean enabled,
ReplicationPeerConfig config) |
ReplicationPeerImpl(org.apache.hadoop.conf.Configuration conf,
String id,
boolean peerState,
ReplicationPeerConfig peerConfig)
Constructor that takes all the objects required to communicate with the specified peer, except
for the region server addresses.
|
Modifier and Type | Method and Description |
---|---|
void |
AccessController.preAddReplicationPeer(ObserverContext<MasterCoprocessorEnvironment> ctx,
String peerId,
ReplicationPeerConfig peerConfig) |
void |
AccessController.preUpdateReplicationPeerConfig(ObserverContext<MasterCoprocessorEnvironment> ctx,
String peerId,
ReplicationPeerConfig peerConfig) |
Modifier and Type | Method and Description |
---|---|
void |
VisibilityReplicationEndpoint.peerConfigUpdated(ReplicationPeerConfig rpc) |
Modifier and Type | Method and Description |
---|---|
ReplicationPeerConfig |
ThriftAdmin.getReplicationPeerConfig(String peerId) |
Modifier and Type | Method and Description |
---|---|
Future<Void> |
ThriftAdmin.addReplicationPeerAsync(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled) |
Future<Void> |
ThriftAdmin.updateReplicationPeerConfigAsync(String peerId,
ReplicationPeerConfig peerConfig) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.