Package org.apache.hadoop.hdfs.server.protocol

Examples of org.apache.hadoop.hdfs.server.protocol.RemoteEditLogManifest


      // And then start looking from after that point
      curStartTxId = bestLog.getEndTxId() + 1;
      if (curStartTxId == 0)
        break;
    }
    RemoteEditLogManifest ret = new RemoteEditLogManifest(logs);
   
    if (LOG.isDebugEnabled()) {
      LOG.debug("Generated manifest for logs since " + fromTxId + ":"
          + ret);     
    }
View Full Code Here


    final PriorityQueue<EditLogInputStream> allStreams =
        new PriorityQueue<EditLogInputStream>(64,
            JournalSet.EDIT_LOG_INPUT_STREAM_COMPARATOR);
    for (Map.Entry<AsyncLogger, RemoteEditLogManifest> e : resps.entrySet()) {
      AsyncLogger logger = e.getKey();
      RemoteEditLogManifest manifest = e.getValue();
     
      for (RemoteEditLog remoteLog : manifest.getLogs()) {
        EditLogInputStream elis = new URLLogInputStream(logger,
            remoteLog.getStartTxId(), httpConnectReadTimeoutMs);
        if (elis.isInProgress() && !inProgressOk) {
          continue;
        }
View Full Code Here

        GetEditLogManifestResponseProto ret = getProxy().getEditLogManifest(
            journalIdBytes, fromTxnId);
        // Update the http port, since we need this to build URLs to any of the
        // returned logs.
        httpPort = ret.getHttpPort();
        return new RemoteEditLogManifest(ret.getLogs());
      }
    });
  }
View Full Code Here

      throws IOException {
    // No need to checkRequest() here - anyone may ask for the list
    // of segments.
    checkJournalStorageFormatted();
   
    RemoteEditLogManifest manifest = fjm.getEditLogManifest(sinceTxId);
    return manifest;
  }
View Full Code Here

        throw new IOException("Asked for firstTxId " + firstTxId
            + " which is in the middle of file " + elf.file);
      }
    }
    Collections.sort(ret);
    return new RemoteEditLogManifest(ret);
  }
View Full Code Here

    }

    // error simulation code for junit test
    InjectionHandler.processEventIO(InjectionEvent.SECONDARYNAMENODE_CHECKPOINT0);

    RemoteEditLogManifest manifest = namenode
        .getEditLogManifest(sig.mostRecentCheckpointTxId + 1);

    boolean loadImage = downloadCheckpointFiles(fsName, checkpointImage, sig,
        manifest); // Fetch fsimage and edits
    doMerge(sig, manifest, loadImage, checkpointImage);
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hdfs.server.protocol.RemoteEditLogManifest

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.