public static class PythonConnectorUtils.RowRowMapper
extends org.apache.flink.streaming.api.functions.ProcessFunction<org.apache.flink.types.Row,org.apache.flink.table.data.RowData>
ProcessFunction
that convert Row
to RowData
.构造器和说明 |
---|
RowRowMapper(org.apache.flink.table.types.DataType dataType) |
限定符和类型 | 方法和说明 |
---|---|
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) |
public void open(org.apache.flink.api.common.functions.OpenContext openContext) throws Exception
Exception
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
processElement
在类中 org.apache.flink.streaming.api.functions.ProcessFunction<org.apache.flink.types.Row,org.apache.flink.table.data.RowData>
Exception
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.