public class CassandraServiceImpl<T>
extends java.lang.Object
CassandraService
that actually use a Cassandra instance.Modifier and Type | Class and Description |
---|---|
static interface |
org.apache.beam.sdk.io.cassandra.CassandraService.Deleter<T>
Deleter for an entity.
|
static interface |
org.apache.beam.sdk.io.cassandra.CassandraService.Writer<T>
Writer for an entity.
|
protected class |
CassandraServiceImpl.DeleterImpl
Deleter storing an entity into Apache Cassandra database.
|
Constructor and Description |
---|
CassandraServiceImpl() |
Modifier and Type | Method and Description |
---|---|
org.apache.beam.sdk.io.cassandra.CassandraService.Deleter<T> |
createDeleter(CassandraIO.Mutate<T> spec)
Create a
CassandraService.Writer that writes entities into the Cassandra instance. |
org.apache.beam.sdk.io.cassandra.CassandraServiceImpl.CassandraReaderImpl |
createReader(org.apache.beam.sdk.io.cassandra.CassandraIO.CassandraSource<T> source)
Returns a
BoundedSource.BoundedReader that will read from
Cassandra using the spec from CassandraIO.CassandraSource . |
org.apache.beam.sdk.io.cassandra.CassandraService.Writer<T> |
createWriter(CassandraIO.Mutate<T> spec)
Create a
CassandraService.Writer that 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.
|
public org.apache.beam.sdk.io.cassandra.CassandraServiceImpl.CassandraReaderImpl createReader(org.apache.beam.sdk.io.cassandra.CassandraIO.CassandraSource<T> source)
BoundedSource.BoundedReader
that will read from
Cassandra using the spec from CassandraIO.CassandraSource
.public long getEstimatedSizeBytes(CassandraIO.Read<T> spec)
public java.util.List<BoundedSource<T>> split(CassandraIO.Read<T> spec, long desiredBundleSizeBytes)
public org.apache.beam.sdk.io.cassandra.CassandraService.Writer<T> createWriter(CassandraIO.Mutate<T> spec)
CassandraService.Writer
that writes entities into the Cassandra instance.public org.apache.beam.sdk.io.cassandra.CassandraService.Deleter<T> createDeleter(CassandraIO.Mutate<T> spec)
CassandraService.Writer
that writes entities into the Cassandra instance.