QuillPostgresContext

class QuillPostgresContext[N <: NamingStrategy](naming: N) extends PostgresZioJdbcContext[N] with ExtSyntax[PostgresDialect, N] with Migrator[PostgresDialect, N]
trait Migrator[PostgresDialect, N]
trait ExtSyntax[PostgresDialect, N]
class PostgresZioJdbcContext[N]
trait PostgresJsonExtensions
trait PostgresJdbcTypes[PostgresDialect, N]
trait ArrayEncoders
trait ArrayDecoders
trait ArrayEncoding
trait UUIDObjectEncoding
trait BooleanObjectEncoding
trait ObjectGenericTimeDecoders
trait ObjectGenericTimeEncoders
class ZioJdbcContext[PostgresDialect, N]
trait ZioTranslateContext[PostgresDialect, N]
trait ContextTranslateMacro[PostgresDialect, N]
trait ContextTranslateProto[PostgresDialect, N]
trait ZioPrepareContext[PostgresDialect, N]
trait ContextVerbPrepare[PostgresDialect, N]
trait JdbcContextTypes[PostgresDialect, N]
trait Decoders
trait Encoders
trait SqlContext[PostgresDialect, N]
trait ZioContext[PostgresDialect, N]
trait ContextVerbStream[PostgresDialect, N]
trait ProtoStreamContext[PostgresDialect, N]
trait Context[PostgresDialect, N]
trait Closeable
trait AutoCloseable
trait EncodingDsl
trait LowPriorityImplicits
trait ProtoContextSecundus[PostgresDialect, 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
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
class JdbcNullChecker extends BaseNullChecker
Inherited from:
JdbcContextTypes

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 CBF[T, Col] = Factory[T, Col]
Inherited from:
ArrayEncoding
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
override type Environment = DataSource
Inherited from:
ZioJdbcContext
override type Error = SQLException
Inherited from:
ZioJdbcContext
type Extractor[T] = (ResultRow, Session) => T
Inherited from:
RowContext
type Index = Int
Inherited from:
JdbcContextTypes
Inherited from:
JdbcContextTypes
type Prepare = (PrepareRow, Session) => (List[Any], PrepareRow)
Inherited from:
RowContext
override type PrepareActionResult = QCIO[PrepareRow]
Inherited from:
ZioJdbcContext
override type PrepareBatchActionResult = QCIO[List[PrepareRow]]
Inherited from:
ZioJdbcContext
override type PrepareQueryResult = QCIO[PrepareRow]
Inherited from:
ZioJdbcContext
override type PrepareRow = PreparedStatement
Inherited from:
ZioJdbcContext
override type Result[T] = ZIO[Environment, Error, T]
Inherited from:
ZioJdbcContext
override type ResultRow = ResultSet
Inherited from:
ZioJdbcContext
type RowTyper[T] = GenericRowTyper[ResultRow, T]
Inherited from:
EncodingDsl
override type RunActionResult = Long
Inherited from:
ZioJdbcContext
override type RunActionReturningResult[T] = T
Inherited from:
ZioJdbcContext
override type RunBatchActionResult = List[Long]
Inherited from:
ZioJdbcContext
override type RunBatchActionReturningResult[T] = List[T]
Inherited from:
ZioJdbcContext
override type RunQueryResult[T] = List[T]
Inherited from:
ZioJdbcContext
override type RunQuerySingleResult[T] = T
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...

Inherited from:
ZioJdbcContext
type RunnerBehavior <: RunnerSummoningBehavior
Inherited from:
ContextTranslateMacro
override type Session = Connection
Inherited from:
ZioJdbcContext
override type StreamResult[T] = ZStream[Environment, Error, T]
Inherited from:
ZioJdbcContext
override type TranslateResult[T] = ZIO[Environment, Error, T]
Inherited from:
ZioJdbcContext
override type TranslateRunner = Unit
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

Inherited from:
ContextVerbStream
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 arrayDecoder[I, O, Col <: Seq[O]](mapper: I => O)(implicit bf: Factory[O, Col], tag: ClassTag[I]): JdbcDecoder[Col]

Generic encoder for JDBC arrays.

Generic encoder for JDBC arrays.

Type parameters:
Col

seq type

I

raw type retrieved form JDBC array

O

mapped type fulfilled in decoder's collection

Value parameters:
bf

builder factory is needed to create instances of decoder's collection

mapper

retrieved raw types fro JDBC array may be mapped via this mapper to satisfy encoder type

Returns:

JDBC array decoder

Inherited from:
ArrayDecoders
def arrayEncoder[T, Col <: Seq[T]](jdbcType: String, mapper: T => AnyRef): JdbcEncoder[Col]

Generic encoder for JDBC arrays.

Generic encoder for JDBC arrays.

Type parameters:
Col

seq type

T

element type

Value parameters:
jdbcType

JDBC specific type identification, may be various regarding to JDBC driver

mapper

jdbc array accepts AnyRef objects hence a mapper is needed. If input type of an element of collection is not comfortable with jdbcType then use this mapper to transform to appropriate type before casting to AnyRef

Returns:

JDBC array encoder

Inherited from:
ArrayEncoders
def arrayRawDecoder[T : ClassTag, Col <: Seq[T]](implicit evidence$1: ClassTag[T], bf: Factory[T, Col]): JdbcDecoder[Col]

Creates JDBC array decoder for type T which is already supported by database as array element.

Creates JDBC array decoder for type T which is already supported by database as array element.

Type parameters:
Col

seq type

T

element type

Value parameters:
bf

builder factory is needed to create instances of decoder's collection

Returns:

JDBC array decoder

Inherited from:
ArrayDecoders
def arrayRawEncoder[T, Col <: Seq[T]](jdbcType: Int): JdbcEncoder[Col]

Transform jdbcType int using parseJdbcType and calls overloaded method to create Encoder

Transform jdbcType int using parseJdbcType and calls overloaded method to create Encoder

Value parameters:
jdbcType

java.sql.Types

See also:

arrayRawEncoder(jdbcType: String)

JdbcContext#parseJdbcType(jdbcType: String)

Inherited from:
ArrayEncoders
def arrayRawEncoder[T, Col <: Seq[T]](jdbcType: String): JdbcEncoder[Col]

Creates JDBC array encoder for type T which is already supported by database as array element.

Creates JDBC array encoder for type T which is already supported by database as array element.

Type parameters:
Col

seq type

T

element type

Value parameters:
jdbcType

JDBC specific type identification, may be various regarding to JDBC driver

Returns:

JDBC array encoder

Inherited from:
ArrayEncoders
def astDecoder[Wrapper](valueFromString: Json => Wrapper): JdbcDecoder[Wrapper]
Inherited from:
PostgresJsonExtensions
def astEncoder[Wrapper](valueToString: Wrapper => String, jsonType: String): JdbcEncoder[Wrapper]
Inherited from:
PostgresJsonExtensions
override def close(): Unit
Definition Classes
ZioJdbcContext -> Context -> Closeable -> AutoCloseable
Inherited from:
ZioJdbcContext
override protected def context: Runner
Definition Classes
ZioJdbcContext -> Context
Inherited from:
ZioJdbcContext
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
def entityDecoder[JsValue : ClassTag, Wrapper](wrap: JsValue => Wrapper)(jsonType: String, jsonDecoder: JsonDecoder[JsValue]): JdbcDecoder[Wrapper]
Inherited from:
PostgresJsonExtensions
def entityEncoder[JsValue, Wrapper](unwrap: Wrapper => JsValue)(jsonType: String, jsonEncoder: JsonEncoder[JsValue]): JdbcEncoder[Wrapper]
Inherited from:
PostgresJsonExtensions
def executeAction(sql: String, prepare: Prepare)(info: ExecutionInfo, dc: Runner): QIO[Long]
Inherited from:
ZioJdbcContext
def executeActionReturning[O](sql: String, prepare: Prepare, extractor: () => O, returningBehavior: ReturnAction)(info: ExecutionInfo, dc: Runner): QIO[O]
Inherited from:
ZioJdbcContext
def executeActionReturningMany[O](sql: String, prepare: Prepare, extractor: () => O, returningBehavior: ReturnAction)(info: ExecutionInfo, dc: Runner): QIO[List[O]]
Inherited from:
ZioJdbcContext
def executeBatchAction(groups: List[BatchGroup])(info: ExecutionInfo, dc: Runner): QIO[List[Long]]
Inherited from:
ZioJdbcContext
def executeBatchActionReturning[T](groups: List[BatchGroupReturning], extractor: () => T)(info: ExecutionInfo, dc: Runner): QIO[List[T]]
Inherited from:
ZioJdbcContext
def executeQuery[T](sql: String, prepare: Prepare, extractor: () => T)(info: ExecutionInfo, dc: Runner): QIO[List[T]]
Inherited from:
ZioJdbcContext
override def executeQuerySingle[T](sql: String, prepare: Prepare, extractor: () => T)(info: ExecutionInfo, dc: Runner): QIO[T]
Definition Classes
ZioJdbcContext -> ZioContext -> ProtoContextSecundus
Inherited from:
ZioJdbcContext
protected def handleSingleResult[T](sql: String, list: List[T]): T
Inherited from:
Context
protected def jdbcEncodeInstant(value: Instant): Any
Inherited from:
ObjectGenericTimeEncoders
protected def jdbcTypeOfInstant: Int
Inherited from:
ObjectGenericTimeEncoders
protected def jdbcTypeOfLocalDate: Int
Inherited from:
ObjectGenericTimeEncoders
protected def jdbcTypeOfLocalDateTime: Int
Inherited from:
ObjectGenericTimeEncoders
protected def jdbcTypeOfLocalTime: Int
Inherited from:
ObjectGenericTimeEncoders
protected def jdbcTypeOfOffsetDateTime: Int
Inherited from:
ObjectGenericTimeEncoders
override protected def jdbcTypeOfOffsetTime: Int
Definition Classes
PostgresJdbcTypes -> ObjectGenericTimeEncoders
Inherited from:
PostgresJdbcTypes
protected def jdbcTypeOfZonedDateTime: Int
Inherited from:
ObjectGenericTimeEncoders
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]): ZIO[DBDataSource, Throwable, Unit]
Inherited from:
Migrator
override 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

