Uses of Interface
org.apache.flink.streaming.runtime.io.PushingAsyncDataInput.DataOutput
-
-
Uses of PushingAsyncDataInput.DataOutput in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators with parameters of type PushingAsyncDataInput.DataOutput Modifier and Type Method Description DataInputStatusSourceOperator. emitNext(PushingAsyncDataInput.DataOutput<OUT> output) -
Uses of PushingAsyncDataInput.DataOutput in org.apache.flink.streaming.api.operators.sort
Methods in org.apache.flink.streaming.api.operators.sort with parameters of type PushingAsyncDataInput.DataOutput Modifier and Type Method Description DataInputStatusMultiInputSortingDataInput. emitNext(PushingAsyncDataInput.DataOutput<IN> output)DataInputStatusSortingDataInput. emitNext(PushingAsyncDataInput.DataOutput<T> output) -
Uses of PushingAsyncDataInput.DataOutput in org.apache.flink.streaming.api.operators.source
Methods in org.apache.flink.streaming.api.operators.source with parameters of type PushingAsyncDataInput.DataOutput Modifier and Type Method Description org.apache.flink.api.connector.source.ReaderOutput<T>NoOpTimestampsAndWatermarks. createMainOutput(PushingAsyncDataInput.DataOutput<T> output, TimestampsAndWatermarks.WatermarkUpdateListener watermarkEmitted)org.apache.flink.api.connector.source.ReaderOutput<T>ProgressiveTimestampsAndWatermarks. createMainOutput(PushingAsyncDataInput.DataOutput<T> output, TimestampsAndWatermarks.WatermarkUpdateListener watermarkUpdateListener)org.apache.flink.api.connector.source.ReaderOutput<T>TimestampsAndWatermarks. createMainOutput(PushingAsyncDataInput.DataOutput<T> output, TimestampsAndWatermarks.WatermarkUpdateListener watermarkCallback)Creates the ReaderOutput for the source reader, than internally runs the timestamp extraction and watermark generation.static <E> SourceOutputWithWatermarks<E>SourceOutputWithWatermarks. createWithSeparateOutputs(PushingAsyncDataInput.DataOutput<E> recordsOutput, org.apache.flink.api.common.eventtime.WatermarkOutput onEventWatermarkOutput, org.apache.flink.api.common.eventtime.WatermarkOutput periodicWatermarkOutput, org.apache.flink.api.common.eventtime.TimestampAssigner<E> timestampAssigner, org.apache.flink.api.common.eventtime.WatermarkGenerator<E> watermarkGenerator)Creates a new SourceOutputWithWatermarks that emits records to the given DataOutput and watermarks to the different WatermarkOutputs.Constructors in org.apache.flink.streaming.api.operators.source with parameters of type PushingAsyncDataInput.DataOutput Constructor Description SourceOutputWithWatermarks(PushingAsyncDataInput.DataOutput<T> recordsOutput, org.apache.flink.api.common.eventtime.WatermarkOutput onEventWatermarkOutput, org.apache.flink.api.common.eventtime.WatermarkOutput periodicWatermarkOutput, org.apache.flink.api.common.eventtime.TimestampAssigner<T> timestampAssigner, org.apache.flink.api.common.eventtime.WatermarkGenerator<T> watermarkGenerator)Creates a new SourceOutputWithWatermarks that emits records to the given DataOutput and watermarks to the (possibly different) WatermarkOutput.WatermarkToDataOutput(PushingAsyncDataInput.DataOutput<?> output)WatermarkToDataOutput(PushingAsyncDataInput.DataOutput<?> output, TimestampsAndWatermarks.WatermarkUpdateListener watermarkEmitted)Creates a new WatermarkOutput against the given DataOutput. -
Uses of PushingAsyncDataInput.DataOutput in org.apache.flink.streaming.runtime.io
Classes in org.apache.flink.streaming.runtime.io that implement PushingAsyncDataInput.DataOutput Modifier and Type Class Description classFinishedDataOutput<IN>An emptyPushingAsyncDataInput.DataOutputwhich is used byStreamOneInputProcessoronce anDataInputStatus.END_OF_DATAis received.Methods in org.apache.flink.streaming.runtime.io with parameters of type PushingAsyncDataInput.DataOutput Modifier and Type Method Description DataInputStatusAbstractStreamTaskNetworkInput. emitNext(PushingAsyncDataInput.DataOutput<T> output)DataInputStatusPushingAsyncDataInput. emitNext(PushingAsyncDataInput.DataOutput<T> output)Pushes elements to the output from current data input, and returns the input status to indicate whether there are more available data in current input.DataInputStatusStreamTaskExternallyInducedSourceInput. emitNext(PushingAsyncDataInput.DataOutput<T> output)DataInputStatusStreamTaskSourceInput. emitNext(PushingAsyncDataInput.DataOutput<T> output)voidRecordAttributesCombiner. inputRecordAttributes(RecordAttributes recordAttributes, int channelIdx, PushingAsyncDataInput.DataOutput<?> output)protected DataInputStatusAbstractStreamTaskNetworkInput. processEvent(BufferOrEvent bufferOrEvent, PushingAsyncDataInput.DataOutput<T> output)Constructors in org.apache.flink.streaming.runtime.io with parameters of type PushingAsyncDataInput.DataOutput Constructor Description StreamOneInputProcessor(StreamTaskInput<IN> input, PushingAsyncDataInput.DataOutput<IN> output, BoundedMultiInput endOfInputAware) -
Uses of PushingAsyncDataInput.DataOutput in org.apache.flink.streaming.runtime.io.recovery
Methods in org.apache.flink.streaming.runtime.io.recovery with parameters of type PushingAsyncDataInput.DataOutput Modifier and Type Method Description protected DataInputStatusRescalingStreamTaskNetworkInput. processEvent(BufferOrEvent bufferOrEvent, PushingAsyncDataInput.DataOutput<T> output) -
Uses of PushingAsyncDataInput.DataOutput in org.apache.flink.streaming.runtime.tasks
Classes in org.apache.flink.streaming.runtime.tasks that implement PushingAsyncDataInput.DataOutput Modifier and Type Class Description static classSourceOperatorStreamTask.AsyncDataOutputToOutput<T>Implementation ofPushingAsyncDataInput.DataOutputthat wraps a specificOutput.Methods in org.apache.flink.streaming.runtime.tasks with parameters of type PushingAsyncDataInput.DataOutput Modifier and Type Method Description DataInputStatusStreamTaskFinishedOnRestoreSourceInput. emitNext(PushingAsyncDataInput.DataOutput<T> output) -
Uses of PushingAsyncDataInput.DataOutput in org.apache.flink.streaming.runtime.watermarkstatus
Methods in org.apache.flink.streaming.runtime.watermarkstatus with parameters of type PushingAsyncDataInput.DataOutput Modifier and Type Method Description voidStatusWatermarkValve. inputWatermark(Watermark watermark, int channelIndex, PushingAsyncDataInput.DataOutput<?> output)Feed aWatermarkinto the valve.voidStatusWatermarkValve. inputWatermarkStatus(WatermarkStatus watermarkStatus, int channelIndex, PushingAsyncDataInput.DataOutput<?> output)Feed aWatermarkStatusinto the valve.
-