Package org.apache.hadoop.hbase.replication

Examples of org.apache.hadoop.hbase.replication.ReplicationZookeeperWrapper$ReplicationStatusWatcher


    this.conf = conf;
    this.stopRequested = stopRequested;
    this.replication =
        conf.getBoolean(HConstants.REPLICATION_ENABLE_KEY, false);
    if (replication) {
      this.zkHelper = new ReplicationZookeeperWrapper(
        ZooKeeperWrapper.createInstance(conf, hsi.getServerName()), conf,
        this.replicating, hsi.getServerName());
      this.replicationMaster = zkHelper.isReplicationMaster();
      this.replicationManager = this.replicationMaster ?
        new ReplicationSourceManager(zkHelper, conf, stopRequested,
View Full Code Here


  @Override
  public void setConf(Configuration conf) {
    this.conf = conf;
    try {
      this.zkHelper = new ReplicationZookeeperWrapper(
          ZooKeeperWrapper.createInstance(this.conf,
              HMaster.class.getName()),
          this.conf, new AtomicBoolean(true), null);
    } catch (IOException e) {
      LOG.error(e);
View Full Code Here

   * @throws java.lang.Exception
   */
  @Before
  public void setUp() throws Exception {
    Configuration conf = TEST_UTIL.getConfiguration();
    zkHelper = new ReplicationZookeeperWrapper(
        ZooKeeperWrapper.createInstance(conf, HRegionServer.class.getName()),
        conf, new AtomicBoolean(true), "test-cluster");
  }
View Full Code Here

    zkw.writeZNode("/hbase/replication/peers", "1",
          conf.get(HConstants.ZOOKEEPER_QUORUM)+":" +
          conf.get("hbase.zookeeper.property.clientPort")+":/1");

    HRegionServer server = new HRegionServer(conf);
    ReplicationZookeeperWrapper helper = new ReplicationZookeeperWrapper(
        server.getZooKeeperWrapper(), conf,
        REPLICATING, "123456789");
    fs = FileSystem.get(conf);
    oldLogDir = new Path(utility.getTestDir(),
        HConstants.HREGION_OLDLOGDIR_NAME);
View Full Code Here

  public void setConf(Configuration conf) {
    this.conf = conf;
    this.ttlCleaner = new TimeToLiveLogCleaner();
    this.ttlCleaner.setConf(conf);
    try {
      this.zkHelper = new ReplicationZookeeperWrapper(
          ZooKeeperWrapper.createInstance(this.conf,
              HMaster.class.getName()),
          this.conf, new AtomicBoolean(true), null);
    } catch (IOException e) {
      LOG.error(e);
View Full Code Here

    this.conf = conf;
    this.stopRequested = stopRequested;
    this.replication =
        conf.getBoolean(HConstants.REPLICATION_ENABLE_KEY, false);
    if (replication) {
      this.zkHelper = new ReplicationZookeeperWrapper(
        ZooKeeperWrapper.getInstance(conf, hsi.getServerName()), conf,
        this.replicating, hsi.getServerName());
      this.replicationMaster = zkHelper.isReplicationMaster();
      this.replicationManager = this.replicationMaster ?
        new ReplicationSourceManager(zkHelper, conf, stopRequested,
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hbase.replication.ReplicationZookeeperWrapper$ReplicationStatusWatcher

Copyright © 2018 www.massapicom. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.