CassandraBaseContext

trait CassandraBaseContext[N <: NamingStrategy] extends CassandraStandardContext[N]
trait Decoders
trait Encoders
trait Encodings
trait Context[CqlIdiom, N]
trait Closeable
trait AutoCloseable
trait EncodingDsl
trait LowPriorityImplicits
trait ProtoContext[CqlIdiom, N]
trait RowContext
class Object
trait Matchable
class Any

Type members

Inherited classlikes

case class BatchGroup(string: String, prepare: List[Prepare])
Inherited from:
RowContext
case class BatchGroupReturning(string: String, returningBehavior: ReturnAction, prepare: List[Prepare])
Inherited from:
RowContext
case class CassandraDecoder[T](decoder: () => T) extends BaseDecoder[T]
Inherited from:
Decoders
case class CassandraEncoder[T](encoder: () => T) extends BaseEncoder[T]
Inherited from:
Encoders
Inherited from:
Context

Types

override type Session = CassandraSession

Inherited types

type BaseDecoder[T] = GenericDecoder[ResultRow, Session, T, Specific]
Inherited from:
EncodingDsl
type BaseEncoder[T] = GenericEncoder[T, PrepareRow, Session]
Inherited from:
EncodingDsl
type BaseNullChecker = GenericNullChecker[ResultRow, Session]
Inherited from:
EncodingDsl
type ColumnResolver = GenericColumnResolver[ResultRow]
Inherited from:
EncodingDsl
Inherited from:
Decoders
type DecoderMethod[T] = (Int, ResultRow, Session) => T
Inherited from:
EncodingDsl
Inherited from:
Encoders
type EncoderMethod[T] = (Int, T, PrepareRow, Session) => PrepareRow
Inherited from:
EncodingDsl
type Extractor[T] = (ResultRow, Session) => T
Inherited from:
RowContext
type Prepare = (PrepareRow, Session) => (List[Any], PrepareRow)
Inherited from:
RowContext
override type PrepareRow = BoundStatement
Inherited from:
CassandraRowContext
type Result[T]
Inherited from:
ProtoContext
override type ResultRow = Row
Inherited from:
CassandraRowContext
type RowTyper[T] = GenericRowTyper[ResultRow, T]
Inherited from:
EncodingDsl
Inherited from:
ProtoContext
override type RunActionReturningResult[T] = Unit
Inherited from:
ProtoContext
override type RunBatchActionReturningResult[T] = Unit
Inherited from:
ProtoContext
Inherited from:
ProtoContext
type Runner

Future class to hold things like ExecutionContext for Cassandra etc...

Future class to hold things like ExecutionContext for Cassandra etc...

Inherited from:
ProtoContext
type RunnerBehavior <: RunnerSummoningBehavior

Base type used to determine whether there is an execution context that needs to be summoned to perform execution methods e.g. in the PostgresJasync contexts that use Scala Futures that need an ExecutionContext.

Base type used to determine whether there is an execution context that needs to be summoned to perform execution methods e.g. in the PostgresJasync contexts that use Scala Futures that need an ExecutionContext.

Inherited from:
Context

Value members

Inherited methods

def close(): Unit
Inherited from:
Context
protected def context: Runner
Inherited from:
Context
def decoder[T](f: ResultRow => Int => T): CassandraDecoder[T]
Inherited from:
Decoders
def decoder[T](d: (Int, ResultRow, Session) => T): CassandraDecoder[T]
Inherited from:
Decoders
def encoder[T](f: PrepareRow => (Int, T) => PrepareRow): CassandraEncoder[T]
Inherited from:
Encoders
Inherited from:
Encoders
def executeAction(sql: String, prepare: Prepare)(executionInfo: ExecutionInfo, rn: Runner): Result[RunActionResult]
Inherited from:
ProtoContext
override def executeActionReturning[O](sql: String, prepare: Prepare, extractor: () => O, returningBehavior: ReturnAction)(info: ExecutionInfo, dc: Runner): Result[RunActionReturningResult[O]]
Definition Classes
CassandraStandardContext -> ProtoContext
Inherited from:
CassandraStandardContext
def executeBatchAction(groups: List[BatchGroup])(executionInfo: ExecutionInfo, rn: Runner): Result[RunBatchActionResult]
Inherited from:
ProtoContext
override def executeBatchActionReturning[T](groups: List[BatchGroupReturning], extractor: () => T)(info: ExecutionInfo, dc: Runner): Result[RunBatchActionReturningResult[T]]
Definition Classes
CassandraStandardContext -> ProtoContext
Inherited from:
CassandraStandardContext
def executeQuery[T](sql: String, prepare: Prepare, extractor: () => T)(executionInfo: ExecutionInfo, rn: Runner): Result[RunQueryResult[T]]
Inherited from:
ProtoContext
def executeQuerySingle[T](string: String, prepare: Prepare, extractor: () => T)(executionInfo: ExecutionInfo, rn: Runner): Result[RunQuerySingleResult[T]]
Inherited from:
ProtoContext
protected def handleSingleResult[T](list: List[T]): T
Inherited from:
Context
inline def lift[T](inline runtimeValue: T): T
Inherited from:
Context
inline def liftQuery[U <: (Iterable), T](inline runtimeValue: U[T]): Query[T]
Inherited from:
Context
protected def mappedBaseDecoder[Base, Mapped](mapped: MappedEncoding[Base, Mapped], decoder: () => Base): () => Mapped
Inherited from:
EncodingDsl
protected def mappedBaseEncoder[Mapped, Base](mapped: MappedEncoding[Mapped, Base], encoder: () => Base): () => Mapped
Inherited from:
EncodingDsl
def naming: N
Inherited from:
ProtoContext

Inherited fields

Inherited from:
RowContext
protected val identityPrepare: Prepare
Inherited from:
RowContext
val idiom: CqlIdiom.type
Inherited from:
CassandraRowContext
protected val zoneId: ZoneId
Inherited from:
Encodings

Extensions

Inherited extensions

extension [T](q: Query[T])
inline def filterByKeys(inline map: Map[String, String]): Query[T]

When using this with FilterColumns make sure it comes FIRST. Otherwise the columns are you filtering may have been nullified in the SQL before the filteration has actually happened.

When using this with FilterColumns make sure it comes FIRST. Otherwise the columns are you filtering may have been nullified in the SQL before the filteration has actually happened.

Inherited from:
Context
inline def filterColumns(inline columns: List[String]): Query[T]
Inherited from:
Context

Implicits

Inherited implicits

