Uses of Interface
org.apache.flink.api.common.functions.Function
-
-
Uses of Function in org.apache.flink.api.common.functions
Classes in org.apache.flink.api.common.functions with type parameters of type Function Modifier and Type Class Description class
WrappingFunction<T extends Function>
Wrapper aroundFunction
.Subinterfaces of Function in org.apache.flink.api.common.functions Modifier and Type Interface Description interface
AggregateFunction<IN,ACC,OUT>
TheAggregateFunction
is a flexible aggregation function, characterized by the following features: The aggregates may use different types for input values, intermediate aggregates, and result type, to support a wide range of aggregation types.interface
CoGroupFunction<IN1,IN2,O>
The interface for CoGroup functions.interface
CombineFunction<IN,OUT>
Generic interface used for combine functions ("combiners").interface
CrossFunction<IN1,IN2,OUT>
Interface for Cross functions.interface
FilterFunction<T>
A filter function is a predicate applied individually to each record.interface
FlatJoinFunction<IN1,IN2,OUT>
Interface for Join functions.interface
FlatMapFunction<T,O>
Base interface for flatMap functions.interface
GroupCombineFunction<IN,OUT>
Generic interface used for combine functions ("combiners").interface
GroupReduceFunction<T,O>
The interface for group reduce functions.interface
JoinFunction<IN1,IN2,OUT>
Interface for Join functions.interface
MapFunction<T,O>
Base interface for Map functions.interface
MapPartitionFunction<T,O>
Interface for "mapPartition" functions.interface
Partitioner<K>
Function to implement a custom partition assignment for keys.interface
ReduceFunction<T>
Base interface for Reduce functions.interface
RichFunction
An base interface for all rich user-defined functions.Classes in org.apache.flink.api.common.functions that implement Function Modifier and Type Class Description class
AbstractRichFunction
An abstract stub implementation for rich user-defined functions.class
RichAggregateFunction<IN,ACC,OUT>
Rich variant of theAggregateFunction
.class
RichCoGroupFunction<IN1,IN2,OUT>
Rich variant of theCoGroupFunction
.class
RichCrossFunction<IN1,IN2,OUT>
Rich variant of theCrossFunction
.class
RichFilterFunction<T>
Rich variant of theFilterFunction
.class
RichFlatJoinFunction<IN1,IN2,OUT>
Rich variant of theFlatJoinFunction
.class
RichFlatMapFunction<IN,OUT>
Rich variant of theFlatMapFunction
.class
RichGroupCombineFunction<IN,OUT>
Rich variant of theGroupCombineFunction
.class
RichGroupReduceFunction<IN,OUT>
Rich variant of theGroupReduceFunction
.class
RichJoinFunction<IN1,IN2,OUT>
Rich variant of theJoinFunction
.class
RichMapFunction<IN,OUT>
Rich variant of theMapFunction
.class
RichMapPartitionFunction<I,O>
Rich variant of theMapPartitionFunction
.class
RichReduceFunction<T>
Rich variant of theReduceFunction
.class
WrappingFunction<T extends Function>
Wrapper aroundFunction
.Fields in org.apache.flink.api.common.functions declared as Function Modifier and Type Field Description protected T
WrappingFunction. wrappedFunction
-
Uses of Function in org.apache.flink.api.common.functions.util
Classes in org.apache.flink.api.common.functions.util that implement Function Modifier and Type Class Description class
NoOpFunction
AnAbstractRichFunction
that does nothing.Methods in org.apache.flink.api.common.functions.util with parameters of type Function Modifier and Type Method Description static void
FunctionUtils. closeFunction(Function function)
static RuntimeContext
FunctionUtils. getFunctionRuntimeContext(Function function, RuntimeContext defaultContext)
static void
FunctionUtils. openFunction(Function function, OpenContext openContext)
static void
FunctionUtils. setFunctionRuntimeContext(Function function, RuntimeContext context)
-
Uses of Function in org.apache.flink.api.common.operators
Classes in org.apache.flink.api.common.operators with type parameters of type Function Modifier and Type Class Description class
AbstractUdfOperator<OUT,FT extends Function>
Abstract superclass for all contracts that represent actual operators.class
DualInputOperator<IN1,IN2,OUT,FT extends Function>
Abstract operator superclass for all operators that have two inputs, like "Join", "CoGroup", or "Cross".class
SingleInputOperator<IN,OUT,FT extends Function>
Abstract superclass for all operators that have one input like "map" or "reduce". -
Uses of Function in org.apache.flink.api.common.operators.base
Classes in org.apache.flink.api.common.operators.base that implement Function Modifier and Type Class Description static class
BulkIterationBase.TerminationCriterionMapper<X>
Special Mapper that is added before a termination criterion and is only a container for an special aggregator -
Uses of Function in org.apache.flink.api.java.functions
Subinterfaces of Function in org.apache.flink.api.java.functions Modifier and Type Interface Description interface
KeySelector<IN,KEY>
TheKeySelector
allows to use deterministic objects for operations such as reduce, reduceGroup, join, coGroup, etc.Classes in org.apache.flink.api.java.functions that implement Function Modifier and Type Class Description class
NullByteKeySelector<T>
Used as a dummyKeySelector
to allow using keyed operators for non-keyed use cases. -
Uses of Function in org.apache.flink.api.java.typeutils
Methods in org.apache.flink.api.java.typeutils with parameters of type Function Modifier and Type Method Description static TypeExtractionUtils.LambdaExecutable
TypeExtractionUtils. checkAndExtractLambda(Function function)
Checks if the given function has been implemented using a Java 8 lambda.static <IN1,IN2,OUT>
TypeInformation<OUT>TypeExtractor. getBinaryOperatorReturnType(Function function, Class<?> baseClass, int input1TypeArgumentIndex, int input2TypeArgumentIndex, int outputTypeArgumentIndex, int[] lambdaOutputTypeArgumentIndices, TypeInformation<IN1> in1Type, TypeInformation<IN2> in2Type, String functionName, boolean allowMissing)
Returns the binary operator's return type.static <IN,OUT>
TypeInformation<OUT>TypeExtractor. getUnaryOperatorReturnType(Function function, Class<?> baseClass, int inputTypeArgumentIndex, int outputTypeArgumentIndex, int[] lambdaOutputTypeArgumentIndices, TypeInformation<IN> inType, String functionName, boolean allowMissing)
Returns the unary operator's return type. -
Uses of Function in org.apache.flink.cep
Subinterfaces of Function in org.apache.flink.cep Modifier and Type Interface Description interface
PatternFlatSelectFunction<IN,OUT>
Base interface for a pattern select function which can produce multiple resulting elements.interface
PatternFlatTimeoutFunction<IN,OUT>
Base interface for a pattern timeout function which can produce multiple resulting elements.interface
PatternSelectFunction<IN,OUT>
Base interface for a pattern select function.interface
PatternTimeoutFunction<IN,OUT>
Base interface for a pattern timeout function.Classes in org.apache.flink.cep that implement Function Modifier and Type Class Description class
RichPatternFlatSelectFunction<IN,OUT>
Rich variant of thePatternFlatSelectFunction
.class
RichPatternSelectFunction<IN,OUT>
Rich variant of thePatternSelectFunction
. -
Uses of Function in org.apache.flink.cep.functions
Classes in org.apache.flink.cep.functions that implement Function Modifier and Type Class Description class
PatternProcessFunction<IN,OUT>
It is called with a map of detected events which are identified by their names. -
Uses of Function in org.apache.flink.cep.functions.adaptors
Classes in org.apache.flink.cep.functions.adaptors that implement Function Modifier and Type Class Description class
PatternFlatSelectAdapter<IN,OUT>
Adapter that expressesPatternFlatSelectFunction
withPatternProcessFunction
.class
PatternSelectAdapter<IN,OUT>
Adapter that expressesPatternSelectFunction
withPatternProcessFunction
.class
PatternTimeoutFlatSelectAdapter<IN,OUT,T>
Adapter that expresses combination ofPatternFlatSelectFunction
andPatternTimeoutFlatSelectAdapter
withPatternProcessFunction
.class
PatternTimeoutSelectAdapter<IN,OUT,T>
Adapter that expresses combination ofPatternSelectFunction
andPatternTimeoutFlatSelectAdapter
withPatternProcessFunction
. -
Uses of Function in org.apache.flink.cep.pattern.conditions
Classes in org.apache.flink.cep.pattern.conditions that implement Function Modifier and Type Class Description class
IterativeCondition<T>
A user-defined condition that decides if an element should be accepted in the pattern or not.class
RichAndCondition<T>
class
RichCompositeIterativeCondition<T>
A base class of compositeIterativeCondition
conditions such asRichAndCondition
,RichOrCondition
andRichNotCondition
, etc.class
RichIterativeCondition<T>
Rich variant of theIterativeCondition
.class
RichNotCondition<T>
Acondition
which negates the condition it wraps and returnstrue
if the original condition returnsfalse
.class
RichOrCondition<T>
Acondition
which combines two conditions with a logicalOR
and returnstrue
if at least one istrue
.class
SimpleCondition<T>
A user-defined condition that decides if an element should be accepted in the pattern or not.class
SubtypeCondition<T>
Acondition
which filters elements of the given type. -
Uses of Function in org.apache.flink.connector.datagen.functions
Classes in org.apache.flink.connector.datagen.functions that implement Function Modifier and Type Class Description class
FromElementsGeneratorFunction<OUT>
A stream generator function that returns a sequence of elements.class
IndexLookupGeneratorFunction<OUT>
A stream generator function that returns elements from the collection based on their index. -
Uses of Function in org.apache.flink.connector.datagen.source
Subinterfaces of Function in org.apache.flink.connector.datagen.source Modifier and Type Interface Description interface
GeneratorFunction<T,O>
Base interface for data generator functions. -
Uses of Function in org.apache.flink.connector.file.table.batch.compact
Classes in org.apache.flink.connector.file.table.batch.compact that implement Function Modifier and Type Class Description class
BatchPartitionCommitterSink
Committer operator for partition in batch mode. -
Uses of Function in org.apache.flink.datastream.api.function
Subinterfaces of Function in org.apache.flink.datastream.api.function Modifier and Type Interface Description interface
ApplyPartitionFunction<OUT>
A function to be applied to all partitions .interface
OneInputStreamProcessFunction<IN,OUT>
This contains all logical related to process records from single input.interface
ProcessFunction
Base class for all user defined process functions.interface
TwoInputBroadcastStreamProcessFunction<IN1,IN2,OUT>
This contains all logical related to process records from a broadcast stream and a non-broadcast stream.interface
TwoInputNonBroadcastStreamProcessFunction<IN1,IN2,OUT>
This contains all logical related to process records from two non-broadcast input.interface
TwoOutputApplyPartitionFunction<OUT1,OUT2>
A function to be applied to all partitions with two outputs.interface
TwoOutputStreamProcessFunction<IN,OUT1,OUT2>
This contains all logical related to process and emit records to two output streams. -
Uses of Function in org.apache.flink.hadoopcompatibility.mapred
Classes in org.apache.flink.hadoopcompatibility.mapred that implement Function Modifier and Type Class Description class
HadoopMapFunction<KEYIN,VALUEIN,KEYOUT,VALUEOUT>
This wrapper maps a Hadoop Mapper (mapred API) to a Flink FlatMapFunction.class
HadoopReducerWrappedFunction<KEYIN,VALUEIN,KEYOUT,VALUEOUT>
This wrapper maps a Hadoop Reducer (mapred API) to a Flink window function. -
Uses of Function in org.apache.flink.python.legacy
Classes in org.apache.flink.python.legacy that implement Function Modifier and Type Class Description class
IdPartitioner
Partitioner that partitions by id. -
Uses of Function in org.apache.flink.python.util
Classes in org.apache.flink.python.util that implement Function Modifier and Type Class Description static class
PythonConnectorUtils.RowRowMapper
-
Uses of Function in org.apache.flink.runtime.asyncprocessing.operators
Classes in org.apache.flink.runtime.asyncprocessing.operators with type parameters of type Function Modifier and Type Class Description class
AbstractAsyncStateUdfStreamOperator<OUT,F extends Function>
This is used as the base class for operators that have a user-defined function.Fields in org.apache.flink.runtime.asyncprocessing.operators declared as Function Modifier and Type Field Description protected F
AbstractAsyncStateUdfStreamOperator. userFunction
The user function. -
Uses of Function in org.apache.flink.runtime.iterative.task
Classes in org.apache.flink.runtime.iterative.task with type parameters of type Function Modifier and Type Class Description class
AbstractIterativeTask<S extends Function,OT>
The abstract base class for all tasks able to participate in an iteration.class
IterationHeadTask<X,Y,S extends Function,OT>
The head is responsible for coordinating an iteration and can run aDriver
inside.class
IterationIntermediateTask<S extends Function,OT>
An intermediate iteration task, which runs aDriver
inside.class
IterationTailTask<S extends Function,OT>
An iteration tail, which runs a driver inside. -
Uses of Function in org.apache.flink.runtime.operators
Classes in org.apache.flink.runtime.operators with type parameters of type Function Modifier and Type Class Description class
BatchTask<S extends Function,OT>
The base class for all batch tasks.interface
Driver<S extends Function,OT>
The interface to be implemented by all drivers that run alone (or as the primary driver) in a task.interface
ResettableDriver<S extends Function,OT>
This interface marks aDriver
as resettable, meaning that will reset part of their internal state but otherwise reuse existing data structures.Fields in org.apache.flink.runtime.operators declared as Function Modifier and Type Field Description protected S
BatchTask. stub
The instantiated user code of this task's main operator (driver).Methods in org.apache.flink.runtime.operators that return Function Modifier and Type Method Description Function
NoOpChainedDriver. getStub()
Methods in org.apache.flink.runtime.operators that return types with arguments of type Function Modifier and Type Method Description Class<Function>
UnionWithTempOperator. getStubType()
Methods in org.apache.flink.runtime.operators with parameters of type Function Modifier and Type Method Description static void
BatchTask. closeUserCode(Function stub)
Closes the given stub using itsRichFunction.close()
method.static void
BatchTask. openUserCode(Function stub, Configuration parameters)
Opens the given stub using itsRichFunction.open(OpenContext)
method.Method parameters in org.apache.flink.runtime.operators with type arguments of type Function Modifier and Type Method Description void
UnionWithTempOperator. setup(TaskContext<Function,T> context)
-
Uses of Function in org.apache.flink.runtime.operators.chaining
Methods in org.apache.flink.runtime.operators.chaining that return Function Modifier and Type Method Description Function
ChainedAllReduceDriver. getStub()
abstract Function
ChainedDriver. getStub()
Function
ChainedFlatMapDriver. getStub()
Function
ChainedMapDriver. getStub()
Function
ChainedReduceCombineDriver. getStub()
Function
SynchronousChainedCombineDriver. getStub()
-
Uses of Function in org.apache.flink.runtime.operators.udf
Classes in org.apache.flink.runtime.operators.udf that implement Function Modifier and Type Class Description class
AssignRangeIndex<IN>
This mapPartition function require a DataSet with RangeBoundaries as broadcast input, it generate Tuple2 which includes range index and record itself as output.class
RangeBoundaryBuilder<T>
Build RangeBoundaries with input records.class
RemoveRangeIndex<T>
-
Uses of Function in org.apache.flink.runtime.operators.util
Methods in org.apache.flink.runtime.operators.util with type parameters of type Function Modifier and Type Method Description <S extends Function,OT>
Class<? extends Driver<S,OT>>TaskConfig. getDriver()
-
Uses of Function in org.apache.flink.sql.tests
Classes in org.apache.flink.sql.tests that implement Function Modifier and Type Class Description static class
StreamSQLTestProgram.Generator
Data-generating source function.static class
StreamSQLTestProgram.KillMapper
Kills the first execution attempt of an application when it receives the second record. -
Uses of Function in org.apache.flink.state.api.functions
Subinterfaces of Function in org.apache.flink.state.api.functions Modifier and Type Interface Description interface
Timestamper<T>
Assigns an event time timestamp to the given record.Classes in org.apache.flink.state.api.functions that implement Function Modifier and Type Class Description class
BroadcastStateBootstrapFunction<IN>
Interface for writing elements to broadcast state.class
KeyedStateBootstrapFunction<K,IN>
A function that writes keyed state to a new operator.class
KeyedStateReaderFunction<K,OUT>
A function that processes keys from a restored operatorclass
StateBootstrapFunction<IN>
Interface for writing elements to operator state.class
WindowReaderFunction<IN,OUT,KEY,W extends Window>
Base abstract class for functions that are evaluated over keyed (grouped) windows using a context for retrieving extra information. -
Uses of Function in org.apache.flink.state.api.input.operator
Classes in org.apache.flink.state.api.input.operator with type parameters of type Function Modifier and Type Class Description class
StateReaderOperator<F extends Function,KEY,N,OUT>
Base class for executing functions that read keyed state.Fields in org.apache.flink.state.api.input.operator declared as Function Modifier and Type Field Description protected F
StateReaderOperator. function
-
Uses of Function in org.apache.flink.state.api.input.operator.window
Classes in org.apache.flink.state.api.input.operator.window that implement Function Modifier and Type Class Description class
AggregateEvictingWindowReaderFunction<IN,ACC,R,OUT,KEY,W extends Window>
A wrapper for reading an evicting window operator with an aggregate function.class
EvictingWindowReaderFunction<IN,R,OUT,KEY,W extends Window>
Wrapper for reading state from an evicting window operator.class
PassThroughReader<KEY,W extends Window,IN>
AWindowReaderFunction
that just emits each input element.class
ProcessEvictingWindowReader<IN,OUT,KEY,W extends Window>
A wrapper function for reading an evicting window with no pre-aggregation.class
ReduceEvictingWindowReaderFunction<IN,OUT,KEY,W extends Window>
A wrapper function for reading state from an evicting window operator with a reduce function. -
Uses of Function in org.apache.flink.state.api.output
Classes in org.apache.flink.state.api.output that implement Function Modifier and Type Class Description class
MergeOperatorStates
A reducer that aggregates multipleOperatorState
's into a singleCheckpointMetadata
.class
OperatorSubtaskStateReducer
A reducer that aggregates allOperatorSubtaskState
's for a particular operator into a singleOperatorState
.class
StatePathExtractor
Extracts all file paths that are part of the providedOperatorState
. -
Uses of Function in org.apache.flink.streaming.api.checkpoint
Subinterfaces of Function in org.apache.flink.streaming.api.checkpoint Modifier and Type Interface Description interface
ExternallyInducedSource<T,CD>
Deprecated.This interface is based on theSourceFunction
API, which is due to be removed. -
Uses of Function in org.apache.flink.streaming.api.functions
Classes in org.apache.flink.streaming.api.functions that implement Function Modifier and Type Class Description class
KeyedProcessFunction<K,I,O>
A keyed function that processes elements of a stream.class
ProcessFunction<I,O>
A function that processes elements of a stream. -
Uses of Function in org.apache.flink.streaming.api.functions.aggregation
Classes in org.apache.flink.streaming.api.functions.aggregation that implement Function Modifier and Type Class Description class
AggregationFunction<T>
Holder class for aggregation types that can be used on a windowed stream or keyed stream.class
ComparableAggregator<T>
AnAggregationFunction
that computes values based on comparisons ofComparables
.class
SumAggregator<T>
AnAggregationFunction
that sums up fields. -
Uses of Function in org.apache.flink.streaming.api.functions.async
Subinterfaces of Function in org.apache.flink.streaming.api.functions.async Modifier and Type Interface Description interface
AsyncFunction<IN,OUT>
A function to trigger Async I/O operation.Classes in org.apache.flink.streaming.api.functions.async that implement Function Modifier and Type Class Description class
RichAsyncFunction<IN,OUT>
Rich variant of theAsyncFunction
. -
Uses of Function in org.apache.flink.streaming.api.functions.co
Subinterfaces of Function in org.apache.flink.streaming.api.functions.co Modifier and Type Interface Description interface
CoFlatMapFunction<IN1,IN2,OUT>
A CoFlatMapFunction implements a flat-map transformation over two connected streams.interface
CoMapFunction<IN1,IN2,OUT>
A CoFlatMapFunction implements a map() transformation over two connected streams.Classes in org.apache.flink.streaming.api.functions.co that implement Function Modifier and Type Class Description class
BaseBroadcastProcessFunction
The base class containing the functionality available to all broadcast process function.class
BroadcastProcessFunction<IN1,IN2,OUT>
A function to be applied to aBroadcastConnectedStream
that connectsBroadcastStream
, i.e.class
CoProcessFunction<IN1,IN2,OUT>
A function that processes elements of two streams and produces a single output one.class
KeyedBroadcastProcessFunction<KS,IN1,IN2,OUT>
A function to be applied to aBroadcastConnectedStream
that connectsBroadcastStream
, i.e.class
KeyedCoProcessFunction<K,IN1,IN2,OUT>
A function that processes elements of two keyed streams and produces a single output one.class
ProcessJoinFunction<IN1,IN2,OUT>
A function that processes two joined elements and produces a single output one.class
RichCoFlatMapFunction<IN1,IN2,OUT>
A RichCoFlatMapFunction represents a FlatMap transformation with two different input types.class
RichCoMapFunction<IN1,IN2,OUT>
A RichCoMapFunction represents a Map transformation with two different input types. -
Uses of Function in org.apache.flink.streaming.api.functions.python
Classes in org.apache.flink.streaming.api.functions.python that implement Function Modifier and Type Class Description class
KeyByKeySelector
KeyByKeySelector
is responsible for extracting the first field of the input row as key.class
PartitionCustomKeySelector
ThePartitionCustomKeySelector
will return the first field of the input row value. -
Uses of Function in org.apache.flink.streaming.api.functions.python.eventtime
Classes in org.apache.flink.streaming.api.functions.python.eventtime that implement Function Modifier and Type Class Description class
RemoveTimestampMapFunction<T>
MapFunction which removes the timestamp field from the input element. -
Uses of Function in org.apache.flink.streaming.api.functions.sink.filesystem.legacy
Classes in org.apache.flink.streaming.api.functions.sink.filesystem.legacy that implement Function Modifier and Type Class Description class
StreamingFileSink<IN>
Deprecated.UseFileSink
instead. -
Uses of Function in org.apache.flink.streaming.api.functions.sink.legacy
Subinterfaces of Function in org.apache.flink.streaming.api.functions.sink.legacy Modifier and Type Interface Description interface
SinkFunction<IN>
Deprecated.This interface will be removed in future versions.Classes in org.apache.flink.streaming.api.functions.sink.legacy that implement Function Modifier and Type Class Description class
DiscardingSink<T>
Deprecated.This interface will be removed in future versions.class
OutputFormatSinkFunction<IN>
Deprecated.Please use theStreamingFileSink
for writing to files from a streaming program.class
PrintSinkFunction<IN>
Deprecated.This interface will be removed in future versions.class
RichSinkFunction<IN>
Deprecated.This interface will be removed in future versions.class
SocketClientSink<IN>
Deprecated.This interface will be removed in future versions.class
TwoPhaseCommitSinkFunction<IN,TXN,CONTEXT>
Deprecated.This interface will be removed in future versions. -
Uses of Function in org.apache.flink.streaming.api.functions.source.datagen
Classes in org.apache.flink.streaming.api.functions.source.datagen that implement Function Modifier and Type Class Description class
DataGeneratorSource<T>
Deprecated.Useorg.apache.flink.connector.datagen.source.DataGeneratorSource
instead. -
Uses of Function in org.apache.flink.streaming.api.functions.source.legacy
Subinterfaces of Function in org.apache.flink.streaming.api.functions.source.legacy Modifier and Type Interface Description interface
ParallelSourceFunction<OUT>
Deprecated.This interface is based on theSourceFunction
API, which is due to be removed.interface
SourceFunction<T>
Deprecated.This interface will be removed in future versions.Classes in org.apache.flink.streaming.api.functions.source.legacy that implement Function Modifier and Type Class Description class
ContinuousFileMonitoringFunction<OUT>
Deprecated.This class is based on theSourceFunction
API, which is due to be removed.class
FileMonitoringFunction
Deprecated.Internal class deprecated in favour ofContinuousFileMonitoringFunction
.class
FileReadFunction
Deprecated.Internal class deprecated in favour ofContinuousFileMonitoringFunction
.class
FromElementsFunction<T>
Deprecated.This class is based on theSourceFunction
API, which is due to be removed.class
FromIteratorFunction<T>
Deprecated.This class is based on theSourceFunction
API, which is due to be removed.class
FromSplittableIteratorFunction<T>
Deprecated.This class is based on theSourceFunction
API, which is due to be removed.class
InputFormatSourceFunction<OUT>
Deprecated.This class is based on theSourceFunction
API, which is due to be removed.class
RichParallelSourceFunction<OUT>
Deprecated.This class is based on theSourceFunction
API, which is due to be removed.class
RichSourceFunction<OUT>
Deprecated.This class is based on theSourceFunction
API, which is due to be removed.class
SocketTextStreamFunction
Deprecated.This class is based on theSourceFunction
API, which is due to be removed.class
StatefulSequenceSource
Deprecated.This class is based on theSourceFunction
API, which is due to be removed. -
Uses of Function in org.apache.flink.streaming.api.functions.windowing
Subinterfaces of Function in org.apache.flink.streaming.api.functions.windowing Modifier and Type Interface Description interface
AllWindowFunction<IN,OUT,W extends Window>
Base interface for functions that are evaluated over non-keyed windows.interface
WindowFunction<IN,OUT,KEY,W extends Window>
Base interface for functions that are evaluated over keyed (grouped) windows.Classes in org.apache.flink.streaming.api.functions.windowing that implement Function Modifier and Type Class Description class
AggregateApplyAllWindowFunction<W extends Window,T,ACC,V,R>
class
AggregateApplyWindowFunction<K,W extends Window,T,ACC,V,R>
class
PassThroughAllWindowFunction<W extends Window,T>
AAllWindowFunction
that just emits each input element.class
PassThroughWindowFunction<K,W extends Window,T>
AWindowFunction
that just emits each input element.class
ProcessAllWindowFunction<IN,OUT,W extends Window>
Base abstract class for functions that are evaluated over non-keyed windows using a context for retrieving extra information.class
ProcessWindowFunction<IN,OUT,KEY,W extends Window>
Base abstract class for functions that are evaluated over keyed (grouped) windows using a context for retrieving extra information.class
ReduceApplyAllWindowFunction<W extends Window,T,R>
InternalAllWindowFunction
that is used for implementing a fold on a window configuration that only allowsAllWindowFunction
and cannot directly execute aReduceFunction
.class
ReduceApplyProcessAllWindowFunction<W extends Window,T,R>
InternalProcessAllWindowFunction
that is used for implementing a fold on a window configuration that only allowsAllWindowFunction
and cannot directly execute aReduceFunction
.class
ReduceApplyProcessWindowFunction<K,W extends Window,T,R>
InternalProcessWindowFunction
that is used for implementing a fold on a window configuration that only allowsAllWindowFunction
and cannot directly execute aReduceFunction
.class
ReduceApplyWindowFunction<K,W extends Window,T,R>
InternalWindowFunction
that is used for implementing a fold on a window configuration that only allowsWindowFunction
and cannot directly execute aReduceFunction
.class
RichAllWindowFunction<IN,OUT,W extends Window>
ARichFunction
version ofAllWindowFunction
.class
RichWindowFunction<IN,OUT,KEY,W extends Window>
Rich variant of theWindowFunction
. -
Uses of Function in org.apache.flink.streaming.api.operators
Classes in org.apache.flink.streaming.api.operators with type parameters of type Function Modifier and Type Class Description class
AbstractUdfStreamOperator<OUT,F extends Function>
This is used as the base class for operators that have a user-defined function.interface
UserFunctionProvider<F extends Function>
The interface with user function.Fields in org.apache.flink.streaming.api.operators declared as Function Modifier and Type Field Description protected F
AbstractUdfStreamOperator. userFunction
The user function.Methods in org.apache.flink.streaming.api.operators that return Function Modifier and Type Method Description Function
SimpleUdfStreamOperatorFactory. getUserFunction()
Function
UdfStreamOperatorFactory. getUserFunction()
-
Uses of Function in org.apache.flink.streaming.api.operators.collect
Classes in org.apache.flink.streaming.api.operators.collect that implement Function Modifier and Type Class Description class
CollectSinkFunction<IN>
A sink function that collects query results and sends them back to the client. -
Uses of Function in org.apache.flink.streaming.connectors.wikiedits.legacy
Classes in org.apache.flink.streaming.connectors.wikiedits.legacy that implement Function Modifier and Type Class Description class
WikipediaEditsSource
Deprecated.This class is based on theSourceFunction
API, which is due to be removed. -
Uses of Function in org.apache.flink.streaming.examples.sideoutput
Classes in org.apache.flink.streaming.examples.sideoutput that implement Function Modifier and Type Class Description static class
SideOutputExample.Tokenizer
Implements the string tokenizer that splits sentences into words as a user-defined FlatMapFunction. -
Uses of Function in org.apache.flink.streaming.examples.statemachine.generator
Classes in org.apache.flink.streaming.examples.statemachine.generator that implement Function Modifier and Type Class Description class
EventsGeneratorFunction
A generator function that produces the events on the fly. -
Uses of Function in org.apache.flink.streaming.examples.windowing.util
Classes in org.apache.flink.streaming.examples.windowing.util that implement Function Modifier and Type Class Description class
CarGeneratorFunction
A generator function for simulating car data. -
Uses of Function in org.apache.flink.streaming.examples.wordcount
Classes in org.apache.flink.streaming.examples.wordcount that implement Function Modifier and Type Class Description static class
WordCount.Tokenizer
Implements the string tokenizer that splits sentences into words as a user-defined FlatMapFunction. -
Uses of Function in org.apache.flink.streaming.experimental
Classes in org.apache.flink.streaming.experimental that implement Function Modifier and Type Class Description class
CollectSink<IN>
A specialized data sink to be used by DataStreamUtils.collect(). -
Uses of Function in org.apache.flink.streaming.runtime.operators.windowing
Methods in org.apache.flink.streaming.runtime.operators.windowing with parameters of type Function Modifier and Type Method Description String
WindowOperatorBuilder. generateOperatorDescription(Function function1, Function function2)
-
Uses of Function in org.apache.flink.streaming.runtime.operators.windowing.functions
Subinterfaces of Function in org.apache.flink.streaming.runtime.operators.windowing.functions Modifier and Type Interface Description interface
InternalWindowFunction<IN,OUT,KEY,W extends Window>
Internal interface for functions that are evaluated over keyed (grouped) windows.Classes in org.apache.flink.streaming.runtime.operators.windowing.functions that implement Function Modifier and Type Class Description class
InternalAggregateProcessAllWindowFunction<T,ACC,V,R,W extends Window>
Internal window function for wrapping aProcessAllWindowFunction
that takes anIterable
and anAggregateFunction
.class
InternalAggregateProcessWindowFunction<T,ACC,V,R,K,W extends Window>
Internal window function for wrapping aProcessWindowFunction
that takes anIterable
and anAggregateFunction
.class
InternalIterableAllWindowFunction<IN,OUT,W extends Window>
Internal window function for wrapping anAllWindowFunction
that takes anIterable
when the window state also is anIterable
.class
InternalIterableProcessAllWindowFunction<IN,OUT,W extends Window>
Internal window function for wrapping aProcessAllWindowFunction
that takes anIterable
when the window state also is anIterable
.class
InternalIterableProcessWindowFunction<IN,OUT,KEY,W extends Window>
Internal window function for wrapping aProcessWindowFunction
that takes anIterable
when the window state also is anIterable
.class
InternalIterableWindowFunction<IN,OUT,KEY,W extends Window>
Internal window function for wrapping aWindowFunction
that takes anIterable
when the window state also is anIterable
.class
InternalSingleValueAllWindowFunction<IN,OUT,W extends Window>
Internal window function for wrapping anAllWindowFunction
that takes anIterable
when the window state is a single value.class
InternalSingleValueProcessAllWindowFunction<IN,OUT,W extends Window>
Internal window function for wrapping aProcessAllWindowFunction
that takes anIterable
when the window state is a single value.class
InternalSingleValueProcessWindowFunction<IN,OUT,KEY,W extends Window>
Internal window function for wrapping aProcessWindowFunction
that takes anIterable
when the window state is a single value.class
InternalSingleValueWindowFunction<IN,OUT,KEY,W extends Window>
Internal window function for wrapping aWindowFunction
that takes anIterable
when the window state is a single value. -
Uses of Function in org.apache.flink.streaming.tests
Classes in org.apache.flink.streaming.tests that implement Function Modifier and Type Class Description class
FailureMapper<T>
This mapper simulates failure by throwing exceptions.class
SemanticsCheckMapper
This mapper validates exactly-once and at-least-once semantics in connection withSequenceGeneratorSource
.class
SequenceGeneratorSource
Deprecated.This class is based on theSourceFunction
API, which is due to be removed.class
SlidingWindowCheckMapper
This mapper validates sliding event time window. -
Uses of Function in org.apache.flink.streaming.tests.artificialstate
Classes in org.apache.flink.streaming.tests.artificialstate that implement Function 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. -
Uses of Function in org.apache.flink.streaming.util
Classes in org.apache.flink.streaming.util that implement Function Modifier and Type Class Description class
FiniteTestSource<T>
A stream source that: 1) emits a list of elements without allowing checkpoints, 2) then waits for two more checkpoints to complete, 3) then re-emits the same elements before 4) waiting for another two checkpoints and 5) exiting. -
Uses of Function in org.apache.flink.streaming.util.functions
Methods in org.apache.flink.streaming.util.functions with parameters of type Function Modifier and Type Method Description static void
StreamingFunctionUtils. restoreFunctionState(StateInitializationContext context, Function userFunction)
static <T> void
StreamingFunctionUtils. setOutputType(Function userFunction, TypeInformation<T> outTypeInfo, ExecutionConfig executionConfig)
static void
StreamingFunctionUtils. snapshotFunctionState(StateSnapshotContext context, OperatorStateBackend backend, Function userFunction)
-
Uses of Function in org.apache.flink.streaming.util.keys
Classes in org.apache.flink.streaming.util.keys that implement Function Modifier and Type Class Description static class
KeySelectorUtil.ArrayKeySelector<IN>
A key selector for selecting individual array fields as keys and returns them as a Tuple.static class
KeySelectorUtil.ComparableKeySelector<IN>
A key selector for selecting key fields via a TypeComparator.static class
KeySelectorUtil.OneKeySelector<IN,K>
Key extractor that extracts a single field via a generic comparator. -
Uses of Function in org.apache.flink.table.runtime.arrow.sources
Classes in org.apache.flink.table.runtime.arrow.sources that implement Function Modifier and Type Class Description class
ArrowSourceFunction
Deprecated.This class is based on theSourceFunction
API, which is due to be removed. -
Uses of Function in org.apache.flink.table.runtime.collector
Classes in org.apache.flink.table.runtime.collector that implement Function Modifier and Type Class Description class
ListenableCollector<T>
A listenable collector for lookup join that can be called when an original record was collected.class
TableFunctionCollector<T>
The basic implementation of collector forTableFunction
.class
TableFunctionResultFuture<T>
The basic implementation of collector forResultFuture
in table joining.class
WrappingCollector<T>
ACollector
that wraps another collector. -
Uses of Function in org.apache.flink.table.runtime.functions
Classes in org.apache.flink.table.runtime.functions that implement Function Modifier and Type Class Description class
KeyedProcessFunctionWithCleanupState<K,IN,OUT>
A function that processes elements of a stream, and could cleanup state. -
Uses of Function in org.apache.flink.table.runtime.generated
Classes in org.apache.flink.table.runtime.generated with type parameters of type Function Modifier and Type Class Description class
GeneratedFunction<F extends Function>
Describes a generatedFunction
.Subinterfaces of Function in org.apache.flink.table.runtime.generated Modifier and Type Interface Description interface
AggsHandleFunction
The base class for handling aggregate functions.interface
AggsHandleFunctionBase
The base class for handling aggregate or table aggregate functions.interface
FilterCondition
Interface for code generated filter condition function on single RowData.interface
JoinCondition
Interface for code generated condition function for [[org.apache.calcite.rel.core.Join]].interface
NamespaceAggsHandleFunction<N>
The base class for handling aggregate functions with namespace.interface
NamespaceAggsHandleFunctionBase<N>
The base class for handling aggregate or table aggregate functions.interface
NamespaceTableAggsHandleFunction<N>
The base class for handling table aggregate functions with namespace.interface
TableAggsHandleFunction
The base class for handling table aggregate functions.Classes in org.apache.flink.table.runtime.generated that implement Function Modifier and Type Class Description class
WatermarkGenerator
TheWatermarkGenerator
is used to generate watermark based the input elements. -
Uses of Function in org.apache.flink.table.runtime.keyselector
Subinterfaces of Function in org.apache.flink.table.runtime.keyselector Modifier and Type Interface Description interface
RowDataKeySelector
RowDataKeySelector takes an RowData and extracts the deterministic key for the RowData.Classes in org.apache.flink.table.runtime.keyselector that implement Function Modifier and Type Class Description class
BinaryRowDataKeySelector
A KeySelector which will extract key from RowData.class
EmptyRowDataKeySelector
A utility class which key is always empty no matter what the input row is.class
GenericRowDataKeySelector
A KeySelector which will extract key from RowData. -
Uses of Function in org.apache.flink.table.runtime.operators.aggregate
Classes in org.apache.flink.table.runtime.operators.aggregate that implement Function Modifier and Type Class Description class
GroupAggFunction
Aggregate Function used for the groupby (without window) aggregate.class
GroupTableAggFunction
Aggregate Function used for the groupby (without window) table aggregate.class
MiniBatchGlobalGroupAggFunction
Aggregate Function used for the global groupby (without window) aggregate in miniBatch mode.class
MiniBatchGroupAggFunction
Aggregate Function used for the groupby (without window) aggregate in miniBatch mode.class
MiniBatchIncrementalGroupAggFunction
Aggregate Function used for the incremental groupby (without window) aggregate in miniBatch mode.class
MiniBatchLocalGroupAggFunction
Aggregate Function used for the local groupby (without window) aggregate in miniBatch mode. -
Uses of Function in org.apache.flink.table.runtime.operators.bundle
Classes in org.apache.flink.table.runtime.operators.bundle that implement Function Modifier and Type Class Description class
MapBundleFunction<K,V,IN,OUT>
Basic interface for map bundle processing. -
Uses of Function in org.apache.flink.table.runtime.operators.calc.async
Classes in org.apache.flink.table.runtime.operators.calc.async that implement Function Modifier and Type Class Description class
AsyncFunctionRunner
Async function runner forAsyncScalarFunction
, which takes the generated function, instantiates it, and then calls its lifecycle methods. -
Uses of Function in org.apache.flink.table.runtime.operators.deduplicate
Classes in org.apache.flink.table.runtime.operators.deduplicate that implement Function Modifier and Type Class Description class
ProcTimeDeduplicateKeepFirstRowFunction
This function is used to deduplicate on keys and keeps only first row.class
ProcTimeDeduplicateKeepLastRowFunction
This function is used to deduplicate on keys and keeps only last row.class
ProcTimeMiniBatchDeduplicateKeepFirstRowFunction
This function is used to get the first row for every key partition in miniBatch mode.class
ProcTimeMiniBatchDeduplicateKeepLastRowFunction
This function is used to get the last row for every key partition in miniBatch mode.class
RowTimeDeduplicateFunction
This function is used to deduplicate on keys and keeps only first or last row on row time.class
RowTimeMiniBatchDeduplicateFunction
This function is used to get the first or last row for every key partition in miniBatch mode.class
RowTimeMiniBatchLatestChangeDeduplicateFunction
This function is used to get the first or last row for every key partition in miniBatch mode. -
Uses of Function in org.apache.flink.table.runtime.operators.join
Classes in org.apache.flink.table.runtime.operators.join that implement Function Modifier and Type Class Description class
JoinConditionWithNullFilters
Utility to take null filters into consideration when apply join condition. -
Uses of Function in org.apache.flink.table.runtime.operators.join.interval
Classes in org.apache.flink.table.runtime.operators.join.interval that implement Function Modifier and Type Class Description class
FilterAllFlatMapFunction
Function filtering out all the input records.class
IntervalJoinFunction
class
PaddingLeftMapFunction
Function performing left padding.class
PaddingRightMapFunction
Function performing right padding.class
ProcTimeIntervalJoin
The function to execute processing time interval stream inner-join.class
RowTimeIntervalJoin
The function to execute row(event) time interval stream inner-join. -
Uses of Function in org.apache.flink.table.runtime.operators.join.lookup
Classes in org.apache.flink.table.runtime.operators.join.lookup that implement Function Modifier and Type Class Description class
AsyncLookupJoinRunner
The async join runner to lookup the dimension table.class
AsyncLookupJoinWithCalcRunner
The async join runner with an additional calculate function on the dimension table.class
KeyedLookupJoinWrapper
The lookup join handler which holds aLookupJoinRunner
to process lookup for insert or update_after record and directly process delete and update_before record via local state.class
LookupJoinRunner
The join runner to lookup the dimension table.class
LookupJoinWithCalcRunner
The join runner with an additional calculate function on the dimension table. -
Uses of Function in org.apache.flink.table.runtime.operators.match
Classes in org.apache.flink.table.runtime.operators.match that implement Function Modifier and Type Class Description class
IterativeConditionRunner
ARichIterativeCondition
wrapper to delegate invocation to the code generatedRichIterativeCondition
.class
PatternProcessFunctionRunner
APatternProcessFunction
wrapper to delegate invocation to the code generatedPatternProcessFunction
. -
Uses of Function in org.apache.flink.table.runtime.operators.misc
Classes in org.apache.flink.table.runtime.operators.misc that implement Function Modifier and Type Class Description class
DropUpdateBeforeFunction
A function drops only rows withRowKind.UPDATE_BEFORE
changelog kind. -
Uses of Function in org.apache.flink.table.runtime.operators.over
Classes in org.apache.flink.table.runtime.operators.over that implement Function Modifier and Type Class Description class
AbstractRowTimeUnboundedPrecedingOver<K>
A basic implementation to support unbounded event-time over-window.class
ProcTimeRangeBoundedPrecedingFunction<K>
Process Function used for the aggregate in bounded proc-time OVER window.class
ProcTimeRowsBoundedPrecedingFunction<K>
Process Function for ROW clause processing-time bounded OVER window.class
ProcTimeUnboundedPrecedingFunction<K>
Process Function for processing-time unbounded OVER window.class
RowTimeRangeBoundedPrecedingFunction<K>
Process Function for RANGE clause event-time bounded OVER window.class
RowTimeRangeUnboundedPrecedingFunction<K>
A ProcessFunction to support unbounded RANGE window.class
RowTimeRowsBoundedPrecedingFunction<K>
Process Function for ROWS clause event-time bounded OVER window.class
RowTimeRowsUnboundedPrecedingFunction<K>
A ProcessFunction to support unbounded ROWS window. -
Uses of Function in org.apache.flink.table.runtime.operators.rank
Classes in org.apache.flink.table.runtime.operators.rank that implement Function Modifier and Type Class Description class
AbstractTopNFunction
Base class for TopN Function.class
AppendOnlyFirstNFunction
A variant ofAppendOnlyTopNFunction
to handle first-n case.class
AppendOnlyTopNFunction
A TopN function could handle insert-only stream.class
FastTop1Function
A more concise implementation forAppendOnlyTopNFunction
andUpdatableTopNFunction
when only Top-1 is desired.class
RetractableTopNFunction
A TopN function could handle updating stream.class
UpdatableTopNFunction
A TopN function could handle updating stream. -
Uses of Function in org.apache.flink.table.runtime.operators.wmassigners
Classes in org.apache.flink.table.runtime.operators.wmassigners that implement Function Modifier and Type Class Description class
BoundedOutOfOrderWatermarkGenerator
A watermark generator for rowtime attributes which are out-of-order by a bounded time interval. -
Uses of Function in org.apache.flink.table.sinks
Classes in org.apache.flink.table.sinks that implement Function 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 Function in org.apache.flink.table.toolbox
Classes in org.apache.flink.table.toolbox that implement Function Modifier and Type Class Description class
TestSourceFunction
A source function used to test. -
Uses of Function in org.apache.flink.test
Classes in org.apache.flink.test that implement Function Modifier and Type Class Description static class
StatefulStreamingJob.MySource
Stub source that emits one record per second.static class
StatefulStreamingJob.MyStatefulFunction
A statefulRichMapFunction
that keeps the required types of state. -
Uses of Function in org.apache.flink.test.streaming.runtime.util
Classes in org.apache.flink.test.streaming.runtime.util that implement Function Modifier and Type Class Description class
TestListResultSink<T>
Thread-safe sink for collecting elements into an on-heap list. -
Uses of Function in org.apache.flink.walkthrough.common.sink
Classes in org.apache.flink.walkthrough.common.sink that implement Function Modifier and Type Class Description class
AlertSink
Deprecated. -
Uses of Function in org.apache.flink.walkthrough.common.source
Classes in org.apache.flink.walkthrough.common.source that implement Function Modifier and Type Class Description class
TransactionSource
Deprecated.This class is based on theSourceFunction
API, which is due to be removed.
-