class UnassignmentProcessingSteps extends ReassignmentProcessingSteps[SubmissionParam, SubmissionResult, UnassignmentViewType, PendingUnassignment] with NamedLogging

Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. UnassignmentProcessingSteps
  2. ReassignmentProcessingSteps
  3. NamedLogging
  4. ProcessingSteps
  5. AnyRef
  6. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. Protected

Instance Constructors

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

  1. 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
  2. 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
  3. 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
  4. 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
  5. sealed trait Submission extends AnyRef
    Definition Classes
    ProcessingSteps
  6. 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
  7. 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
  8. case class ReassignmentsSubmission(batch: Batch[DefaultOpenEnvelope], pendingSubmissionId: PendingSubmissionId) extends UntrackedSubmission with Product with Serializable
    Definition Classes
    ReassignmentProcessingSteps
  9. type DecryptedView = View

    The type of decrypted view trees

    The type of decrypted view trees

    Definition Classes
    ProcessingSteps
  10. 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
  11. 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
    ReassignmentProcessingStepsProcessingSteps
  12. 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
    ReassignmentProcessingStepsProcessingSteps
  13. type PendingSubmissionId = RootHash

    The type used for look-ups into the PendingSubmissions

    The type used for look-ups into the PendingSubmissions

    Definition Classes
    ReassignmentProcessingStepsProcessingSteps
  14. 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
    ReassignmentProcessingStepsProcessingSteps
  15. 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
    ReassignmentProcessingStepsProcessingSteps
  16. type RequestBatch = RequestAndRootHashMessage[OpenEnvelope[EncryptedViewMessage[UnassignmentViewType]]]

    The type of request messages

    The type of request messages

    Definition Classes
    ProcessingSteps
  17. 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
    ReassignmentProcessingStepsProcessingSteps
  18. type RequestType = Unassignment.type

    The type of the request (transaction, unassignment, assignment)

    The type of the request (transaction, unassignment, assignment)

    Definition Classes
    UnassignmentProcessingStepsReassignmentProcessingStepsProcessingSteps
  19. 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
    ReassignmentProcessingStepsProcessingSteps
  20. 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
    UnassignmentProcessingStepsProcessingSteps
  21. 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
    ReassignmentProcessingStepsProcessingSteps
  22. type ViewSubmitterMetadata = data.ViewType.UnassignmentViewType.ViewSubmitterMetadata
    Definition Classes
    ProcessingSteps

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(parsedRequest: ParsedRequestType)(implicit traceContext: TraceContext): EitherT[Future, ReassignmentProcessorError, Unit]
  7. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.CloneNotSupportedException]) @IntrinsicCandidate() @native()
  8. 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
    UnassignmentProcessingStepsProcessingSteps
  9. 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
    ReassignmentProcessingStepsProcessingSteps
  10. 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
    ReassignmentProcessingStepsProcessingSteps
  11. 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
    UnassignmentProcessingStepsProcessingSteps
  12. 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
    ReassignmentProcessingStepsProcessingSteps
  13. val contractAuthenticator: ContractAuthenticator
    Attributes
    protected
    Definition Classes
    UnassignmentProcessingStepsReassignmentProcessingSteps
  14. def createConfirmationResponses(requestId: RequestId, topologySnapshot: TopologySnapshot, protocolVersion: ProtocolVersion, confirmingParties: Set[LfPartyId], validationResult: ReassignmentValidationResult)(implicit traceContext: TraceContext): FutureUnlessShutdown[Option[ConfirmationResponses]]
    Attributes
    protected
    Definition Classes
    ReassignmentProcessingSteps
  15. 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
    ReassignmentProcessingStepsProcessingSteps
  16. 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
    UnassignmentProcessingStepsProcessingSteps
  17. def createSubmissionResult(deliver: Deliver[Envelope[_]], pendingSubmission: SubmissionResultArgs): SubmissionResult

    Phase 1, step 3:

    Phase 1, step 3:

    Definition Classes
    UnassignmentProcessingStepsProcessingSteps
  18. def decryptTree(sourceSnapshot: SynchronizerSnapshotSyncCryptoApi, sessionKeyStore: ConfirmationRequestSessionKeyStore)(envelope: OpenEnvelope[EncryptedViewMessage[UnassignmentViewType]])(implicit tc: TraceContext): EitherT[FutureUnlessShutdown, EncryptedViewMessageError, (WithRecipients[FullUnassignmentTree], Option[Signature])]
    Attributes
    protected
    Definition Classes
    UnassignmentProcessingStepsReassignmentProcessingSteps
  19. 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
    ReassignmentProcessingStepsProcessingSteps
  20. implicit val ec: ExecutionContext
  21. def embedNoMediatorError(error: NoMediatorError): ReassignmentProcessorError
  22. 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
    ReassignmentProcessingStepsProcessingSteps
  23. 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
    ReassignmentProcessingStepsProcessingSteps
  24. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  25. def equals(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef → Any
  26. implicit def errorLoggingContext(implicit traceContext: TraceContext): ErrorLoggingContext
    Attributes
    protected
    Definition Classes
    NamedLogging
  27. 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
    ReassignmentProcessingStepsProcessingSteps
  28. def explicitMediatorGroup(param: SubmissionParam): Option[MediatorGroupIndex]

    Extract an optionally explicitly chosen mediator group index

    Extract an optionally explicitly chosen mediator group index

    Definition Classes
    UnassignmentProcessingStepsProcessingSteps
  29. final def getClass(): Class[_ <: AnyRef]
    Definition Classes
    AnyRef → Any
    Annotations
    @IntrinsicCandidate() @native()
  30. 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
    UnassignmentProcessingStepsProcessingSteps
  31. def getSubmitterInformation(views: Seq[DecryptedView]): Option[ViewSubmitterMetadata]

    Return the submitter metadata

    Return the submitter metadata

    Definition Classes
    ReassignmentProcessingStepsProcessingSteps
  32. 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
    UnassignmentProcessingStepsProcessingSteps
  33. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @IntrinsicCandidate() @native()
  34. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  35. def localRejectFromActivenessCheck(requestId: RequestId, activenessResult: ActivenessResult, validationResult: ReassignmentValidationResult): Option[LocalRejectError]
  36. def logger: TracedLogger
    Attributes
    protected
    Definition Classes
    NamedLogging
  37. val loggerFactory: NamedLoggerFactory
    Attributes
    protected
    Definition Classes
    UnassignmentProcessingStepsNamedLogging
  38. implicit def namedLoggingContext(implicit traceContext: TraceContext): NamedLoggingContext
    Attributes
    protected
    Definition Classes
    NamedLogging
  39. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  40. def noTracingLogger: Logger
    Attributes
    protected
    Definition Classes
    NamedLogging
  41. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @IntrinsicCandidate() @native()
  42. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @IntrinsicCandidate() @native()
  43. val participantId: ParticipantId
  44. def pendingSubmissions(state: SyncEphemeralState): PendingSubmissions

    Selector to get the PendingSubmissions, if any

    Selector to get the PendingSubmissions, if any

    Definition Classes
    UnassignmentProcessingStepsProcessingSteps
  45. def performPendingSubmissionMapUpdate(pendingSubmissionMap: Map[RootHash, PendingReassignmentSubmission], reassignmentRef: ReassignmentRef, submitterLf: LfPartyId, rootHash: RootHash): EitherT[Future, ReassignmentProcessorError, PendingReassignmentSubmission]
    Attributes
    protected
    Definition Classes
    ReassignmentProcessingSteps
  46. 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
    ReassignmentProcessingStepsProcessingSteps
  47. 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
    ReassignmentProcessingStepsProcessingSteps
    See also

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

  48. val protocolVersion: Source[ProtocolVersion]
  49. 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
    ReassignmentProcessingStepsProcessingSteps
  50. 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
    UnassignmentProcessingStepsProcessingSteps
  51. val requestType: RequestType
  52. 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
    ReassignmentProcessingStepsProcessingSteps
  53. 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
    UnassignmentProcessingStepsProcessingSteps
  54. 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
    UnassignmentProcessingStepsProcessingSteps
  55. final def synchronized[T0](arg0: => T0): T0
    Definition Classes
    AnyRef
  56. val synchronizerId: Source[SynchronizerId]
  57. def toString(): String
    Definition Classes
    AnyRef → Any
  58. 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
    UnassignmentProcessingStepsProcessingSteps
  59. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  60. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException]) @native()
  61. 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

    (Since version 9)

Ungrouped