Definition Classes
PostgresJdbcTypes -> JdbcContextTypes
Inherited from:
PostgresJdbcTypes
inline def prepare[I, A <: Action[I] & QAC[I, Nothing]](inline quoted: Quoted[BatchAction[A]]): PrepareBatchActionResult
Inherited from:
ContextVerbPrepare
inline def prepare[E](inline quoted: Quoted[Action[E]]): PrepareActionResult
Inherited from:
ContextVerbPrepare
inline def prepare[T](inline quoted: Quoted[T]): PrepareQueryResult
Inherited from:
ContextVerbPrepare
inline def prepare[T](inline quoted: Quoted[Query[T]]): PrepareQueryResult
Inherited from:
ContextVerbPrepare
override def prepareAction(sql: String, prepare: Prepare)(info: ExecutionInfo, dc: Runner): QCIO[PreparedStatement]
Definition Classes
ZioJdbcContext -> ZioPrepareContext -> ContextVerbPrepare
Inherited from:
ZioJdbcContext
override def prepareBatchAction(groups: List[BatchGroup])(info: ExecutionInfo, dc: Runner): QCIO[List[PreparedStatement]]
Definition Classes
ZioJdbcContext -> ZioPrepareContext -> ContextVerbPrepare
Inherited from:
ZioJdbcContext
final protected def prepareParam(param: Any): String
Inherited from:
ContextTranslateProto
override def prepareQuery(sql: String, prepare: Prepare)(info: ExecutionInfo, dc: Runner): QCIO[PreparedStatement]
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.