implicit inline def anyValDecoder[Cls <: AnyVal]: CassandraDecoder[Cls]
Inherited from:
LowPriorityImplicits
implicit inline def anyValEncoder[Cls <: AnyVal]: CassandraEncoder[Cls]
Inherited from:
LowPriorityImplicits
implicit val bigDecimalDecoder: CassandraDecoder[BigDecimal]
Inherited from:
Decoders
implicit val bigDecimalEncoder: CassandraEncoder[BigDecimal]
Inherited from:
Encoders
implicit val booleanCassandraType: CassandraType[Boolean]
Inherited from:
CassandraTypes
implicit val booleanDecoder: CassandraDecoder[Boolean]
Inherited from:
Decoders
implicit val booleanEncoder: CassandraEncoder[Boolean]
Inherited from:
Encoders
implicit val byteArrayDecoder: CassandraDecoder[Array[Byte]]
Inherited from:
Decoders
implicit val byteArrayEncoder: CassandraEncoder[Array[Byte]]
Inherited from:
Encoders
implicit val byteBufferCassandraType: CassandraType[ByteBuffer]
Inherited from:
CassandraTypes
implicit val byteCassandraType: CassandraType[Byte]
Inherited from:
CassandraTypes
implicit val byteDecoder: CassandraDecoder[Byte]
Inherited from:
Decoders
implicit val byteEncoder: CassandraEncoder[Byte]
Inherited from:
Encoders
implicit def cassandraIdentityDecodeMapper[Cas](implicit cas: CassandraType[Cas]): CassandraMapper[Cas, Cas, Decode]
implicit def cassandraIdentityEncodeMapper[Cas](implicit cas: CassandraType[Cas]): CassandraMapper[Cas, Cas, Encode]
Inherited from:
Decoders
Inherited from:
Encoders
Inherited from:
Decoders
Inherited from:
Encoders
implicit def cassandraMapperDecode[T, Cas](implicit m: MappedEncoding[Cas, T], cas: CassandraType[Cas]): CassandraMapper[Cas, T, Decode]
implicit def cassandraMapperDecodeRec[I, O, Cas](implicit m: MappedEncoding[I, O], cm: CassandraMapper[Cas, I, Decode]): CassandraMapper[Cas, O, Decode]
implicit def cassandraMapperEncode[T, Cas](implicit m: MappedEncoding[T, Cas], cas: CassandraType[Cas]): CassandraMapper[T, Cas, Encode]
implicit def cassandraMapperEncodeRec[I, O, Cas](implicit me: MappedEncoding[I, O], cm: CassandraMapper[O, Cas, Encode]): CassandraMapper[I, Cas, Encode]
implicit val dateCassandraType: CassandraType[Instant]
Inherited from:
CassandraTypes
implicit inline def dec[T]: GenericDecoder[ResultRow, Session, T, Generic]
Inherited from:
Context
implicit val decimalCassandraType: CassandraType[BigDecimal]
Inherited from:
CassandraTypes
implicit val decodeBigDecimal: CassandraMapper[BigDecimal, BigDecimal, Decode]
Inherited from:
CassandraMappedTypes
implicit val decodeBoolean: CassandraMapper[Boolean, Boolean, Decode]
Inherited from:
CassandraMappedTypes
implicit val decodeByte: CassandraMapper[Byte, Byte, Decode]
Inherited from:
CassandraMappedTypes
implicit val decodeByteArray: CassandraMapper[ByteBuffer, Array[Byte], Decode]
Inherited from:
CassandraMappedTypes
implicit val decodeDouble: CassandraMapper[Double, Double, Decode]
Inherited from:
CassandraMappedTypes
implicit val decodeFloat: CassandraMapper[Float, Float, Decode]
Inherited from:
CassandraMappedTypes
implicit val decodeInt: CassandraMapper[Integer, Int, Decode]
Inherited from:
CassandraMappedTypes
implicit val decodeJava8ZonedDateTime: MappedEncoding[Instant, ZonedDateTime]
Inherited from:
Encodings
implicit val decodeLong: CassandraMapper[Long, Long, Decode]
Inherited from:
CassandraMappedTypes
implicit val decodeShort: CassandraMapper[Short, Short, Decode]
Inherited from:
CassandraMappedTypes
implicit val doubleCassandraType: CassandraType[Double]
Inherited from:
CassandraTypes
implicit val doubleDecoder: CassandraDecoder[Double]
Inherited from:
Decoders
implicit val doubleEncoder: CassandraEncoder[Double]
Inherited from:
Encoders
implicit val encodeBigDecimal: CassandraMapper[BigDecimal, BigDecimal, Encode]
Inherited from:
CassandraMappedTypes
implicit val encodeBoolean: CassandraMapper[Boolean, Boolean, Encode]
Inherited from:
CassandraMappedTypes
implicit val encodeByte: CassandraMapper[Byte, Byte, Encode]
Inherited from:
CassandraMappedTypes
implicit val encodeByteArray: CassandraMapper[Array[Byte], ByteBuffer, Encode]
Inherited from:
CassandraMappedTypes
implicit val encodeDouble: CassandraMapper[Double, Double, Encode]
Inherited from:
CassandraMappedTypes
implicit val encodeFloat: CassandraMapper[Float, Float, Encode]
Inherited from:
CassandraMappedTypes
implicit val encodeInt: CassandraMapper[Int, Integer, Encode]
Inherited from:
CassandraMappedTypes
implicit val encodeJava8ZonedDateTime: MappedEncoding[ZonedDateTime, Instant]
Inherited from:
Encodings
implicit val encodeLong: CassandraMapper[Long, Long, Encode]
Inherited from:
CassandraMappedTypes
implicit val encodeShort: CassandraMapper[Short, Short, Encode]
Inherited from:
CassandraMappedTypes
implicit val floatCassandraType: CassandraType[Float]
Inherited from:
CassandraTypes
implicit val floatDecoder: CassandraDecoder[Float]
Inherited from:
Decoders
implicit val floatEncoder: CassandraEncoder[Float]
Inherited from:
Encoders
implicit val intDecoder: CassandraDecoder[Int]
Inherited from:
Decoders
implicit val intEncoder: CassandraEncoder[Int]
Inherited from:
Encoders
implicit val integerCassandraType: CassandraType[Integer]
Inherited from:
CassandraTypes
implicit def listDecoder[T, Cas](implicit mapper: CassandraMapper[Cas, T, Decode], ct: ClassTag[Cas]): CassandraDecoder[List[T]]
Inherited from:
CollectionDecoders
implicit def listEncoder[T, Cas](implicit mapper: CassandraMapper[T, Cas, Encode], ct: ClassTag[Cas]): CassandraEncoder[List[T]]
Inherited from:
CollectionEncoders
implicit val localDateCassandraType: CassandraType[LocalDate]
Inherited from:
CassandraTypes
implicit val longCassandraType: CassandraType[Long]
Inherited from:
CassandraTypes
implicit val longDecoder: CassandraDecoder[Long]
Inherited from:
Decoders
implicit val longEncoder: CassandraEncoder[Long]
Inherited from:
Encoders
implicit def mapDecoder[K, V, KCas, VCas](implicit keyMapper: CassandraMapper[KCas, K, Decode], valMapper: CassandraMapper[VCas, V, Decode], a: ClassTag[KCas], b: ClassTag[VCas]): CassandraDecoder[Map[K, V]]
Inherited from:
CollectionDecoders
implicit def mapEncoder[K, V, KCas, VCas](implicit keyMapper: CassandraMapper[K, KCas, Encode], valMapper: CassandraMapper[V, VCas, Encode], a: ClassTag[KCas], b: ClassTag[VCas]): CassandraEncoder[Map[K, V]]
Inherited from:
CollectionEncoders
implicit def mappedDecoder[I, O](implicit mapped: MappedEncoding[I, O], decoder: CassandraDecoder[I]): CassandraDecoder[O]
Inherited from:
Decoders
implicit def mappedEncoder[I, O](implicit mapped: MappedEncoding[I, O], encoder: CassandraEncoder[O]): CassandraEncoder[I]
Inherited from:
Encoders
implicit val nullChecker: NullChecker
Inherited from:
CassandraRowContext
implicit def optionDecoder[T](implicit d: CassandraDecoder[T]): CassandraDecoder[Option[T]]
Inherited from:
Decoders
implicit def optionEncoder[T](implicit d: CassandraEncoder[T]): CassandraEncoder[Option[T]]
Inherited from:
Encoders
implicit def setDecoder[T, Cas](implicit mapper: CassandraMapper[Cas, T, Decode], ct: ClassTag[Cas]): CassandraDecoder[Set[T]]
Inherited from:
CollectionDecoders
implicit def setEncoder[T, Cas](implicit mapper: CassandraMapper[T, Cas, Encode], ct: ClassTag[Cas]): CassandraEncoder[Set[T]]
Inherited from:
CollectionEncoders
implicit val shortCassandraType: CassandraType[Short]
Inherited from:
CassandraTypes
implicit val shortDecoder: CassandraDecoder[Short]
Inherited from:
Decoders
implicit val shortEncoder: CassandraEncoder[Short]
Inherited from:
Encoders
implicit val stringCassandraType: CassandraType[String]
Inherited from:
CassandraTypes
implicit val stringDecoder: CassandraDecoder[String]
Inherited from:
Decoders
implicit val stringEncoder: CassandraEncoder[String]
Inherited from:
Encoders
implicit val timestampDecoder: CassandraDecoder[Instant]
Inherited from:
Decoders
implicit val timestampEncoder: CassandraEncoder[Instant]
Inherited from:
Encoders
implicit inline def udtDecodeMapper[T <: Udt](using NotGiven[T =:= Udt]): CassandraMapper[UdtValue, T, Decode]
Inherited from:
UdtDecoding
implicit inline def udtDecoder[T <: Udt](using NotGiven[T =:= Udt]): CassandraDecoder[T]
Inherited from:
UdtDecoding
implicit inline def udtEncodeMapper[T <: Udt]: CassandraMapper[T, UdtValue, Encode]
Inherited from:
UdtEncoding
implicit inline def udtEncoder[T <: Udt]: CassandraEncoder[T]
Inherited from:
UdtEncoding
implicit val uuidCassandraType: CassandraType[UUID]
Inherited from:
CassandraTypes
implicit val uuidDecoder: CassandraDecoder[UUID]
Inherited from:
Decoders
implicit val uuidEncoder: CassandraEncoder[UUID]
Inherited from:
Encoders