class DbActiveContractStore extends ActiveContractStore with DbStore with DbPrunableByTimeDomain

Active contracts journal

This database table has the following indexes to support scaling query performance: - CREATE index active_contracts_dirty_request_reset_idx ON active_contracts (domain_id, request_counter) used on startup of the SyncDomain to delete all dirty requests. - CREATE index active_contracts_contract_id_idx ON active_contracts (contract_id) used in conflict detection for point wise lookup of the contract status. - CREATE index active_contracts_ts_domain_id_idx ON active_contracts (ts, domain_id) used on startup by the SyncDomain to replay ACS changes to the ACS commitment processor.

Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. DbActiveContractStore
  2. DbPrunableByTimeDomain
  3. DbPrunableByTime
  4. DbStore
  5. HasCloseContext
  6. PromiseUnlessShutdownFactory
  7. NamedLogging
  8. FlagCloseable
  9. PerformUnlessClosing
  10. OnShutdownRunner
  11. AutoCloseable
  12. ActiveContractStore
  13. ConflictDetectionStore
  14. PrunableByTime
  15. ActiveContractSnapshot
  16. AnyRef
  17. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. Protected

Instance Constructors

  1. new DbActiveContractStore(storage: DbStorage, domainId: IndexedDomain, enableAdditionalConsistencyChecks: Boolean, maxContractIdSqlInListSize: PositiveNumeric[Int], batchingParametersConfig: PrunableByTimeParameters, indexedStringStore: IndexedStringStore, protocolVersion: ProtocolVersion, timeouts: ProcessingTimeout, loggerFactory: NamedLoggerFactory)(implicit ec: ExecutionContext)

