public class IterationTailTask<S extends org.apache.flink.api.common.functions.Function,OT> extends AbstractIterativeTask<S,OT>
If the iteration state is updated, the output of this task will be send back to the IterationHeadTask via
a BackChannel for the workset -OR- a HashTable for the solution set. Therefore this
task must be scheduled on the same instance as the head. It's also possible for the tail to update *both* the workset
and the solution set.
If there is a separate solution set tail, the iteration head has to make sure to wait for it to finish.
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 |
|---|
IterationTailTask(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 IterationTailTask(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.