com.digitalasset.canton.participant.protocol.reassignment
UnassignmentProcessingSteps
Companion object UnassignmentProcessingSteps
class UnassignmentProcessingSteps extends ReassignmentProcessingSteps[SubmissionParam, SubmissionResult, UnassignmentViewType, PendingUnassignment] with NamedLogging
- Alphabetic
- By Inheritance
- UnassignmentProcessingSteps
- ReassignmentProcessingSteps
- NamedLogging
- ProcessingSteps
- AnyRef
- Any
- Hide All
- Show All
- Public
- Protected
Instance Constructors
- new UnassignmentProcessingSteps(synchronizerId: Source[SynchronizerId], participantId: ParticipantId, reassignmentCoordination: ReassignmentCoordination, seedGenerator: SeedGenerator, staticSynchronizerParameters: Source[StaticSynchronizerParameters], contractAuthenticator: ContractAuthenticator, protocolVersion: Source[ProtocolVersion], loggerFactory: NamedLoggerFactory)(implicit ec: ExecutionContext)
Type Members
- case class CommitAndStoreContractsAndPublishEvent(commitSet: Option[FutureUnlessShutdown[CommitSet]], contractsToBeStored: Seq[SerializableContract], maybeEvent: Option[SequencedUpdate]) 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.
- maybeEvent
The event to be published via the com.digitalasset.canton.participant.event.RecordOrderPublisher
- Definition Classes
- ProcessingSteps
- case class DecryptedViews(views: Seq[(WithRecipients[DecryptedView], Option[Signature])], decryptionErrors: Seq[EncryptedViewMessageError]) extends Product with Serializable
Phase 3, step 1a:
Phase 3, step 1a:
- 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
- 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
- case class StorePendingDataAndSendResponseAndCreateTimeout(pendingData: RequestType.PendingRequestData, confirmationResponsesF: EitherT[FutureUnlessShutdown, RequestError, Option[(ConfirmationResponses, Recipients)]], rejectionArgs: RejectionArgs) extends Product with Serializable
Phase 3:
Phase 3:
- pendingData
The
requestType.PendingRequestData
to be stored until Phase 7- confirmationResponsesF
The responses to be sent to the mediator
- rejectionArgs
The implementation-specific arguments needed to create a rejection event on timeout
- Definition Classes
- ProcessingSteps
- sealed trait Submission extends AnyRef
- Definition Classes
- ProcessingSteps
- 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
- 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
- case class ReassignmentsSubmission(batch: Batch[DefaultOpenEnvelope], pendingSubmissionId: PendingSubmissionId) extends UntrackedSubmission with Product with Serializable
- Definition Classes
- ReassignmentProcessingSteps
- type DecryptedView = View
The type of decrypted view trees
The type of decrypted view trees
- Definition Classes
- ProcessingSteps
- type FullView = data.ViewType.UnassignmentViewType.FullView
The type of full view trees, i.e., after decomposing light views.
The type of full view trees, i.e., after decomposing light views.
- Definition Classes
- ProcessingSteps
- type ParsedRequestType = ParsedReassignmentRequest[FullView]
Type of a request that has been parsed and contains at least one well-formed view.
Type of a request that has been parsed and contains at least one well-formed view.
- Definition Classes
- ReassignmentProcessingSteps → ProcessingSteps
- type PendingSubmissionData = PendingReassignmentSubmission
The data stored for submissions that have been sent out, if any.
The data stored for submissions that have been sent out, if any. It is created by createSubmission and passed to createSubmissionResult
- Definition Classes
- ReassignmentProcessingSteps → ProcessingSteps
- type PendingSubmissionId = RootHash
The type used for look-ups into the PendingSubmissions
The type used for look-ups into the PendingSubmissions
- Definition Classes
- ReassignmentProcessingSteps → ProcessingSteps
- type PendingSubmissions = Map[RootHash, PendingReassignmentSubmission]
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
- ReassignmentProcessingSteps → ProcessingSteps
- type RejectionArgs = ReassignmentProcessingSteps.RejectionArgs[PendingUnassignment]
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
- ReassignmentProcessingSteps → ProcessingSteps
- type RequestBatch = RequestAndRootHashMessage[OpenEnvelope[EncryptedViewMessage[UnassignmentViewType]]]
The type of request messages
The type of request messages
- Definition Classes
- ProcessingSteps
- type RequestError = ReassignmentProcessorError
The type of errors that can occur during request processing
The type of errors that can occur during request processing
- Definition Classes
- ReassignmentProcessingSteps → ProcessingSteps
- type RequestType = Unassignment.type
The type of the request (transaction, unassignment, assignment)
The type of the request (transaction, unassignment, assignment)
- Definition Classes
- UnassignmentProcessingSteps → ReassignmentProcessingSteps → ProcessingSteps
- type ResultError = ReassignmentProcessorError
The type of errors that can occur during result processing
The type of errors that can occur during result processing
- Definition Classes
- ReassignmentProcessingSteps → ProcessingSteps
- type SubmissionResultArgs = PendingReassignmentSubmission
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
- UnassignmentProcessingSteps → ProcessingSteps
- type SubmissionSendError = ReassignmentProcessorError
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
- ReassignmentProcessingSteps → ProcessingSteps
- type ViewSubmitterMetadata = data.ViewType.UnassignmentViewType.ViewSubmitterMetadata
- Definition Classes
- ProcessingSteps
Value Members
- object DecryptedViews extends Serializable
- Definition Classes
- ProcessingSteps
- 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
- final def asInstanceOf[T0]: T0
- Definition Classes
- Any
- def authenticateInputContracts(parsedRequest: ParsedRequestType)(implicit traceContext: TraceContext): EitherT[Future, ReassignmentProcessorError, Unit]
- Definition Classes
- ReassignmentProcessingSteps → ProcessingSteps
- def clone(): AnyRef
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.CloneNotSupportedException]) @IntrinsicCandidate() @native()
- def computeActivenessSet(parsedRequest: ParsedReassignmentRequest[FullUnassignmentTree])(implicit traceContext: TraceContext): Either[ReassignmentProcessorError, ActivenessSet]
Phase 3, step 2 (some good views)
Phase 3, step 2 (some good views)
- Definition Classes
- UnassignmentProcessingSteps → ProcessingSteps
- def computeFullViews(decryptedViewsWithSignatures: Seq[(WithRecipients[DecryptedView], Option[Signature])]): (Seq[(WithRecipients[FullView], Option[Signature])], Seq[MalformedPayload])
Phase 3, step 1b
Phase 3, step 1b
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
- ReassignmentProcessingSteps → ProcessingSteps
- def computeParsedRequest(rc: RequestCounter, ts: CantonTimestamp, sc: SequencerCounter, rootViewsWithMetadata: NonEmpty[Seq[(WithRecipients[FullView], Option[Signature])]], submitterMetadataO: Option[ViewSubmitterMetadata], isFreshOwnTimelyRequest: Boolean, malformedPayloads: Seq[MalformedPayload], mediator: MediatorGroupRecipient, snapshot: SynchronizerSnapshotSyncCryptoApi, synchronizerParameters: DynamicSynchronizerParametersWithValidity)(implicit traceContext: TraceContext): FutureUnlessShutdown[ParsedReassignmentRequest[FullView]]
Phase 3, step 1c
Phase 3, step 1c
Create a ParsedRequest out of the data computed so far.
- Definition Classes
- ReassignmentProcessingSteps → ProcessingSteps
- def constructPendingDataAndResponse(parsedRequest: ParsedReassignmentRequest[FullUnassignmentTree], reassignmentLookup: ReassignmentLookup, activenessF: FutureUnlessShutdown[ActivenessResult], engineController: EngineController, decisionTimeTickRequest: TickRequest)(implicit traceContext: TraceContext): EitherT[FutureUnlessShutdown, ReassignmentProcessorError, StorePendingDataAndSendResponseAndCreateTimeout]
Phase 3, step 3: Yields the pending data and confirmation responses for the case that at least one payload is well-formed.
Phase 3, step 3: Yields the pending data and confirmation responses for the case that at least one payload is well-formed.
- reassignmentLookup
Read-only interface of the com.digitalasset.canton.participant.store.memory.ReassignmentCache
- returns
Returns the
requestType.PendingRequestData
to be stored until Phase 7 and the responses to be sent to the mediator.
- Definition Classes
- UnassignmentProcessingSteps → ProcessingSteps
- def constructResponsesForMalformedPayloads(requestId: RequestId, rootHash: RootHash, malformedPayloads: Seq[MalformedPayload])(implicit traceContext: TraceContext): Option[ConfirmationResponses]
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
- ReassignmentProcessingSteps → ProcessingSteps
- val contractAuthenticator: ContractAuthenticator
- Attributes
- protected
- Definition Classes
- UnassignmentProcessingSteps → ReassignmentProcessingSteps
- def createConfirmationResponses(requestId: RequestId, topologySnapshot: TopologySnapshot, protocolVersion: ProtocolVersion, confirmingParties: Set[LfPartyId], validationResult: ReassignmentValidationResult)(implicit traceContext: TraceContext): FutureUnlessShutdown[Option[ConfirmationResponses]]
- Attributes
- protected
- Definition Classes
- ReassignmentProcessingSteps
- def createRejectionEvent(rejectionArgs: RejectionArgs)(implicit traceContext: TraceContext): Either[ReassignmentProcessorError, Option[SequencedUpdate]]
Phase 3, step 4:
Phase 3, step 4:
- rejectionArgs
The implementation-specific information needed for the creation of the rejection event
- Definition Classes
- ReassignmentProcessingSteps → ProcessingSteps
- def createSubmission(submissionParam: SubmissionParam, mediator: MediatorGroupRecipient, ephemeralState: SyncEphemeralStateLookup, sourceRecentSnapshot: SynchronizerSnapshotSyncCryptoApi)(implicit traceContext: TraceContext): EitherT[FutureUnlessShutdown, ReassignmentProcessorError, Submission]
Phase 1, step 1:
Phase 1, step 1:
- submissionParam
The parameter object encapsulating the parameters of the submit method
- mediator
The mediator ID to use for this submission
- ephemeralState
Read-only access to the com.digitalasset.canton.participant.sync.SyncEphemeralState
- Definition Classes
- UnassignmentProcessingSteps → ProcessingSteps
- def createSubmissionResult(deliver: Deliver[Envelope[_]], pendingSubmission: SubmissionResultArgs): SubmissionResult
Phase 1, step 3:
Phase 1, step 3:
- Definition Classes
- UnassignmentProcessingSteps → ProcessingSteps
- def decryptTree(sourceSnapshot: SynchronizerSnapshotSyncCryptoApi, sessionKeyStore: ConfirmationRequestSessionKeyStore)(envelope: OpenEnvelope[EncryptedViewMessage[UnassignmentViewType]])(implicit tc: TraceContext): EitherT[FutureUnlessShutdown, EncryptedViewMessageError, (WithRecipients[FullUnassignmentTree], Option[Signature])]
- Attributes
- protected
- Definition Classes
- UnassignmentProcessingSteps → ReassignmentProcessingSteps
- def decryptViews(batch: NonEmpty[Seq[OpenEnvelope[EncryptedViewMessage[UnassignmentViewType]]]], snapshot: SynchronizerSnapshotSyncCryptoApi, sessionKeyStore: ConfirmationRequestSessionKeyStore)(implicit traceContext: TraceContext): EitherT[FutureUnlessShutdown, ReassignmentProcessorError, 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
- ReassignmentProcessingSteps → ProcessingSteps
- implicit val ec: ExecutionContext
- Definition Classes
- UnassignmentProcessingSteps → ReassignmentProcessingSteps
- def embedNoMediatorError(error: NoMediatorError): ReassignmentProcessorError
- Definition Classes
- ReassignmentProcessingSteps → ProcessingSteps
- def embedRequestError(err: RequestProcessingError): ReassignmentProcessorError
Wrap an error in request processing from the generic request processor
Wrap an error in request processing from the generic request processor
- Definition Classes
- ReassignmentProcessingSteps → ProcessingSteps
- def embedResultError(err: ResultProcessingError): ReassignmentProcessorError
Wrap an error in result processing from the generic request processor
Wrap an error in result processing from the generic request processor
- Definition Classes
- ReassignmentProcessingSteps → ProcessingSteps
- final def eq(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
- def equals(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef → Any
- implicit def errorLoggingContext(implicit traceContext: TraceContext): ErrorLoggingContext
- Attributes
- protected
- Definition Classes
- NamedLogging
- def eventAndSubmissionIdForRejectedCommand(ts: CantonTimestamp, sc: SequencerCounter, submitterMetadata: ViewSubmitterMetadata, rootHash: RootHash, freshOwnTimelyTx: Boolean, error: TransactionError)(implicit traceContext: TraceContext): (Option[SequencedUpdate], Option[PendingSubmissionId])
Phase 3, step 2: Some good views, but we are rejecting (e.g.
Phase 3, step 2: Some good views, but we are rejecting (e.g. because the chosen mediator is inactive or there are no valid recipients).
- ts
The timestamp of the request
- sc
The com.digitalasset.canton.SequencerCounter of the request
- submitterMetadata
Metadata of the submitter
- rootHash
Root hash of the transaction
- freshOwnTimelyTx
The resolved status from com.digitalasset.canton.participant.protocol.SubmissionTracker.register
- error
Error to be included in the generated event
- returns
The optional rejection event to be published in the event log, and the optional submission ID corresponding to this request
- Definition Classes
- ReassignmentProcessingSteps → ProcessingSteps
- def explicitMediatorGroup(param: SubmissionParam): Option[MediatorGroupIndex]
Extract an optionally explicitly chosen mediator group index
Extract an optionally explicitly chosen mediator group index
- Definition Classes
- UnassignmentProcessingSteps → ProcessingSteps
- final def getClass(): Class[_ <: AnyRef]
- Definition Classes
- AnyRef → Any
- Annotations
- @IntrinsicCandidate() @native()
- def getCommitSetAndContractsToBeStoredAndEvent(event: WithOpeningErrors[SignedContent[Deliver[DefaultOpenEnvelope]]], verdict: Verdict, pendingRequestData: PendingUnassignment, pendingSubmissionMap: PendingSubmissions, hashOps: HashOps)(implicit traceContext: TraceContext): EitherT[FutureUnlessShutdown, ReassignmentProcessorError, CommitAndStoreContractsAndPublishEvent]
Phase 7, step 2:
Phase 7, step 2:
- event
The signed com.digitalasset.canton.sequencing.protocol.Deliver event containing the confirmation result. It is ensured that the
event
contains exactly one com.digitalasset.canton.protocol.messages.ConfirmationResultMessage- verdict
The verdict 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
- UnassignmentProcessingSteps → ProcessingSteps
- def getSubmitterInformation(views: Seq[DecryptedView]): Option[ViewSubmitterMetadata]
Return the submitter metadata
Return the submitter metadata
- Definition Classes
- ReassignmentProcessingSteps → ProcessingSteps
- def handleTimeout(parsedRequest: ParsedReassignmentRequest[FullView])(implicit traceContext: TraceContext): EitherT[FutureUnlessShutdown, ReassignmentProcessorError, Unit]
Processor specific handling of the timeout
Processor specific handling of the timeout
- Definition Classes
- UnassignmentProcessingSteps → ProcessingSteps
- def hashCode(): Int
- Definition Classes
- AnyRef → Any
- Annotations
- @IntrinsicCandidate() @native()
- final def isInstanceOf[T0]: Boolean
- Definition Classes
- Any
- def localRejectFromActivenessCheck(requestId: RequestId, activenessResult: ActivenessResult, validationResult: ReassignmentValidationResult): Option[LocalRejectError]
- Definition Classes
- UnassignmentProcessingSteps → ReassignmentProcessingSteps
- def logger: TracedLogger
- Attributes
- protected
- Definition Classes
- NamedLogging
- val loggerFactory: NamedLoggerFactory
- Attributes
- protected
- Definition Classes
- UnassignmentProcessingSteps → NamedLogging
- implicit def namedLoggingContext(implicit traceContext: TraceContext): NamedLoggingContext
- Attributes
- protected
- Definition Classes
- NamedLogging
- final def ne(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
- def noTracingLogger: Logger
- Attributes
- protected
- Definition Classes
- NamedLogging
- final def notify(): Unit
- Definition Classes
- AnyRef
- Annotations
- @IntrinsicCandidate() @native()
- final def notifyAll(): Unit
- Definition Classes
- AnyRef
- Annotations
- @IntrinsicCandidate() @native()
- val participantId: ParticipantId
- Definition Classes
- UnassignmentProcessingSteps → ReassignmentProcessingSteps
- def pendingSubmissions(state: SyncEphemeralState): PendingSubmissions
Selector to get the PendingSubmissions, if any
Selector to get the PendingSubmissions, if any
- Definition Classes
- UnassignmentProcessingSteps → ProcessingSteps
- def performPendingSubmissionMapUpdate(pendingSubmissionMap: Map[RootHash, PendingReassignmentSubmission], reassignmentRef: ReassignmentRef, submitterLf: LfPartyId, rootHash: RootHash): EitherT[Future, ReassignmentProcessorError, PendingReassignmentSubmission]
- Attributes
- protected
- Definition Classes
- ReassignmentProcessingSteps
- def postProcessResult(verdict: Verdict, pendingSubmission: PendingReassignmentSubmission)(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.MediatorReject.
- verdict
The verdict on the request
- Definition Classes
- ReassignmentProcessingSteps → ProcessingSteps
- def postProcessSubmissionRejectedCommand(error: TransactionError, pendingSubmission: PendingReassignmentSubmission)(implicit traceContext: TraceContext): Unit
Phase 3, step 2 (rejected submission, e.g.
Phase 3, step 2 (rejected submission, e.g. chosen mediator is inactive, invalid recipients)
Called when we are rejecting the submission and eventAndSubmissionIdForRejectedCommand returned a submission ID that was pending.
- pendingSubmission
The PendingSubmissionData for the submission ID returned by eventAndSubmissionIdForRejectedCommand
- Definition Classes
- ReassignmentProcessingSteps → ProcessingSteps
- See also
com.digitalasset.canton.participant.protocol.ProcessingSteps.postProcessResult
- val protocolVersion: Source[ProtocolVersion]
- def removePendingSubmission(pendingSubmissions: Map[RootHash, PendingReassignmentSubmission], pendingSubmissionId: RootHash): Option[PendingReassignmentSubmission]
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
- ReassignmentProcessingSteps → ProcessingSteps
- 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
- UnassignmentProcessingSteps → ProcessingSteps
- val requestType: RequestType
- Definition Classes
- UnassignmentProcessingSteps → ReassignmentProcessingSteps → ProcessingSteps
- def setDecisionTimeTickRequest(pendingSubmissions: Map[RootHash, PendingReassignmentSubmission], pendingSubmissionId: RootHash, requestedTick: TickRequest): Unit
Phase 1, step 3:
Phase 1, step 3:
Remember the com.digitalasset.canton.time.SynchronizerTimeTracker.TickRequest for the decision time in the PendingSubmissionData so that the tick request can be cancelled if the tick is no longer needed. Called when sending the submission succeeded.
- Definition Classes
- ReassignmentProcessingSteps → ProcessingSteps
- 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
- UnassignmentProcessingSteps → ProcessingSteps
- def submissionIdOfPendingRequest(pendingData: PendingUnassignment): RootHash
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
- UnassignmentProcessingSteps → ProcessingSteps
- final def synchronized[T0](arg0: => T0): T0
- Definition Classes
- AnyRef
- val synchronizerId: Source[SynchronizerId]
- Definition Classes
- UnassignmentProcessingSteps → ReassignmentProcessingSteps
- def toString(): String
- Definition Classes
- AnyRef → Any
- def updatePendingSubmissions(pendingSubmissionMap: PendingSubmissions, submissionParam: SubmissionParam, pendingSubmissionId: PendingSubmissionId): EitherT[Future, ReassignmentProcessorError, 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
- UnassignmentProcessingSteps → ProcessingSteps
- final def wait(arg0: Long, arg1: Int): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
- final def wait(arg0: Long): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException]) @native()
- final def wait(): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])