public interface CassandraService<T>
extends java.io.Serializable
| Modifier and Type | Interface and Description | 
|---|---|
| static interface  | CassandraService.Writer<T>Writer for an entity. | 
| Modifier and Type | Method and Description | 
|---|---|
| BoundedSource.BoundedReader<T> | createReader(org.apache.beam.sdk.io.cassandra.CassandraIO.CassandraSource<T> source)Returns a  BoundedSource.BoundedReaderthat will read from
 Cassandra using the spec fromCassandraIO.CassandraSource. | 
| CassandraService.Writer | createWriter(CassandraIO.Write<T> spec)Create a  CassandraService.Writerthat writes entities into the Cassandra instance. | 
| long | getEstimatedSizeBytes(CassandraIO.Read<T> spec)Returns an estimation of the size that could be read. | 
| java.util.List<BoundedSource<T>> | split(CassandraIO.Read<T> spec,
     long desiredBundleSizeBytes)Split a table read into several sources. | 
BoundedSource.BoundedReader<T> createReader(org.apache.beam.sdk.io.cassandra.CassandraIO.CassandraSource<T> source)
BoundedSource.BoundedReader that will read from
 Cassandra using the spec from CassandraIO.CassandraSource.long getEstimatedSizeBytes(CassandraIO.Read<T> spec)
java.util.List<BoundedSource<T>> split(CassandraIO.Read<T> spec, long desiredBundleSizeBytes)
CassandraService.Writer createWriter(CassandraIO.Write<T> spec)
CassandraService.Writer that writes entities into the Cassandra instance.