Interface IterationRuntimeContext
-
- All Superinterfaces:
RuntimeContext
@Public public interface IterationRuntimeContext extends RuntimeContext
A specialization of theRuntimeContext
available in iterative computations of the DataSet API.
-
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description <T extends Aggregator<?>>
TgetIterationAggregator(String name)
<T extends Value>
TgetPreviousIterationAggregate(String name)
int
getSuperstepNumber()
Gets the number of the current superstep.-
Methods inherited from interface org.apache.flink.api.common.functions.RuntimeContext
addAccumulator, createSerializer, getAccumulator, getAggregatingState, getBroadcastVariable, getBroadcastVariableWithInitializer, getDistributedCache, getDoubleCounter, getExternalResourceInfos, getGlobalJobParameters, getHistogram, getIntCounter, getJobInfo, getListState, getLongCounter, getMapState, getMetricGroup, getReducingState, getState, getTaskInfo, getUserCodeClassLoader, hasBroadcastVariable, isObjectReuseEnabled, registerUserCodeClassLoaderReleaseHookIfAbsent
-
-
-
-
Method Detail
-
getSuperstepNumber
int getSuperstepNumber()
Gets the number of the current superstep. Superstep numbers start at 1.- Returns:
- The number of the current superstep.
-
getIterationAggregator
@PublicEvolving <T extends Aggregator<?>> T getIterationAggregator(String name)
-
-