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

Examples of org.apache.hadoop.hdfs.server.namenode.EditsDoubleBuffer$TxnBuffer


  public QuorumOutputStream(AsyncLoggerSet loggers,
      long txId, int outputBufferCapacity,
      int writeTimeoutMs) throws IOException {
    super();
    this.buf = new EditsDoubleBuffer(outputBufferCapacity);
    this.loggers = loggers;
    this.segmentTxId = txId;
    this.writeTimeoutMs = writeTimeoutMs;
  }
View Full Code Here


  public QuorumOutputStream(AsyncLoggerSet loggers,
      long txId, int outputBufferCapacity,
      int writeTimeoutMs) throws IOException {
    super();
    this.buf = new EditsDoubleBuffer(outputBufferCapacity);
    this.loggers = loggers;
    this.segmentTxId = txId;
    this.writeTimeoutMs = writeTimeoutMs;
  }
View Full Code Here

  public QuorumOutputStream(AsyncLoggerSet loggers,
      long txId, int outputBufferCapacity,
      int writeTimeoutMs) throws IOException {
    super();
    this.buf = new EditsDoubleBuffer(outputBufferCapacity);
    this.loggers = loggers;
    this.segmentTxId = txId;
    this.writeTimeoutMs = writeTimeoutMs;
  }
View Full Code Here

  public BookKeeperEditLogOutputStream(LedgerHandle ledger, String parentPath,
      NameNodeMetrics metrics) throws IOException {
    super();
    this.ledger = ledger;
    doubleBuf = new EditsDoubleBuffer(FSEditLog.sizeFlushBuffer);
    outputStream = new BookKeeperJournalOutputStream(ledger);
    if (metrics != null) { // Metrics is non-null only when used inside name node
      String metricsName = "sync_bk_" + parentPath + "_edit";
      MetricsBase retrMetrics = metrics.registry.get(metricsName);
      if (retrMetrics != null) {
View Full Code Here

  public QuorumOutputStream(AsyncLoggerSet loggers, long txId,
      int outputBufferCapacity, int writeTimeoutMs, NameNodeMetrics metrics, String journalId)
      throws IOException {
    super();
    this.buf = new EditsDoubleBuffer(outputBufferCapacity);
    this.loggers = loggers;
    this.segmentTxId = txId;
    this.writeTimeoutMs = writeTimeoutMs;
    this.journalId = journalId;
    if (metrics != null) { // Metrics is non-null only when used inside name node
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hdfs.server.namenode.EditsDoubleBuffer$TxnBuffer

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.