Package org.apache.flink.compiler.dataproperties

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


    return Collections.singletonList(props);
  }

  @Override
  protected List<RequestedLocalProperties> createPossibleLocalProperties() {
    RequestedLocalProperties props = new RequestedLocalProperties();
    if (this.ordering == null) {
      props.setGroupedFields(this.keys);
    } else {
      props.setOrdering(this.ordering);
    }
    return Collections.singletonList(props);
  }
View Full Code Here


    return Collections.singletonList(partProps);
  }

  @Override
  protected List<RequestedLocalProperties> createPossibleLocalProperties() {
    return Collections.singletonList(new RequestedLocalProperties());
  }
View Full Code Here

    super(keys1, keys2);
  }
 
  @Override
  protected List<LocalPropertiesPair> createPossibleLocalProperties() {
    RequestedLocalProperties sort = new RequestedLocalProperties(Utils.createOrdering(this.keys1));
    RequestedLocalProperties none = new RequestedLocalProperties();
    return Collections.singletonList(new LocalPropertiesPair(sort, none));
  }
View Full Code Here

    return Collections.singletonList(new RequestedGlobalProperties());
  }

  @Override
  protected List<RequestedLocalProperties> createPossibleLocalProperties() {
    return Collections.singletonList(new RequestedLocalProperties());
  }
View Full Code Here

    return Collections.singletonList(new GlobalPropertiesPair(partitioned1, partitioned2));
  }
 
  @Override
  protected List<LocalPropertiesPair> createPossibleLocalProperties() {
    RequestedLocalProperties sort1 = new RequestedLocalProperties(this.ordering1);
    RequestedLocalProperties sort2 = new RequestedLocalProperties(this.ordering2);
    return Collections.singletonList(new LocalPropertiesPair(sort1, sort2));
  }
View Full Code Here

  }

  @Override
  protected List<LocalPropertiesPair> createPossibleLocalProperties() {
    // all properties are possible
    return Collections.singletonList(new LocalPropertiesPair(new RequestedLocalProperties(), new RequestedLocalProperties()));
  }
View Full Code Here

    this.nextPartialSolution.accept(new InterestingPropertyVisitor(estimator));
   
    // now add the interesting properties of the partial solution to the input
    final InterestingProperties inProps = this.partialSolution.getInterestingProperties().clone();
    inProps.addGlobalProperties(new RequestedGlobalProperties());
    inProps.addLocalProperties(new RequestedLocalProperties());
    this.inConn.setInterestingProperties(inProps);
  }
View Full Code Here

    return Collections.singletonList(props);
  }

  @Override
  protected List<RequestedLocalProperties> createPossibleLocalProperties() {
    RequestedLocalProperties props = new RequestedLocalProperties();
    if (this.ordering == null) {
      props.setGroupedFields(this.keys);
    } else {
      props.setOrdering(this.ordering);
    }
    return Collections.singletonList(props);
  }
View Full Code Here

   
    RequestedGlobalProperties partitionedProperties = new RequestedGlobalProperties();
    partitionedProperties.setHashPartitioned(this.solutionSetKeyFields);
    InterestingProperties partitionedIP = new InterestingProperties();
    partitionedIP.addGlobalProperties(partitionedProperties);
    partitionedIP.addLocalProperties(new RequestedLocalProperties());
   
    this.nextWorksetRootConnection.setInterestingProperties(new InterestingProperties());
    this.solutionSetDeltaRootConnection.setInterestingProperties(partitionedIP.clone());
   
    InterestingPropertyVisitor ipv = new InterestingPropertyVisitor(estimator);
    this.nextWorkset.accept(ipv);
    this.solutionSetDelta.accept(ipv);
   
    // take the interesting properties of the partial solution and add them to the root interesting properties
    InterestingProperties worksetIntProps = this.worksetNode.getInterestingProperties();
    InterestingProperties intProps = new InterestingProperties();
    intProps.getGlobalProperties().addAll(worksetIntProps.getGlobalProperties());
    intProps.getLocalProperties().addAll(worksetIntProps.getLocalProperties());
   
    // clear all interesting properties to prepare the second traversal
    this.nextWorksetRootConnection.clearInterestingProperties();
    this.nextWorkset.accept(InterestingPropertiesClearer.INSTANCE);
   
    // 2nd pass
    this.nextWorksetRootConnection.setInterestingProperties(intProps);
    this.nextWorkset.accept(ipv);
   
    // now add the interesting properties of the workset to the workset input
    final InterestingProperties inProps = this.worksetNode.getInterestingProperties().clone();
    inProps.addGlobalProperties(new RequestedGlobalProperties());
    inProps.addLocalProperties(new RequestedLocalProperties());
    this.input2.setInterestingProperties(inProps);
   
    // the partial solution must be hash partitioned, so it has only that as interesting properties
    this.input1.setInterestingProperties(partitionedIP);
  }
View Full Code Here

    return Collections.singletonList(new RequestedGlobalProperties());
  }

  @Override
  protected List<RequestedLocalProperties> createPossibleLocalProperties() {
    return Collections.singletonList(new RequestedLocalProperties());
  }
View Full Code Here

TOP

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

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.