Underlying

class Underlying[N <: NamingStrategy](val naming: N) extends ZioJdbcUnderlyingContext[OracleDialect, N] with OracleJdbcTypes[N]
trait OracleJdbcTypes[N]
trait UUIDStringEncoding
trait BooleanIntEncoding
class ZioJdbcUnderlyingContext[OracleDialect, N]
trait ZioTranslateContext[OracleDialect, N]
trait ContextTranslateMacro[OracleDialect, N]
trait ContextTranslateProto[OracleDialect, N]
trait ZioPrepareContext[OracleDialect, N]
trait ContextVerbPrepare[OracleDialect, N]
trait JdbcContextVerbExecute[OracleDialect, N]
trait JdbcContextTypes[OracleDialect, N]
trait Decoders
trait Encoders
trait SqlContext[OracleDialect, N]
trait ZioContext[OracleDialect, N]
trait ContextVerbStream[OracleDialect, N]
trait ProtoStreamContext[OracleDialect, N]
trait Context[OracleDialect, N]
trait Closeable
trait AutoCloseable
trait EncodingDsl
trait LowPriorityImplicits
trait ProtoContext[OracleDialect, 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)
Inherited from
Decoders
case
class JdbcEncoder[T](sqlType: Int, encoder: () => 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
override
type Environment = Has[Session]
override
type Error = SQLException
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
Inherited from
ZioPrepareContext
Inherited from
ZioPrepareContext
override
type PrepareRow = PreparedStatement
override
type Result[T] = ZIO[Environment, Error, T]
Inherited from
ZioContext
override
type ResultRow = ResultSet
type RowTyper[T] = GenericRowTyper[ResultRow, T]
Inherited from
EncodingDsl
override
type RunActionResult = Long
override
override
type RunBatchActionResult = List[Long]
override
override
type RunQueryResult[T] = List[T]
Inherited from
JdbcContextVerbExecute
override
Inherited from
JdbcContextVerbExecute
override
type Runner = Unit
type RunnerBehavior <: RunnerSummoningBehavior
Inherited from
ContextTranslateMacro
override
type Session = Connection
Inherited from
ZioPrepareContext
override
type StreamResult[T] = ZStream[Environment, Error, T]
Inherited from
ZioContext
override
type TranslateResult[T] = ZIO[Environment, Error, T]
Inherited from
ZioTranslateContext
override
type TranslateRunner = Unit

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
Inherited from
ContextVerbPrepare

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
override
def close(): Unit

ZIO Contexts do not managed DB connections so this is a no-op

ZIO Contexts do not managed DB connections so this is a no-op

Definition Classes
ZioJdbcUnderlyingContext -> Context -> Closeable -> AutoCloseable
Inherited from
ZioJdbcUnderlyingContext
override protected
Definition Classes
Inherited from
ZioJdbcUnderlyingContext
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): QCIO[Long]
Definition Classes
ZioJdbcUnderlyingContext -> JdbcContextVerbExecute -> ProtoContext
Inherited from
ZioJdbcUnderlyingContext
override
def executeActionReturning[O](sql: String, prepare: Prepare, extractor: () => O, returningBehavior: ReturnAction)(info: ExecutionInfo, dc: Runner): QCIO[O]
Definition Classes
ZioJdbcUnderlyingContext -> JdbcContextVerbExecute -> ProtoContext
Inherited from
ZioJdbcUnderlyingContext
override
def executeBatchAction(groups: List[BatchGroup])(info: ExecutionInfo, dc: Runner): QCIO[List[Long]]
Definition Classes
ZioJdbcUnderlyingContext -> JdbcContextVerbExecute -> ProtoContext
Inherited from
ZioJdbcUnderlyingContext
override
def executeBatchActionReturning[T](groups: List[BatchGroupReturning], extractor: () => T)(info: ExecutionInfo, dc: Runner): QCIO[List[T]]
Definition Classes
ZioJdbcUnderlyingContext -> JdbcContextVerbExecute -> ProtoContext
Inherited from
ZioJdbcUnderlyingContext
override
def executeQuery[T](sql: String, prepare: Prepare, extractor: () => T)(info: ExecutionInfo, dc: Runner): QCIO[List[T]]
Definition Classes
ZioJdbcUnderlyingContext -> JdbcContextVerbExecute -> ZioContext -> ProtoContext
Inherited from
ZioJdbcUnderlyingContext
override
def executeQuerySingle[T](sql: String, prepare: Prepare, extractor: () => T)(info: ExecutionInfo, dc: Runner): QCIO[T]
Definition Classes
ZioJdbcUnderlyingContext -> JdbcContextVerbExecute -> ZioContext -> ProtoContext
Inherited from
ZioJdbcUnderlyingContext
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 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 Params
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
override
def prepareAction(sql: String, prepare: Prepare)(info: ExecutionInfo, dc: Runner): QCIO[PreparedStatement]
Definition Classes
Inherited from
ZioJdbcUnderlyingContext
override
def prepareBatchAction(groups: List[BatchGroup])(info: ExecutionInfo, dc: Runner): QCIO[List[PreparedStatement]]
Definition Classes
Inherited from
ZioJdbcUnderlyingContext
@tailrec
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
Inherited from
ZioJdbcUnderlyingContext
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
protected
def prepareStatementForStreaming(sql: String, conn: Connection, fetchSize: Option[Int]): PreparedStatement

