public class CassandraAppendTableSink extends Object implements AppendStreamTableSink<Row>
AppendStreamTableSink
to write an append stream Table to a Cassandra table.Constructor and Description |
---|
CassandraAppendTableSink(ClusterBuilder builder,
String cql) |
CassandraAppendTableSink(ClusterBuilder builder,
String cql,
Properties properties) |
Modifier and Type | Method and Description |
---|---|
CassandraAppendTableSink |
configure(String[] fieldNames,
TypeInformation<?>[] fieldTypes)
Returns a copy of this
TableSink configured with the field names and types of the
table to emit. |
DataStreamSink<?> |
consumeDataStream(DataStream<Row> dataStream)
Consumes the DataStream and return the sink transformation
DataStreamSink . |
String[] |
getFieldNames() |
TypeInformation<?>[] |
getFieldTypes() |
TypeInformation<Row> |
getOutputType() |
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
getConsumedDataType, getTableSchema
public CassandraAppendTableSink(ClusterBuilder builder, String cql)
public CassandraAppendTableSink(ClusterBuilder builder, String cql, Properties properties)
public TypeInformation<Row> getOutputType()
getOutputType
in interface TableSink<Row>
public String[] getFieldNames()
getFieldNames
in interface TableSink<Row>
public TypeInformation<?>[] getFieldTypes()
getFieldTypes
in interface TableSink<Row>
public CassandraAppendTableSink configure(String[] fieldNames, TypeInformation<?>[] fieldTypes)
TableSink
TableSink
configured with the field names and types of the
table to emit.public DataStreamSink<?> consumeDataStream(DataStream<Row> dataStream)
StreamTableSink
DataStreamSink
. The
returned DataStreamSink
will be used to set resources for the sink operator.consumeDataStream
in interface StreamTableSink<Row>
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.