public class IterationIntermediateTask<S extends org.apache.flink.api.common.functions.Function,OT> extends AbstractIterativeTask<S,OT>
Driver inside.
It will propagate EndOfSuperstepEvents and TerminationEvents to its connected tasks. Furthermore
intermediate tasks can also update the iteration state, either the workset or the solution set.
If the iteration state is updated, the output of this task will be send back to the IterationHeadTask via
a BlockingBackChannel for the workset -XOR- a HashTable for the solution set. In this case
this task must be scheduled on the same instance as the head.
isSolutionSetUpdate, isWorksetIteration, isWorksetUpdate, worksetAggregator, worksetBackChannelaccumulatorMap, broadcastInputReaders, broadcastInputSerializers, chainedTasks, config, driver, eventualOutputs, inputComparators, inputIterators, inputReaders, inputs, inputSerializers, iterativeBroadcastInputs, iterativeInputs, localStrategies, LOG, output, resettableInputs, running, runtimeUdfContext, stub, tempBarriers| Constructor and Description |
|---|
IterationIntermediateTask(Environment environment)
Create an Invokable task and set its environment.
|
| Modifier and Type | Method and Description |
|---|---|
protected void |
initialize() |
void |
run() |
brokerKey, cancel, closeLocalStrategiesAndCaches, createRuntimeContext, createSolutionSetUpdateOutputCollector, createWorksetUpdateOutputCollector, createWorksetUpdateOutputCollector, currentIteration, getIterationAggregators, incrementIterationCounter, inFirstIteration, requestTermination, terminationRequested, verifyEndOfSuperstepStatecancelChainedTasks, clearReaders, clearWriters, closeChainedTasks, closeUserCode, constructLogString, createInputIterator, excludeFromReset, formatLogString, getContainingTask, getDriverComparator, getInput, getInputSerializer, getIOManager, getLastOutputCollector, getLastTasksConfig, getMemoryManager, getMetricGroup, getNumTaskInputs, getOutputCollector, getOutputCollector, getStub, getTaskConfig, getTaskManagerInfo, initBroadcastInputReaders, initBroadcastInputsSerializers, initInputReaders, initInputsSerializersAndComparators, initLocalStrategies, initOutputs, initOutputs, initStub, instantiateUserCode, invoke, logAndThrowException, openChainedTasks, openUserCode, readAndSetBroadcastInput, releaseBroadcastVariables, resetAllInputs, setLastOutputCollectorabortCheckpointOnBarrier, getCurrentNumberOfSubtasks, getEnvironment, getExecutingThread, getExecutionConfig, getIndexInSubtaskGroup, getJobConfiguration, getTaskConfiguration, getUserCodeClassLoader, notifyCheckpointComplete, setShouldInterruptOnCancel, shouldInterruptOnCancel, triggerCheckpoint, triggerCheckpointOnBarrierclone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitgetExecutionConfig, getUserCodeClassLoaderpublic IterationIntermediateTask(Environment environment)
environment - The environment assigned to this invokable.protected void initialize()
throws Exception
initialize in class AbstractIterativeTask<S extends org.apache.flink.api.common.functions.Function,OT>ExceptionCopyright © 2014–2019 The Apache Software Foundation. All rights reserved.