Uses of Class
org.apache.hadoop.hbase.replication.ReplicationException

Packages that use ReplicationException
org.apache.hadoop.hbase.client.replication   
org.apache.hadoop.hbase.replication   
 

Uses of ReplicationException in org.apache.hadoop.hbase.client.replication
 

Methods in org.apache.hadoop.hbase.client.replication that throw ReplicationException
 void ReplicationAdmin.addPeer(String id, ReplicationPeerConfig peerConfig, Map<TableName,? extends Collection<String>> tableCfs)
          Add a new remote slave cluster for replication.
 void ReplicationAdmin.addPeer(String id, String clusterKey)
          Deprecated. Use addPeer(String, ReplicationPeerConfig, Map) instead.
 void ReplicationAdmin.addPeer(String id, String clusterKey, String tableCFs)
          Deprecated. 
 void ReplicationAdmin.disablePeer(String id)
          Stop the replication stream to the specified peer.
 void ReplicationAdmin.enablePeer(String id)
          Restart the replication stream to the specified peer.
 ReplicationPeerConfig ReplicationAdmin.getPeerConfig(String id)
           
 boolean ReplicationAdmin.getPeerState(String id)
          Get the state of the specified peer cluster
 String ReplicationAdmin.getPeerTableCFs(String id)
          Get the replicable table-cf config of the specified peer.
 void ReplicationAdmin.removePeer(String id)
          Removes a peer cluster and stops the replication to it.
 void ReplicationAdmin.setPeerTableCFs(String id, Map<TableName,? extends Collection<String>> tableCfs)
          Set the replicable table-cf config of the specified peer
 void ReplicationAdmin.setPeerTableCFs(String id, String tableCFs)
          Deprecated. use ReplicationAdmin.setPeerTableCFs(String, Map)
 

Uses of ReplicationException in org.apache.hadoop.hbase.replication
 

Methods in org.apache.hadoop.hbase.replication that throw ReplicationException
 void ReplicationQueuesZKImpl.addLog(String queueId, String filename)
           
 void ReplicationQueues.addLog(String queueId, String filename)
          Add a new HLog file to the given queue.
 void ReplicationPeers.addPeer(String peerId, ReplicationPeerConfig peerConfig, String tableCFs)
          Add a new remote slave cluster for replication.
 void ReplicationPeersZKImpl.addPeer(String id, ReplicationPeerConfig peerConfig, String tableCFs)
           
 boolean ReplicationPeersZKImpl.createAndAddPeer(String peerId)
          Attempt to connect to a new remote slave cluster.
 void ReplicationPeers.disablePeer(String peerId)
          Stop the replication to the specified remote slave cluster.
 void ReplicationPeersZKImpl.disablePeer(String id)
           
 void ReplicationPeers.enablePeer(String peerId)
          Restart the replication to the specified remote slave cluster.
 void ReplicationPeersZKImpl.enablePeer(String id)
           
 long ReplicationQueuesZKImpl.getLogPosition(String queueId, String filename)
           
 long ReplicationQueues.getLogPosition(String queueId, String filename)
          Get the current position for a specific HLog in a given queue.
 Pair<ReplicationPeerConfig,org.apache.hadoop.conf.Configuration> ReplicationPeers.getPeerConf(String peerId)
          Returns the configuration needed to talk to the remote slave cluster.
 Pair<ReplicationPeerConfig,org.apache.hadoop.conf.Configuration> ReplicationPeersZKImpl.getPeerConf(String peerId)
           
 String ReplicationPeers.getPeerTableCFsConfig(String peerId)
          Get the table and column-family list string of the peer from ZK.
 String ReplicationPeersZKImpl.getPeerTableCFsConfig(String id)
           
 ReplicationPeerConfig ReplicationPeers.getReplicationPeerConfig(String peerId)
          Returns the configured ReplicationPeerConfig for this peerId
 ReplicationPeerConfig ReplicationPeersZKImpl.getReplicationPeerConfig(String peerId)
           
 boolean ReplicationPeers.getStatusOfPeerFromBackingStore(String peerId)
          Get the replication status for the specified remote slave cluster, which doesn't have to be connected.
 boolean ReplicationPeersZKImpl.getStatusOfPeerFromBackingStore(String id)
           
 void ReplicationQueuesClientZKImpl.init()
           
 void ReplicationPeers.init()
          Initialize the ReplicationPeers interface.
 void ReplicationQueuesClient.init()
          Initialize the replication queue client interface.
 void ReplicationPeersZKImpl.init()
           
 void ReplicationQueuesZKImpl.init(String serverName)
           
 void ReplicationQueues.init(String serverName)
          Initialize the region server replication queue interface.
 boolean ReplicationPeers.peerAdded(String peerId)
           
 boolean ReplicationPeersZKImpl.peerAdded(String peerId)
           
 void ReplicationPeers.removePeer(String peerId)
          Removes a remote slave cluster and stops the replication to it.
 void ReplicationPeersZKImpl.removePeer(String id)
           
 void ReplicationPeers.setPeerTableCFsConfig(String peerId, String tableCFs)
          Set the table and column-family list string of the peer to ZK.
 void ReplicationPeersZKImpl.setPeerTableCFsConfig(String id, String tableCFsStr)
           
 

Constructors in org.apache.hadoop.hbase.replication that throw ReplicationException
ReplicationPeerZKImpl(org.apache.hadoop.conf.Configuration conf, String id, ReplicationPeerConfig peerConfig)
          Constructor that takes all the objects required to communicate with the specified peer, except for the region server addresses.
 



Copyright © 2007-2015 The Apache Software Foundation. All Rights Reserved.