class TransactionProcessingSteps extends ProcessingSteps[SubmissionParam, TransactionSubmitted, TransactionViewType, TransactionResultMessage, TransactionSubmissionError] with NamedLogging

The transaction processor that coordinates the Canton transaction protocol.

Annotations
@nowarn()
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. TransactionProcessingSteps
  2. NamedLogging
  3. ProcessingSteps
  4. AnyRef
  5. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. Protected

Instance Constructors

  1. new TransactionProcessingSteps(domainId: DomainId, participantId: ParticipantId, confirmationRequestFactory: ConfirmationRequestFactory, confirmationResponseFactory: ConfirmationResponseFactory, modelConformanceChecker: ModelConformanceChecker, staticDomainParameters: StaticDomainParameters, crypto: DomainSyncCryptoClient, contractStore: ContractStore, metrics: TransactionProcessingMetrics, serializableContractAuthenticator: SerializableContractAuthenticator, authenticationValidator: AuthenticationValidator, authorizationValidator: AuthorizationValidator, internalConsistencyChecker: InternalConsistencyChecker, loggerFactory: NamedLoggerFactory, futureSupervisor: FutureSupervisor)(implicit ec: ExecutionContext)

    participantId

    The participant id hosting the transaction processor.

Type Members

  1. case class CheckActivenessAndWritePendingContracts(activenessSet: ActivenessSet, pendingDataAndResponseArgs: PendingDataAndResponseArgs) extends Product with Serializable

    Phase 3

    Phase 3

    activenessSet

    The activeness set for the activeness check

    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: Seq[WithTransactionId[SerializableContract]], maybeEvent: Option[TimestampedEvent]) 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], Option[Signature])], decryptionErrors: Seq[EncryptedViewMessageError]) extends Product with Serializable

    Phase 3:

    Phase 3:

    views

    The successfully decrypted views and their signatures. Signatures are only present for top-level views (where the submitter metadata is not blinded)

    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: RequestType.PendingRequestData, mediatorResponses: Seq[(MediatorResponse, Recipients)], rejectionArgs: RejectionArgs) extends Product with Serializable

    Phase 3:

    Phase 3:

    pendingData

    The requestType.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 = View

    The type of decrypted view trees

    The type of decrypted view trees

    Definition Classes
    ProcessingSteps
  10. type FullView = data.ViewType.TransactionViewType.FullView
    Definition Classes
    ProcessingSteps
  11. type PendingDataAndResponseArgs = TransactionProcessingSteps.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
    TransactionProcessingStepsProcessingSteps
  12. type PendingSubmissionData = Nothing

    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
    TransactionProcessingStepsProcessingSteps
  13. type PendingSubmissionId = Unit

    The type used for look-ups into the PendingSubmissions

    The type used for look-ups into the PendingSubmissions

    Definition Classes
    TransactionProcessingStepsProcessingSteps
  14. type PendingSubmissions = Unit

    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
    TransactionProcessingStepsProcessingSteps
  15. type RejectionArgs = TransactionProcessingSteps.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
    TransactionProcessingStepsProcessingSteps
  16. type RequestBatch = RequestAndRootHashMessage[OpenEnvelope[EncryptedViewMessage[TransactionViewType]]]

    The type of request messages

    The type of request messages

    Definition Classes
    ProcessingSteps
  17. type RequestError = TransactionProcessorError

    The type of errors that can occur during request processing

    The type of errors that can occur during request processing

    Definition Classes
    TransactionProcessingStepsProcessingSteps
  18. type RequestType = Transaction.type

    The type of the request (transaction, transfer-out, transfer-in)

    The type of the request (transaction, transfer-out, transfer-in)

    Definition Classes
    TransactionProcessingStepsProcessingSteps
  19. type ResultError = TransactionProcessorError

    The type of errors that can occur during result processing

    The type of errors that can occur during result processing

    Definition Classes
    TransactionProcessingStepsProcessingSteps
  20. type SubmissionResultArgs = Unit

    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
    TransactionProcessingStepsProcessingSteps
  21. type SubmissionSendError = Error

    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
    TransactionProcessingStepsProcessingSteps

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. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  6. def authenticateInputContracts(pendingDataAndResponseArgs: PendingDataAndResponseArgs)(implicit traceContext: TraceContext): EitherT[Future, TransactionProcessorError, Unit]
  7. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.CloneNotSupportedException]) @native() @HotSpotIntrinsicCandidate()
  8. def computeActivenessSetAndPendingContracts(ts: CantonTimestamp, rc: RequestCounter, sc: SequencerCounter, fullViewsWithSignatures: NonEmpty[Seq[(WithRecipients[FullView], Option[Signature])]], malformedPayloads: Seq[MalformedPayload], snapshot: DomainSnapshotSyncCryptoApi, mediator: MediatorRef)(implicit traceContext: TraceContext): EitherT[Future, TransactionProcessorError, 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.RequestCounter of the request

    sc

    The com.digitalasset.canton.SequencerCounter of the request

    fullViewsWithSignatures

    The decrypted views from step 1 with the right root hash and their respective signatures

    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 contracts to store with the com.digitalasset.canton.participant.store.ContractStore in Phase 7, and the arguments for step 2.

    Definition Classes
    TransactionProcessingStepsProcessingSteps
  9. def computeFullViews(decryptedViewsWithSignatures: Seq[(WithRecipients[DecryptedView], Option[Signature])]): (Seq[(WithRecipients[FullView], Option[Signature])], Seq[MalformedPayload])

    Converts the decrypted (possible light-weight) view trees to the corresponding full view trees.

    Converts the decrypted (possible light-weight) view trees to the corresponding full view trees. Views that cannot be converted are mapped to ProtocolProcessor.MalformedPayload errors.

    Definition Classes
    TransactionProcessingStepsProcessingSteps
  10. def constructPendingDataAndResponse(pendingDataAndResponseArgs: PendingDataAndResponseArgs, transferLookup: TransferLookup, contractLookup: ContractLookup, activenessResultFuture: FutureUnlessShutdown[ActivenessResult], mediator: MediatorRef, freshOwnTimelyTx: Boolean)(implicit traceContext: TraceContext): EitherT[FutureUnlessShutdown, TransactionProcessorError, StorePendingDataAndSendResponseAndCreateTimeout]

    Phase 3, step 3: Yields the pending data and mediator responses for the case that at least one payload is well-formed.

    Phase 3, step 3: Yields the pending data and mediator responses for the case that at least one payload is well-formed.

    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.ContractStore

    activenessResultFuture

    Future of the result of the activeness check<

    returns

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

    Definition Classes
    TransactionProcessingStepsProcessingSteps
  11. def constructResponsesForMalformedPayloads(requestId: RequestId, malformedPayloads: Seq[MalformedPayload])(implicit traceContext: TraceContext): Seq[MediatorResponse]

    Phase 3: Yields the mediator responses (i.e.

    Phase 3: Yields the mediator responses (i.e. rejections) for the case that all payloads are malformed.

    Definition Classes
    TransactionProcessingStepsProcessingSteps
  12. def createRejectionEvent(rejectionArgs: TransactionProcessingSteps.RejectionArgs)(implicit traceContext: TraceContext): Either[TransactionProcessorError, 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
    TransactionProcessingStepsProcessingSteps
  13. def createSubmissionResult(deliver: Deliver[Envelope[_]], unit: Unit): TransactionSubmitted

    Phase 1, step 3:

    Phase 1, step 3:

    Definition Classes
    TransactionProcessingStepsProcessingSteps
  14. def decisionTimeFor(parameters: DynamicDomainParametersWithValidity, requestTs: CantonTimestamp): Either[TransactionProcessorError, CantonTimestamp]
  15. def decryptViews(batch: NonEmpty[Seq[OpenEnvelope[EncryptedViewMessage[TransactionViewType]]]], snapshot: DomainSnapshotSyncCryptoApi, sessionKeyStore: SessionKeyStore)(implicit traceContext: TraceContext): EitherT[Future, TransactionProcessorError, 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
    TransactionProcessingStepsProcessingSteps
  16. implicit val ec: ExecutionContext
  17. def embedNoMediatorError(error: NoMediatorError): TransactionSubmissionError

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

  18. def embedRequestError(err: RequestProcessingError): TransactionProcessorError

    Wrap an error in request processing from the generic request processor

    Wrap an error in request processing from the generic request processor

    Definition Classes
    TransactionProcessingStepsProcessingSteps
  19. def embedResultError(err: ResultProcessingError): TransactionProcessorError

    Wrap an error in result processing from the generic request processor

    Wrap an error in result processing from the generic request processor

    Definition Classes
    TransactionProcessingStepsProcessingSteps
  20. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  21. def equals(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef → Any
  22. implicit def errorLoggingContext(implicit traceContext: TraceContext): ErrorLoggingContext
    Attributes
    protected
    Definition Classes
    NamedLogging
  23. def eventAndSubmissionIdForInactiveMediator(ts: CantonTimestamp, rc: RequestCounter, sc: SequencerCounter, fullViews: NonEmpty[Seq[WithRecipients[FullView]]], freshOwnTimelyTx: Boolean)(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.RequestCounter of the request

    sc

    The com.digitalasset.canton.SequencerCounter of the request

    fullViews

    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
    TransactionProcessingStepsProcessingSteps
  24. final def getClass(): Class[_ <: AnyRef]
    Definition Classes
    AnyRef → Any
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  25. def getCommitSetAndContractsToBeStoredAndEvent(eventE: Either[EventWithErrors[Deliver[DefaultOpenEnvelope]], SignedContent[Deliver[DefaultOpenEnvelope]]], resultE: Either[MalformedMediatorRequestResult, TransactionResultMessage], pendingRequestData: PendingRequestData, pendingSubmissionMap: PendingSubmissions, hashOps: HashOps)(implicit traceContext: TraceContext): EitherT[Future, TransactionProcessorError, CommitAndStoreContractsAndPublishEvent]

    Phase 7, step 2:

    Phase 7, step 2:

    eventE

    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

    resultE

    The unpacked mediator result that is contained in the event

    pendingRequestData

    The requestType.PendingRequestData produced in Phase 3

    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
    TransactionProcessingStepsProcessingSteps
  26. def getSubmissionDataForTracker(views: Seq[FullView]): Option[SubmissionData]

    Return the submission data needed by the SubmissionTracker to decide on transaction validity

    Return the submission data needed by the SubmissionTracker to decide on transaction validity

    Definition Classes
    TransactionProcessingStepsProcessingSteps
  27. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  28. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  29. def logger: TracedLogger
    Attributes
    protected
    Definition Classes
    NamedLogging
  30. val loggerFactory: NamedLoggerFactory
    Attributes
    protected
    Definition Classes
    TransactionProcessingStepsNamedLogging
  31. implicit def namedLoggingContext(implicit traceContext: TraceContext): NamedLoggingContext
    Attributes
    protected
    Definition Classes
    NamedLogging
  32. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  33. def noTracingLogger: Logger
    Attributes
    protected
    Definition Classes
    NamedLogging
  34. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  35. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  36. def participantResponseDeadlineFor(parameters: DynamicDomainParametersWithValidity, requestTs: CantonTimestamp): Either[TransactionProcessorError, CantonTimestamp]
  37. def pendingSubmissions(state: SyncDomainEphemeralState): Unit

    Selector to get the PendingSubmissions, if any

    Selector to get the PendingSubmissions, if any

    Definition Classes
    TransactionProcessingStepsProcessingSteps
  38. def postProcessResult(verdict: Verdict, pendingSubmission: Nothing)(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.MediatorRejectV1.

    verdict

    The verdict on the request

    Definition Classes
    TransactionProcessingStepsProcessingSteps
  39. def postProcessSubmissionForInactiveMediator(declaredMediator: MediatorRef, ts: CantonTimestamp, pendingSubmission: Nothing)(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
    TransactionProcessingStepsProcessingSteps
    See also

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

  40. def prepareSubmission(param: SubmissionParam, mediator: MediatorRef, ephemeralState: SyncDomainEphemeralStateLookup, recentSnapshot: DomainSnapshotSyncCryptoApi)(implicit traceContext: TraceContext): EitherT[FutureUnlessShutdown, TransactionSubmissionError, Submission]

    Phase 1, step 1:

    Phase 1, step 1:

    param

    The parameter object encapsulating the parameters of the submit method

    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
    TransactionProcessingStepsProcessingSteps
  41. def removePendingSubmission(pendingSubmissions: Unit, pendingSubmissionId: Unit): Option[Nothing]

    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
    TransactionProcessingStepsProcessingSteps
  42. 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
    TransactionProcessingStepsProcessingSteps
  43. val requestType: RequestType
  44. 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
    TransactionProcessingStepsProcessingSteps
  45. def submissionIdOfPendingRequest(pendingData: PendingTransaction): Unit

    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
    TransactionProcessingStepsProcessingSteps
  46. final def synchronized[T0](arg0: => T0): T0
    Definition Classes
    AnyRef
  47. def toString(): String
    Definition Classes
    AnyRef → Any
  48. def updatePendingSubmissions(pendingSubmissionMap: Unit, submissionParam: SubmissionParam, pendingSubmissionId: PendingSubmissionId): EitherT[Future, SubmissionSendError, SubmissionResultArgs]

    Phase 1, step 2:

    Phase 1, step 2:

    submissionParam

    Implementation-specific details on the submission, used for logging

    pendingSubmissionId

    The key used for updates to the pendingSubmissions

    Definition Classes
    TransactionProcessingStepsProcessingSteps
  49. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  50. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException]) @native()
  51. 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

Ungrouped