Class CassandraInputFormat<OUT extends org.apache.flink.api.java.tuple.Tuple>

  • Type Parameters:
    OUT - type of Tuple
    All Implemented Interfaces:
    Serializable, org.apache.flink.api.common.io.InputFormat<OUT,​org.apache.flink.core.io.InputSplit>, org.apache.flink.api.common.io.NonParallelInput, org.apache.flink.core.io.InputSplitSource<org.apache.flink.core.io.InputSplit>

    public class CassandraInputFormat<OUT extends org.apache.flink.api.java.tuple.Tuple>
    extends CassandraInputFormatBase<OUT>
    InputFormat to read data from Apache Cassandra and generate $Tuple.
    See Also:
    Serialized Form
    • Constructor Detail

    • Method Detail

      • open

        public void open​(org.apache.flink.core.io.InputSplit ignored)
                  throws IOException
        Opens a Session and executes the query.
        Parameters:
        ignored - because parameter is not parallelizable.
        Throws:
        IOException