QuillMysqlContext

class QuillMysqlContext(dataSource: HikariDataSource) extends MysqlJdbcContext[SnakeCase.type] with RawCodecs[MySQLDialect, SnakeCase.type] with Migrator[MySQLDialect, SnakeCase.type]
trait Migrator[MySQLDialect, SnakeCase.type]
trait RawCodecs[MySQLDialect, SnakeCase.type]
class MysqlJdbcContext[SnakeCase.type]
trait MysqlJdbcContextBase[SnakeCase.type]
trait MysqlJdbcTypes[SnakeCase.type]
trait UUIDStringEncoding
trait BooleanObjectEncoding
class JdbcContext[MySQLDialect, SnakeCase.type]
trait JdbcContextBase[MySQLDialect, SnakeCase.type]
trait ContextVerbPrepareLamba[MySQLDialect, SnakeCase.type]
trait JdbcContextVerbPrepare[MySQLDialect, SnakeCase.type]
trait ContextVerbPrepare[MySQLDialect, SnakeCase.type]
trait JdbcContextVerbExecute[MySQLDialect, SnakeCase.type]
trait JdbcContextTypes[MySQLDialect, SnakeCase.type]
trait Decoders
trait Encoders
trait SqlContext[MySQLDialect, SnakeCase.type]
trait Context[MySQLDialect, SnakeCase.type]
trait Closeable
trait AutoCloseable
trait EncodingDsl
trait LowPriorityImplicits
trait ProtoContext[MySQLDialect, SnakeCase.type]
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
Inherited from:
Migrator
Inherited from:
Context
case class JdbcDecoder[T](decoder: () => T) extends BaseDecoder[T]
Inherited from:
Decoders
case class JdbcEncoder[T](sqlType: Int, encoder: () => T) extends BaseEncoder[T]
Inherited from:
Encoders

Inherited types

type BaseDecoder[T] = GenericDecoder[ResultRow, Session, T, Specific]
Inherited from:
EncodingDsl
type BaseEncoder[T] = GenericEncoder[T, PrepareRow, Session]
Inherited from:
EncodingDsl
type ColumnResolver = GenericColumnResolver[ResultRow]
Inherited from:
EncodingDsl
type Decoder[T] = JdbcDecoder[T]
Inherited from:
Decoders
type DecoderMethod[T] = (Int, ResultRow, Session) => T
Inherited from:
EncodingDsl
type Encoder[T] = JdbcEncoder[T]
Inherited from:
Encoders
type EncoderMethod[T] = (Int, T, PrepareRow, Session) => PrepareRow
Inherited from:
EncodingDsl
type Extractor[T] = (ResultRow, Session) => T
Inherited from:
RowContext
type Index = Int
Inherited from:
JdbcContextTypes
type Prepare = (PrepareRow, Session) => (List[Any], PrepareRow)
Inherited from:
RowContext
override type PrepareActionResult = Connection => Result[PreparedStatement]
Inherited from:
JdbcContextBase
override type PrepareBatchActionResult = Connection => Result[List[PreparedStatement]]
Inherited from:
JdbcContextBase
override type PrepareQueryResult = Connection => Result[PreparedStatement]
Inherited from:
JdbcContextBase
type PrepareRow = PreparedStatement
Inherited from:
JdbcContextTypes
override type Result[T] = T
Inherited from:
JdbcContext
type ResultRow = ResultSet
Inherited from:
JdbcContextTypes
type RowTyper[T] = GenericRowTyper[ResultRow, T]
Inherited from:
EncodingDsl
override type RunActionResult = Long
Inherited from:
JdbcContext
override type RunActionReturningResult[T] = T
Inherited from:
JdbcContext
override type RunBatchActionResult = List[Long]
Inherited from:
JdbcContext
override type RunBatchActionReturningResult[T] = List[T]
Inherited from:
JdbcContext
override type RunQueryResult[T] = List[T]
Inherited from:
JdbcContext
override type RunQuerySingleResult[T] = T
Inherited from:
JdbcContext
override type Runner = Unit
Inherited from:
JdbcContext
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
type Session = Connection
Inherited from:
JdbcContextTypes

