Uses of Interface
org.apache.flink.api.common.functions.MapFunction
-
-
Uses of MapFunction in org.apache.flink.api.common.functions
Classes in org.apache.flink.api.common.functions that implement MapFunction Modifier and Type Class Description class
RichMapFunction<IN,OUT>
Rich variant of theMapFunction
. -
Uses of MapFunction in org.apache.flink.api.common.operators.base
Classes in org.apache.flink.api.common.operators.base with type parameters of type MapFunction Modifier and Type Class Description class
MapOperatorBase<IN,OUT,FT extends MapFunction<IN,OUT>>
-
Uses of MapFunction in org.apache.flink.api.java.typeutils
Methods in org.apache.flink.api.java.typeutils with parameters of type MapFunction Modifier and Type Method Description static <IN,OUT>
TypeInformation<OUT>TypeExtractor. getMapReturnTypes(MapFunction<IN,OUT> mapInterface, TypeInformation<IN> inType)
static <IN,OUT>
TypeInformation<OUT>TypeExtractor. getMapReturnTypes(MapFunction<IN,OUT> mapInterface, TypeInformation<IN> inType, String functionName, boolean allowMissing)
-
Uses of MapFunction in org.apache.flink.runtime.operators
Methods in org.apache.flink.runtime.operators that return types with arguments of type MapFunction Modifier and Type Method Description Class<MapFunction<IT,OT>>
MapDriver. getStubType()
Method parameters in org.apache.flink.runtime.operators with type arguments of type MapFunction Modifier and Type Method Description void
MapDriver. setup(TaskContext<MapFunction<IT,OT>,OT> context)
-
Uses of MapFunction in org.apache.flink.runtime.operators.udf
Classes in org.apache.flink.runtime.operators.udf that implement MapFunction Modifier and Type Class Description class
RemoveRangeIndex<T>
-
Uses of MapFunction in org.apache.flink.sql.tests
Classes in org.apache.flink.sql.tests that implement MapFunction Modifier and Type Class Description static class
StreamSQLTestProgram.KillMapper
Kills the first execution attempt of an application when it receives the second record. -
Uses of MapFunction in org.apache.flink.streaming.api.datastream
Methods in org.apache.flink.streaming.api.datastream with parameters of type MapFunction Modifier and Type Method Description <R> SingleOutputStreamOperator<R>
DataStream. map(MapFunction<T,R> mapper)
Applies a Map transformation on aDataStream
.<R> SingleOutputStreamOperator<R>
DataStream. map(MapFunction<T,R> mapper, TypeInformation<R> outputType)
Applies a Map transformation on aDataStream
. -
Uses of MapFunction in org.apache.flink.streaming.api.functions.python.eventtime
Classes in org.apache.flink.streaming.api.functions.python.eventtime that implement MapFunction Modifier and Type Class Description class
RemoveTimestampMapFunction<T>
MapFunction which removes the timestamp field from the input element. -
Uses of MapFunction in org.apache.flink.streaming.api.operators
Constructors in org.apache.flink.streaming.api.operators with parameters of type MapFunction Constructor Description StreamMap(MapFunction<IN,OUT> mapper)
-
Uses of MapFunction in org.apache.flink.streaming.tests
Classes in org.apache.flink.streaming.tests that implement MapFunction Modifier and Type Class Description class
FailureMapper<T>
This mapper simulates failure by throwing exceptions. -
Uses of MapFunction in org.apache.flink.streaming.tests.artificialstate
Classes in org.apache.flink.streaming.tests.artificialstate that implement MapFunction Modifier and Type Class Description class
ArtificalOperatorStateMapper<IN,OUT>
A self-verifiableRichMapFunction
used to verify checkpointing and restore semantics for various kinds of operator state.class
ArtificialKeyedStateMapper<IN,OUT>
A generic, statefulMapFunction
that allows specifying what states to maintain based on a provided list ofArtificialStateBuilder
s.Constructors in org.apache.flink.streaming.tests.artificialstate with parameters of type MapFunction Constructor Description ArtificalOperatorStateMapper(MapFunction<IN,OUT> mapFunction)
ArtificialKeyedStateMapper(MapFunction<IN,OUT> mapFunction, List<ArtificialStateBuilder<IN>> artificialStateBuilders)
ArtificialKeyedStateMapper(MapFunction<IN,OUT> mapFunction, ArtificialStateBuilder<IN> artificialStateBuilders)
-
Uses of MapFunction in org.apache.flink.table.runtime.operators.join.interval
Classes in org.apache.flink.table.runtime.operators.join.interval that implement MapFunction Modifier and Type Class Description class
PaddingLeftMapFunction
Function performing left padding.class
PaddingRightMapFunction
Function performing right padding. -
Uses of MapFunction in org.apache.flink.table.sinks
Classes in org.apache.flink.table.sinks that implement MapFunction Modifier and Type Class Description static class
CsvTableSink.CsvFormatter
Deprecated.Formats a Row into a String with fields separated by the field delimiter. -
Uses of MapFunction in org.apache.flink.test
Classes in org.apache.flink.test that implement MapFunction Modifier and Type Class Description static class
StatefulStreamingJob.MyStatefulFunction
A statefulRichMapFunction
that keeps the required types of state.
-