Package org.apache.hadoop.hdfs.server.namenode.bookkeeper.zk

Examples of org.apache.hadoop.hdfs.server.namenode.bookkeeper.zk.BasicZooKeeper


      throw new IllegalStateException(e); // never reached
    } catch (InterruptedException e) {
      interruptedException("Interrupted creating a BookKeeper client", e);
      throw new IllegalStateException(e); // never reached
    }
    zk = new RecoveringZooKeeper(new BasicZooKeeper(zooKeeper), zkMaxRetries,
        zkRetryIntervalMs);
    metadataManager = new BookKeeperJournalMetadataManager(zk, zkParentPath);
    maxTxId = new MaxTxId(zk, maxTxIdPath);
    currentInProgressMetadata = new CurrentInProgressMetadata(zk,
        currentInProgressPath);
View Full Code Here


    createAndStartBookKeeperCluster();
    zooKeeperClient = bookKeeperCluster.initZK();
    bookKeeperClient = new BookKeeper(new ClientConfiguration(),
        zooKeeperClient);
    recoveringZooKeeperClient = new RecoveringZooKeeper(
        new BasicZooKeeper(zooKeeperClient), MAX_ZK_RETRIES, ZK_RETRY_MS);
  }
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hdfs.server.namenode.bookkeeper.zk.BasicZooKeeper

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.