Examples of TaskID


Examples of com.facebook.presto.execution.TaskId

        return outputFactory.getMaterializingOperator().getMaterializedResult();
    }

    public List<Driver> createDrivers(@Language("SQL") String sql, OutputFactory outputFactory)
    {
        return createDrivers(sql, outputFactory, new TaskContext(new TaskId("query", "stage", "task"), executor, session));
    }
View Full Code Here

Examples of edu.berkeley.xtrace.TaskID

    if (!canTest) return;
   
    long startTime = System.currentTimeMillis();
   
    /* Insert a single report into the file store */
    XTraceMetadata md = new XTraceMetadata(new TaskID(8), 0);
    Report report = randomReport(md);
    fs.receiveReport(report.toString());
   
    /* Sync() the report */
    fs.sync();
 
View Full Code Here

Examples of org.apache.agila.services.task.TaskID

        task.setTaskExpirationDate( new Date() );
        task.setSourceTokenID( new TokenID( 1 ) );
        task.setTaskStatus( Task.TASK_INCOMPLETE );
        task.setInstanceID( new InstanceID( 1 ) );

        TaskID taskID = dao.insertTask( task );
        assertNotNull( "TaskID should not be null", taskID );
    }
View Full Code Here

Examples of org.apache.hadoop.mapred.TaskID

            this.beat = new HeartBeat(progressable, cfg, settings.getHeartBeatLead(), log);
            this.beat.start();
        }

        private int detectCurrentInstance(Configuration conf) {
            TaskID taskID = HadoopCfgUtils.getTaskID(conf);

            if (taskID == null) {
                log.warn(String.format("Cannot determine task id - redirecting writes in a random fashion"));
                return NO_TASK_ID;
            }

            return taskID.getId();
        }
View Full Code Here

Examples of org.apache.hadoop.mapred.TaskID

  String[] ret = new String[2];

  @Override
  public String[] getTaskJobIDs(TaskCompletionEvent t) {
    TaskID tid = t.getTaskAttemptId().getTaskID();
    ret[0] = tid.toString();
    ret[1] = tid.getJobID().toString();
    return ret;
  }
View Full Code Here

Examples of org.apache.hadoop.mapred.TaskID

  String[] ret = new String[2];

  @Override
  public String[] getTaskJobIDs(TaskCompletionEvent t) {
    TaskID tid = t.getTaskAttemptId().getTaskID();
    ret[0] = tid.toString();
    ret[1] = tid.getJobID().toString();
    return ret;
  }
View Full Code Here

Examples of org.apache.hadoop.mapred.TaskID

  String[] ret = new String[2];

  @Override
  public String[] getTaskJobIDs(TaskCompletionEvent t) {
    TaskID tid = t.getTaskAttemptId().getTaskID();
    ret[0] = tid.toString();
    ret[1] = tid.getJobID().toString();
    return ret;
  }
View Full Code Here

Examples of org.apache.hadoop.mapred.TaskID

        this.progressable = progressable;
        this.rate = new TimeValue(tv.getMillis() - delay.getMillis(), TimeUnit.MILLISECONDS);
        this.log = log;

        String taskId;
        TaskID taskID = HadoopCfgUtils.getTaskID(cfg);

        if (taskID == null) {
            log.warn("Cannot determine task id...");
            taskId = "<unknown>";
            if (log.isTraceEnabled()) {
View Full Code Here

Examples of org.apache.hadoop.mapred.TaskID

      return;
    for(String filename : fileNames)
    {
      String periodParts[] = filename.split("\\.");
      try{
        TaskID tid = TaskID.forName(periodParts[0]);
        if (tid.getJobID().equals(job))
        {
    //      if (! Files.delete(path + "/" + filename))
            //logger.warn("Could not delete temporary map side-effect file "+ path + "/" + filename);
        }
      } catch (Exception e) {}
View Full Code Here

Examples of org.apache.hadoop.mapred.TaskID

  String[] ret = new String[2];

  @Override
  public String[] getTaskJobIDs(TaskCompletionEvent t) {
    TaskID tid = t.getTaskAttemptId().getTaskID();
    ret[0] = tid.toString();
    ret[1] = tid.getJobID().toString();
    return ret;
  }
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.