SqliteZioJdbcContext

io.getquill.SqliteZioJdbcContext
See theSqliteZioJdbcContext companion object
class SqliteZioJdbcContext[+N <: NamingStrategy](val naming: N) extends ZioJdbcContext[SqliteDialect, N], SqliteJdbcTypes[SqliteDialect, N]

Attributes

Companion
object
Graph
Supertypes
trait SqliteJdbcTypes[SqliteDialect, N]
trait UUIDObjectEncoding
trait BooleanObjectEncoding
trait BasicTimeDecoders
trait BasicTimeEncoders
class ZioJdbcContext[SqliteDialect, N]
trait ZioTranslateContext[SqliteDialect, N]
trait ContextTranslateMacro[SqliteDialect, N]
trait ContextTranslateProto[SqliteDialect, N]
trait ZioPrepareContext[SqliteDialect, N]
trait ContextVerbPrepare[SqliteDialect, N]
trait JdbcContextTypes[SqliteDialect, N]
trait Decoders
trait Encoders
trait SqlContext[SqliteDialect, N]
trait ZioContext[SqliteDialect, N]
trait ContextVerbStream[SqliteDialect, N]
trait ProtoStreamContext[SqliteDialect, N]
trait Context[SqliteDialect, N]
trait Closeable
trait AutoCloseable
trait EncodingDsl
trait LowPriorityImplicits
trait ProtoContextSecundus[SqliteDialect, N]
trait RowContext
class Object
trait Matchable
class Any
Show all

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
object InternalApi

Attributes