Value Members

  1. final def !=(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  2. final def ##: Int
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  4. def advancePruningTimestamp(phase: PruningPhase, timestamp: CantonTimestamp)(implicit traceContext: TraceContext): Future[Unit]
    Attributes
    protected[canton]
    Definition Classes
    DbPrunableByTimePrunableByTime
  5. def archiveContract(cid: LfContractId, toc: TimeOfChange)(implicit traceContext: TraceContext): CheckedT[Future, AcsError, AcsWarning, Unit]

    Shorthand for archiveContracts(Seq(contractId), toc)

    Shorthand for archiveContracts(Seq(contractId), toc)

    Definition Classes
    ActiveContractStore
  6. def archiveContracts(contracts: Seq[LfContractId], toc: TimeOfChange)(implicit traceContext: TraceContext): CheckedT[Future, AcsError, AcsWarning, Unit]

    Marks the given contracts as archived from toc's timestamp (inclusive) onwards.

    Marks the given contracts as archived from toc's timestamp (inclusive) onwards.

    toc

    The time of change consisting of

    • The request counter of the confirmation request that archives the contracts.
    • The timestamp on the confirmation request that archives the contracts.
    returns

    The future completes when all contract states have been updated. The following irregularities are reported for each contract:

    Definition Classes
    DbActiveContractStoreActiveContractStore
  7. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  8. def batchingParameters: Option[PrunableByTimeParameters]

    Parameters to control prune batching

    Parameters to control prune batching

    If defined, then the pruning window will be computed such that it targets the ideal target batch size in order to optimize the load on the database.

    This is currently used with the journal stores. Normal pruning of other stores already does batching on its own.

    Attributes
    protected
    Definition Classes
    DbActiveContractStorePrunableByTime
  9. def bulkContractsTransferCounterSnapshot(contractIds: Set[LfContractId], requestCounter: RequestCounter)(implicit traceContext: TraceContext): Future[Map[LfContractId, TransferCounterO]]

    Returns a map to the latest transfer counter of the contract before the given request counter.

    Returns a map to the latest transfer counter of the contract before the given request counter. If the contract does not exist in the ACS, it returns a None.

    requestCounter

    The request counter *immediately before* which the state of the contracts shall be determined.

    Definition Classes
    DbActiveContractStoreActiveContractSnapshot
    Exceptions thrown

    java.lang.IllegalArgumentException if requestCounter is equal to RequestCounter.MinValue.

  10. def cancelShutdownTask(token: Long): Unit

    Removes a shutdown task from the list using a token returned by runOnShutdown

    Removes a shutdown task from the list using a token returned by runOnShutdown

    Definition Classes
    OnShutdownRunner
  11. def changesBetween(fromExclusive: TimeOfChange, toInclusive: TimeOfChange)(implicit traceContext: TraceContext): Future[LazyList[(TimeOfChange, ActiveContractIdsChange)]]

    Returns all changes to the active contract set between the two timestamps (exclusive lower bound timestamp, inclusive upper bound timestamp) in the order of their changes.

    Returns all changes to the active contract set between the two timestamps (exclusive lower bound timestamp, inclusive upper bound timestamp) in the order of their changes. The provided lower bound must not be larger than the upper bound.

    fromExclusive

    The lower bound for the changes. Must not be larger than the upper bound.

    toInclusive

    The upper bound for the changes. Must not be smaller than the lower bound.

    Definition Classes
    DbActiveContractStoreActiveContractSnapshot
    Exceptions thrown

    java.lang.IllegalArgumentException If the intervals are in the wrong order.

  12. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.CloneNotSupportedException]) @native() @HotSpotIntrinsicCandidate()
  13. final def close(): Unit

    Blocks until all earlier tasks have completed and then prevents further tasks from being run.

    Blocks until all earlier tasks have completed and then prevents further tasks from being run.

    Definition Classes
    FlagCloseableOnShutdownRunner → AutoCloseable
  14. implicit val closeContext: CloseContext
    Definition Classes
    HasCloseContext
  15. def closingTimeout: FiniteDuration
    Attributes
    protected
    Definition Classes
    FlagCloseablePerformUnlessClosing
  16. def containsShutdownTask(token: Long): Boolean
    Definition Classes
    OnShutdownRunner
  17. def contractSnapshot(contractIds: Set[LfContractId], timestamp: CantonTimestamp)(implicit traceContext: TraceContext): Future[Map[LfContractId, CantonTimestamp]]

    Returns a map to the timestamp when the contract became active for the last time before or at the given timestamp.

    Returns a map to the timestamp when the contract became active for the last time before or at the given timestamp. Omits contracts that not active right after the given timestamp.

    timestamp

    The timestamp at which the activeness of the contracts shall be determined. Must be before the timestamp that corresponds to the head cursor in the com.digitalasset.canton.participant.protocol.RequestJournal for the state com.digitalasset.canton.participant.protocol.RequestJournal.RequestState.Clean. If this precondition is violated, the returned snapshot may be inconsistent, i.e., it may omit some contracts that were ActiveContractStore.Active at the given time and it may include contracts that were actually ActiveContractStore.Archived or ActiveContractStore.TransferredAway.

    Definition Classes
    DbActiveContractStoreActiveContractSnapshot
  18. def deleteSince(criterion: RequestCounter)(implicit traceContext: TraceContext): Future[Unit]

    Deletes all activeness changes from requests whose request counter is at least the given one.

    Deletes all activeness changes from requests whose request counter is at least the given one. This method must not be called concurrently with creating, archiving, or transferring contracts.

    Therefore, this method need not be linearizable w.r.t. creating, archiving, or transferring contracts. For example, if a request rc1 creates a contract c and another request rc2 archives it while deleteSince is running for some rc <= rc1, rc2, then there are no guarantees which of the effects of rc1 and rc2 remain. For example, c could end up being inexistent, active, or archived but never created, even if the writes for rc1 and rc2 are successful.

    Definition Classes
    DbActiveContractStoreActiveContractStore
  19. def doPrune(beforeAndIncluding: CantonTimestamp, lastPruning: Option[CantonTimestamp])(implicit traceContext: TraceContext): Future[Int]

    Deletes all entries about archived contracts whose status hasn't changed after the timestamp.

    Deletes all entries about archived contracts whose status hasn't changed after the timestamp.

    The caller must ensure that the given timestamp is at most the one of the clean cursor in the com.digitalasset.canton.participant.protocol.RequestJournal

    returns

    the approximate number of pruned rows, used to adjust the pruning windows to reach optimal batch sizes

    Definition Classes
    DbActiveContractStoreActiveContractStorePrunableByTime
  20. val domainId: IndexedDomain
    Attributes
    protected[this]
    Definition Classes
    DbActiveContractStoreDbPrunableByTimeDomain
  21. implicit val ec: ExecutionContext
  22. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  23. def equals(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef → Any
  24. implicit def errorLoggingContext(implicit traceContext: TraceContext): ErrorLoggingContext
    Attributes
    protected
    Definition Classes
    NamedLogging
  25. def fetchState(id: LfContractId)(implicit traceContext: TraceContext): Future[Option[StateChange[Status]]]

    Short-hand for fetchStates for a single identifier

    Short-hand for fetchStates for a single identifier

    Definition Classes
    ConflictDetectionStore
  26. def fetchStates(contractIds: Iterable[LfContractId])(implicit traceContext: TraceContext): Future[Map[LfContractId, ContractState]]

    Returns the latest com.digitalasset.canton.participant.store.ActiveContractStore.Status for the given contract IDs along with its com.digitalasset.canton.participant.util.TimeOfChange.

    Returns the latest com.digitalasset.canton.participant.store.ActiveContractStore.Status for the given contract IDs along with its com.digitalasset.canton.participant.util.TimeOfChange.

    This method is used by the protocol processors for conflict detection. In-flight transactions may have changesets not yet written to the ACS datastore. Since only the ConflictDetector tracks in-flight changesets, this method cannot be used as a source of valid data to other components.

    If a contract is created or transferred-in and archived or transferred-out at the same com.digitalasset.canton.participant.util.TimeOfChange, the contract is ActiveContractStore.Archived or ActiveContractStore.TransferredAway. A contract cannot be archived and transferred out at the same timestamp.

    returns

    The map from contracts in contractIds in the store to their latest state. Nonexistent contracts are excluded from the map.

    Definition Classes
    DbActiveContractStoreActiveContractStoreConflictDetectionStore
    See also

    ActiveContractSnapshot!.snapshot

  27. final def getClass(): Class[_ <: AnyRef]
    Definition Classes
    AnyRef → Any
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  28. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  29. def internalPerformUnlessClosingF[A](name: String)(f: => Future[A])(implicit ec: ExecutionContext, traceContext: TraceContext): UnlessShutdown[Future[A]]
    Attributes
    protected
    Definition Classes
    PerformUnlessClosing
  30. def isClosing: Boolean

    Check whether we're closing.

    Check whether we're closing. Susceptible to race conditions; unless you're using using this as a flag to the retry lib or you really know what you're doing, prefer performUnlessClosing and friends.

    Definition Classes
    OnShutdownRunner
  31. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  32. def keepTrackOfOpenFutures: Boolean

    track running futures on shutdown

    track running futures on shutdown

    set to true to get detailed information about all futures that did not complete during shutdown. if set to false, we don't do anything.

    Attributes
    protected
    Definition Classes
    PerformUnlessClosing
  33. def kind: String
    Attributes
    protected
    Definition Classes
    ActiveContractStorePrunableByTime
  34. def logger: TracedLogger
    Attributes
    protected
    Definition Classes
    NamedLogging
  35. val loggerFactory: NamedLoggerFactory
    Attributes
    protected
    Definition Classes
    DbActiveContractStoreNamedLogging
  36. def markContractActive(contract: (LfContractId, TransferCounterO), toc: TimeOfChange)(implicit traceContext: TraceContext): CheckedT[Future, AcsError, AcsWarning, Unit]

    Shorthand for markContractsActive(Seq(contractId), toc)

    Shorthand for markContractsActive(Seq(contractId), toc)

    Definition Classes
    ActiveContractStore
  37. def markContractsActive(contracts: Seq[(LfContractId, TransferCounterO)], toc: TimeOfChange)(implicit traceContext: TraceContext): CheckedT[Future, AcsError, AcsWarning, Unit]

    Marks the given contracts as active from timestamp (inclusive) onwards.

    Marks the given contracts as active from timestamp (inclusive) onwards.

    contracts

    The contracts represented as a tuple of contract id and reassignment counter

    toc

    The time of change consisting of

    • The request counter of the confirmation request that created the contracts
    • The timestamp of the confirmation request that created the contracts.
    returns

    The future completes when all contract states have been updated. The following irregularities are reported for each contract:

    Definition Classes
    DbActiveContractStoreActiveContractStore
  38. def maxSleepMillis: Long

    How often to poll to check that all tasks have completed.

    How often to poll to check that all tasks have completed.

    Attributes
    protected
    Definition Classes
    PerformUnlessClosing
  39. def mkPromise[A](description: String, futureSupervisor: FutureSupervisor, logAfter: Duration = 10.seconds, logLevel: Level = Level.DEBUG)(implicit elc: ErrorLoggingContext, ec: ExecutionContext): PromiseUnlessShutdown[A]

    Use this method to create a PromiseUnlessShutdown that will automatically be cancelled when the close context is closed.

    Use this method to create a PromiseUnlessShutdown that will automatically be cancelled when the close context is closed. This allows proper clean up of stray promises when the node is transitioning to a passive state.

    Note: you should *not* invoke success on the returned promise but rather use trySuccess. The reason is that the call to success may fail in case of shutdown.

    Definition Classes
    PromiseUnlessShutdownFactory
  40. implicit def namedLoggingContext(implicit traceContext: TraceContext): NamedLoggingContext
    Attributes
    protected
    Definition Classes
    NamedLogging
  41. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  42. def noTracingLogger: Logger
    Attributes
    protected
    Definition Classes
    NamedLogging
  43. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  44. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  45. def onCloseFailure(e: Throwable): Unit
    Attributes
    protected
    Definition Classes
    PerformUnlessClosing
  46. def onClosed(): Unit
    Attributes
    protected
    Definition Classes
    PerformUnlessClosing
  47. final def onFirstClose(): Unit

    Blocks until all earlier tasks have completed and then prevents further tasks from being run.

    Blocks until all earlier tasks have completed and then prevents further tasks from being run.

    Definition Classes
    PerformUnlessClosingOnShutdownRunner
    Annotations
    @SuppressWarnings()
  48. def packageUsage(pkg: PackageId, contractStore: ContractStore)(implicit traceContext: TraceContext): Future[Option[LfContractId]]

    Returns Some(contractId) if an active contract belonging to package pkg exists, otherwise returns None.

    Returns Some(contractId) if an active contract belonging to package pkg exists, otherwise returns None. The returned contractId may be any active contract from package pkg. The most recent contract state is used.

    Definition Classes
    DbActiveContractStoreActiveContractSnapshot
  49. val partitionColumn: String
    Attributes
    protected[this]
    Definition Classes
    DbPrunableByTimeDomainDbPrunableByTime
  50. def partitionKey: IndexedDomain
    Attributes
    protected[this]
    Definition Classes
    DbPrunableByTimeDomainDbPrunableByTime
  51. def performUnlessClosing[A](name: String)(f: => A)(implicit traceContext: TraceContext): UnlessShutdown[A]

    Performs the task given by f unless a shutdown has been initiated.

    Performs the task given by f unless a shutdown has been initiated. The shutdown will only begin after f completes, but other tasks may execute concurrently with f, if started using this function, or one of the other variants (performUnlessClosingF and performUnlessClosingEitherT). The tasks are assumed to take less than closingTimeout to complete.

    DO NOT CALL this.close as part of f, because it will result in a deadlock.

    f

    The task to perform

    returns

    scala.None$ if a shutdown has been initiated. Otherwise the result of the task.

    Definition Classes
    PerformUnlessClosing
  52. def performUnlessClosingCheckedT[A, N, R](name: String, onClosing: => Checked[A, N, R])(etf: => CheckedT[Future, A, N, R])(implicit ec: ExecutionContext, traceContext: TraceContext): CheckedT[Future, A, N, R]
    Definition Classes
    PerformUnlessClosing
  53. def performUnlessClosingEitherT[E, R](name: String, onClosing: => E)(etf: => EitherT[Future, E, R])(implicit ec: ExecutionContext, traceContext: TraceContext): EitherT[Future, E, R]

    Performs the EitherT[Future] given by etf unless a shutdown has been initiated, in which case the provided error is returned instead.

    Performs the EitherT[Future] given by etf unless a shutdown has been initiated, in which case the provided error is returned instead. Both etf and the error are lazy; etf is only evaluated if there is no shutdown, the error only if we're shutting down. The shutdown will only begin after etf completes, but other tasks may execute concurrently with etf, if started using this function, or one of the other variants (performUnlessClosing and performUnlessClosingF). The tasks are assumed to take less than closingTimeout to complete.

    DO NOT CALL this.close as part of etf, because it will result in a deadlock.

    etf

    The task to perform

    Definition Classes
    PerformUnlessClosing
  54. def performUnlessClosingEitherTF[E, R](name: String, onClosing: => E)(etf: => EitherT[Future, E, Future[R]])(implicit ec: ExecutionContext, traceContext: TraceContext): EitherT[Future, E, Future[R]]
    Definition Classes
    PerformUnlessClosing
  55. def performUnlessClosingEitherU[E, R](name: String)(etf: => EitherT[Future, E, R])(implicit ec: ExecutionContext, traceContext: TraceContext): EitherT[FutureUnlessShutdown, E, R]
    Definition Classes
    PerformUnlessClosing
  56. def performUnlessClosingEitherUSF[E, R](name: String)(etf: => EitherT[FutureUnlessShutdown, E, R])(implicit ec: ExecutionContext, traceContext: TraceContext): EitherT[FutureUnlessShutdown, E, R]
    Definition Classes
    PerformUnlessClosing
  57. def performUnlessClosingF[A](name: String)(f: => Future[A])(implicit ec: ExecutionContext, traceContext: TraceContext): FutureUnlessShutdown[A]

    Performs the Future given by f unless a shutdown has been initiated.

    Performs the Future given by f unless a shutdown has been initiated. The future is lazy and not evaluated during shutdown. The shutdown will only begin after f completes, but other tasks may execute concurrently with f, if started using this function, or one of the other variants (performUnlessClosing and performUnlessClosingEitherT). The tasks are assumed to take less than closingTimeout to complete.

    DO NOT CALL this.close as part of f, because it will result in a deadlock.

    f

    The task to perform

    returns

    The future completes with com.digitalasset.canton.lifecycle.UnlessShutdown.AbortedDueToShutdown if a shutdown has been initiated. Otherwise the result of the task wrapped in com.digitalasset.canton.lifecycle.UnlessShutdown.Outcome.

    Definition Classes
    PerformUnlessClosing
  58. def performUnlessClosingUSF[A](name: String)(f: => FutureUnlessShutdown[A])(implicit ec: ExecutionContext, traceContext: TraceContext): FutureUnlessShutdown[A]
    Definition Classes
    PerformUnlessClosing
  59. val processingTime: TimedLoadGauge
    Attributes
    protected
    Definition Classes
    DbActiveContractStoreDbPrunableByTime
  60. final def prune(limit: CantonTimestamp)(implicit errorLoggingContext: ErrorLoggingContext, closeContext: CloseContext): Future[Unit]

    Prune all unnecessary data relating to events before the given timestamp.

    Prune all unnecessary data relating to events before the given timestamp.

    The meaning of "unnecessary", and whether the limit is inclusive or exclusive both depend on the particular store. The store must implement the actual pruning logic in the doPrune method.

    Definition Classes
    PrunableByTime
  61. def pruningStatus(implicit traceContext: TraceContext): Future[Option[PruningStatus]]

    Returns the latest timestamp at which pruning was started or completed.

    Returns the latest timestamp at which pruning was started or completed. For com.digitalasset.canton.pruning.PruningPhase.Started, it is guaranteed that no pruning has been run on the store after the returned timestamp. For com.digitalasset.canton.pruning.PruningPhase.Completed, it is guaranteed that the store is pruned at least up to the returned timestamp (inclusive). That is, another pruning with the returned timestamp (or earlier) has no effect on the store. Returns scala.None$ if no pruning has ever been started on the store.

    Definition Classes
    DbPrunableByTimePrunableByTime
  62. val pruning_status_table: String

    The table name to store the pruning timestamp in.

    The table name to store the pruning timestamp in. The table must define the following fields:

    Attributes
    protected[this]
    Definition Classes
    DbActiveContractStoreDbPrunableByTime
  63. def runOnShutdown[T](task: RunOnShutdown)(implicit traceContext: TraceContext): Long

    Same as runOnShutdown_ but returns a token that allows you to remove the task explicitly from being run using cancelShutdownTask

    Same as runOnShutdown_ but returns a token that allows you to remove the task explicitly from being run using cancelShutdownTask

    Definition Classes
    OnShutdownRunner
  64. def runOnShutdown_[T](task: RunOnShutdown)(implicit traceContext: TraceContext): Unit

    Register a task to run when shutdown is initiated.

    Register a task to run when shutdown is initiated.

    You can use this for example to register tasks that cancel long-running computations, whose termination you can then wait for in "closeAsync".

    Definition Classes
    OnShutdownRunner
  65. def runStateChanged(waitingState: Boolean = false): Unit
    Attributes
    protected
    Definition Classes
    OnShutdownRunner
    Annotations
    @VisibleForTesting()
  66. implicit val setParameterDiscriminator: SetParameter[IndexedDomain]
    Attributes
    protected[this]
    Definition Classes
    DbPrunableByTimeDomainDbPrunableByTime
  67. def snapshot(rc: RequestCounter)(implicit traceContext: TraceContext): Future[SortedMap[LfContractId, (RequestCounter, TransferCounterO)]]

    Returns all contracts that were active right after the given request counter, and when the contract became active for the last time before or at the given request counter.

    Returns all contracts that were active right after the given request counter, and when the contract became active for the last time before or at the given request counter.

    rc

    The request counter at which the snapshot shall be taken. Must be before the request counter that corresponds to the head cursor in the com.digitalasset.canton.participant.protocol.RequestJournal for the state com.digitalasset.canton.participant.protocol.RequestJournal.RequestState.Clean. If this precondition is violated, the returned snapshot may be inconsistent, i.e., it may omit some contracts that were ActiveContractStore.Active at the given counter and it may include contracts that were actually ActiveContractStore.Archived or ActiveContractStore.TransferredAway.

    returns

    A map from contracts to the latest request counter (no later than the given rc) when they became active again. It contains exactly those contracts that were active right after the given request counter. If a contract is created or transferred-in and archived or transferred-out at the same request counter, it does not show up in any snapshot. The map is sorted by cats.kernel.Order[com.digitalasset.canton.protocol.LfContractId].

    Definition Classes
    DbActiveContractStoreActiveContractSnapshot
  68. def snapshot(timestamp: CantonTimestamp)(implicit traceContext: TraceContext): Future[SortedMap[LfContractId, (CantonTimestamp, TransferCounterO)]]

    Returns all contracts that were active right after the given timestamp, and when the contract became active for the last time before or at the given timestamp.

    Returns all contracts that were active right after the given timestamp, and when the contract became active for the last time before or at the given timestamp.

    timestamp

    The timestamp at which the snapshot shall be taken. Must be before the timestamp that corresponds to the head cursor in the com.digitalasset.canton.participant.protocol.RequestJournal for the state com.digitalasset.canton.participant.protocol.RequestJournal.RequestState.Clean. If this precondition is violated, the returned snapshot may be inconsistent, i.e., it may omit some contracts that were ActiveContractStore.Active at the given time and it may include contracts that were actually ActiveContractStore.Archived or ActiveContractStore.TransferredAway.

    returns

    A map from contracts to the latest timestamp (no later than the given timestamp) when they became active again. It contains exactly those contracts that were active right after the given timestamp. If a contract is created or transferred-in and archived or transferred-out at the same timestamp, it does not show up in any snapshot. The map is sorted by cats.kernel.Order[com.digitalasset.canton.protocol.LfContractId].

    Definition Classes
    DbActiveContractStoreActiveContractSnapshot
  69. val storage: DbStorage
    Attributes
    protected
    Definition Classes
    DbActiveContractStoreDbStore
  70. final def synchronized[T0](arg0: => T0): T0
    Definition Classes
    AnyRef
  71. val timeouts: ProcessingTimeout
    Attributes
    protected
    Definition Classes
    DbActiveContractStoreFlagCloseable
  72. def toString(): String
    Definition Classes
    AnyRef → Any
  73. def transferInContract(contractId: LfContractId, toc: TimeOfChange, sourceDomain: SourceDomainId, transferCounter: TransferCounterO)(implicit traceContext: TraceContext): CheckedT[Future, AcsError, AcsWarning, Unit]
    Definition Classes
    ActiveContractStore
  74. def transferInContracts(transferIns: Seq[(LfContractId, SourceDomainId, TransferCounterO, TimeOfChange)])(implicit traceContext: TraceContext): CheckedT[Future, AcsError, AcsWarning, Unit]

    Marks the given contracts as transferred in from toc's timestamp (inclusive) onwards.

    Marks the given contracts as transferred in from toc's timestamp (inclusive) onwards.

    transferIns

    The contract IDs to transfer-in, each with its source domain, transfer counter and time of change.

    returns

    The future completes when the contract states have been updated. The following irregularities are reported:

    Definition Classes
    DbActiveContractStoreActiveContractStore
  75. def transferOutContract(contractId: LfContractId, toc: TimeOfChange, targetDomain: TargetDomainId, transferCounter: TransferCounterO)(implicit traceContext: TraceContext): CheckedT[Future, AcsError, AcsWarning, Unit]
    Definition Classes
    ActiveContractStore
  76. def transferOutContracts(transferOuts: Seq[(LfContractId, TargetDomainId, TransferCounterO, TimeOfChange)])(implicit traceContext: TraceContext): CheckedT[Future, AcsError, AcsWarning, Unit]

    Marks the given contracts as ActiveContractStore.TransferredAway from toc's timestamp (inclusive) onwards.

    Marks the given contracts as ActiveContractStore.TransferredAway from toc's timestamp (inclusive) onwards.

    transferOuts

    The contract IDs to transfer out, each with its target domain, transfer counter and time of change.

    returns

    The future completes when the contract state has been updated. The following irregularities are reported:

    Definition Classes
    DbActiveContractStoreActiveContractStore
  77. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  78. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException]) @native()
  79. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])

Deprecated Value Members

  1. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.Throwable]) @Deprecated @Deprecated
    Deprecated

Inherited from DbPrunableByTimeDomain

Inherited from DbStore

Inherited from HasCloseContext

Inherited from NamedLogging

Inherited from FlagCloseable

Inherited from PerformUnlessClosing

Inherited from OnShutdownRunner

Inherited from AutoCloseable

Inherited from ActiveContractStore

Inherited from PrunableByTime

Inherited from ActiveContractSnapshot

Inherited from AnyRef

Inherited from Any

Ungrouped