Uses of Class
org.apache.flink.runtime.event.AbstractEvent
-
-
Uses of AbstractEvent in org.apache.flink.runtime.event
Subclasses of AbstractEvent in org.apache.flink.runtime.event Modifier and Type Class Description class
RuntimeEvent
Subclasses of this event are recognized as events exchanged by the core runtime.class
TaskEvent
Subclasses of this event are recognized as custom events that are not part of the core flink runtime.class
WatermarkEvent
This event wraps theWatermark
, it is used in propagateWatermark
between shuffle components, and should not be visible to operators and functions. -
Uses of AbstractEvent in org.apache.flink.runtime.io.network.api
Subclasses of AbstractEvent in org.apache.flink.runtime.io.network.api Modifier and Type Class Description class
CancelCheckpointMarker
The CancelCheckpointMarker travels through the data streams, similar to theCheckpointBarrier
, but signals that a certain checkpoint should be canceled.class
CheckpointBarrier
Checkpoint barriers are used to align checkpoints throughout the streaming topology.class
EndOfData
This event indicates there will be no more data records in a subpartition.class
EndOfPartitionEvent
This event marks a subpartition as fully consumed.class
EndOfSegmentEvent
EndOfSegmentEvent
is used to notify the downstream switch tiers in tiered storage shuffle mode.class
EndOfSuperstepEvent
Marks the end of a superstep of one particular iteration superstep.class
EventAnnouncement
EventAnnouncement
is announcing presence or receiving of anAbstractEvent
.class
RecoveryMetadata
RecoveryMetadata
contains the metadata used during a recovery process.class
SubtaskConnectionDescriptor
An event that is used to (de)multiplex old channels over the same new channel.Methods in org.apache.flink.runtime.io.network.api that return AbstractEvent Modifier and Type Method Description AbstractEvent
EventAnnouncement. getAnnouncedEvent()
Constructors in org.apache.flink.runtime.io.network.api with parameters of type AbstractEvent Constructor Description EventAnnouncement(AbstractEvent announcedEvent, int sequenceNumber)
-
Uses of AbstractEvent in org.apache.flink.runtime.io.network.api.reader
Methods in org.apache.flink.runtime.io.network.api.reader with parameters of type AbstractEvent Modifier and Type Method Description protected boolean
AbstractReader. handleEvent(AbstractEvent event)
Handles the event and returns whether the reader reached an end-of-stream event (either the end of the whole stream or the end of an superstep). -
Uses of AbstractEvent in org.apache.flink.runtime.io.network.api.serialization
Methods in org.apache.flink.runtime.io.network.api.serialization that return AbstractEvent Modifier and Type Method Description static AbstractEvent
EventSerializer. fromBuffer(Buffer buffer, ClassLoader classLoader)
static AbstractEvent
EventSerializer. fromSerializedEvent(ByteBuffer buffer, ClassLoader classLoader)
Methods in org.apache.flink.runtime.io.network.api.serialization with parameters of type AbstractEvent Modifier and Type Method Description static Buffer
EventSerializer. toBuffer(AbstractEvent event, boolean hasPriority)
static BufferConsumer
EventSerializer. toBufferConsumer(AbstractEvent event, boolean hasPriority)
static ByteBuffer
EventSerializer. toSerializedEvent(AbstractEvent event)
-
Uses of AbstractEvent in org.apache.flink.runtime.io.network.api.writer
Methods in org.apache.flink.runtime.io.network.api.writer with parameters of type AbstractEvent Modifier and Type Method Description void
MultipleRecordWriters. broadcastEvent(AbstractEvent event)
void
NonRecordWriter. broadcastEvent(AbstractEvent event)
void
RecordWriter. broadcastEvent(AbstractEvent event)
void
RecordWriter. broadcastEvent(AbstractEvent event, boolean isPriorityEvent)
void
RecordWriterDelegate. broadcastEvent(AbstractEvent event)
Broadcasts the provided event to all the internal record writer instances.void
ResultPartitionWriter. broadcastEvent(AbstractEvent event, boolean isPriorityEvent)
Writes the givenAbstractEvent
to all subpartitions.void
SingleRecordWriter. broadcastEvent(AbstractEvent event)
-
Uses of AbstractEvent in org.apache.flink.runtime.io.network.buffer
Methods in org.apache.flink.runtime.io.network.buffer with parameters of type AbstractEvent Modifier and Type Method Description static Buffer.DataType
Buffer.DataType. getDataType(AbstractEvent event, boolean hasPriority)
-
Uses of AbstractEvent in org.apache.flink.runtime.io.network.partition
Methods in org.apache.flink.runtime.io.network.partition with parameters of type AbstractEvent Modifier and Type Method Description void
BufferWritingResultPartition. broadcastEvent(AbstractEvent event, boolean isPriorityEvent)
void
SortMergeResultPartition. broadcastEvent(AbstractEvent event, boolean isPriorityEvent)
-
Uses of AbstractEvent in org.apache.flink.runtime.io.network.partition.consumer
Subclasses of AbstractEvent in org.apache.flink.runtime.io.network.partition.consumer Modifier and Type Class Description class
EndOfChannelStateEvent
Marks the end of recovered state ofRecoveredInputChannel
of this subtask orResultSubpartition
on the upstream.Methods in org.apache.flink.runtime.io.network.partition.consumer that return AbstractEvent Modifier and Type Method Description AbstractEvent
BufferOrEvent. getEvent()
protected AbstractEvent
ChannelStatePersister. parseEvent(Buffer buffer)
Parses the buffer as an event and returns theCheckpointBarrier
if the event is indeed a barrier or returns null in all other cases.Constructors in org.apache.flink.runtime.io.network.partition.consumer with parameters of type AbstractEvent Constructor Description BufferOrEvent(AbstractEvent event, boolean hasPriority, InputChannelInfo channelInfo, boolean moreAvailable, int size, boolean morePriorityEvents)
BufferOrEvent(AbstractEvent event, InputChannelInfo channelInfo)
-
Uses of AbstractEvent in org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle
Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle with parameters of type AbstractEvent Modifier and Type Method Description void
TieredResultPartition. broadcastEvent(AbstractEvent event, boolean isPriorityEvent)
-
Uses of AbstractEvent in org.apache.flink.runtime.iterative.event
Subclasses of AbstractEvent in org.apache.flink.runtime.iterative.event Modifier and Type Class Description class
AllWorkersDoneEvent
Event sent by theIterationSynchronizationSinkTask
to eachIterationHead
signaling to start a new superstep.class
IterationEventWithAggregators
Base class for iterationTaskEvent
transmitting operator aggregators.class
TerminationEvent
Signals that the iteration is completely executed, participating tasks must terminate now.class
WorkerDoneEvent
Completion event sent from eachIterationHead
to theIterationSynchronizationSinkTask
. -
Uses of AbstractEvent in org.apache.flink.streaming.runtime.io
Methods in org.apache.flink.streaming.runtime.io with parameters of type AbstractEvent Modifier and Type Method Description void
RecordWriterOutput. broadcastEvent(AbstractEvent event, boolean isPriorityEvent)
-
Uses of AbstractEvent in org.apache.flink.streaming.runtime.tasks
Methods in org.apache.flink.streaming.runtime.tasks with parameters of type AbstractEvent Modifier and Type Method Description void
OperatorChain. broadcastEvent(AbstractEvent event)
void
OperatorChain. broadcastEvent(AbstractEvent event, boolean isPriorityEvent)
-