Uses of Enum Class
org.apache.hadoop.hbase.replication.SyncReplicationState
Packages that use org.apache.hadoop.hbase.replication.SyncReplicationState
Package
Description
Provides HBase Client
Table of Contents
Multi Cluster Replication
-
Uses of org.apache.hadoop.hbase.replication.SyncReplicationState in org.apache.hadoop.hbase.client
Methods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.replication.SyncReplicationState in inModifier and TypeMethodDescriptiondefault org.apache.hadoop.hbase.replication.SyncReplicationState
Admin.getReplicationPeerSyncReplicationState
(String peerId) Get the current cluster state in a synchronous replication peer.Methods in org.apache.hadoop.hbase.client that return types with arguments of type org.apache.hadoop.hbase.replication.SyncReplicationState in inModifier and TypeMethodDescriptiondefault CompletableFuture<org.apache.hadoop.hbase.replication.SyncReplicationState>
AsyncAdmin.getReplicationPeerSyncReplicationState
(String peerId) Get the current cluster state in a synchronous replication peer.Methods in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.replication.SyncReplicationState in inModifier and TypeMethodDescriptiondefault void
Admin.transitReplicationPeerSyncReplicationState
(String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState state) Transit current cluster to a new state in a synchronous replication peer.AsyncAdmin.transitReplicationPeerSyncReplicationState
(String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState state) Transit current cluster to a new state in a synchronous replication peer.Admin.transitReplicationPeerSyncReplicationStateAsync
(String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState state) Transit current cluster to a new state in a synchronous replication peer. -
Uses of org.apache.hadoop.hbase.replication.SyncReplicationState in org.apache.hadoop.hbase.client.replication
Methods in org.apache.hadoop.hbase.client.replication that return org.apache.hadoop.hbase.replication.SyncReplicationState in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.replication.SyncReplicationState
ReplicationPeerConfigUtil.toSyncReplicationState
(org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.SyncReplicationState state) Methods in org.apache.hadoop.hbase.client.replication with parameters of type org.apache.hadoop.hbase.replication.SyncReplicationState in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.SyncReplicationState
ReplicationPeerConfigUtil.toSyncReplicationState
(org.apache.hadoop.hbase.replication.SyncReplicationState state) -
Uses of org.apache.hadoop.hbase.replication.SyncReplicationState in org.apache.hadoop.hbase.coprocessor
Methods in org.apache.hadoop.hbase.coprocessor with parameters of type org.apache.hadoop.hbase.replication.SyncReplicationState in inModifier and TypeMethodDescriptiondefault void
MasterObserver.postTransitReplicationPeerSyncReplicationState
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState from, org.apache.hadoop.hbase.replication.SyncReplicationState to) Called after transit current cluster state for the specified synchronous replication peerdefault void
MasterObserver.preTransitReplicationPeerSyncReplicationState
(org.apache.hadoop.hbase.coprocessor.ObserverContext<org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment> ctx, String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState state) Called before transit current cluster state for the specified synchronous replication peer -
Uses of org.apache.hadoop.hbase.replication.SyncReplicationState in org.apache.hadoop.hbase.master
Methods in org.apache.hadoop.hbase.master with parameters of type org.apache.hadoop.hbase.replication.SyncReplicationState in inModifier and TypeMethodDescriptionvoid
MasterCoprocessorHost.postTransitReplicationPeerSyncReplicationState
(String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState from, org.apache.hadoop.hbase.replication.SyncReplicationState to) void
MasterCoprocessorHost.preTransitReplicationPeerSyncReplicationState
(String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState state) long
HMaster.transitReplicationPeerSyncReplicationState
(String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState state) long
MasterServices.transitReplicationPeerSyncReplicationState
(String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState clusterState) Set current cluster state for a synchronous replication peer. -
Uses of org.apache.hadoop.hbase.replication.SyncReplicationState in org.apache.hadoop.hbase.replication
Methods in org.apache.hadoop.hbase.replication that return org.apache.hadoop.hbase.replication.SyncReplicationState in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.replication.SyncReplicationState
ReplicationPeerImpl.getNewSyncReplicationState()
org.apache.hadoop.hbase.replication.SyncReplicationState
FSReplicationPeerStorage.getPeerNewSyncReplicationState
(String peerId) org.apache.hadoop.hbase.replication.SyncReplicationState
ReplicationPeerStorage.getPeerNewSyncReplicationState
(String peerId) Get the new sync replication state.org.apache.hadoop.hbase.replication.SyncReplicationState
ZKReplicationPeerStorage.getPeerNewSyncReplicationState
(String peerId) org.apache.hadoop.hbase.replication.SyncReplicationState
FSReplicationPeerStorage.getPeerSyncReplicationState
(String peerId) org.apache.hadoop.hbase.replication.SyncReplicationState
ReplicationPeerStorage.getPeerSyncReplicationState
(String peerId) Get the sync replication state.org.apache.hadoop.hbase.replication.SyncReplicationState
ZKReplicationPeerStorage.getPeerSyncReplicationState
(String peerId) org.apache.hadoop.hbase.replication.SyncReplicationState
ReplicationPeer.getSyncReplicationState()
Returns the sync replication state of the peer by reading local cache.org.apache.hadoop.hbase.replication.SyncReplicationState
ReplicationPeerDescription.getSyncReplicationState()
org.apache.hadoop.hbase.replication.SyncReplicationState
ReplicationPeerImpl.getSyncReplicationState()
static org.apache.hadoop.hbase.replication.SyncReplicationState
SyncReplicationState.parseFrom
(byte[] bytes) org.apache.hadoop.hbase.replication.SyncReplicationState
ReplicationPeers.refreshPeerNewSyncReplicationState
(String peerId) static org.apache.hadoop.hbase.replication.SyncReplicationState
SyncReplicationState.valueOf
(int value) static org.apache.hadoop.hbase.replication.SyncReplicationState
SyncReplicationState.valueOf
(String name) static org.apache.hadoop.hbase.replication.SyncReplicationState[]
SyncReplicationState.values()
Methods in org.apache.hadoop.hbase.replication that return types with arguments of type org.apache.hadoop.hbase.replication.SyncReplicationState in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.replication.SyncReplicationState,
org.apache.hadoop.hbase.replication.SyncReplicationState> ReplicationPeerImpl.getSyncReplicationStateAndNewState()
org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.replication.SyncReplicationState,
org.apache.hadoop.hbase.replication.SyncReplicationState> ReplicationPeerImpl.getSyncReplicationStateAndNewState()
static org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.replication.SyncReplicationState,
org.apache.hadoop.hbase.replication.SyncReplicationState> SyncReplicationState.parseStateAndNewStateFrom
(byte[] bytes) static org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.replication.SyncReplicationState,
org.apache.hadoop.hbase.replication.SyncReplicationState> SyncReplicationState.parseStateAndNewStateFrom
(byte[] bytes) Methods in org.apache.hadoop.hbase.replication with parameters of type org.apache.hadoop.hbase.replication.SyncReplicationState in inModifier 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) void
ReplicationPeerImpl.setNewSyncReplicationState
(org.apache.hadoop.hbase.replication.SyncReplicationState newState) void
FSReplicationPeerStorage.setPeerNewSyncReplicationState
(String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState newState) void
ReplicationPeerStorage.setPeerNewSyncReplicationState
(String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState state) Set the new sync replication state that we are going to transit to.void
ZKReplicationPeerStorage.setPeerNewSyncReplicationState
(String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState state) static byte[]
SyncReplicationState.toByteArray
(org.apache.hadoop.hbase.replication.SyncReplicationState state) static byte[]
SyncReplicationState.toByteArray
(org.apache.hadoop.hbase.replication.SyncReplicationState state, org.apache.hadoop.hbase.replication.SyncReplicationState newState) Constructors in org.apache.hadoop.hbase.replication with parameters of type org.apache.hadoop.hbase.replication.SyncReplicationState in inModifierConstructorDescriptionReplicationPeerDescription
(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.SyncReplicationState in org.apache.hadoop.hbase.shaded.protobuf
Methods in org.apache.hadoop.hbase.shaded.protobuf with parameters of type org.apache.hadoop.hbase.replication.SyncReplicationState in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.ReplicationProtos.TransitReplicationPeerSyncReplicationStateRequest
RequestConverter.buildTransitReplicationPeerSyncReplicationStateRequest
(String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState state) -
Uses of org.apache.hadoop.hbase.replication.SyncReplicationState in org.apache.hadoop.hbase.wal
Methods in org.apache.hadoop.hbase.wal with parameters of type org.apache.hadoop.hbase.replication.SyncReplicationState in inModifier and TypeMethodDescriptionvoid
AbstractWALProvider.peerSyncReplicationStateChange
(String peerId, org.apache.hadoop.hbase.replication.SyncReplicationState from, org.apache.hadoop.hbase.replication.SyncReplicationState to, int stage)