Modifier and Type | Method and Description |
---|---|
boolean |
TaskEventPublisher.publish(ResultPartitionID partitionId,
TaskEvent event)
Publishes the event to the registered
EventListener instances. |
boolean |
TaskEventDispatcher.publish(ResultPartitionID partitionId,
TaskEvent event)
Publishes the event to the registered
EventListener instances. |
void |
PartitionRequestClient.sendTaskEvent(ResultPartitionID partitionId,
TaskEvent event,
RemoteInputChannel inputChannel)
Sends a task event backwards to an intermediate result partition.
|
Modifier and Type | Method and Description |
---|---|
void |
TaskEventDispatcher.subscribeToEvent(ResultPartitionID partitionId,
EventListener<TaskEvent> eventListener,
Class<? extends TaskEvent> eventType)
Subscribes a listener to this dispatcher for events on a partition.
|
void |
TaskEventDispatcher.subscribeToEvent(ResultPartitionID partitionId,
EventListener<TaskEvent> eventListener,
Class<? extends TaskEvent> eventType)
Subscribes a listener to this dispatcher for events on a partition.
|
Modifier and Type | Method and Description |
---|---|
void |
TaskEventHandler.publish(TaskEvent event)
Publishes the task event to all subscribed event listeners.
|
Modifier and Type | Method and Description |
---|---|
void |
TaskEventHandler.subscribe(EventListener<TaskEvent> listener,
Class<? extends TaskEvent> eventType) |
void |
TaskEventHandler.subscribe(EventListener<TaskEvent> listener,
Class<? extends TaskEvent> eventType) |
Modifier and Type | Method and Description |
---|---|
void |
AbstractReader.publish(TaskEvent event) |
void |
AbstractReader.sendTaskEvent(TaskEvent event) |
void |
ReaderBase.sendTaskEvent(TaskEvent event) |
Modifier and Type | Method and Description |
---|---|
void |
AbstractReader.registerTaskEventListener(EventListener<TaskEvent> listener,
Class<? extends TaskEvent> eventType) |
void |
AbstractReader.registerTaskEventListener(EventListener<TaskEvent> listener,
Class<? extends TaskEvent> eventType) |
void |
ReaderBase.registerTaskEventListener(EventListener<TaskEvent> listener,
Class<? extends TaskEvent> eventType) |
void |
ReaderBase.registerTaskEventListener(EventListener<TaskEvent> listener,
Class<? extends TaskEvent> eventType) |
Modifier and Type | Method and Description |
---|---|
void |
NettyPartitionRequestClient.sendTaskEvent(ResultPartitionID partitionId,
TaskEvent event,
RemoteInputChannel inputChannel)
Sends a task event backwards to an intermediate result partition producer.
|
Modifier and Type | Method and Description |
---|---|
void |
SingleInputGate.sendTaskEvent(TaskEvent event) |
abstract void |
InputGate.sendTaskEvent(TaskEvent event) |
void |
UnionInputGate.sendTaskEvent(TaskEvent event) |
Modifier and Type | Method and Description |
---|---|
void |
SuperstepBarrier.onEvent(TaskEvent event)
Barrier will release the waiting thread if an event occurs.
|
Modifier and Type | Class and Description |
---|---|
class |
AllWorkersDoneEvent
Event sent by the
IterationSynchronizationSinkTask to each IterationHead
signaling to start a new superstep. |
class |
IterationEventWithAggregators
Base class for iteration
TaskEvent transmitting operator aggregators. |
class |
TerminationEvent
Signals that the iteration is completely executed, participating tasks must terminate now.
|
class |
WorkerDoneEvent
Completion event sent from each
IterationHead to the IterationSynchronizationSinkTask . |
Modifier and Type | Method and Description |
---|---|
void |
SyncEventHandler.onEvent(TaskEvent event) |
Modifier and Type | Method and Description |
---|---|
void |
InputGateWithMetrics.sendTaskEvent(TaskEvent event) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.