@Internal public class ArrowTableSource extends Object implements org.apache.flink.table.sources.StreamTableSource<org.apache.flink.table.data.RowData>
StreamTableSource
for serialized arrow record batch data.构造器和说明 |
---|
ArrowTableSource(org.apache.flink.table.types.DataType dataType,
byte[][] arrowData) |
限定符和类型 | 方法和说明 |
---|---|
org.apache.flink.streaming.api.datastream.DataStream<org.apache.flink.table.data.RowData> |
getDataStream(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment execEnv) |
org.apache.flink.table.types.DataType |
getProducedDataType() |
org.apache.flink.table.api.TableSchema |
getTableSchema() |
boolean |
isBounded() |
public ArrowTableSource(org.apache.flink.table.types.DataType dataType, byte[][] arrowData)
public boolean isBounded()
isBounded
在接口中 org.apache.flink.table.sources.StreamTableSource<org.apache.flink.table.data.RowData>
public org.apache.flink.streaming.api.datastream.DataStream<org.apache.flink.table.data.RowData> getDataStream(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment execEnv)
getDataStream
在接口中 org.apache.flink.table.sources.StreamTableSource<org.apache.flink.table.data.RowData>
public org.apache.flink.table.api.TableSchema getTableSchema()
getTableSchema
在接口中 org.apache.flink.table.sources.TableSource<org.apache.flink.table.data.RowData>
public org.apache.flink.table.types.DataType getProducedDataType()
getProducedDataType
在接口中 org.apache.flink.table.sources.TableSource<org.apache.flink.table.data.RowData>
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.