Package org.apache.flink.runtime.jobgraph

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


        }
      } else {
        // predecessor is its own vertex
        sourceVertexConfig = new TaskConfig(sourceVertex.getConfiguration());
      }
      DistributionPattern pattern = connectJobVertices(
        inConn, inputIndex, sourceVertex, sourceVertexConfig, targetVertex, targetVertexConfig, isBroadcast);
     
      // accounting on channels and senders
      numChannelsTotal++;
      if (inConn.isOnDynamicPath()) {
View Full Code Here


      final AbstractJobVertex sourceVertex, final TaskConfig sourceConfig,
      final AbstractJobVertex targetVertex, final TaskConfig targetConfig, boolean isBroadcast)
  throws CompilerException
  {
    // ------------ connect the vertices to the job graph --------------
    final DistributionPattern distributionPattern;

    switch (channel.getShipStrategy()) {
      case FORWARD:
        distributionPattern = DistributionPattern.POINTWISE;
        break;
View Full Code Here

  //  Graph building
  // --------------------------------------------------------------------------------------------
 
  public void connectSource(int inputNumber, IntermediateResult source, JobEdge edge, int consumerNumber) {
   
    final DistributionPattern pattern = edge.getDistributionPattern();
    final IntermediateResultPartition[] sourcePartitions = source.getPartitions();
   
    ExecutionEdge[] edges = null;
   
    switch (pattern) {
View Full Code Here

TOP

Related Classes of org.apache.flink.runtime.jobgraph.DistributionPattern

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.