Package org.apache.flink.compiler.dataproperties

Examples of org.apache.flink.compiler.dataproperties.LocalProperties


  public NAryUnionPlanNode(BinaryUnionNode template, List<Channel> inputs, GlobalProperties gProps) {
    super(template, "Union", DriverStrategy.NONE);
   
    this.inputs = inputs;
    this.globalProps = gProps;
    this.localProps = new LocalProperties();
  }
View Full Code Here


   */
  public SourcePlanNode(DataSourceNode template, String nodeName) {
    super(template, nodeName, DriverStrategy.NONE);
   
    this.globalProps = new GlobalProperties();
    this.localProps = new LocalProperties();
    updatePropertiesWithUniqueSets(template.getUniqueFields());
  }
View Full Code Here

      final SingleInputPlanNode node = dps.instantiate(in, this);
      node.setBroadcastInputs(broadcastChannelsCombination);
     
      // compute how the strategy affects the properties
      GlobalProperties gProps = in.getGlobalProperties().clone();
      LocalProperties lProps = in.getLocalProperties().clone();
      gProps = dps.computeGlobalProperties(gProps);
      lProps = dps.computeLocalProperties(lProps);
     
      // filter by the user code field copies
      gProps = gProps.filterByNodesConstantSet(this, 0);
      lProps = lProps.filterByNodesConstantSet(this, 0);
     
      // apply
      node.initProperties(gProps, lProps);
      node.updatePropertiesWithUniqueSets(getUniqueFields());
      target.add(node);
View Full Code Here

    }
  }

  @Override
  public LocalProperties computeLocalProperties(LocalProperties in1, LocalProperties in2) {
    return new LocalProperties();
  }
View Full Code Here

TOP

Related Classes of org.apache.flink.compiler.dataproperties.LocalProperties

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.