Package org.apache.hadoop.yarn.api.records.impl.pb

Examples of org.apache.hadoop.yarn.api.records.impl.pb.ContainerIdPBImpl


    }
    viaProto = false;
  }

  private ContainerIdPBImpl convertFromProtoFormat(ContainerIdProto p) {
    return new ContainerIdPBImpl(p);
  }
View Full Code Here


    this.queryTaskContext = queryTaskContext;
  }

  @Override
  public ContainerId makeContainerId(YarnProtos.ContainerIdProto containerId) {
    return new ContainerIdPBImpl(containerId);
  }
View Full Code Here

    result.setAttemptId(1);
    return result;
  }

  private ContainerId getContainerId(int containerID, int appAttemptId) {
    ContainerIdPBImpl containerId = new ContainerIdPBImpl();
    containerId.setId(containerID);
    containerId.setApplicationAttemptId(getApplicationAttemptId(appAttemptId));
    return containerId;
  }
View Full Code Here

    taId.setId(0);
    taId.setTaskId(task.getID());
    when(attempt.getID()).thenReturn(taId);
    when(attempt.getNodeHttpAddress()).thenReturn("Node address");

    ContainerId containerId = new ContainerIdPBImpl();
    containerId.setId(1);
    ApplicationAttemptId appAId = new ApplicationAttemptIdPBImpl();
    appAId.setAttemptId(1);
    ApplicationId appId = new ApplicationIdPBImpl();
    appId.setClusterTimestamp(System.currentTimeMillis());
    appId.setId(5);
    appAId.setApplicationId(appId);
    containerId.setApplicationAttemptId(appAId);
    when(attempt.getAssignedContainerID()).thenReturn(containerId);

    when(attempt.getAssignedContainerMgrAddress()).thenReturn(
            "assignedContainerMgrAddress");
    when(attempt.getNodeRackName()).thenReturn("nodeRackName");
View Full Code Here

    return aggregatedBlock;
  }

  private void writeLog(Configuration configuration, String user)
      throws Exception {
    ContainerId containerId = new ContainerIdPBImpl();
    ApplicationAttemptId appAttemptId = new ApplicationAttemptIdPBImpl();
    ApplicationId appId = new ApplicationIdPBImpl();
    appId.setId(1);
    appAttemptId.setApplicationId(appId);
    appAttemptId.setAttemptId(1);
    containerId.setApplicationAttemptId(appAttemptId);
    containerId.setId(1);
    String path = "target/logs/" + user
        + "/logs/application_0_0001/localhost_1234";
    File f = new File(path);
    if (!f.getParentFile().exists()) {
     assertTrue(f.getParentFile().mkdirs());
View Full Code Here

    this.queryTaskContext = queryTaskContext;
  }

  @Override
  public ContainerId makeContainerId(YarnProtos.ContainerIdProto containerId) {
    return new ContainerIdPBImpl(containerId);
  }
View Full Code Here

  private ResourceRequestProto convertToProtoFormat(ResourceRequest t) {
    return ((ResourceRequestPBImpl)t).getProto();
  }

  private ContainerIdPBImpl convertFromProtoFormat(ContainerIdProto p) {
    return new ContainerIdPBImpl(p);
  }
View Full Code Here

    initApplicationsToCleanup();
    this.applicationsToCleanup.clear();
  }

  private ContainerIdPBImpl convertFromProtoFormat(ContainerIdProto p) {
    return new ContainerIdPBImpl(p);
  }
View Full Code Here

    return ((ContainerIdPBImpl) containerId).getProto();
  }

  private ContainerIdPBImpl
      convertFromProtoFormat(ContainerIdProto containerId) {
    return new ContainerIdPBImpl(containerId);
  }
View Full Code Here

    return ((ContainerIdPBImpl) containerId).getProto();
  }

  private ContainerIdPBImpl
      convertFromProtoFormat(ContainerIdProto containerId) {
    return new ContainerIdPBImpl(containerId);
  }
View Full Code Here

TOP

Related Classes of org.apache.hadoop.yarn.api.records.impl.pb.ContainerIdPBImpl

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.