Packages

trait TransferProcessingSteps[SubmissionParam, SubmissionResult, RequestViewType <: ViewType, Result <: SignedProtocolMessageContent] extends ProcessingSteps[SubmissionParam, SubmissionResult, RequestViewType, Result, TransferProcessorError] with NamedLogging

Linear Supertypes
NamedLogging, ProcessingSteps[SubmissionParam, SubmissionResult, RequestViewType, Result, TransferProcessorError], AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. TransferProcessingSteps
  2. NamedLogging
  3. ProcessingSteps
  4. AnyRef
  5. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. Protected

Type Members

  1. case class CheckActivenessAndWritePendingContracts(activenessSet: ActivenessSet, pendingContracts: Seq[WithTransactionId[SerializableContract]], pendingDataAndResponseArgs: PendingDataAndResponseArgs) extends Product with Serializable

    Phase 3

    Phase 3

    activenessSet

    The activeness set for the activeness check

    pendingContracts

    The pending contracts to be added to the com.digitalasset.canton.participant.store.StoredContractManager, along with the com.digitalasset.canton.protocol.TransactionId that created the contract

    pendingDataAndResponseArgs

    The implementation-specific arguments needed to create the pending data and response

    Definition Classes
    ProcessingSteps
  2. case class CommitAndStoreContractsAndPublishEvent(commitSet: Option[Future[CommitSet]], contractsToBeStored: Set[LfContractId], maybeEvent: Option[TimestampedEvent], update: Option[CausalityUpdate]) extends Product with Serializable

    Phase 7, step 3:

    Phase 7, step 3:

    commitSet

    scala.None$ if the request should be rejected scala.Some$ a future that will produce the commit set for updating the active contract store

    contractsToBeStored

    The contracts to be persisted to the contract store. Must be a subset of the contracts produced in Phase 3, step 2 in CheckActivenessAndWritePendingContracts.

    maybeEvent

    The event to be published via the com.digitalasset.canton.participant.event.RecordOrderPublisher

    Definition Classes
    ProcessingSteps
  3. case class DecryptedViews(views: Seq[WithRecipients[DecryptedView]], decryptionErrors: Seq[EncryptedViewMessageDecryptionError[RequestViewType]]) extends Product with Serializable

    Phase 3:

    Phase 3:

    views

    The successfully decrypted views

    decryptionErrors

    The decryption errors while trying to decrypt the views

    Definition Classes
    ProcessingSteps
  4. trait PreparedBatch extends AnyRef

    The actual batch to be sent for a TrackedSubmission

    The actual batch to be sent for a TrackedSubmission

    Definition Classes
    ProcessingSteps
  5. case class StorePendingDataAndSendResponseAndCreateTimeout(pendingData: PendingRequestData, mediatorResponses: Seq[(MediatorResponse, Recipients)], causalityMessages: Seq[(CausalityMessage, Recipients)], rejectionArgs: RejectionArgs) extends Product with Serializable

    Phase 3:

    Phase 3:

    pendingData

    The PendingRequestData to be stored until Phase 7

    mediatorResponses

    The responses to be sent to the mediator

    rejectionArgs

    The implementation-specific arguments needed to create a rejection event on timeout

    Definition Classes
    ProcessingSteps
  6. sealed trait Submission extends AnyRef
    Definition Classes
    ProcessingSteps
  7. trait TrackedSubmission extends Submission

    Submission to be tracked in-flight and with deduplication.

    Submission to be tracked in-flight and with deduplication.

    The actual batch to be sent is computed only later by TrackedSubmission.prepareBatch so that tracking information (e.g., the chosen deduplication period) can be incorporated into the batch.

    Definition Classes
    ProcessingSteps
  8. trait UntrackedSubmission extends Submission

    Submission to be sent off without tracking the in-flight submission and without deduplication.

    Submission to be sent off without tracking the in-flight submission and without deduplication.

    Definition Classes
    ProcessingSteps
  9. type DecryptedView = RequestViewType.View

    The type of decrypted view trees

    The type of decrypted view trees

    Definition Classes
    ProcessingSteps
  10. abstract type PendingDataAndResponseArgs

    The type of data needed to generate the pending data and response in constructPendingDataAndResponse.

    The type of data needed to generate the pending data and response in constructPendingDataAndResponse. The data is created by decryptViews

    Definition Classes
    ProcessingSteps
  11. abstract type PendingRequestData <: ProcessingSteps.PendingRequestData

    The type of data stored after request processing to make it available for result processing

    The type of data stored after request processing to make it available for result processing

    Definition Classes
    ProcessingSteps
  12. type PendingSubmissionData = PendingTransferSubmission

    The data stored for submissions that have been sent out, if any

    The data stored for submissions that have been sent out, if any

    Definition Classes
    TransferProcessingStepsProcessingSteps
  13. type PendingSubmissionId = RootHash

    The type used for look-ups into the PendingSubmissions

    The type used for look-ups into the PendingSubmissions

    Definition Classes
    TransferProcessingStepsProcessingSteps
  14. type PendingSubmissions = Map[RootHash, PendingTransferSubmission]

    A store of data on submissions that have been sent out, if any

    A store of data on submissions that have been sent out, if any

    Definition Classes
    TransferProcessingStepsProcessingSteps
  15. abstract type RejectionArgs

    The type of data needed to create a rejection event in createRejectionEvent.

    The type of data needed to create a rejection event in createRejectionEvent. Created by constructPendingDataAndResponse

    Definition Classes
    ProcessingSteps
  16. type RequestBatch = RequestAndRootHashMessage[OpenEnvelope[EncryptedViewMessage[RequestViewType]]]

    The type of request messages

    The type of request messages

    Definition Classes
    ProcessingSteps
  17. type RequestError = TransferProcessorError

    The type of errors that can occur during request processing

    The type of errors that can occur during request processing

    Definition Classes
    TransferProcessingStepsProcessingSteps
  18. type ResultError = TransferProcessorError

    The type of errors that can occur during result processing

    The type of errors that can occur during result processing

    Definition Classes
    TransferProcessingStepsProcessingSteps
  19. abstract type SubmissionResultArgs

    The type of data needed to generate the submission result in createSubmissionResult.

    The type of data needed to generate the submission result in createSubmissionResult. The data is created by updatePendingSubmissions.

    Definition Classes
    ProcessingSteps
  20. type SubmissionSendError = TransferProcessorError

    The submission errors that can occur during sending the batch to the sequencer and updating the pending submission map.

    The submission errors that can occur during sending the batch to the sequencer and updating the pending submission map.

    Definition Classes
    TransferProcessingStepsProcessingSteps
  21. case class TransferSubmission(batch: Batch[DefaultOpenEnvelope], pendingSubmissionId: PendingSubmissionId) extends UntrackedSubmission with Product with Serializable

