Package org.apache.flink.compiler.dataproperties

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


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

  @Override
  protected List<RequestedLocalProperties> createPossibleLocalProperties() {
    return Collections.singletonList(new RequestedLocalProperties());
  }
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

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

    return Collections.singletonList(props);
  }

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

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

  @Override
  protected List<RequestedLocalProperties> createPossibleLocalProperties() {
    return Collections.singletonList(new RequestedLocalProperties());
  }
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

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

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

    return DriverStrategy.MERGE;
  }

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

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

      iProps.addGlobalProperties(partitioningProps);
    }
   
    {
      final Ordering localOrder = getPactContract().getLocalOrder();
      final RequestedLocalProperties orderProps = new RequestedLocalProperties();
      if (localOrder != null) {
        orderProps.setOrdering(localOrder);
      }
      iProps.addLocalProperties(orderProps);
    }
   
    this.input.setInterestingProperties(iProps);
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.