Uses of Class
org.apache.flink.runtime.event.TaskEvent
-
-
Uses of TaskEvent in org.apache.flink.runtime.io.network
Methods in org.apache.flink.runtime.io.network with parameters of type TaskEvent Modifier and Type Method Description booleanTaskEventDispatcher. publish(ResultPartitionID partitionId, TaskEvent event)Publishes the event to the registeredEventListenerinstances.booleanTaskEventPublisher. publish(ResultPartitionID partitionId, TaskEvent event)Publishes the event to the registeredEventListenerinstances.voidPartitionRequestClient. sendTaskEvent(ResultPartitionID partitionId, TaskEvent event, RemoteInputChannel inputChannel)Sends a task event backwards to an intermediate result partition.Method parameters in org.apache.flink.runtime.io.network with type arguments of type TaskEvent Modifier and Type Method Description voidTaskEventDispatcher. subscribeToEvent(ResultPartitionID partitionId, EventListener<TaskEvent> eventListener, Class<? extends TaskEvent> eventType)Subscribes a listener to this dispatcher for events on a partition.voidTaskEventDispatcher. subscribeToEvent(ResultPartitionID partitionId, EventListener<TaskEvent> eventListener, Class<? extends TaskEvent> eventType)Subscribes a listener to this dispatcher for events on a partition. -
Uses of TaskEvent in org.apache.flink.runtime.io.network.api
Methods in org.apache.flink.runtime.io.network.api with parameters of type TaskEvent Modifier and Type Method Description voidTaskEventHandler. publish(TaskEvent event)Publishes the task event to all subscribed event listeners.Method parameters in org.apache.flink.runtime.io.network.api with type arguments of type TaskEvent Modifier and Type Method Description voidTaskEventHandler. subscribe(EventListener<TaskEvent> listener, Class<? extends TaskEvent> eventType)voidTaskEventHandler. subscribe(EventListener<TaskEvent> listener, Class<? extends TaskEvent> eventType) -
Uses of TaskEvent in org.apache.flink.runtime.io.network.api.reader
Methods in org.apache.flink.runtime.io.network.api.reader with parameters of type TaskEvent Modifier and Type Method Description voidAbstractReader. publish(TaskEvent event)voidAbstractReader. sendTaskEvent(TaskEvent event)voidReaderBase. sendTaskEvent(TaskEvent event)Method parameters in org.apache.flink.runtime.io.network.api.reader with type arguments of type TaskEvent Modifier and Type Method Description voidAbstractReader. registerTaskEventListener(EventListener<TaskEvent> listener, Class<? extends TaskEvent> eventType)voidAbstractReader. registerTaskEventListener(EventListener<TaskEvent> listener, Class<? extends TaskEvent> eventType)voidReaderBase. registerTaskEventListener(EventListener<TaskEvent> listener, Class<? extends TaskEvent> eventType)voidReaderBase. registerTaskEventListener(EventListener<TaskEvent> listener, Class<? extends TaskEvent> eventType) -
Uses of TaskEvent in org.apache.flink.runtime.io.network.netty
Methods in org.apache.flink.runtime.io.network.netty with parameters of type TaskEvent Modifier and Type Method Description voidNettyPartitionRequestClient. sendTaskEvent(ResultPartitionID partitionId, TaskEvent event, RemoteInputChannel inputChannel)Sends a task event backwards to an intermediate result partition producer. -
Uses of TaskEvent in org.apache.flink.runtime.io.network.partition.consumer
Methods in org.apache.flink.runtime.io.network.partition.consumer with parameters of type TaskEvent Modifier and Type Method Description abstract voidInputGate. sendTaskEvent(TaskEvent event)voidSingleInputGate. sendTaskEvent(TaskEvent event)voidUnionInputGate. sendTaskEvent(TaskEvent event) -
Uses of TaskEvent in org.apache.flink.runtime.iterative.concurrent
Methods in org.apache.flink.runtime.iterative.concurrent with parameters of type TaskEvent Modifier and Type Method Description voidSuperstepBarrier. onEvent(TaskEvent event)Barrier will release the waiting thread if an event occurs. -
Uses of TaskEvent in org.apache.flink.runtime.iterative.event
Subclasses of TaskEvent in org.apache.flink.runtime.iterative.event Modifier and Type Class Description classAllWorkersDoneEventEvent sent by theIterationSynchronizationSinkTaskto eachIterationHeadsignaling to start a new superstep.classIterationEventWithAggregatorsBase class for iterationTaskEventtransmitting operator aggregators.classTerminationEventSignals that the iteration is completely executed, participating tasks must terminate now.classWorkerDoneEventCompletion event sent from eachIterationHeadto theIterationSynchronizationSinkTask. -
Uses of TaskEvent in org.apache.flink.runtime.iterative.task
Methods in org.apache.flink.runtime.iterative.task with parameters of type TaskEvent Modifier and Type Method Description voidSyncEventHandler. onEvent(TaskEvent event) -
Uses of TaskEvent in org.apache.flink.runtime.taskmanager
Methods in org.apache.flink.runtime.taskmanager with parameters of type TaskEvent Modifier and Type Method Description voidInputGateWithMetrics. sendTaskEvent(TaskEvent event)
-