Value members

Inherited methods

inline def _summonPrepareRunner(): Runner
Inherited from:
ContextVerbPrepare
override def close(): Unit
Definition Classes
JdbcContext -> Context -> Closeable -> AutoCloseable
Inherited from:
JdbcContext
def constructPrepareAction(f: Connection => Result[PreparedStatement]): Connection => Result[PreparedStatement]
Inherited from:
JdbcContextBase
def constructPrepareBatchAction(f: Connection => Result[List[PreparedStatement]]): Connection => Result[List[PreparedStatement]]
Inherited from:
JdbcContextBase
def constructPrepareQuery(f: Connection => Result[PreparedStatement]): Connection => Result[PreparedStatement]
Inherited from:
JdbcContextBase
override protected def context: Runner
Definition Classes
JdbcContext -> Context
Inherited from:
JdbcContext
def decoder[T](f: ResultRow => Index => T): JdbcDecoder[T]
Inherited from:
Decoders
def decoder[T](d: (Int, ResultRow, Session) => T): JdbcDecoder[T]
Inherited from:
Decoders
def encoder[T](sqlType: Int, f: PrepareRow => (Index, T) => Unit): JdbcEncoder[T]
Inherited from:
Encoders
def encoder[T](sqlType: Int, f: (Index, T, PrepareRow) => Unit): JdbcEncoder[T]
Inherited from:
Encoders
override def executeAction(sql: String, prepare: Prepare)(info: ExecutionInfo, dc: Runner): Result[Long]
Definition Classes
JdbcContextVerbExecute -> ProtoContext
Inherited from:
JdbcContextVerbExecute
override def executeActionReturning[O](sql: String, prepare: Prepare, extractor: () => O, returningBehavior: ReturnAction)(info: ExecutionInfo, dc: Runner): Result[O]
Definition Classes
JdbcContextVerbExecute -> ProtoContext
Inherited from:
JdbcContextVerbExecute
def executeBatchAction(groups: List[BatchGroup])(info: ExecutionInfo, dc: Runner): Result[List[Long]]
Inherited from:
JdbcContextVerbExecute
def executeBatchActionReturning[T](groups: List[BatchGroupReturning], extractor: () => T)(info: ExecutionInfo, dc: Runner): Result[List[T]]
Inherited from:
JdbcContextVerbExecute
override def executeQuery[T](sql: String, prepare: Prepare, extractor: () => T)(info: ExecutionInfo, dc: Runner): Result[List[T]]
Definition Classes
JdbcContextVerbExecute -> ProtoContext
Inherited from:
JdbcContextVerbExecute
override def executeQuerySingle[T](sql: String, prepare: Prepare, extractor: () => T)(info: ExecutionInfo, dc: Runner): Result[T]
Definition Classes
JdbcContextVerbExecute -> ProtoContext
Inherited from:
JdbcContextVerbExecute
protected def handleSingleResult[T](list: List[T]): T
Inherited from:
Context
protected def handleSingleWrappedResult[T](list: Result[List[T]]): Result[T]
Inherited from:
JdbcContextVerbExecute
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 migrate[T](using t: Table[T]): Unit
Inherited from:
Migrator
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

Returns:

JDBC type in string form

Inherited from:
JdbcContextTypes
@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(sql: String, prepare: Prepare)(executionInfo: ExecutionInfo, dc: Runner): PrepareActionResult
Inherited from:
JdbcContextVerbPrepare
def prepareBatchAction(groups: List[BatchGroup])(executionInfo: ExecutionInfo, dc: Runner): PrepareBatchActionResult
Inherited from:
JdbcContextVerbPrepare
def prepareQuery(sql: String, prepare: Prepare)(executionInfo: ExecutionInfo, dc: Runner): PrepareQueryResult
Inherited from:
JdbcContextVerbPrepare
def prepareSingle(sql: String, prepare: Prepare)(executionInfo: ExecutionInfo, dc: Runner): Connection => Result[PreparedStatement]
Inherited from:
JdbcContextVerbPrepare
protected def prepareWithReturning(sql: String, conn: Connection, returningBehavior: ReturnAction): PreparedStatement
Inherited from:
JdbcContextVerbExecute
def probe(sql: String): Try[Result[Boolean]]
Inherited from:
JdbcContext
override def push[A, B](result: A)(f: A => B): B
Definition Classes
JdbcContext -> JdbcContextVerbPrepare -> JdbcContextVerbExecute
Inherited from:
JdbcContext
@targetName("runBatchActionReturning")
inline def run[I, T, A <: Action[I] & QAC[I, T]](inline quoted: Quoted[BatchAction[A]]): List[T]
Inherited from:
JdbcContext
@targetName("runBatchAction")
inline def run[I, A <: Action[I] & QAC[I, Nothing]](inline quoted: Quoted[BatchAction[A]]): List[Long]
Inherited from:
JdbcContext
@targetName("runActionReturning")
inline def run[E, T](inline quoted: Quoted[ActionReturning[E, T]]): T
Inherited from:
JdbcContext
@targetName("runAction")
inline def run[E](inline quoted: Quoted[Action[E]]): Long
Inherited from:
JdbcContext
@targetName("runQuerySingle")
inline def run[T](inline quoted: Quoted[T]): T
Inherited from:
JdbcContext
@targetName("runQuery")
inline def run[T](inline quoted: Quoted[Query[T]], inline wrap: OuterSelectWrap): List[T]
Inherited from:
JdbcContext
@targetName("runQueryDefault")
inline def run[T](inline quoted: Quoted[Query[T]]): List[T]
Inherited from:
JdbcContext
override def seq[A](list: List[A]): List[A]
Definition Classes
JdbcContext -> JdbcContextVerbPrepare -> JdbcContextVerbExecute
Inherited from:
JdbcContext
def transaction[T](f: => T): Result[T]
Inherited from:
JdbcContext
protected def withConnection[T](f: Connection => Result[T]): Result[T]
Inherited from:
JdbcContext
protected def withConnectionWrapped[T](f: Connection => T): Result[T]
Inherited from:
JdbcContextVerbExecute
override def wrap[T](t: => T): T
Definition Classes
JdbcContext -> JdbcContextVerbPrepare -> JdbcContextVerbExecute
Inherited from:
JdbcContext

Inherited fields

protected val currentConnection: DynamicVariable[Option[Connection]]
Inherited from:
JdbcContext
protected val dateTimeZone: TimeZone
Inherited from:
JdbcContextTypes
protected val identityExtractor: (ResultRow, Session) => ResultRow
Inherited from:
RowContext
protected val identityPrepare: Prepare
Inherited from:
RowContext
val idiom: MySQLDialect
Inherited from:
MysqlJdbcTypes
val migratorLogger: Logger
Inherited from:
Migrator
val naming: SnakeCase.type
Inherited from:
MysqlJdbcContext

Extensions

Inherited extensions

extension [T](left: T)
inline def eq(right: T): Quoted[Boolean]
Inherited from:
RawCodecs
inline def gt(right: T): Quoted[Boolean]
Inherited from:
RawCodecs
inline def gte(right: T): Quoted[Boolean]
Inherited from:
RawCodecs
inline def lt(right: T): Quoted[Boolean]
Inherited from:
RawCodecs
inline def lte(right: T): Quoted[Boolean]
Inherited from:
RawCodecs
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
extension [T](q: Query[T])
inline def forUpdate: Quoted[Query[T]]
Inherited from:
RawCodecs

Implicits

Inherited implicits

implicit inline def anyValDecoder[Cls <: AnyVal]: JdbcDecoder[Cls]
Inherited from:
LowPriorityImplicits
implicit inline def anyValEncoder[Cls <: AnyVal]: JdbcEncoder[Cls]
Inherited from:
LowPriorityImplicits
implicit val bigDecimalDecoder: JdbcDecoder[BigDecimal]
Inherited from:
Decoders
implicit val bigDecimalEncoder: JdbcEncoder[BigDecimal]
Inherited from:
Encoders
implicit val bigIntDecoder: JdbcDecoder[BigInt]
Inherited from:
RawCodecs
implicit val bigIntEncoder: JdbcEncoder[BigInt]
Inherited from:
RawCodecs
implicit val booleanDecoder: JdbcDecoder[Boolean]
Inherited from:
BooleanObjectEncoding
implicit val booleanEncoder: JdbcEncoder[Boolean]
Inherited from:
BooleanObjectEncoding
implicit val byteArrayDecoder: JdbcDecoder[Array[Byte]]
Inherited from:
Decoders
implicit val byteArrayEncoder: JdbcEncoder[Array[Byte]]
Inherited from:
Encoders
implicit val byteDecoder: JdbcDecoder[Byte]
Inherited from:
Decoders
implicit val byteEncoder: JdbcEncoder[Byte]
Inherited from:
Encoders
implicit val dateDecoder: JdbcDecoder[Date]
Inherited from:
Decoders
implicit val dateEncoder: JdbcEncoder[Date]
Inherited from:
Encoders
implicit inline def dec[T]: GenericDecoder[ResultRow, Session, T, Generic]
Inherited from:
Context
implicit val doubleDecoder: JdbcDecoder[Double]
Inherited from:
Decoders
implicit val doubleEncoder: JdbcEncoder[Double]
Inherited from:
Encoders
implicit val dtEncoder: JdbcEncoder[ZonedDateTime]
Inherited from:
RawCodecs
implicit val floatDecoder: JdbcDecoder[Float]
Inherited from:
Decoders
implicit val floatEncoder: JdbcEncoder[Float]
Inherited from:
Encoders
implicit val intDecoder: JdbcDecoder[Int]
Inherited from:
Decoders
implicit val intEncoder: JdbcEncoder[Int]
Inherited from:
Encoders
implicit val localDateDecoder: JdbcDecoder[LocalDate]
Inherited from:
Decoders
implicit val localDateEncoder: JdbcEncoder[LocalDate]
Inherited from:
Encoders
implicit val localDateTimeDecoder: JdbcDecoder[LocalDateTime]
Inherited from:
Decoders
implicit val localDateTimeEncoder: JdbcEncoder[LocalDateTime]
Inherited from:
Encoders
implicit val longDecoder: JdbcDecoder[Long]
Inherited from:
Decoders
implicit val longEncoder: JdbcEncoder[Long]
Inherited from:
Encoders
implicit def mappedDecoder[I, O](implicit mapped: MappedEncoding[I, O], d: JdbcDecoder[I]): JdbcDecoder[O]
Inherited from:
Decoders
implicit override def mappedEncoder[I, O](implicit mapped: MappedEncoding[I, O], e: JdbcEncoder[O]): JdbcEncoder[I]
Definition Classes
Encoders -> EncodingDsl
Inherited from:
Encoders
implicit def optionDecoder[T](implicit d: JdbcDecoder[T]): JdbcDecoder[Option[T]]
Inherited from:
Decoders
implicit def optionEncoder[T](implicit d: JdbcEncoder[T]): JdbcEncoder[Option[T]]
Inherited from:
Encoders
implicit val shortDecoder: JdbcDecoder[Short]
Inherited from:
Decoders
implicit val shortEncoder: JdbcEncoder[Short]
Inherited from:
Encoders
implicit val stringDecoder: JdbcDecoder[String]
Inherited from:
Decoders
implicit val stringEncoder: JdbcEncoder[String]
Inherited from:
Encoders
implicit val uuidDecoder: JdbcDecoder[UUID]
Inherited from:
UUIDStringEncoding
implicit val uuidEncoder: JdbcEncoder[UUID]
Inherited from:
UUIDStringEncoding
implicit val zdD: JdbcDecoder[ZonedDateTime]
Inherited from:
RawCodecs