Examples of TaskInfo


Examples of com.alibaba.jstorm.task.TaskInfo

       
        for (Entry<String, TaskHeartbeat> entry : heartbeats.entrySet()) {
          taskId = entry.getKey();
            taskHb = entry.getValue();
           
            TaskInfo taskInfo = clusterState.task_info(topologyId, Integer.parseInt(taskId));
            if (taskInfo == null ) {
              LOG.warn("Task information can not be found in ZK for task-" + taskId);
              continue;
            }
            componentId = taskInfo.getComponentId();
           
            //update taskHb into the corresponding component map
            if (taskHb.getComponentType().equals("spout")) {
              commStatsInfo.addToSpoutList(componentId, taskId, taskHb);
            } else {
View Full Code Here

Examples of com.alipay.bluewhale.core.task.common.TaskInfo

    Set<Entry<Integer, String>> entrySet = taskToComponetId.entrySet();
    for (Iterator<Entry<Integer, String>> it = entrySet.iterator(); it
        .hasNext();) {
      // key is taskid, value is taskinfo
      Entry<Integer, String> entry = it.next();
      TaskInfo taskinfo = new TaskInfo(entry.getValue());
      stormClusterState.set_task(stormId, entry.getKey(), taskinfo);
    }
  }
View Full Code Here

Examples of com.alipay.bluewhale.core.task.common.TaskInfo

      shardTask.put(i, new HashSet<Integer>());
      realtimeTask.put(i, new HashSet<Integer>());
    }
   
    for (Integer tid : reassignIds) {
      TaskInfo info = assen.zkCluster.task_info(assen.topologyId, tid);
      if (info == null) {
        this.otherTask.add(tid);
      }
      String commnetId=info.getComponentId();
      Integer group=0;
      String[] cols=commnetId.split("@");
      if(cols.length>=2)
      {
        group=StormUtils.parseInt(cols[1]);
View Full Code Here

Examples of com.alipay.bluewhale.core.task.common.TaskInfo

        List<Integer> taks_ids = zkCluster.task_ids(topologyid);
        HashMap<Integer, String> rtn = null;
        if (taks_ids != null) {
          rtn = new HashMap<Integer, String>();
            for (Integer task : taks_ids) {
                TaskInfo info = zkCluster.task_info(topologyid, task);
                String componment_id = info.getComponentId();
                rtn.put(task, componment_id);
            }
        }
        return rtn;
    }
View Full Code Here

Examples of com.alipay.bluewhale.core.task.common.TaskInfo

      nonAssignNodePort.add(p);
    }
   
    for(Integer task:reassignIds)
    {
      TaskInfo info=taskId2TaskInfo.get(task);
      if(info==null)
      {
        nonAssignTask.add(task);
        LOG.info("can`t find task:"+task+","+this.topologyId);
        continue;
      }
     
      String componname=info.getComponentId();
      Integer index=taskId2Index.get(new TaskId(componname, task));
      if(index==null)
      {
        nonAssignTask.add(task);
        LOG.info("can`t find taskindex:"+task+","+this.topologyId+",index:"+index);
View Full Code Here

Examples of com.alipay.bluewhale.core.task.common.TaskInfo

    Set<Integer> allTaskIds = StormUtils.listToSet(this.zkCluster.task_ids(this.topologyId));
   
    HashSet<String> componnames=new HashSet<String>();
    HashMap<String,ArrayList<Integer>> componname2Ids=new HashMap<String,ArrayList<Integer>>();
    for (Integer tid : allTaskIds) {
      TaskInfo info = this.zkCluster.task_info(this.topologyId, tid);
      if (info == null) {
        LOG.info("can`t find TaskInfo "+this.topologyId+","+ tid);
        continue;
      }
      taskId2TaskInfo.put(tid, info);
     
      String componentId=info.getComponentId();
      componnames.add(componentId);
      ArrayList<Integer> tasks=componname2Ids.get(componentId);
      if(tasks==null)
      {
        tasks=new ArrayList<Integer>();
View Full Code Here

Examples of com.defaultcompany.external.model.TaskInfo

  }
 
  class TaskInfoRowMapper implements RowMapper {

    public Object mapRow(ResultSet rs, int arg1) throws SQLException {
      TaskInfo item = new TaskInfo();
     
      item.setInstanceId(rs.getString("INSTID"));
      item.setTaskId(rs.getString("TASKID"));
      item.setTracingTag(rs.getString("TRCTAG"));
     
      item.setHandler(rs.getString("TOOL"));
      item.setMainParam(rs.getString("EXT1"));
      item.setSubParam(rs.getString("EXT2"));
     
      item.setExternalKey(rs.getString("INFO"));
       
      return item;
    }
View Full Code Here

Examples of com.facebook.presto.execution.TaskInfo

                pendingSplits.put(planFragment.getPartitionedSource(), new ScheduledSplit(nextSplitId.getAndIncrement(), initialSplit));
            }

            TaskStats taskStats = new TaskContext(taskId, executor, session).getTaskStats();

            taskInfo = new StateMachine<>("task " + taskId, executor, new TaskInfo(
                    taskId,
                    TaskInfo.MIN_VERSION,
                    TaskState.PLANNED,
                    location,
                    DateTime.now(),
View Full Code Here

Examples of com.microsoft.windowsazure.services.media.models.TaskInfo

            retryCounter++;
        }

        ListResult<TaskInfo> tasks = service.list(Task.list(actualJob
                .getTasksLink()));
        TaskInfo taskInfo = tasks.get(0);
        List<ErrorDetail> errorDetails = taskInfo.getErrorDetails();

        assertEquals(1, errorDetails.size());
        ErrorDetail errorDetail = errorDetails.get(0);
        assertNotNull(errorDetail.getCode());
        assertNotNull(errorDetail.getMessage());
View Full Code Here

Examples of com.narirelays.ems.persistence.orm.TaskInfo

      // result.setFailed(TASK_PARAM_NOTEXIST,param_id);
      // }else{
      if (jobid == null) {
        result.setFailed(TASK_INFO_REQUIRE_ID);
      } else {
        TaskInfo taskInfo = taskInfoDAO.findById(jobid);
        if (taskInfo == null) {
          result.setFailed(TASK_INFO_NOTEXIST, jobid);
        } else {
          TaskParamV taskParamV = new TaskParamV();
          try {
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.