CassandraMirrorContext

class CassandraMirrorContext[Naming <: NamingStrategy](naming: Naming) extends MirrorContext[CqlIdiom, Naming] with CassandraContext[Naming]
trait CassandraContext[Naming]
trait Encodings
class MirrorContext[CqlIdiom, Naming]
trait AstSplicing
trait MirrorContextBase[CqlIdiom, Naming]
trait MirrorEncoders
trait MirrorDecoders
trait ContextVerbTranslate[CqlIdiom, Naming]
trait ContextTranslateMacro[CqlIdiom, Naming]
trait ContextTranslateProto[CqlIdiom, Naming]
trait ContextVerbPrepare[CqlIdiom, Naming]
trait Context[CqlIdiom, Naming]
trait Closeable
trait AutoCloseable
trait EncodingDsl
trait LowPriorityImplicits
trait ProtoContext[CqlIdiom, Naming]
trait RowContext
class Object
trait Matchable
class Any

Type members

Inherited classlikes

case class ActionMirror(string: String, prepareRow: PrepareRow, info: ExecutionInfo)
Inherited from:
MirrorContextBase
case class ActionReturningMirror[T](string: String, prepareRow: PrepareRow, extractor: () => T, returningBehavior: ReturnAction, info: ExecutionInfo)
Inherited from:
MirrorContextBase
case class BatchActionMirror(groups: List[(String, List[Row])], info: ExecutionInfo)
Inherited from:
MirrorContextBase
case class BatchActionReturningMirror[T](groups: List[(String, ReturnAction, List[PrepareRow])], extractor: () => T, info: ExecutionInfo)
Inherited from:
MirrorContextBase
case class BatchGroup(string: String, prepare: List[Prepare])
Inherited from:
RowContext
case class BatchGroupReturning(string: String, returningBehavior: ReturnAction, prepare: List[Prepare])
Inherited from:
RowContext
Inherited from:
Context
case class MirrorDecoder[T](decoder: () => T) extends BaseDecoder[T]
Inherited from:
MirrorDecoders
case class MirrorEncoder[T](encoder: () => T) extends BaseEncoder[T]
Inherited from:
MirrorEncoders
class MirrorNullChecker extends BaseNullChecker
Inherited from:
MirrorContextBase
case class PrepareBatchMirror(groups: List[(String, List[PrepareRow])], info: ExecutionInfo)
Inherited from:
MirrorContextBase
case class PrepareQueryMirror(sql: String, prepare: Prepare, info: ExecutionInfo)
Inherited from:
MirrorContextBase
case class QueryMirror[T](string: String, prepareRow: PrepareRow, extractor: () => T, info: ExecutionInfo)
Inherited from:
MirrorContextBase

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
type Decoder[T] = MirrorDecoder[T]
Inherited from:
MirrorDecoders
type DecoderMethod[T] = (Int, ResultRow, Session) => T
Inherited from:
EncodingDsl
type Encoder[T] = MirrorEncoder[T]
Inherited from:
MirrorEncoders
type EncoderMethod[T] = (Int, T, PrepareRow, Session) => PrepareRow
Inherited from:
EncodingDsl
override type Extractor[T] = (ResultRow, MirrorSession) => T
Inherited from:
MirrorContextBase
Inherited from:
MirrorContextBase
type Prepare = (PrepareRow, Session) => (List[Any], PrepareRow)
Inherited from:
RowContext
Inherited from:
MirrorContextBase
Inherited from:
MirrorContextBase
Inherited from:
MirrorContextBase
override type PrepareRow = Row
Inherited from:
MirrorContextBase
override type Result[T] = T
Inherited from:
MirrorContextBase
override type ResultRow = Row
Inherited from:
MirrorContextBase
type RowTyper[T] = GenericRowTyper[ResultRow, T]
Inherited from:
EncodingDsl
Inherited from:
MirrorContextBase
Inherited from:
MirrorContextBase
Inherited from:
MirrorContextBase
Inherited from:
MirrorContextBase
override type RunQueryResult[T] = QueryMirror[T]
Inherited from:
MirrorContextBase
override type RunQuerySingleResult[T] = QueryMirror[T]
Inherited from:
MirrorContextBase
override type Runner = Unit
Inherited from:
MirrorContextBase
type RunnerBehavior <: RunnerSummoningBehavior
Inherited from:
ContextTranslateMacro
override type Session = MirrorSession
Inherited from:
MirrorContextBase
override type TranslateResult[T] = T
Inherited from:
ContextVerbTranslate
override type TranslateRunner = Unit
Inherited from:
MirrorContextBase

