类 OutputReflectionContext


  • public class OutputReflectionContext
    extends Object
    The reflection utilities to parse the output and create the broadcast output.
    • 构造器详细资料

      • OutputReflectionContext

        public OutputReflectionContext()
    • 方法详细资料

      • isBroadcastingOutput

        public boolean isBroadcastingOutput​(org.apache.flink.streaming.api.operators.Output<?> rawOutput)
      • isChainingOutput

        public boolean isChainingOutput​(org.apache.flink.streaming.api.operators.Output<?> rawOutput)
      • isRecordWriterOutput

        public boolean isRecordWriterOutput​(org.apache.flink.streaming.api.operators.Output<?> rawOutput)
      • getBroadcastingInternalOutputs

        public <OUT> org.apache.flink.streaming.api.operators.Output<org.apache.flink.streaming.runtime.streamrecord.StreamRecord<OUT>>[] getBroadcastingInternalOutputs​(Object output)
      • getChainingOutputTag

        public org.apache.flink.util.OutputTag<?> getChainingOutputTag​(Object output)
      • getRecordWriter

        public org.apache.flink.runtime.io.network.api.writer.RecordWriter<org.apache.flink.runtime.plugable.SerializationDelegate<org.apache.flink.streaming.runtime.streamrecord.StreamElement>> getRecordWriter​(Object output)
      • getRecordWriterTypeSerializer

        public org.apache.flink.api.common.typeutils.TypeSerializer<org.apache.flink.streaming.runtime.streamrecord.StreamElement> getRecordWriterTypeSerializer​(Object output)