Uses of Interface
org.apache.flink.streaming.runtime.tasks.StreamTaskCancellationContext
-
Packages that use StreamTaskCancellationContext Package Description org.apache.flink.streaming.api.operators org.apache.flink.streaming.api.operators.sorted.state org.apache.flink.streaming.runtime.tasks -
-
Uses of StreamTaskCancellationContext in org.apache.flink.streaming.api.operators
Fields in org.apache.flink.streaming.api.operators declared as StreamTaskCancellationContext Modifier and Type Field Description protected StreamTaskCancellationContext
InternalTimerServiceImpl. cancellationContext
Context that allows us to stop firing timers if the containing task has been cancelled.Methods in org.apache.flink.streaming.api.operators with parameters of type StreamTaskCancellationContext Modifier and Type Method Description <K> InternalTimeServiceManager<K>
InternalTimeServiceManager.Provider. create(TaskIOMetricGroup taskIOMetricGroup, PriorityQueueSetFactory factory, KeyGroupRange keyGroupRange, ClassLoader userClassloader, KeyContext keyContext, ProcessingTimeService processingTimeService, Iterable<KeyGroupStatePartitionStreamProvider> rawKeyedStates, StreamTaskCancellationContext cancellationContext)
static <K> InternalTimeServiceManagerImpl<K>
InternalTimeServiceManagerImpl. create(TaskIOMetricGroup taskIOMetricGroup, PriorityQueueSetFactory factory, KeyGroupRange keyGroupRange, ClassLoader userClassloader, KeyContext keyContext, ProcessingTimeService processingTimeService, Iterable<KeyGroupStatePartitionStreamProvider> rawKeyedStates, StreamTaskCancellationContext cancellationContext)
A factory method for creating theInternalTimeServiceManagerImpl
.Constructors in org.apache.flink.streaming.api.operators with parameters of type StreamTaskCancellationContext Constructor Description StreamTaskStateInitializerImpl(Environment environment, StateBackend stateBackend, SubTaskInitializationMetricsBuilder initializationMetrics, TtlTimeProvider ttlTimeProvider, InternalTimeServiceManager.Provider timeServiceManagerProvider, StreamTaskCancellationContext cancellationContext)
-
Uses of StreamTaskCancellationContext in org.apache.flink.streaming.api.operators.sorted.state
Methods in org.apache.flink.streaming.api.operators.sorted.state with parameters of type StreamTaskCancellationContext Modifier and Type Method Description static <K> InternalTimeServiceManager<K>
BatchExecutionInternalTimeServiceManager. create(TaskIOMetricGroup taskIOMetricGroup, PriorityQueueSetFactory factory, KeyGroupRange keyGroupRange, ClassLoader userClassloader, KeyContext keyContext, ProcessingTimeService processingTimeService, Iterable<KeyGroupStatePartitionStreamProvider> rawKeyedStates, StreamTaskCancellationContext cancellationContext)
-
Uses of StreamTaskCancellationContext in org.apache.flink.streaming.runtime.tasks
Methods in org.apache.flink.streaming.runtime.tasks that return StreamTaskCancellationContext Modifier and Type Method Description static StreamTaskCancellationContext
StreamTaskCancellationContext. alwaysRunning()
Factory for a context that always returnsfalse
whenisCancelled()
is called.
-