org.apache.flink.streaming.api.datastream.AllWindowedStream.apply(ReduceFunction, AllWindowFunction)
|
org.apache.flink.streaming.api.datastream.AllWindowedStream.apply(ReduceFunction, AllWindowFunction, TypeInformation)
|
org.apache.flink.streaming.api.datastream.WindowedStream.apply(ReduceFunction, WindowFunction)
|
org.apache.flink.streaming.api.datastream.WindowedStream.apply(ReduceFunction, WindowFunction, TypeInformation)
|
org.apache.flink.streaming.api.datastream.AllWindowedStream.apply(R, FoldFunction, AllWindowFunction)
|
org.apache.flink.streaming.api.datastream.AllWindowedStream.apply(R, FoldFunction, AllWindowFunction, TypeInformation)
|
org.apache.flink.streaming.api.datastream.WindowedStream.apply(R, FoldFunction, WindowFunction)
|
org.apache.flink.streaming.api.datastream.WindowedStream.apply(R, FoldFunction, WindowFunction, TypeInformation)
|
org.apache.flink.streaming.api.datastream.KeyedStream.asQueryableState(String, FoldingStateDescriptor)
will be removed in a future version
|
org.apache.flink.streaming.api.datastream.DataStream.assignTimestamps(TimestampExtractor)
|
org.apache.flink.streaming.api.environment.StreamExecutionEnvironment.enableCheckpointing()
|
org.apache.flink.streaming.api.environment.StreamExecutionEnvironment.enableCheckpointing(long, CheckpointingMode, boolean)
|
org.apache.flink.streaming.api.datastream.AllWindowedStream.fold(ACC, FoldFunction, AllWindowFunction)
|
org.apache.flink.streaming.api.datastream.AllWindowedStream.fold(ACC, FoldFunction, AllWindowFunction, TypeInformation, TypeInformation)
|
org.apache.flink.streaming.api.datastream.AllWindowedStream.fold(ACC, FoldFunction, ProcessAllWindowFunction)
|
org.apache.flink.streaming.api.datastream.AllWindowedStream.fold(ACC, FoldFunction, ProcessAllWindowFunction, TypeInformation, TypeInformation)
|
org.apache.flink.streaming.api.datastream.WindowedStream.fold(ACC, FoldFunction, ProcessWindowFunction)
|
org.apache.flink.streaming.api.datastream.WindowedStream.fold(ACC, FoldFunction, ProcessWindowFunction, TypeInformation, TypeInformation)
|
org.apache.flink.streaming.api.datastream.WindowedStream.fold(ACC, FoldFunction, WindowFunction)
|
org.apache.flink.streaming.api.datastream.WindowedStream.fold(ACC, FoldFunction, WindowFunction, TypeInformation, TypeInformation)
|
org.apache.flink.streaming.api.datastream.AllWindowedStream.fold(R, FoldFunction)
|
org.apache.flink.streaming.api.datastream.KeyedStream.fold(R, FoldFunction)
will be removed in a future version
|
org.apache.flink.streaming.api.datastream.WindowedStream.fold(R, FoldFunction)
|
org.apache.flink.streaming.api.datastream.AllWindowedStream.fold(R, FoldFunction, TypeInformation)
|
org.apache.flink.streaming.api.datastream.WindowedStream.fold(R, FoldFunction, TypeInformation)
|
org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext.getKeyValueState(String, Class, S)
|
org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext.getKeyValueState(String, TypeInformation, S)
|
org.apache.flink.streaming.api.environment.StreamExecutionEnvironment.getNumberOfExecutionRetries()
|
org.apache.flink.streaming.api.environment.CheckpointConfig.isForceCheckpointing()
This will be removed once iterations properly participate in checkpointing.
|
org.apache.flink.streaming.api.environment.StreamExecutionEnvironment.isForceCheckpointing()
Forcing checkpoints will be removed in future version.
|
org.apache.flink.streaming.api.windowing.assigners.TumblingTimeWindows.of(Time)
|
org.apache.flink.streaming.api.windowing.assigners.SlidingTimeWindows.of(Time, Time)
|
org.apache.flink.streaming.api.environment.StreamExecutionEnvironment.readFile(FileInputFormat, String, FileProcessingMode, long, FilePathFilter)
|
org.apache.flink.streaming.api.environment.StreamExecutionEnvironment.readFileStream(String, long, FileMonitoringFunction.WatchType)
|
org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator.returns(String)
|
org.apache.flink.streaming.api.environment.CheckpointConfig.setForceCheckpointing(boolean)
This will be removed once iterations properly participate in checkpointing.
|
org.apache.flink.streaming.api.environment.StreamExecutionEnvironment.setNumberOfExecutionRetries(int)
|
org.apache.flink.streaming.api.operators.StreamOperator.snapshotLegacyOperatorState(long, long, CheckpointOptions)
This method will be removed as soon as no more operators use the legacy state code paths
|
org.apache.flink.streaming.api.operators.AbstractStreamOperator.snapshotLegacyOperatorState(long, long, CheckpointOptions)
Non-repartitionable operator state that has been deprecated.
Can be removed when we remove the APIs for non-repartitionable operator state.
|
org.apache.flink.streaming.api.environment.StreamExecutionEnvironment.socketTextStream(String, int, char)
|
org.apache.flink.streaming.api.environment.StreamExecutionEnvironment.socketTextStream(String, int, char, long)
|
org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow.with(CoGroupFunction)
|
org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow.with(CoGroupFunction, TypeInformation)
|
org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow.with(FlatJoinFunction)
|
org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow.with(FlatJoinFunction, TypeInformation)
|
org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow.with(JoinFunction)
|
org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow.with(JoinFunction, TypeInformation)
|