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 classRuntimeEventSubclasses of this event are recognized as events exchanged by the core runtime.classTaskEventSubclasses of this event are recognized as custom events that are not part of the core flink runtime.classWatermarkEventThis event wraps theWatermark, it is used in propagateWatermarkbetween 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 classCancelCheckpointMarkerThe CancelCheckpointMarker travels through the data streams, similar to theCheckpointBarrier, but signals that a certain checkpoint should be canceled.classCheckpointBarrierCheckpoint barriers are used to align checkpoints throughout the streaming topology.classEndOfDataThis event indicates there will be no more data records in a subpartition.classEndOfPartitionEventThis event marks a subpartition as fully consumed.classEndOfSegmentEventEndOfSegmentEventis used to notify the downstream switch tiers in tiered storage shuffle mode.classEndOfSuperstepEventMarks the end of a superstep of one particular iteration superstep.classEventAnnouncementEventAnnouncementis announcing presence or receiving of anAbstractEvent.classRecoveryMetadataRecoveryMetadatacontains the metadata used during a recovery process.classSubtaskConnectionDescriptorAn 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 AbstractEventEventAnnouncement. 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 booleanAbstractReader. 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 AbstractEventEventSerializer. fromBuffer(Buffer buffer, ClassLoader classLoader)static AbstractEventEventSerializer. 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 BufferEventSerializer. toBuffer(AbstractEvent event, boolean hasPriority)static BufferConsumerEventSerializer. toBufferConsumer(AbstractEvent event, boolean hasPriority)static ByteBufferEventSerializer. 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 voidMultipleRecordWriters. broadcastEvent(AbstractEvent event)voidNonRecordWriter. broadcastEvent(AbstractEvent event)voidRecordWriter. broadcastEvent(AbstractEvent event)voidRecordWriter. broadcastEvent(AbstractEvent event, boolean isPriorityEvent)voidRecordWriterDelegate. broadcastEvent(AbstractEvent event)Broadcasts the provided event to all the internal record writer instances.voidResultPartitionWriter. broadcastEvent(AbstractEvent event, boolean isPriorityEvent)Writes the givenAbstractEventto all subpartitions.voidSingleRecordWriter. 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.DataTypeBuffer.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 voidBufferWritingResultPartition. broadcastEvent(AbstractEvent event, boolean isPriorityEvent)voidSortMergeResultPartition. 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 classEndOfChannelStateEventMarks the end of recovered state ofRecoveredInputChannelof this subtask orResultSubpartitionon the upstream.Methods in org.apache.flink.runtime.io.network.partition.consumer that return AbstractEvent Modifier and Type Method Description AbstractEventBufferOrEvent. getEvent()protected AbstractEventChannelStatePersister. parseEvent(Buffer buffer)Parses the buffer as an event and returns theCheckpointBarrierif 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 voidTieredResultPartition. 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 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 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 voidRecordWriterOutput. 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 voidOperatorChain. broadcastEvent(AbstractEvent event)voidOperatorChain. broadcastEvent(AbstractEvent event, boolean isPriorityEvent)
-