OracleZioJdbcContext

class OracleZioJdbcContext[N <: NamingStrategy](val naming: N) extends ZioJdbcContext[OracleDialect, N] with OracleJdbcRunContext[N]
trait OracleJdbcRunContext[N]
trait UUIDStringEncoding
trait BooleanIntEncoding
class ZioJdbcContext[OracleDialect, N]
trait ZioPrepareContext[OracleDialect, N]
trait PrepareContext[OracleDialect, N]
trait JdbcRunContext[OracleDialect, N]
trait Decoders
trait Encoders
trait SqlContext[OracleDialect, N]
trait ZioContext[OracleDialect, N]
trait StreamingContext[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
ProtoContext
case class BatchGroupReturning(string: String, returningBehavior: ReturnAction, prepare: List[Prepare])
Inherited from
ProtoContext
case class JdbcDecoder[T](decoder: () => T)
Inherited from
Decoders
case class JdbcEncoder[T](sqlType: Int, encoder: () => T)
Inherited from
Encoders
class ResultSetIterator[T](rs: ResultSet, extractor: () => T)

In order to allow a ResultSet to be consumed by an Observable, a ResultSet iterator must be created. Since Quill provides a extractor for an individual ResultSet row, a single row can easily be cached in memory. This allows for a straightforward implementation of a hasNext method.

In order to allow a ResultSet to be consumed by an Observable, a ResultSet iterator must be created. Since Quill provides a extractor for an individual ResultSet row, a single row can easily be cached in memory. This allows for a straightforward implementation of a hasNext method.

Inherited from
ZioJdbcContext

Inherited types

type BaseDecoder[T] = GenericDecoder[ResultRow, T, Specific]
Inherited from
EncodingDsl
type BaseEncoder[T] = GenericEncoder[T, PrepareRow]
Inherited from
EncodingDsl
type ColumnResolver = GenericColumnResolver[ResultRow]
Inherited from
EncodingDsl
override type DatasourceContext = Unit
Inherited from
JdbcRunContext
type DatasourceContextBehavior <: DatasourceContextInjection
Inherited from
Context
type Decoder[T] = JdbcDecoder[T]
Inherited from
Decoders
type DecoderMethod[T] = (Int, ResultRow) => T
Inherited from
EncodingDsl
type Encoder[T] = JdbcEncoder[T]
Inherited from
Encoders
type EncoderMethod[T] = (Int, T, PrepareRow) => PrepareRow
Inherited from
EncodingDsl
override type Environment = Has[Session] & Blocking
Inherited from
ZioJdbcContext
override type Error = SQLException
Inherited from
ZioJdbcContext
type Extractor[T] = ResultRow => T
Inherited from
ProtoStreamContext
type Index = Int
Inherited from
JdbcRunContext
type Prepare = PrepareRow => (List[Any], PrepareRow)
Inherited from
ProtoStreamContext
Inherited from
ZioPrepareContext
override type PrepareBatchActionResult = QIO[List[PrepareRow]]
Inherited from
ZioPrepareContext
Inherited from
ZioPrepareContext
override type PrepareRow = PreparedStatement
Inherited from
ZioJdbcContext
override type Result[T] = ZIO[Has[Session] & Blocking, SQLException, 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
JdbcRunContext
override type RunQuerySingleResult[T] = T
Inherited from
JdbcRunContext
override type Session = Connection
Inherited from
JdbcRunContext
override type StreamResult[T] = ZStream[Environment, Error, T]
Inherited from
ZioContext

Value members

Inherited methods

def chunkedFetch[T](iter: ResultSetIterator[T], fetchSize: Int): ZStream[Any, Throwable, T]
Inherited from
ZioJdbcContext
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
ZioJdbcContext -> Context -> Closeable -> AutoCloseable
Inherited from
ZioJdbcContext
override def context: DatasourceContext
Definition Classes
JdbcRunContext -> Context
Inherited from
JdbcRunContext
def decoder[T](f: ResultRow => Index => T): JdbcDecoder[T]
Inherited from
Decoders
def decoder[T](d: (Int, ResultRow) => 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[T](sql: String, prepare: Prepare)(executionInfo: ExecutionInfo, dc: DatasourceContext): Result[Long]
Definition Classes
JdbcRunContext -> ProtoContext
Inherited from
JdbcRunContext
override def executeActionReturning[O](sql: String, prepare: Prepare, extractor: () => O, returningBehavior: ReturnAction)(executionInfo: ExecutionInfo, dc: DatasourceContext): Result[O]
Definition Classes
JdbcRunContext -> ProtoContext
Inherited from
JdbcRunContext
override def executeBatchAction(groups: List[BatchGroup])(executionInfo: ExecutionInfo, dc: DatasourceContext): Result[List[Long]]
Definition Classes
JdbcRunContext -> ProtoContext
Inherited from
JdbcRunContext
def executeBatchActionReturning[T](groups: List[BatchGroupReturning], extractor: () => T)(executionInfo: ExecutionInfo, dc: DatasourceContext): Result[List[T]]
Inherited from
JdbcRunContext
override def executeQuery[T](sql: String, prepare: Prepare, extractor: () => T)(executionInfo: ExecutionInfo, dc: DatasourceContext): Result[List[T]]
Definition Classes
JdbcRunContext -> ProtoContext
Inherited from
JdbcRunContext
override def executeQuerySingle[T](sql: String, prepare: Prepare, extractor: () => T)(executionInfo: ExecutionInfo, dc: DatasourceContext): Result[T]
Definition Classes
JdbcRunContext -> ProtoContext
Inherited from
JdbcRunContext
def guardedChunkFill[A](n: Int)(hasNext: => Boolean, elem: => A): Chunk[A]
Inherited from
ZioJdbcContext
protected def handleSingleResult[T](list: List[T]): T
Inherited from
Context
protected def handleSingleWrappedResult[T](list: Result[List[T]]): Result[T]
Inherited from
JdbcRunContext
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
JdbcRunContext
@targetName("runPrepareBatchAction")
inline def prepare[I, A <: Action[I] & QAC[I, Nothing]](inline quoted: Quoted[BatchAction[A]]): PrepareBatchActionResult
Inherited from
PrepareContext
@targetName("runPrepareAction")
inline def prepare[E](inline quoted: Quoted[Action[E]]): PrepareActionResult
Inherited from
PrepareContext
@targetName("runPrepareQuerySingle")
inline def prepare[T](inline quoted: Quoted[T]): PrepareQueryResult
Inherited from
PrepareContext
@targetName("runPrepareQuery")
inline def prepare[T](inline quoted: Quoted[Query[T]]): PrepareQueryResult
Inherited from
PrepareContext
def prepareAction(sql: String, prepare: Prepare)(executionInfo: ExecutionInfo, dc: DatasourceContext): PrepareActionResult
Inherited from
ZioPrepareContext
def prepareBatchAction(groups: List[BatchGroup])(executionInfo: ExecutionInfo, dc: DatasourceContext): PrepareBatchActionResult
Inherited from
ZioPrepareContext
def prepareQuery(sql: String, prepare: Prepare)(executionInfo: ExecutionInfo, dc: DatasourceContext): PrepareQueryResult
Inherited from
ZioPrepareContext
def prepareSingle(sql: String, prepare: Prepare)(executionInfo: ExecutionInfo, dc: DatasourceContext): QIO[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
ZioJdbcContext
protected def prepareWithReturning(sql: String, conn: Connection, returningBehavior: ReturnAction): PreparedStatement
Inherited from
JdbcRunContext
@targetName("runBatchActionReturning")
inline def run[I, T, A <: Action[I] & QAC[I, T]](inline quoted: Quoted[BatchAction[A]]): Result[List[T]]
Inherited from
Context
@targetName("runBatchAction")
inline def run[I, A <: Action[I] & QAC[I, Nothing]](inline quoted: Quoted[BatchAction[A]]): Result[RunBatchActionResult]
Inherited from
Context
@targetName("runActionReturning")
inline def run[E, T](inline quoted: Quoted[ActionReturning[E, T]]): Result[RunActionReturningResult[T]]
Inherited from
Context
@targetName("runAction")
inline def run[E](inline quoted: Quoted[Action[E]]): Result[RunActionResult]
Inherited from
Context
@targetName("runQuerySingle")
inline def run[T](inline quoted: Quoted[T]): Result[RunQuerySingleResult[T]]
Inherited from
Context
@targetName("runQuery")
inline def run[T](inline quoted: Quoted[Query[T]]): Result[List[T]]
Inherited from
Context
@targetName("streamQueryWithFetchSize")
inline def stream[T](inline quoted: Quoted[Query[T]], fetchSize: Int): StreamResult[T]
Inherited from
StreamingContext
@targetName("streamQuery")
inline def stream[T](inline quoted: Quoted[Query[T]]): StreamResult[T]
Inherited from
StreamingContext
def streamQuery[T](fetchSize: Option[Int], sql: String, prepare: Prepare, extractor: () => T)(executionInfo: ExecutionInfo, dc: DatasourceContext): QStream[T]
Inherited from
ZioJdbcContext
def transaction[A](f: ZIO[QConnection, Throwable, A]): ZIO[QConnection, Throwable, A]
Inherited from
ZioJdbcContext
protected def withConnection[T](f: Connection => Result[T]): Result[T]
Inherited from
ZioJdbcContext
override protected def withConnectionWrapped[T](f: Connection => T): QIO[T]
Definition Classes
ZioJdbcContext -> JdbcRunContext
Inherited from
ZioJdbcContext

Concrete fields

val naming: N

Inherited fields

override protected val effect: ContextEffect[Result]
Inherited from
ZioJdbcContext
Inherited from
RowContext
val identityPrepare: Prepare
Inherited from
RowContext
val idiom: OracleDialect
Inherited from
OracleJdbcRunContext
val streamBlocker: ZStream[Blocking, Nothing, Any]
Inherited from
ZioJdbcContext

Extensions

Inherited extensions

extension (q: Query[T])
inline def filterByKeys[T](inline map: Map[String, 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 val bigDecimalDecoder: JdbcDecoder[BigDecimal]
Inherited from
Decoders
implicit val bigDecimalEncoder: JdbcEncoder[BigDecimal]
Inherited from
Encoders
implicit val booleanDecoder: JdbcDecoder[Boolean]
Inherited from
BooleanIntEncoding
implicit val booleanEncoder: JdbcEncoder[Boolean]
Inherited from
BooleanIntEncoding
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, 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 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](mapped: MappedEncoding[I, O], d: JdbcDecoder[I]): JdbcDecoder[O]
Inherited from
Decoders
implicit override def mappedEncoder[I, O](mapped: MappedEncoding[I, O], e: JdbcEncoder[O]): JdbcEncoder[I]
Definition Classes
Encoders -> EncodingDsl
Inherited from
Encoders
implicit def optionDecoder[T](d: JdbcDecoder[T]): JdbcDecoder[Option[T]]
Inherited from
Decoders
implicit def optionEncoder[T](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