Class CassandraRowOutputFormat

  • All Implemented Interfaces:
    Serializable, org.apache.flink.api.common.io.OutputFormat<org.apache.flink.types.Row>

    public class CassandraRowOutputFormat
    extends CassandraOutputFormatBase<org.apache.flink.types.Row>
    OutputFormat to write Flink Rows into a Cassandra cluster.
    See Also:
    Serialized Form