Uses of Class
org.apache.hadoop.hbase.replication.ReplicationPeerConfig
Package
Description
Provides HBase Client
Table of Contents
Multi Cluster Replication
-
Uses of org.apache.hadoop.hbase.replication.ReplicationPeerConfig in org.apache.hadoop.hbase.client
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.replication.ReplicationPeerConfig
Admin.getReplicationPeerConfig
(String peerId) Returns the configured ReplicationPeerConfig for the specified peer.Modifier and TypeMethodDescriptionCompletableFuture<org.apache.hadoop.hbase.replication.ReplicationPeerConfig>
AsyncAdmin.getReplicationPeerConfig
(String peerId) Returns the configured ReplicationPeerConfig for the specified peerModifier and TypeMethodDescriptiondefault void
Admin.addReplicationPeer
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) Add a new replication peer for replicating data to slave cluster.default void
Admin.addReplicationPeer
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled) Add a new replication peer for replicating data to slave cluster.default CompletableFuture<Void>
AsyncAdmin.addReplicationPeer
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) Add a new replication peer for replicating data to slave clusterAsyncAdmin.addReplicationPeer
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled) Add a new replication peer for replicating data to slave clusterAdmin.addReplicationPeerAsync
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) Add a new replication peer but does not block and wait for it.Admin.addReplicationPeerAsync
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled) Add a new replication peer but does not block and wait for it.default void
Admin.updateReplicationPeerConfig
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) Update the peerConfig for the specified peer.AsyncAdmin.updateReplicationPeerConfig
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) Update the peerConfig for the specified peerAdmin.updateReplicationPeerConfigAsync
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) Update the peerConfig for the specified peer but does not block and wait for it. -
Uses of org.apache.hadoop.hbase.replication.ReplicationPeerConfig in org.apache.hadoop.hbase.client.replication
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerConfigUtil.appendExcludeTableCFsToReplicationPeerConfig
(Map<org.apache.hadoop.hbase.TableName, List<String>> excludeTableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) static org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerConfigUtil.appendTableCFsToReplicationPeerConfig
(Map<org.apache.hadoop.hbase.TableName, List<String>> tableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) static org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerConfigUtil.convert
(org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.ReplicationPeer peer) static org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerConfigUtil.parsePeerFrom
(byte[] bytes) Parse the serialized representation of a peer configuration.static org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerConfigUtil.removeExcludeTableCFsFromReplicationPeerConfig
(Map<org.apache.hadoop.hbase.TableName, List<String>> excludeTableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, String id) static org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerConfigUtil.removeTableCFsFromReplicationPeerConfig
(Map<org.apache.hadoop.hbase.TableName, List<String>> tableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, String id) static org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerConfigUtil.updateReplicationBasePeerConfigs
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.replication.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 TypeMethodDescriptionstatic org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerConfigUtil.appendExcludeTableCFsToReplicationPeerConfig
(Map<org.apache.hadoop.hbase.TableName, List<String>> excludeTableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) static org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerConfigUtil.appendTableCFsToReplicationPeerConfig
(Map<org.apache.hadoop.hbase.TableName, List<String>> tableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) static org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.ReplicationPeer
ReplicationPeerConfigUtil.convert
(org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) static org.apache.hadoop.conf.Configuration
ReplicationPeerConfigUtil.getPeerClusterConfiguration
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) Returns the configuration needed to talk to the remote slave cluster.static org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerConfigUtil.removeExcludeTableCFsFromReplicationPeerConfig
(Map<org.apache.hadoop.hbase.TableName, List<String>> excludeTableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, String id) static org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerConfigUtil.removeTableCFsFromReplicationPeerConfig
(Map<org.apache.hadoop.hbase.TableName, List<String>> tableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, String id) static byte[]
ReplicationPeerConfigUtil.toByteArray
(org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) Returns Serialized protobuf ofpeerConfig
with pb magic prefix prepended suitable for use as content of a this.peersZNode; i.e.static org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerConfigUtil.updateReplicationBasePeerConfigs
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.replication.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 org.apache.hadoop.hbase.replication.ReplicationPeerConfig in org.apache.hadoop.hbase.coprocessor
Modifier and TypeMethodDescriptiondefault void
MasterObserver.postAddReplicationPeer
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) Called after add a replication peerdefault void
MasterObserver.postUpdateReplicationPeerConfig
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) Called after update peerConfig for the specified peerdefault void
MasterObserver.preAddReplicationPeer
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) Called before add a replication peerdefault void
MasterObserver.preUpdateReplicationPeerConfig
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) Called before update peerConfig for the specified peer -
Uses of org.apache.hadoop.hbase.replication.ReplicationPeerConfig in org.apache.hadoop.hbase.master
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.replication.ReplicationPeerConfig
HMaster.getReplicationPeerConfig
(String peerId) org.apache.hadoop.hbase.replication.ReplicationPeerConfig
MasterServices.getReplicationPeerConfig
(String peerId) Returns the configured ReplicationPeerConfig for the specified peerModifier and TypeMethodDescriptionlong
HMaster.addReplicationPeer
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled) long
MasterServices.addReplicationPeer
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled) Add a new replication peer for replicating data to slave clustervoid
MasterCoprocessorHost.postAddReplicationPeer
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) void
MasterCoprocessorHost.postUpdateReplicationPeerConfig
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) void
MasterCoprocessorHost.preAddReplicationPeer
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) void
MasterCoprocessorHost.preUpdateReplicationPeerConfig
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) long
HMaster.updateReplicationPeerConfig
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) long
MasterServices.updateReplicationPeerConfig
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) Update the peerConfig for the specified peer -
Uses of org.apache.hadoop.hbase.replication.ReplicationPeerConfig in org.apache.hadoop.hbase.replication
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerConfigBuilder.build()
Builds the configuration object from the current state ofthis
.org.apache.hadoop.hbase.replication.ReplicationPeerConfig
FSReplicationPeerStorage.getPeerConfig
(String peerId) org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationEndpoint.Context.getPeerConfig()
org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeer.getPeerConfig()
Get the peer config objectorg.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerDescription.getPeerConfig()
org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerImpl.getPeerConfig()
org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerStorage.getPeerConfig
(String peerId) Get the peer config of a replication peer.org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ZKReplicationPeerStorage.getPeerConfig
(String peerId) org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeers.refreshPeerConfig
(String peerId) Modifier and TypeMethodDescriptionvoid
FSReplicationPeerStorage.addPeer
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled, org.apache.hadoop.hbase.replication.SyncReplicationState syncReplicationState) void
ReplicationPeerStorage.addPeer
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled, org.apache.hadoop.hbase.replication.SyncReplicationState syncReplicationState) Add a replication peer.void
ZKReplicationPeerStorage.addPeer
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled, org.apache.hadoop.hbase.replication.SyncReplicationState syncReplicationState) static boolean
ReplicationUtils.isNamespacesAndTableCFsEqual
(org.apache.hadoop.hbase.replication.ReplicationPeerConfig rpc1, org.apache.hadoop.hbase.replication.ReplicationPeerConfig rpc2) static org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilder
ReplicationPeerConfig.newBuilder
(org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) void
BaseReplicationEndpoint.peerConfigUpdated
(org.apache.hadoop.hbase.replication.ReplicationPeerConfig rpc) void
ReplicationPeerConfigListener.peerConfigUpdated
(org.apache.hadoop.hbase.replication.ReplicationPeerConfig rpc) Callback method for when users update the ReplicationPeerConfig for this peervoid
ReplicationPeerImpl.setPeerConfig
(org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) void
FSReplicationPeerStorage.updatePeerConfig
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) void
ReplicationPeerStorage.updatePeerConfig
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) Update the config a replication peer.void
ZKReplicationPeerStorage.updatePeerConfig
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) ModifierConstructorDescriptionReplicationPeerDescription
(String id, boolean enabled, org.apache.hadoop.hbase.replication.ReplicationPeerConfig config, org.apache.hadoop.hbase.replication.SyncReplicationState syncReplicationState) ReplicationPeerImpl
(org.apache.hadoop.conf.Configuration conf, String id, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean peerState, org.apache.hadoop.hbase.replication.SyncReplicationState syncReplicationState, org.apache.hadoop.hbase.replication.SyncReplicationState newSyncReplicationState) Constructor that takes all the objects required to communicate with the specified peer, except for the region server addresses. -
Uses of org.apache.hadoop.hbase.replication.ReplicationPeerConfig in org.apache.hadoop.hbase.shaded.protobuf
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.AddReplicationPeerRequest
RequestConverter.buildAddReplicationPeerRequest
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled) static org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.UpdateReplicationPeerConfigRequest
RequestConverter.buildUpdateReplicationPeerConfigRequest
(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig)