public class CassandraBackingMap<T> extends Object implements IBackingMap<T>
An IBackingState implementation for Cassandra.
The implementation stores state as a binary blob in cassandra using a Serializer
. It supports Opaque, Transactional and NonTransactional states, given a matching serializer.
Configuration is done with three separate constructs: - One tuple mapper for multiGet, which should map keys to a select statement and return Values
. - One state mapper, which maps the state to/from a Values
representation, which is used for binding. - One tuple mapper for multiPut, which should map Values
to an INSERT or UPDATE statement.
multiPut(List, List)
updates Cassandra with parallel statements. multiGet(List)
queries Cassandra with parallel statements.
Parallelism defaults to half the maximum requests per host, either local or remote whichever is lower. The driver defaults to 256 for remote hosts and 1024 for local hosts, so the default value is 128 unless the driver is configured otherwise.
Modifier and Type | Class and Description |
---|---|
static class |
CassandraBackingMap.Options<T> |
Modifier | Constructor and Description |
---|---|
protected |
CassandraBackingMap(Map<String,Object> conf,
CassandraBackingMap.Options<T> options) |
protected CassandraBackingMap(Map<String,Object> conf, CassandraBackingMap.Options<T> options)
Copyright © 2022 The Apache Software Foundation. All rights reserved.