PostgresJAsyncContext

io.getquill.PostgresJAsyncContext
class PostgresJAsyncContext[+N <: NamingStrategy](naming: N, pool: ConnectionPool[PostgreSQLConnection]) extends JAsyncContext[PostgresDialect, N, PostgreSQLConnection], PostgresJAsyncContextBase[N]

Attributes

Graph
Supertypes
trait UUIDObjectEncoding
trait ArrayEncoding
class JAsyncContext[PostgresDialect, N, PostgreSQLConnection]
trait JAsyncContextBase[PostgresDialect, N]
trait Encoders
trait Decoders
trait SqlContext[PostgresDialect, N]
trait ContextVerbTranslate[PostgresDialect, N]
trait ContextTranslateMacro[PostgresDialect, N]
trait ContextTranslateProto[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
Show all

Members list

Type members

Inherited classlikes

case class AsyncDecoder[T](sqlType: DecoderSqlType)(implicit decoder: BaseDecoder[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 AsyncEncoder[T](sqlType: DecoderSqlType)(implicit encoder: BaseEncoder[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
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
class JasyncNullChecker extends BaseNullChecker

Attributes

Inherited from:
JAsyncContext
Supertypes
trait GenericNullChecker[ResultRow, Session]
class Object
trait Matchable
class Any
trait NumericDecoder[T] extends BaseDecoder[T]

Attributes

Inherited from:
Decoders
Supertypes
trait GenericDecoder[ResultRow, Session, T, Specific]
trait (Int, ResultRow, Session) => T
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 CBF[T, Col] = Factory[T, Col]

Attributes

Inherited from:
ArrayEncoding
type ColumnResolver = GenericColumnResolver[ResultRow]

Attributes

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

Attributes

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

Attributes

Inherited from:
EncodingDsl
type DecoderSqlType = SqlTypes

Attributes

Inherited from:
Decoders
type Encoder[T] = AsyncEncoder[T]

Attributes

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

Attributes

Inherited from:
EncodingDsl
type EncoderSqlType = SqlTypes

Attributes

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

Attributes

Inherited from:
RowContext
type Index = Int

Attributes

Inherited from:
Decoders
override type NullChecker = JasyncNullChecker

Attributes

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

Attributes

Inherited from:
RowContext
override type PrepareRow = Seq[Any]

Attributes

Inherited from:
JAsyncContextBase
override type Result[T] = Future[T]

Attributes

Inherited from:
JAsyncContext
override type ResultRow = RowData

Attributes

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

Attributes

Inherited from:
EncodingDsl
override type RunActionResult = Long

Attributes

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

Attributes

Inherited from:
JAsyncContext
override type RunBatchActionResult = Seq[Long]

Attributes

Inherited from:
JAsyncContext
override type RunBatchActionReturningResult[T] = Seq[T]

Attributes

Inherited from:
JAsyncContext
override type RunQueryResult[T] = Seq[T]

Attributes

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

Attributes

Inherited from:
JAsyncContext
override type Runner = ExecutionContext

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

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

Attributes

Inherited from:
JAsyncContextBase
override type RunnerBehavior = Implicit

Base type used to determine whether there is an execution context that needs to be summoned to perform execution methods e.g. in the PostgresJasync contexts that use Scala Futures that need an ExecutionContext.

Base type used to determine whether there is an execution context that needs to be summoned to perform execution methods e.g. in the PostgresJasync contexts that use Scala Futures that need an ExecutionContext.

Attributes

Inherited from:
JAsyncContextBase
override type Session = Unit

Attributes

Inherited from:
JAsyncContextBase
override type TranslateResult[T] = T

Attributes

Inherited from:
ContextVerbTranslate

Attributes

Inherited from:
ContextTranslateMacro

Value members

Constructors

def this(naming: N, config: PostgresJAsyncContextConfig)
def this(naming: N, config: Config)
def this(naming: N, configPrefix: String)

Concrete methods

override protected def expandAction(sql: String, returningAction: ReturnAction): String

Attributes

Definition Classes
JAsyncContext
override protected def extractActionResult[O](returningAction: ReturnAction, returningExtractor: () => O)(result: QueryResult): List[O]

Attributes

Definition Classes
JAsyncContext
inline def run[T](inline quoted: Quoted[Query[T]]): Future[Seq[T]]
inline def run[T](inline quoted: Quoted[Query[T]], inline wrap: OuterSelectWrap): Future[Seq[T]]
inline def run[T](inline quoted: Quoted[T]): Future[T]
inline def run[E](inline quoted: Quoted[Action[E]]): Future[Long]
inline def run[E, T](inline quoted: Quoted[ActionReturning[E, T]]): Future[T]
inline def run[E, T](inline quoted: Quoted[ActionReturning[E, List[T]]]): Future[List[T]]
inline def run[I, A <: Action[I] & QAC[I, Nothing]](inline quoted: Quoted[BatchAction[A]], rowsPerBatch: Int): Future[Seq[Long]]
inline def run[I, A <: Action[I] & QAC[I, Nothing]](inline quoted: Quoted[BatchAction[A]]): Future[Seq[Long]]
inline def run[I, T, A <: Action[I] & QAC[I, T]](inline quoted: Quoted[BatchAction[A]], rowsPerBatch: Int): Future[Seq[T]]
inline def run[I, T, A <: Action[I] & QAC[I, T]](inline quoted: Quoted[BatchAction[A]]): Future[Seq[T]]

Inherited methods

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
def arrayDecoder[I, O, Col <: Seq[O]](mapper: I => O)(implicit bf: Factory[O, Col], iTag: ClassTag[I], oTag: ClassTag[O]): AsyncDecoder[Col]

Attributes

Inherited from:
ArrayDecoders
def arrayEncoder[T, Col <: Seq[T]](mapper: T => Any): AsyncEncoder[Col]

Attributes

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

Attributes

Inherited from:
ArrayDecoders
def arrayRawEncoder[T, Col <: Seq[T]]: AsyncEncoder[Col]

Attributes

Inherited from:
ArrayEncoders
override def close: Unit

Attributes

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

Attributes

Definition Classes
JAsyncContext -> Context
Inherited from:
JAsyncContext
def decoder[T : ClassTag](f: PartialFunction[Any, T], sqlType: DecoderSqlType): AsyncDecoder[T]

Attributes

Inherited from:
Decoders
def encoder[T](f: T => Any, sqlType: DecoderSqlType): AsyncEncoder[T]

Attributes

Inherited from:
Encoders
def encoder[T](sqlType: DecoderSqlType): AsyncEncoder[T]

Attributes

Inherited from:
Encoders
def executeAction(sql: String, prepare: Prepare)(executionInfo: ExecutionInfo, dc: ExecutionContext): Future[Long]

Attributes

Inherited from:
JAsyncContext
def executeActionReturning[T](sql: String, prepare: Prepare, extractor: () => T, returningAction: ReturnAction)(info: ExecutionInfo, dc: Runner): Future[T]

Attributes

Inherited from:
JAsyncContext
def executeActionReturningMany[T](sql: String, prepare: Prepare, extractor: () => T, returningAction: ReturnAction)(info: ExecutionInfo, dc: Runner): Future[List[T]]

Attributes

Inherited from:
JAsyncContext
def executeBatchAction(groups: List[BatchGroup])(executionInfo: ExecutionInfo, dc: ExecutionContext): Future[List[Long]]

Attributes

Inherited from:
JAsyncContext
def executeBatchActionReturning[T](groups: List[BatchGroupReturning], extractor: () => T)(executionInfo: ExecutionInfo, dc: ExecutionContext): Future[List[T]]

Attributes

Inherited from:
JAsyncContext
def executeQuery[T](sql: String, prepare: Prepare, extractor: () => T)(executionInfo: ExecutionInfo, dc: ExecutionContext): Future[List[T]]

Attributes

Inherited from:
JAsyncContext
def executeQuerySingle[T](sql: String, prepare: Prepare, extractor: () => T)(executionInfo: ExecutionInfo, dc: ExecutionContext): Future[T]

Attributes

Inherited from:
JAsyncContext
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
final protected def prepareParam(param: Any): String

Attributes

Inherited from:
ContextTranslateProto
def probe(sql: String): Try[QueryResult]

Attributes

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

Attributes

Definition Classes
ContextVerbTranslate -> ContextTranslateProto
Inherited from:
ContextVerbTranslate
override def seq[A](list: List[A]): List[A]

Attributes

Definition Classes
ContextVerbTranslate -> ContextTranslateProto
Inherited from:
ContextVerbTranslate
def transaction[T](f: TransactionalExecutionContext => Future[T])(implicit ec: ExecutionContext): CompletableFuture[T]

Attributes

Inherited from:
JAsyncContext
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
def translateBatchQueryEndpoint(groups: List[BatchGroup], prettyPrint: Boolean)(executionInfo: ExecutionInfo, dc: TranslateRunner): TranslateResult[List[String]]

Attributes

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

Attributes

Inherited from:
ContextTranslateProto
override def translateContext: TranslateRunner

Attributes

Definition Classes
JAsyncContext -> ContextTranslateMacro
Inherited from:
JAsyncContext
def translateQueryEndpoint[T](statement: String, prepare: Prepare, extractor: () => T, prettyPrint: Boolean)(executionInfo: ExecutionInfo, dc: TranslateRunner): TranslateResult[String]

Attributes

Inherited from:
ContextTranslateProto
protected def withConnection[T](f: Connection => Future[T])(implicit ec: ExecutionContext): Future[T]

Attributes

Inherited from:
JAsyncContext
override def wrap[T](t: => T): T

Attributes

Definition Classes
ContextVerbTranslate -> ContextTranslateProto
Inherited from:
ContextVerbTranslate

Inherited fields

val dateTimeZone: ZoneId

Attributes

Inherited from:
JAsyncContextBase
protected val identityExtractor: (ResultRow, Session) => ResultRow

Attributes

Inherited from:
RowContext
protected val identityPrepare: Prepare

Attributes

Inherited from:
RowContext
val idiom: PostgresDialect

Attributes

Inherited from:
JAsyncContext

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 def arrayBigDecimalDecoder[Col <: Seq[BigDecimal]](implicit bf: Factory[BigDecimal, Col]): AsyncDecoder[Col]

Attributes

Inherited from:
ArrayDecoders
implicit def arrayBigDecimalEncoder[Col <: Seq[BigDecimal]]: AsyncEncoder[Col]

Attributes

Inherited from:
ArrayEncoders
implicit def arrayBooleanDecoder[Col <: Seq[Boolean]](implicit bf: Factory[Boolean, Col]): AsyncDecoder[Col]

Attributes

Inherited from:
ArrayDecoders
implicit def arrayBooleanEncoder[Col <: Seq[Boolean]]: AsyncEncoder[Col]

Attributes

Inherited from:
ArrayEncoders
implicit def arrayByteDecoder[Col <: Seq[Byte]](implicit bf: Factory[Byte, Col]): AsyncDecoder[Col]

Attributes

Inherited from:
ArrayDecoders
implicit def arrayByteEncoder[Col <: Seq[Byte]]: AsyncEncoder[Col]

Attributes

Inherited from:
ArrayEncoders
implicit def arrayDateDecoder[Col <: Seq[Date]](implicit bf: Factory[Date, Col]): AsyncDecoder[Col]

Attributes

Inherited from:
ArrayDecoders
implicit def arrayDateEncoder[Col <: Seq[Date]]: AsyncEncoder[Col]

Attributes

Inherited from:
ArrayEncoders
implicit def arrayDoubleDecoder[Col <: Seq[Double]](implicit bf: Factory[Double, Col]): AsyncDecoder[Col]

Attributes

Inherited from:
ArrayDecoders
implicit def arrayDoubleEncoder[Col <: Seq[Double]]: AsyncEncoder[Col]

Attributes

Inherited from:
ArrayEncoders
implicit def arrayFloatDecoder[Col <: Seq[Float]](implicit bf: Factory[Float, Col]): AsyncDecoder[Col]

Attributes

Inherited from:
ArrayDecoders
implicit def arrayFloatEncoder[Col <: Seq[Float]]: AsyncEncoder[Col]

Attributes

Inherited from:
ArrayEncoders
implicit def arrayIntDecoder[Col <: Seq[Index]](implicit bf: Factory[Index, Col]): AsyncDecoder[Col]

Attributes

Inherited from:
ArrayDecoders
implicit def arrayIntEncoder[Col <: Seq[Index]]: AsyncEncoder[Col]

Attributes

Inherited from:
ArrayEncoders
implicit def arrayLocalDateDecoder[Col <: Seq[LocalDate]](implicit bf: Factory[LocalDate, Col]): AsyncDecoder[Col]

Attributes

Inherited from:
ArrayDecoders
implicit def arrayLocalDateEncoder[Col <: Seq[LocalDate]]: AsyncEncoder[Col]

Attributes

Inherited from:
ArrayEncoders
implicit def arrayLocalDateTimeDecoder[Col <: Seq[LocalDateTime]](implicit bf: Factory[LocalDateTime, Col]): AsyncDecoder[Col]

Attributes

Inherited from:
ArrayDecoders
implicit def arrayLocalDateTimeEncoder[Col <: Seq[LocalDateTime]]: AsyncEncoder[Col]

Attributes

Inherited from:
ArrayEncoders
implicit def arrayLongDecoder[Col <: Seq[Long]](implicit bf: Factory[Long, Col]): AsyncDecoder[Col]

Attributes

Inherited from:
ArrayDecoders
implicit def arrayLongEncoder[Col <: Seq[Long]]: AsyncEncoder[Col]

Attributes

Inherited from:
ArrayEncoders
implicit def arrayMappedDecoder[I, O, Col <: (Seq)](implicit mapped: MappedEncoding[I, O], d: AsyncDecoder[Seq[I]], bf: Factory[O, Col[O]]): Decoder[Col[O]]

Attributes

Inherited from:
ArrayEncoding
implicit def arrayMappedEncoder[I, O, Col <: (Seq)](implicit mapped: MappedEncoding[I, O], e: AsyncEncoder[Seq[O]]): Encoder[Col[I]]

Attributes

Inherited from:
ArrayEncoding
implicit def arrayShortDecoder[Col <: Seq[Short]](implicit bf: Factory[Short, Col]): AsyncDecoder[Col]

Attributes

Inherited from:
ArrayDecoders
implicit def arrayShortEncoder[Col <: Seq[Short]]: AsyncEncoder[Col]

Attributes

Inherited from:
ArrayEncoders
implicit def arrayStringDecoder[Col <: Seq[String]](implicit bf: Factory[String, Col]): AsyncDecoder[Col]

Attributes

Inherited from:
ArrayDecoders
implicit def arrayStringEncoder[Col <: Seq[String]]: AsyncEncoder[Col]

Attributes

Inherited from:
ArrayEncoders
implicit def arrayUuidDecoder[Col <: Seq[UUID]](implicit bf: Factory[UUID, Col]): AsyncDecoder[Col]

Attributes

Inherited from:
ArrayDecoders
implicit def arrayUuidEncoder[Col <: Seq[UUID]]: AsyncEncoder[Col]

Attributes

Inherited from:
ArrayEncoders
implicit val bigDecimalDecoder: AsyncDecoder[BigDecimal]

Attributes

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

Attributes

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

Attributes

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

Attributes

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

Attributes

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

Attributes

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

Attributes

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

Attributes

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

Attributes

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

Attributes

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

Attributes

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

Attributes

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

Attributes

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

Attributes

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

Attributes

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

Attributes

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

Attributes

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

Attributes

Inherited from:
Decoders
implicit val localDateEncoder: AsyncEncoder[LocalDate]

Attributes

Inherited from:
Encoders
implicit val localDateTimeDecoder: AsyncDecoder[LocalDateTime]

Attributes

Inherited from:
Decoders
implicit val localDateTimeEncoder: AsyncEncoder[LocalDateTime]

Attributes

Inherited from:
Encoders
implicit val longDecoder: AsyncDecoder[Long]

Attributes

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

Attributes

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

Attributes

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

Attributes

Inherited from:
Encoders
implicit val nullChecker: NullChecker

Attributes

Inherited from:
JAsyncContext
implicit def optionDecoder[T](implicit d: AsyncDecoder[T]): AsyncDecoder[Option[T]]

Attributes

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

Attributes

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

Attributes

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

Attributes

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

Attributes

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

Attributes

Inherited from:
Encoders
implicit def toCompletableFuture[T](f: Future[T]): CompletableFuture[T]

Attributes

Inherited from:
JAsyncContext
implicit def toFuture[T](cf: CompletableFuture[T]): Future[T]

Attributes

Inherited from:
JAsyncContext
implicit def toKotlinFunction[T, R](f: T => R): Function1[T, R]

Attributes

Inherited from:
JAsyncContext
implicit val uuidDecoder: AsyncDecoder[UUID]

Attributes

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

Attributes

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

Attributes

Inherited from:
Decoders
implicit val zonedDateTimeEncoder: AsyncEncoder[ZonedDateTime]

Attributes

Inherited from:
Encoders