Modifier and Type | Class and Description |
---|---|
class |
RichGroupCombineFunction<IN,OUT>
Rich variant of the
GroupCombineFunction . |
Modifier and Type | Class and Description |
---|---|
class |
GroupCombineOperatorBase<IN,OUT,FT extends GroupCombineFunction<IN,OUT>>
Base operator for the combineGroup transformation.
|
Modifier and Type | Method and Description |
---|---|
<R> GroupCombineOperator<T,R> |
DataSet.combineGroup(GroupCombineFunction<T,R> combiner)
Applies a GroupCombineFunction on a non-grouped
DataSet . |
Modifier and Type | Class and Description |
---|---|
class |
FirstReducer<T>
Reducer that only emits the first N elements in a group.
|
Modifier and Type | Method and Description |
---|---|
protected GroupCombineFunction<IN,OUT> |
GroupCombineOperator.getFunction() |
Modifier and Type | Method and Description |
---|---|
<R> GroupCombineOperator<T,R> |
SortedGrouping.combineGroup(GroupCombineFunction<T,R> combiner)
Applies a GroupCombineFunction on a grouped
DataSet . |
<R> GroupCombineOperator<T,R> |
UnsortedGrouping.combineGroup(GroupCombineFunction<T,R> combiner)
Applies a GroupCombineFunction on a grouped
DataSet . |
Constructor and Description |
---|
GroupCombineOperator(DataSet<IN> input,
TypeInformation<OUT> resultType,
GroupCombineFunction<IN,OUT> function,
String defaultName)
Constructor for a non-grouped reduce (all reduce).
|
GroupCombineOperator(Grouping<IN> input,
TypeInformation<OUT> resultType,
GroupCombineFunction<IN,OUT> function,
String defaultName)
Constructor for a grouped reduce.
|
Modifier and Type | Class and Description |
---|---|
class |
CombineToGroupCombineWrapper<IN,OUT,F extends CombineFunction<IN,IN> & GroupReduceFunction<IN,OUT>>
A wrapper the wraps a function that implements both
CombineFunction and GroupReduceFunction interfaces and makes it look like a function that implements GroupCombineFunction and GroupReduceFunction to the runtime. |
class |
RichCombineToGroupCombineWrapper<IN,OUT,F extends RichGroupReduceFunction<IN,OUT> & CombineFunction<IN,IN>>
A wrapper the wraps a function that implements both
CombineFunction and GroupReduceFunction interfaces and makes it look like a function that implements GroupCombineFunction and GroupReduceFunction to the runtime. |
Constructor and Description |
---|
PlanUnwrappingGroupCombineOperator(GroupCombineFunction<IN,OUT> udf,
Keys.SelectorFunctionKeys<IN,K> key,
String name,
TypeInformation<OUT> outType,
TypeInformation<Tuple2<K,IN>> typeInfoWithKey) |
PlanUnwrappingSortedGroupCombineOperator(GroupCombineFunction<IN,OUT> udf,
Keys.SelectorFunctionKeys<IN,K1> groupingKey,
Keys.SelectorFunctionKeys<IN,K2> sortingKey,
String name,
TypeInformation<OUT> outType,
TypeInformation<Tuple3<K1,K2,IN>> typeInfoWithKey) |
Modifier and Type | Method and Description |
---|---|
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getGroupCombineReturnTypes(GroupCombineFunction<IN,OUT> combineInterface,
TypeInformation<IN> inType) |
static <IN,OUT> TypeInformation<OUT> |
TypeExtractor.getGroupCombineReturnTypes(GroupCombineFunction<IN,OUT> combineInterface,
TypeInformation<IN> inType,
String functionName,
boolean allowMissing) |
Modifier and Type | Class and Description |
---|---|
class |
HadoopReduceCombineFunction<KEYIN,VALUEIN,KEYOUT,VALUEOUT>
This wrapper maps a Hadoop Reducer and Combiner (mapred API) to a combinable Flink
GroupReduceFunction.
|
Modifier and Type | Method and Description |
---|---|
Class<GroupCombineFunction<IN,OUT>> |
GroupReduceCombineDriver.getStubType() |
Class<GroupCombineFunction<IN,OUT>> |
AllGroupCombineDriver.getStubType() |
Modifier and Type | Method and Description |
---|---|
void |
GroupReduceCombineDriver.setup(TaskContext<GroupCombineFunction<IN,OUT>,OUT> context) |
void |
AllGroupCombineDriver.setup(TaskContext<GroupCombineFunction<IN,OUT>,OUT> context) |
Constructor and Description |
---|
CombiningUnilateralSortMerger(GroupCombineFunction<E,E> combineStub,
MemoryManager memoryManager,
IOManager ioManager,
MutableObjectIterator<E> input,
AbstractInvokable parentTask,
TypeSerializerFactory<E> serializerFactory,
TypeComparator<E> comparator,
double memoryFraction,
int maxNumFileHandles,
float startSpillingFraction,
boolean handleLargeRecords,
boolean objectReuseEnabled)
Creates a new sorter that reads the data from a given reader and provides an iterator
returning that data in a sorted manner.
|
CombiningUnilateralSortMerger(GroupCombineFunction<E,E> combineStub,
MemoryManager memoryManager,
IOManager ioManager,
MutableObjectIterator<E> input,
AbstractInvokable parentTask,
TypeSerializerFactory<E> serializerFactory,
TypeComparator<E> comparator,
double memoryFraction,
int numSortBuffers,
int maxNumFileHandles,
float startSpillingFraction,
boolean handleLargeRecords,
boolean objectReuseEnabled)
Creates a new sorter that reads the data from a given reader and provides an iterator
returning that data in a sorted manner.
|
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.