Package | Description |
---|---|
org.apache.flink.cep | |
org.apache.flink.cep.operator | |
org.apache.flink.streaming.api.datastream | |
org.apache.flink.streaming.python.api.datastream |
Modifier and Type | Method and Description |
---|---|
<L,R> SingleOutputStreamOperator<R> |
PatternStream.flatSelect(OutputTag<L> timeoutOutputTag,
PatternFlatTimeoutFunction<T,L> patternFlatTimeoutFunction,
PatternFlatSelectFunction<T,R> patternFlatSelectFunction)
Applies a flat select function to the detected pattern sequence.
|
<L,R> SingleOutputStreamOperator<R> |
PatternStream.flatSelect(OutputTag<L> timeoutOutputTag,
PatternFlatTimeoutFunction<T,L> patternFlatTimeoutFunction,
TypeInformation<R> outTypeInfo,
PatternFlatSelectFunction<T,R> patternFlatSelectFunction)
Applies a flat select function to the detected pattern sequence.
|
<R> SingleOutputStreamOperator<R> |
PatternStream.flatSelect(PatternFlatSelectFunction<T,R> patternFlatSelectFunction)
Applies a flat select function to the detected pattern sequence.
|
<R> SingleOutputStreamOperator<R> |
PatternStream.flatSelect(PatternFlatSelectFunction<T,R> patternFlatSelectFunction,
TypeInformation<R> outTypeInfo)
Applies a flat select function to the detected pattern sequence.
|
<L,R> SingleOutputStreamOperator<Either<L,R>> |
PatternStream.flatSelect(PatternFlatTimeoutFunction<T,L> patternFlatTimeoutFunction,
PatternFlatSelectFunction<T,R> patternFlatSelectFunction)
Deprecated.
Use
PatternStream.flatSelect(OutputTag, PatternFlatTimeoutFunction, PatternFlatSelectFunction)
that returns timed out events as a side-output |
<L,R> SingleOutputStreamOperator<R> |
PatternStream.select(OutputTag<L> timeoutOutputTag,
PatternTimeoutFunction<T,L> patternTimeoutFunction,
PatternSelectFunction<T,R> patternSelectFunction)
Applies a select function to the detected pattern sequence.
|
<L,R> SingleOutputStreamOperator<R> |
PatternStream.select(OutputTag<L> timeoutOutputTag,
PatternTimeoutFunction<T,L> patternTimeoutFunction,
TypeInformation<R> outTypeInfo,
PatternSelectFunction<T,R> patternSelectFunction)
Applies a select function to the detected pattern sequence.
|
<R> SingleOutputStreamOperator<R> |
PatternStream.select(PatternSelectFunction<T,R> patternSelectFunction)
Applies a select function to the detected pattern sequence.
|
<R> SingleOutputStreamOperator<R> |
PatternStream.select(PatternSelectFunction<T,R> patternSelectFunction,
TypeInformation<R> outTypeInfo)
Applies a select function to the detected pattern sequence.
|
<L,R> SingleOutputStreamOperator<Either<L,R>> |
PatternStream.select(PatternTimeoutFunction<T,L> patternTimeoutFunction,
PatternSelectFunction<T,R> patternSelectFunction)
Deprecated.
Use
PatternStream.select(OutputTag, PatternTimeoutFunction, PatternSelectFunction)
that returns timed out events as a side-output |
Modifier and Type | Method and Description |
---|---|
static <IN,OUT> SingleOutputStreamOperator<OUT> |
CEPOperatorUtils.createPatternStream(DataStream<IN> inputStream,
Pattern<IN,?> pattern,
EventComparator<IN> comparator,
PatternFlatSelectFunction<IN,OUT> selectFunction,
TypeInformation<OUT> outTypeInfo)
Creates a data stream containing results of
PatternFlatSelectFunction to fully matching event patterns. |
static <IN,OUT> SingleOutputStreamOperator<OUT> |
CEPOperatorUtils.createPatternStream(DataStream<IN> inputStream,
Pattern<IN,?> pattern,
EventComparator<IN> comparator,
PatternSelectFunction<IN,OUT> selectFunction,
TypeInformation<OUT> outTypeInfo)
Creates a data stream containing results of
PatternSelectFunction to fully matching event patterns. |
static <IN,OUT1,OUT2> |
CEPOperatorUtils.createTimeoutPatternStream(DataStream<IN> inputStream,
Pattern<IN,?> pattern,
EventComparator<IN> comparator,
PatternFlatSelectFunction<IN,OUT1> selectFunction,
TypeInformation<OUT1> outTypeInfo,
OutputTag<OUT2> outputTag,
PatternFlatTimeoutFunction<IN,OUT2> timeoutFunction)
Creates a data stream containing results of
PatternFlatSelectFunction to fully matching event patterns and
also timed out partially matched with applied PatternFlatTimeoutFunction as a sideoutput. |
static <IN,OUT1,OUT2> |
CEPOperatorUtils.createTimeoutPatternStream(DataStream<IN> inputStream,
Pattern<IN,?> pattern,
EventComparator<IN> comparator,
PatternSelectFunction<IN,OUT1> selectFunction,
TypeInformation<OUT1> outTypeInfo,
OutputTag<OUT2> outputTag,
PatternTimeoutFunction<IN,OUT2> timeoutFunction)
Creates a data stream containing results of
PatternSelectFunction to fully matching event patterns and
also timed out partially matched with applied PatternTimeoutFunction as a sideoutput. |
Modifier and Type | Class and Description |
---|---|
class |
DataStreamSource<T>
The DataStreamSource represents the starting point of a DataStream.
|
class |
IterativeStream<T>
The iterative data stream represents the start of an iteration in a
DataStream . |
Modifier and Type | Method and Description |
---|---|
<ACC,R> SingleOutputStreamOperator<R> |
AllWindowedStream.aggregate(AggregateFunction<T,ACC,R> function)
Applies the given
AggregateFunction to each window. |
<ACC,R> SingleOutputStreamOperator<R> |
WindowedStream.aggregate(AggregateFunction<T,ACC,R> function)
Applies the given aggregation function to each window.
|
<ACC,R> SingleOutputStreamOperator<R> |
AllWindowedStream.aggregate(AggregateFunction<T,ACC,R> function,
TypeInformation<ACC> accumulatorType,
TypeInformation<R> resultType)
Applies the given
AggregateFunction to each window. |
<ACC,R> SingleOutputStreamOperator<R> |
WindowedStream.aggregate(AggregateFunction<T,ACC,R> function,
TypeInformation<ACC> accumulatorType,
TypeInformation<R> resultType)
Applies the given aggregation function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
AllWindowedStream.aggregate(AggregateFunction<T,ACC,V> aggFunction,
AllWindowFunction<V,R,W> windowFunction)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
AllWindowedStream.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
AllWindowFunction<V,R,W> windowFunction,
TypeInformation<ACC> accumulatorType,
TypeInformation<V> aggregateResultType,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
AllWindowedStream.aggregate(AggregateFunction<T,ACC,V> aggFunction,
ProcessAllWindowFunction<V,R,W> windowFunction)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
AllWindowedStream.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
ProcessAllWindowFunction<V,R,W> windowFunction,
TypeInformation<ACC> accumulatorType,
TypeInformation<V> aggregateResultType,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
WindowedStream.aggregate(AggregateFunction<T,ACC,V> aggFunction,
ProcessWindowFunction<V,R,K,W> windowFunction)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
WindowedStream.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
ProcessWindowFunction<V,R,K,W> windowFunction,
TypeInformation<ACC> accumulatorType,
TypeInformation<V> aggregateResultType,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
WindowedStream.aggregate(AggregateFunction<T,ACC,V> aggFunction,
WindowFunction<V,R,K,W> windowFunction)
Applies the given window function to each window.
|
<ACC,V,R> SingleOutputStreamOperator<R> |
WindowedStream.aggregate(AggregateFunction<T,ACC,V> aggregateFunction,
WindowFunction<V,R,K,W> windowFunction,
TypeInformation<ACC> accumulatorType,
TypeInformation<V> aggregateResultType,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
protected SingleOutputStreamOperator<T> |
KeyedStream.aggregate(AggregationFunction<T> aggregate) |
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.apply(AllWindowFunction<T,R,W> function)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.apply(AllWindowFunction<T,R,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.apply(ReduceFunction<T> reduceFunction,
AllWindowFunction<T,R,W> function)
Deprecated.
|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.apply(ReduceFunction<T> reduceFunction,
AllWindowFunction<T,R,W> function,
TypeInformation<R> resultType)
Deprecated.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.apply(ReduceFunction<T> reduceFunction,
WindowFunction<T,R,K,W> function)
Deprecated.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.apply(ReduceFunction<T> reduceFunction,
WindowFunction<T,R,K,W> function,
TypeInformation<R> resultType)
Deprecated.
|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.apply(R initialValue,
FoldFunction<T,R> foldFunction,
AllWindowFunction<R,R,W> function)
Deprecated.
|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.apply(R initialValue,
FoldFunction<T,R> foldFunction,
AllWindowFunction<R,R,W> function,
TypeInformation<R> resultType)
Deprecated.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.apply(R initialValue,
FoldFunction<T,R> foldFunction,
WindowFunction<R,R,K,W> function)
Deprecated.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.apply(R initialValue,
FoldFunction<T,R> foldFunction,
WindowFunction<R,R,K,W> function,
TypeInformation<R> resultType)
Deprecated.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.apply(WindowFunction<T,R,K,W> function)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.apply(WindowFunction<T,R,K,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
SingleOutputStreamOperator<T> |
DataStream.assignTimestamps(TimestampExtractor<T> extractor)
|
SingleOutputStreamOperator<T> |
DataStream.assignTimestampsAndWatermarks(AssignerWithPeriodicWatermarks<T> timestampAndWatermarkAssigner)
Assigns timestamps to the elements in the data stream and periodically creates
watermarks to signal event time progress.
|
SingleOutputStreamOperator<T> |
DataStream.assignTimestampsAndWatermarks(AssignerWithPunctuatedWatermarks<T> timestampAndWatermarkAssigner)
Assigns timestamps to the elements in the data stream and creates watermarks to
signal event time progress based on the elements themselves.
|
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.disableChaining()
Turns off chaining for this operator so thread co-location will not be used as an
optimization.
|
SingleOutputStreamOperator<T> |
DataStream.filter(FilterFunction<T> filter)
Applies a Filter transformation on a
DataStream . |
<R> SingleOutputStreamOperator<R> |
ConnectedStreams.flatMap(CoFlatMapFunction<IN1,IN2,R> coFlatMapper)
Applies a CoFlatMap transformation on a
ConnectedStreams and
maps the output to a common type. |
<R> SingleOutputStreamOperator<R> |
DataStream.flatMap(FlatMapFunction<T,R> flatMapper)
Applies a FlatMap transformation on a
DataStream . |
<ACC,R> SingleOutputStreamOperator<R> |
AllWindowedStream.fold(ACC initialValue,
FoldFunction<T,ACC> foldFunction,
AllWindowFunction<ACC,R,W> function)
Deprecated.
|
<ACC,R> SingleOutputStreamOperator<R> |
AllWindowedStream.fold(ACC initialValue,
FoldFunction<T,ACC> foldFunction,
AllWindowFunction<ACC,R,W> function,
TypeInformation<ACC> foldAccumulatorType,
TypeInformation<R> resultType)
|
<ACC,R> SingleOutputStreamOperator<R> |
AllWindowedStream.fold(ACC initialValue,
FoldFunction<T,ACC> foldFunction,
ProcessAllWindowFunction<ACC,R,W> function)
Deprecated.
|
<ACC,R> SingleOutputStreamOperator<R> |
AllWindowedStream.fold(ACC initialValue,
FoldFunction<T,ACC> foldFunction,
ProcessAllWindowFunction<ACC,R,W> function,
TypeInformation<ACC> foldAccumulatorType,
TypeInformation<R> resultType)
|
<R,ACC> SingleOutputStreamOperator<R> |
WindowedStream.fold(ACC initialValue,
FoldFunction<T,ACC> foldFunction,
ProcessWindowFunction<ACC,R,K,W> windowFunction)
Deprecated.
|
<R,ACC> SingleOutputStreamOperator<R> |
WindowedStream.fold(ACC initialValue,
FoldFunction<T,ACC> foldFunction,
ProcessWindowFunction<ACC,R,K,W> windowFunction,
TypeInformation<ACC> foldResultType,
TypeInformation<R> windowResultType)
|
<ACC,R> SingleOutputStreamOperator<R> |
WindowedStream.fold(ACC initialValue,
FoldFunction<T,ACC> foldFunction,
WindowFunction<ACC,R,K,W> function)
Deprecated.
|
<ACC,R> SingleOutputStreamOperator<R> |
WindowedStream.fold(ACC initialValue,
FoldFunction<T,ACC> foldFunction,
WindowFunction<ACC,R,K,W> function,
TypeInformation<ACC> foldAccumulatorType,
TypeInformation<R> resultType)
|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.fold(R initialValue,
FoldFunction<T,R> function)
Deprecated.
use
AllWindowedStream.aggregate(AggregateFunction) instead |
<R> SingleOutputStreamOperator<R> |
WindowedStream.fold(R initialValue,
FoldFunction<T,R> function)
Deprecated.
use
WindowedStream.aggregate(AggregationFunction) instead |
<R> SingleOutputStreamOperator<R> |
KeyedStream.fold(R initialValue,
FoldFunction<T,R> folder)
Deprecated.
will be removed in a future version
|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.fold(R initialValue,
FoldFunction<T,R> function,
TypeInformation<R> resultType)
Deprecated.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.fold(R initialValue,
FoldFunction<T,R> function,
TypeInformation<R> resultType)
Deprecated.
|
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.forceNonParallel()
Sets the parallelism and maximum parallelism of this operator to one.
|
<R> SingleOutputStreamOperator<R> |
ConnectedStreams.map(CoMapFunction<IN1,IN2,R> coMapper)
Applies a CoMap transformation on a
ConnectedStreams and maps
the output to a common type. |
<R> SingleOutputStreamOperator<R> |
DataStream.map(MapFunction<T,R> mapper)
Applies a Map transformation on a
DataStream . |
SingleOutputStreamOperator<T> |
AllWindowedStream.max(int positionToMax)
Applies an aggregation that gives the maximum value of every window of
the data stream at the given position.
|
SingleOutputStreamOperator<T> |
WindowedStream.max(int positionToMax)
Applies an aggregation that gives the maximum value of every window of
the data stream at the given position.
|
SingleOutputStreamOperator<T> |
KeyedStream.max(int positionToMax)
Applies an aggregation that gives the current maximum of the data stream
at the given position by the given key.
|
SingleOutputStreamOperator<T> |
AllWindowedStream.max(String field)
Applies an aggregation that that gives the maximum value of the pojo data
stream at the given field expression for every window.
|
SingleOutputStreamOperator<T> |
WindowedStream.max(String field)
Applies an aggregation that that gives the maximum value of the pojo data
stream at the given field expression for every window.
|
SingleOutputStreamOperator<T> |
KeyedStream.max(String field)
Applies an aggregation that gives the current maximum of the
data stream at the given field expression by the given key.
|
SingleOutputStreamOperator<T> |
AllWindowedStream.maxBy(int positionToMaxBy)
Applies an aggregation that gives the maximum element of every window of
the data stream by the given position.
|
SingleOutputStreamOperator<T> |
WindowedStream.maxBy(int positionToMaxBy)
Applies an aggregation that gives the maximum element of every window of
the data stream by the given position.
|
SingleOutputStreamOperator<T> |
KeyedStream.maxBy(int positionToMaxBy)
Applies an aggregation that gives the current element with the
maximum value at the given position by the given key.
|
SingleOutputStreamOperator<T> |
AllWindowedStream.maxBy(int positionToMaxBy,
boolean first)
Applies an aggregation that gives the maximum element of every window of
the data stream by the given position.
|
SingleOutputStreamOperator<T> |
WindowedStream.maxBy(int positionToMaxBy,
boolean first)
Applies an aggregation that gives the maximum element of every window of
the data stream by the given position.
|
SingleOutputStreamOperator<T> |
KeyedStream.maxBy(int positionToMaxBy,
boolean first)
Applies an aggregation that gives the current element with the
maximum value at the given position by the given key.
|
SingleOutputStreamOperator<T> |
AllWindowedStream.maxBy(String positionToMaxBy)
Applies an aggregation that gives the maximum element of every window of
the data stream by the given position.
|
SingleOutputStreamOperator<T> |
WindowedStream.maxBy(String field)
Applies an aggregation that gives the maximum element of every window of
the data stream by the given field.
|
SingleOutputStreamOperator<T> |
KeyedStream.maxBy(String positionToMaxBy)
Applies an aggregation that gives the current element with the
maximum value at the given position by the given key.
|
SingleOutputStreamOperator<T> |
AllWindowedStream.maxBy(String field,
boolean first)
Applies an aggregation that that gives the maximum element of the pojo
data stream by the given field expression for every window.
|
SingleOutputStreamOperator<T> |
WindowedStream.maxBy(String field,
boolean first)
Applies an aggregation that that gives the maximum element of the pojo
data stream by the given field expression for every window.
|
SingleOutputStreamOperator<T> |
KeyedStream.maxBy(String field,
boolean first)
Applies an aggregation that gives the current maximum element of the
data stream by the given field expression by the given key.
|
SingleOutputStreamOperator<T> |
AllWindowedStream.min(int positionToMin)
Applies an aggregation that that gives the minimum value of every window
of the data stream at the given position.
|
SingleOutputStreamOperator<T> |
WindowedStream.min(int positionToMin)
Applies an aggregation that that gives the minimum value of every window
of the data stream at the given position.
|
SingleOutputStreamOperator<T> |
KeyedStream.min(int positionToMin)
Applies an aggregation that gives the current minimum of the data
stream at the given position by the given key.
|
SingleOutputStreamOperator<T> |
AllWindowedStream.min(String field)
Applies an aggregation that that gives the minimum value of the pojo data
stream at the given field expression for every window.
|
SingleOutputStreamOperator<T> |
WindowedStream.min(String field)
Applies an aggregation that that gives the minimum value of the pojo data
stream at the given field expression for every window.
|
SingleOutputStreamOperator<T> |
KeyedStream.min(String field)
Applies an aggregation that gives the current minimum of the
data stream at the given field expression by the given key.
|
SingleOutputStreamOperator<T> |
AllWindowedStream.minBy(int positionToMinBy)
Applies an aggregation that gives the minimum element of every window of
the data stream by the given position.
|
SingleOutputStreamOperator<T> |
WindowedStream.minBy(int positionToMinBy)
Applies an aggregation that gives the minimum element of every window of
the data stream by the given position.
|
SingleOutputStreamOperator<T> |
KeyedStream.minBy(int positionToMinBy)
Applies an aggregation that gives the current element with the
minimum value at the given position by the given key.
|
SingleOutputStreamOperator<T> |
AllWindowedStream.minBy(int positionToMinBy,
boolean first)
Applies an aggregation that gives the minimum element of every window of
the data stream by the given position.
|
SingleOutputStreamOperator<T> |
WindowedStream.minBy(int positionToMinBy,
boolean first)
Applies an aggregation that gives the minimum element of every window of
the data stream by the given position.
|
SingleOutputStreamOperator<T> |
KeyedStream.minBy(int positionToMinBy,
boolean first)
Applies an aggregation that gives the current element with the
minimum value at the given position by the given key.
|
SingleOutputStreamOperator<T> |
AllWindowedStream.minBy(String positionToMinBy)
Applies an aggregation that gives the minimum element of every window of
the data stream by the given position.
|
SingleOutputStreamOperator<T> |
WindowedStream.minBy(String field)
Applies an aggregation that gives the minimum element of every window of
the data stream by the given field.
|
SingleOutputStreamOperator<T> |
KeyedStream.minBy(String positionToMinBy)
Applies an aggregation that gives the current element with the
minimum value at the given position by the given key.
|
SingleOutputStreamOperator<T> |
AllWindowedStream.minBy(String field,
boolean first)
Applies an aggregation that that gives the minimum element of the pojo
data stream by the given field expression for every window.
|
SingleOutputStreamOperator<T> |
WindowedStream.minBy(String field,
boolean first)
Applies an aggregation that that gives the minimum element of the pojo
data stream by the given field expression for every window.
|
SingleOutputStreamOperator<T> |
KeyedStream.minBy(String field,
boolean first)
Applies an aggregation that gives the current minimum element of the
data stream by the given field expression by the given key.
|
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.name(String name)
Sets the name of the current data stream.
|
static <IN,OUT> SingleOutputStreamOperator<OUT> |
AsyncDataStream.orderedWait(DataStream<IN> in,
AsyncFunction<IN,OUT> func,
long timeout,
TimeUnit timeUnit)
Add an AsyncWaitOperator.
|
static <IN,OUT> SingleOutputStreamOperator<OUT> |
AsyncDataStream.orderedWait(DataStream<IN> in,
AsyncFunction<IN,OUT> func,
long timeout,
TimeUnit timeUnit,
int capacity)
Add an AsyncWaitOperator.
|
<OUT> SingleOutputStreamOperator<OUT> |
BroadcastConnectedStream.process(BroadcastProcessFunction<IN1,IN2,OUT> function)
Assumes as inputs a
BroadcastStream and a non-keyed DataStream and applies the given
BroadcastProcessFunction on them, thereby creating a transformed output stream. |
<OUT> SingleOutputStreamOperator<OUT> |
BroadcastConnectedStream.process(BroadcastProcessFunction<IN1,IN2,OUT> function,
TypeInformation<OUT> outTypeInfo)
Assumes as inputs a
BroadcastStream and a non-keyed DataStream and applies the given
BroadcastProcessFunction on them, thereby creating a transformed output stream. |
<R> SingleOutputStreamOperator<R> |
ConnectedStreams.process(CoProcessFunction<IN1,IN2,R> coProcessFunction)
Applies the given
CoProcessFunction on the connected input streams,
thereby creating a transformed output stream. |
<R> SingleOutputStreamOperator<R> |
ConnectedStreams.process(CoProcessFunction<IN1,IN2,R> coProcessFunction,
TypeInformation<R> outputType)
Applies the given
CoProcessFunction on the connected input streams,
thereby creating a transformed output stream. |
<KS,OUT> SingleOutputStreamOperator<OUT> |
BroadcastConnectedStream.process(KeyedBroadcastProcessFunction<KS,IN1,IN2,OUT> function)
Assumes as inputs a
BroadcastStream and a KeyedStream and applies the given
KeyedBroadcastProcessFunction on them, thereby creating a transformed output stream. |
<KS,OUT> SingleOutputStreamOperator<OUT> |
BroadcastConnectedStream.process(KeyedBroadcastProcessFunction<KS,IN1,IN2,OUT> function,
TypeInformation<OUT> outTypeInfo)
Assumes as inputs a
BroadcastStream and a KeyedStream and applies the given
KeyedBroadcastProcessFunction on them, thereby creating a transformed output stream. |
<R> SingleOutputStreamOperator<R> |
KeyedStream.process(KeyedProcessFunction<KEY,T,R> keyedProcessFunction)
Applies the given
KeyedProcessFunction on the input stream, thereby creating a transformed output stream. |
<R> SingleOutputStreamOperator<R> |
KeyedStream.process(KeyedProcessFunction<KEY,T,R> keyedProcessFunction,
TypeInformation<R> outputType)
Applies the given
KeyedProcessFunction on the input stream, thereby creating a transformed output stream. |
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.process(ProcessAllWindowFunction<T,R,W> function)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.process(ProcessAllWindowFunction<T,R,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
DataStream.process(ProcessFunction<T,R> processFunction)
Applies the given
ProcessFunction on the input stream, thereby
creating a transformed output stream. |
<R> SingleOutputStreamOperator<R> |
KeyedStream.process(ProcessFunction<T,R> processFunction)
Deprecated.
|
<R> SingleOutputStreamOperator<R> |
DataStream.process(ProcessFunction<T,R> processFunction,
TypeInformation<R> outputType)
Applies the given
ProcessFunction on the input stream, thereby
creating a transformed output stream. |
<R> SingleOutputStreamOperator<R> |
KeyedStream.process(ProcessFunction<T,R> processFunction,
TypeInformation<R> outputType)
Deprecated.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.process(ProcessWindowFunction<T,R,K,W> function)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.process(ProcessWindowFunction<T,R,K,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<R extends Tuple> |
DataStream.project(int... fieldIndexes)
Initiates a Project transformation on a
Tuple DataStream .Note: Only Tuple DataStreams can be projected. |
<T0> SingleOutputStreamOperator<Tuple1<T0>> |
StreamProjection.projectTuple1()
Projects a
Tuple DataStream to the previously selected fields. |
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9> |
StreamProjection.projectTuple10()
Projects a
Tuple DataStream to the previously selected fields. |
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10> |
StreamProjection.projectTuple11()
Projects a
Tuple DataStream to the previously selected fields. |
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11> |
StreamProjection.projectTuple12()
Projects a
Tuple DataStream to the previously selected fields. |
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12> |
StreamProjection.projectTuple13()
Projects a
Tuple DataStream to the previously selected fields. |
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13> |
StreamProjection.projectTuple14()
Projects a
Tuple DataStream to the previously selected fields. |
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14> |
StreamProjection.projectTuple15()
Projects a
Tuple DataStream to the previously selected fields. |
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15> |
StreamProjection.projectTuple16()
Projects a
Tuple DataStream to the previously selected fields. |
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16> |
StreamProjection.projectTuple17()
Projects a
Tuple DataStream to the previously selected fields. |
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17> |
StreamProjection.projectTuple18()
Projects a
Tuple DataStream to the previously selected fields. |
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18> |
StreamProjection.projectTuple19()
Projects a
Tuple DataStream to the previously selected fields. |
<T0,T1> SingleOutputStreamOperator<Tuple2<T0,T1>> |
StreamProjection.projectTuple2()
Projects a
Tuple DataStream to the previously selected fields. |
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19> |
StreamProjection.projectTuple20()
Projects a
Tuple DataStream to the previously selected fields. |
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20> |
StreamProjection.projectTuple21()
Projects a
Tuple DataStream to the previously selected fields. |
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21> |
StreamProjection.projectTuple22()
Projects a
Tuple DataStream to the previously selected fields. |
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22> |
StreamProjection.projectTuple23()
Projects a
Tuple DataStream to the previously selected fields. |
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23> |
StreamProjection.projectTuple24()
Projects a
Tuple DataStream to the previously selected fields. |
<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23,T24> |
StreamProjection.projectTuple25()
Projects a
Tuple DataStream to the previously selected fields. |
<T0,T1,T2> SingleOutputStreamOperator<Tuple3<T0,T1,T2>> |
StreamProjection.projectTuple3()
Projects a
Tuple DataStream to the previously selected fields. |
<T0,T1,T2,T3> |
StreamProjection.projectTuple4()
Projects a
Tuple DataStream to the previously selected fields. |
<T0,T1,T2,T3,T4> |
StreamProjection.projectTuple5()
Projects a
Tuple DataStream to the previously selected fields. |
<T0,T1,T2,T3,T4,T5> |
StreamProjection.projectTuple6()
Projects a
Tuple DataStream to the previously selected fields. |
<T0,T1,T2,T3,T4,T5,T6> |
StreamProjection.projectTuple7()
Projects a
Tuple DataStream to the previously selected fields. |
<T0,T1,T2,T3,T4,T5,T6,T7> |
StreamProjection.projectTuple8()
Projects a
Tuple DataStream to the previously selected fields. |
<T0,T1,T2,T3,T4,T5,T6,T7,T8> |
StreamProjection.projectTuple9()
Projects a
Tuple DataStream to the previously selected fields. |
<OUT extends Tuple> |
StreamProjection.projectTupleX()
Chooses a projectTupleX according to the length of
StreamProjection.fieldIndexes . |
SingleOutputStreamOperator<T> |
AllWindowedStream.reduce(ReduceFunction<T> function)
Applies a reduce function to the window.
|
SingleOutputStreamOperator<T> |
WindowedStream.reduce(ReduceFunction<T> function)
Applies a reduce function to the window.
|
SingleOutputStreamOperator<T> |
KeyedStream.reduce(ReduceFunction<T> reducer)
Applies a reduce transformation on the grouped data stream grouped on by
the given key position.
|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.reduce(ReduceFunction<T> reduceFunction,
AllWindowFunction<T,R,W> function)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.reduce(ReduceFunction<T> reduceFunction,
AllWindowFunction<T,R,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.reduce(ReduceFunction<T> reduceFunction,
ProcessAllWindowFunction<T,R,W> function)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
AllWindowedStream.reduce(ReduceFunction<T> reduceFunction,
ProcessAllWindowFunction<T,R,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.reduce(ReduceFunction<T> reduceFunction,
ProcessWindowFunction<T,R,K,W> function)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.reduce(ReduceFunction<T> reduceFunction,
ProcessWindowFunction<T,R,K,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.reduce(ReduceFunction<T> reduceFunction,
WindowFunction<T,R,K,W> function)
Applies the given window function to each window.
|
<R> SingleOutputStreamOperator<R> |
WindowedStream.reduce(ReduceFunction<T> reduceFunction,
WindowFunction<T,R,K,W> function,
TypeInformation<R> resultType)
Applies the given window function to each window.
|
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.returns(Class<T> typeClass)
Adds a type information hint about the return type of this operator.
|
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.returns(String typeInfoString)
Deprecated.
Please use
returns(Class) or returns(TypeHint) instead. |
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.returns(TypeHint<T> typeHint)
Adds a type information hint about the return type of this operator.
|
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.returns(TypeInformation<T> typeInfo)
Adds a type information hint about the return type of this operator.
|
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.setBufferTimeout(long timeoutMillis)
Sets the buffering timeout for data produced by this operation.
|
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.setMaxParallelism(int maxParallelism)
Sets the maximum parallelism of this operator.
|
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.setParallelism(int parallelism)
Sets the parallelism for this operator.
|
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.setUidHash(String uidHash)
Sets an user provided hash for this operator.
|
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.slotSharingGroup(String slotSharingGroup)
Sets the slot sharing group of this operation.
|
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.startNewChain()
Starts a new task chain beginning at this operator.
|
SingleOutputStreamOperator<T> |
AllWindowedStream.sum(int positionToSum)
Applies an aggregation that sums every window of the data stream at the
given position.
|
SingleOutputStreamOperator<T> |
WindowedStream.sum(int positionToSum)
Applies an aggregation that sums every window of the data stream at the
given position.
|
SingleOutputStreamOperator<T> |
KeyedStream.sum(int positionToSum)
Applies an aggregation that gives a rolling sum of the data stream at the
given position grouped by the given key.
|
SingleOutputStreamOperator<T> |
AllWindowedStream.sum(String field)
Applies an aggregation that sums every window of the pojo data stream at
the given field for every window.
|
SingleOutputStreamOperator<T> |
WindowedStream.sum(String field)
Applies an aggregation that sums every window of the pojo data stream at the given field for
every window.
|
SingleOutputStreamOperator<T> |
KeyedStream.sum(String field)
Applies an aggregation that gives the current sum of the data
stream at the given field by the given key.
|
<R> SingleOutputStreamOperator<R> |
DataStream.transform(String operatorName,
TypeInformation<R> outTypeInfo,
OneInputStreamOperator<T,R> operator)
Method for passing user defined operators along with the type
information that will transform the DataStream.
|
<R> SingleOutputStreamOperator<R> |
KeyedStream.transform(String operatorName,
TypeInformation<R> outTypeInfo,
OneInputStreamOperator<T,R> operator) |
<R> SingleOutputStreamOperator<R> |
ConnectedStreams.transform(String functionName,
TypeInformation<R> outTypeInfo,
TwoInputStreamOperator<IN1,IN2,R> operator) |
SingleOutputStreamOperator<T> |
SingleOutputStreamOperator.uid(String uid)
Sets an ID for this operator.
|
static <IN,OUT> SingleOutputStreamOperator<OUT> |
AsyncDataStream.unorderedWait(DataStream<IN> in,
AsyncFunction<IN,OUT> func,
long timeout,
TimeUnit timeUnit)
Add an AsyncWaitOperator.
|
static <IN,OUT> SingleOutputStreamOperator<OUT> |
AsyncDataStream.unorderedWait(DataStream<IN> in,
AsyncFunction<IN,OUT> func,
long timeout,
TimeUnit timeUnit,
int capacity)
Add an AsyncWaitOperator.
|
<T> SingleOutputStreamOperator<T> |
CoGroupedStreams.WithWindow.with(CoGroupFunction<T1,T2,T> function)
Deprecated.
This method will be removed once the
CoGroupedStreams.WithWindow.apply(CoGroupFunction) method is fixed
in the next major version of Flink (2.0). |
<T> SingleOutputStreamOperator<T> |
CoGroupedStreams.WithWindow.with(CoGroupFunction<T1,T2,T> function,
TypeInformation<T> resultType)
Deprecated.
This method will be removed once the
CoGroupedStreams.WithWindow.apply(CoGroupFunction, TypeInformation)
method is fixed in the next major version of Flink (2.0). |
<T> SingleOutputStreamOperator<T> |
JoinedStreams.WithWindow.with(FlatJoinFunction<T1,T2,T> function)
Deprecated.
This method will be removed once the
JoinedStreams.WithWindow.apply(FlatJoinFunction)
method is fixed in the next major version of Flink (2.0). |
<T> SingleOutputStreamOperator<T> |
JoinedStreams.WithWindow.with(FlatJoinFunction<T1,T2,T> function,
TypeInformation<T> resultType)
Deprecated.
This method will be replaced by
JoinedStreams.WithWindow.apply(FlatJoinFunction, TypeInformation) in Flink 2.0.
So use the JoinedStreams.WithWindow.apply(FlatJoinFunction, TypeInformation) in the future. |
<T> SingleOutputStreamOperator<T> |
JoinedStreams.WithWindow.with(JoinFunction<T1,T2,T> function)
Deprecated.
This method will be removed once the
JoinedStreams.WithWindow.apply(JoinFunction) method is fixed
in the next major version of Flink (2.0). |
<T> SingleOutputStreamOperator<T> |
JoinedStreams.WithWindow.with(JoinFunction<T1,T2,T> function,
TypeInformation<T> resultType)
Deprecated.
This method will be removed once the
JoinedStreams.WithWindow.apply(JoinFunction, TypeInformation)
method is fixed in the next major version of Flink (2.0). |
Constructor and Description |
---|
DataStreamSource(SingleOutputStreamOperator<T> operator) |
Modifier and Type | Method and Description |
---|---|
PythonDataStream<SingleOutputStreamOperator<org.python.core.PyObject>> |
PythonDataStream.flat_map(FlatMapFunction<org.python.core.PyObject,Object> flat_mapper)
A thin wrapper layer over
DataStream.flatMap(FlatMapFunction) . |
PythonDataStream<SingleOutputStreamOperator<org.python.core.PyObject>> |
PythonDataStream.map(MapFunction<org.python.core.PyObject,org.python.core.PyObject> mapper)
A thin wrapper layer over
DataStream.map(MapFunction) . |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.