Inherited from:
ZioPrepareContext
override def push[A, B](result: TranslateResult[A])(f: A => B): TranslateResult[B]
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]]
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]]
Inherited from:
ZioJdbcContext
inline def run[I, A <: Action[I] & QAC[I, Nothing]](inline quoted: Quoted[BatchAction[A]]): ZIO[DataSource, SQLException, List[Long]]
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]]
Inherited from:
ZioJdbcContext
inline def run[E, T](inline quoted: Quoted[ActionReturning[E, List[T]]]): ZIO[DataSource, SQLException, List[T]]
Inherited from:
ZioJdbcContext
inline def run[E, T](inline quoted: Quoted[ActionReturning[E, T]]): ZIO[DataSource, SQLException, T]
Inherited from:
ZioJdbcContext
inline def run[E](inline quoted: Quoted[Action[E]]): ZIO[DataSource, SQLException, Long]
Inherited from:
ZioJdbcContext
inline def run[T](inline quoted: Quoted[T]): ZIO[DataSource, SQLException, T]
Inherited from:
ZioJdbcContext
inline def run[T](inline quoted: Quoted[Query[T]], inline wrap: OuterSelectWrap): ZIO[DataSource, SQLException, List[T]]
Inherited from:
ZioJdbcContext
inline def run[T](inline quoted: Quoted[Query[T]]): ZIO[DataSource, SQLException, List[T]]
Inherited from:
ZioJdbcContext
override def seq[A](list: List[TranslateResult[A]]): TranslateResult[List[A]]
Definition Classes
ZioTranslateContext -> ContextTranslateProto
Inherited from:
ZioTranslateContext
inline def stream[T](inline quoted: Quoted[Query[T]], fetchSize: Int): StreamResult[T]
Inherited from:
ContextVerbStream
inline def stream[T](inline quoted: Quoted[Query[T]]): StreamResult[T]
Inherited from:
ContextVerbStream
def streamQuery[T](fetchSize: Option[Int], sql: String, prepare: Prepare, extractor: () => T)(info: ExecutionInfo, dc: Runner): QStream[T]
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
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]]
Inherited from:
ContextTranslateMacro
inline def translate[I, T, A <: Action[I] & QAC[I, T]](inline quoted: Quoted[BatchAction[A]]): TranslateResult[List[String]]
Inherited from:
ContextTranslateMacro
inline def translate[I, A <: Action[I] & QAC[I, Nothing]](inline quoted: Quoted[BatchAction[A]], inline prettyPrint: Boolean): TranslateResult[List[String]]
Inherited from:
ContextTranslateMacro
inline def translate[I, A <: Action[I] & QAC[I, Nothing]](inline quoted: Quoted[BatchAction[A]]): TranslateResult[List[String]]
Inherited from:
ContextTranslateMacro
inline def translate[E, T](inline quoted: Quoted[ActionReturning[E, T]], inline prettyPrint: Boolean): TranslateResult[String]
Inherited from:
ContextTranslateMacro
inline def translate[E, T](inline quoted: Quoted[ActionReturning[E, T]]): TranslateResult[String]
Inherited from:
ContextTranslateMacro
inline def translate[E](inline quoted: Quoted[Action[E]], inline prettyPrint: Boolean): TranslateResult[String]
Inherited from:
ContextTranslateMacro
inline def translate[E](inline quoted: Quoted[Action[E]]): TranslateResult[String]
Inherited from:
ContextTranslateMacro
inline def translate[T](inline quoted: Quoted[T], inline prettyPrint: Boolean): TranslateResult[String]
Inherited from:
ContextTranslateMacro
inline def translate[T](inline quoted: Quoted[T]): TranslateResult[String]
Inherited from:
ContextTranslateMacro
inline def translate[T](inline quoted: Quoted[Query[T]], inline prettyPrint: Boolean): TranslateResult[String]
Inherited from:
ContextTranslateMacro
inline def translate[T](inline quoted: Quoted[Query[T]]): TranslateResult[String]
Inherited from:
ContextTranslateMacro
override def translateBatchQueryEndpoint(groups: List[BatchGroup], prettyPrint: Boolean)(executionInfo: ExecutionInfo, dc: Runner): TranslateResult[List[String]]
Definition Classes
ZioJdbcContext -> ContextTranslateProto
Inherited from:
ZioJdbcContext
def translateBatchQueryReturningEndpoint(groups: List[BatchGroupReturning], prettyPrint: Boolean)(executionInfo: ExecutionInfo, dc: TranslateRunner): TranslateResult[List[String]]
Inherited from:
ContextTranslateProto
def translateContext: TranslateRunner
Inherited from:
ZioJdbcContext
override def translateQueryEndpoint[T](statement: String, prepare: Prepare, extractor: () => T, prettyPrint: Boolean)(executionInfo: ExecutionInfo, dc: Runner): TranslateResult[String]
Definition Classes
ZioJdbcContext -> ContextTranslateProto
Inherited from:
ZioJdbcContext
override def wrap[T](t: => T): TranslateResult[T]
Definition Classes
ZioTranslateContext -> ContextTranslateProto
Inherited from:
ZioTranslateContext

