Uses of Class
org.apache.hadoop.hbase.replication.ReplicationPeerConfig
Package
Description
Provides HBase Client
Table of Contents
Multi Cluster Replication
-
Uses of ReplicationPeerConfig in org.apache.hadoop.hbase.client
Modifier and TypeMethodDescriptionAdmin.getReplicationPeerConfig
(String peerId) Returns the configured ReplicationPeerConfig for the specified peer.HBaseAdmin.getReplicationPeerConfig
(String peerId) Modifier and TypeMethodDescriptionAsyncAdmin.getReplicationPeerConfig
(String peerId) Returns the configured ReplicationPeerConfig for the specified peerAsyncHBaseAdmin.getReplicationPeerConfig
(String peerId) RawAsyncHBaseAdmin.getReplicationPeerConfig
(String peerId) Modifier and TypeMethodDescriptiondefault void
Admin.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.default CompletableFuture<Void>
AsyncAdmin.addReplicationPeer
(String peerId, ReplicationPeerConfig peerConfig) Add a new replication peer for replicating data to slave clusterAsyncAdmin.addReplicationPeer
(String peerId, ReplicationPeerConfig peerConfig, boolean enabled) Add a new replication peer for replicating data to slave clusterAsyncHBaseAdmin.addReplicationPeer
(String peerId, ReplicationPeerConfig peerConfig, boolean enabled) RawAsyncHBaseAdmin.addReplicationPeer
(String peerId, ReplicationPeerConfig peerConfig, boolean enabled) Admin.addReplicationPeerAsync
(String peerId, ReplicationPeerConfig peerConfig) Add a new replication peer but does not block and wait for it.Admin.addReplicationPeerAsync
(String peerId, ReplicationPeerConfig peerConfig, boolean enabled) Add a new replication peer but does not block and wait for it.HBaseAdmin.addReplicationPeerAsync
(String peerId, ReplicationPeerConfig peerConfig, boolean enabled) default void
Admin.updateReplicationPeerConfig
(String peerId, ReplicationPeerConfig peerConfig) Update the peerConfig for the specified peer.AsyncAdmin.updateReplicationPeerConfig
(String peerId, ReplicationPeerConfig peerConfig) Update the peerConfig for the specified peerAsyncHBaseAdmin.updateReplicationPeerConfig
(String peerId, ReplicationPeerConfig peerConfig) RawAsyncHBaseAdmin.updateReplicationPeerConfig
(String peerId, ReplicationPeerConfig peerConfig) Admin.updateReplicationPeerConfigAsync
(String peerId, ReplicationPeerConfig peerConfig) Update the peerConfig for the specified peer but does not block and wait for it.HBaseAdmin.updateReplicationPeerConfigAsync
(String peerId, ReplicationPeerConfig peerConfig) -
Uses of ReplicationPeerConfig in org.apache.hadoop.hbase.client.replication
Modifier and TypeMethodDescriptionstatic 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) ReplicationAdmin.getPeerConfig
(String id) Deprecated.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 configurationReplicationPeerConfig
with peer configs provided as property hbase.replication.peer.base.configs in hbase configuration.Modifier and TypeMethodDescriptionReplicationAdmin.listPeerConfigs()
Deprecated.useAdmin.listReplicationPeers()
insteadModifier and TypeMethodDescriptionvoid
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, useReplicationAdmin.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 ofpeerConfig
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 configurationReplicationPeerConfig
with peer configs provided as property hbase.replication.peer.base.configs in hbase configuration. -
Uses of ReplicationPeerConfig in org.apache.hadoop.hbase.coprocessor
Modifier and TypeMethodDescriptiondefault void
MasterObserver.postAddReplicationPeer
(ObserverContext<MasterCoprocessorEnvironment> ctx, String peerId, ReplicationPeerConfig peerConfig) Called after add a replication peerdefault void
MasterObserver.postUpdateReplicationPeerConfig
(ObserverContext<MasterCoprocessorEnvironment> ctx, String peerId, ReplicationPeerConfig peerConfig) Called after update peerConfig for the specified peerdefault void
MasterObserver.preAddReplicationPeer
(ObserverContext<MasterCoprocessorEnvironment> ctx, String peerId, ReplicationPeerConfig peerConfig) Called before add a replication peerdefault void
MasterObserver.preUpdateReplicationPeerConfig
(ObserverContext<MasterCoprocessorEnvironment> ctx, String peerId, ReplicationPeerConfig peerConfig) Called before update peerConfig for the specified peer -
Uses of ReplicationPeerConfig in org.apache.hadoop.hbase.mapreduce.replication
Modifier and TypeMethodDescriptionprivate static Pair<ReplicationPeerConfig,
org.apache.hadoop.conf.Configuration> VerifyReplication.getPeerQuorumConfig
(org.apache.hadoop.conf.Configuration conf, String peerId) -
Uses of ReplicationPeerConfig in org.apache.hadoop.hbase.master
Modifier and TypeMethodDescriptionHMaster.getReplicationPeerConfig
(String peerId) MasterServices.getReplicationPeerConfig
(String peerId) Returns the configured ReplicationPeerConfig for the specified peerModifier and TypeMethodDescriptionlong
HMaster.addReplicationPeer
(String peerId, ReplicationPeerConfig peerConfig, boolean enabled) long
MasterServices.addReplicationPeer
(String peerId, ReplicationPeerConfig peerConfig, boolean enabled) Add a new replication peer for replicating data to slave clustervoid
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
HMaster.updateReplicationPeerConfig
(String peerId, ReplicationPeerConfig peerConfig) long
MasterServices.updateReplicationPeerConfig
(String peerId, ReplicationPeerConfig peerConfig) Update the peerConfig for the specified peer -
Uses of ReplicationPeerConfig in org.apache.hadoop.hbase.master.replication
Modifier and TypeFieldDescriptionprivate ReplicationPeerConfig
UpdatePeerConfigProcedure.oldPeerConfig
private ReplicationPeerConfig
AddPeerProcedure.peerConfig
private ReplicationPeerConfig
RemovePeerProcedure.peerConfig
private ReplicationPeerConfig
UpdatePeerConfigProcedure.peerConfig
Modifier and TypeMethodDescriptionprotected ReplicationPeerConfig
AddPeerProcedure.getNewPeerConfig()
protected ReplicationPeerConfig
ModifyPeerProcedure.getNewPeerConfig()
protected ReplicationPeerConfig
UpdatePeerConfigProcedure.getNewPeerConfig()
protected ReplicationPeerConfig
ModifyPeerProcedure.getOldPeerConfig()
protected ReplicationPeerConfig
UpdatePeerConfigProcedure.getOldPeerConfig()
(package private) ReplicationPeerConfig
ReplicationPeerManager.preRemovePeer
(String peerId) Modifier and TypeMethodDescriptionvoid
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 final void
ModifyPeerProcedure.setLastPushedSequenceId
(MasterProcedureEnv env, ReplicationPeerConfig peerConfig) void
ReplicationPeerManager.updatePeerConfig
(String peerId, ReplicationPeerConfig peerConfig) ModifierConstructorDescriptionAddPeerProcedure
(String peerId, ReplicationPeerConfig peerConfig, boolean enabled) UpdatePeerConfigProcedure
(String peerId, ReplicationPeerConfig peerConfig) -
Uses of ReplicationPeerConfig in org.apache.hadoop.hbase.replication
Modifier and TypeFieldDescriptionprivate final ReplicationPeerConfig
ReplicationPeerDescription.config
private ReplicationPeerConfig
ReplicationPeerImpl.peerConfig
Modifier and TypeMethodDescriptionReplicationPeerConfig.ReplicationPeerConfigBuilderImpl.build()
ReplicationPeerConfigBuilder.build()
Builds the configuration object from the current state ofthis
.FSReplicationPeerStorage.getPeerConfig
(String peerId) ReplicationEndpoint.Context.getPeerConfig()
ReplicationPeer.getPeerConfig()
Get the peer config objectReplicationPeerDescription.getPeerConfig()
ReplicationPeerImpl.getPeerConfig()
Get the peer config objectReplicationPeerStorage.getPeerConfig
(String peerId) Get the peer config of a replication peer.ZKReplicationPeerStorage.getPeerConfig
(String peerId) ReplicationPeers.refreshPeerConfig
(String peerId) ReplicationPeerConfig.setBandwidth
(long bandwidth) Deprecated.as release of 2.0.0, and it will be removed in 3.0.0.ReplicationPeerConfig.setClusterKey
(String clusterKey) Deprecated.as release of 2.0.0, and it will be removed in 3.0.0.ReplicationPeerConfig.setExcludeNamespaces
(Set<String> namespaces) Deprecated.as release of 2.0.0, and it will be removed in 3.0.0.ReplicationPeerConfig.setExcludeTableCFsMap
(Map<TableName, ? extends Collection<String>> tableCFsMap) Deprecated.as release of 2.0.0, and it will be removed in 3.0.0.ReplicationPeerConfig.setNamespaces
(Set<String> namespaces) Deprecated.as release of 2.0.0, and it will be removed in 3.0.0.ReplicationPeerConfig.setReplicateAllUserTables
(boolean replicateAllUserTables) Deprecated.as release of 2.0.0, and it will be removed in 3.0.0.ReplicationPeerConfig.setReplicationEndpointImpl
(String replicationEndpointImpl) Deprecated.as release of 2.0.0, and it will be removed in 3.0.0.ReplicationPeerConfig.setTableCFsMap
(Map<TableName, ? extends Collection<String>> tableCFsMap) Deprecated.as release of 2.0.0, and it will be removed in 3.0.0.Modifier and TypeMethodDescriptionvoid
FSReplicationPeerStorage.addPeer
(String peerId, ReplicationPeerConfig peerConfig, boolean enabled) 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.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
BaseReplicationEndpoint.peerConfigUpdated
(ReplicationPeerConfig rpc) void
ReplicationPeerConfigListener.peerConfigUpdated
(ReplicationPeerConfig rpc) Callback method for when users update the ReplicationPeerConfig for this peervoid
ReplicationPeerImpl.setPeerConfig
(ReplicationPeerConfig peerConfig) void
FSReplicationPeerStorage.updatePeerConfig
(String peerId, ReplicationPeerConfig peerConfig) void
ReplicationPeerStorage.updatePeerConfig
(String peerId, ReplicationPeerConfig peerConfig) Update the config a replication peer.void
ZKReplicationPeerStorage.updatePeerConfig
(String peerId, ReplicationPeerConfig peerConfig) ModifierConstructorDescriptionReplicationPeerDescription
(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. -
Uses of ReplicationPeerConfig in org.apache.hadoop.hbase.security.access
Modifier and TypeMethodDescriptionvoid
AccessController.preAddReplicationPeer
(ObserverContext<MasterCoprocessorEnvironment> ctx, String peerId, ReplicationPeerConfig peerConfig) void
AccessController.preUpdateReplicationPeerConfig
(ObserverContext<MasterCoprocessorEnvironment> ctx, String peerId, ReplicationPeerConfig peerConfig) -
Uses of ReplicationPeerConfig in org.apache.hadoop.hbase.security.visibility
Modifier and TypeMethodDescriptionvoid
VisibilityReplicationEndpoint.peerConfigUpdated
(ReplicationPeerConfig rpc) -
Uses of ReplicationPeerConfig in org.apache.hadoop.hbase.thrift2.client
Modifier and TypeMethodDescriptionThriftAdmin.addReplicationPeerAsync
(String peerId, ReplicationPeerConfig peerConfig, boolean enabled) ThriftAdmin.updateReplicationPeerConfigAsync
(String peerId, ReplicationPeerConfig peerConfig)
Admin.getReplicationPeerConfig(String)
instead