object Txn
The Txn
object provides methods that operate on the current transaction
context. These methods are only valid within an atomic block or a
transaction life-cycle handler, which is checked at compile time by
requiring that an implicit InTxn
or InTxnEnd
be available.
- Alphabetic
- By Inheritance
- Txn
- AnyRef
- Any
- Hide All
- Show All
- Public
- All
Type Members
-
case class
ExplicitRetryCause
(timeoutNanos: Option[Long]) extends TransientRollbackCause with Product with Serializable
The
RollbackCause
for an atomic block execution attempt that ended with a call toretry
orretryFor
.The
RollbackCause
for an atomic block execution attempt that ended with a call toretry
orretryFor
. The atomic block will be retried after some memory location read in the previous attempt has changed. -
trait
ExternalDecider
extends AnyRef
An
ExternalDecider
is given the final control over the decision of whether or not to commit a transaction, which allows two-phase commit to be integrated with a single non-transactional resource.An
ExternalDecider
is given the final control over the decision of whether or not to commit a transaction, which allows two-phase commit to be integrated with a single non-transactional resource.shouldCommit
will only be called if aInTxn
has successfully called all of its before-commit handlers, acquired all necessary write locks, validated all of its reads and called all of its while-preparing handlers. The decider may then attempt a non-transactional operation whose outcome is uncertain, and based on the outcome may directly cause the transaction to commit or roll back. -
case class
OptimisticFailureCause
(category: Symbol, trigger: Option[Any]) extends TransientRollbackCause with Product with Serializable
The
RollbackCause
for aNestingLevel
whose optimistic execution was invalid, and that should be retried.The
RollbackCause
for aNestingLevel
whose optimistic execution was invalid, and that should be retried. The specific situations in which an optimistic failure can occur are specific to the STM algorithm, but may include:- the STM detected that the value returned by a previous read in this nesting level is no longer valid;
- a cyclic dependency has occurred and this nesting level must be rolled back to avoid deadlock;
- a transaction with a higher priority wanted to write to a
Ref
written by this transaction; - the STM decided to switch execution strategies for this atomic block; or
- no apparent reason (*).
(*) - Some STMs perform validation, conflict detection and deadlock cycle breaking using algorithms that are conservative approximations. This means that any particular attempt to execute an atomic block might fail spuriously.
- category
an STM-specific label for the reason behind this optimistic failure. The set of possible categories is bounded.
- trigger
the specific object that led to the optimistic failure, if it is available, otherwise
None
.
-
sealed abstract
class
PermanentRollbackCause
extends RollbackCause
RollbackCause
s for which the failure is permanent and no attempt should be made to retry the underlying atomic block. -
sealed abstract
class
RollbackCause
extends AnyRef
A record of the reason that a atomic block execution attempt was rolled back.
-
case class
RolledBack
(cause: RollbackCause) extends Status with Product with Serializable
The
Status
for an atomic block execution attempt that is being or that has been cancelled.The
Status
for an atomic block execution attempt that is being or that has been cancelled. None of theRef
writes made during this nesting level or in any child nesting level will ever be visible to other threads. The atomic block will be automatically retried ifcause
is aTransientRollbackCause
, unless STM-specific retry thresholds are exceeded. -
sealed abstract
class
Status
extends AnyRef
The current state of an attempt to execute an atomic block.
-
sealed abstract
class
TransientRollbackCause
extends RollbackCause
RollbackCause
s for which the failure is transient and another attempt should be made to execute the underlying atomic block. -
case class
UncaughtExceptionCause
(x: Throwable) extends PermanentRollbackCause with Product with Serializable
The
RollbackCause
for an atomic block that should not be restarted because it threw an exception.The
RollbackCause
for an atomic block that should not be restarted because it threw an exception. The exception might have been thrown from the body of the atomic block or from a handler invoked before the commit decision. Exceptions used for control flow are not included (seeTxnExecutor.isControlFlow
).Scala's STM discards
Ref
writes performed by atomic blocks that throw an exception. This is referred to as "failure atomicity". In a system that uses exceptions for error cleanup this design tends to preserve the invariants of shared data structures, which is a good thing. If a system uses exceptions for control flow, however, this design may lead to unexpected behavior. TheTxnExecutor
object'sisControlFlow
method is used to distinguish exceptions representing control flow transfers from those used to represent error conditions. SeeTxnExecutor.transformDefault
to change the default rules. -
case class
UnrecordedTxnCause
[Z](z: Z) extends PermanentRollbackCause with Product with Serializable
The
RollbackCause
of a successfully completedatomic.unrecorded
block.The
RollbackCause
of a successfully completedatomic.unrecorded
block. SeeTxnExecutor.unrecorded
.
Value Members
-
final
def
!=(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
-
final
def
##(): Int
- Definition Classes
- AnyRef → Any
-
final
def
==(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
-
def
afterCommit(handler: (Status) ⇒ Unit)(implicit txn: InTxnEnd): Unit
Arranges for
handler
to be executed as soon as possible after the current transaction is committed, if this nesting level is part of the overall transaction commit.Arranges for
handler
to be executed as soon as possible after the current transaction is committed, if this nesting level is part of the overall transaction commit. Details:- no transaction will be active while the handler is run, but it may
access
Ref
s using a new top-level atomic block or.single
; - the handler runs after all internal locks have been released, so any values read or written in the transaction might already have been changed by another thread before the handler is executed;
- handlers will be executed in their registration order; and
- handlers may be registered so long as the current transaction status is
not
RolledBack
orCommitted
.
- no transaction will be active while the handler is run, but it may
access
-
def
afterCompletion(handler: (Status) ⇒ Unit)(implicit txn: InTxnEnd): Unit
Arranges for
handler
to be called as both an after-commit and after-rollback handler.Arranges for
handler
to be called as both an after-commit and after-rollback handler.Equivalent to:
afterRollback(handler) afterCommit(handler)
-
def
afterRollback(handler: (Status) ⇒ Unit)(implicit txn: InTxnEnd): Unit
Arranges for
handler
to be executed as soon as possible after the current nesting level is rolled back, or runs the handler immediately if the current nesting level's status is alreadyRolledBack
.Arranges for
handler
to be executed as soon as possible after the current nesting level is rolled back, or runs the handler immediately if the current nesting level's status is alreadyRolledBack
. Details:- the handler will be executed during any partial rollback that includes the current nesting level;
- the handler will be run before any additional attempts to execute the atomic block;
- handlers will be run in the reverse of their registration order; and
- handlers may be registered so long as the current transaction status is
not
Committed
.
-
final
def
asInstanceOf[T0]: T0
- Definition Classes
- Any
-
def
beforeCommit(handler: (InTxn) ⇒ Unit)(implicit txn: InTxn): Unit
Arranges for
handler
to be executed as late as possible while the root nesting level of the current transaction is stillActive
, unless the current nesting level is rolled back.Arranges for
handler
to be executed as late as possible while the root nesting level of the current transaction is stillActive
, unless the current nesting level is rolled back. Reads, writes and additional nested transactions may be performed inside the handler. Details:- it is possible that after
handler
is run the transaction might still be rolled back; - it is okay to call
beforeCommit
from insidehandler
, the reentrantly added handler will be included in this before-commit phase; and - before-commit handlers will be executed in their registration order.
- it is possible that after
-
def
clone(): AnyRef
- Attributes
- protected[java.lang]
- Definition Classes
- AnyRef
- Annotations
- @throws( ... )
-
final
def
eq(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
-
def
equals(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
-
def
finalize(): Unit
- Attributes
- protected[java.lang]
- Definition Classes
- AnyRef
- Annotations
- @throws( classOf[java.lang.Throwable] )
-
def
findCurrent(implicit mt: MaybeTxn): Option[InTxn]
Returns
Some(t)
if called from inside the static or dynamic scope of the transaction contextt
,None
otherwise.Returns
Some(t)
if called from inside the static or dynamic scope of the transaction contextt
,None
otherwise. If an implicitInTxn
is available it may be used. -
final
def
getClass(): Class[_]
- Definition Classes
- AnyRef → Any
-
def
hashCode(): Int
- Definition Classes
- AnyRef → Any
-
final
def
isInstanceOf[T0]: Boolean
- Definition Classes
- Any
-
final
def
ne(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
-
final
def
notify(): Unit
- Definition Classes
- AnyRef
-
final
def
notifyAll(): Unit
- Definition Classes
- AnyRef
-
def
retry(implicit txn: InTxn): Nothing
Rolls back the current nesting level for modular blocking.
Rolls back the current nesting level for modular blocking. It will be retried, but only after some memory location observed by this transaction has been changed. If any alternatives to this atomic block were provided via
orAtomic
oratomic.oneOf
, then the alternative will be tried before blocking.- Exceptions thrown
IllegalStateException
if the transaction is not active.
-
def
retryFor(timeout: Long, unit: TimeUnit = TimeUnit.MILLISECONDS)(implicit txn: InTxn): Unit
Causes the transaction to roll back and retry using modular blocking with a timeout, or returns immediately if the timeout has already expired.
Causes the transaction to roll back and retry using modular blocking with a timeout, or returns immediately if the timeout has already expired. The STM keeps track of the total amount of blocking that has occurred during modular blocking; this time is apportioned among the calls to
View.tryAwait
andretryFor
that are part of the current attempt.retryFor(0)
is a no-op.Returns only if the timeout has expired.
- timeout
the maximum amount of time that this
retryFor
should block, in units ofunit
.- unit
the units in which to measure
timeout
, by default milliseconds.
-
def
rollback(cause: RollbackCause)(implicit txn: InTxnEnd): Nothing
Causes the current nesting level to be rolled back due to the specified
cause
.Causes the current nesting level to be rolled back due to the specified
cause
. This method may only be called by the thread executing the transaction; obtain aNestingLevel
instancen
and calln.requestRollback(cause)
if you wish to doom a transaction from another thread.- Exceptions thrown
IllegalStateException
if the current transaction has already decided to commit.
-
def
setExternalDecider(decider: ExternalDecider)(implicit txn: InTxnEnd): Unit
(rare) Delegates final decision of the outcome of the transaction to
decider
if the current nesting level participates in the top-level commit.(rare) Delegates final decision of the outcome of the transaction to
decider
if the current nesting level participates in the top-level commit. This method can succeed with at most one value per top-level transaction.- Exceptions thrown
IllegalArgumentException
ifsetExternalDecider(d)
was previously called in this transaction,d != decider
, and the nesting level from whichsetExternalDecider(d)
was called has not rolled back.IllegalStateException
if the current transaction's status is notActive
orPreparing
-
def
status(implicit txn: InTxnEnd): Status
Returns the status of the current nesting level of the current transaction, equivalent to
NestingLevel.current.status
. -
final
def
synchronized[T0](arg0: ⇒ T0): T0
- Definition Classes
- AnyRef
-
def
toString(): String
- Definition Classes
- AnyRef → Any
-
final
def
wait(): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws( ... )
-
final
def
wait(arg0: Long, arg1: Int): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws( ... )
-
final
def
wait(arg0: Long): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws( ... )
-
def
whileCommitting(handler: (InTxnEnd) ⇒ Unit)(implicit txn: InTxnEnd): Unit
(rare) Arranges for
handler
to be called after (if) it has been decided that the current transaction will commit, but before the writes made by the transaction have become available to other threads.(rare) Arranges for
handler
to be called after (if) it has been decided that the current transaction will commit, but before the writes made by the transaction have become available to other threads. While-committing handlers can lead to scalability problems, because while this transaction is in theCommitting
state it might obstruct other transactions. Details:- the handler must not access any
Ref
s, even usingRef.single
; - handlers will be executed in their registration order; and
- handlers may be registered so long as the current transaction status is
not
RolledBack
orCommitted
.
- the handler must not access any
-
def
whilePreparing(handler: (InTxnEnd) ⇒ Unit)(implicit txn: InTxnEnd): Unit
(rare) Arranges for
handler
to be called after theRef
reads and writes have been checked for serializability, but before the decision has been made to commit or roll back.(rare) Arranges for
handler
to be called after theRef
reads and writes have been checked for serializability, but before the decision has been made to commit or roll back. While-preparing handlers can lead to scalability problems, because while this transaction is in thePreparing
state it might obstruct other transactions. Details:- the handler must not access any
Ref
s, even usingRef.single
; - handlers will be executed in their registration order; and
- handlers may be registered while the transaction is active, or from a
while-preparing callback during the
Preparing
phase.
- the handler must not access any
-
object
Active
extends Status with Product with Serializable
The
Status
for a transaction nesting level that may performRef
reads and writes, that is waiting for a child nesting level to complete, or that has been merged into anActive
parent nesting level. -
object
Committed
extends Status with Product with Serializable
The
Status
for the nesting levels of a transaction that has been committed.The
Status
for the nesting levels of a transaction that has been committed. After-commit callbacks may still be running. -
object
Committing
extends Status with Product with Serializable
The
Status
for the nesting levels of a transaction that has decided to commit, but whoseRef
writes are not yet visible to other threads. -
object
Prepared
extends Status with Product with Serializable
The
Status
for the nesting levels of a transaction that has successfully acquired all write permissions necessary to succeed, and that has delegated the final commit decision to an external decider. -
object
Preparing
extends Status with Product with Serializable
The
Status
for the nesting levels of a transaction that are attempting to commit, but for which the outcome is uncertain.