Value members

Inherited methods

inline def _summonPrepareRunner(): Runner
Inherited from:
ContextVerbPrepare
inline def _summonTranslateRunner(): TranslateRunner

Internal API that cannot be made private due to how inline functions

Internal API that cannot be made private due to how inline functions

Inherited from:
ContextTranslateMacro
def close(): Unit
Inherited from:
Context
override def context: Runner
Definition Classes
MirrorContextBase -> Context
Inherited from:
MirrorContextBase
def decoder[T : ClassTag]: MirrorDecoder[T]
Inherited from:
MirrorDecoders
Inherited from:
MirrorDecoders
Inherited from:
MirrorEncoders
override def executeAction(string: String, prepare: Prepare)(info: ExecutionInfo, dc: Runner): Result[RunActionResult]
Definition Classes
MirrorContextBase -> ProtoContext
Inherited from:
MirrorContextBase
def executeActionReturning[T](sql: String, prepare: Prepare, extractor: () => T, returningBehavior: ReturnAction)(info: ExecutionInfo, dc: Runner): Result[ActionReturningMirror[T]]
Inherited from:
MirrorContextBase
override def executeBatchAction(groups: List[BatchGroup])(info: ExecutionInfo, dc: Runner): Result[RunBatchActionResult]
Definition Classes
MirrorContextBase -> ProtoContext
Inherited from:
MirrorContextBase
override def executeBatchActionReturning[T](groups: List[BatchGroupReturning], extractor: () => T)(info: ExecutionInfo, dc: Runner): Result[BatchActionReturningMirror[T]]
Definition Classes
MirrorContextBase -> ProtoContext
Inherited from:
MirrorContextBase
override def executeQuery[T](string: String, prepare: Prepare, extractor: () => T)(info: ExecutionInfo, dc: Runner): Result[QueryMirror[T]]
Definition Classes
MirrorContextBase -> ProtoContext
Inherited from:
MirrorContextBase
override def executeQuerySingle[T](string: String, prepare: Prepare, extractor: () => T)(info: ExecutionInfo, dc: Runner): Result[QueryMirror[T]]
Definition Classes
MirrorContextBase -> ProtoContext
Inherited from:
MirrorContextBase
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
@targetName("runPrepareBatchAction")
inline def prepare[I, A <: Action[I] & QAC[I, Nothing]](inline quoted: Quoted[BatchAction[A]]): PrepareBatchActionResult
Inherited from:
ContextVerbPrepare
@targetName("runPrepareAction")
inline def prepare[E](inline quoted: Quoted[Action[E]]): PrepareActionResult
Inherited from:
ContextVerbPrepare
@targetName("runPrepareQuerySingle")
inline def prepare[T](inline quoted: Quoted[T]): PrepareQueryResult
Inherited from:
ContextVerbPrepare
@targetName("runPrepareQuery")
inline def prepare[T](inline quoted: Quoted[Query[T]]): PrepareQueryResult
Inherited from:
ContextVerbPrepare
def prepareAction(string: String, prepare: Prepare)(info: ExecutionInfo, dc: Runner): PrepareActionResult
Inherited from:
MirrorContextBase
def prepareBatchAction(groups: List[BatchGroup])(info: ExecutionInfo, dc: Runner): PrepareBatchActionResult
Inherited from:
MirrorContextBase
@tailrec
final protected def prepareParam(param: Any): String
Inherited from:
ContextTranslateProto
def prepareQuery(string: String, prepare: Prepare)(info: ExecutionInfo, dc: Runner): PrepareQueryResult
Inherited from:
MirrorContextBase
def prepareSingle(string: String, prepare: Prepare)(info: ExecutionInfo, dc: Runner): PrepareQueryResult
Inherited from:
MirrorContextBase
override def push[A, B](result: A)(f: A => B): B
Definition Classes
ContextVerbTranslate -> ContextTranslateProto
Inherited from:
ContextVerbTranslate
@targetName("runBatchActionReturning")
inline def run[I, T, A <: Action[I] & QAC[I, T]](inline quoted: Quoted[BatchAction[A]]): BatchActionReturningMirror[T]
Inherited from:
MirrorContextBase
@targetName("runBatchAction")
inline def run[I, A <: Action[I] & QAC[I, Nothing]](inline quoted: Quoted[BatchAction[A]]): BatchActionMirror
Inherited from:
MirrorContextBase
@targetName("runActionReturning")
inline def run[E, T](inline quoted: Quoted[ActionReturning[E, T]]): ActionReturningMirror[T]
Inherited from:
MirrorContextBase
@targetName("runAction")
inline def run[E](inline quoted: Quoted[Action[E]]): ActionMirror
Inherited from:
MirrorContextBase
@targetName("runQuerySingle")
inline def run[T](inline quoted: Quoted[T]): QueryMirror[T]
Inherited from:
MirrorContextBase
@targetName("runQuery")
inline def run[T](inline quoted: Quoted[Query[T]], inline wrap: OuterSelectWrap): QueryMirror[T]
Inherited from:
MirrorContextBase
@targetName("runQueryDefault")
inline def run[T](inline quoted: Quoted[Query[T]]): QueryMirror[T]
Inherited from:
MirrorContextBase
override def seq[A](list: List[A]): List[A]
Definition Classes
ContextVerbTranslate -> ContextTranslateProto
Inherited from:
ContextVerbTranslate
@targetName("translateBatchActionReturning")
inline def translate[I, T, A <: Action[I] & QAC[I, T]](inline quoted: Quoted[BatchAction[A]], inline prettyPrint: Boolean): TranslateResult[List[String]]
Inherited from:
ContextTranslateMacro
@targetName("translateBatchActionReturning")
inline def translate[I, T, A <: Action[I] & QAC[I, T]](inline quoted: Quoted[BatchAction[A]]): TranslateResult[List[String]]
Inherited from:
ContextTranslateMacro
@targetName("translateBatchAction")
inline def translate[I, A <: Action[I] & QAC[I, Nothing]](inline quoted: Quoted[BatchAction[A]], inline prettyPrint: Boolean): TranslateResult[List[String]]
Inherited from:
ContextTranslateMacro
@targetName("translateBatchAction")
inline def translate[I, A <: Action[I] & QAC[I, Nothing]](inline quoted: Quoted[BatchAction[A]]): TranslateResult[List[String]]
Inherited from:
ContextTranslateMacro
@targetName("translateActionReturning")
inline def translate[E, T](inline quoted: Quoted[ActionReturning[E, T]], inline prettyPrint: Boolean): TranslateResult[String]
Inherited from:
ContextTranslateMacro
@targetName("translateActionReturning")
inline def translate[E, T](inline quoted: Quoted[ActionReturning[E, T]]): TranslateResult[String]
Inherited from:
ContextTranslateMacro
@targetName("translateAction")
inline def translate[E](inline quoted: Quoted[Action[E]], inline prettyPrint: Boolean): TranslateResult[String]
Inherited from:
ContextTranslateMacro
@targetName("translateAction")
inline def translate[E](inline quoted: Quoted[Action[E]]): TranslateResult[String]
Inherited from:
ContextTranslateMacro
@targetName("translateQuerySingle")
inline def translate[T](inline quoted: Quoted[T], inline prettyPrint: Boolean): TranslateResult[String]
Inherited from:
ContextTranslateMacro
@targetName("translateQuerySingle")
inline def translate[T](inline quoted: Quoted[T]): TranslateResult[String]
Inherited from:
ContextTranslateMacro
@targetName("translateQuery")
inline def translate[T](inline quoted: Quoted[Query[T]], inline prettyPrint: Boolean): TranslateResult[String]
Inherited from:
ContextTranslateMacro
@targetName("translateQuery")
inline def translate[T](inline quoted: Quoted[Query[T]]): TranslateResult[String]
Inherited from:
ContextTranslateMacro
def translateBatchQueryEndpoint(groups: List[BatchGroup], prettyPrint: Boolean)(executionInfo: ExecutionInfo, dc: TranslateRunner): TranslateResult[List[String]]
Inherited from:
ContextTranslateProto
def translateBatchQueryReturningEndpoint(groups: List[BatchGroupReturning], prettyPrint: Boolean)(executionInfo: ExecutionInfo, dc: TranslateRunner): TranslateResult[List[String]]
Inherited from:
ContextTranslateProto
override def translateContext: Runner
Definition Classes
MirrorContextBase -> ContextTranslateMacro
Inherited from:
MirrorContextBase
def translateQueryEndpoint[T](statement: String, prepare: Prepare, extractor: () => T, prettyPrint: Boolean)(executionInfo: ExecutionInfo, dc: TranslateRunner): TranslateResult[String]
Inherited from:
ContextTranslateProto
override def wrap[T](t: => T): T
Definition Classes
ContextVerbTranslate -> ContextTranslateProto
Inherited from:
ContextVerbTranslate

Inherited fields

protected val identityExtractor: (ResultRow, Session) => ResultRow
Inherited from:
RowContext
protected val identityPrepare: Prepare
Inherited from:
RowContext
val idiom: CqlIdiom
Inherited from:
MirrorContext
val session: MirrorSession
Inherited from:
MirrorContext
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

Implicits

implicit val cassandraLocalDateDecoder: MirrorDecoder[LocalDate]
implicit val cassandraLocalDateEncoder: MirrorEncoder[LocalDate]
implicit def listDecoder[T, Cas](implicit mapper: CassandraMapper[Cas, T, Decode], ct: ClassTag[Cas]): MirrorDecoder[List[T]]
implicit def listEncoder[T, Cas](implicit mapper: CassandraMapper[T, Cas, Encode], ct: ClassTag[Cas]): MirrorEncoder[List[T]]
implicit def mapDecoder[K, V, KCas, VCas](implicit keyMapper: CassandraMapper[KCas, K, Decode], valMapper: CassandraMapper[VCas, V, Decode], a: ClassTag[KCas], b: ClassTag[VCas]): MirrorDecoder[Map[K, V]]
implicit def mapEncoder[K, V, KCas, VCas](implicit keyMapper: CassandraMapper[K, KCas, Encode], valMapper: CassandraMapper[V, VCas, Encode], a: ClassTag[KCas], b: ClassTag[VCas]): MirrorEncoder[Map[K, V]]
implicit def setDecoder[T, Cas](implicit mapper: CassandraMapper[Cas, T, Decode], ct: ClassTag[Cas]): MirrorDecoder[Set[T]]
implicit def setEncoder[T, Cas](implicit mapper: CassandraMapper[T, Cas, Encode], ct: ClassTag[Cas]): MirrorEncoder[Set[T]]
implicit val timestampDecoder: MirrorDecoder[Instant]
implicit val timestampEncoder: MirrorEncoder[Instant]
implicit def udtCassandraType[T <: Udt]: CassandraType[T]
implicit def udtDecoder[T <: Udt : ClassTag]: MirrorDecoder[T]
implicit def udtEncoder[T <: Udt]: MirrorEncoder[T]

Inherited implicits

implicit inline def anyValDecoder[Cls <: AnyVal]: MirrorDecoder[Cls]
Inherited from:
LowPriorityImplicits
implicit inline def anyValEncoder[Cls <: AnyVal]: MirrorEncoder[Cls]
Inherited from:
LowPriorityImplicits
implicit val bigDecimalDecoder: MirrorDecoder[BigDecimal]
Inherited from:
MirrorDecoders
implicit val bigDecimalEncoder: MirrorEncoder[BigDecimal]
Inherited from:
MirrorEncoders
implicit val booleanCassandraType: CassandraType[Boolean]
Inherited from:
CassandraTypes
implicit val booleanDecoder: MirrorDecoder[Boolean]
Inherited from:
MirrorDecoders
implicit val booleanEncoder: MirrorEncoder[Boolean]
Inherited from:
MirrorEncoders
implicit val byteArrayDecoder: MirrorDecoder[Array[Byte]]
Inherited from:
MirrorDecoders
implicit val byteArrayEncoder: MirrorEncoder[Array[Byte]]
Inherited from:
MirrorEncoders
implicit val byteBufferCassandraType: CassandraType[ByteBuffer]
Inherited from:
CassandraTypes
implicit val byteCassandraType: CassandraType[Byte]
Inherited from:
CassandraTypes
implicit val byteDecoder: MirrorDecoder[Byte]
Inherited from:
MirrorDecoders
implicit val byteEncoder: MirrorEncoder[Byte]
Inherited from:
MirrorEncoders
implicit def cassandraIdentityDecodeMapper[Cas](implicit cas: CassandraType[Cas]): CassandraMapper[Cas, Cas, Decode]
implicit def cassandraIdentityEncodeMapper[Cas](implicit cas: CassandraType[Cas]): CassandraMapper[Cas, Cas, Encode]
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 val dateDecoder: MirrorDecoder[Date]
Inherited from:
MirrorDecoders
implicit val dateEncoder: MirrorEncoder[Date]
Inherited from:
MirrorEncoders
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: MirrorDecoder[Double]
Inherited from:
MirrorDecoders
implicit val doubleEncoder: MirrorEncoder[Double]
Inherited from:
MirrorEncoders
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: MirrorDecoder[Float]
Inherited from:
MirrorDecoders
implicit val floatEncoder: MirrorEncoder[Float]
Inherited from:
MirrorEncoders
implicit val intDecoder: MirrorDecoder[Int]
Inherited from:
MirrorDecoders
implicit val intEncoder: MirrorEncoder[Int]
Inherited from:
MirrorEncoders
implicit val integerCassandraType: CassandraType[Integer]
Inherited from:
CassandraTypes
implicit val localDateCassandraType: CassandraType[LocalDate]
Inherited from:
CassandraTypes
implicit val localDateDecoder: MirrorDecoder[LocalDate]
Inherited from:
MirrorDecoders
implicit val localDateEncoder: MirrorEncoder[LocalDate]
Inherited from:
MirrorEncoders
implicit val longCassandraType: CassandraType[Long]
Inherited from:
CassandraTypes
implicit val longDecoder: MirrorDecoder[Long]
Inherited from:
MirrorDecoders
implicit val longEncoder: MirrorEncoder[Long]
Inherited from:
MirrorEncoders
implicit def mappedDecoder[I, O](implicit mapped: MappedEncoding[I, O], d: MirrorDecoder[I]): MirrorDecoder[O]
Inherited from:
MirrorDecoders
implicit def mappedEncoder[I, O](implicit mapped: MappedEncoding[I, O], e: MirrorEncoder[O]): MirrorEncoder[I]
Inherited from:
MirrorEncoders
implicit val nullChecker: NullChecker
Inherited from:
MirrorContextBase
implicit def optionDecoder[T](implicit d: MirrorDecoder[T]): MirrorDecoder[Option[T]]
Inherited from:
MirrorDecoders
implicit def optionEncoder[T](implicit d: MirrorEncoder[T]): MirrorEncoder[Option[T]]
Inherited from:
MirrorEncoders
implicit val shortCassandraType: CassandraType[Short]
Inherited from:
CassandraTypes
implicit val shortDecoder: MirrorDecoder[Short]
Inherited from:
MirrorDecoders
implicit val shortEncoder: MirrorEncoder[Short]
Inherited from:
MirrorEncoders
implicit val stringCassandraType: CassandraType[String]
Inherited from:
CassandraTypes
implicit val stringDecoder: MirrorDecoder[String]
Inherited from:
MirrorDecoders
implicit val stringEncoder: MirrorEncoder[String]
Inherited from:
MirrorEncoders
implicit val uuidCassandraType: CassandraType[UUID]
Inherited from:
CassandraTypes
implicit val uuidDecoder: MirrorDecoder[UUID]
Inherited from:
MirrorDecoders
implicit val uuidEncoder: MirrorEncoder[UUID]
Inherited from:
MirrorEncoders