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

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


  @Override
  public ListenableFuture<GetJournalStateResponseProto> getJournalState() {
    return executor.submit(new Callable<GetJournalStateResponseProto>() {
      @Override
      public GetJournalStateResponseProto call() throws IOException {
        GetJournalStateResponseProto ret =
            getProxy().getJournalState(journalId);
        constructHttpServerURI(ret);
        return ret;
      }
    });
View Full Code Here


      @Override
      public PrepareRecoveryResponseProto call() throws IOException {
        if (!hasHttpServerEndPoint()) {
          // force an RPC call so we know what the HTTP port should be if it
          // haven't done so.
          GetJournalStateResponseProto ret = getProxy().getJournalState(
              journalId);
          constructHttpServerURI(ret);
        }
        return getProxy().prepareRecovery(createReqInfo(), segmentTxId);
      }
View Full Code Here

  @Override
  public ListenableFuture<GetJournalStateResponseProto> getJournalState() {
    return executor.submit(new Callable<GetJournalStateResponseProto>() {
      @Override
      public GetJournalStateResponseProto call() throws IOException {
        GetJournalStateResponseProto ret =
            getProxy().getJournalState(journalId);
        httpPort = ret.getHttpPort();
        return ret;
      }
    });
  }
View Full Code Here

  @Override
  public ListenableFuture<GetJournalStateResponseProto> getJournalState() {
    return executor.submit(new Callable<GetJournalStateResponseProto>() {
      @Override
      public GetJournalStateResponseProto call() throws IOException {
        GetJournalStateResponseProto ret =
            getProxy().getJournalState(journalId);
        httpPort = ret.getHttpPort();
        return ret;
      }
    });
  }
View Full Code Here

  @Override
  public ListenableFuture<GetJournalStateResponseProto> getJournalState() {
    return executor.submit(new Callable<GetJournalStateResponseProto>() {
      @Override
      public GetJournalStateResponseProto call() throws IOException {
        GetJournalStateResponseProto ret =
            getProxy().getJournalState(journalId);
        httpPort = ret.getHttpPort();
        return ret;
      }
    });
  }
View Full Code Here

  @Override
  public ListenableFuture<GetJournalStateResponseProto> getJournalState() {
    return executor.submit(new Callable<GetJournalStateResponseProto>() {
      @Override
      public GetJournalStateResponseProto call() throws IOException {
        GetJournalStateResponseProto ret =
            getProxy().getJournalState(journalId);
        constructHttpServerURI(ret);
        return ret;
      }
    });
View Full Code Here

      @Override
      public PrepareRecoveryResponseProto call() throws IOException {
        if (!hasHttpServerEndPoint()) {
          // force an RPC call so we know what the HTTP port should be if it
          // haven't done so.
          GetJournalStateResponseProto ret = getProxy().getJournalState(
              journalId);
          constructHttpServerURI(ret);
        }
        return getProxy().prepareRecovery(createReqInfo(), segmentTxId);
      }
View Full Code Here

  @Override
  public GetJournalStateResponseProto getJournalState(byte[] journalId)
        throws IOException {
    long epoch = jn.getOrCreateJournal(journalId).getLastPromisedEpoch();
   
    GetJournalStateResponseProto ret = new GetJournalStateResponseProto();
    ret.setLastPromisedEpoch(epoch);
    ret.setHttpPort(jn.getBoundHttpAddress().getPort());
    return ret;
  }
View Full Code Here

        return spyLoggers;
      }
    };

    for (AsyncLogger logger : spyLoggers) {
      GetJournalStateResponseProto p = new GetJournalStateResponseProto();
      p.setLastPromisedEpoch(0);
      p.setHttpPort(-1);
      futureReturns(p)
        .when(logger).getJournalState();
     
      futureReturns(
          new NewEpochResponseProto()
View Full Code Here

  @Override
  public ListenableFuture<GetJournalStateResponseProto> getJournalState() {
    return executor.submit(new Callable<GetJournalStateResponseProto>() {
      @Override
      public GetJournalStateResponseProto call() throws IOException {
        GetJournalStateResponseProto ret =
            getProxy().getJournalState(journalIdBytes);
        httpPort = ret.getHttpPort();
        return ret;
      }
    });
  }
View Full Code Here

TOP

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

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.