Inherited fields

val connDelegate: ZioJdbcUnderlyingContext[PostgresDialect, N]
Inherited from:
PostgresZioJdbcContext
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.

Inherited from:
ZioJdbcContext
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: PostgresDialect
Inherited from:
PostgresZioJdbcContext
val migratorLogger: Logger
Inherited from:
Migrator
final lazy val underlying: ZioJdbcUnderlyingContext[PostgresDialect, N]
Inherited from:
ZioJdbcContext

Extensions

Inherited extensions

extension [T](dynamicQuery: DynamicEntityQuery[T])
inline def insertValue(value: T): DynamicInsert[T]
Inherited from:
Context
inline def updateValue(value: T): DynamicUpdate[T]
Inherited from:
Context
extension [T](entity: EntityQuery[T])
inline def insertValue(inline value: T): Insert[T]
Inherited from:
Context
inline def updateValue(inline value: T): Update[T]
Inherited from:
Context
extension [T](left: T)
inline def <(right: T): Quoted[Boolean]
Inherited from:
ExtSyntax
inline def <=(right: T): Quoted[Boolean]
Inherited from:
ExtSyntax
inline def ==(right: T): Quoted[Boolean]
Inherited from:
ExtSyntax
inline def >(right: T): Quoted[Boolean]
Inherited from:
ExtSyntax
inline def >=(right: T): Quoted[Boolean]
Inherited from:
ExtSyntax
extension [T](q: Query[T])
inline def forUpdate: Quoted[Query[T]]
Inherited from:
ExtSyntax
extension [T](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.

Inherited from:
Context
inline def filterColumns(inline columns: List[String]): Query[T]
Inherited from:
Context
extension [T](quotedEntity: Quoted[EntityQuery[T]])
inline def insertValue(inline value: T): Insert[T]
Inherited from:
Context
inline def updateValue(inline value: T): Update[T]
Inherited from:
Context

Implicits

Implicits

implicit override val zonedDateTimeDecoder: JdbcDecoder[ZonedDateTime]
implicit override val zonedDateTimeEncoder: JdbcEncoder[ZonedDateTime]

Inherited implicits

implicit inline def anyValDecoder[Cls <: AnyVal]: Decoder[Cls]
Inherited from:
LowPriorityImplicits
implicit inline def anyValEncoder[Cls <: AnyVal]: Encoder[Cls]
Inherited from:
LowPriorityImplicits
implicit def arrayBigDecimalDecoder[Col <: Seq[BigDecimal]](implicit bf: Factory[BigDecimal, Col]): JdbcDecoder[Col]
Inherited from:
ArrayDecoders
implicit def arrayBigDecimalEncoder[Col <: Seq[BigDecimal]]: JdbcEncoder[Col]
Inherited from:
ArrayEncoders
implicit def arrayBooleanDecoder[Col <: Seq[Boolean]](implicit bf: Factory[Boolean, Col]): JdbcDecoder[Col]
Inherited from:
ArrayDecoders
implicit def arrayBooleanEncoder[Col <: Seq[Boolean]]: JdbcEncoder[Col]
Inherited from:
ArrayEncoders
implicit def arrayByteDecoder[Col <: Seq[Byte]](implicit bf: Factory[Byte, Col]): JdbcDecoder[Col]
Inherited from:
ArrayDecoders
implicit def arrayByteEncoder[Col <: Seq[Byte]]: JdbcEncoder[Col]
Inherited from:
ArrayEncoders
implicit def arrayDateDecoder[Col <: Seq[Date]](implicit bf: Factory[Date, Col]): JdbcDecoder[Col]
Inherited from:
ArrayDecoders
implicit def arrayDateEncoder[Col <: Seq[Date]]: JdbcEncoder[Col]
Inherited from:
ArrayEncoders
implicit def arrayDoubleDecoder[Col <: Seq[Double]](implicit bf: Factory[Double, Col]): JdbcDecoder[Col]
Inherited from:
ArrayDecoders
implicit def arrayDoubleEncoder[Col <: Seq[Double]]: JdbcEncoder[Col]
Inherited from:
ArrayEncoders
implicit def arrayFloatDecoder[Col <: Seq[Float]](implicit bf: Factory[Float, Col]): JdbcDecoder[Col]
Inherited from:
ArrayDecoders
implicit def arrayFloatEncoder[Col <: Seq[Float]]: JdbcEncoder[Col]
Inherited from:
ArrayEncoders
implicit def arrayIntDecoder[Col <: Seq[Int]](implicit bf: Factory[Int, Col]): JdbcDecoder[Col]
Inherited from:
ArrayDecoders
implicit def arrayIntEncoder[Col <: Seq[Int]]: JdbcEncoder[Col]
Inherited from:
ArrayEncoders
implicit def arrayLocalDateDecoder[Col <: Seq[LocalDate]](implicit bf: Factory[LocalDate, Col]): JdbcDecoder[Col]
Inherited from:
ArrayDecoders
implicit def arrayLocalDateEncoder[Col <: Seq[LocalDate]]: JdbcEncoder[Col]
Inherited from:
ArrayEncoders
implicit def arrayLongDecoder[Col <: Seq[Long]](implicit bf: Factory[Long, Col]): JdbcDecoder[Col]
Inherited from:
ArrayDecoders
implicit def arrayLongEncoder[Col <: Seq[Long]]: JdbcEncoder[Col]
Inherited from:
ArrayEncoders
implicit def arrayMappedDecoder[I, O, Col <: (Seq)](implicit mapped: MappedEncoding[I, O], d: JdbcDecoder[Seq[I]], bf: Factory[O, Col[O]]): Decoder[Col[O]]
Inherited from:
ArrayEncoding
implicit def arrayMappedEncoder[I, O, Col <: (Seq)](implicit mapped: MappedEncoding[I, O], e: JdbcEncoder[Seq[O]]): Encoder[Col[I]]
Inherited from:
ArrayEncoding
implicit def arrayShortDecoder[Col <: Seq[Short]](implicit bf: Factory[Short, Col]): JdbcDecoder[Col]
Inherited from:
ArrayDecoders
implicit def arrayShortEncoder[Col <: Seq[Short]]: JdbcEncoder[Col]
Inherited from:
ArrayEncoders
implicit def arrayStringDecoder[Col <: Seq[String]](implicit bf: Factory[String, Col]): JdbcDecoder[Col]
Inherited from:
ArrayDecoders
implicit def arrayStringEncoder[Col <: Seq[String]]: JdbcEncoder[Col]
Inherited from:
ArrayEncoders
implicit def arrayTimestampDecoder[Col <: Seq[Timestamp]](implicit bf: Factory[Timestamp, Col]): JdbcDecoder[Col]
Inherited from:
ArrayDecoders
implicit def arrayTimestampEncoder[Col <: Seq[Timestamp]]: JdbcEncoder[Col]
Inherited from:
ArrayEncoders
implicit val bigDecimalDecoder: JdbcDecoder[BigDecimal]
Inherited from:
Decoders
implicit val bigDecimalEncoder: JdbcEncoder[BigDecimal]
Inherited from:
Encoders
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 floatDecoder: JdbcDecoder[Float]
Inherited from:
Decoders
implicit val floatEncoder: JdbcEncoder[Float]
Inherited from:
Encoders
implicit val instantDecoder: JdbcDecoder[Instant]
Inherited from:
ObjectGenericTimeDecoders
implicit val instantEncoder: JdbcEncoder[Instant]
Inherited from:
ObjectGenericTimeEncoders
implicit val intDecoder: JdbcDecoder[Int]
Inherited from:
Decoders
implicit val intEncoder: JdbcEncoder[Int]
Inherited from:
Encoders
implicit def jsonAstDecoder: JdbcDecoder[JsonValue[Json]]
Inherited from:
PostgresJsonExtensions
implicit def jsonAstEncoder: JdbcEncoder[JsonValue[Json]]
Inherited from:
PostgresJsonExtensions
implicit def jsonEntityDecoder[T : ClassTag](implicit evidence$1: ClassTag[T], jsonDecoder: JsonDecoder[T]): JdbcDecoder[JsonValue[T]]
Inherited from:
PostgresJsonExtensions
implicit def jsonEntityEncoder[T](implicit jsonEncoder: JsonEncoder[T]): JdbcEncoder[JsonValue[T]]
Inherited from:
PostgresJsonExtensions
implicit def jsonbAstDecoder: JdbcDecoder[JsonbValue[Json]]
Inherited from:
PostgresJsonExtensions
implicit def jsonbAstEncoder: JdbcEncoder[JsonbValue[Json]]
Inherited from:
PostgresJsonExtensions
implicit def jsonbEntityDecoder[T : ClassTag](implicit evidence$2: ClassTag[T], jsonDecoder: JsonDecoder[T]): JdbcDecoder[JsonbValue[T]]
Inherited from:
PostgresJsonExtensions
implicit def jsonbEntityEncoder[T](implicit jsonEncoder: JsonEncoder[T]): JdbcEncoder[JsonbValue[T]]
Inherited from:
PostgresJsonExtensions
implicit val localDateDecoder: JdbcDecoder[LocalDate]
Inherited from:
ObjectGenericTimeDecoders
implicit val localDateEncoder: JdbcEncoder[LocalDate]
Inherited from:
ObjectGenericTimeEncoders
implicit val localDateTimeDecoder: JdbcDecoder[LocalDateTime]
Inherited from:
ObjectGenericTimeDecoders
implicit val localDateTimeEncoder: JdbcEncoder[LocalDateTime]
Inherited from:
ObjectGenericTimeEncoders
implicit val localTimeDecoder: JdbcDecoder[LocalTime]
Inherited from:
ObjectGenericTimeDecoders
implicit val localTimeEncoder: JdbcEncoder[LocalTime]
Inherited from:
ObjectGenericTimeEncoders
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
Inherited from:
JdbcContextTypes
implicit val nullEncoder: JdbcEncoder[Null]
Inherited from:
Encoders
implicit val offseDateTimeEncoder: JdbcEncoder[OffsetDateTime]
Inherited from:
ObjectGenericTimeEncoders
implicit val offseTimeEncoder: JdbcEncoder[OffsetTime]
Inherited from:
ObjectGenericTimeEncoders
implicit val offsetDateTimeDecoder: JdbcDecoder[OffsetDateTime]
Inherited from:
ObjectGenericTimeDecoders
implicit val offsetTimeDecoder: JdbcDecoder[OffsetTime]
Inherited from:
ObjectGenericTimeDecoders
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 sqlDateDecoder: JdbcDecoder[Date]
Inherited from:
Decoders
implicit val sqlDateEncoder: JdbcEncoder[Date]
Inherited from:
Encoders
implicit val sqlTimeDecoder: JdbcDecoder[Time]
Inherited from:
Decoders
implicit val sqlTimeEncoder: JdbcEncoder[Time]
Inherited from:
Encoders
implicit val sqlTimestampDecoder: JdbcDecoder[Timestamp]
Inherited from:
Decoders
implicit val sqlTimestampEncoder: JdbcEncoder[Timestamp]
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:
UUIDObjectEncoding
implicit val uuidEncoder: JdbcEncoder[UUID]
Inherited from:
UUIDObjectEncoding