Class CassandraAppendTableSink

  • All Implemented Interfaces:
    org.apache.flink.table.sinks.AppendStreamTableSink<org.apache.flink.types.Row>, org.apache.flink.table.sinks.StreamTableSink<org.apache.flink.types.Row>, org.apache.flink.table.sinks.TableSink<org.apache.flink.types.Row>

    public class CassandraAppendTableSink
    extends Object
    implements org.apache.flink.table.sinks.AppendStreamTableSink<org.apache.flink.types.Row>
    An AppendStreamTableSink to write an append stream Table to a Cassandra table.
    • Method Detail

      • getOutputType

        public org.apache.flink.api.common.typeinfo.TypeInformation<org.apache.flink.types.Row> getOutputType()
        Specified by:
        getOutputType in interface org.apache.flink.table.sinks.TableSink<org.apache.flink.types.Row>
      • getFieldNames

        public String[] getFieldNames()
        Specified by:
        getFieldNames in interface org.apache.flink.table.sinks.TableSink<org.apache.flink.types.Row>
      • getFieldTypes

        public org.apache.flink.api.common.typeinfo.TypeInformation<?>[] getFieldTypes()
        Specified by:
        getFieldTypes in interface org.apache.flink.table.sinks.TableSink<org.apache.flink.types.Row>
      • configure

        public CassandraAppendTableSink configure​(String[] fieldNames,
                                                  org.apache.flink.api.common.typeinfo.TypeInformation<?>[] fieldTypes)
        Specified by:
        configure in interface org.apache.flink.table.sinks.TableSink<org.apache.flink.types.Row>
      • consumeDataStream

        public org.apache.flink.streaming.api.datastream.DataStreamSink<?> consumeDataStream​(org.apache.flink.streaming.api.datastream.DataStream<org.apache.flink.types.Row> dataStream)
        Specified by:
        consumeDataStream in interface org.apache.flink.table.sinks.StreamTableSink<org.apache.flink.types.Row>