Class PythonConnectorUtils.RowRowMapper

  • All Implemented Interfaces:
    Serializable, org.apache.flink.api.common.functions.Function, org.apache.flink.api.common.functions.RichFunction
    Enclosing class:
    PythonConnectorUtils

    public static class PythonConnectorUtils.RowRowMapper
    extends org.apache.flink.streaming.api.functions.ProcessFunction<org.apache.flink.types.Row,​org.apache.flink.table.data.RowData>
    A ProcessFunction that convert Row to RowData.
    See Also:
    Serialized Form
    • Nested Class Summary

      • Nested classes/interfaces inherited from class org.apache.flink.streaming.api.functions.ProcessFunction

        org.apache.flink.streaming.api.functions.ProcessFunction.Context, org.apache.flink.streaming.api.functions.ProcessFunction.OnTimerContext
    • Constructor Summary

      Constructors 
      Constructor Description
      RowRowMapper​(org.apache.flink.table.types.DataType dataType)  
    • Method Summary

      All Methods Instance Methods Concrete Methods 
      Modifier and Type Method Description
      void open​(org.apache.flink.api.common.functions.OpenContext openContext)  
      void processElement​(org.apache.flink.types.Row row, org.apache.flink.streaming.api.functions.ProcessFunction.Context ctx, org.apache.flink.util.Collector<org.apache.flink.table.data.RowData> out)  
      • Methods inherited from class org.apache.flink.streaming.api.functions.ProcessFunction

        onTimer
      • Methods inherited from class org.apache.flink.api.common.functions.AbstractRichFunction

        close, getIterationRuntimeContext, getRuntimeContext, setRuntimeContext
    • Constructor Detail

      • RowRowMapper

        public RowRowMapper​(org.apache.flink.table.types.DataType dataType)
    • Method Detail

      • open

        public void open​(org.apache.flink.api.common.functions.OpenContext openContext)
                  throws Exception
        Specified by:
        open in interface org.apache.flink.api.common.functions.RichFunction
        Overrides:
        open in class org.apache.flink.api.common.functions.AbstractRichFunction
        Throws:
        Exception
      • processElement

        public void processElement​(org.apache.flink.types.Row row,
                                   org.apache.flink.streaming.api.functions.ProcessFunction.Context ctx,
                                   org.apache.flink.util.Collector<org.apache.flink.table.data.RowData> out)
                            throws Exception
        Specified by:
        processElement in class org.apache.flink.streaming.api.functions.ProcessFunction<org.apache.flink.types.Row,​org.apache.flink.table.data.RowData>
        Throws:
        Exception