IN
- OUT
- @Deprecated @PublicEvolving public abstract class GroupReduceIterator<IN,OUT> extends org.apache.flink.api.common.functions.RichGroupReduceFunction<IN,OUT>
Iterable
.Constructor and Description |
---|
GroupReduceIterator()
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
reduce(Iterable<IN> values,
org.apache.flink.util.Collector<OUT> out)
Deprecated.
|
abstract Iterator<OUT> |
reduceGroup(Iterable<IN> values)
Deprecated.
|
close, getIterationRuntimeContext, getRuntimeContext, open, setRuntimeContext
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.