Abstract Value Members

  1. abstract def computeActivenessSetAndPendingContracts(ts: CantonTimestamp, rc: RequestCounter, sc: SequencerCounter, decryptedViews: NonEmptyList[WithRecipients[DecryptedView]], malformedPayloads: Seq[MalformedPayload], snapshot: DomainSnapshotSyncCryptoApi)(implicit traceContext: TraceContext): EitherT[Future, RequestError, CheckActivenessAndWritePendingContracts]

    Phase 3, step 2 (some good views):

    Phase 3, step 2 (some good views):

    ts

    The timestamp of the request

    rc

    The com.digitalasset.canton.participant.RequestCounter of the request

    sc

    The com.digitalasset.canton.SequencerCounter of the request

    decryptedViews

    The decrypted views from step 1 with the right root hash

    malformedPayloads

    The decryption errors and decrypted views with a wrong root hash

    snapshot

    Snapshot of the topology state at the request timestamp

    returns

    The activeness set and the pending contracts to add to the com.digitalasset.canton.participant.store.StoredContractManager, and the arguments for step 2.

    Definition Classes
    ProcessingSteps
  2. abstract def constructPendingDataAndResponse(pendingDataAndResponseArgs: PendingDataAndResponseArgs, transferLookup: TransferLookup, contractLookup: ContractLookup, causalityLookup: SingleDomainCausalTracker, activenessResultFuture: Future[ActivenessResult], pendingCursor: Future[Unit], mediatorId: MediatorId)(implicit traceContext: TraceContext): EitherT[Future, RequestError, StorePendingDataAndSendResponseAndCreateTimeout]

    Phase 3, step 3:

    Phase 3, step 3:

    pendingDataAndResponseArgs

    Implementation-specific data passed from decryptViews

    transferLookup

    Read-only interface of the com.digitalasset.canton.participant.store.memory.TransferCache

    contractLookup

    Read-only interface to the com.digitalasset.canton.participant.store.StoredContractManager, which includes the pending contracts

    activenessResultFuture

    Future of the result of the activeness check<

    pendingCursor

    Future to complete when the com.digitalasset.canton.participant.protocol.RequestJournal's cursor for the com.digitalasset.canton.participant.protocol.RequestJournal.RequestState.Pending reaching the current request. Block on this future to ensure that all earlier contract store writes are visible.

    mediatorId

    The mediator that handles this request

    returns

    Returns the PendingRequestData to be stored until Phase 7 and the responses to be sent to the mediator.

    Definition Classes
    ProcessingSteps
  3. abstract def createSubmissionResult(deliver: Deliver[Envelope[_]], submissionResultArgs: SubmissionResultArgs): SubmissionResult

    Phase 1, step 3:

    Phase 1, step 3:

    Definition Classes
    ProcessingSteps
  4. abstract def decryptTree(snapshot: DomainSnapshotSyncCryptoApi)(envelope: OpenEnvelope[EncryptedViewMessage[RequestViewType]]): EitherT[Future, EncryptedViewMessageDecryptionError[RequestViewType], WithRecipients[DecryptedView]]
    Attributes
    protected
  5. implicit abstract def ec: ExecutionContext
    Attributes
    protected
  6. abstract def engine: DAMLe
    Attributes
    protected
  7. abstract def getCommitSetAndContractsToBeStoredAndEvent(event: SignedContent[Deliver[DefaultOpenEnvelope]], result: Either[MalformedMediatorRequestResult, Result], pendingRequestData: PendingRequestData, pendingSubmissions: PendingSubmissions, tracker: SingleDomainCausalTracker, hashOps: HashOps)(implicit traceContext: TraceContext): EitherT[Future, ResultError, CommitAndStoreContractsAndPublishEvent]

    Phase 7, step 2:

    Phase 7, step 2:

    event

    The signed com.digitalasset.canton.sequencing.protocol.Deliver event containing the mediator result. It is ensured that the event contains exactly one com.digitalasset.canton.protocol.messages.MediatorResult

    result

    The unpacked mediator result that is contained in the event

    pendingRequestData

    The PendingRequestData produced in Phase 3

    pendingSubmissions

    The data stored on submissions in the PendingSubmissions

    returns

    The com.digitalasset.canton.participant.protocol.conflictdetection.CommitSet, the contracts from Phase 3 to be persisted to the contract store, and the event to be published

    Definition Classes
    ProcessingSteps
  8. abstract def loggerFactory: NamedLoggerFactory
    Attributes
    protected
    Definition Classes
    NamedLogging
  9. abstract val participantId: ParticipantId
  10. abstract def pendingRequestMap: (SyncDomainEphemeralState) => Map[RequestId, PendingRequestDataOrReplayData[PendingRequestData]]

    Selector for the storage slot for PendingRequestData

    Selector for the storage slot for PendingRequestData

    Definition Classes
    ProcessingSteps
  11. abstract def pendingSubmissions(state: SyncDomainEphemeralState): PendingSubmissions

    Selector to get the PendingSubmissions, if any

    Selector to get the PendingSubmissions, if any

    Definition Classes
    ProcessingSteps
  12. abstract def prepareSubmission(param: SubmissionParam, mediatorId: MediatorId, ephemeralState: SyncDomainEphemeralStateLookup, recentSnapshot: DomainSnapshotSyncCryptoApi)(implicit traceContext: TraceContext): EitherT[FutureUnlessShutdown, TransferProcessorError, Submission]

    Phase 1, step 1:

    Phase 1, step 1:

    param

    The parameter object encapsulating the parameters of the submit method

    mediatorId

    The mediator ID to use for this submission

    ephemeralState

    Read-only access to the com.digitalasset.canton.participant.store.SyncDomainEphemeralState

    recentSnapshot

    A recent snapshot of the topology state to be used for submission

    Definition Classes
    ProcessingSteps
  13. abstract def requestKind: String

    The kind of request, used for logging and error reporting

    The kind of request, used for logging and error reporting

    Definition Classes
    ProcessingSteps
  14. abstract def submissionDescription(param: SubmissionParam): String

    Extract a description for a submission, used for logging and error reporting

    Extract a description for a submission, used for logging and error reporting

    Definition Classes
    ProcessingSteps
  15. abstract def submissionIdOfPendingRequest(pendingData: PendingRequestData): PendingSubmissionId

    Extract the submission ID that corresponds to a pending request, if any

    Extract the submission ID that corresponds to a pending request, if any

    Definition Classes
    ProcessingSteps
  16. abstract def updatePendingSubmissions(pendingSubmissions: PendingSubmissions, submissionParam: SubmissionParam, pendingSubmissionId: PendingSubmissionId): EitherT[Future, SubmissionSendError, SubmissionResultArgs]

    Phase 1, step 2:

    Phase 1, step 2:

    pendingSubmissions

    Stateful store to be updated with data on the pending submission

    submissionParam

    Implementation-specific details on the submission, used for logging

    pendingSubmissionId

    The key used for updates to the pendingSubmissions

    Definition Classes
    ProcessingSteps

