public static class StreamSQLTestProgram.GeneratorTableSource extends Object implements org.apache.flink.table.sources.StreamTableSource<Row>, org.apache.flink.table.sources.DefinedRowtimeAttributes, org.apache.flink.table.sources.DefinedFieldMapping
Constructor and Description |
---|
GeneratorTableSource(int numKeys,
float recordsPerKeyAndSecond,
int durationSeconds,
int offsetSeconds) |
Modifier and Type | Method and Description |
---|---|
String |
explainSource() |
DataStream<Row> |
getDataStream(StreamExecutionEnvironment execEnv) |
Map<String,String> |
getFieldMapping() |
TypeInformation<Row> |
getReturnType() |
List<org.apache.flink.table.sources.RowtimeAttributeDescriptor> |
getRowtimeAttributeDescriptors() |
org.apache.flink.table.api.TableSchema |
getTableSchema() |
public GeneratorTableSource(int numKeys, float recordsPerKeyAndSecond, int durationSeconds, int offsetSeconds)
public DataStream<Row> getDataStream(StreamExecutionEnvironment execEnv)
getDataStream
in interface org.apache.flink.table.sources.StreamTableSource<Row>
public TypeInformation<Row> getReturnType()
getReturnType
in interface org.apache.flink.table.sources.TableSource<Row>
public org.apache.flink.table.api.TableSchema getTableSchema()
getTableSchema
in interface org.apache.flink.table.sources.TableSource<Row>
public String explainSource()
explainSource
in interface org.apache.flink.table.sources.TableSource<Row>
public List<org.apache.flink.table.sources.RowtimeAttributeDescriptor> getRowtimeAttributeDescriptors()
getRowtimeAttributeDescriptors
in interface org.apache.flink.table.sources.DefinedRowtimeAttributes
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.