Class StreamProjection<IN>


  • @PublicEvolving
    public class StreamProjection<IN>
    extends Object
    The result of DataStream.project(int...). This can be used to add more fields to the projection.
    • Constructor Summary

      Constructors 
      Modifier Constructor Description
      protected StreamProjection​(DataStream<IN> dataStream, int[] fieldIndexes)  
    • Method Summary

      All Methods Static Methods Instance Methods Concrete Methods 
      Modifier and Type Method Description
      static org.apache.flink.api.common.typeinfo.TypeInformation<?>[] extractFieldTypes​(int[] fields, org.apache.flink.api.common.typeinfo.TypeInformation<?> inType)  
      <T0> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple1<T0>> projectTuple1()
      Projects a Tuple DataStream to the previously selected fields.
      <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9>
      SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple10<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9>>
      projectTuple10()
      Projects a Tuple DataStream to the previously selected fields.
      <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10>
      SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple11<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10>>
      projectTuple11()
      Projects a Tuple DataStream to the previously selected fields.
      <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11>
      SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple12<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11>>
      projectTuple12()
      Projects a Tuple DataStream to the previously selected fields.
      <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12>
      SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple13<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12>>
      projectTuple13()
      Projects a Tuple DataStream to the previously selected fields.
      <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13>
      SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple14<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13>>
      projectTuple14()
      Projects a Tuple DataStream to the previously selected fields.
      <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14>
      SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple15<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14>>
      projectTuple15()
      Projects a Tuple DataStream to the previously selected fields.
      <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15>
      SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple16<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15>>
      projectTuple16()
      Projects a Tuple DataStream to the previously selected fields.
      <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16>
      SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple17<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16>>
      projectTuple17()
      Projects a Tuple DataStream to the previously selected fields.
      <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17>
      SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple18<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17>>
      projectTuple18()
      Projects a Tuple DataStream to the previously selected fields.
      <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18>
      SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple19<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18>>
      projectTuple19()
      Projects a Tuple DataStream to the previously selected fields.
      <T0,​T1>
      SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple2<T0,​T1>>
      projectTuple2()
      Projects a Tuple DataStream to the previously selected fields.
      <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18,​T19>
      SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple20<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18,​T19>>
      projectTuple20()
      Projects a Tuple DataStream to the previously selected fields.
      <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18,​T19,​T20>
      SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple21<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18,​T19,​T20>>
      projectTuple21()
      Projects a Tuple DataStream to the previously selected fields.
      <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18,​T19,​T20,​T21>
      SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple22<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18,​T19,​T20,​T21>>
      projectTuple22()
      Projects a Tuple DataStream to the previously selected fields.
      <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18,​T19,​T20,​T21,​T22>
      SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple23<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18,​T19,​T20,​T21,​T22>>
      projectTuple23()
      Projects a Tuple DataStream to the previously selected fields.
      <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18,​T19,​T20,​T21,​T22,​T23>
      SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple24<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18,​T19,​T20,​T21,​T22,​T23>>
      projectTuple24()
      Projects a Tuple DataStream to the previously selected fields.
      <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18,​T19,​T20,​T21,​T22,​T23,​T24>
      SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple25<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18,​T19,​T20,​T21,​T22,​T23,​T24>>
      projectTuple25()
      Projects a Tuple DataStream to the previously selected fields.
      <T0,​T1,​T2>
      SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple3<T0,​T1,​T2>>
      projectTuple3()
      Projects a Tuple DataStream to the previously selected fields.
      <T0,​T1,​T2,​T3>
      SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple4<T0,​T1,​T2,​T3>>
      projectTuple4()
      Projects a Tuple DataStream to the previously selected fields.
      <T0,​T1,​T2,​T3,​T4>
      SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple5<T0,​T1,​T2,​T3,​T4>>
      projectTuple5()
      Projects a Tuple DataStream to the previously selected fields.
      <T0,​T1,​T2,​T3,​T4,​T5>
      SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple6<T0,​T1,​T2,​T3,​T4,​T5>>
      projectTuple6()
      Projects a Tuple DataStream to the previously selected fields.
      <T0,​T1,​T2,​T3,​T4,​T5,​T6>
      SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple7<T0,​T1,​T2,​T3,​T4,​T5,​T6>>
      projectTuple7()
      Projects a Tuple DataStream to the previously selected fields.
      <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7>
      SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple8<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7>>
      projectTuple8()
      Projects a Tuple DataStream to the previously selected fields.
      <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8>
      SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple9<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8>>
      projectTuple9()
      Projects a Tuple DataStream to the previously selected fields.
      <OUT extends org.apache.flink.api.java.tuple.Tuple>
      SingleOutputStreamOperator<OUT>
      projectTupleX()
      Chooses a projectTupleX according to the length of fieldIndexes.
    • Constructor Detail

      • StreamProjection

        protected StreamProjection​(DataStream<IN> dataStream,
                                   int[] fieldIndexes)
    • Method Detail

      • projectTupleX

        public <OUT extends org.apache.flink.api.java.tuple.Tuple> SingleOutputStreamOperator<OUT> projectTupleX()
        Chooses a projectTupleX according to the length of fieldIndexes.
        Returns:
        The projected DataStream.
        See Also:
        org.apache.flink.api.java.operators.ProjectOperator.Projection
      • projectTuple1

        public <T0> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple1<T0>> projectTuple1()
        Projects a Tuple DataStream to the previously selected fields.
        Returns:
        The projected DataStream.
        See Also:
        Tuple, DataStream
      • projectTuple2

        public <T0,​T1> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple2<T0,​T1>> projectTuple2()
        Projects a Tuple DataStream to the previously selected fields.
        Returns:
        The projected DataStream.
        See Also:
        Tuple, DataStream
      • projectTuple3

        public <T0,​T1,​T2> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple3<T0,​T1,​T2>> projectTuple3()
        Projects a Tuple DataStream to the previously selected fields.
        Returns:
        The projected DataStream.
        See Also:
        Tuple, DataStream
      • projectTuple4

        public <T0,​T1,​T2,​T3> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple4<T0,​T1,​T2,​T3>> projectTuple4()
        Projects a Tuple DataStream to the previously selected fields.
        Returns:
        The projected DataStream.
        See Also:
        Tuple, DataStream
      • projectTuple5

        public <T0,​T1,​T2,​T3,​T4> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple5<T0,​T1,​T2,​T3,​T4>> projectTuple5()
        Projects a Tuple DataStream to the previously selected fields.
        Returns:
        The projected DataStream.
        See Also:
        Tuple, DataStream
      • projectTuple6

        public <T0,​T1,​T2,​T3,​T4,​T5> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple6<T0,​T1,​T2,​T3,​T4,​T5>> projectTuple6()
        Projects a Tuple DataStream to the previously selected fields.
        Returns:
        The projected DataStream.
        See Also:
        Tuple, DataStream
      • projectTuple7

        public <T0,​T1,​T2,​T3,​T4,​T5,​T6> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple7<T0,​T1,​T2,​T3,​T4,​T5,​T6>> projectTuple7()
        Projects a Tuple DataStream to the previously selected fields.
        Returns:
        The projected DataStream.
        See Also:
        Tuple, DataStream
      • projectTuple8

        public <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple8<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7>> projectTuple8()
        Projects a Tuple DataStream to the previously selected fields.
        Returns:
        The projected DataStream.
        See Also:
        Tuple, DataStream
      • projectTuple9

        public <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple9<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8>> projectTuple9()
        Projects a Tuple DataStream to the previously selected fields.
        Returns:
        The projected DataStream.
        See Also:
        Tuple, DataStream
      • projectTuple10

        public <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple10<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9>> projectTuple10()
        Projects a Tuple DataStream to the previously selected fields.
        Returns:
        The projected DataStream.
        See Also:
        Tuple, DataStream
      • projectTuple11

        public <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple11<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10>> projectTuple11()
        Projects a Tuple DataStream to the previously selected fields.
        Returns:
        The projected DataStream.
        See Also:
        Tuple, DataStream
      • projectTuple12

        public <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple12<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11>> projectTuple12()
        Projects a Tuple DataStream to the previously selected fields.
        Returns:
        The projected DataStream.
        See Also:
        Tuple, DataStream
      • projectTuple13

        public <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple13<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12>> projectTuple13()
        Projects a Tuple DataStream to the previously selected fields.
        Returns:
        The projected DataStream.
        See Also:
        Tuple, DataStream
      • projectTuple14

        public <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple14<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13>> projectTuple14()
        Projects a Tuple DataStream to the previously selected fields.
        Returns:
        The projected DataStream.
        See Also:
        Tuple, DataStream
      • projectTuple15

        public <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple15<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14>> projectTuple15()
        Projects a Tuple DataStream to the previously selected fields.
        Returns:
        The projected DataStream.
        See Also:
        Tuple, DataStream
      • projectTuple16

        public <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple16<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15>> projectTuple16()
        Projects a Tuple DataStream to the previously selected fields.
        Returns:
        The projected DataStream.
        See Also:
        Tuple, DataStream
      • projectTuple17

        public <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple17<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16>> projectTuple17()
        Projects a Tuple DataStream to the previously selected fields.
        Returns:
        The projected DataStream.
        See Also:
        Tuple, DataStream
      • projectTuple18

        public <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple18<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17>> projectTuple18()
        Projects a Tuple DataStream to the previously selected fields.
        Returns:
        The projected DataStream.
        See Also:
        Tuple, DataStream
      • projectTuple19

        public <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple19<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18>> projectTuple19()
        Projects a Tuple DataStream to the previously selected fields.
        Returns:
        The projected DataStream.
        See Also:
        Tuple, DataStream
      • projectTuple20

        public <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18,​T19> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple20<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18,​T19>> projectTuple20()
        Projects a Tuple DataStream to the previously selected fields.
        Returns:
        The projected DataStream.
        See Also:
        Tuple, DataStream
      • projectTuple21

        public <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18,​T19,​T20> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple21<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18,​T19,​T20>> projectTuple21()
        Projects a Tuple DataStream to the previously selected fields.
        Returns:
        The projected DataStream.
        See Also:
        Tuple, DataStream
      • projectTuple22

        public <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18,​T19,​T20,​T21> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple22<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18,​T19,​T20,​T21>> projectTuple22()
        Projects a Tuple DataStream to the previously selected fields.
        Returns:
        The projected DataStream.
        See Also:
        Tuple, DataStream
      • projectTuple23

        public <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18,​T19,​T20,​T21,​T22> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple23<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18,​T19,​T20,​T21,​T22>> projectTuple23()
        Projects a Tuple DataStream to the previously selected fields.
        Returns:
        The projected DataStream.
        See Also:
        Tuple, DataStream
      • projectTuple24

        public <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18,​T19,​T20,​T21,​T22,​T23> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple24<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18,​T19,​T20,​T21,​T22,​T23>> projectTuple24()
        Projects a Tuple DataStream to the previously selected fields.
        Returns:
        The projected DataStream.
        See Also:
        Tuple, DataStream
      • projectTuple25

        public <T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18,​T19,​T20,​T21,​T22,​T23,​T24> SingleOutputStreamOperator<org.apache.flink.api.java.tuple.Tuple25<T0,​T1,​T2,​T3,​T4,​T5,​T6,​T7,​T8,​T9,​T10,​T11,​T12,​T13,​T14,​T15,​T16,​T17,​T18,​T19,​T20,​T21,​T22,​T23,​T24>> projectTuple25()
        Projects a Tuple DataStream to the previously selected fields.
        Returns:
        The projected DataStream.
        See Also:
        Tuple, DataStream
      • extractFieldTypes

        public static org.apache.flink.api.common.typeinfo.TypeInformation<?>[] extractFieldTypes​(int[] fields,
                                                                                                  org.apache.flink.api.common.typeinfo.TypeInformation<?> inType)