Interface | Description |
---|---|
MapperOptions |
This class is used to configure a
Mapper after deployment. |
Class | Description |
---|---|
AbstractCassandraTupleSink<IN> |
Abstract sink to write tuple-like values into a Cassandra cluster.
|
CassandraAppendTableSink |
An
AppendStreamTableSink to write an append stream Table to a Cassandra table. |
CassandraCommitter |
CheckpointCommitter that saves information about completed checkpoints within a separate table in a cassandra
database.
|
CassandraPojoSink<IN> |
Flink Sink to save data into a Cassandra cluster using
Mapper,
which it uses annotations from
com.datastax.driver.mapping.annotations.
|
CassandraRowSink |
A SinkFunction to write Row records into a Cassandra table.
|
CassandraRowWriteAheadSink |
Sink that emits its input elements into a Cassandra table.
|
CassandraScalaProductSink<IN extends scala.Product> |
Sink to write scala tuples and case classes into a Cassandra cluster.
|
CassandraSink<IN> |
This class wraps different Cassandra sink implementations to provide a common interface for all of them.
|
CassandraSink.CassandraPojoSinkBuilder<IN> |
Builder for a
CassandraPojoSink . |
CassandraSink.CassandraRowSinkBuilder |
Builder for a
CassandraRowSink . |
CassandraSink.CassandraScalaProductSinkBuilder<IN extends scala.Product> |
Builder for a
CassandraScalaProductSink . |
CassandraSink.CassandraSinkBuilder<IN> |
Builder for a
CassandraSink . |
CassandraSink.CassandraTupleSinkBuilder<IN extends Tuple> |
Builder for a
CassandraTupleSink . |
CassandraSinkBase<IN,V> |
CassandraSinkBase is the common abstract class of
CassandraPojoSink and CassandraTupleSink . |
CassandraTupleSink<IN extends Tuple> |
Sink to write Flink
Tuple s into a Cassandra cluster. |
CassandraTupleWriteAheadSink<IN extends Tuple> |
Sink that emits its input elements into a Cassandra database.
|
ClusterBuilder |
This class is used to configure a
Cluster after deployment. |
Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.