ListCheckpointed
CheckpointedFunction
Checkpointed
AssignerWithPeriodicWatermarks
AssignerWithPunctuatedWatermarks
WindowOperator
AscendingTimestampExtractor
TimestampsAndPeriodicWatermarksOperator
TimestampsAndPunctuatedWatermarksOperator
ContinuousFileMonitoringFunction
ProcessAllWindowFunction
ProcessWindowFunction
SlidingEventTimeWindows
TumblingEventTimeWindows
AllWindowedStream.reduce(ReduceFunction, AllWindowFunction)
AllWindowedStream.reduce(ReduceFunction, AllWindowFunction, TypeInformation)
WindowedStream.reduce(ReduceFunction, WindowFunction)
WindowedStream.reduce(ReduceFunction, WindowFunction, TypeInformation)
AllWindowedStream.fold(Object, FoldFunction, AllWindowFunction)
AllWindowedStream.fold(Object, FoldFunction, AllWindowFunction, TypeInformation, TypeInformation)
WindowedStream.fold(Object, FoldFunction, WindowFunction)
WindowedStream.fold(Object, FoldFunction, WindowFunction, TypeInformation, TypeInformation)
DataStream.assignTimestampsAndWatermarks(AssignerWithPeriodicWatermarks)
DataStream.assignTimestampsAndWatermarks(AssignerWithPunctuatedWatermarks)
StreamExecutionEnvironment.enableCheckpointing(long)
StreamExecutionEnvironment.enableCheckpointing(long, CheckpointingMode)
AllWindowedStream.aggregate(AggregateFunction, ProcessAllWindowFunction)
AllWindowedStream.aggregate(AggregateFunction, AllWindowFunction, TypeInformation, TypeInformation, TypeInformation)
AllWindowedStream.aggregate(AggregateFunction, ProcessAllWindowFunction, TypeInformation, TypeInformation, TypeInformation)
WindowedStream.aggregate(AggregateFunction, WindowFunction)
WindowedStream.aggregate(AggregateFunction, WindowFunction, TypeInformation, TypeInformation, TypeInformation)
WindowedStream.aggregate(AggregateFunction, ProcessWindowFunction, TypeInformation, TypeInformation, TypeInformation)
WindowedStream.aggregate(AggregationFunction)
AllWindowedStream.aggregate(AggregateFunction)
WindowedStream.aggregate(AggregateFunction, TypeInformation, TypeInformation)
AllWindowedStream.aggregate(AggregateFunction, TypeInformation, TypeInformation)
Trigger.TriggerContext.getPartitionedState(StateDescriptor)
StreamExecutionEnvironment.getRestartStrategy()
TumblingEventTimeWindows.of(Time)
SlidingEventTimeWindows.of(Time, Time)
FileInputFormat.setFilesFilter(FilePathFilter)
StreamExecutionEnvironment.readFile(FileInputFormat, String, FileProcessingMode, long)
SingleOutputStreamOperator.returns(Class)
SingleOutputStreamOperator.returns(TypeHint)
StreamExecutionEnvironment.setRestartStrategy(org.apache.flink.api.common.restartstrategy.RestartStrategies.RestartStrategyConfiguration)
RestartStrategies.fixedDelayRestart(int, Time)
StreamExecutionEnvironment.socketTextStream(String, int, String)
StreamExecutionEnvironment.socketTextStream(String, int, String, long)
CoGroupedStreams.WithWindow.apply(CoGroupFunction)
CoGroupedStreams.WithWindow.apply(CoGroupFunction, TypeInformation)
JoinedStreams.WithWindow.apply(FlatJoinFunction)
JoinedStreams.WithWindow.apply(FlatJoinFunction, TypeInformation)
JoinedStreams.WithWindow.apply(JoinFunction)
JoinedStreams.WithWindow.apply(JoinFunction, TypeInformation)
Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.