Package org.apache.flink.python.util
Class PythonConnectorUtils.RowRowMapper
- java.lang.Object
-
- org.apache.flink.api.common.functions.AbstractRichFunction
-
- org.apache.flink.streaming.api.functions.ProcessFunction<org.apache.flink.types.Row,org.apache.flink.table.data.RowData>
-
- org.apache.flink.python.util.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>
AProcessFunction
that convertRow
toRowData
.- See Also:
- Serialized Form
-
-
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)
-
-
-
Method Detail
-
open
public void open(org.apache.flink.api.common.functions.OpenContext openContext) throws Exception
- Specified by:
open
in interfaceorg.apache.flink.api.common.functions.RichFunction
- Overrides:
open
in classorg.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 classorg.apache.flink.streaming.api.functions.ProcessFunction<org.apache.flink.types.Row,org.apache.flink.table.data.RowData>
- Throws:
Exception
-
-