Package org.apache.hadoop.hdfs.qjournal.protocol.QJournalProtocolProtos

Examples of org.apache.hadoop.hdfs.qjournal.protocol.QJournalProtocolProtos.GetImageManifestResponseProto


  }

  @Override
  public GetImageManifestResponseProto getImageManifest(byte[] jid,
      long sinceTxId) throws IOException {
    GetImageManifestResponseProto ret = new GetImageManifestResponseProto();
    ret.setImages(jn.getOrCreateJournal(jid).getImageManifest(sinceTxId)
        .getImages());
    return ret;
  }
View Full Code Here


  public ListenableFuture<RemoteImageManifest> getImageManifest(
      final long fromTxnId) {
    return executor.submit(new Callable<RemoteImageManifest>() {
      @Override
      public RemoteImageManifest call() throws IOException {
        GetImageManifestResponseProto ret = getProxy().getImageManifest(
            journalIdBytes, fromTxnId);
        return new RemoteImageManifest(ret.getImages());
      }
    });
  }
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hdfs.qjournal.protocol.QJournalProtocolProtos.GetImageManifestResponseProto

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.