Override to enable specific vendor options needed for streaming

Override to enable specific vendor options needed for streaming

Inherited from
ZioJdbcUnderlyingContext
protected
def prepareWithReturning(sql: String, conn: Connection, returningBehavior: ReturnAction): PreparedStatement
Inherited from
JdbcContextVerbExecute
def probingDataSource: Option[DataSource]
override
def push[A, B](result: ZIO[Has[Connection], SQLException, A])(f: A => B): ZIO[Has[Connection], SQLException, B]
Definition Classes
ZioJdbcUnderlyingContext -> ZioTranslateContext -> ContextTranslateProto -> JdbcContextVerbExecute
Inherited from
ZioJdbcUnderlyingContext
@targetName("runBatchActionReturning")
inline
def run[I, T, A <: Action[I] & QAC[I, T]](inline quoted: Quoted[BatchAction[A]]): ZIO[Has[Connection], SQLException, List[T]]
@targetName("runBatchAction")
inline
def run[I, A <: Action[I] & QAC[I, Nothing]](inline quoted: Quoted[BatchAction[A]]): ZIO[Has[Connection], SQLException, List[Long]]
@targetName("runActionReturning")
inline
def run[E, T](inline quoted: Quoted[ActionReturning[E, T]]): ZIO[Has[Connection], SQLException, T]
@targetName("runAction")
inline
def run[E](inline quoted: Quoted[Action[E]]): ZIO[Has[Connection], SQLException, Long]
@targetName("runQuerySingle")
inline
def run[T](inline quoted: Quoted[T]): ZIO[Has[Connection], SQLException, T]
@targetName("runQuery")
inline
def run[T](inline quoted: Quoted[Query[T]], inline wrap: OuterSelectWrap): ZIO[Has[Connection], SQLException, List[T]]
@targetName("runQueryDefault")
inline
def run[T](inline quoted: Quoted[Query[T]]): ZIO[Has[Connection], SQLException, List[T]]
override
def seq[A](f: List[ZIO[Has[Connection], SQLException, A]]): ZIO[Has[Connection], SQLException, List[A]]
Definition Classes
ZioJdbcUnderlyingContext -> ZioTranslateContext -> ContextTranslateProto -> JdbcContextVerbExecute
Inherited from
ZioJdbcUnderlyingContext
@targetName("streamQueryWithFetchSize")
inline
def stream[T](inline quoted: Quoted[Query[T]], fetchSize: Int): StreamResult[T]
Inherited from
ContextVerbStream
@targetName("streamQuery")
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): QCStream[T]
def transaction[R <: Has[Connection], A](f: ZIO[R, Throwable, A]): ZIO[R, Throwable, A]
@targetName("translateBatchActionReturning")
inline
def translate[I, T, A <: Action[I] & QAC[I, T]](inline quoted: Quoted[BatchAction[A]], inline prettyPrint: Boolean): TranslateResult[List[String]]
Inherited from
ContextTranslateMacro
@targetName("translateBatchActionReturning")
inline
def translate[I, T, A <: Action[I] & QAC[I, T]](inline quoted: Quoted[BatchAction[A]]): TranslateResult[List[String]]
Inherited from
ContextTranslateMacro
@targetName("translateBatchAction")
inline
def translate[I, A <: Action[I] & QAC[I, Nothing]](inline quoted: Quoted[BatchAction[A]], inline prettyPrint: Boolean): TranslateResult[List[String]]
Inherited from
ContextTranslateMacro
@targetName("translateBatchAction")
inline
def translate[I, A <: Action[I] & QAC[I, Nothing]](inline quoted: Quoted[BatchAction[A]]): TranslateResult[List[String]]
Inherited from
ContextTranslateMacro
@targetName("translateActionReturning")
inline
def translate[E, T](inline quoted: Quoted[ActionReturning[E, T]], inline prettyPrint: Boolean): TranslateResult[String]
Inherited from
ContextTranslateMacro
@targetName("translateActionReturning")
inline
def translate[E, T](inline quoted: Quoted[ActionReturning[E, T]]): TranslateResult[String]
Inherited from
ContextTranslateMacro
@targetName("translateAction")
inline
def translate[E](inline quoted: Quoted[Action[E]], inline prettyPrint: Boolean): TranslateResult[String]
Inherited from
ContextTranslateMacro
@targetName("translateAction")
inline
def translate[E](inline quoted: Quoted[Action[E]]): TranslateResult[String]
Inherited from
ContextTranslateMacro
@targetName("translateQuerySingle")
inline
def translate[T](inline quoted: Quoted[T], inline prettyPrint: Boolean): TranslateResult[String]
Inherited from
ContextTranslateMacro
@targetName("translateQuerySingle")
inline
def translate[T](inline quoted: Quoted[T]): TranslateResult[String]
Inherited from
ContextTranslateMacro
@targetName("translateQuery")
inline
def translate[T](inline quoted: Quoted[Query[T]], inline prettyPrint: Boolean): TranslateResult[String]
Inherited from
ContextTranslateMacro
@targetName("translateQuery")
inline
def translate[T](inline quoted: Quoted[Query[T]]): TranslateResult[String]
Inherited from
ContextTranslateMacro
override
def translateBatchQueryEndpoint(groups: List[BatchGroup], prettyPrint: Boolean)(info: ExecutionInfo, dc: Runner): QCIO[List[String]]
Definition Classes
ZioJdbcUnderlyingContext -> ContextTranslateProto
Inherited from
ZioJdbcUnderlyingContext
def translateBatchQueryReturningEndpoint(groups: List[BatchGroupReturning], prettyPrint: Boolean)(executionInfo: ExecutionInfo, dc: TranslateRunner): TranslateResult[List[String]]
Inherited from
ContextTranslateProto
override
def translateQueryEndpoint[T](statement: String, prepare: Prepare, extractor: () => T, prettyPrint: Boolean)(info: ExecutionInfo, dc: Runner): QCIO[String]
Definition Classes
ZioJdbcUnderlyingContext -> ContextTranslateProto
Inherited from
ZioJdbcUnderlyingContext
protected
def withConnection[T](f: Connection => Result[T]): Result[T]
override protected
def withConnectionWrapped[T](f: Connection => T): QCIO[T]
Definition Classes
ZioJdbcUnderlyingContext -> JdbcContextVerbExecute
Inherited from
ZioJdbcUnderlyingContext
override
def wrap[T](t: => T): ZIO[Has[Connection], SQLException, T]
Definition Classes
ZioJdbcUnderlyingContext -> ZioTranslateContext -> ContextTranslateProto -> JdbcContextVerbExecute
Inherited from
ZioJdbcUnderlyingContext

