CassandraSessionContext

io.getquill.context.cassandra.CassandraSessionContext
abstract class CassandraSessionContext[+N <: NamingStrategy] extends CassandraPrepareContext[N], CassandraBaseContext[N]

Attributes

Graph
Supertypes
trait Decoders
trait UdtDecoding
trait Encoders
trait UdtEncoding
trait CassandraContext[N]
trait Encodings
trait Context[CqlIdiom, N]
trait Closeable
trait AutoCloseable
trait EncodingDsl
trait LowPriorityImplicits
trait ProtoContextSecundus[CqlIdiom, N]
trait RowContext
class Object
trait Matchable
class Any
Show all
Known subtypes

Members list

Type members

Inherited classlikes

case class BatchGroup(string: String, prepare: List[Prepare])

Attributes

Inherited from:
RowContext
Supertypes
trait Serializable
trait Product
trait Equals
class Object
trait Matchable
class Any
Show all
case class BatchGroupReturning(string: String, returningBehavior: ReturnAction, prepare: List[Prepare])

Attributes

Inherited from:
RowContext
Supertypes
trait Serializable
trait Product
trait Equals
class Object
trait Matchable
class Any
Show all
case class CassandraDecoder[T](decoder: () => T) extends BaseDecoder[T]

Attributes

Inherited from:
Decoders
Supertypes
trait Serializable
trait Product
trait Equals
trait GenericDecoder[ResultRow, Session, T, Specific]
trait (Int, ResultRow, Session) => T
class Object
trait Matchable
class Any
Show all
case class CassandraEncoder[T](encoder: () => T) extends BaseEncoder[T]

Attributes

Inherited from:
Encoders
Supertypes
trait Serializable
trait Product
trait Equals
trait GenericEncoder[T, PrepareRow, Session]
trait (Int, T, PrepareRow, Session) => PrepareRow
class Object
trait Matchable
class Any
Show all

Attributes

Inherited from:
CassandraRowContext
Supertypes
trait GenericNullChecker[ResultRow, Session]
class Object
trait Matchable
class Any
object InternalApi

Attributes

Inherited from:
Context
Supertypes
class Object
trait Matchable
class Any

Inherited types

type BaseDecoder[T] = GenericDecoder[ResultRow, Session, T, Specific]

Attributes

Inherited from:
EncodingDsl
type BaseEncoder[T] = GenericEncoder[T, PrepareRow, Session]

Attributes

Inherited from:
EncodingDsl
type BaseNullChecker = GenericNullChecker[ResultRow, Session]

Attributes

Inherited from:
EncodingDsl
type ColumnResolver = GenericColumnResolver[ResultRow]

Attributes

Inherited from:
EncodingDsl
type Decoder[T] = CassandraDecoder[T]

Attributes

Inherited from:
Decoders
type DecoderMethod[T] = (Int, ResultRow, Session) => T

Attributes

Inherited from:
EncodingDsl
type Encoder[T] = CassandraEncoder[T]

Attributes

Inherited from:
Encoders
type EncoderMethod[T] = (Int, T, PrepareRow, Session) => PrepareRow

Attributes

Inherited from:
EncodingDsl
type Extractor[T] = (ResultRow, Session) => T

Attributes

Inherited from:
RowContext

Attributes

Inherited from:
CassandraRowContext
type Prepare = (PrepareRow, Session) => (List[Any], PrepareRow)

Attributes

Inherited from:
RowContext
override type PrepareRow = BoundStatement

Attributes

Inherited from:
CassandraRowContext
type Result[T]

Attributes

Inherited from:
ProtoContextSecundus
override type ResultRow = Row

Attributes

Inherited from:
CassandraRowContext
type RowTyper[T] = GenericRowTyper[ResultRow, T]

Attributes

Inherited from:
EncodingDsl

Attributes

Inherited from:
ProtoContextSecundus
override type RunActionReturningResult[T] = Unit

Attributes

Inherited from:
CassandraStandardContext

Attributes

Inherited from:
ProtoContextSecundus
override type RunBatchActionReturningResult[T] = Unit

Attributes

Inherited from:
CassandraStandardContext
type RunQueryResult[T]

Attributes

Inherited from:
ProtoContextSecundus

Attributes

Inherited from:
ProtoContextSecundus
type Runner

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

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

Attributes

Inherited from:
ProtoContextSecundus
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.

Attributes

Inherited from:
Context
override type Session = CassandraSession

Attributes

Inherited from:
CassandraBaseContext

Value members

Inherited methods

def close(): Unit

Attributes

Inherited from:
Context
protected def context: Runner

Attributes

Inherited from:
Context
def decoder[T](f: ResultRow => Int => T): CassandraDecoder[T]

Attributes

Inherited from:
Decoders
def decoder[T](d: (Int, ResultRow, Session) => T): CassandraDecoder[T]

Attributes

Inherited from:
Decoders
def encoder[T](f: PrepareRow => (Int, T) => PrepareRow): CassandraEncoder[T]

Attributes

Inherited from:
Encoders
def encoder[T](e: (Int, T, PrepareRow, Session) => PrepareRow): CassandraEncoder[T]

Attributes

Inherited from:
Encoders
def executeAction(sql: String, prepare: Prepare)(executionInfo: ExecutionInfo, rn: Runner): Result[RunActionResult]

Attributes

Inherited from:
ProtoContextSecundus
override def executeActionReturning[O](sql: String, prepare: Prepare, extractor: () => O, returningBehavior: ReturnAction)(info: ExecutionInfo, dc: Runner): Result[RunActionReturningResult[O]]

Attributes

Definition Classes
CassandraStandardContext -> ProtoContextSecundus
Inherited from:
CassandraStandardContext
override def executeActionReturningMany[O](sql: String, prepare: Prepare, extractor: () => O, returningBehavior: ReturnAction)(info: ExecutionInfo, dc: Runner): Result[RunActionReturningResult[List[O]]]

Attributes

Definition Classes
CassandraStandardContext -> ProtoContextSecundus
Inherited from:
CassandraStandardContext
def executeBatchAction(groups: List[BatchGroup])(executionInfo: ExecutionInfo, rn: Runner): Result[RunBatchActionResult]

Attributes

Inherited from:
ProtoContextSecundus
override def executeBatchActionReturning[T](groups: List[BatchGroupReturning], extractor: () => T)(info: ExecutionInfo, dc: Runner): Result[RunBatchActionReturningResult[T]]

Attributes

Definition Classes
CassandraStandardContext -> ProtoContextSecundus
Inherited from:
CassandraStandardContext
def executeQuery[T](sql: String, prepare: Prepare, extractor: () => T)(executionInfo: ExecutionInfo, rn: Runner): Result[RunQueryResult[T]]

Attributes

Inherited from:
ProtoContextSecundus
def executeQuerySingle[T](string: String, prepare: Prepare, extractor: () => T)(executionInfo: ExecutionInfo, rn: Runner): Result[RunQuerySingleResult[T]]

Attributes

Inherited from:
ProtoContextSecundus
protected def handleSingleResult[T](sql: String, list: List[T]): T

Attributes

Inherited from:
Context
inline def lift[T](inline runtimeValue: T): T

Attributes

Inherited from:
Context
inline def liftQuery[U <: (Iterable), T](inline runtimeValue: U[T]): Query[T]

Attributes

Inherited from:
Context
protected def mappedBaseDecoder[Base, Mapped](mapped: MappedEncoding[Base, Mapped], decoder: () => Base): () => Mapped

Attributes

Inherited from:
EncodingDsl
protected def mappedBaseEncoder[Mapped, Base](mapped: MappedEncoding[Mapped, Base], encoder: () => Base): () => Mapped

Attributes

Inherited from:
EncodingDsl
def naming: Naming

Attributes

Inherited from:
ProtoContextSecundus
protected def prepareAsync(cql: String)(implicit executionContext: ExecutionContext): Future[BoundStatement]

Attributes

Inherited from:
CassandraPrepareContext
protected def prepareAsyncAndGetStatement(cql: String, prepare: Prepare, session: Session, logger: ContextLogger)(implicit executionContext: ExecutionContext): Future[BoundStatement]

Attributes

Inherited from:
CassandraPrepareContext
def probe(cql: String): Try[_]

Attributes

Inherited from:
CassandraPrepareContext

Inherited fields

Attributes

Inherited from:
RowContext
protected val identityPrepare: Prepare

Attributes

Inherited from:
RowContext
val idiom: CqlIdiom.type

Attributes

Inherited from:
CassandraRowContext
protected val zoneId: ZoneId

Attributes

Inherited from:
Encodings

Extensions

Inherited extensions

extension [T](inline dynamicQuery: DynamicEntityQuery[T])
inline def insertValue(value: T): DynamicInsert[T]

Attributes

Inherited from:
Context
inline def updateValue(value: T): DynamicUpdate[T]

Attributes

Inherited from:
Context
extension [T](inline entity: EntityQuery[T])
inline def insertValue(inline value: T): Insert[T]

Attributes

Inherited from:
Context
inline def updateValue(inline value: T): Update[T]

Attributes

Inherited from:
Context
extension [T](inline q: Query[T])
inline def filterByKeys(inline map: Map[String, Any]): 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.

Attributes

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

Attributes

Inherited from:
Context
extension [T](inline quotedEntity: Quoted[EntityQuery[T]])
inline def insertValue(inline value: T): Insert[T]

Attributes

Inherited from:
Context
inline def updateValue(inline value: T): Update[T]

Attributes

Inherited from:
Context

Implicits

Inherited implicits

implicit inline def anyValDecoder[Cls <: AnyVal]: Decoder[Cls]

Attributes

Inherited from:
LowPriorityImplicits
implicit inline def anyValEncoder[Cls <: AnyVal]: Encoder[Cls]

Attributes

Inherited from:
LowPriorityImplicits
implicit val bigDecimalDecoder: CassandraDecoder[BigDecimal]

Attributes

Inherited from:
Decoders
implicit val bigDecimalEncoder: CassandraEncoder[BigDecimal]

Attributes

Inherited from:
Encoders
implicit val booleanCassandraType: CassandraType[Boolean]

Attributes

Inherited from:
CassandraTypes
implicit val booleanDecoder: CassandraDecoder[Boolean]

Attributes

Inherited from:
Decoders
implicit val booleanEncoder: CassandraEncoder[Boolean]

Attributes

Inherited from:
Encoders
implicit val byteArrayDecoder: CassandraDecoder[Array[Byte]]

Attributes

Inherited from:
Decoders
implicit val byteArrayEncoder: CassandraEncoder[Array[Byte]]

Attributes

Inherited from:
Encoders
implicit val byteBufferCassandraType: CassandraType[ByteBuffer]

Attributes

Inherited from:
CassandraTypes
implicit val byteCassandraType: CassandraType[Byte]

Attributes

Inherited from:
CassandraTypes
implicit val byteDecoder: CassandraDecoder[Byte]

Attributes

Inherited from:
Decoders
implicit val byteEncoder: CassandraEncoder[Byte]

Attributes

Inherited from:
Encoders
implicit def cassandraIdentityDecodeMapper[Cas](implicit cas: CassandraType[Cas]): CassandraMapper[Cas, Cas, Decode]

Attributes

Inherited from:
CassandraMapperConversions
implicit def cassandraIdentityEncodeMapper[Cas](implicit cas: CassandraType[Cas]): CassandraMapper[Cas, Cas, Encode]

Attributes

Inherited from:
CassandraMapperConversions
implicit val cassandraLocalDateDecoder: CassandraDecoder[LocalDate]

Attributes

Inherited from:
Decoders
implicit val cassandraLocalDateEncoder: CassandraEncoder[LocalDate]

Attributes

Inherited from:
Encoders
implicit val cassandraLocalTimeDecoder: CassandraDecoder[LocalTime]

Attributes

Inherited from:
Decoders
implicit val cassandraLocalTimeEncoder: CassandraEncoder[LocalTime]

Attributes

Inherited from:
Encoders
implicit def cassandraMapperDecode[T, Cas](implicit m: MappedEncoding[Cas, T], cas: CassandraType[Cas]): CassandraMapper[Cas, T, Decode]

Attributes

Inherited from:
CassandraMapperConversions
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]

Attributes

Inherited from:
CassandraMapperConversions
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]

Attributes

Inherited from:
CassandraTypes
implicit inline def dec[T]: GenericDecoder[ResultRow, Session, T, Generic]

Attributes

Inherited from:
Context
implicit val decimalCassandraType: CassandraType[BigDecimal]

Attributes

Inherited from:
CassandraTypes
implicit val decodeBigDecimal: CassandraMapper[BigDecimal, BigDecimal, Decode]

Attributes

Inherited from:
CassandraMappedTypes
implicit val decodeBoolean: CassandraMapper[Boolean, Boolean, Decode]

Attributes

Inherited from:
CassandraMappedTypes
implicit val decodeByte: CassandraMapper[Byte, Byte, Decode]

Attributes

Inherited from:
CassandraMappedTypes
implicit val decodeByteArray: CassandraMapper[ByteBuffer, Array[Byte], Decode]

Attributes

Inherited from:
CassandraMappedTypes
implicit val decodeDouble: CassandraMapper[Double, Double, Decode]

Attributes

Inherited from:
CassandraMappedTypes
implicit val decodeFloat: CassandraMapper[Float, Float, Decode]

Attributes

Inherited from:
CassandraMappedTypes
implicit val decodeInt: CassandraMapper[Integer, Int, Decode]

Attributes

Inherited from:
CassandraMappedTypes
implicit val decodeJava8ZonedDateTime: MappedEncoding[Instant, ZonedDateTime]

Attributes

Inherited from:
Encodings
implicit val decodeLong: CassandraMapper[Long, Long, Decode]

Attributes

Inherited from:
CassandraMappedTypes
implicit val decodeShort: CassandraMapper[Short, Short, Decode]

Attributes

Inherited from:
CassandraMappedTypes
implicit val doubleCassandraType: CassandraType[Double]

Attributes

Inherited from:
CassandraTypes
implicit val doubleDecoder: CassandraDecoder[Double]

Attributes

Inherited from:
Decoders
implicit val doubleEncoder: CassandraEncoder[Double]

Attributes

Inherited from:
Encoders
implicit val encodeBigDecimal: CassandraMapper[BigDecimal, BigDecimal, Encode]

Attributes

Inherited from:
CassandraMappedTypes
implicit val encodeBoolean: CassandraMapper[Boolean, Boolean, Encode]

Attributes

Inherited from:
CassandraMappedTypes
implicit val encodeByte: CassandraMapper[Byte, Byte, Encode]

Attributes

Inherited from:
CassandraMappedTypes
implicit val encodeByteArray: CassandraMapper[Array[Byte], ByteBuffer, Encode]

Attributes

Inherited from:
CassandraMappedTypes
implicit val encodeDouble: CassandraMapper[Double, Double, Encode]

Attributes

Inherited from:
CassandraMappedTypes
implicit val encodeFloat: CassandraMapper[Float, Float, Encode]

Attributes

Inherited from:
CassandraMappedTypes
implicit val encodeInt: CassandraMapper[Int, Integer, Encode]

Attributes

Inherited from:
CassandraMappedTypes
implicit val encodeJava8ZonedDateTime: MappedEncoding[ZonedDateTime, Instant]

Attributes

Inherited from:
Encodings
implicit val encodeLong: CassandraMapper[Long, Long, Encode]

Attributes

Inherited from:
CassandraMappedTypes
implicit val encodeShort: CassandraMapper[Short, Short, Encode]

Attributes

Inherited from:
CassandraMappedTypes
implicit val floatCassandraType: CassandraType[Float]

Attributes

Inherited from:
CassandraTypes
implicit val floatDecoder: CassandraDecoder[Float]

Attributes

Inherited from:
Decoders
implicit val floatEncoder: CassandraEncoder[Float]

Attributes

Inherited from:
Encoders
implicit val intDecoder: CassandraDecoder[Int]

Attributes

Inherited from:
Decoders
implicit val intEncoder: CassandraEncoder[Int]

Attributes

Inherited from:
Encoders
implicit val integerCassandraType: CassandraType[Integer]

Attributes

Inherited from:
CassandraTypes
implicit def listDecoder[T, Cas](implicit mapper: CassandraMapper[Cas, T, Decode], ct: ClassTag[Cas]): CassandraDecoder[List[T]]

Attributes

Inherited from:
CollectionDecoders
implicit def listEncoder[T, Cas](implicit mapper: CassandraMapper[T, Cas, Encode], ct: ClassTag[Cas]): CassandraEncoder[List[T]]

Attributes

Inherited from:
CollectionEncoders
implicit val localDateCassandraType: CassandraType[LocalDate]

Attributes

Inherited from:
CassandraTypes
implicit val longCassandraType: CassandraType[Long]

Attributes

Inherited from:
CassandraTypes
implicit val longDecoder: CassandraDecoder[Long]

Attributes

Inherited from:
Decoders
implicit val longEncoder: CassandraEncoder[Long]

Attributes

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]]

Attributes

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]]

Attributes

Inherited from:
CollectionEncoders
implicit def mappedDecoder[I, O](implicit mapped: MappedEncoding[I, O], decoder: CassandraDecoder[I]): CassandraDecoder[O]

Attributes

Inherited from:
Decoders
implicit def mappedEncoder[I, O](implicit mapped: MappedEncoding[I, O], encoder: CassandraEncoder[O]): CassandraEncoder[I]

Attributes

Inherited from:
Encoders
implicit val nullChecker: NullChecker

Attributes

Inherited from:
CassandraRowContext
implicit def optionDecoder[T](implicit d: CassandraDecoder[T]): CassandraDecoder[Option[T]]

Attributes

Inherited from:
Decoders
implicit def optionEncoder[T](implicit d: CassandraEncoder[T]): CassandraEncoder[Option[T]]

Attributes

Inherited from:
Encoders
implicit def setDecoder[T, Cas](implicit mapper: CassandraMapper[Cas, T, Decode], ct: ClassTag[Cas]): CassandraDecoder[Set[T]]

Attributes

Inherited from:
CollectionDecoders
implicit def setEncoder[T, Cas](implicit mapper: CassandraMapper[T, Cas, Encode], ct: ClassTag[Cas]): CassandraEncoder[Set[T]]

Attributes

Inherited from:
CollectionEncoders
implicit val shortCassandraType: CassandraType[Short]

Attributes

Inherited from:
CassandraTypes
implicit val shortDecoder: CassandraDecoder[Short]

Attributes

Inherited from:
Decoders
implicit val shortEncoder: CassandraEncoder[Short]

Attributes

Inherited from:
Encoders
implicit val stringCassandraType: CassandraType[String]

Attributes

Inherited from:
CassandraTypes
implicit val stringDecoder: CassandraDecoder[String]

Attributes

Inherited from:
Decoders
implicit val stringEncoder: CassandraEncoder[String]

Attributes

Inherited from:
Encoders
implicit val timestampDecoder: CassandraDecoder[Instant]

Attributes

Inherited from:
Decoders
implicit val timestampEncoder: CassandraEncoder[Instant]

Attributes

Inherited from:
Encoders
implicit inline def udtDecodeMapper[T <: Udt](using NotGiven[T =:= Udt]): CassandraMapper[UdtValue, T, Decode]

Attributes

Inherited from:
UdtDecoding
implicit inline def udtDecoder[T <: Udt](using NotGiven[T =:= Udt]): CassandraDecoder[T]

Attributes

Inherited from:
UdtDecoding
implicit inline def udtEncodeMapper[T <: Udt]: CassandraMapper[T, UdtValue, Encode]

Attributes

Inherited from:
UdtEncoding
implicit inline def udtEncoder[T <: Udt]: CassandraEncoder[T]

Attributes

Inherited from:
UdtEncoding
implicit val uuidCassandraType: CassandraType[UUID]

Attributes

Inherited from:
CassandraTypes
implicit val uuidDecoder: CassandraDecoder[UUID]

Attributes

Inherited from:
Decoders
implicit val uuidEncoder: CassandraEncoder[UUID]

Attributes

Inherited from:
Encoders