Package | Description |
---|---|
org.apache.flink.streaming.api.datastream | |
org.apache.flink.streaming.api.functions | |
org.apache.flink.streaming.api.functions.timestamps | |
org.apache.flink.streaming.api.operators | |
org.apache.flink.streaming.runtime.operators |
This package contains the operators that perform the stream transformations.
|
Class and Description |
---|
AssignerWithPeriodicWatermarks
The
AssignerWithPeriodicWatermarks assigns event time timestamps to elements,
and generates low watermarks that signal event time progress within the stream. |
AssignerWithPunctuatedWatermarks
The
AssignerWithPunctuatedWatermarks assigns event time timestamps to elements,
and generates low watermarks that signal event time progress within the stream. |
KeyedProcessFunction
A keyed function that processes elements of a stream.
|
ProcessFunction
A function that processes elements of a stream.
|
TimestampExtractor
Deprecated.
This class has been replaced by
AssignerWithPeriodicWatermarks and
AssignerWithPunctuatedWatermarks |
Class and Description |
---|
AssignerWithPeriodicWatermarks
The
AssignerWithPeriodicWatermarks assigns event time timestamps to elements,
and generates low watermarks that signal event time progress within the stream. |
TimestampAssigner
A
TimestampAssigner assigns event time timestamps to elements. |
Class and Description |
---|
KeyedProcessFunction
A keyed function that processes elements of a stream.
|
ProcessFunction
A function that processes elements of a stream.
|
Class and Description |
---|
AssignerWithPeriodicWatermarks
The
AssignerWithPeriodicWatermarks assigns event time timestamps to elements,
and generates low watermarks that signal event time progress within the stream. |
AssignerWithPunctuatedWatermarks
The
AssignerWithPunctuatedWatermarks assigns event time timestamps to elements,
and generates low watermarks that signal event time progress within the stream. |
TimestampExtractor
Deprecated.
This class has been replaced by
AssignerWithPeriodicWatermarks and
AssignerWithPunctuatedWatermarks |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.