Concrete fields

val naming: N

Inherited fields

protected
val dateTimeZone: TimeZone
Inherited from
JdbcContextTypes
Inherited from
RowContext
protected
val identityPrepare: Prepare
Inherited from
RowContext
val idiom: OracleDialect
Inherited from
OracleJdbcTypes

Extensions

Inherited extensions

extension [T](q: Query[T])
inline
def filterByKeys(inline map: Map[String, String]): Query[T]

When using this with FilterColumns make sure it comes FIRST. Otherwise the columns are you filtering may have been nullified in the SQL before the filteration has actually happened.

When using this with FilterColumns make sure it comes FIRST. Otherwise the columns are you filtering may have been nullified in the SQL before the filteration has actually happened.

Inherited from
Context
inline
def filterColumns(inline columns: List[String]): Query[T]
Inherited from
Context

Implicits

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
Inherited from
Decoders
implicit
Inherited from
Encoders
implicit
Inherited from
BooleanIntEncoding
implicit
Inherited from
BooleanIntEncoding
implicit
val byteArrayDecoder: JdbcDecoder[Array[Byte]]
Inherited from
Decoders
implicit
val byteArrayEncoder: JdbcEncoder[Array[Byte]]
Inherited from
Encoders
implicit
Inherited from
Decoders
implicit
Inherited from
Encoders
implicit
Inherited from
Decoders
implicit
Inherited from
Encoders
implicit inline
def dec[T]: GenericDecoder[ResultRow, Session, T, Generic]
Inherited from
Context
implicit
Inherited from
Decoders
implicit
Inherited from
Encoders
implicit
Inherited from
Decoders
implicit
Inherited from
Encoders
implicit
Inherited from
Decoders
implicit
Inherited from
Encoders
implicit
Inherited from
Decoders
implicit
Inherited from
Encoders
implicit
val localDateTimeDecoder: JdbcDecoder[LocalDateTime]
Inherited from
Decoders
implicit
val localDateTimeEncoder: JdbcEncoder[LocalDateTime]
Inherited from
Encoders
implicit
Inherited from
Decoders
implicit
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
Inherited from
Decoders
implicit
Inherited from
Encoders
implicit
Inherited from
Decoders
implicit
Inherited from
Encoders
implicit
Inherited from
UUIDStringEncoding
implicit
Inherited from
UUIDStringEncoding