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, String clusterKey)
          Add a new peer cluster to replicate to.
 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.
 boolean ReplicationAdmin.getPeerState(String id)
          Get the state of the specified peer cluster
 void ReplicationAdmin.removePeer(String id)
          Removes a peer cluster and stops the replication to it.
 

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 ReplicationPeersZKImpl.addPeer(String id, String clusterKey)
           
 void ReplicationPeers.addPeer(String peerId, String clusterKey)
          Add a new remote slave cluster for replication.
 boolean ReplicationPeersZKImpl.connectToPeer(String peerId)
           
 boolean ReplicationPeers.connectToPeer(String peerId)
          Attempt to connect to a new remote slave cluster.
 void ReplicationPeersZKImpl.disablePeer(String id)
           
 void ReplicationPeers.disablePeer(String peerId)
          Stop the replication to the specified remote slave cluster.
 void ReplicationPeersZKImpl.enablePeer(String id)
           
 void ReplicationPeers.enablePeer(String peerId)
          Restart the replication to the specified remote slave cluster.
 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.
 org.apache.hadoop.conf.Configuration ReplicationPeersZKImpl.getPeerConf(String peerId)
           
 org.apache.hadoop.conf.Configuration ReplicationPeers.getPeerConf(String peerId)
          Returns the configuration needed to talk to the remote slave cluster.
 boolean ReplicationPeersZKImpl.getStatusOfPeerFromBackingStore(String id)
           
 boolean ReplicationPeers.getStatusOfPeerFromBackingStore(String peerId)
          Get the replication status for the specified remote slave cluster, which doesn't have to be connected.
 void ReplicationPeersZKImpl.init()
           
 void ReplicationQueuesClientZKImpl.init()
           
 void ReplicationPeers.init()
          Initialize the ReplicationPeers interface.
 void ReplicationQueuesClient.init()
          Initialize the replication queue client interface.
 void ReplicationQueuesZKImpl.init(String serverName)
           
 void ReplicationQueues.init(String serverName)
          Initialize the region server replication queue interface.
 void ReplicationPeersZKImpl.removePeer(String id)
           
 void ReplicationPeers.removePeer(String peerId)
          Removes a remote slave cluster and stops the replication to it.
 

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



Copyright © 2013 The Apache Software Foundation. All Rights Reserved.