Uses of Interface
org.apache.flink.util.CloseableIterable
-
Packages that use CloseableIterable Package Description org.apache.flink.streaming.api.operators org.apache.flink.util -
-
Uses of CloseableIterable in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators that return CloseableIterable Modifier and Type Method Description CloseableIterable<KeyGroupStatePartitionStreamProvider>
StreamOperatorStateContext. rawKeyedStateInputs()
Returns an iterable to obtain input streams for previously stored keyed state partitions that are assigned to this operator.protected CloseableIterable<KeyGroupStatePartitionStreamProvider>
StreamTaskStateInitializerImpl. rawKeyedStateInputs(Iterator<StateObjectCollection<KeyedStateHandle>> restoreStateAlternatives, StateObject.StateObjectSizeStatsCollector statsCollector)
CloseableIterable<StatePartitionStreamProvider>
StreamOperatorStateContext. rawOperatorStateInputs()
Returns an iterable to obtain input streams for previously stored operator state partitions that are assigned to this stream operator.protected CloseableIterable<StatePartitionStreamProvider>
StreamTaskStateInitializerImpl. rawOperatorStateInputs(Iterator<StateObjectCollection<OperatorStateHandle>> restoreStateAlternatives, StateObject.StateObjectSizeStatsCollector statsCollector)
-
Uses of CloseableIterable in org.apache.flink.util
Classes in org.apache.flink.util that implement CloseableIterable Modifier and Type Class Description static class
CloseableIterable.Empty<T>
Empty iterator.Methods in org.apache.flink.util that return CloseableIterable Modifier and Type Method Description static <T> CloseableIterable<T>
CloseableIterable. empty()
Returns an empty iterator.
-