Examples of JobID


Examples of com.asakusafw.yaess.jobqueue.client.JobId

        JobScript job = convert(context, script);
        for (int i = 1, n = clients.count() * 2; i <= n; i++) {
            monitor.checkCancelled();
            JobClient client = clients.get();
            try {
                JobId id = registerWithTimeout(job, client);
                return new JobInfo(job, id, client);
            } catch (IOException e) {
                clients.setError(client);
                YSLOG.warn(e, "W01001",
                        job.getBatchId(),
View Full Code Here

Examples of com.asakusafw.yaess.jobqueue.client.JobId

                        job.getPhase(),
                        job.getExecutionId(),
                        job.getStageId(),
                        client);
                long start = System.currentTimeMillis();
                JobId id = client.register(job);
                long end = System.currentTimeMillis();
                YSLOG.info("I01002",
                        job.getBatchId(),
                        job.getFlowId(),
                        job.getPhase(),
View Full Code Here

Examples of com.asakusafw.yaess.jobqueue.client.JobId

        private final LinkedList<JobStatus> sequence;

        private volatile boolean submitted;

        public MockJobClient(String id, JobStatus.Kind... sequence) {
            this.jobId = id == null ? null : new JobId(id);
            this.sequence = new LinkedList<JobStatus>();
            for (JobStatus.Kind kind : sequence) {
                JobStatus result = new JobStatus();
                result.setKind(kind);
                result.setJobId(id == null ? "DUMMY" : id);
View Full Code Here

Examples of com.socrata.datasync.deltaimporter2.JobId

        String typicalBlobJson = "{\"blobId\":\"xxxx-xxxx\"}";
        BlobId id1 = mapper.readValue(typicalBlobJson, BlobId.class);
        TestCase.assertEquals("xxxx-xxxx", id1.blobId);

        String typicalJobJson = "{\"jobId\":\"yyyyyy\"}";
        JobId id2 = mapper.readValue(typicalJobJson, JobId.class);
        TestCase.assertEquals("yyyyyy", id2.jobId);

        String emptyJson = "{}";
        BlobId id3 = mapper.readValue(emptyJson, BlobId.class);
        JobId id4 = mapper.readValue(emptyJson, JobId.class);
        TestCase.assertNull(id3.blobId);
        TestCase.assertNull(id4.jobId);

        String extraStuffJson = "{\"blobId\":\"some-4by4\", \"junk\":0}";
        BlobId id5 = mapper.readValue(extraStuffJson, BlobId.class);
View Full Code Here

Examples of com.spotify.helios.common.descriptors.JobId

    try (final DockerClient dockerClient = getNewDockerClient()) {

      final List<String> command = asList("hostname", "-f");

      // Create job
      final JobId jobId = createJob(testJobName, testJobVersion, BUSYBOX, command);

      // deploy
      deployJob(jobId, testHost());

      final TaskStatus taskStatus = awaitTaskState(jobId, testHost(), EXITED);
View Full Code Here

Examples of edu.uci.ics.hyracks.api.job.JobId

                        DynamicContext dCtx = new DynamicContextImpl(compiler.getModule().getModuleContext());
                        spec.setGlobalJobDataFactory(new VXQueryGlobalDataFactory(dCtx.createFactory()));

                        spec.setMaxReattempts(0);
                        JobId jobId = hcc.startJob(spec, EnumSet.of(JobFlag.PROFILE_RUNTIME));

                        if (hds == null) {
                            hds = new HyracksDataset(hcc, spec.getFrameSize(), opts.threads);
                        }
                        ByteBuffer buffer = ByteBuffer.allocate(spec.getFrameSize());
View Full Code Here

Examples of eu.stratosphere.nephele.jobgraph.JobID

    }
  }

  @Test
  public void testFileReuseForNextTask() {
    JobID jobID = new JobID();
    String filePath = f.toURI().toString();
    fileCache.createTmpFile("test_file", filePath, jobID);
    try {
      Thread.sleep(1000);
    } catch (InterruptedException e) {
View Full Code Here

Examples of org.apache.flink.runtime.jobgraph.JobID

  /**
   * Constructor for serialization/deserialization. Should not be called on other occasions.
   */
  public RecentJobEvent() {
    super();
    this.jobID = new JobID();
  }
View Full Code Here

Examples of org.apache.hadoop.mapred.JobID

    @Override
    protected void processKill(String jobid) throws IOException
    {
        if (mJobConf != null) {
            JobClient jc = new JobClient(mJobConf);
            JobID id = JobID.forName(jobid);
            RunningJob job = jc.getJob(id);
            if (job == null)
                System.out.println("Job with id " + jobid + " is not active");
            else
            {   
View Full Code Here

Examples of org.apache.hadoop.mapreduce.JobID

  public static org.apache.hadoop.mapred.JobID getOldJobId(Job job) {
    if (job == null) {
      return null;
    }
    JobID id = getJobId(job);
    if (id != null) {
      return org.apache.hadoop.mapred.JobID.downgrade(id);
    }
    return null;
  }
View Full Code Here
TOP
Copyright © 2018 www.massapi.com. 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.