Uses of Class
org.apache.hadoop.hbase.replication.ReplicationPeerConfig
Packages that use 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
Methods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.replication.ReplicationPeerConfig in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.replication.ReplicationPeerConfigAdmin.getReplicationPeerConfig(String peerId) Returns the configured ReplicationPeerConfig for the specified peer.org.apache.hadoop.hbase.replication.ReplicationPeerConfigHBaseAdmin.getReplicationPeerConfig(String peerId) Methods in org.apache.hadoop.hbase.client that return types with arguments of type org.apache.hadoop.hbase.replication.ReplicationPeerConfig in inModifier and TypeMethodDescriptionCompletableFuture<org.apache.hadoop.hbase.replication.ReplicationPeerConfig>AsyncAdmin.getReplicationPeerConfig(String peerId) Returns the configured ReplicationPeerConfig for the specified peerMethods in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.replication.ReplicationPeerConfig in inModifier and TypeMethodDescriptiondefault voidAdmin.addReplicationPeer(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) Add a new replication peer for replicating data to slave cluster.default voidAdmin.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.HBaseAdmin.addReplicationPeerAsync(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled) default voidAdmin.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.HBaseAdmin.updateReplicationPeerConfigAsync(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) -
Uses of org.apache.hadoop.hbase.replication.ReplicationPeerConfig in org.apache.hadoop.hbase.client.replication
Methods in org.apache.hadoop.hbase.client.replication that return org.apache.hadoop.hbase.replication.ReplicationPeerConfig in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerConfigUtil.appendExcludeTableCFsToReplicationPeerConfig(Map<org.apache.hadoop.hbase.TableName, List<String>> excludeTableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) static org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerConfigUtil.appendTableCFsToReplicationPeerConfig(Map<org.apache.hadoop.hbase.TableName, List<String>> tableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) static org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerConfigUtil.convert(org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.ReplicationPeer peer) org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationAdmin.getPeerConfig(String id) Deprecated.static org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerConfigUtil.parsePeerFrom(byte[] bytes) Parse the serialized representation of a peer configuration.static org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerConfigUtil.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.ReplicationPeerConfigReplicationPeerConfigUtil.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.ReplicationPeerConfigReplicationPeerConfigUtil.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 configurationReplicationPeerConfigwith peer configs provided as property hbase.replication.peer.base.configs in hbase configuration.Methods in org.apache.hadoop.hbase.client.replication that return types with arguments of type org.apache.hadoop.hbase.replication.ReplicationPeerConfig in inModifier and TypeMethodDescriptionReplicationAdmin.listPeerConfigs()Deprecated.useAdmin.listReplicationPeers()insteadMethods in org.apache.hadoop.hbase.client.replication with parameters of type org.apache.hadoop.hbase.replication.ReplicationPeerConfig in inModifier and TypeMethodDescriptionvoidReplicationAdmin.addPeer(String id, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) Deprecated.useAdmin.addReplicationPeer(String, ReplicationPeerConfig)insteadvoidReplicationAdmin.addPeer(String id, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, Map<org.apache.hadoop.hbase.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 org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerConfigUtil.appendExcludeTableCFsToReplicationPeerConfig(Map<org.apache.hadoop.hbase.TableName, List<String>> excludeTableCfs, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) static org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerConfigUtil.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.ReplicationPeerReplicationPeerConfigUtil.convert(org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) static org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerConfigUtil.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.ReplicationPeerConfigReplicationPeerConfigUtil.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 ofpeerConfigwith pb magic prefix prepended suitable for use as content of a this.peersZNode; i.e.voidReplicationAdmin.updatePeerConfig(String id, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) Deprecated.useAdmin.updateReplicationPeerConfig(String, ReplicationPeerConfig)insteadstatic org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerConfigUtil.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 configurationReplicationPeerConfigwith 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
Methods in org.apache.hadoop.hbase.coprocessor with parameters of type org.apache.hadoop.hbase.replication.ReplicationPeerConfig in inModifier and TypeMethodDescriptiondefault voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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 voidMasterObserver.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
Methods in org.apache.hadoop.hbase.master that return org.apache.hadoop.hbase.replication.ReplicationPeerConfig in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.replication.ReplicationPeerConfigHMaster.getReplicationPeerConfig(String peerId) org.apache.hadoop.hbase.replication.ReplicationPeerConfigMasterServices.getReplicationPeerConfig(String peerId) Returns the configured ReplicationPeerConfig for the specified peerMethods in org.apache.hadoop.hbase.master with parameters of type org.apache.hadoop.hbase.replication.ReplicationPeerConfig in inModifier and TypeMethodDescriptionlongHMaster.addReplicationPeer(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled) longMasterServices.addReplicationPeer(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled) Add a new replication peer for replicating data to slave clustervoidMasterCoprocessorHost.postAddReplicationPeer(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) voidMasterCoprocessorHost.postUpdateReplicationPeerConfig(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) voidMasterCoprocessorHost.preAddReplicationPeer(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) voidMasterCoprocessorHost.preUpdateReplicationPeerConfig(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) longHMaster.updateReplicationPeerConfig(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) longMasterServices.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
Methods in org.apache.hadoop.hbase.replication that return org.apache.hadoop.hbase.replication.ReplicationPeerConfig in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerConfigBuilder.build()Builds the configuration object from the current state ofthis.org.apache.hadoop.hbase.replication.ReplicationPeerConfigFSReplicationPeerStorage.getPeerConfig(String peerId) org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationEndpoint.Context.getPeerConfig()org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeer.getPeerConfig()Get the peer config objectorg.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerDescription.getPeerConfig()org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerImpl.getPeerConfig()Get the peer config objectorg.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerStorage.getPeerConfig(String peerId) Get the peer config of a replication peer.org.apache.hadoop.hbase.replication.ReplicationPeerConfigZKReplicationPeerStorage.getPeerConfig(String peerId) org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeers.refreshPeerConfig(String peerId) org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerConfig.setBandwidth(long bandwidth) Deprecated.as release of 2.0.0, and it will be removed in 3.0.0.org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerConfig.setClusterKey(String clusterKey) Deprecated.as release of 2.0.0, and it will be removed in 3.0.0.org.apache.hadoop.hbase.replication.ReplicationPeerConfigDeprecated.as release of 2.0.0, and it will be removed in 3.0.0.org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerConfig.setExcludeTableCFsMap(Map<org.apache.hadoop.hbase.TableName, ? extends Collection<String>> tableCFsMap) Deprecated.as release of 2.0.0, and it will be removed in 3.0.0.org.apache.hadoop.hbase.replication.ReplicationPeerConfigDeprecated.as release of 2.0.0, and it will be removed in 3.0.0.org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerConfig.setReplicateAllUserTables(boolean replicateAllUserTables) Deprecated.as release of 2.0.0, and it will be removed in 3.0.0.org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerConfig.setReplicationEndpointImpl(String replicationEndpointImpl) Deprecated.as release of 2.0.0, and it will be removed in 3.0.0.org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerConfig.setTableCFsMap(Map<org.apache.hadoop.hbase.TableName, ? extends Collection<String>> tableCFsMap) Deprecated.as release of 2.0.0, and it will be removed in 3.0.0.Methods in org.apache.hadoop.hbase.replication with parameters of type org.apache.hadoop.hbase.replication.ReplicationPeerConfig in inModifier and TypeMethodDescriptionvoidFSReplicationPeerStorage.addPeer(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled) voidReplicationPeerStorage.addPeer(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled) Add a replication peer.voidZKReplicationPeerStorage.addPeer(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled) static booleanReplicationUtils.contains(org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, org.apache.hadoop.hbase.TableName tableName) Deprecated.Will be removed in HBase 3.static org.apache.hadoop.conf.ConfigurationReplicationUtils.getPeerClusterConfiguration(org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, org.apache.hadoop.conf.Configuration baseConf) static booleanReplicationUtils.isNamespacesAndTableCFsEqual(org.apache.hadoop.hbase.replication.ReplicationPeerConfig rpc1, org.apache.hadoop.hbase.replication.ReplicationPeerConfig rpc2) static org.apache.hadoop.hbase.replication.ReplicationPeerConfigBuilderReplicationPeerConfig.newBuilder(org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) voidBaseReplicationEndpoint.peerConfigUpdated(org.apache.hadoop.hbase.replication.ReplicationPeerConfig rpc) voidReplicationPeerConfigListener.peerConfigUpdated(org.apache.hadoop.hbase.replication.ReplicationPeerConfig rpc) Callback method for when users update the ReplicationPeerConfig for this peervoidReplicationPeerImpl.setPeerConfig(org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) voidFSReplicationPeerStorage.updatePeerConfig(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) voidReplicationPeerStorage.updatePeerConfig(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) Update the config a replication peer.voidZKReplicationPeerStorage.updatePeerConfig(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) Constructors in org.apache.hadoop.hbase.replication with parameters of type org.apache.hadoop.hbase.replication.ReplicationPeerConfig in inModifierConstructorDescriptionReplicationPeerDescription(String id, boolean enabled, org.apache.hadoop.hbase.replication.ReplicationPeerConfig config) ReplicationPeerImpl(org.apache.hadoop.conf.Configuration conf, String id, boolean peerState, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig) 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
Methods in org.apache.hadoop.hbase.shaded.protobuf with parameters of type org.apache.hadoop.hbase.replication.ReplicationPeerConfig in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.AddReplicationPeerRequestRequestConverter.buildAddReplicationPeerRequest(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig, boolean enabled) static org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.UpdateReplicationPeerConfigRequestRequestConverter.buildUpdateReplicationPeerConfigRequest(String peerId, org.apache.hadoop.hbase.replication.ReplicationPeerConfig peerConfig)
Admin.getReplicationPeerConfig(String)instead