Package org.apache.flink.runtime.jobmanager.scheduler

Examples of org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup


    for (AbstractJobVertex vertex : streamVertices.values()) {
      vertex.setSlotSharingGroup(shareGroup);
    }

    for (String iterID : new HashSet<String>(iterationIds.values())) {
      CoLocationGroup ccg = new CoLocationGroup();
      AbstractJobVertex tail = streamVertices.get(iterationIDtoTailName.get(iterID));
      AbstractJobVertex head = streamVertices.get(iterationIDtoHeadName.get(iterID));

      ccg.addVertex(head);
      ccg.addVertex(tail);
    }
  }
View Full Code Here


    this.priorExecutions = new CopyOnWriteArrayList<Execution>();
   
    this.currentExecution = new Execution(this, 0, createTimestamp);
   
    // create a co-location scheduling hint, if necessary
    CoLocationGroup clg = jobVertex.getCoLocationGroup();
    if (clg != null) {
      this.locationConstraint = clg.getLocationConstraint(subTaskIndex);
    } else {
      this.locationConstraint = null;
    }
  }
View Full Code Here

     
      if (state == FINISHED || state == CANCELED || state == FAILED) {
        priorExecutions.add(execution);
        currentExecution = new Execution(this, execution.getAttemptNumber()+1, System.currentTimeMillis());
       
        CoLocationGroup grp = jobVertex.getCoLocationGroup();
        if (grp != null) {
          this.locationConstraint = grp.getLocationConstraint(subTaskIndex);
        }
       
        // temp: assign new channel IDs.
        ExecutionGraph graph = getExecutionGraph();
       
View Full Code Here

  public void setStrictlyCoLocatedWith(AbstractJobVertex strictlyCoLocatedWith) {
    if (this.slotSharingGroup == null || this.slotSharingGroup != strictlyCoLocatedWith.slotSharingGroup) {
      throw new IllegalArgumentException("Strict co-location requires that both vertices are in the same slot sharing group.");
    }
   
    CoLocationGroup thisGroup = this.coLocationGroup;
    CoLocationGroup otherGroup = strictlyCoLocatedWith.coLocationGroup;
   
    if (otherGroup == null) {
      if (thisGroup == null) {
        CoLocationGroup group = new CoLocationGroup(this, strictlyCoLocatedWith);
        this.coLocationGroup = group;
        strictlyCoLocatedWith.coLocationGroup = group;
      }
      else {
        thisGroup.addVertex(strictlyCoLocatedWith);
View Full Code Here

TOP

Related Classes of org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup

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.