Inherited from:
Context
Supertypes
class Object
trait Matchable
class Any
case class JdbcDecoder[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 JdbcEncoder[T](sqlType: Int, 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
class JdbcNullChecker extends BaseNullChecker

Attributes

Inherited from:
JdbcContextTypes
Supertypes
trait GenericNullChecker[ResultRow, Session]
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] = JdbcDecoder[T]

Attributes

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

Attributes

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

Attributes

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

Attributes

Inherited from:
EncodingDsl
override type Environment = DataSource

Attributes

Inherited from:
ZioJdbcContext
override type Error = SQLException

Attributes

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

Attributes

Inherited from:
RowContext
type Index = Int

Attributes

Inherited from:
JdbcContextTypes
override type NullChecker = JdbcNullChecker

Attributes

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

Attributes

Inherited from:
RowContext

Attributes

Inherited from:
ZioJdbcContext
override type PrepareBatchActionResult = QCIO[List[PrepareRow]]

Attributes

Inherited from:
ZioJdbcContext

Attributes

Inherited from:
ZioJdbcContext
override type PrepareRow = PreparedStatement

Attributes

Inherited from:
ZioJdbcContext
override type Result[T] = ZIO[Environment, Error, T]

Attributes

Inherited from:
ZioJdbcContext
override type ResultRow = ResultSet

Attributes

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

Attributes

Inherited from:
EncodingDsl
override type RunActionResult = Long

Attributes

Inherited from:
ZioJdbcContext
override type RunActionReturningResult[T] = T

Attributes

Inherited from:
ZioJdbcContext
override type RunBatchActionResult = List[Long]

Attributes

Inherited from:
ZioJdbcContext
override type RunBatchActionReturningResult[T] = List[T]

Attributes

Inherited from:
ZioJdbcContext
override type RunQueryResult[T] = List[T]

Attributes

Inherited from:
ZioJdbcContext
override type RunQuerySingleResult[T] = T

Attributes

Inherited from:
ZioJdbcContext
override type Runner = Unit

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

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

Attributes

Inherited from:
ZioJdbcContext
type RunnerBehavior <: RunnerSummoningBehavior

Attributes

Inherited from:
ContextTranslateMacro
override type Session = Connection

Attributes

Inherited from:
ZioJdbcContext
override type StreamResult[T] = ZStream[Environment, Error, T]

Attributes

Inherited from:
ZioJdbcContext
override type TranslateResult[T] = ZIO[Environment, Error, T]

Attributes

Inherited from:
ZioJdbcContext
override type TranslateRunner = Unit

Attributes

Inherited from:
ZioJdbcContext

Value members

Inherited methods

inline def _streamInternal[T](inline quoted: Quoted[Query[T]], fetchSize: Option[Int]): StreamResult[T]

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

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

Attributes

Inherited from:
ContextVerbStream
inline def _summonPrepareRunner(): Runner

Attributes

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

Attributes

Inherited from:
ContextTranslateMacro
override def close(): Unit

Attributes

Definition Classes
ZioJdbcContext -> Context -> Closeable -> AutoCloseable
Inherited from:
ZioJdbcContext
override protected def context: Runner

Attributes

Definition Classes
ZioJdbcContext -> Context
Inherited from:
ZioJdbcContext
def decoder[T](f: ResultRow => Index => T): JdbcDecoder[T]

Attributes

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

Attributes

Inherited from:
Decoders
def encoder[T](sqlType: Int, f: PrepareRow => (Index, T) => Unit): JdbcEncoder[T]

Attributes

Inherited from:
Encoders
def encoder[T](sqlType: Int, f: (Index, T, PrepareRow) => Unit): JdbcEncoder[T]

Attributes

Inherited from:
Encoders
def executeAction(sql: String, prepare: Prepare)(info: ExecutionInfo, dc: Runner): QIO[Long]

Attributes

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

Attributes

Inherited from:
ZioJdbcContext
def executeActionReturningMany[O](sql: String, prepare: Prepare, extractor: () => O, returningBehavior: ReturnAction)(info: ExecutionInfo, dc: Runner): QIO[List[O]]

Attributes

Inherited from:
ZioJdbcContext
def executeBatchAction(groups: List[BatchGroup])(info: ExecutionInfo, dc: Runner): QIO[List[Long]]

Attributes

Inherited from:
ZioJdbcContext
def executeBatchActionReturning[T](groups: List[BatchGroupReturning], extractor: () => T)(info: ExecutionInfo, dc: Runner): QIO[List[T]]

Attributes

Inherited from:
ZioJdbcContext
def executeQuery[T](sql: String, prepare: Prepare, extractor: () => T)(info: ExecutionInfo, dc: Runner): QIO[List[T]]

Attributes

Inherited from:
ZioJdbcContext
override def executeQuerySingle[T](sql: String, prepare: Prepare, extractor: () => T)(info: ExecutionInfo, dc: Runner): QIO[T]

Attributes

Definition Classes
ZioJdbcContext -> ZioContext -> ProtoContextSecundus
Inherited from:
ZioJdbcContext
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 parseJdbcType(intType: Int): String

Parses instances of java.sql.Types to string form so it can be used in creation of sql arrays. Some databases does not support each of generic types, hence it's welcome to override this method and provide alternatives to non-existent types.

Parses instances of java.sql.Types to string form so it can be used in creation of sql arrays. Some databases does not support each of generic types, hence it's welcome to override this method and provide alternatives to non-existent types.

Value parameters

intType

one of java.sql.Types

Attributes

Returns

JDBC type in string form

Inherited from:
JdbcContextTypes
inline def prepare[I, A <: Action[I] & QAC[I, Nothing]](inline quoted: Quoted[BatchAction[A]]): PrepareBatchActionResult

Attributes

Inherited from:
ContextVerbPrepare
inline def prepare[E](inline quoted: Quoted[Action[E]]): PrepareActionResult

Attributes

Inherited from:
ContextVerbPrepare
inline def prepare[T](inline quoted: Quoted[T]): PrepareQueryResult

Attributes

Inherited from:
ContextVerbPrepare
inline def prepare[T](inline quoted: Quoted[Query[T]]): PrepareQueryResult

Attributes

Inherited from:
ContextVerbPrepare
override def prepareAction(sql: String, prepare: Prepare)(info: ExecutionInfo, dc: Runner): QCIO[PreparedStatement]

Attributes

Definition Classes
ZioJdbcContext -> ZioPrepareContext -> ContextVerbPrepare
Inherited from:
ZioJdbcContext
override def prepareBatchAction(groups: List[BatchGroup])(info: ExecutionInfo, dc: Runner): QCIO[List[PreparedStatement]]

Attributes

Definition Classes
ZioJdbcContext -> ZioPrepareContext -> ContextVerbPrepare
Inherited from:
ZioJdbcContext
final protected def prepareParam(param: Any): String

Attributes

Inherited from:
ContextTranslateProto
override def prepareQuery(sql: String, prepare: Prepare)(info: ExecutionInfo, dc: Runner): QCIO[PreparedStatement]

Attributes

Definition Classes
ZioJdbcContext -> ZioPrepareContext -> ContextVerbPrepare
Inherited from:
ZioJdbcContext
def prepareSingle(sql: String, prepare: Prepare)(info: ExecutionInfo, dc: Runner): QCIO[PreparedStatement]

Execute SQL on connection and return prepared statement. Closes the statement in a bracket.

Execute SQL on connection and return prepared statement. Closes the statement in a bracket.

Attributes

Inherited from:
ZioPrepareContext
override def push[A, B](result: TranslateResult[A])(f: A => B): TranslateResult[B]

Attributes

Definition Classes
ZioTranslateContext -> ContextTranslateProto
Inherited from:
ZioTranslateContext
inline def run[I, T, A <: Action[I] & QAC[I, T]](inline quoted: Quoted[BatchAction[A]]): ZIO[DataSource, SQLException, List[T]]

Attributes

Inherited from:
ZioJdbcContext
inline def run[I, T, A <: Action[I] & QAC[I, T]](inline quoted: Quoted[BatchAction[A]], rowsPerBatch: Int): ZIO[DataSource, SQLException, List[T]]

Attributes

Inherited from:
ZioJdbcContext
inline def run[I, A <: Action[I] & QAC[I, Nothing]](inline quoted: Quoted[BatchAction[A]]): ZIO[DataSource, SQLException, List[Long]]

Attributes

Inherited from:
ZioJdbcContext
inline def run[I, A <: Action[I] & QAC[I, Nothing]](inline quoted: Quoted[BatchAction[A]], rowsPerBatch: Int): ZIO[DataSource, SQLException, List[Long]]

Attributes

Inherited from:
ZioJdbcContext
inline def run[E, T](inline quoted: Quoted[ActionReturning[E, List[T]]]): ZIO[DataSource, SQLException, List[T]]

Attributes

Inherited from:
ZioJdbcContext
inline def run[E, T](inline quoted: Quoted[ActionReturning[E, T]]): ZIO[DataSource, SQLException, T]

Attributes

Inherited from:
ZioJdbcContext
inline def run[E](inline quoted: Quoted[Action[E]]): ZIO[DataSource, SQLException, Long]

Attributes

Inherited from:
ZioJdbcContext
inline def run[T](inline quoted: Quoted[T]): ZIO[DataSource, SQLException, T]

Attributes

Inherited from:
ZioJdbcContext
inline def run[T](inline quoted: Quoted[Query[T]], inline wrap: OuterSelectWrap): ZIO[DataSource, SQLException, List[T]]

Attributes

Inherited from:
ZioJdbcContext
inline def run[T](inline quoted: Quoted[Query[T]]): ZIO[DataSource, SQLException, List[T]]

Attributes

Inherited from:
ZioJdbcContext
override def seq[A](list: List[TranslateResult[A]]): TranslateResult[List[A]]

Attributes

Definition Classes
ZioTranslateContext -> ContextTranslateProto
Inherited from:
ZioTranslateContext
inline def stream[T](inline quoted: Quoted[Query[T]], fetchSize: Int): StreamResult[T]

Attributes

Inherited from:
ContextVerbStream
inline def stream[T](inline quoted: Quoted[Query[T]]): StreamResult[T]

Attributes

Inherited from:
ContextVerbStream
def streamQuery[T](fetchSize: Option[Int], sql: String, prepare: Prepare, extractor: () => T)(info: ExecutionInfo, dc: Runner): QStream[T]

Attributes

Inherited from:
ZioJdbcContext
def transaction[R <: DataSource, A](op: ZIO[R, Throwable, A]): ZIO[R, Throwable, A]

Execute instructions in a transaction. For example, to add a Person row to the database and return the contents of the Person table immediately after that:

Execute instructions in a transaction. For example, to add a Person row to the database and return the contents of the Person table immediately after that:

 val a = run(query[Person].insert(Person(...)): ZIO[Has[DataSource], SQLException, Long]
 val b = run(query[Person]): ZIO[Has[DataSource], SQLException, Person]
 transaction(a *> b): ZIO[Has[DataSource], SQLException, Person]

The order of operations run in the case that a new connection needs to be aquired are as follows:

 getDS from env,
 acquire-connection,
   set-no-autocommit(connection),
     put-into-fiberref(connection),
       op - the corresponding execute_ method which will execute and pull connection from the fiberref,
     remove-from-fiberref(connection),
   set-prev-autocommit(connection),
 release-conn

Attributes

Inherited from:
ZioJdbcContext
inline def translate[I, T, A <: Action[I] & QAC[I, T]](inline quoted: Quoted[BatchAction[A]], inline prettyPrint: Boolean): TranslateResult[List[String]]

Attributes

Inherited from:
ContextTranslateMacro
inline def translate[I, T, A <: Action[I] & QAC[I, T]](inline quoted: Quoted[BatchAction[A]]): TranslateResult[List[String]]

Attributes

Inherited from:
ContextTranslateMacro
inline def translate[I, A <: Action[I] & QAC[I, Nothing]](inline quoted: Quoted[BatchAction[A]], inline prettyPrint: Boolean): TranslateResult[List[String]]

Attributes

Inherited from:
ContextTranslateMacro
inline def translate[I, A <: Action[I] & QAC[I, Nothing]](inline quoted: Quoted[BatchAction[A]]): TranslateResult[List[String]]

Attributes

Inherited from:
ContextTranslateMacro
inline def translate[E, T](inline quoted: Quoted[ActionReturning[E, T]], inline prettyPrint: Boolean): TranslateResult[String]

Attributes

Inherited from:
ContextTranslateMacro
inline def translate[E, T](inline quoted: Quoted[ActionReturning[E, T]]): TranslateResult[String]

Attributes

Inherited from:
ContextTranslateMacro
inline def translate[E](inline quoted: Quoted[Action[E]], inline prettyPrint: Boolean): TranslateResult[String]

Attributes

Inherited from:
ContextTranslateMacro
inline def translate[E](inline quoted: Quoted[Action[E]]): TranslateResult[String]

Attributes

Inherited from:
ContextTranslateMacro
inline def translate[T](inline quoted: Quoted[T], inline prettyPrint: Boolean): TranslateResult[String]

Attributes

Inherited from:
ContextTranslateMacro
inline def translate[T](inline quoted: Quoted[T]): TranslateResult[String]

Attributes

Inherited from:
ContextTranslateMacro
inline def translate[T](inline quoted: Quoted[Query[T]], inline prettyPrint: Boolean): TranslateResult[String]

Attributes

Inherited from:
ContextTranslateMacro
inline def translate[T](inline quoted: Quoted[Query[T]]): TranslateResult[String]

Attributes

Inherited from:
ContextTranslateMacro
override def translateBatchQueryEndpoint(groups: List[BatchGroup], prettyPrint: Boolean)(executionInfo: ExecutionInfo, dc: Runner): TranslateResult[List[String]]

Attributes

Definition Classes
ZioJdbcContext -> ContextTranslateProto
Inherited from:
ZioJdbcContext
def translateBatchQueryReturningEndpoint(groups: List[BatchGroupReturning], prettyPrint: Boolean)(executionInfo: ExecutionInfo, dc: TranslateRunner): TranslateResult[List[String]]

Attributes

Inherited from:
ContextTranslateProto

Attributes

Inherited from:
ZioJdbcContext
override def translateQueryEndpoint[T](statement: String, prepare: Prepare, extractor: () => T, prettyPrint: Boolean)(executionInfo: ExecutionInfo, dc: Runner): TranslateResult[String]

Attributes

Definition Classes
ZioJdbcContext -> ContextTranslateProto
Inherited from:
ZioJdbcContext
override def wrap[T](t: => T): TranslateResult[T]

Attributes

Definition Classes
ZioTranslateContext -> ContextTranslateProto
Inherited from:
ZioTranslateContext

Concrete fields

val connDelegate: ZioJdbcUnderlyingContext[SqliteDialect, N]
val idiom: SqliteDialect
val naming: N

Inherited fields

val currentConnection: FiberRef[Option[Connection]]

Since we are immediately executing the ZIO that creates this fiber ref whether it is global is not really relevant since it does not really use scope However if it were used for something else it would be scoped to the fiber-ref of the zio-jdbc context's creator i.e. the global scope.

Since we are immediately executing the ZIO that creates this fiber ref whether it is global is not really relevant since it does not really use scope However if it were used for something else it would be scoped to the fiber-ref of the zio-jdbc context's creator i.e. the global scope.

Attributes

Inherited from:
ZioJdbcContext
protected val dateTimeZone: TimeZone

Attributes

Inherited from:
JdbcContextTypes

Attributes

Inherited from:
RowContext
protected val identityPrepare: Prepare

Attributes

Inherited from:
RowContext
final lazy val underlying: ZioJdbcUnderlyingContext[SqliteDialect, N]

Attributes

Inherited from:
ZioJdbcContext

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: JdbcDecoder[BigDecimal]

Attributes

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

Attributes

Inherited from:
Encoders
implicit val booleanDecoder: JdbcDecoder[Boolean]

Attributes

Inherited from:
BooleanObjectEncoding
implicit val booleanEncoder: JdbcEncoder[Boolean]

Attributes

Inherited from:
BooleanObjectEncoding
implicit val byteArrayDecoder: JdbcDecoder[Array[Byte]]

Attributes

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

Attributes

Inherited from:
Encoders
implicit val byteDecoder: JdbcDecoder[Byte]

Attributes

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

Attributes

Inherited from:
Encoders
implicit val dateDecoder: JdbcDecoder[Date]

Attributes

Inherited from:
Decoders
implicit val dateEncoder: JdbcEncoder[Date]

Attributes

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

Attributes

Inherited from:
Context
implicit val doubleDecoder: JdbcDecoder[Double]

Attributes

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

Attributes

Inherited from:
Encoders
implicit val floatDecoder: JdbcDecoder[Float]

Attributes

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

Attributes

Inherited from:
Encoders
implicit val instantDecoder: JdbcDecoder[Instant]

Attributes

Inherited from:
BasicTimeDecoders
implicit val instantEncoder: JdbcEncoder[Instant]

Attributes

Inherited from:
BasicTimeEncoders
implicit val intDecoder: JdbcDecoder[Int]

Attributes

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

Attributes

Inherited from:
Encoders
implicit val localDateDecoder: JdbcDecoder[LocalDate]

Attributes

Inherited from:
BasicTimeDecoders
implicit val localDateEncoder: JdbcEncoder[LocalDate]

Attributes

Inherited from:
BasicTimeEncoders
implicit val localDateTimeDecoder: JdbcDecoder[LocalDateTime]

Attributes

Inherited from:
BasicTimeDecoders
implicit val localDateTimeEncoder: JdbcEncoder[LocalDateTime]

Attributes

Inherited from:
BasicTimeEncoders
implicit val localTimeDecoder: JdbcDecoder[LocalTime]

Attributes

Inherited from:
BasicTimeDecoders
implicit val localTimeEncoder: JdbcEncoder[LocalTime]

Attributes

Inherited from:
BasicTimeEncoders
implicit val longDecoder: JdbcDecoder[Long]

Attributes

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

Attributes

Inherited from:
Encoders
implicit def mappedDecoder[I, O](implicit mapped: MappedEncoding[I, O], d: JdbcDecoder[I]): JdbcDecoder[O]

Attributes

Inherited from:
Decoders
implicit override def mappedEncoder[I, O](implicit mapped: MappedEncoding[I, O], e: JdbcEncoder[O]): JdbcEncoder[I]

Attributes

Definition Classes
Encoders -> EncodingDsl
Inherited from:
Encoders

Attributes

Inherited from:
JdbcContextTypes
implicit val nullEncoder: JdbcEncoder[Null]

Attributes

Inherited from:
Encoders
implicit val offseDateTimeEncoder: JdbcEncoder[OffsetDateTime]

Attributes

Inherited from:
BasicTimeEncoders
implicit val offseTimeEncoder: JdbcEncoder[OffsetTime]

Attributes

Inherited from:
BasicTimeEncoders
implicit val offsetDateTimeDecoder: JdbcDecoder[OffsetDateTime]

Attributes

Inherited from:
BasicTimeDecoders
implicit val offsetTimeDecoder: JdbcDecoder[OffsetTime]

Attributes

Inherited from:
BasicTimeDecoders
implicit def optionDecoder[T](implicit d: JdbcDecoder[T]): JdbcDecoder[Option[T]]

Attributes

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

Attributes

Inherited from:
Encoders
implicit val shortDecoder: JdbcDecoder[Short]

Attributes

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

Attributes

Inherited from:
Encoders
implicit val sqlDateDecoder: JdbcDecoder[Date]

Attributes

Inherited from:
Decoders
implicit val sqlDateEncoder: JdbcEncoder[Date]

Attributes

Inherited from:
Encoders
implicit val sqlTimeDecoder: JdbcDecoder[Time]

Attributes

Inherited from:
Decoders
implicit val sqlTimeEncoder: JdbcEncoder[Time]

Attributes

Inherited from:
Encoders
implicit val sqlTimestampDecoder: JdbcDecoder[Timestamp]

Attributes

Inherited from:
Decoders
implicit val sqlTimestampEncoder: JdbcEncoder[Timestamp]

Attributes

Inherited from:
Encoders
implicit val stringDecoder: JdbcDecoder[String]

Attributes

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

Attributes

Inherited from:
Encoders
implicit val uuidDecoder: JdbcDecoder[UUID]

Attributes

Inherited from:
UUIDObjectEncoding
implicit val uuidEncoder: JdbcEncoder[UUID]

Attributes

Inherited from:
UUIDObjectEncoding
implicit val zonedDateTimeDecoder: JdbcDecoder[ZonedDateTime]

Attributes

Inherited from:
BasicTimeDecoders
implicit val zonedDateTimeEncoder: JdbcEncoder[ZonedDateTime]

Attributes

Inherited from:
BasicTimeEncoders