T
public abstract class Grouping<T> extends Object
UnsortedGrouping.reduce(org.apache.flink.api.common.functions.ReduceFunction)
UnsortedGrouping.reduceGroup(org.apache.flink.api.common.functions.GroupReduceFunction)
UnsortedGrouping.aggregate(org.apache.flink.api.java.aggregation.Aggregations, int)
DataSet
protected DataSet<T>
dataSet
protected Keys<T>
keys
Grouping(DataSet<T> set, Keys<T> keys)
DataSet<T>
getDataSet()
Keys<T>
getKeys()
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
protected final DataSet<T> dataSet
protected final Keys<T> keys
public Grouping(DataSet<T> set, Keys<T> keys)
public DataSet<T> getDataSet()
public Keys<T> getKeys()
Copyright © 2014 The Apache Software Foundation. All rights reserved.