IN - Type of the input elements.OUT - Type of the returned elements.@PublicEvolving
public abstract class FlatMapIterator<IN,OUT>
extends org.apache.flink.api.common.functions.RichFlatMapFunction<IN,OUT>
RichFlatMapFunction that returns elements through an iterator, rather then
 through a collector. In all other respects, it behaves exactly like the FlatMapFunction.
 The function needs to be serializable, as defined in Serializable.
| 构造器和说明 | 
|---|
| FlatMapIterator() | 
| 限定符和类型 | 方法和说明 | 
|---|---|
| abstract Iterator<OUT> | flatMap(IN value)The core method of the function. | 
| void | flatMap(IN value,
       org.apache.flink.util.Collector<OUT> out)Delegates calls to the  flatMap(Object)method. | 
public abstract Iterator<OUT> flatMap(IN value) throws Exception
value - The input value.Exception - This method may throw exceptions. Throwing an exception will cause the operation
                   to fail and may trigger recovery.public final void flatMap(IN value, org.apache.flink.util.Collector<OUT> out) throws Exception
flatMap(Object) method.Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.