Uses of Class
org.apache.hadoop.hbase.replication.ReplicationPeerDescription
Packages that use ReplicationPeerDescription
Package
Description
Provides HBase Client
-
Uses of ReplicationPeerDescription in org.apache.hadoop.hbase.client
Methods in org.apache.hadoop.hbase.client that return types with arguments of type ReplicationPeerDescriptionModifier and TypeMethodDescriptionAdmin.listReplicationPeers()
Return a list of replication peers.Admin.listReplicationPeers
(Pattern pattern) Return a list of replication peers.AdminOverAsyncAdmin.listReplicationPeers()
AdminOverAsyncAdmin.listReplicationPeers
(Pattern pattern) AsyncAdmin.listReplicationPeers()
Return a list of replication peers.AsyncAdmin.listReplicationPeers
(Pattern pattern) Return a list of replication peers.AsyncHBaseAdmin.listReplicationPeers()
AsyncHBaseAdmin.listReplicationPeers
(Pattern pattern) RawAsyncHBaseAdmin.listReplicationPeers()
RawAsyncHBaseAdmin.listReplicationPeers
(Pattern pattern) private CompletableFuture<List<ReplicationPeerDescription>>
RawAsyncHBaseAdmin.listReplicationPeers
(org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.ListReplicationPeersRequest request) Methods in org.apache.hadoop.hbase.client with parameters of type ReplicationPeerDescriptionModifier and TypeMethodDescriptionprivate CompletableFuture<Void>
RawAsyncHBaseAdmin.compareTableWithPeerCluster
(TableName tableName, TableDescriptor tableDesc, ReplicationPeerDescription peer, AsyncAdmin peerAdmin) private CompletableFuture<Void>
RawAsyncHBaseAdmin.trySyncTableToPeerCluster
(TableName tableName, byte[][] splits, ReplicationPeerDescription peer) -
Uses of ReplicationPeerDescription in org.apache.hadoop.hbase.client.replication
Methods in org.apache.hadoop.hbase.client.replication that return ReplicationPeerDescriptionModifier and TypeMethodDescriptionstatic ReplicationPeerDescription
ReplicationPeerConfigUtil.toReplicationPeerDescription
(org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.ReplicationPeerDescription desc) Methods in org.apache.hadoop.hbase.client.replication with parameters of type ReplicationPeerDescriptionModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.ReplicationPeerDescription
ReplicationPeerConfigUtil.toProtoReplicationPeerDescription
(ReplicationPeerDescription desc) -
Uses of ReplicationPeerDescription in org.apache.hadoop.hbase.master
Methods in org.apache.hadoop.hbase.master that return types with arguments of type ReplicationPeerDescriptionModifier and TypeMethodDescriptionHMaster.listReplicationPeers
(String regex) MasterServices.listReplicationPeers
(String regex) Return a list of replication peers. -
Uses of ReplicationPeerDescription in org.apache.hadoop.hbase.master.replication
Fields in org.apache.hadoop.hbase.master.replication with type parameters of type ReplicationPeerDescriptionModifier and TypeFieldDescriptionprivate final ConcurrentMap<String,
ReplicationPeerDescription> ReplicationPeerManager.peers
Methods in org.apache.hadoop.hbase.master.replication that return ReplicationPeerDescriptionModifier and TypeMethodDescriptionprivate ReplicationPeerDescription
ReplicationPeerManager.checkPeerExists
(String peerId) (package private) ReplicationPeerDescription
ReplicationPeerManager.preTransitPeerSyncReplicationState
(String peerId, SyncReplicationState state) Returns the old desciption of the peer(package private) ReplicationPeerDescription
ReplicationPeerManager.preUpdatePeerConfig
(String peerId, ReplicationPeerConfig peerConfig) Return the old peer description.Methods in org.apache.hadoop.hbase.master.replication that return types with arguments of type ReplicationPeerDescriptionModifier and TypeMethodDescriptionConstructor parameters in org.apache.hadoop.hbase.master.replication with type arguments of type ReplicationPeerDescriptionModifierConstructorDescription(package private)
ReplicationPeerManager
(org.apache.hadoop.fs.FileSystem fs, ZKWatcher zk, ReplicationPeerStorage peerStorage, ReplicationQueueStorage queueStorage, ConcurrentMap<String, ReplicationPeerDescription> peers, org.apache.hadoop.conf.Configuration conf, String clusterId, ReplicationPeerManager.ReplicationQueueStorageInitializer queueStorageInitializer) -
Uses of ReplicationPeerDescription in org.apache.hadoop.hbase.replication.regionserver
Method parameters in org.apache.hadoop.hbase.replication.regionserver with type arguments of type ReplicationPeerDescriptionModifier and TypeMethodDescriptionDumpReplicationQueues.dumpPeersState
(List<ReplicationPeerDescription> peers) -
Uses of ReplicationPeerDescription in org.apache.hadoop.hbase.thrift2.client
Methods in org.apache.hadoop.hbase.thrift2.client that return types with arguments of type ReplicationPeerDescriptionModifier and TypeMethodDescriptionThriftAdmin.listReplicationPeers()
ThriftAdmin.listReplicationPeers
(Pattern pattern)