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.replication.master | |
org.apache.hadoop.hbase.replication.regionserver | |
org.apache.hadoop.hbase.security.access | |
org.apache.hadoop.hbase.security.visibility |
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
|
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) |
void |
HBaseAdmin.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled) |
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) |
void |
HBaseAdmin.updateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig) |
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) |
void |
ReplicationAdmin.updatePeerConfig(String id,
ReplicationPeerConfig peerConfig)
Deprecated.
|
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
|
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 |
---|---|
void |
MasterServices.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled)
Add a new replication peer for replicating data to slave cluster
|
void |
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) |
void |
MasterServices.updateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig)
Update the peerConfig for the specified peer
|
void |
HMaster.updateReplicationPeerConfig(String peerId,
ReplicationPeerConfig peerConfig) |
Modifier and Type | Method and Description |
---|---|
ReplicationPeerConfig |
ReplicationManager.getPeerConfig(String peerId) |
Modifier and Type | Method and Description |
---|---|
void |
ReplicationManager.addReplicationPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled) |
private void |
ReplicationManager.checkConfiguredWALEntryFilters(ReplicationPeerConfig peerConfig) |
private void |
ReplicationManager.checkPeerConfig(ReplicationPeerConfig peerConfig)
If replicate_all flag is true, it means all user tables will be replicated to peer cluster.
|
void |
ReplicationManager.updatePeerConfig(String peerId,
ReplicationPeerConfig peerConfig) |
Modifier and Type | Field and Description |
---|---|
private ReplicationPeerConfig |
ReplicationPeerDescription.config |
private ReplicationPeerConfig |
ReplicationPeerZKImpl.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 |
ReplicationPeerDescription.getPeerConfig() |
ReplicationPeerConfig |
ReplicationPeerZKImpl.getPeerConfig()
Get the peer config object
|
ReplicationPeerConfig |
ReplicationPeer.getPeerConfig()
Get the peer config object
|
ReplicationPeerConfig |
ReplicationEndpoint.Context.getPeerConfig() |
ReplicationPeerConfig |
ReplicationPeers.getReplicationPeerConfig(String peerId)
Returns the configured ReplicationPeerConfig for this peerId
|
ReplicationPeerConfig |
ReplicationPeersZKImpl.getReplicationPeerConfig(String peerId)
Returns a ReplicationPeerConfig from the znode or null for the given peerId.
|
private ReplicationPeerConfig |
ReplicationPeerZKImpl.readPeerConfig() |
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 |
---|---|
Map<String,ReplicationPeerConfig> |
ReplicationPeers.getAllPeerConfigs()
List the cluster replication configs of all remote slave clusters (whether they are
enabled/disabled or connected/disconnected).
|
Map<String,ReplicationPeerConfig> |
ReplicationPeersZKImpl.getAllPeerConfigs() |
Pair<ReplicationPeerConfig,org.apache.hadoop.conf.Configuration> |
ReplicationPeers.getPeerConf(String peerId)
Returns the configuration needed to talk to the remote slave cluster.
|
Pair<ReplicationPeerConfig,org.apache.hadoop.conf.Configuration> |
ReplicationPeersZKImpl.getPeerConf(String peerId) |
Modifier and Type | Method and Description |
---|---|
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) |
default void |
ReplicationPeers.registerPeer(String peerId,
ReplicationPeerConfig peerConfig)
Add a new remote slave cluster for replication.
|
void |
ReplicationPeers.registerPeer(String peerId,
ReplicationPeerConfig peerConfig,
boolean enabled)
Add a new remote slave cluster for replication.
|
void |
ReplicationPeersZKImpl.registerPeer(String id,
ReplicationPeerConfig peerConfig,
boolean enabled) |
void |
ReplicationPeers.updatePeerConfig(String id,
ReplicationPeerConfig peerConfig)
Update the peerConfig for the a given peer cluster
|
void |
ReplicationPeersZKImpl.updatePeerConfig(String id,
ReplicationPeerConfig newConfig) |
Constructor and Description |
---|
ReplicationPeerDescription(String id,
boolean enabled,
ReplicationPeerConfig config) |
ReplicationPeerZKImpl(ZKWatcher zkWatcher,
org.apache.hadoop.conf.Configuration conf,
String id,
ReplicationPeerConfig peerConfig,
Abortable abortable)
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 |
---|---|
private ReplicationPeerConfig |
ReplicationPeerConfigUpgrader.getReplicationPeerConig(String peerNode) |
Modifier and Type | Method and Description |
---|---|
private ReplicationSourceInterface |
ReplicationSourceManager.getReplicationSource(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
ReplicationSourceManager manager,
ReplicationQueues replicationQueues,
ReplicationPeers replicationPeers,
Server server,
String peerId,
UUID clusterId,
ReplicationPeerConfig peerConfig,
ReplicationPeer replicationPeer,
WALFileLengthProvider walFileLengthProvider)
Factory method to create a replication source
|
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) |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.