Concrete Value Members

  1. object DecryptedViews extends Serializable
    Definition Classes
    ProcessingSteps
  2. final def !=(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  3. final def ##: Int
    Definition Classes
    AnyRef → Any
  4. final def ==(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  5. val alarmer: LoggingAlarmStreamer
    Attributes
    protected
  6. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  7. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.CloneNotSupportedException]) @native() @HotSpotIntrinsicCandidate()
  8. def createRejectionEvent(rejectionArgs: RejectionArgs)(implicit traceContext: TraceContext): Either[TransferProcessorError, Option[TimestampedEvent]]

    Phase 3, step 4:

    Phase 3, step 4:

    rejectionArgs

    The implementation-specific information needed for the creation of the rejection event

    Definition Classes
    TransferProcessingStepsProcessingSteps
  9. def decryptViews(batch: NonEmptyList[OpenEnvelope[EncryptedViewMessage[RequestViewType]]], snapshot: DomainSnapshotSyncCryptoApi)(implicit traceContext: TraceContext): EitherT[Future, TransferProcessorError, DecryptedViews]

    Phase 3, step 1:

    Phase 3, step 1:

    batch

    The batch of messages in the request to be processed

    snapshot

    Snapshot of the topology state at the request timestamp

    returns

    The decrypted views and the errors encountered during decryption

    Definition Classes
    TransferProcessingStepsProcessingSteps
  10. def embedNoMediatorError(error: NoMediatorError): TransferProcessorError

    Convert com.digitalasset.canton.participant.protocol.ProtocolProcessor.NoMediatorError into a submission error

  11. def embedRequestError(err: RequestProcessingError): TransferProcessorError

    Wrap an error in request processing from the generic request processor

    Wrap an error in request processing from the generic request processor

    Definition Classes
    TransferProcessingStepsProcessingSteps
  12. def embedResultError(err: ResultProcessingError): TransferProcessorError

    Wrap an error in result processing from the generic request processor

    Wrap an error in result processing from the generic request processor

    Definition Classes
    TransferProcessingStepsProcessingSteps
  13. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  14. def equals(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef → Any
  15. def eventAndSubmissionIdForInactiveMediator(ts: CantonTimestamp, rc: RequestCounter, sc: SequencerCounter, decryptedViews: NonEmptyList[WithRecipients[DecryptedView]])(implicit traceContext: TraceContext): (Option[TimestampedEvent], Option[PendingSubmissionId])

    Phase 3, step 2 (some good views, but the chosen mediator is inactive)

    Phase 3, step 2 (some good views, but the chosen mediator is inactive)

    ts

    The timestamp of the request

    rc

    The com.digitalasset.canton.participant.RequestCounter of the request

    sc

    The com.digitalasset.canton.SequencerCounter of the request

    decryptedViews

    The decrypted views from step 1 with the right root hash

    returns

    The optional rejection event to be published in the event log, and the optional submission ID corresponding to this request

    Definition Classes
    TransferProcessingStepsProcessingSteps
  16. final def getClass(): Class[_ <: AnyRef]
    Definition Classes
    AnyRef → Any
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  17. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  18. def hostedStakeholders(stakeholders: List[LfPartyId], snapshot: TopologySnapshot): Future[List[LfPartyId]]
    Attributes
    protected
  19. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  20. def logger: TracedLogger
    Attributes
    protected
    Definition Classes
    NamedLogging
  21. implicit def loggingContext(implicit traceContext: TraceContext): ErrorLoggingContext
    Attributes
    protected
    Definition Classes
    NamedLogging
  22. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  23. def noTracingLogger: Logger
    Attributes
    protected
    Definition Classes
    NamedLogging
  24. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  25. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  26. def pendingDataAndResponseArgsForMalformedPayloads(ts: CantonTimestamp, rc: RequestCounter, sc: SequencerCounter, malformedPayloads: Seq[MalformedPayload], snapshot: DomainSnapshotSyncCryptoApi): Either[RequestError, PendingDataAndResponseArgs]

    Phase 3, step 2 (only malformed payloads):

    Phase 3, step 2 (only malformed payloads):

    Called when no decrypted view has the right root hash.

    returns

    scala.Left$ aborts processing and scala.Right$ continues processing with an empty activeness set and no pending contracts

    Definition Classes
    TransferProcessingStepsProcessingSteps
  27. def performPendingSubmissionMapUpdate(pendingSubmissionMap: Map[RootHash, PendingTransferSubmission], transferId: Option[TransferId], submitterLf: LfPartyId, rootHash: RootHash): EitherT[Future, TransferProcessorError, PendingTransferSubmission]
    Attributes
    protected
  28. def postProcessResult(verdict: Verdict, pendingSubmission: PendingTransferSubmission)(implicit traceContext: TraceContext): Unit

    Phase 7, step 4:

    Phase 7, step 4:

    Called after the request reached the state com.digitalasset.canton.participant.protocol.RequestJournal.RequestState.Clean in the request journal, if the participant is the submitter. Also called if a timeout occurs with com.digitalasset.canton.protocol.messages.Verdict.Timeout.

    verdict

    The verdict on the request

    Definition Classes
    TransferProcessingStepsProcessingSteps
  29. def postProcessSubmissionForInactiveMediator(declaredMediator: MediatorId, ts: CantonTimestamp, pendingSubmission: PendingTransferSubmission)(implicit traceContext: TraceContext): Unit

    Phase 3, step 2 (submission where the chosen mediator is inactive)

    Phase 3, step 2 (submission where the chosen mediator is inactive)

    Called if the chosen mediator is inactive and eventAndSubmissionIdForInactiveMediator returned a submission ID that was pending.

    pendingSubmission

    The PendingSubmissionData for the submission ID returned by eventAndSubmissionIdForInactiveMediator

    Definition Classes
    TransferProcessingStepsProcessingSteps
    See also

    com.digitalasset.canton.participant.protocol.ProcessingSteps.postProcessResult

  30. def removePendingSubmission(pendingSubmissions: Map[RootHash, PendingTransferSubmission], pendingSubmissionId: RootHash): Option[PendingTransferSubmission]

    Phase 1, step 4; and Phase 7, step 1:

    Phase 1, step 4; and Phase 7, step 1:

    Remove the pending submission from the pending submissions. Called when sending the submission failed or did not lead to a result in time or a result has arrived for the request.

    Definition Classes
    TransferProcessingStepsProcessingSteps
  31. final def synchronized[T0](arg0: => T0): T0
    Definition Classes
    AnyRef
  32. def toString(): String
    Definition Classes
    AnyRef → Any
  33. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  34. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException]) @native()
  35. 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

Inherited from NamedLogging

Inherited from ProcessingSteps[SubmissionParam, SubmissionResult, RequestViewType, Result, TransferProcessorError]

Inherited from AnyRef

Inherited from Any

Ungrouped