Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- abort() - Method in interface io.camunda.zeebe.engine.state.migration.DbMigrator
- abort() - Method in class io.camunda.zeebe.engine.state.migration.DbMigratorImpl
- abortCondition(BooleanSupplier) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- AbstractFlowElement - Class in io.camunda.zeebe.engine.processing.deployment.model.element
- AbstractFlowElement(String) - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.element.AbstractFlowElement
- accept(TypedRecord<JobRecord>, CommandProcessor.CommandControl<JobRecord>, Consumer<SideEffectProducer>) - Method in interface io.camunda.zeebe.engine.processing.job.JobAcceptFunction
- accept(Intent, T) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.CommandProcessor.CommandControl
- accept(Intent, T) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.CommandProcessorImpl
- ACTIVATABLE - Enum constant in enum io.camunda.zeebe.engine.state.immutable.JobState.State
- activate(long, JobRecord) - Method in class io.camunda.zeebe.engine.state.instance.DbJobState
-
Note: calling this method will reset the variables of the job record.
- activate(long, JobRecord) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableJobState
- activateChildInstance(BpmnElementContext, ExecutableFlowElement) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateTransitionBehavior
- activateChildInstanceWithKey(BpmnElementContext, ExecutableFlowElement) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateTransitionBehavior
- ACTIVATED - Enum constant in enum io.camunda.zeebe.engine.state.immutable.JobState.State
- activateElement(ExecutableFlowElement, long, ProcessInstanceRecord) - Method in class io.camunda.zeebe.engine.processing.common.EventHandle
- activateElement(ExecutableFlowElement, long, ProcessInstanceRecord, DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.common.EventHandle
- activateElementInstanceInFlowScope(BpmnElementContext, ExecutableFlowElement) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateTransitionBehavior
- activateProcessInstanceForStartEvent(long, long, DirectBuffer, DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.common.EventHandle
- activateTriggeredEvent(long, long, EventTrigger, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnEventSubscriptionBehavior
-
Activates the element that was triggered by an event and pass in the variables of the event.
- activateTriggeredEvent(long, ExecutableFlowElement, long, long, ProcessInstanceRecord, DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.common.EventTriggerBehavior
- activateTriggeredStartEvent(BpmnElementContext, EventTrigger) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnEventSubscriptionBehavior
- actor(ActorControl) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- actorSchedulingService(ActorSchedulingService) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorBuilder
- add(SideEffectProducer) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.sideeffect.SideEffectQueue
- add(SideEffectProducer) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.sideeffect.SideEffects
-
Chain the given side effect.
- add(TransientSubscriptionCommandState.CommandEntry) - Method in class io.camunda.zeebe.engine.state.message.TransientSubscriptionCommandState
- add(MessageStartEventSubscriptionRecord) - Method in class io.camunda.zeebe.engine.processing.message.Subscriptions
- add(MessageSubscriptionRecord) - Method in class io.camunda.zeebe.engine.processing.message.Subscriptions
- addError(ExecutableError) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformation.TransformContext
- addFailureListener(FailureListener) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- addFlowElement(AbstractFlowElement) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableProcess
- addIncoming(ExecutableSequenceFlow) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableFlowNode
- addInterrupting(DirectBuffer) - Method in class io.camunda.zeebe.engine.state.instance.EventScopeInstance
- addJobProcessors(TypedRecordProcessors, MutableZeebeState, Consumer<String>, BpmnEventPublicationBehavior, int, Writers, JobMetrics, EventTriggerBehavior) - Static method in class io.camunda.zeebe.engine.processing.job.JobEventProcessors
- addMessage(ExecutableMessage) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformation.TransformContext
- addMessageProcessors(EventTriggerBehavior, TypedRecordProcessors, MutableZeebeState, SubscriptionCommandSender, Writers) - Static method in class io.camunda.zeebe.engine.processing.message.MessageEventProcessors
- addOutgoing(ExecutableSequenceFlow) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableExclusiveGateway
- addOutgoing(ExecutableSequenceFlow) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableFlowNode
- addPendingDeploymentDistribution(long, int) - Method in class io.camunda.zeebe.engine.state.deployment.DbDeploymentState
- addPendingDeploymentDistribution(long, int) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableDeploymentState
- addProcess(ExecutableProcess) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformation.TransformContext
- addProcessors(TypedRecordProcessors, ZeebeState, TypedRecordProcessor<ProcessInstanceRecord>, Writers, KeyGenerator) - Static method in class io.camunda.zeebe.engine.processing.incident.IncidentEventProcessors
- addProcessProcessors(MutableZeebeState, ExpressionProcessor, TypedRecordProcessors, SubscriptionCommandSender, CatchEventBehavior, DueDateTimerChecker, EventTriggerBehavior, Writers, JobMetrics) - Static method in class io.camunda.zeebe.engine.processing.ProcessEventProcessors
- addStartEvent(ExecutableStartEvent) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableFlowElementContainer
- afterAccept(TypedCommandWriter, StateWriter, long, Intent, JobRecord) - Method in class io.camunda.zeebe.engine.processing.job.JobCompleteProcessor
- afterAccept(TypedCommandWriter, StateWriter, long, Intent, JobRecord) - Method in class io.camunda.zeebe.engine.processing.job.JobFailProcessor
- afterAccept(TypedCommandWriter, StateWriter, long, Intent, JobRecord) - Method in class io.camunda.zeebe.engine.processing.job.JobThrowErrorProcessor
- afterAccept(TypedCommandWriter, StateWriter, long, Intent, ProcessInstanceCreationRecord) - Method in class io.camunda.zeebe.engine.processing.processinstance.CreateProcessInstanceWithResultProcessor
- afterAccept(TypedCommandWriter, StateWriter, long, Intent, T) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.CommandProcessor
- afterExecutionPathCompleted(ExecutableCallActivity, BpmnElementContext, BpmnElementContext, Boolean) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.CallActivityProcessor
- afterExecutionPathCompleted(ExecutableFlowElementContainer, BpmnElementContext, BpmnElementContext, Boolean) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.EventSubProcessProcessor
- afterExecutionPathCompleted(ExecutableFlowElementContainer, BpmnElementContext, BpmnElementContext, Boolean) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.ProcessProcessor
- afterExecutionPathCompleted(ExecutableFlowElementContainer, BpmnElementContext, BpmnElementContext, Boolean) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.SubProcessProcessor
- afterExecutionPathCompleted(ExecutableFlowElement, BpmnElementContext, Boolean) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateTransitionBehavior
- afterExecutionPathCompleted(ExecutableMultiInstanceBody, BpmnElementContext, BpmnElementContext, Boolean) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.MultiInstanceBodyProcessor
- afterExecutionPathCompleted(T, BpmnElementContext, BpmnElementContext, Boolean) - Method in interface io.camunda.zeebe.engine.processing.bpmn.BpmnElementContainerProcessor
-
The execution path of a child element has completed.
- and(EventFilter) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.EventFilter
- and(MetadataFilter) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.MetadataFilter
- appendFollowUpCommand(long, Intent, RecordValue) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.TypedStreamWriterProxy
- appendFollowUpCommand(long, Intent, RecordValue) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.NoopTypedStreamWriter
- appendFollowUpCommand(long, Intent, RecordValue) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedCommandWriter
- appendFollowUpCommand(long, Intent, RecordValue) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedStreamWriterImpl
- appendFollowUpEvent(long, Intent, RecordValue) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.TypedStreamWriterProxy
- appendFollowUpEvent(long, Intent, RecordValue) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.EventApplyingStateWriter
- appendFollowUpEvent(long, Intent, RecordValue) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.NoopTypedStreamWriter
- appendFollowUpEvent(long, Intent, RecordValue) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedEventWriter
- appendFollowUpEvent(long, Intent, RecordValue) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedStreamWriterImpl
- appendNewCommand(Intent, RecordValue) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.TypedStreamWriterProxy
- appendNewCommand(Intent, RecordValue) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.NoopTypedStreamWriter
- appendNewCommand(Intent, RecordValue) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedCommandWriter
- appendNewCommand(Intent, RecordValue) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedStreamWriterImpl
- appendRecord(long, RecordType, Intent, RecordValue) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedStreamWriterImpl
- appendRecord(long, RecordType, Intent, RejectionType, String, RecordValue) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedStreamWriterImpl
- appendRejection(TypedRecord<? extends RecordValue>, RejectionType, String) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.TypedStreamWriterProxy
- appendRejection(TypedRecord<? extends RecordValue>, RejectionType, String) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.NoopTypedStreamWriter
- appendRejection(TypedRecord<? extends RecordValue>, RejectionType, String) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedRejectionWriter
- appendRejection(TypedRecord<? extends RecordValue>, RejectionType, String) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedStreamWriterImpl
- appendTo(StringBuilder) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- appendTo(StringBuilder) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- appendTo(StringBuilder) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- appendTo(StringBuilder) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- appendTo(StringBuilder) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- appendTo(StringBuilder) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- appendTo(StringBuilder) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- appendTo(StringBuilder) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- appendTo(StringBuilder) - Method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- appendTo(StringBuilder) - Method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- appendTo(StringBuilder) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- appendTo(StringBuilder) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- appendTo(StringBuilder) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- appendTo(StringBuilder) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- appendTo(StringBuilder) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- appendTo(StringBuilder) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- appendTo(StringBuilder) - Method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- appendTo(StringBuilder) - Method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingEncoder
- applies(LoggedEvent) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.EventFilter
- applies(LoggedEvent) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.MetadataEventFilter
- applies(RecordMetadata) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.MetadataFilter
- applies(RecordMetadata) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.RecordProtocolVersionFilter
- apply(byte[]) - Method in class io.camunda.zeebe.engine.processing.message.command.SubscriptionCommandMessageHandler
- apply(Subscriptions.Subscription) - Method in interface io.camunda.zeebe.engine.processing.message.Subscriptions.SubscriptionVisitor
- applyInputMappings(BpmnElementContext, ExecutableFlowNode) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnVariableMappingBehavior
-
Apply the input mappings for a BPMN element.
- applyOutputMappings(BpmnElementContext, ExecutableFlowNode) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnVariableMappingBehavior
-
Apply the output mappings for a BPMN element.
- applyState(long, DeploymentDistributionRecord) - Method in class io.camunda.zeebe.engine.state.appliers.DeploymentDistributionApplier
- applyState(long, DeploymentDistributionRecord) - Method in class io.camunda.zeebe.engine.state.appliers.DeploymentDistributionCompletedApplier
- applyState(long, DeploymentRecord) - Method in class io.camunda.zeebe.engine.state.appliers.DeploymentCreatedApplier
- applyState(long, DeploymentRecord) - Method in class io.camunda.zeebe.engine.state.appliers.DeploymentDistributedApplier
- applyState(long, DeploymentRecord) - Method in class io.camunda.zeebe.engine.state.appliers.DeploymentFullyDistributedApplier
- applyState(long, ProcessRecord) - Method in class io.camunda.zeebe.engine.state.appliers.ProcessCreatedApplier
- applyState(long, ErrorRecord) - Method in class io.camunda.zeebe.engine.state.appliers.ErrorCreatedApplier
- applyState(long, JobBatchRecord) - Method in class io.camunda.zeebe.engine.state.appliers.JobBatchActivatedApplier
- applyState(long, JobRecord) - Method in class io.camunda.zeebe.engine.state.appliers.JobCanceledApplier
- applyState(long, JobRecord) - Method in class io.camunda.zeebe.engine.state.appliers.JobErrorThrownApplier
- applyState(long, JobRecord) - Method in class io.camunda.zeebe.engine.state.appliers.JobRecurredApplier
- applyState(long, JobRecord) - Method in class io.camunda.zeebe.engine.state.appliers.JobRetriesUpdatedApplier
- applyState(long, JobRecord) - Method in class io.camunda.zeebe.engine.state.appliers.JobTimedOutApplier
- applyState(long, MessageRecord) - Method in class io.camunda.zeebe.engine.state.appliers.MessageExpiredApplier
- applyState(long, MessageRecord) - Method in class io.camunda.zeebe.engine.state.appliers.MessagePublishedApplier
- applyState(long, MessageStartEventSubscriptionRecord) - Method in class io.camunda.zeebe.engine.state.appliers.MessageStartEventSubscriptionCorrelatedApplier
- applyState(long, MessageStartEventSubscriptionRecord) - Method in class io.camunda.zeebe.engine.state.appliers.MessageStartEventSubscriptionCreatedApplier
- applyState(long, MessageStartEventSubscriptionRecord) - Method in class io.camunda.zeebe.engine.state.appliers.MessageStartEventSubscriptionDeletedApplier
- applyState(long, MessageSubscriptionRecord) - Method in class io.camunda.zeebe.engine.state.appliers.MessageSubscriptionCorrelatedApplier
- applyState(long, MessageSubscriptionRecord) - Method in class io.camunda.zeebe.engine.state.appliers.MessageSubscriptionCorrelatingApplier
- applyState(long, MessageSubscriptionRecord) - Method in class io.camunda.zeebe.engine.state.appliers.MessageSubscriptionCreatedApplier
- applyState(long, MessageSubscriptionRecord) - Method in class io.camunda.zeebe.engine.state.appliers.MessageSubscriptionDeletedApplier
- applyState(long, MessageSubscriptionRecord) - Method in class io.camunda.zeebe.engine.state.appliers.MessageSubscriptionRejectedApplier
- applyState(long, ProcessMessageSubscriptionRecord) - Method in class io.camunda.zeebe.engine.state.appliers.ProcessMessageSubscriptionCorrelatedApplier
- applyState(long, ProcessMessageSubscriptionRecord) - Method in class io.camunda.zeebe.engine.state.appliers.ProcessMessageSubscriptionCreatedApplier
- applyState(long, ProcessMessageSubscriptionRecord) - Method in class io.camunda.zeebe.engine.state.appliers.ProcessMessageSubscriptionCreatingApplier
- applyState(long, ProcessMessageSubscriptionRecord) - Method in class io.camunda.zeebe.engine.state.appliers.ProcessMessageSubscriptionDeletedApplier
- applyState(long, Intent, RecordValue) - Method in class io.camunda.zeebe.engine.state.appliers.EventAppliers
- applyState(long, Intent, RecordValue) - Method in interface io.camunda.zeebe.engine.state.EventApplier
-
Apply the state changes of the given event.
- applyState(long, V) - Method in interface io.camunda.zeebe.engine.state.TypedEventApplier
- asFeelExpressionString(String) - Static method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.ExpressionTransformer
-
Transforms an expression string into a FEEL expression string.
- asListLiteral(List<String>) - Static method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.ExpressionTransformer
-
Serializes a list of strings to a list-literal, e.g.
- attach(ExecutableBoundaryEvent) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableActivity
- attach(ExecutableFlowElementContainer) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableActivity
- AWAIT_WORKLOW_RESULT - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- AwaitProcessInstanceResultMetadata - Class in io.camunda.zeebe.engine.state.instance
- AwaitProcessInstanceResultMetadata() - Constructor for class io.camunda.zeebe.engine.state.instance.AwaitProcessInstanceResultMetadata
B
- beforeExecutionPathCompleted(ExecutableFlowElement, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateTransitionBehavior
- beforeExecutionPathCompleted(ExecutableMultiInstanceBody, BpmnElementContext, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.MultiInstanceBodyProcessor
- beforeExecutionPathCompleted(T, BpmnElementContext, BpmnElementContext) - Method in interface io.camunda.zeebe.engine.processing.bpmn.BpmnElementContainerProcessor
-
The execution path of a child element is about to be completed.
- BLACKLIST - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- BlacklistMetrics - Class in io.camunda.zeebe.engine.metrics
- BlacklistMetrics(int) - Constructor for class io.camunda.zeebe.engine.metrics.BlacklistMetrics
- blacklistProcessInstance(long) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableBlackListState
- blacklistProcessInstance(long) - Method in class io.camunda.zeebe.engine.state.processing.DbBlackListState
- BlackListState - Interface in io.camunda.zeebe.engine.state.immutable
- BLOCK_LENGTH - Static variable in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- BLOCK_LENGTH - Static variable in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- BLOCK_LENGTH - Static variable in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- BLOCK_LENGTH - Static variable in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- BLOCK_LENGTH - Static variable in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- BLOCK_LENGTH - Static variable in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- BLOCK_LENGTH - Static variable in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- BLOCK_LENGTH - Static variable in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- BLOCK_LENGTH - Static variable in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- BLOCK_LENGTH - Static variable in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- BLOCK_LENGTH - Static variable in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- BLOCK_LENGTH - Static variable in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- BLOCK_LENGTH - Static variable in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- BLOCK_LENGTH - Static variable in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- blockLength() - Method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- blockLength(int) - Method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- blockLengthEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- blockLengthEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- blockLengthEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- blockLengthEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- blockLengthMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- blockLengthMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- blockLengthMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- blockLengthMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- blockLengthNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- blockLengthNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- blockLengthSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- BooleanType - Enum in io.camunda.zeebe.engine.processing.message.command
- BoundaryEventProcessor - Class in io.camunda.zeebe.engine.processing.bpmn.event
- BoundaryEventProcessor(BpmnBehaviors) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.event.BoundaryEventProcessor
- BoundaryEventTransformer - Class in io.camunda.zeebe.engine.processing.deployment.model.transformer
- BoundaryEventTransformer() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.transformer.BoundaryEventTransformer
- BpmnBehaviors - Interface in io.camunda.zeebe.engine.processing.bpmn.behavior
- BpmnBehaviorsImpl - Class in io.camunda.zeebe.engine.processing.bpmn.behavior
- BpmnBehaviorsImpl(ExpressionProcessor, SideEffects, MutableZeebeState, CatchEventBehavior, VariableBehavior, EventTriggerBehavior, Function<BpmnElementType, BpmnElementContainerProcessor<ExecutableFlowElement>>, Writers, JobMetrics) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBehaviorsImpl
- BpmnBufferedMessageStartEventBehavior - Class in io.camunda.zeebe.engine.processing.bpmn.behavior
- BpmnBufferedMessageStartEventBehavior(ZeebeState, KeyGenerator, EventTriggerBehavior, Writers) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBufferedMessageStartEventBehavior
- BpmnElementContainerProcessor<T extends ExecutableFlowElement> - Interface in io.camunda.zeebe.engine.processing.bpmn
-
The business logic of an BPMN element container (e.g.
- BpmnElementContext - Interface in io.camunda.zeebe.engine.processing.bpmn
-
Process instance-related data of the element that is executed.
- BpmnElementContextImpl - Class in io.camunda.zeebe.engine.processing.bpmn
- BpmnElementContextImpl() - Constructor for class io.camunda.zeebe.engine.processing.bpmn.BpmnElementContextImpl
- BpmnElementProcessor<T extends ExecutableFlowElement> - Interface in io.camunda.zeebe.engine.processing.bpmn
-
The business logic of a BPMN element.
- BpmnElementProcessors - Class in io.camunda.zeebe.engine.processing.bpmn
- BpmnElementProcessors(BpmnBehaviors) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.BpmnElementProcessors
- BpmnEventPublicationBehavior - Class in io.camunda.zeebe.engine.processing.bpmn.behavior
- BpmnEventPublicationBehavior(ZeebeState, KeyGenerator, EventTriggerBehavior, Writers) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnEventPublicationBehavior
- BpmnEventSubscriptionBehavior - Class in io.camunda.zeebe.engine.processing.bpmn.behavior
- BpmnEventSubscriptionBehavior(CatchEventBehavior, EventTriggerBehavior, TypedCommandWriter, SideEffects, ZeebeState, KeyGenerator) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnEventSubscriptionBehavior
- BpmnFactory - Class in io.camunda.zeebe.engine.processing.deployment.model
- BpmnFactory() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.BpmnFactory
- BpmnIncidentBehavior - Class in io.camunda.zeebe.engine.processing.bpmn.behavior
- BpmnIncidentBehavior(ZeebeState, KeyGenerator, StateWriter) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnIncidentBehavior
- BpmnJobBehavior - Class in io.camunda.zeebe.engine.processing.bpmn.behavior
- BpmnJobBehavior(KeyGenerator, JobState, Writers, ExpressionProcessor, BpmnStateBehavior, BpmnIncidentBehavior, JobMetrics) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnJobBehavior
- bpmnProcessId() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- bpmnProcessId() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- bpmnProcessId() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- bpmnProcessId() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- bpmnProcessId(String) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- bpmnProcessId(String) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- bpmnProcessId(String) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- bpmnProcessId(String) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- bpmnProcessIdCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- bpmnProcessIdCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- bpmnProcessIdCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- bpmnProcessIdCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- bpmnProcessIdCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- bpmnProcessIdCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- bpmnProcessIdCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- bpmnProcessIdCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- bpmnProcessIdHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- bpmnProcessIdHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- bpmnProcessIdHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- bpmnProcessIdHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- bpmnProcessIdHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- bpmnProcessIdHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- bpmnProcessIdHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- bpmnProcessIdHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- bpmnProcessIdId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- bpmnProcessIdId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- bpmnProcessIdId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- bpmnProcessIdId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- bpmnProcessIdId() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- bpmnProcessIdId() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- bpmnProcessIdId() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- bpmnProcessIdId() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- bpmnProcessIdLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- bpmnProcessIdLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- bpmnProcessIdLength() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- bpmnProcessIdLength() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- bpmnProcessIdMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- bpmnProcessIdMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- bpmnProcessIdMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- bpmnProcessIdMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- bpmnProcessIdMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- bpmnProcessIdMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- bpmnProcessIdMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- bpmnProcessIdMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- bpmnProcessIdSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- bpmnProcessIdSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- bpmnProcessIdSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- bpmnProcessIdSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- BpmnProcessingException - Exception in io.camunda.zeebe.engine.processing.bpmn
-
Something went wrong during the process processing.
- BpmnProcessingException(BpmnElementContext, String) - Constructor for exception io.camunda.zeebe.engine.processing.bpmn.BpmnProcessingException
-
The failure message of the exception is build from the given context and the message.
- BpmnProcessResultSenderBehavior - Class in io.camunda.zeebe.engine.processing.bpmn.behavior
- BpmnProcessResultSenderBehavior(ZeebeState, TypedResponseWriter) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnProcessResultSenderBehavior
- BpmnStateBehavior - Class in io.camunda.zeebe.engine.processing.bpmn.behavior
- BpmnStateBehavior(ZeebeState, VariableBehavior) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateBehavior
- BpmnStateTransitionBehavior - Class in io.camunda.zeebe.engine.processing.bpmn.behavior
- BpmnStateTransitionBehavior(KeyGenerator, BpmnStateBehavior, ProcessEngineMetrics, Function<BpmnElementType, BpmnElementContainerProcessor<ExecutableFlowElement>>, Writers, ElementInstanceState) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateTransitionBehavior
- BpmnStreamProcessor - Class in io.camunda.zeebe.engine.processing.bpmn
- BpmnStreamProcessor(ExpressionProcessor, CatchEventBehavior, VariableBehavior, EventTriggerBehavior, MutableZeebeState, Writers, JobMetrics) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.BpmnStreamProcessor
- BpmnTransformer - Class in io.camunda.zeebe.engine.processing.deployment.model.transformation
- BpmnTransformer(ExpressionLanguage) - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.transformation.BpmnTransformer
- BpmnValidator - Class in io.camunda.zeebe.engine.processing.deployment.transform
- BpmnValidator(ExpressionLanguage, ExpressionProcessor) - Constructor for class io.camunda.zeebe.engine.processing.deployment.transform.BpmnValidator
- BpmnVariableMappingBehavior - Class in io.camunda.zeebe.engine.processing.bpmn.behavior
- BpmnVariableMappingBehavior(ExpressionProcessor, ZeebeState, VariableBehavior) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnVariableMappingBehavior
- buffer() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- buffer() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- buffer() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- buffer() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- buffer() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- buffer() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- buffer() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- buffer() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- buffer() - Method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- buffer() - Method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- buffer() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- buffer() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- buffer() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- buffer() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- buffer() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- buffer() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- buffer() - Method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- buffer() - Method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingEncoder
- bufferedMessageStartEventBehavior() - Method in interface io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBehaviors
- bufferedMessageStartEventBehavior() - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBehaviorsImpl
- BufferedStartMessageEventStateApplier - Class in io.camunda.zeebe.engine.state.appliers
- BufferedStartMessageEventStateApplier(ProcessState, MutableMessageState) - Constructor for class io.camunda.zeebe.engine.state.appliers.BufferedStartMessageEventStateApplier
- build() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorBuilder
- build(ExpressionLanguage) - Method in class io.camunda.zeebe.engine.processing.deployment.model.validation.ZeebeExpressionValidator.Builder
- builder() - Static method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- Builder(Class<T>) - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.validation.ZeebeExpressionValidator.Builder
- BYTE_ORDER - Static variable in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- BYTE_ORDER - Static variable in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- BYTE_ORDER - Static variable in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- BYTE_ORDER - Static variable in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- BYTE_ORDER - Static variable in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- BYTE_ORDER - Static variable in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- BYTE_ORDER - Static variable in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- BYTE_ORDER - Static variable in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- BYTE_ORDER - Static variable in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- BYTE_ORDER - Static variable in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- BYTE_ORDER - Static variable in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- BYTE_ORDER - Static variable in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- BYTE_ORDER - Static variable in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- BYTE_ORDER - Static variable in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- BYTE_ORDER - Static variable in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- BYTE_ORDER - Static variable in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- BYTE_ORDER - Static variable in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- BYTE_ORDER - Static variable in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingEncoder
C
- CallActivityProcessor - Class in io.camunda.zeebe.engine.processing.bpmn.container
- CallActivityProcessor(BpmnBehaviors) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.container.CallActivityProcessor
- CallActivityTransformer - Class in io.camunda.zeebe.engine.processing.deployment.model.transformer
- CallActivityTransformer() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.transformer.CallActivityTransformer
- canBeCompleted(BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateBehavior
- canBeTerminated(BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateBehavior
- cancel(long, JobRecord) - Method in class io.camunda.zeebe.engine.state.instance.DbJobState
- cancel(long, JobRecord) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableJobState
- cancelJob(BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnJobBehavior
- CancelProcessInstanceHandler - Class in io.camunda.zeebe.engine.processing.processinstance
- CancelProcessInstanceHandler() - Constructor for class io.camunda.zeebe.engine.processing.processinstance.CancelProcessInstanceHandler
- CancelTimerProcessor - Class in io.camunda.zeebe.engine.processing.timer
- CancelTimerProcessor(TimerInstanceState, StateWriter, TypedRejectionWriter) - Constructor for class io.camunda.zeebe.engine.processing.timer.CancelTimerProcessor
- canTerminate() - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- canTerminate(ProcessInstanceIntent) - Static method in class io.camunda.zeebe.engine.processing.bpmn.ProcessInstanceLifecycle
- canTransition(ProcessInstanceIntent, ProcessInstanceIntent) - Static method in class io.camunda.zeebe.engine.processing.bpmn.ProcessInstanceLifecycle
- canTriggerElement(ElementInstance) - Method in class io.camunda.zeebe.engine.processing.common.EventHandle
- CatchEventAnalyzer - Class in io.camunda.zeebe.engine.state.analyzers
-
Helper class that analyzes a process instance at runtime.
- CatchEventAnalyzer(ProcessState, ElementInstanceState) - Constructor for class io.camunda.zeebe.engine.state.analyzers.CatchEventAnalyzer
- CatchEventAnalyzer.CatchEventTuple - Class in io.camunda.zeebe.engine.state.analyzers
- CatchEventBehavior - Class in io.camunda.zeebe.engine.processing.common
- CatchEventBehavior(MutableZeebeState, ExpressionProcessor, SubscriptionCommandSender, StateWriter, DueDateTimerChecker, int) - Constructor for class io.camunda.zeebe.engine.processing.common.CatchEventBehavior
- CatchEventTransformer - Class in io.camunda.zeebe.engine.processing.deployment.model.transformer
- CatchEventTransformer() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.transformer.CatchEventTransformer
- CatchEventTuple() - Constructor for class io.camunda.zeebe.engine.state.analyzers.CatchEventAnalyzer.CatchEventTuple
- clear() - Method in class io.camunda.zeebe.engine.processing.message.Subscriptions
- clear() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.sideeffect.SideEffectQueue
- clone() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.TypedEventImpl
- close() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ReplayStateMachine
- close() - Method in class io.camunda.zeebe.engine.state.query.StateQueryService
- closeAsync() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- ClosedServiceException() - Constructor for exception io.camunda.zeebe.engine.state.QueryService.ClosedServiceException
-
Deprecated.
- closeMessageSubscription(int, long, long, DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.message.command.SubscriptionCommandSender
- CloseMessageSubscriptionCommand - Class in io.camunda.zeebe.engine.processing.message.command
- CloseMessageSubscriptionCommand() - Constructor for class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionCommand
- CloseMessageSubscriptionDecoder - Class in io.camunda.zeebe.engine.processing.message.command
- CloseMessageSubscriptionDecoder() - Constructor for class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- CloseMessageSubscriptionEncoder - Class in io.camunda.zeebe.engine.processing.message.command
- CloseMessageSubscriptionEncoder() - Constructor for class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- closeOnCorrelate() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- closeOnCorrelate() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- closeOnCorrelate(BooleanType) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- closeOnCorrelate(BooleanType) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- closeOnCorrelateEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- closeOnCorrelateEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- closeOnCorrelateEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- closeOnCorrelateEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- closeOnCorrelateEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- closeOnCorrelateEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- closeOnCorrelateEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- closeOnCorrelateEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- closeOnCorrelateId() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- closeOnCorrelateId() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- closeOnCorrelateId() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- closeOnCorrelateId() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- closeOnCorrelateMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- closeOnCorrelateMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- closeOnCorrelateMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- closeOnCorrelateMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- closeOnCorrelateRaw() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- closeOnCorrelateRaw() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- closeOnCorrelateSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- closeOnCorrelateSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- closeOnCorrelateSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- closeOnCorrelateSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- closeProcessMessageSubscription(long, long, DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.message.command.SubscriptionCommandSender
- CloseProcessMessageSubscriptionCommand - Class in io.camunda.zeebe.engine.processing.message.command
- CloseProcessMessageSubscriptionCommand() - Constructor for class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionCommand
- CloseProcessMessageSubscriptionDecoder - Class in io.camunda.zeebe.engine.processing.message.command
- CloseProcessMessageSubscriptionDecoder() - Constructor for class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- CloseProcessMessageSubscriptionEncoder - Class in io.camunda.zeebe.engine.processing.message.command
- CloseProcessMessageSubscriptionEncoder() - Constructor for class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- command() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.Writers
- CommandEntry(long, String, long) - Constructor for class io.camunda.zeebe.engine.state.message.TransientSubscriptionCommandState.CommandEntry
- CommandProcessor<T extends UnifiedRecordValue> - Interface in io.camunda.zeebe.engine.processing.streamprocessor
-
High-level record processor abstraction that implements the common behavior of most command-handling processors.
- CommandProcessor.CommandControl<T> - Interface in io.camunda.zeebe.engine.processing.streamprocessor
- CommandProcessorImpl<T extends UnifiedRecordValue> - Class in io.camunda.zeebe.engine.processing.streamprocessor
-
Decorates a command processor with simple accept and reject logic.
- CommandProcessorImpl(CommandProcessor<T>, KeyGenerator, Writers) - Constructor for class io.camunda.zeebe.engine.processing.streamprocessor.CommandProcessorImpl
- commandResponseWriter(CommandResponseWriter) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- commandResponseWriter(CommandResponseWriter) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorBuilder
- CommandResponseWriter - Interface in io.camunda.zeebe.engine.processing.streamprocessor.writers
- commandsProcessed() - Method in class io.camunda.zeebe.engine.metrics.StreamProcessorMetrics
-
We only process commands.
- compareTo(TransientSubscriptionCommandState.CommandEntry) - Method in class io.camunda.zeebe.engine.state.message.TransientSubscriptionCommandState.CommandEntry
- complete(long, JobRecord) - Method in class io.camunda.zeebe.engine.state.instance.DbJobState
- complete(long, JobRecord) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableJobState
- CompleteDeploymentDistributionProcessor - Class in io.camunda.zeebe.engine.processing.deployment.distribute
- CompleteDeploymentDistributionProcessor(DeploymentState, Writers) - Constructor for class io.camunda.zeebe.engine.processing.deployment.distribute.CompleteDeploymentDistributionProcessor
- completeElement(BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateTransitionBehavior
- configureSourceContext(long) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.TypedStreamWriterProxy
- configureSourceContext(long) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.NoopTypedStreamWriter
- configureSourceContext(long) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedStreamWriter
- configureSourceContext(long) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedStreamWriterImpl
- contains(DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.message.Subscriptions
- ContextProcessTransformer - Class in io.camunda.zeebe.engine.processing.deployment.model.transformer
- ContextProcessTransformer() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.transformer.ContextProcessTransformer
- CopiedRecords - Class in io.camunda.zeebe.engine.processing.streamprocessor
- CopiedRecords() - Constructor for class io.camunda.zeebe.engine.processing.streamprocessor.CopiedRecords
- copy(long, ProcessInstanceRecord, ProcessInstanceIntent) - Method in interface io.camunda.zeebe.engine.processing.bpmn.BpmnElementContext
- copy(long, ProcessInstanceRecord, ProcessInstanceIntent) - Method in class io.camunda.zeebe.engine.processing.bpmn.BpmnElementContextImpl
- copyVariablesToProcessInstance(long, long, DeployedProcess) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateBehavior
- correlateMessage(BpmnElementContext, DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBufferedMessageStartEventBehavior
- correlateMessageSubscription(int, long, long, DirectBuffer, DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.message.command.SubscriptionCommandSender
- CorrelateMessageSubscriptionCommand - Class in io.camunda.zeebe.engine.processing.message.command
- CorrelateMessageSubscriptionCommand() - Constructor for class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionCommand
- CorrelateMessageSubscriptionDecoder - Class in io.camunda.zeebe.engine.processing.message.command
- CorrelateMessageSubscriptionDecoder() - Constructor for class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- CorrelateMessageSubscriptionEncoder - Class in io.camunda.zeebe.engine.processing.message.command
- CorrelateMessageSubscriptionEncoder() - Constructor for class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- correlateNextMessage(long, MessageSubscriptionRecord, Consumer<SideEffectProducer>) - Method in class io.camunda.zeebe.engine.processing.message.MessageCorrelator
- correlateProcessMessageSubscription(long, long, DirectBuffer, DirectBuffer, long, DirectBuffer, DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.message.command.SubscriptionCommandSender
- CorrelateProcessMessageSubscriptionCommand - Class in io.camunda.zeebe.engine.processing.message.command
- CorrelateProcessMessageSubscriptionCommand() - Constructor for class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionCommand
- CorrelateProcessMessageSubscriptionDecoder - Class in io.camunda.zeebe.engine.processing.message.command
- CorrelateProcessMessageSubscriptionDecoder() - Constructor for class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- CorrelateProcessMessageSubscriptionEncoder - Class in io.camunda.zeebe.engine.processing.message.command
- CorrelateProcessMessageSubscriptionEncoder() - Constructor for class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- correlationKey() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- correlationKey() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- correlationKey() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- correlationKey(String) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- correlationKey(String) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- correlationKey(String) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- correlationKeyCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- correlationKeyCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- correlationKeyCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- correlationKeyCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- correlationKeyCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- correlationKeyCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- correlationKeyHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- correlationKeyHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- correlationKeyHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- correlationKeyHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- correlationKeyHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- correlationKeyHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- correlationKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- correlationKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- correlationKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- correlationKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- correlationKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- correlationKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- correlationKeyLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- correlationKeyLength() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- correlationKeyLength() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- correlationKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- correlationKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- correlationKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- correlationKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- correlationKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- correlationKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- correlationKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- correlationKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- correlationKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- countBlacklistedInstance() - Method in class io.camunda.zeebe.engine.metrics.BlacklistMetrics
- create(long, JobRecord) - Method in class io.camunda.zeebe.engine.state.instance.DbJobState
- create(long, JobRecord) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableJobState
- createChildProcessInstance(DeployedProcess, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateTransitionBehavior
- createContext() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- createCopiedRecord(int, LoggedEvent) - Static method in class io.camunda.zeebe.engine.processing.streamprocessor.CopiedRecords
- createEngineProcessors(ProcessingContext, int, SubscriptionCommandSender, DeploymentDistributor, DeploymentResponder, Consumer<String>) - Static method in class io.camunda.zeebe.engine.processing.EngineProcessors
- createIfNotExists(long, Collection<DirectBuffer>) - Method in class io.camunda.zeebe.engine.state.instance.DbEventScopeInstanceState
- createIfNotExists(long, Collection<DirectBuffer>) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableEventScopeInstanceState
-
Creates a new event scope instance in the state
- createIncident(long, IncidentRecord) - Method in class io.camunda.zeebe.engine.state.instance.DbIncidentState
- createIncident(long, IncidentRecord) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableIncidentState
- createIncident(Failure, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnIncidentBehavior
- createIncident(Tuple<Failure, BpmnElementContext>) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnIncidentBehavior
- createInstance(long, Collection<DirectBuffer>) - Method in class io.camunda.zeebe.engine.state.instance.DbEventScopeInstanceState
- createInstance(long, Collection<DirectBuffer>) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableEventScopeInstanceState
-
Creates a new event scope instance in the state
- createNewJob(BpmnElementContext, ExecutableJobWorkerElement) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnJobBehavior
- CreateProcessInstanceProcessor - Class in io.camunda.zeebe.engine.processing.processinstance
- CreateProcessInstanceProcessor(ProcessState, KeyGenerator, Writers, VariableBehavior) - Constructor for class io.camunda.zeebe.engine.processing.processinstance.CreateProcessInstanceProcessor
- CreateProcessInstanceWithResultProcessor - Class in io.camunda.zeebe.engine.processing.processinstance
- CreateProcessInstanceWithResultProcessor(CreateProcessInstanceProcessor, MutableElementInstanceState) - Constructor for class io.camunda.zeebe.engine.processing.processinstance.CreateProcessInstanceWithResultProcessor
- createProcessors(ProcessingContext) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.TypedRecordProcessorFactory
-
Creates typed record processors with the given context.
- createScope(long, long) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableVariableState
- createScope(long, long) - Method in class io.camunda.zeebe.engine.state.variable.DbVariableState
- createTransformer() - Static method in class io.camunda.zeebe.engine.processing.deployment.model.BpmnFactory
- createValidator(ExpressionProcessor) - Static method in class io.camunda.zeebe.engine.processing.deployment.model.BpmnFactory
D
- DbBlackListState - Class in io.camunda.zeebe.engine.state.processing
- DbBlackListState(ZeebeDb<ZbColumnFamilies>, TransactionContext, int) - Constructor for class io.camunda.zeebe.engine.state.processing.DbBlackListState
- DbDeploymentState - Class in io.camunda.zeebe.engine.state.deployment
- DbDeploymentState(ZeebeDb<ZbColumnFamilies>, TransactionContext) - Constructor for class io.camunda.zeebe.engine.state.deployment.DbDeploymentState
- DbElementInstanceState - Class in io.camunda.zeebe.engine.state.instance
- DbElementInstanceState(ZeebeDb<ZbColumnFamilies>, TransactionContext, MutableVariableState) - Constructor for class io.camunda.zeebe.engine.state.instance.DbElementInstanceState
- DbElementInstanceState.RecordVisitor - Interface in io.camunda.zeebe.engine.state.instance
- DbEventScopeInstanceState - Class in io.camunda.zeebe.engine.state.instance
- DbEventScopeInstanceState(ZeebeDb<ZbColumnFamilies>, TransactionContext) - Constructor for class io.camunda.zeebe.engine.state.instance.DbEventScopeInstanceState
- DbIncidentState - Class in io.camunda.zeebe.engine.state.instance
- DbIncidentState(ZeebeDb<ZbColumnFamilies>, TransactionContext, int) - Constructor for class io.camunda.zeebe.engine.state.instance.DbIncidentState
- DbJobState - Class in io.camunda.zeebe.engine.state.instance
- DbJobState(ZeebeDb<ZbColumnFamilies>, TransactionContext, int) - Constructor for class io.camunda.zeebe.engine.state.instance.DbJobState
- DbKeyGenerator - Class in io.camunda.zeebe.engine.state.processing
- DbKeyGenerator(int, ZeebeDb, TransactionContext) - Constructor for class io.camunda.zeebe.engine.state.processing.DbKeyGenerator
-
Initializes the key state with the corresponding partition id, so that unique keys are generated over all partitions.
- DbLastProcessedPositionState - Class in io.camunda.zeebe.engine.state.processing
- DbLastProcessedPositionState(ZeebeDb<ZbColumnFamilies>, TransactionContext) - Constructor for class io.camunda.zeebe.engine.state.processing.DbLastProcessedPositionState
- DbMessageStartEventSubscriptionState - Class in io.camunda.zeebe.engine.state.message
- DbMessageStartEventSubscriptionState(ZeebeDb<ZbColumnFamilies>, TransactionContext) - Constructor for class io.camunda.zeebe.engine.state.message.DbMessageStartEventSubscriptionState
- DbMessageState - Class in io.camunda.zeebe.engine.state.message
- DbMessageState(ZeebeDb<ZbColumnFamilies>, TransactionContext) - Constructor for class io.camunda.zeebe.engine.state.message.DbMessageState
- DbMessageSubscriptionState - Class in io.camunda.zeebe.engine.state.message
- DbMessageSubscriptionState(ZeebeDb<ZbColumnFamilies>, TransactionContext) - Constructor for class io.camunda.zeebe.engine.state.message.DbMessageSubscriptionState
- DbMigrationController - Class in io.camunda.zeebe.engine.state.migration
- DbMigrationController() - Constructor for class io.camunda.zeebe.engine.state.migration.DbMigrationController
- DbMigrationState - Class in io.camunda.zeebe.engine.state.migration
- DbMigrationState(ZeebeDb<ZbColumnFamilies>, TransactionContext) - Constructor for class io.camunda.zeebe.engine.state.migration.DbMigrationState
- DbMigrator - Interface in io.camunda.zeebe.engine.state.migration
- DbMigratorImpl - Class in io.camunda.zeebe.engine.state.migration
- DbMigratorImpl(MutableZeebeState) - Constructor for class io.camunda.zeebe.engine.state.migration.DbMigratorImpl
- DbProcessMessageSubscriptionState - Class in io.camunda.zeebe.engine.state.message
- DbProcessMessageSubscriptionState(ZeebeDb<ZbColumnFamilies>, TransactionContext) - Constructor for class io.camunda.zeebe.engine.state.message.DbProcessMessageSubscriptionState
- DbProcessState - Class in io.camunda.zeebe.engine.state.deployment
- DbProcessState(ZeebeDb<ZbColumnFamilies>, TransactionContext) - Constructor for class io.camunda.zeebe.engine.state.deployment.DbProcessState
- DbTimerInstanceState - Class in io.camunda.zeebe.engine.state.instance
- DbTimerInstanceState(ZeebeDb<ZbColumnFamilies>, TransactionContext) - Constructor for class io.camunda.zeebe.engine.state.instance.DbTimerInstanceState
- DbVariableState - Class in io.camunda.zeebe.engine.state.variable
- DbVariableState(ZeebeDb<ZbColumnFamilies>, TransactionContext) - Constructor for class io.camunda.zeebe.engine.state.variable.DbVariableState
- decrementActiveSequenceFlows() - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- decrementChildCount() - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- decrementNumberOfTakenSequenceFlows(long, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.instance.DbElementInstanceState
- decrementNumberOfTakenSequenceFlows(long, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableElementInstanceState
-
Decrements the numbers that counts how often a sequence flow of the given gateway has been taken.
- DEFAULT - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- DEFAULT_DB_METRIC_EXPORTER_FACTORY - Static variable in class io.camunda.zeebe.engine.state.DefaultZeebeDbFactory
- defaultFactory() - Static method in class io.camunda.zeebe.engine.state.DefaultZeebeDbFactory
-
Returns the default zeebe database factory, which is used in most of the places except for the exporters.
- defaultFactory(RocksDbConfiguration) - Static method in class io.camunda.zeebe.engine.state.DefaultZeebeDbFactory
-
Returns the default zeebe database factory which is used in the broker.
- defaultFactory(Properties) - Static method in class io.camunda.zeebe.engine.state.DefaultZeebeDbFactory
-
Returns the default zeebe database factory, which is used in most of the places except for the exporters.
- DefaultZeebeDbFactory - Class in io.camunda.zeebe.engine.state
- DefaultZeebeDbFactory() - Constructor for class io.camunda.zeebe.engine.state.DefaultZeebeDbFactory
- delete(long, JobRecord) - Method in class io.camunda.zeebe.engine.state.instance.DbJobState
- delete(long, JobRecord) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableJobState
- deleteIncident(long) - Method in class io.camunda.zeebe.engine.state.instance.DbIncidentState
- deleteIncident(long) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableIncidentState
- deleteInstance(long) - Method in class io.camunda.zeebe.engine.state.instance.DbEventScopeInstanceState
- deleteInstance(long) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableEventScopeInstanceState
-
Delete an event scope from the state.
- deleteTrigger(long, long) - Method in class io.camunda.zeebe.engine.state.instance.DbEventScopeInstanceState
- deleteTrigger(long, long) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableEventScopeInstanceState
-
Deletes an event trigger by key and scope key.
- DeployedProcess - Class in io.camunda.zeebe.engine.state.deployment
- DeployedProcess(ExecutableProcess, PersistedProcess) - Constructor for class io.camunda.zeebe.engine.state.deployment.DeployedProcess
- DEPLOYMENT_RAW - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- DeploymentCreatedApplier - Class in io.camunda.zeebe.engine.state.appliers
- DeploymentCreatedApplier(MutableDeploymentState) - Constructor for class io.camunda.zeebe.engine.state.appliers.DeploymentCreatedApplier
- DeploymentCreateProcessor - Class in io.camunda.zeebe.engine.processing.deployment
- DeploymentCreateProcessor(ZeebeState, CatchEventBehavior, ExpressionProcessor, int, Writers, ActorControl, DeploymentDistributor, KeyGenerator) - Constructor for class io.camunda.zeebe.engine.processing.deployment.DeploymentCreateProcessor
- DeploymentDistributedApplier - Class in io.camunda.zeebe.engine.state.appliers
- DeploymentDistributedApplier(MutableProcessState) - Constructor for class io.camunda.zeebe.engine.state.appliers.DeploymentDistributedApplier
- DeploymentDistributeProcessor - Class in io.camunda.zeebe.engine.processing.deployment.distribute
- DeploymentDistributeProcessor(ProcessState, MessageStartEventSubscriptionState, DeploymentResponder, int, Writers, KeyGenerator) - Constructor for class io.camunda.zeebe.engine.processing.deployment.distribute.DeploymentDistributeProcessor
- DeploymentDistributionApplier - Class in io.camunda.zeebe.engine.state.appliers
- DeploymentDistributionApplier(MutableZeebeState) - Constructor for class io.camunda.zeebe.engine.state.appliers.DeploymentDistributionApplier
- DeploymentDistributionBehavior - Class in io.camunda.zeebe.engine.processing.deployment.distribute
- DeploymentDistributionBehavior(Writers, int, DeploymentDistributor, ActorControl) - Constructor for class io.camunda.zeebe.engine.processing.deployment.distribute.DeploymentDistributionBehavior
- DeploymentDistributionCompletedApplier - Class in io.camunda.zeebe.engine.state.appliers
- DeploymentDistributionCompletedApplier(MutableDeploymentState) - Constructor for class io.camunda.zeebe.engine.state.appliers.DeploymentDistributionCompletedApplier
- DeploymentDistributor - Interface in io.camunda.zeebe.engine.processing.deployment.distribute
- DeploymentFullyDistributedApplier - Class in io.camunda.zeebe.engine.state.appliers
- DeploymentFullyDistributedApplier(MutableDeploymentState) - Constructor for class io.camunda.zeebe.engine.state.appliers.DeploymentFullyDistributedApplier
- DeploymentRaw - Class in io.camunda.zeebe.engine.state.deployment
-
DeplyomentRecord wrapper to store the record in the State.
- DeploymentRaw() - Constructor for class io.camunda.zeebe.engine.state.deployment.DeploymentRaw
- DeploymentRedistributor - Class in io.camunda.zeebe.engine.processing.deployment.distribute
- DeploymentRedistributor(int, DeploymentDistributor, DeploymentState) - Constructor for class io.camunda.zeebe.engine.processing.deployment.distribute.DeploymentRedistributor
- DeploymentResponder - Interface in io.camunda.zeebe.engine.processing.deployment
- DeploymentState - Interface in io.camunda.zeebe.engine.state.immutable
- DeploymentState.PendingDeploymentVisitor - Interface in io.camunda.zeebe.engine.state.immutable
- DeploymentTransformer - Class in io.camunda.zeebe.engine.processing.deployment.transform
- DeploymentTransformer(StateWriter, ZeebeState, ExpressionProcessor, KeyGenerator) - Constructor for class io.camunda.zeebe.engine.processing.deployment.transform.DeploymentTransformer
- Digest - Class in io.camunda.zeebe.engine.state.deployment
- Digest() - Constructor for class io.camunda.zeebe.engine.state.deployment.Digest
- disable(long, JobRecord) - Method in class io.camunda.zeebe.engine.state.instance.DbJobState
- disable(long, JobRecord) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableJobState
- disableLogStreamWriter() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- distributeDeployment(DeploymentRecord, long) - Method in class io.camunda.zeebe.engine.processing.deployment.distribute.DeploymentDistributionBehavior
- distributeDeploymentToPartition(int, long, DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.deployment.distribute.DeploymentDistributionBehavior
- DocumentEntry - Class in io.camunda.zeebe.engine.state.variable
- DueDateChecker - Class in io.camunda.zeebe.engine.processing.scheduled
- DueDateChecker(long, Function<TypedCommandWriter, Long>) - Constructor for class io.camunda.zeebe.engine.processing.scheduled.DueDateChecker
- DueDateTimerChecker - Class in io.camunda.zeebe.engine.processing.timer
- DueDateTimerChecker(TimerInstanceState) - Constructor for class io.camunda.zeebe.engine.processing.timer.DueDateTimerChecker
E
- ELEMENT_INSTANCE_CHILD_PARENT - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- ELEMENT_INSTANCE_KEY - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- ELEMENT_INSTANCE_PARENT_CHILD - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- ElementInstance - Class in io.camunda.zeebe.engine.state.instance
- ElementInstance(long, ElementInstance, ProcessInstanceIntent, ProcessInstanceRecord) - Constructor for class io.camunda.zeebe.engine.state.instance.ElementInstance
- ElementInstance(long, ProcessInstanceIntent, ProcessInstanceRecord) - Constructor for class io.camunda.zeebe.engine.state.instance.ElementInstance
- elementInstanceActivated(BpmnElementContext) - Method in class io.camunda.zeebe.engine.metrics.ProcessEngineMetrics
- elementInstanceCompleted(BpmnElementContext) - Method in class io.camunda.zeebe.engine.metrics.ProcessEngineMetrics
- elementInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- elementInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- elementInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- elementInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- elementInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- elementInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- elementInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- elementInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- elementInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- elementInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- elementInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- elementInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- elementInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- elementInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- elementInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- elementInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- elementInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- elementInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- elementInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- elementInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- elementInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- elementInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- elementInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- elementInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- elementInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- elementInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- elementInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- elementInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- elementInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- elementInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- elementInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- elementInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- elementInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- elementInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- elementInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- elementInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- elementInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- elementInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- elementInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- elementInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- elementInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- elementInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- elementInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- elementInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- elementInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- elementInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- elementInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- elementInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- elementInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- elementInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- elementInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- elementInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- elementInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- elementInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- elementInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- elementInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- elementInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- elementInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- elementInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- elementInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- elementInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- elementInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- elementInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- elementInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- elementInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- elementInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- elementInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- elementInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- elementInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- elementInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- elementInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- elementInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- elementInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- elementInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- elementInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- elementInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- elementInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- elementInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- elementInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- elementInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- elementInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- elementInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- elementInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- elementInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- elementInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- elementInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- elementInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- elementInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- elementInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- elementInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- elementInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- elementInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- elementInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- elementInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- elementInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- elementInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- elementInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- elementInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- elementInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- elementInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- elementInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- elementInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- elementInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- elementInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- elementInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- elementInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- elementInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- elementInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- ElementInstanceState - Interface in io.camunda.zeebe.engine.state.immutable
- elementInstanceTerminated(BpmnElementContext) - Method in class io.camunda.zeebe.engine.metrics.ProcessEngineMetrics
- enableLogStreamWriter() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- ENCODED_LENGTH - Static variable in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- ENCODED_LENGTH - Static variable in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- ENCODED_LENGTH - Static variable in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- ENCODED_LENGTH - Static variable in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingEncoder
- encodedLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- encodedLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- encodedLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- encodedLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- encodedLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- encodedLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- encodedLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- encodedLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- encodedLength() - Method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- encodedLength() - Method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- encodedLength() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- encodedLength() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- encodedLength() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- encodedLength() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- encodedLength() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- encodedLength() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- encodedLength() - Method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- encodedLength() - Method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingEncoder
- EndEventProcessor - Class in io.camunda.zeebe.engine.processing.bpmn.event
- EndEventProcessor(BpmnBehaviors) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.event.EndEventProcessor
- EndEventTransformer - Class in io.camunda.zeebe.engine.processing.deployment.model.transformer
- EndEventTransformer() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.transformer.EndEventTransformer
- EngineProcessors - Class in io.camunda.zeebe.engine.processing
- EngineProcessors() - Constructor for class io.camunda.zeebe.engine.processing.EngineProcessors
- EPOCH - Enum constant in enum io.camunda.zeebe.engine.processing.message.command.MetaAttribute
-
The epoch or start of time.
- equals(Object) - Method in class io.camunda.zeebe.engine.processing.common.Failure
- equals(Object) - Method in class io.camunda.zeebe.engine.state.instance.AwaitProcessInstanceResultMetadata
- equals(Object) - Method in class io.camunda.zeebe.engine.state.instance.EventScopeInstance
- equals(Object) - Method in class io.camunda.zeebe.engine.state.instance.EventTrigger
- equals(Object) - Method in class io.camunda.zeebe.engine.state.message.TransientSubscriptionCommandState.CommandEntry
- equals(Object) - Method in class io.camunda.zeebe.engine.state.variable.DocumentEntry
- ERROR_THROWN - Enum constant in enum io.camunda.zeebe.engine.state.immutable.JobState.State
- ErrorCreatedApplier - Class in io.camunda.zeebe.engine.state.appliers
- ErrorCreatedApplier(MutableBlackListState) - Constructor for class io.camunda.zeebe.engine.state.appliers.ErrorCreatedApplier
- ErrorTransformer - Class in io.camunda.zeebe.engine.processing.deployment.model.transformer
- ErrorTransformer() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.transformer.ErrorTransformer
- evaluateAnyExpression(Expression, long) - Method in class io.camunda.zeebe.engine.processing.common.ExpressionProcessor
-
Evaluates the given expression and returns the result no matter the type.
- evaluateArrayExpression(Expression, long) - Method in class io.camunda.zeebe.engine.processing.common.ExpressionProcessor
-
Evaluates the given expression and returns the result as a list.
- evaluateArrayOfStringsExpression(Expression, long) - Method in class io.camunda.zeebe.engine.processing.common.ExpressionProcessor
-
Evaluates the given expression and returns the result as a list of strings.
- evaluateBooleanExpression(Expression, long) - Method in class io.camunda.zeebe.engine.processing.common.ExpressionProcessor
-
Evaluates the given expression and returns the result as boolean.
- evaluateDateTimeExpression(Expression, Long) - Method in class io.camunda.zeebe.engine.processing.common.ExpressionProcessor
-
Evaluates the given expression and returns the result as ZonedDateTime.
- evaluateIntervalExpression(Expression, long) - Method in class io.camunda.zeebe.engine.processing.common.ExpressionProcessor
-
Evaluates the given expression and returns the result as an Interval.
- evaluateLongExpression(Expression, long) - Method in class io.camunda.zeebe.engine.processing.common.ExpressionProcessor
-
Evaluates the given expression and returns the result as long.
- evaluateMessageCorrelationKeyExpression(Expression, long) - Method in class io.camunda.zeebe.engine.processing.common.ExpressionProcessor
-
Evaluates the given expression and returns the result as String.
- evaluateStringExpression(Expression, long) - Method in class io.camunda.zeebe.engine.processing.common.ExpressionProcessor
-
Evaluates the given expression and returns the result as string.
- evaluateStringExpressionAsDirectBuffer(Expression, long) - Method in class io.camunda.zeebe.engine.processing.common.ExpressionProcessor
-
Evaluates the given expression and returns the result as string wrapped in
DirectBuffer
. - evaluateVariableMappingExpression(Expression, long) - Method in class io.camunda.zeebe.engine.processing.common.ExpressionProcessor
-
Evaluates the given expression of a variable mapping and returns the result as buffer.
- EvaluationException(String) - Constructor for exception io.camunda.zeebe.engine.processing.common.ExpressionProcessor.EvaluationException
- event() - Method in class io.camunda.zeebe.engine.metrics.ReplayMetrics
- EVENT_REGISTRY - Static variable in class io.camunda.zeebe.engine.processing.streamprocessor.TypedEventRegistry
- EVENT_SCOPE - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- EVENT_TRIGGER - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- eventApplier(EventApplier) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- EventApplier - Interface in io.camunda.zeebe.engine.state
-
Applies the state changes for a specific event.
- eventApplierFactory(Function<MutableZeebeState, EventApplier>) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorBuilder
- EventAppliers - Class in io.camunda.zeebe.engine.state.appliers
-
Applies state changes from events to the
MutableZeebeState
. - EventAppliers(MutableZeebeState) - Constructor for class io.camunda.zeebe.engine.state.appliers.EventAppliers
- EventApplyingStateWriter - Class in io.camunda.zeebe.engine.processing.streamprocessor.writers
-
A state writer that uses the event applier, to alter the state for each written event.
- EventApplyingStateWriter(TypedEventWriter, EventApplier) - Constructor for class io.camunda.zeebe.engine.processing.streamprocessor.writers.EventApplyingStateWriter
- EventBasedGatewayProcessor - Class in io.camunda.zeebe.engine.processing.bpmn.gateway
- EventBasedGatewayProcessor(BpmnBehaviors) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.gateway.EventBasedGatewayProcessor
- EventBasedGatewayTransformer - Class in io.camunda.zeebe.engine.processing.deployment.model.transformer
- EventBasedGatewayTransformer() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.transformer.EventBasedGatewayTransformer
- eventCache(RecordValues) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- EventFilter - Interface in io.camunda.zeebe.engine.processing.streamprocessor
-
Implement to control which events should be handled by a
StreamProcessor
. - EventHandle - Class in io.camunda.zeebe.engine.processing.common
- EventHandle(KeyGenerator, EventScopeInstanceState, Writers, ProcessState, EventTriggerBehavior) - Constructor for class io.camunda.zeebe.engine.processing.common.EventHandle
- eventPublicationBehavior() - Method in interface io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBehaviors
- eventPublicationBehavior() - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBehaviorsImpl
- EventScopeInstance - Class in io.camunda.zeebe.engine.state.instance
- EventScopeInstance() - Constructor for class io.camunda.zeebe.engine.state.instance.EventScopeInstance
- EventScopeInstance(EventScopeInstance) - Constructor for class io.camunda.zeebe.engine.state.instance.EventScopeInstance
- EventScopeInstanceState - Interface in io.camunda.zeebe.engine.state.immutable
- eventSkipped() - Method in class io.camunda.zeebe.engine.metrics.StreamProcessorMetrics
-
We skip events on processing.
- EventSubProcessInterruptionMarker - Class in io.camunda.zeebe.engine.state.appliers
- EventSubProcessInterruptionMarker(ProcessState, MutableElementInstanceState) - Constructor for class io.camunda.zeebe.engine.state.appliers.EventSubProcessInterruptionMarker
- EventSubProcessProcessor - Class in io.camunda.zeebe.engine.processing.bpmn.container
- EventSubProcessProcessor(BpmnBehaviors) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.container.EventSubProcessProcessor
- eventSubscriptionBehavior() - Method in interface io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBehaviors
- eventSubscriptionBehavior() - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBehaviorsImpl
- EventTrigger - Class in io.camunda.zeebe.engine.state.instance
- EventTrigger() - Constructor for class io.camunda.zeebe.engine.state.instance.EventTrigger
- EventTrigger(EventTrigger) - Constructor for class io.camunda.zeebe.engine.state.instance.EventTrigger
- EventTriggerBehavior - Class in io.camunda.zeebe.engine.processing.common
- EventTriggerBehavior(KeyGenerator, CatchEventBehavior, Writers, ZeebeState) - Constructor for class io.camunda.zeebe.engine.processing.common.EventTriggerBehavior
- ExclusiveGatewayProcessor - Class in io.camunda.zeebe.engine.processing.bpmn.gateway
- ExclusiveGatewayProcessor(BpmnBehaviors) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.gateway.ExclusiveGatewayProcessor
- ExclusiveGatewayTransformer - Class in io.camunda.zeebe.engine.processing.deployment.model.transformer
- ExclusiveGatewayTransformer() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.transformer.ExclusiveGatewayTransformer
- ExecutableActivity - Class in io.camunda.zeebe.engine.processing.deployment.model.element
- ExecutableActivity(String) - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableActivity
- ExecutableBoundaryEvent - Class in io.camunda.zeebe.engine.processing.deployment.model.element
- ExecutableBoundaryEvent(String) - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableBoundaryEvent
- ExecutableCallActivity - Class in io.camunda.zeebe.engine.processing.deployment.model.element
- ExecutableCallActivity(String) - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCallActivity
- ExecutableCatchEvent - Interface in io.camunda.zeebe.engine.processing.deployment.model.element
- ExecutableCatchEventElement - Class in io.camunda.zeebe.engine.processing.deployment.model.element
- ExecutableCatchEventElement(String) - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEventElement
- ExecutableCatchEventSupplier - Interface in io.camunda.zeebe.engine.processing.deployment.model.element
- ExecutableEndEvent - Class in io.camunda.zeebe.engine.processing.deployment.model.element
- ExecutableEndEvent(String) - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableEndEvent
- ExecutableError - Class in io.camunda.zeebe.engine.processing.deployment.model.element
- ExecutableError(String) - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableError
- ExecutableEventBasedGateway - Class in io.camunda.zeebe.engine.processing.deployment.model.element
- ExecutableEventBasedGateway(String) - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableEventBasedGateway
- ExecutableExclusiveGateway - Class in io.camunda.zeebe.engine.processing.deployment.model.element
- ExecutableExclusiveGateway(String) - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableExclusiveGateway
- ExecutableFlowElement - Interface in io.camunda.zeebe.engine.processing.deployment.model.element
- ExecutableFlowElementContainer - Class in io.camunda.zeebe.engine.processing.deployment.model.element
-
ExecutableFlowElementContainer is currently used to represent processes as well (
Process
), which may seem counter intuitive; at the moment, the reason is that sub processes are also modelled using the same class, and sub processes need to reuse the logic for both. - ExecutableFlowElementContainer(String) - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableFlowElementContainer
- ExecutableFlowNode - Class in io.camunda.zeebe.engine.processing.deployment.model.element
- ExecutableFlowNode(String) - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableFlowNode
- ExecutableIntermediateThrowEvent - Class in io.camunda.zeebe.engine.processing.deployment.model.element
- ExecutableIntermediateThrowEvent(String) - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableIntermediateThrowEvent
- ExecutableJobWorkerElement - Interface in io.camunda.zeebe.engine.processing.deployment.model.element
-
A representation of an element that is based on a job and should be processed by a job worker.
- ExecutableJobWorkerTask - Class in io.camunda.zeebe.engine.processing.deployment.model.element
- ExecutableJobWorkerTask(String) - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableJobWorkerTask
- ExecutableLoopCharacteristics - Class in io.camunda.zeebe.engine.processing.deployment.model.element
- ExecutableLoopCharacteristics(boolean, Optional<Expression>, Expression, Optional<DirectBuffer>, Optional<DirectBuffer>, Optional<Expression>) - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableLoopCharacteristics
- ExecutableMessage - Class in io.camunda.zeebe.engine.processing.deployment.model.element
- ExecutableMessage(String) - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableMessage
- ExecutableMultiInstanceBody - Class in io.camunda.zeebe.engine.processing.deployment.model.element
- ExecutableMultiInstanceBody(String, ExecutableLoopCharacteristics, ExecutableActivity) - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableMultiInstanceBody
- ExecutableProcess - Class in io.camunda.zeebe.engine.processing.deployment.model.element
-
Executable* prefix in order to avoid confusion with model API classes.
- ExecutableProcess(String) - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableProcess
- ExecutableReceiveTask - Class in io.camunda.zeebe.engine.processing.deployment.model.element
- ExecutableReceiveTask(String) - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableReceiveTask
- ExecutableSequenceFlow - Class in io.camunda.zeebe.engine.processing.deployment.model.element
- ExecutableSequenceFlow(String) - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableSequenceFlow
- ExecutableStartEvent - Class in io.camunda.zeebe.engine.processing.deployment.model.element
- ExecutableStartEvent(String) - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableStartEvent
- exist(DirectBuffer, DirectBuffer, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.immutable.MessageState
- exist(DirectBuffer, DirectBuffer, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.message.DbMessageState
- existActiveProcessInstance(DirectBuffer, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.immutable.MessageState
- existActiveProcessInstance(DirectBuffer, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.message.DbMessageState
- existMessageCorrelation(long, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.immutable.MessageState
- existMessageCorrelation(long, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.message.DbMessageState
- exists(long) - Method in interface io.camunda.zeebe.engine.state.immutable.JobState
- exists(long) - Method in class io.camunda.zeebe.engine.state.instance.DbJobState
- exists(MessageStartEventSubscriptionRecord) - Method in interface io.camunda.zeebe.engine.state.immutable.MessageStartEventSubscriptionState
- exists(MessageStartEventSubscriptionRecord) - Method in class io.camunda.zeebe.engine.state.message.DbMessageStartEventSubscriptionState
- existSubscriptionForElementInstance(long, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.immutable.MessageSubscriptionState
- existSubscriptionForElementInstance(long, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.immutable.ProcessMessageSubscriptionState
- existSubscriptionForElementInstance(long, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.message.DbMessageSubscriptionState
- existSubscriptionForElementInstance(long, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.message.DbProcessMessageSubscriptionState
- EXPORTER - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- expressionBehavior() - Method in interface io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBehaviors
- expressionBehavior() - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBehaviorsImpl
- ExpressionProcessor - Class in io.camunda.zeebe.engine.processing.common
- ExpressionProcessor(ExpressionLanguage, ExpressionProcessor.VariablesLookup) - Constructor for class io.camunda.zeebe.engine.processing.common.ExpressionProcessor
- ExpressionProcessor.EvaluationException - Exception in io.camunda.zeebe.engine.processing.common
- ExpressionProcessor.VariablesLookup - Interface in io.camunda.zeebe.engine.processing.common
- ExpressionTransformer - Class in io.camunda.zeebe.engine.processing.deployment.model.transformer
-
Utility class to help with transforming expressions from strings to objects (i.e.
- ExpressionVerification() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.validation.ZeebeExpressionValidator.ExpressionVerification
F
- fail(long, JobRecord) - Method in class io.camunda.zeebe.engine.state.instance.DbJobState
- fail(long, JobRecord) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableJobState
- FAILED - Enum constant in enum io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor.Phase
- FAILED - Enum constant in enum io.camunda.zeebe.engine.state.immutable.JobState.State
- Failure - Class in io.camunda.zeebe.engine.processing.common
-
Simple String wrapper for when something fails and a message needs to be used.
- Failure(String) - Constructor for class io.camunda.zeebe.engine.processing.common.Failure
- Failure(String, ErrorType) - Constructor for class io.camunda.zeebe.engine.processing.common.Failure
- Failure(String, ErrorType, long) - Constructor for class io.camunda.zeebe.engine.processing.common.Failure
- FALSE - Enum constant in enum io.camunda.zeebe.engine.processing.message.command.BooleanType
- fetchVariables() - Method in class io.camunda.zeebe.engine.state.instance.AwaitProcessInstanceResultMetadata
- findBackedOffJobs(long, BiPredicate<Long, JobRecord>) - Method in interface io.camunda.zeebe.engine.state.immutable.JobState
- findBackedOffJobs(long, BiPredicate<Long, JobRecord>) - Method in class io.camunda.zeebe.engine.state.instance.DbJobState
- findCatchEvent(DirectBuffer, ElementInstance, Optional<DirectBuffer>) - Method in class io.camunda.zeebe.engine.state.analyzers.CatchEventAnalyzer
- findCorrelationKey(BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBufferedMessageStartEventBehavior
- findErrorCatchEvent(DirectBuffer, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnEventPublicationBehavior
-
Finds the right catch event for the given error.
- findEventTrigger(BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnEventSubscriptionBehavior
-
Checks if the given element instance was triggered by an event.
- findTimersWithDueDateBefore(long, TimerInstanceState.TimerVisitor) - Method in interface io.camunda.zeebe.engine.state.immutable.TimerInstanceState
- findTimersWithDueDateBefore(long, TimerInstanceState.TimerVisitor) - Method in class io.camunda.zeebe.engine.state.instance.DbTimerInstanceState
- FlowElementInstantiationTransformer - Class in io.camunda.zeebe.engine.processing.deployment.model.transformer
- FlowElementInstantiationTransformer() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.transformer.FlowElementInstantiationTransformer
- FlowNodeTransformer - Class in io.camunda.zeebe.engine.processing.deployment.model.transformer
- FlowNodeTransformer() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.transformer.FlowNodeTransformer
- flush() - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.TypedStreamWriterProxy
- flush() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.sideeffect.SideEffectProducer
-
Applies the side effect.
- flush() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.sideeffect.SideEffectQueue
- flush() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.NoopResponseWriter
- flush() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.NoopTypedStreamWriter
- flush() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedCommandWriter
- flush() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedResponseWriter
-
Submits the response to transport.
- flush() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedResponseWriterImpl
- flush() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedStreamWriterImpl
- forEach(ZbColumnFamilies, KeyType, ValueType, BiConsumer<KeyType, ValueType>) - Method in class io.camunda.zeebe.engine.state.ZeebeDbState
-
Iterates over all entries for a given column family and presents each entry to the consumer.
- forEachActivatableJobs(DirectBuffer, BiFunction<Long, JobRecord, Boolean>) - Method in interface io.camunda.zeebe.engine.state.immutable.JobState
- forEachActivatableJobs(DirectBuffer, BiFunction<Long, JobRecord, Boolean>) - Method in class io.camunda.zeebe.engine.state.instance.DbJobState
- foreachPendingDeploymentDistribution(DeploymentState.PendingDeploymentVisitor) - Method in class io.camunda.zeebe.engine.state.deployment.DbDeploymentState
- foreachPendingDeploymentDistribution(DeploymentState.PendingDeploymentVisitor) - Method in interface io.camunda.zeebe.engine.state.immutable.DeploymentState
- forEachTimedOutEntry(long, BiFunction<Long, JobRecord, Boolean>) - Method in interface io.camunda.zeebe.engine.state.immutable.JobState
- forEachTimedOutEntry(long, BiFunction<Long, JobRecord, Boolean>) - Method in class io.camunda.zeebe.engine.state.instance.DbJobState
- forEachTimerForElementInstance(long, Consumer<TimerInstance>) - Method in interface io.camunda.zeebe.engine.state.immutable.TimerInstanceState
-
NOTE: the timer instance given to the consumer is shared and will be mutated on the next iteration.
- forEachTimerForElementInstance(long, Consumer<TimerInstance>) - Method in class io.camunda.zeebe.engine.state.instance.DbTimerInstanceState
- forExistingProcessIncident(long, ObjLongConsumer<IncidentRecord>) - Method in interface io.camunda.zeebe.engine.state.immutable.IncidentState
- forExistingProcessIncident(long, ObjLongConsumer<IncidentRecord>) - Method in class io.camunda.zeebe.engine.state.instance.DbIncidentState
- formatElement(StringWriter, ModelElementInstance) - Method in class io.camunda.zeebe.engine.processing.deployment.transform.ValidationErrorFormatter
- formatResult(StringWriter, ValidationResult) - Method in class io.camunda.zeebe.engine.processing.deployment.transform.ValidationErrorFormatter
G
- get() - Method in class io.camunda.zeebe.engine.state.deployment.Digest
- get() - Method in class io.camunda.zeebe.engine.state.deployment.LatestProcessVersion
- get() - Method in class io.camunda.zeebe.engine.state.instance.IncidentKey
- get() - Method in class io.camunda.zeebe.engine.state.instance.ParentScopeKey
- get() - Method in class io.camunda.zeebe.engine.state.migration.TemporaryVariables
- get() - Method in class io.camunda.zeebe.engine.state.NextValue
- get() - Method in class io.camunda.zeebe.engine.state.processing.LastProcessedPosition
- get(long, long) - Method in interface io.camunda.zeebe.engine.state.immutable.TimerInstanceState
- get(long, long) - Method in class io.camunda.zeebe.engine.state.instance.DbTimerInstanceState
- get(long, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.immutable.MessageSubscriptionState
- get(long, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.message.DbMessageSubscriptionState
- get(short) - Static method in enum io.camunda.zeebe.engine.processing.message.command.BooleanType
-
Lookup the enum value representing the value.
- get(RecordType, ValueType, int) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.RecordProcessorMap
- getAbortCondition() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- getAbortCondition() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.ReadonlyProcessingContext
- getActiveSequenceFlows() - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- getActor() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- getActor() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.ReadonlyProcessingContext
- getActorSchedulingService() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorBuilder
- getAssignee() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.JobWorkerProperties
- getAwaitResultRequestMetadata(long) - Method in interface io.camunda.zeebe.engine.state.immutable.ElementInstanceState
- getAwaitResultRequestMetadata(long) - Method in class io.camunda.zeebe.engine.state.instance.DbElementInstanceState
- getBlackListState() - Method in interface io.camunda.zeebe.engine.state.immutable.ZeebeState
- getBlackListState() - Method in interface io.camunda.zeebe.engine.state.mutable.MutableZeebeState
- getBlackListState() - Method in class io.camunda.zeebe.engine.state.ZeebeDbState
- getBodyDecoder() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionCommand
- getBodyDecoder() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionCommand
- getBodyDecoder() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionCommand
- getBodyDecoder() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionCommand
- getBodyDecoder() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionCommand
- getBodyDecoder() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionCommand
- getBodyDecoder() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionCommand
- getBodyEncoder() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionCommand
- getBodyEncoder() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionCommand
- getBodyEncoder() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionCommand
- getBodyEncoder() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionCommand
- getBodyEncoder() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionCommand
- getBodyEncoder() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionCommand
- getBodyEncoder() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionCommand
- getBoundaryEvents() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableActivity
- getBpmnElementType() - Method in interface io.camunda.zeebe.engine.processing.bpmn.BpmnElementContext
- getBpmnElementType() - Method in class io.camunda.zeebe.engine.processing.bpmn.BpmnElementContextImpl
- getBpmnProcessId() - Method in interface io.camunda.zeebe.engine.processing.bpmn.BpmnElementContext
- getBpmnProcessId() - Method in class io.camunda.zeebe.engine.processing.bpmn.BpmnElementContextImpl
- getBpmnProcessId() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionCommand
- getBpmnProcessId() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionCommand
- getBpmnProcessId() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionCommand
- getBpmnProcessId() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionCommand
- getBpmnProcessId() - Method in class io.camunda.zeebe.engine.processing.message.Subscriptions.Subscription
- getBpmnProcessId() - Method in class io.camunda.zeebe.engine.state.deployment.DeployedProcess
- getBpmnProcessId() - Method in class io.camunda.zeebe.engine.state.deployment.PersistedProcess
- getBpmnProcessId(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- getBpmnProcessId(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- getBpmnProcessId(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- getBpmnProcessId(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- getBpmnProcessId(MutableDirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- getBpmnProcessId(MutableDirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- getBpmnProcessId(MutableDirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- getBpmnProcessId(MutableDirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- getBpmnProcessIdForJob(long) - Method in class io.camunda.zeebe.engine.state.query.StateQueryService
- getBpmnProcessIdForJob(long) - Method in interface io.camunda.zeebe.engine.state.QueryService
-
Deprecated.Queries the state for the bpmn process id of the process that a specific job belongs to.
- getBpmnProcessIdForProcess(long) - Method in class io.camunda.zeebe.engine.state.query.StateQueryService
- getBpmnProcessIdForProcess(long) - Method in interface io.camunda.zeebe.engine.state.QueryService
-
Deprecated.Queries the state for the bpmn process id of a specific process.
- getBpmnProcessIdForProcessInstance(long) - Method in class io.camunda.zeebe.engine.state.query.StateQueryService
- getBpmnProcessIdForProcessInstance(long) - Method in interface io.camunda.zeebe.engine.state.QueryService
-
Deprecated.Queries the state for the bpmn process id of the process of a specific process instance.
- getBrokerVersion() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.TypedEventImpl
- getCalledChildInstance(BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateBehavior
- getCalledChildInstanceKey() - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- getCalledElementProcessId() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCallActivity
- getCandidateGroups() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.JobWorkerProperties
- getCatchEvent() - Method in class io.camunda.zeebe.engine.state.analyzers.CatchEventAnalyzer.CatchEventTuple
- getChildInstances(BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateBehavior
- getChildren(long) - Method in interface io.camunda.zeebe.engine.state.immutable.ElementInstanceState
- getChildren(long) - Method in class io.camunda.zeebe.engine.state.instance.DbElementInstanceState
- getCommand() - Method in class io.camunda.zeebe.engine.processing.processinstance.ProcessInstanceCommandContext
- getCommandResponseWriter() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- getCommandSentTime() - Method in class io.camunda.zeebe.engine.state.message.TransientSubscriptionCommandState.CommandEntry
- getCompletionCondition() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableLoopCharacteristics
- getCondition() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableSequenceFlow
- getContainerProcessor(BpmnElementType) - Method in class io.camunda.zeebe.engine.processing.bpmn.BpmnElementProcessors
- getContext() - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformation.TransformationVisitor
- getCorrelationKey() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionCommand
- getCorrelationKey() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionCommand
- getCorrelationKey() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionCommand
- getCorrelationKey(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- getCorrelationKey(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- getCorrelationKey(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- getCorrelationKey(MutableDirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- getCorrelationKey(MutableDirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- getCorrelationKey(MutableDirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- getCorrelationKeyExpression() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableMessage
- getCurrentPhase() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- getCurrentProcess() - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformation.TransformContext
- getCurrentValue(String) - Method in class io.camunda.zeebe.engine.state.NextValueManager
- getCurrentValue(DirectBuffer) - Method in class io.camunda.zeebe.engine.state.NextValueManager
- getDefaultFlow() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableExclusiveGateway
- getDeploymentRecord() - Method in class io.camunda.zeebe.engine.state.deployment.DeploymentRaw
- getDeploymentState() - Method in interface io.camunda.zeebe.engine.state.immutable.ZeebeState
- getDeploymentState() - Method in interface io.camunda.zeebe.engine.state.mutable.MutableZeebeState
- getDeploymentState() - Method in class io.camunda.zeebe.engine.state.ZeebeDbState
- getDueDate() - Method in class io.camunda.zeebe.engine.state.instance.TimerInstance
- getElementById(String, Class<T>) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableProcess
-
convenience function for transformation
- getElementById(DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableProcess
- getElementById(DirectBuffer, BpmnElementType, Class<T>) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableProcess
- getElementById(DirectBuffer, Class<T>) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableProcess
- getElementId() - Method in interface io.camunda.zeebe.engine.processing.bpmn.BpmnElementContext
- getElementId() - Method in class io.camunda.zeebe.engine.processing.bpmn.BpmnElementContextImpl
- getElementId() - Method in class io.camunda.zeebe.engine.state.instance.EventTrigger
- getElementInstance() - Method in class io.camunda.zeebe.engine.processing.processinstance.ProcessInstanceCommandContext
- getElementInstance() - Method in class io.camunda.zeebe.engine.state.analyzers.CatchEventAnalyzer.CatchEventTuple
- getElementInstance(long) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateBehavior
- getElementInstance(BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateBehavior
- getElementInstanceKey() - Method in interface io.camunda.zeebe.engine.processing.bpmn.BpmnElementContext
- getElementInstanceKey() - Method in class io.camunda.zeebe.engine.processing.bpmn.BpmnElementContextImpl
- getElementInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionCommand
- getElementInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionCommand
- getElementInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionCommand
- getElementInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionCommand
- getElementInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionCommand
- getElementInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionCommand
- getElementInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.Subscriptions.Subscription
- getElementInstanceKey() - Method in class io.camunda.zeebe.engine.state.instance.TimerInstance
- getElementInstanceKey() - Method in class io.camunda.zeebe.engine.state.message.TransientSubscriptionCommandState.CommandEntry
- getElementInstanceState() - Method in class io.camunda.zeebe.engine.processing.processinstance.ProcessInstanceCommandContext
- getElementInstanceState() - Method in interface io.camunda.zeebe.engine.state.immutable.ZeebeState
- getElementInstanceState() - Method in interface io.camunda.zeebe.engine.state.mutable.MutableZeebeState
- getElementInstanceState() - Method in class io.camunda.zeebe.engine.state.ZeebeDbState
- getElementType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.AbstractFlowElement
- getElementType() - Method in interface io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableFlowElement
- getElementType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.validation.TimerCatchEventExpressionValidator
- getElementType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.validation.ZeebeExpressionValidator
- getElementType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.validation.ZeebeTaskHeadersValidator
- getError() - Method in interface io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEvent
- getError() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEventElement
- getError() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableEndEvent
- getError() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableReceiveTask
- getError(String) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformation.TransformContext
- getErrorCode() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableError
- getErrorType() - Method in class io.camunda.zeebe.engine.processing.common.Failure
- getEventApplier() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- getEventApplier() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.ReadonlyProcessingContext
- getEventApplierFactory() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorBuilder
- getEventKey() - Method in class io.camunda.zeebe.engine.state.instance.EventTrigger
- getEvents() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableActivity
- getEvents() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEventElement
- getEvents() - Method in interface io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEventSupplier
- getEvents() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableEventBasedGateway
- getEventScopeInstanceState() - Method in interface io.camunda.zeebe.engine.state.immutable.ZeebeState
- getEventScopeInstanceState() - Method in interface io.camunda.zeebe.engine.state.mutable.MutableZeebeState
- getEventScopeInstanceState() - Method in class io.camunda.zeebe.engine.state.ZeebeDbState
- getEventSubProcess() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableStartEvent
- getEventSubprocesses() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableActivity
- getEventTriggerForProcessDefinition(long) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnEventSubscriptionBehavior
- getExporterLogger(String) - Static method in class io.camunda.zeebe.engine.Loggers
- getExpressionLanguage() - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformation.TransformContext
- getFailure() - Method in exception io.camunda.zeebe.engine.processing.message.MessageNameException
- getFlowElement(long, DirectBuffer, Class<T>) - Method in class io.camunda.zeebe.engine.state.deployment.DbProcessState
- getFlowElement(long, DirectBuffer, Class<T>) - Method in interface io.camunda.zeebe.engine.state.immutable.ProcessState
- getFlowScope() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.AbstractFlowElement
- getFlowScope() - Method in interface io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableFlowElement
- getFlowScopeContext(BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateBehavior
- getFlowScopeInstance(BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateBehavior
- getFlowScopeKey() - Method in interface io.camunda.zeebe.engine.processing.bpmn.BpmnElementContext
- getFlowScopeKey() - Method in class io.camunda.zeebe.engine.processing.bpmn.BpmnElementContextImpl
- getHandlerNodeId() - Method in class io.camunda.zeebe.engine.state.instance.TimerInstance
- getHealthReport() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- getId() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.AbstractFlowElement
- getId() - Method in interface io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableFlowElement
- getIdentifier() - Method in class io.camunda.zeebe.engine.state.migration.MessageSubscriptionSentTimeMigration
- getIdentifier() - Method in interface io.camunda.zeebe.engine.state.migration.MigrationTask
-
Returns identifier for the migration task.
- getIdentifier() - Method in class io.camunda.zeebe.engine.state.migration.ProcessMessageSubscriptionSentTimeMigration
- getIdentifier() - Method in class io.camunda.zeebe.engine.state.migration.TemporaryVariableMigration
- getIncidentRecord(long) - Method in interface io.camunda.zeebe.engine.state.immutable.IncidentState
- getIncidentRecord(long) - Method in class io.camunda.zeebe.engine.state.instance.DbIncidentState
- getIncidentState() - Method in interface io.camunda.zeebe.engine.state.immutable.ZeebeState
- getIncidentState() - Method in interface io.camunda.zeebe.engine.state.mutable.MutableZeebeState
- getIncidentState() - Method in class io.camunda.zeebe.engine.state.ZeebeDbState
- getIncoming() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableFlowNode
- getInnerActivity() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableMultiInstanceBody
- getInputCollection() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableLoopCharacteristics
- getInputElement() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableLoopCharacteristics
- getInputMappings() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableFlowNode
- getInstance(long) - Method in interface io.camunda.zeebe.engine.state.immutable.ElementInstanceState
- getInstance(long) - Method in interface io.camunda.zeebe.engine.state.immutable.EventScopeInstanceState
-
Returns a event scope instance by key or null if none exists with this key.
- getInstance(long) - Method in class io.camunda.zeebe.engine.state.instance.DbElementInstanceState
- getInstance(long) - Method in class io.camunda.zeebe.engine.state.instance.DbEventScopeInstanceState
- getIntent() - Method in interface io.camunda.zeebe.engine.processing.bpmn.BpmnElementContext
- getIntent() - Method in class io.camunda.zeebe.engine.processing.bpmn.BpmnElementContextImpl
- getIntent() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.TypedEventImpl
- getIntent() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.ReprocessingRecord
- getInterruptingElementId() - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- getInterruptingElementIds() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableActivity
- getInterruptingElementIds() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEventElement
- getInterruptingElementIds() - Method in interface io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEventSupplier
- getInterruptingElementIds() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableEventBasedGateway
- getJob(long) - Method in interface io.camunda.zeebe.engine.state.immutable.JobState
- getJob(long) - Method in class io.camunda.zeebe.engine.state.instance.DbJobState
- getJobIncidentKey(long) - Method in interface io.camunda.zeebe.engine.state.immutable.IncidentState
- getJobIncidentKey(long) - Method in class io.camunda.zeebe.engine.state.instance.DbIncidentState
- getJobKey() - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- getJobState() - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateBehavior
- getJobState() - Method in interface io.camunda.zeebe.engine.state.immutable.ZeebeState
- getJobState() - Method in interface io.camunda.zeebe.engine.state.mutable.MutableZeebeState
- getJobState() - Method in class io.camunda.zeebe.engine.state.ZeebeDbState
- getJobWorkerProperties() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableEndEvent
- getJobWorkerProperties() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableIntermediateThrowEvent
- getJobWorkerProperties() - Method in interface io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableJobWorkerElement
- getJobWorkerProperties() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableJobWorkerTask
- getKey() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.TypedEventImpl
- getKey() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.TypedRecord
- getKey() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.ReprocessingRecord
- getKey() - Method in class io.camunda.zeebe.engine.state.deployment.DeployedProcess
- getKey() - Method in class io.camunda.zeebe.engine.state.deployment.PersistedProcess
- getKey() - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- getKey() - Method in class io.camunda.zeebe.engine.state.instance.IndexedRecord
- getKey() - Method in class io.camunda.zeebe.engine.state.instance.TimerInstance
- getKey() - Method in class io.camunda.zeebe.engine.state.message.MessageStartEventSubscription
- getKey() - Method in class io.camunda.zeebe.engine.state.message.MessageSubscription
- getKey() - Method in class io.camunda.zeebe.engine.state.message.ProcessMessageSubscription
- getKey() - Method in class io.camunda.zeebe.engine.state.variable.VariableInstance
- getKeyGenerator() - Method in interface io.camunda.zeebe.engine.state.mutable.MutableZeebeState
- getKeyGenerator() - Method in class io.camunda.zeebe.engine.state.ZeebeDbState
- getKeyGeneratorControls() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- getKeyGeneratorControls() - Method in class io.camunda.zeebe.engine.state.ZeebeDbState
- getLastProcessedPosition() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.LastProcessingPositions
- getLastProcessedPositionAsync() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- getLastProcessedPositionState() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- getLastProcessedPositionState() - Method in interface io.camunda.zeebe.engine.state.mutable.MutableZeebeState
- getLastProcessedPositionState() - Method in class io.camunda.zeebe.engine.state.ZeebeDbState
- getLastReplayedEventPosition() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ReplayStateMachine
- getLastSourceEventPosition() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ReplayStateMachine
- getLastSuccessfulProcessedEventPosition() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingStateMachine
- getLastSuccessfulProcessedRecordPosition() - Method in interface io.camunda.zeebe.engine.state.immutable.LastProcessedPositionState
- getLastSuccessfulProcessedRecordPosition() - Method in class io.camunda.zeebe.engine.state.processing.DbLastProcessedPositionState
- getLastWrittenPosition() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.LastProcessingPositions
- getLastWrittenPosition() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingStateMachine
- getLastWrittenPositionAsync() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- getLatestProcessVersion(DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateBehavior
- getLatestProcessVersionByProcessId(DirectBuffer) - Method in class io.camunda.zeebe.engine.state.deployment.DbProcessState
- getLatestProcessVersionByProcessId(DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.immutable.ProcessState
- getLatestVersionDigest(DirectBuffer) - Method in class io.camunda.zeebe.engine.state.deployment.DbProcessState
- getLatestVersionDigest(DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.immutable.ProcessState
- getLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionCommand
- getLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionCommand
- getLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionCommand
- getLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionCommand
- getLength() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionCommand
- getLength() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionCommand
- getLength() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionCommand
- getLength() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.TypedEventImpl
- getLength() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.TypedRecord
- getLifecycleListeners() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorBuilder
- getLifecycleListeners() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.TypedRecordProcessors
- getLocalVariable(BpmnElementContext, DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateBehavior
- getLogStream() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- getLogStream() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.ReadonlyProcessingContext
- getLogStreamReader() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- getLogStreamReader() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.ReadonlyProcessingContext
- getLogStreamWriter() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- getLogStreamWriter() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.ReadonlyProcessingContext
- getLoopCharacteristics() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableMultiInstanceBody
- getMaxFragmentSize() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- getMaxFragmentSize() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.ReadonlyProcessingContext
- getMessage() - Method in class io.camunda.zeebe.engine.processing.common.Failure
- getMessage() - Method in interface io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEvent
- getMessage() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEventElement
- getMessage() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableReceiveTask
- getMessage() - Method in class io.camunda.zeebe.engine.state.message.StoredMessage
- getMessage(long) - Method in interface io.camunda.zeebe.engine.state.immutable.MessageState
- getMessage(long) - Method in class io.camunda.zeebe.engine.state.message.DbMessageState
- getMessage(String) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformation.TransformContext
- getMessageKey() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionCommand
- getMessageKey() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionCommand
- getMessageKey() - Method in class io.camunda.zeebe.engine.state.message.StoredMessage
- getMessageName() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableMessage
-
Returns the message name, if it has been resolved previously (and is independent of the variable context).
- getMessageName() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionCommand
- getMessageName() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionCommand
- getMessageName() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionCommand
- getMessageName() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionCommand
- getMessageName() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionCommand
- getMessageName() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionCommand
- getMessageName() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionCommand
- getMessageName() - Method in class io.camunda.zeebe.engine.state.message.TransientSubscriptionCommandState.CommandEntry
- getMessageName(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- getMessageName(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- getMessageName(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- getMessageName(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- getMessageName(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- getMessageName(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- getMessageName(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- getMessageName(MutableDirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- getMessageName(MutableDirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- getMessageName(MutableDirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- getMessageName(MutableDirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- getMessageName(MutableDirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- getMessageName(MutableDirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- getMessageName(MutableDirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- getMessageNameExpression() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableMessage
- getMessageStartEventSubscriptionState() - Method in interface io.camunda.zeebe.engine.state.immutable.ZeebeState
- getMessageStartEventSubscriptionState() - Method in interface io.camunda.zeebe.engine.state.mutable.MutableZeebeState
- getMessageStartEventSubscriptionState() - Method in class io.camunda.zeebe.engine.state.ZeebeDbState
- getMessageState() - Method in interface io.camunda.zeebe.engine.state.immutable.ZeebeState
- getMessageState() - Method in interface io.camunda.zeebe.engine.state.mutable.MutableZeebeState
- getMessageState() - Method in class io.camunda.zeebe.engine.state.ZeebeDbState
- getMessageSubscriptionState() - Method in interface io.camunda.zeebe.engine.state.immutable.ZeebeState
- getMessageSubscriptionState() - Method in interface io.camunda.zeebe.engine.state.mutable.MutableZeebeState
- getMessageSubscriptionState() - Method in class io.camunda.zeebe.engine.state.ZeebeDbState
- getMigrationState() - Method in interface io.camunda.zeebe.engine.state.mutable.MutableZeebeState
- getMigrationState() - Method in class io.camunda.zeebe.engine.state.ZeebeDbState
- getMultiInstanceLoopCounter() - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- getName() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- getName() - Method in class io.camunda.zeebe.engine.state.variable.DocumentEntry
- getNextValue(String) - Method in class io.camunda.zeebe.engine.state.NextValueManager
- getNodeId() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorBuilder
- getNoneStartEvent() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableFlowElementContainer
- getNumberOfActiveElementInstances() - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- getNumberOfTakenSequenceFlows(long, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.immutable.ElementInstanceState
-
Returns the number of the taken sequence flows that are connected to the given parallel (joining) gateway.
- getNumberOfTakenSequenceFlows(long, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.instance.DbElementInstanceState
- getOutgoing() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableFlowNode
- getOutgoingWithCondition() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableExclusiveGateway
- getOutputCollection() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableLoopCharacteristics
- getOutputElement() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableLoopCharacteristics
- getOutputMappings() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableFlowNode
- getParentElementInstanceContext(BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateBehavior
- getParentElementInstanceKey() - Method in interface io.camunda.zeebe.engine.processing.bpmn.BpmnElementContext
- getParentElementInstanceKey() - Method in class io.camunda.zeebe.engine.processing.bpmn.BpmnElementContextImpl
- getParentKey() - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- getParentProcessInstanceKey() - Method in interface io.camunda.zeebe.engine.processing.bpmn.BpmnElementContext
- getParentProcessInstanceKey() - Method in class io.camunda.zeebe.engine.processing.bpmn.BpmnElementContextImpl
- getParentScopeKey(long) - Method in interface io.camunda.zeebe.engine.state.immutable.VariableState
- getParentScopeKey(long) - Method in class io.camunda.zeebe.engine.state.variable.DbVariableState
- getPartitionId() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.TypedEventImpl
- getPartitionId() - Method in interface io.camunda.zeebe.engine.state.immutable.ZeebeState
- getPartitionId() - Method in class io.camunda.zeebe.engine.state.ZeebeDbState
- getPendingMessageSubscriptionState() - Method in interface io.camunda.zeebe.engine.state.mutable.MutableZeebeState
- getPendingMessageSubscriptionState() - Method in class io.camunda.zeebe.engine.state.ZeebeDbState
- getPendingProcessMessageSubscriptionState() - Method in interface io.camunda.zeebe.engine.state.mutable.MutableZeebeState
- getPendingProcessMessageSubscriptionState() - Method in class io.camunda.zeebe.engine.state.ZeebeDbState
- getPosition() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.TypedEventImpl
- getProcess() - Method in class io.camunda.zeebe.engine.state.deployment.DeployedProcess
- getProcess(long) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateBehavior
- getProcess(String) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformation.TransformContext
- getProcessByKey(long) - Method in class io.camunda.zeebe.engine.state.deployment.DbProcessState
- getProcessByKey(long) - Method in interface io.camunda.zeebe.engine.state.immutable.ProcessState
- getProcessByProcessIdAndVersion(DirectBuffer, int) - Method in class io.camunda.zeebe.engine.state.deployment.DbProcessState
- getProcessByProcessIdAndVersion(DirectBuffer, int) - Method in interface io.camunda.zeebe.engine.state.immutable.ProcessState
- getProcessDefinitionKey() - Method in interface io.camunda.zeebe.engine.processing.bpmn.BpmnElementContext
- getProcessDefinitionKey() - Method in class io.camunda.zeebe.engine.processing.bpmn.BpmnElementContextImpl
- getProcessDefinitionKey() - Method in class io.camunda.zeebe.engine.state.instance.TimerInstance
- getProcesses() - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformation.TransformContext
- getProcesses() - Method in class io.camunda.zeebe.engine.state.deployment.DbProcessState
- getProcesses() - Method in interface io.camunda.zeebe.engine.state.immutable.ProcessState
- getProcessesByBpmnProcessId(DirectBuffer) - Method in class io.camunda.zeebe.engine.state.deployment.DbProcessState
- getProcessesByBpmnProcessId(DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.immutable.ProcessState
- getProcessingContext() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorBuilder
- getProcessInstanceCorrelationKey(long) - Method in interface io.camunda.zeebe.engine.state.immutable.MessageState
- getProcessInstanceCorrelationKey(long) - Method in class io.camunda.zeebe.engine.state.message.DbMessageState
- getProcessInstanceIncidentKey(long) - Method in interface io.camunda.zeebe.engine.state.immutable.IncidentState
- getProcessInstanceIncidentKey(long) - Method in class io.camunda.zeebe.engine.state.instance.DbIncidentState
- getProcessInstanceKey() - Method in interface io.camunda.zeebe.engine.processing.bpmn.BpmnElementContext
- getProcessInstanceKey() - Method in class io.camunda.zeebe.engine.processing.bpmn.BpmnElementContextImpl
- getProcessInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionCommand
- getProcessInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionCommand
- getProcessInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionCommand
- getProcessInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionCommand
- getProcessInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionCommand
- getProcessInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionCommand
- getProcessInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionCommand
- getProcessInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.Subscriptions.Subscription
- getProcessInstanceKey() - Method in class io.camunda.zeebe.engine.state.instance.TimerInstance
- getProcessMessageSubscriptionState() - Method in interface io.camunda.zeebe.engine.state.immutable.ZeebeState
- getProcessMessageSubscriptionState() - Method in interface io.camunda.zeebe.engine.state.mutable.MutableZeebeState
- getProcessMessageSubscriptionState() - Method in class io.camunda.zeebe.engine.state.ZeebeDbState
- getProcessor(BpmnElementType) - Method in class io.camunda.zeebe.engine.processing.bpmn.BpmnElementProcessors
- getProcessorMode() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- getProcessState() - Method in interface io.camunda.zeebe.engine.state.immutable.ZeebeState
- getProcessState() - Method in interface io.camunda.zeebe.engine.state.mutable.MutableZeebeState
- getProcessState() - Method in class io.camunda.zeebe.engine.state.ZeebeDbState
- getProcessVersion() - Method in interface io.camunda.zeebe.engine.processing.bpmn.BpmnElementContext
- getProcessVersion() - Method in class io.camunda.zeebe.engine.processing.bpmn.BpmnElementContextImpl
- getProcessVersion(String) - Method in class io.camunda.zeebe.engine.state.deployment.DbProcessState
- getProcessVersion(String) - Method in interface io.camunda.zeebe.engine.state.immutable.ProcessState
- getRecord() - Method in class io.camunda.zeebe.engine.processing.processinstance.ProcessInstanceCommandContext
- getRecord() - Method in class io.camunda.zeebe.engine.state.instance.Incident
- getRecord() - Method in class io.camunda.zeebe.engine.state.instance.JobRecordValue
- getRecord() - Method in class io.camunda.zeebe.engine.state.message.MessageStartEventSubscription
- getRecord() - Method in class io.camunda.zeebe.engine.state.message.MessageSubscription
- getRecord() - Method in class io.camunda.zeebe.engine.state.message.ProcessMessageSubscription
- getRecordProcessorMap() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- getRecordProcessorMap() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.ReadonlyProcessingContext
- getRecordProcessorMap() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.TypedRecordProcessors
- getRecordType() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.TypedEventImpl
- getRecordValue() - Method in interface io.camunda.zeebe.engine.processing.bpmn.BpmnElementContext
-
Caution! Don't modify the value to avoid unexpected side-effects.
- getRecordValue() - Method in class io.camunda.zeebe.engine.processing.bpmn.BpmnElementContextImpl
- getRecordValues() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- getRecordValues() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.ReadonlyProcessingContext
- getRejectionReason() - Method in class io.camunda.zeebe.engine.processing.deployment.transform.DeploymentTransformer
- getRejectionReason() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.TypedEventImpl
- getRejectionType() - Method in class io.camunda.zeebe.engine.processing.deployment.transform.DeploymentTransformer
- getRejectionType() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.TypedEventImpl
- getRepetitions() - Method in class io.camunda.zeebe.engine.state.instance.TimerInstance
- getRequestId() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.TypedEventImpl
- getRequestId() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.TypedRecord
- getRequestId() - Method in class io.camunda.zeebe.engine.state.instance.AwaitProcessInstanceResultMetadata
- getRequestStreamId() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.TypedEventImpl
- getRequestStreamId() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.TypedRecord
- getRequestStreamId() - Method in class io.camunda.zeebe.engine.state.instance.AwaitProcessInstanceResultMetadata
- getResource() - Method in class io.camunda.zeebe.engine.state.deployment.DeployedProcess
- getResource() - Method in class io.camunda.zeebe.engine.state.deployment.PersistedProcess
- getResourceName() - Method in class io.camunda.zeebe.engine.state.deployment.DeployedProcess
- getResourceName() - Method in class io.camunda.zeebe.engine.state.deployment.PersistedProcess
- getResponseWriter() - Method in class io.camunda.zeebe.engine.processing.processinstance.ProcessInstanceCommandContext
- getRetries() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.JobWorkerProperties
- getSource() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableSequenceFlow
- getSourceRecordPosition() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.TypedEventImpl
- getSourceRecordPosition() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.ReprocessingRecord
- getStartEvents() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableFlowElementContainer
- getState() - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- getState() - Method in class io.camunda.zeebe.engine.state.instance.IndexedRecord
- getState() - Method in class io.camunda.zeebe.engine.state.instance.JobStateValue
- getState(long) - Method in interface io.camunda.zeebe.engine.state.immutable.JobState
- getState(long) - Method in class io.camunda.zeebe.engine.state.instance.DbJobState
- getStoredDeploymentRecord(long) - Method in class io.camunda.zeebe.engine.state.deployment.DbDeploymentState
- getStoredDeploymentRecord(long) - Method in interface io.camunda.zeebe.engine.state.immutable.DeploymentState
- getStreamProcessorListener() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- getStreamWriter() - Method in class io.camunda.zeebe.engine.processing.processinstance.ProcessInstanceCommandContext
- getSubscription(long, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.immutable.ProcessMessageSubscriptionState
- getSubscription(long, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.message.DbProcessMessageSubscriptionState
- getSubscriptionPartitionId() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionCommand
- getSubscriptionPartitionId() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionCommand
- getSubscriptionPartitionId() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionCommand
- getSubscriptionPartitionId() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionCommand
- getSubscriptionPartitionId() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionCommand
- getSubscriptionPartitionId() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionCommand
- getSubscriptionPartitionId() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionCommand
- getTarget() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableSequenceFlow
- getTaskHeaders() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.JobWorkerProperties
- getTimerFactory() - Method in interface io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEvent
- getTimerFactory() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEventElement
- getTimerFactory() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableReceiveTask
- getTimerState() - Method in interface io.camunda.zeebe.engine.state.immutable.ZeebeState
- getTimerState() - Method in interface io.camunda.zeebe.engine.state.mutable.MutableZeebeState
- getTimerState() - Method in class io.camunda.zeebe.engine.state.ZeebeDbState
- getTimestamp() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.TypedEventImpl
- getTransactionContext() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- getTransactionContext() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.ReadonlyProcessingContext
- getType() - Method in interface io.camunda.zeebe.engine.processing.bpmn.BpmnElementProcessor
- getType() - Method in class io.camunda.zeebe.engine.processing.bpmn.container.CallActivityProcessor
- getType() - Method in class io.camunda.zeebe.engine.processing.bpmn.container.EventSubProcessProcessor
- getType() - Method in class io.camunda.zeebe.engine.processing.bpmn.container.MultiInstanceBodyProcessor
- getType() - Method in class io.camunda.zeebe.engine.processing.bpmn.container.ProcessProcessor
- getType() - Method in class io.camunda.zeebe.engine.processing.bpmn.container.SubProcessProcessor
- getType() - Method in class io.camunda.zeebe.engine.processing.bpmn.event.BoundaryEventProcessor
- getType() - Method in class io.camunda.zeebe.engine.processing.bpmn.event.EndEventProcessor
- getType() - Method in class io.camunda.zeebe.engine.processing.bpmn.event.IntermediateCatchEventProcessor
- getType() - Method in class io.camunda.zeebe.engine.processing.bpmn.event.IntermediateThrowEventProcessor
- getType() - Method in class io.camunda.zeebe.engine.processing.bpmn.event.StartEventProcessor
- getType() - Method in class io.camunda.zeebe.engine.processing.bpmn.gateway.EventBasedGatewayProcessor
- getType() - Method in class io.camunda.zeebe.engine.processing.bpmn.gateway.ExclusiveGatewayProcessor
- getType() - Method in class io.camunda.zeebe.engine.processing.bpmn.gateway.ParallelGatewayProcessor
- getType() - Method in class io.camunda.zeebe.engine.processing.bpmn.task.JobWorkerTaskProcessor
- getType() - Method in class io.camunda.zeebe.engine.processing.bpmn.task.ManualTaskProcessor
- getType() - Method in class io.camunda.zeebe.engine.processing.bpmn.task.ReceiveTaskProcessor
- getType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.JobWorkerProperties
- getType() - Method in interface io.camunda.zeebe.engine.processing.deployment.model.transformation.ModelElementTransformer
- getType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.BoundaryEventTransformer
- getType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.CallActivityTransformer
- getType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.CatchEventTransformer
- getType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.ContextProcessTransformer
- getType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.EndEventTransformer
- getType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.ErrorTransformer
- getType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.EventBasedGatewayTransformer
- getType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.ExclusiveGatewayTransformer
- getType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.FlowElementInstantiationTransformer
- getType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.FlowNodeTransformer
- getType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.IntermediateCatchEventTransformer
- getType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.IntermediateThrowEventTransformer
- getType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.JobWorkerElementTransformer
- getType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.MessageTransformer
- getType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.MultiInstanceActivityTransformer
- getType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.ProcessTransformer
- getType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.ReceiveTaskTransformer
- getType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.SequenceFlowTransformer
- getType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.StartEventTransformer
- getType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.SubProcessTransformer
- getType() - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.UserTaskTransformer
- getTypedRecordProcessorFactory() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorBuilder
- getValidators(ExpressionLanguage, ExpressionProcessor) - Static method in class io.camunda.zeebe.engine.processing.deployment.model.validation.ZeebeRuntimeValidators
- getValue() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.TypedEventImpl
- getValue() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.TypedRecord
- getValue() - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- getValue() - Method in class io.camunda.zeebe.engine.state.instance.IndexedRecord
- getValue() - Method in class io.camunda.zeebe.engine.state.variable.DocumentEntry
- getValue() - Method in class io.camunda.zeebe.engine.state.variable.VariableInstance
- getValueType() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.TypedEventImpl
- getVariable(long, DirectBuffer) - Method in interface io.camunda.zeebe.engine.processing.common.ExpressionProcessor.VariablesLookup
- getVariable(long, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.immutable.VariableState
- getVariable(long, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.variable.DbVariableState
-
Find the variable with the given name.
- getVariable(long, DirectBuffer, int, int) - Method in interface io.camunda.zeebe.engine.state.immutable.VariableState
- getVariable(long, DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.state.variable.DbVariableState
-
Find the variable with the given name.
- getVariableInstanceLocal(long, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.immutable.VariableState
- getVariableInstanceLocal(long, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.variable.DbVariableState
- getVariableLocal(long, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.immutable.VariableState
- getVariableLocal(long, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.variable.DbVariableState
- getVariables() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionCommand
- getVariables() - Method in class io.camunda.zeebe.engine.state.instance.EventTrigger
- getVariables(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- getVariables(MutableDirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- getVariablesAsDocument(long) - Method in interface io.camunda.zeebe.engine.state.immutable.VariableState
- getVariablesAsDocument(long) - Method in class io.camunda.zeebe.engine.state.variable.DbVariableState
- getVariablesAsDocument(long, Collection<DirectBuffer>) - Method in interface io.camunda.zeebe.engine.state.immutable.VariableState
- getVariablesAsDocument(long, Collection<DirectBuffer>) - Method in class io.camunda.zeebe.engine.state.variable.DbVariableState
- getVariableScopeKey() - Method in class io.camunda.zeebe.engine.processing.common.Failure
- getVariableScopeKey() - Method in exception io.camunda.zeebe.engine.processing.message.MessageCorrelationKeyException
- getVariablesLocalAsDocument(long) - Method in interface io.camunda.zeebe.engine.state.immutable.VariableState
- getVariablesLocalAsDocument(long) - Method in class io.camunda.zeebe.engine.state.variable.DbVariableState
- getVariableState() - Method in interface io.camunda.zeebe.engine.state.immutable.ZeebeState
- getVariableState() - Method in interface io.camunda.zeebe.engine.state.mutable.MutableZeebeState
- getVariableState() - Method in class io.camunda.zeebe.engine.state.ZeebeDbState
- getVersion() - Method in class io.camunda.zeebe.engine.state.deployment.DeployedProcess
- getVersion() - Method in class io.camunda.zeebe.engine.state.deployment.PersistedProcess
- getWriters() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- getWriters() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.ReadonlyProcessingContext
- getZeebeDb() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorBuilder
- getZeebeState() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- getZeebeState() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.ReadonlyProcessingContext
H
- handle(ProcessInstanceCommandContext) - Method in class io.camunda.zeebe.engine.processing.processinstance.CancelProcessInstanceHandler
- handle(ProcessInstanceCommandContext) - Method in interface io.camunda.zeebe.engine.processing.processinstance.ProcessInstanceCommandHandler
- handle(ProcessInstanceCommandContext) - Method in class io.camunda.zeebe.engine.processing.processinstance.ProcessInstanceCommandHandlers
- handleFailure(Throwable) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- hasError() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableEndEvent
- hashCode() - Method in class io.camunda.zeebe.engine.processing.common.Failure
- hashCode() - Method in class io.camunda.zeebe.engine.state.instance.AwaitProcessInstanceResultMetadata
- hashCode() - Method in class io.camunda.zeebe.engine.state.instance.EventScopeInstance
- hashCode() - Method in class io.camunda.zeebe.engine.state.instance.EventTrigger
- hashCode() - Method in class io.camunda.zeebe.engine.state.message.TransientSubscriptionCommandState.CommandEntry
- hashCode() - Method in class io.camunda.zeebe.engine.state.variable.DocumentEntry
- hasMessageStartEvent() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableFlowElementContainer
- hasNoneStartEvent() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableFlowElementContainer
- hasPendingDeploymentDistribution(long) - Method in class io.camunda.zeebe.engine.state.deployment.DbDeploymentState
- hasPendingDeploymentDistribution(long) - Method in interface io.camunda.zeebe.engine.state.immutable.DeploymentState
- hasProcessingReachedTheEnd() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- hasReachedEnd() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingStateMachine
-
Be aware this is a transient property which can change anytime, e.g.
- hasRequestMetadata() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.TypedRecord
- hasState(ProcessInstanceIntent) - Method in class io.camunda.zeebe.engine.state.instance.IndexedRecord
- hasTimerStartEvent() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableFlowElementContainer
- hasValidExpression(Function<T, String>, Consumer<ZeebeExpressionValidator.ExpressionVerification>) - Method in class io.camunda.zeebe.engine.processing.deployment.model.validation.ZeebeExpressionValidator.Builder
- hasValidPath(Function<T, String>) - Method in class io.camunda.zeebe.engine.processing.deployment.model.validation.ZeebeExpressionValidator.Builder
- HEALTH_CHECK_TICK_DURATION - Static variable in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
I
- Incident - Class in io.camunda.zeebe.engine.state.instance
- Incident() - Constructor for class io.camunda.zeebe.engine.state.instance.Incident
- INCIDENT_JOBS - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- INCIDENT_PROCESS_INSTANCES - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- incidentBehavior() - Method in interface io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBehaviors
- incidentBehavior() - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBehaviorsImpl
- incidentCreated() - Method in class io.camunda.zeebe.engine.metrics.IncidentMetrics
- IncidentEventProcessors - Class in io.camunda.zeebe.engine.processing.incident
- IncidentEventProcessors() - Constructor for class io.camunda.zeebe.engine.processing.incident.IncidentEventProcessors
- IncidentKey - Class in io.camunda.zeebe.engine.state.instance
- IncidentKey() - Constructor for class io.camunda.zeebe.engine.state.instance.IncidentKey
- IncidentMetrics - Class in io.camunda.zeebe.engine.metrics
- IncidentMetrics(int) - Constructor for class io.camunda.zeebe.engine.metrics.IncidentMetrics
- incidentResolved() - Method in class io.camunda.zeebe.engine.metrics.IncidentMetrics
- INCIDENTS - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- IncidentState - Interface in io.camunda.zeebe.engine.state.immutable
- incrementActiveSequenceFlows() - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- incrementMultiInstanceLoopCounter() - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- incrementNumberOfTakenSequenceFlows(long, DirectBuffer, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.instance.DbElementInstanceState
- incrementNumberOfTakenSequenceFlows(long, DirectBuffer, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableElementInstanceState
-
Increments the number that counts how often the given sequence flow has been taken.
- index(DirectBuffer) - Method in class io.camunda.zeebe.engine.state.variable.IndexedDocument
- IndexedDocument - Class in io.camunda.zeebe.engine.state.variable
-
This class indexes a MsgPack document from the given buffer by doing an initial parsing and caching the offsets for each key-value pair.
- IndexedDocument() - Constructor for class io.camunda.zeebe.engine.state.variable.IndexedDocument
- IndexedDocument(MsgPackReader) - Constructor for class io.camunda.zeebe.engine.state.variable.IndexedDocument
- IndexedRecord - Class in io.camunda.zeebe.engine.state.instance
- IndexedRecord(long, ProcessInstanceIntent, ProcessInstanceRecord) - Constructor for class io.camunda.zeebe.engine.state.instance.IndexedRecord
- init(long, ProcessInstanceRecord, ProcessInstanceIntent) - Method in class io.camunda.zeebe.engine.processing.bpmn.BpmnElementContextImpl
- initialOffset() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- initialOffset() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- initialOffset() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- initialOffset() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- initialOffset() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- initialOffset() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- initialOffset() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- initialOffset() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- initialOffset() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- initialOffset() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- initialOffset() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- initialOffset() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- initialOffset() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- initialOffset() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- initMetadata(RecordType, Intent, RecordValue) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedStreamWriterImpl
- intent(Intent) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.writers.CommandResponseWriter
- IntermediateCatchEventProcessor - Class in io.camunda.zeebe.engine.processing.bpmn.event
- IntermediateCatchEventProcessor(BpmnBehaviors) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.event.IntermediateCatchEventProcessor
- IntermediateCatchEventTransformer - Class in io.camunda.zeebe.engine.processing.deployment.model.transformer
- IntermediateCatchEventTransformer() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.transformer.IntermediateCatchEventTransformer
- IntermediateThrowEventProcessor - Class in io.camunda.zeebe.engine.processing.bpmn.event
- IntermediateThrowEventProcessor(BpmnBehaviors) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.event.IntermediateThrowEventProcessor
- IntermediateThrowEventTransformer - Class in io.camunda.zeebe.engine.processing.deployment.model.transformer
- IntermediateThrowEventTransformer() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.transformer.IntermediateThrowEventTransformer
- interrupting() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEventElement
- io.camunda.zeebe.engine - package io.camunda.zeebe.engine
- io.camunda.zeebe.engine.metrics - package io.camunda.zeebe.engine.metrics
- io.camunda.zeebe.engine.processing - package io.camunda.zeebe.engine.processing
- io.camunda.zeebe.engine.processing.bpmn - package io.camunda.zeebe.engine.processing.bpmn
- io.camunda.zeebe.engine.processing.bpmn.behavior - package io.camunda.zeebe.engine.processing.bpmn.behavior
- io.camunda.zeebe.engine.processing.bpmn.container - package io.camunda.zeebe.engine.processing.bpmn.container
- io.camunda.zeebe.engine.processing.bpmn.event - package io.camunda.zeebe.engine.processing.bpmn.event
- io.camunda.zeebe.engine.processing.bpmn.gateway - package io.camunda.zeebe.engine.processing.bpmn.gateway
- io.camunda.zeebe.engine.processing.bpmn.task - package io.camunda.zeebe.engine.processing.bpmn.task
- io.camunda.zeebe.engine.processing.common - package io.camunda.zeebe.engine.processing.common
- io.camunda.zeebe.engine.processing.deployment - package io.camunda.zeebe.engine.processing.deployment
- io.camunda.zeebe.engine.processing.deployment.distribute - package io.camunda.zeebe.engine.processing.deployment.distribute
- io.camunda.zeebe.engine.processing.deployment.model - package io.camunda.zeebe.engine.processing.deployment.model
- io.camunda.zeebe.engine.processing.deployment.model.element - package io.camunda.zeebe.engine.processing.deployment.model.element
- io.camunda.zeebe.engine.processing.deployment.model.transformation - package io.camunda.zeebe.engine.processing.deployment.model.transformation
- io.camunda.zeebe.engine.processing.deployment.model.transformer - package io.camunda.zeebe.engine.processing.deployment.model.transformer
- io.camunda.zeebe.engine.processing.deployment.model.validation - package io.camunda.zeebe.engine.processing.deployment.model.validation
- io.camunda.zeebe.engine.processing.deployment.transform - package io.camunda.zeebe.engine.processing.deployment.transform
- io.camunda.zeebe.engine.processing.incident - package io.camunda.zeebe.engine.processing.incident
- io.camunda.zeebe.engine.processing.job - package io.camunda.zeebe.engine.processing.job
- io.camunda.zeebe.engine.processing.message - package io.camunda.zeebe.engine.processing.message
- io.camunda.zeebe.engine.processing.message.command - package io.camunda.zeebe.engine.processing.message.command
-
Zeebe Subscription Protocol
- io.camunda.zeebe.engine.processing.processinstance - package io.camunda.zeebe.engine.processing.processinstance
- io.camunda.zeebe.engine.processing.scheduled - package io.camunda.zeebe.engine.processing.scheduled
- io.camunda.zeebe.engine.processing.streamprocessor - package io.camunda.zeebe.engine.processing.streamprocessor
- io.camunda.zeebe.engine.processing.streamprocessor.sideeffect - package io.camunda.zeebe.engine.processing.streamprocessor.sideeffect
- io.camunda.zeebe.engine.processing.streamprocessor.writers - package io.camunda.zeebe.engine.processing.streamprocessor.writers
- io.camunda.zeebe.engine.processing.timer - package io.camunda.zeebe.engine.processing.timer
- io.camunda.zeebe.engine.processing.variable - package io.camunda.zeebe.engine.processing.variable
- io.camunda.zeebe.engine.state - package io.camunda.zeebe.engine.state
- io.camunda.zeebe.engine.state.analyzers - package io.camunda.zeebe.engine.state.analyzers
- io.camunda.zeebe.engine.state.appliers - package io.camunda.zeebe.engine.state.appliers
- io.camunda.zeebe.engine.state.deployment - package io.camunda.zeebe.engine.state.deployment
- io.camunda.zeebe.engine.state.immutable - package io.camunda.zeebe.engine.state.immutable
- io.camunda.zeebe.engine.state.instance - package io.camunda.zeebe.engine.state.instance
- io.camunda.zeebe.engine.state.message - package io.camunda.zeebe.engine.state.message
- io.camunda.zeebe.engine.state.migration - package io.camunda.zeebe.engine.state.migration
- io.camunda.zeebe.engine.state.mutable - package io.camunda.zeebe.engine.state.mutable
- io.camunda.zeebe.engine.state.processing - package io.camunda.zeebe.engine.state.processing
- io.camunda.zeebe.engine.state.query - package io.camunda.zeebe.engine.state.query
- io.camunda.zeebe.engine.state.variable - package io.camunda.zeebe.engine.state.variable
- isAccepting() - Method in class io.camunda.zeebe.engine.state.instance.EventScopeInstance
- isAcceptingEvent(long) - Method in interface io.camunda.zeebe.engine.state.immutable.EventScopeInstanceState
- isAcceptingEvent(long) - Method in class io.camunda.zeebe.engine.state.instance.DbEventScopeInstanceState
- isActive() - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- isActive(ProcessInstanceIntent) - Static method in class io.camunda.zeebe.engine.processing.bpmn.ProcessInstanceLifecycle
- isClosed() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- isClosing() - Method in class io.camunda.zeebe.engine.state.message.ProcessMessageSubscription
- isConnectedToEventBasedGateway() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEventElement
- isCorrelating() - Method in class io.camunda.zeebe.engine.state.message.MessageSubscription
- isElementInstanceState(ProcessInstanceIntent) - Static method in class io.camunda.zeebe.engine.processing.bpmn.ProcessInstanceLifecycle
- isEmpty() - Method in interface io.camunda.zeebe.engine.state.immutable.VariableState
- isEmpty() - Method in class io.camunda.zeebe.engine.state.variable.DbVariableState
- isEmpty() - Method in class io.camunda.zeebe.engine.state.variable.IndexedDocument
- isEmpty(ZbColumnFamilies) - Method in interface io.camunda.zeebe.engine.state.immutable.ZeebeState
- isEmpty(ZbColumnFamilies) - Method in class io.camunda.zeebe.engine.state.ZeebeDbState
- isError() - Method in interface io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEvent
- isError() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEventElement
- isError() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableReceiveTask
- isFailed() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- isFinalState(ProcessInstanceIntent) - Static method in class io.camunda.zeebe.engine.processing.bpmn.ProcessInstanceLifecycle
- isInFinalState() - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- isInitialState(ProcessInstanceIntent) - Static method in class io.camunda.zeebe.engine.processing.bpmn.ProcessInstanceLifecycle
- isInState(long, JobState.State) - Method in interface io.camunda.zeebe.engine.state.immutable.JobState
- isInState(long, JobState.State) - Method in class io.camunda.zeebe.engine.state.instance.DbJobState
- isInterrupted() - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- isInterrupted(BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateBehavior
- isInterrupting() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableBoundaryEvent
- isInterrupting() - Method in interface io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEvent
- isInterrupting() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableStartEvent
- isInterrupting(DirectBuffer) - Method in class io.camunda.zeebe.engine.state.instance.EventScopeInstance
- isJobIncident(IncidentRecord) - Method in interface io.camunda.zeebe.engine.state.immutable.IncidentState
- isJobIncident(IncidentRecord) - Method in class io.camunda.zeebe.engine.state.instance.DbIncidentState
- isListOfCsv(Expression) - Static method in class io.camunda.zeebe.engine.processing.deployment.model.validation.ZeebeExpressionValidator
- isMakingProgress() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingStateMachine
- isMandatory() - Method in class io.camunda.zeebe.engine.processing.deployment.model.validation.ZeebeExpressionValidator.ExpressionVerification
- isMessage() - Method in interface io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEvent
- isMessage() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEventElement
- isMessage() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableReceiveTask
- isNone() - Method in interface io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEvent
- isNonStatic() - Method in class io.camunda.zeebe.engine.processing.deployment.model.validation.ZeebeExpressionValidator.ExpressionVerification
- isOnBlacklist(TypedRecord) - Method in interface io.camunda.zeebe.engine.state.immutable.BlackListState
- isOnBlacklist(TypedRecord) - Method in class io.camunda.zeebe.engine.state.processing.DbBlackListState
- isOpened() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- isOpening() - Method in class io.camunda.zeebe.engine.state.message.ProcessMessageSubscription
- isOptional() - Method in class io.camunda.zeebe.engine.processing.deployment.model.validation.ZeebeExpressionValidator.ExpressionVerification
- isPropagateAllChildVariablesEnabled() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCallActivity
- isSequential() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableLoopCharacteristics
- isTerminating() - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- isTerminating(ProcessInstanceIntent) - Static method in class io.camunda.zeebe.engine.processing.bpmn.ProcessInstanceLifecycle
- isTimer() - Method in interface io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEvent
- isTimer() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEventElement
- isTimer() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableReceiveTask
- isTokenState(ProcessInstanceIntent) - Static method in class io.camunda.zeebe.engine.processing.bpmn.ProcessInstanceLifecycle
- isValidStateTransition(BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.ProcessInstanceStateTransitionGuard
-
Checks if the preconditions of the given command are met.
- iterator() - Method in class io.camunda.zeebe.engine.state.variable.IndexedDocument
J
- JOB_ACTIVATABLE - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- JOB_BACKOFF - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- JOB_DEADLINES - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- JOB_STATES - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- JobAcceptFunction - Interface in io.camunda.zeebe.engine.processing.job
- jobActivated(String, int) - Method in class io.camunda.zeebe.engine.metrics.JobMetrics
- JobBackoffChecker - Class in io.camunda.zeebe.engine.processing.job
- JobBackoffChecker(JobState) - Constructor for class io.camunda.zeebe.engine.processing.job.JobBackoffChecker
- JobBatchActivatedApplier - Class in io.camunda.zeebe.engine.state.appliers
- JobBatchActivatedApplier(MutableZeebeState) - Constructor for class io.camunda.zeebe.engine.state.appliers.JobBatchActivatedApplier
- JobBatchActivateProcessor - Class in io.camunda.zeebe.engine.processing.job
- JobBatchActivateProcessor(Writers, ZeebeState, KeyGenerator, long, JobMetrics) - Constructor for class io.camunda.zeebe.engine.processing.job.JobBatchActivateProcessor
- jobBehavior() - Method in interface io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBehaviors
- jobBehavior() - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBehaviorsImpl
- jobCanceled(String) - Method in class io.camunda.zeebe.engine.metrics.JobMetrics
- JobCanceledApplier - Class in io.camunda.zeebe.engine.state.appliers
- JobCancelProcessor - Class in io.camunda.zeebe.engine.processing.job
- JobCancelProcessor(ZeebeState, JobMetrics) - Constructor for class io.camunda.zeebe.engine.processing.job.JobCancelProcessor
- jobCompleted(String) - Method in class io.camunda.zeebe.engine.metrics.JobMetrics
- JobCompleteProcessor - Class in io.camunda.zeebe.engine.processing.job
- JobCompleteProcessor(ZeebeState, JobMetrics, EventHandle) - Constructor for class io.camunda.zeebe.engine.processing.job.JobCompleteProcessor
- jobCreated(String) - Method in class io.camunda.zeebe.engine.metrics.JobMetrics
- jobErrorThrown(String) - Method in class io.camunda.zeebe.engine.metrics.JobMetrics
- JobErrorThrownApplier - Class in io.camunda.zeebe.engine.state.appliers
- JobEventProcessors - Class in io.camunda.zeebe.engine.processing.job
- JobEventProcessors() - Constructor for class io.camunda.zeebe.engine.processing.job.JobEventProcessors
- jobFailed(String) - Method in class io.camunda.zeebe.engine.metrics.JobMetrics
- JobFailProcessor - Class in io.camunda.zeebe.engine.processing.job
- JobFailProcessor(ZeebeState, KeyGenerator, JobMetrics, JobBackoffChecker) - Constructor for class io.camunda.zeebe.engine.processing.job.JobFailProcessor
- JobMetrics - Class in io.camunda.zeebe.engine.metrics
- JobMetrics(int) - Constructor for class io.camunda.zeebe.engine.metrics.JobMetrics
- JobRecordValue - Class in io.camunda.zeebe.engine.state.instance
- JobRecordValue() - Constructor for class io.camunda.zeebe.engine.state.instance.JobRecordValue
- JobRecurProcessor - Class in io.camunda.zeebe.engine.processing.job
- JobRecurProcessor(ZeebeState) - Constructor for class io.camunda.zeebe.engine.processing.job.JobRecurProcessor
- JobRecurredApplier - Class in io.camunda.zeebe.engine.state.appliers
- JobRetriesUpdatedApplier - Class in io.camunda.zeebe.engine.state.appliers
- JOBS - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- JobState - Interface in io.camunda.zeebe.engine.state.immutable
- JobState.State - Enum in io.camunda.zeebe.engine.state.immutable
- JobStateValue - Class in io.camunda.zeebe.engine.state.instance
- JobStateValue() - Constructor for class io.camunda.zeebe.engine.state.instance.JobStateValue
- JobThrowErrorProcessor - Class in io.camunda.zeebe.engine.processing.job
- JobThrowErrorProcessor(ZeebeState, BpmnEventPublicationBehavior, KeyGenerator, JobMetrics) - Constructor for class io.camunda.zeebe.engine.processing.job.JobThrowErrorProcessor
- jobTimedOut(String) - Method in class io.camunda.zeebe.engine.metrics.JobMetrics
- JobTimedOutApplier - Class in io.camunda.zeebe.engine.state.appliers
- JobTimeOutProcessor - Class in io.camunda.zeebe.engine.processing.job
- JobTimeOutProcessor(ZeebeState, JobMetrics) - Constructor for class io.camunda.zeebe.engine.processing.job.JobTimeOutProcessor
- JobTimeoutTrigger - Class in io.camunda.zeebe.engine.processing.job
- JobTimeoutTrigger(JobState) - Constructor for class io.camunda.zeebe.engine.processing.job.JobTimeoutTrigger
- JobUpdateRetriesProcessor - Class in io.camunda.zeebe.engine.processing.job
- JobUpdateRetriesProcessor(ZeebeState) - Constructor for class io.camunda.zeebe.engine.processing.job.JobUpdateRetriesProcessor
- JobWorkerElementTransformer<T extends FlowElement> - Class in io.camunda.zeebe.engine.processing.deployment.model.transformer
- JobWorkerElementTransformer(Class<T>) - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.transformer.JobWorkerElementTransformer
- JobWorkerProperties - Class in io.camunda.zeebe.engine.processing.deployment.model.element
-
The properties of an element that is based on a job and should be processed by a job worker.
- JobWorkerProperties() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.element.JobWorkerProperties
- JobWorkerTaskProcessor - Class in io.camunda.zeebe.engine.processing.bpmn.task
-
A BPMN processor for tasks that are based on jobs and should be processed by job workers.
- JobWorkerTaskProcessor(BpmnBehaviors) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.task.JobWorkerTaskProcessor
K
- key(long) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.writers.CommandResponseWriter
- KEY - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- KeyGenerator - Interface in io.camunda.zeebe.engine.state
-
Generate unique keys.
- KeyGeneratorControls - Interface in io.camunda.zeebe.engine.state
-
Allows to manipulate the key generator.
L
- LastProcessedPosition - Class in io.camunda.zeebe.engine.state.processing
- LastProcessedPosition() - Constructor for class io.camunda.zeebe.engine.state.processing.LastProcessedPosition
- LastProcessedPositionState - Interface in io.camunda.zeebe.engine.state.immutable
- LastProcessingPositions - Class in io.camunda.zeebe.engine.processing.streamprocessor
-
Contains positions which are related to the last processing, and are used to restore the processing state machine.
- LastProcessingPositions(long, long) - Constructor for class io.camunda.zeebe.engine.processing.streamprocessor.LastProcessingPositions
- LatestProcessVersion - Class in io.camunda.zeebe.engine.state.deployment
- LatestProcessVersion() - Constructor for class io.camunda.zeebe.engine.state.deployment.LatestProcessVersion
- length() - Method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- length(long) - Method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingEncoder
- lengthEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- lengthEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingEncoder
- lengthEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- lengthEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingEncoder
- lengthMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- lengthMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingEncoder
- lengthMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- lengthMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingEncoder
- lengthNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- lengthNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingEncoder
- lengthSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- limit() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- limit() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- limit() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- limit() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- limit() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- limit() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- limit() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- limit() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- limit() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- limit() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- limit() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- limit() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- limit() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- limit() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- limit(int) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- limit(int) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- limit(int) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- limit(int) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- limit(int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- limit(int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- limit(int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- limit(int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- limit(int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- limit(int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- limit(int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- limit(int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- limit(int) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- limit(int) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- listener(StreamProcessorListener) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- listener(StreamProcessorListener) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorBuilder
- Loggers - Class in io.camunda.zeebe.engine
- Loggers() - Constructor for class io.camunda.zeebe.engine.Loggers
- logStream(LogStream) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- logStream(LogStream) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorBuilder
- logStreamReader(LogStreamReader) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- logStreamWriter(TypedStreamWriter) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
M
- ManualTaskProcessor - Class in io.camunda.zeebe.engine.processing.bpmn.task
- ManualTaskProcessor(BpmnBehaviors) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.task.ManualTaskProcessor
- markAsProcessed(long) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableLastProcessedPositionState
- markAsProcessed(long) - Method in class io.camunda.zeebe.engine.state.processing.DbLastProcessedPositionState
- markInstanceIfInterrupted(long, long, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.appliers.EventSubProcessInterruptionMarker
-
Marks the flow scope as interrupted, if the triggered element id, corresponds to an interrupting event sub process.
- maxFragmentSize(int) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- mergeDocument(long, long, long, DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.variable.VariableBehavior
-
Merges the given document, propagating its changes from the bottom to the top of the scope hierarchy.
- mergeLocalDocument(long, long, long, DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.variable.VariableBehavior
-
Merges the given document directly on the given scope key.
- MESSAGE_CORRELATED - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- MESSAGE_DEADLINES - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- MESSAGE_IDS - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- MESSAGE_KEY - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- MESSAGE_PROCESS_INSTANCE_CORRELATION_KEYS - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- MESSAGE_PROCESSES_ACTIVE_BY_CORRELATION_KEY - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- MESSAGE_START_EVENT_SUBSCRIPTION_BY_KEY_AND_NAME - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- MESSAGE_START_EVENT_SUBSCRIPTION_BY_NAME_AND_KEY - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- MESSAGE_SUBSCRIPTION_BY_KEY - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- MESSAGE_SUBSCRIPTION_BY_NAME_AND_CORRELATION_KEY - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- MESSAGE_SUBSCRIPTION_BY_SENT_TIME - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
-
Deprecated.
- MESSAGE_TIME_TO_LIVE_CHECK_INTERVAL - Static variable in class io.camunda.zeebe.engine.processing.message.MessageObserver
- MessageCorrelationKeyException - Exception in io.camunda.zeebe.engine.processing.message
- MessageCorrelationKeyException(long, String) - Constructor for exception io.camunda.zeebe.engine.processing.message.MessageCorrelationKeyException
- MessageCorrelator - Class in io.camunda.zeebe.engine.processing.message
- MessageCorrelator(MessageState, SubscriptionCommandSender, StateWriter) - Constructor for class io.camunda.zeebe.engine.processing.message.MessageCorrelator
- MessageEventProcessors - Class in io.camunda.zeebe.engine.processing.message
- MessageEventProcessors() - Constructor for class io.camunda.zeebe.engine.processing.message.MessageEventProcessors
- MessageExpiredApplier - Class in io.camunda.zeebe.engine.state.appliers
- MessageExpiredApplier(MutableMessageState) - Constructor for class io.camunda.zeebe.engine.state.appliers.MessageExpiredApplier
- MessageExpireProcessor - Class in io.camunda.zeebe.engine.processing.message
- MessageExpireProcessor(StateWriter) - Constructor for class io.camunda.zeebe.engine.processing.message.MessageExpireProcessor
- MessageHeaderDecoder - Class in io.camunda.zeebe.engine.processing.message.command
-
Message identifiers and length of message root
- MessageHeaderDecoder() - Constructor for class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- MessageHeaderEncoder - Class in io.camunda.zeebe.engine.processing.message.command
-
Message identifiers and length of message root
- MessageHeaderEncoder() - Constructor for class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- messageKey() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- messageKey() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- messageKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- messageKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- messageKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- messageKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- messageKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- messageKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- messageKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- messageKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- messageKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- messageKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- messageKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- messageKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- messageKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- messageKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- messageKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- messageKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- messageKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- messageKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- messageKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- messageKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- messageKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- messageKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- messageKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- messageKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- messageKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- messageKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- messageKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- messageKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- messageKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- messageKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- messageKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- messageKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- messageKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- messageKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- messageName() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- messageName() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- messageName() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- messageName() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- messageName() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- messageName() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- messageName() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- messageName(String) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- messageName(String) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- messageName(String) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- messageName(String) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- messageName(String) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- messageName(String) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- messageName(String) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- messageNameCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- messageNameCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- messageNameCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- messageNameCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- messageNameCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- messageNameCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- messageNameCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- messageNameCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- messageNameCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- messageNameCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- messageNameCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- messageNameCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- messageNameCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- messageNameCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- MessageNameException - Exception in io.camunda.zeebe.engine.processing.message
- MessageNameException(Failure, DirectBuffer) - Constructor for exception io.camunda.zeebe.engine.processing.message.MessageNameException
- messageNameHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- messageNameHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- messageNameHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- messageNameHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- messageNameHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- messageNameHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- messageNameHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- messageNameHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- messageNameHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- messageNameHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- messageNameHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- messageNameHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- messageNameHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- messageNameHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- messageNameId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- messageNameId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- messageNameId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- messageNameId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- messageNameId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- messageNameId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- messageNameId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- messageNameId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- messageNameId() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- messageNameId() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- messageNameId() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- messageNameId() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- messageNameId() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- messageNameId() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- messageNameLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- messageNameLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- messageNameLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- messageNameLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- messageNameLength() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- messageNameLength() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- messageNameLength() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- messageNameMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- messageNameMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- messageNameMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- messageNameMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- messageNameMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- messageNameMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- messageNameMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- messageNameMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- messageNameMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- messageNameMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- messageNameMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- messageNameMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- messageNameMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- messageNameMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- messageNameSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- messageNameSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- messageNameSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- messageNameSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- messageNameSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- messageNameSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- messageNameSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- MessageObserver - Class in io.camunda.zeebe.engine.processing.message
- MessageObserver(MessageState, MutablePendingMessageSubscriptionState, SubscriptionCommandSender) - Constructor for class io.camunda.zeebe.engine.processing.message.MessageObserver
- MessagePublishedApplier - Class in io.camunda.zeebe.engine.state.appliers
- MessagePublishedApplier(MutableMessageState) - Constructor for class io.camunda.zeebe.engine.state.appliers.MessagePublishedApplier
- MessagePublishProcessor - Class in io.camunda.zeebe.engine.processing.message
- MessagePublishProcessor(MessageState, MessageSubscriptionState, MessageStartEventSubscriptionState, EventScopeInstanceState, SubscriptionCommandSender, KeyGenerator, Writers, ProcessState, EventTriggerBehavior) - Constructor for class io.camunda.zeebe.engine.processing.message.MessagePublishProcessor
- MESSAGES - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- MessageStartEventSubscription - Class in io.camunda.zeebe.engine.state.message
- MessageStartEventSubscription() - Constructor for class io.camunda.zeebe.engine.state.message.MessageStartEventSubscription
- MessageStartEventSubscriptionCorrelatedApplier - Class in io.camunda.zeebe.engine.state.appliers
- MessageStartEventSubscriptionCorrelatedApplier(MutableMessageState) - Constructor for class io.camunda.zeebe.engine.state.appliers.MessageStartEventSubscriptionCorrelatedApplier
- MessageStartEventSubscriptionCreatedApplier - Class in io.camunda.zeebe.engine.state.appliers
- MessageStartEventSubscriptionCreatedApplier(MutableMessageStartEventSubscriptionState) - Constructor for class io.camunda.zeebe.engine.state.appliers.MessageStartEventSubscriptionCreatedApplier
- MessageStartEventSubscriptionDeletedApplier - Class in io.camunda.zeebe.engine.state.appliers
- MessageStartEventSubscriptionDeletedApplier(MutableMessageStartEventSubscriptionState) - Constructor for class io.camunda.zeebe.engine.state.appliers.MessageStartEventSubscriptionDeletedApplier
- MessageStartEventSubscriptionManager - Class in io.camunda.zeebe.engine.processing.deployment
- MessageStartEventSubscriptionManager(ProcessState, MessageStartEventSubscriptionState, KeyGenerator) - Constructor for class io.camunda.zeebe.engine.processing.deployment.MessageStartEventSubscriptionManager
- MessageStartEventSubscriptionState - Interface in io.camunda.zeebe.engine.state.immutable
- MessageStartEventSubscriptionState.MessageStartEventSubscriptionVisitor - Interface in io.camunda.zeebe.engine.state.immutable
- MessageState - Interface in io.camunda.zeebe.engine.state.immutable
- MessageState.MessageVisitor - Interface in io.camunda.zeebe.engine.state.immutable
- MessageSubscription - Class in io.camunda.zeebe.engine.state.message
- MessageSubscription() - Constructor for class io.camunda.zeebe.engine.state.message.MessageSubscription
- MessageSubscriptionCorrelatedApplier - Class in io.camunda.zeebe.engine.state.appliers
- MessageSubscriptionCorrelatedApplier(MutableMessageSubscriptionState) - Constructor for class io.camunda.zeebe.engine.state.appliers.MessageSubscriptionCorrelatedApplier
- MessageSubscriptionCorrelateProcessor - Class in io.camunda.zeebe.engine.processing.message
- MessageSubscriptionCorrelateProcessor(MessageState, MessageSubscriptionState, SubscriptionCommandSender, Writers) - Constructor for class io.camunda.zeebe.engine.processing.message.MessageSubscriptionCorrelateProcessor
- MessageSubscriptionCorrelatingApplier - Class in io.camunda.zeebe.engine.state.appliers
- MessageSubscriptionCorrelatingApplier(MutableMessageSubscriptionState, MutableMessageState) - Constructor for class io.camunda.zeebe.engine.state.appliers.MessageSubscriptionCorrelatingApplier
- MessageSubscriptionCreatedApplier - Class in io.camunda.zeebe.engine.state.appliers
- MessageSubscriptionCreatedApplier(MutableMessageSubscriptionState) - Constructor for class io.camunda.zeebe.engine.state.appliers.MessageSubscriptionCreatedApplier
- MessageSubscriptionCreateProcessor - Class in io.camunda.zeebe.engine.processing.message
- MessageSubscriptionCreateProcessor(MessageState, MessageSubscriptionState, SubscriptionCommandSender, Writers, KeyGenerator) - Constructor for class io.camunda.zeebe.engine.processing.message.MessageSubscriptionCreateProcessor
- MessageSubscriptionDeletedApplier - Class in io.camunda.zeebe.engine.state.appliers
- MessageSubscriptionDeletedApplier(MutableMessageSubscriptionState) - Constructor for class io.camunda.zeebe.engine.state.appliers.MessageSubscriptionDeletedApplier
- MessageSubscriptionDeleteProcessor - Class in io.camunda.zeebe.engine.processing.message
- MessageSubscriptionDeleteProcessor(MessageSubscriptionState, SubscriptionCommandSender, Writers) - Constructor for class io.camunda.zeebe.engine.processing.message.MessageSubscriptionDeleteProcessor
- MessageSubscriptionRejectedApplier - Class in io.camunda.zeebe.engine.state.appliers
- MessageSubscriptionRejectedApplier(MutableMessageState) - Constructor for class io.camunda.zeebe.engine.state.appliers.MessageSubscriptionRejectedApplier
- MessageSubscriptionRejectProcessor - Class in io.camunda.zeebe.engine.processing.message
- MessageSubscriptionRejectProcessor(MessageState, MessageSubscriptionState, SubscriptionCommandSender, Writers) - Constructor for class io.camunda.zeebe.engine.processing.message.MessageSubscriptionRejectProcessor
- MessageSubscriptionSentTimeMigration - Class in io.camunda.zeebe.engine.state.migration
-
Reads out the sent time for message subscriptions and sets the
correlating
field in records inZbColumnFamilies.MESSAGE_SUBSCRIPTION_BY_KEY
- MessageSubscriptionSentTimeMigration() - Constructor for class io.camunda.zeebe.engine.state.migration.MessageSubscriptionSentTimeMigration
- MessageSubscriptionState - Interface in io.camunda.zeebe.engine.state.immutable
- MessageSubscriptionState.MessageSubscriptionVisitor - Interface in io.camunda.zeebe.engine.state.immutable
- MessageTimeToLiveChecker - Class in io.camunda.zeebe.engine.processing.message
- MessageTimeToLiveChecker(TypedCommandWriter, MessageState) - Constructor for class io.camunda.zeebe.engine.processing.message.MessageTimeToLiveChecker
- MessageTransformer - Class in io.camunda.zeebe.engine.processing.deployment.model.transformer
- MessageTransformer() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.transformer.MessageTransformer
- MetaAttribute - Enum in io.camunda.zeebe.engine.processing.message.command
-
Meta attribute enum for selecting a particular meta attribute value.
- metadata - Variable in class io.camunda.zeebe.engine.processing.streamprocessor.MetadataEventFilter
- MetadataEventFilter - Class in io.camunda.zeebe.engine.processing.streamprocessor
- MetadataEventFilter(MetadataFilter) - Constructor for class io.camunda.zeebe.engine.processing.streamprocessor.MetadataEventFilter
- metadataFilter - Variable in class io.camunda.zeebe.engine.processing.streamprocessor.MetadataEventFilter
- MetadataFilter - Interface in io.camunda.zeebe.engine.processing.streamprocessor
-
Implement to control which events should be handled by a
StreamProcessor
based on the event's metadata. - migrateMessageSubscriptionSentTime(MutableMessageSubscriptionState, MutablePendingMessageSubscriptionState) - Method in class io.camunda.zeebe.engine.state.migration.DbMigrationState
- migrateMessageSubscriptionSentTime(MutableMessageSubscriptionState, MutablePendingMessageSubscriptionState) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableMigrationState
- migrateProcessMessageSubscriptionSentTime(MutableProcessMessageSubscriptionState, MutablePendingProcessMessageSubscriptionState) - Method in class io.camunda.zeebe.engine.state.migration.DbMigrationState
- migrateProcessMessageSubscriptionSentTime(MutableProcessMessageSubscriptionState, MutablePendingProcessMessageSubscriptionState) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableMigrationState
- migrateTemporaryVariables(MutableEventScopeInstanceState, MutableElementInstanceState) - Method in class io.camunda.zeebe.engine.state.migration.DbMigrationState
- migrateTemporaryVariables(MutableEventScopeInstanceState, MutableElementInstanceState) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableMigrationState
- MigrationTask - Interface in io.camunda.zeebe.engine.state.migration
-
Interface for migration tasks.
- MISSING_INCIDENT - Static variable in interface io.camunda.zeebe.engine.state.immutable.IncidentState
- MISSING_INCIDENT - Static variable in class io.camunda.zeebe.engine.state.instance.DbIncidentState
- ModelElementTransformer<T extends BpmnModelElementInstance> - Interface in io.camunda.zeebe.engine.processing.deployment.model.transformation
- MultiInstanceActivityTransformer - Class in io.camunda.zeebe.engine.processing.deployment.model.transformer
- MultiInstanceActivityTransformer() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.transformer.MultiInstanceActivityTransformer
- MultiInstanceBodyProcessor - Class in io.camunda.zeebe.engine.processing.bpmn.container
- MultiInstanceBodyProcessor(BpmnBehaviors) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.container.MultiInstanceBodyProcessor
- MutableBlackListState - Interface in io.camunda.zeebe.engine.state.mutable
- MutableDeploymentState - Interface in io.camunda.zeebe.engine.state.mutable
- MutableElementInstanceState - Interface in io.camunda.zeebe.engine.state.mutable
- MutableEventScopeInstanceState - Interface in io.camunda.zeebe.engine.state.mutable
- MutableIncidentState - Interface in io.camunda.zeebe.engine.state.mutable
- MutableJobState - Interface in io.camunda.zeebe.engine.state.mutable
- MutableLastProcessedPositionState - Interface in io.camunda.zeebe.engine.state.mutable
- MutableMessageStartEventSubscriptionState - Interface in io.camunda.zeebe.engine.state.mutable
- MutableMessageState - Interface in io.camunda.zeebe.engine.state.mutable
- MutableMessageSubscriptionState - Interface in io.camunda.zeebe.engine.state.mutable
- MutableMigrationState - Interface in io.camunda.zeebe.engine.state.mutable
- MutablePendingMessageSubscriptionState - Interface in io.camunda.zeebe.engine.state.mutable
- MutablePendingProcessMessageSubscriptionState - Interface in io.camunda.zeebe.engine.state.mutable
-
Captures the transient (in-memory) state for a ProcessMessageSubscription.
- MutableProcessMessageSubscriptionState - Interface in io.camunda.zeebe.engine.state.mutable
- MutableProcessState - Interface in io.camunda.zeebe.engine.state.mutable
- MutableTimerInstanceState - Interface in io.camunda.zeebe.engine.state.mutable
- MutableVariableState - Interface in io.camunda.zeebe.engine.state.mutable
- MutableZeebeState - Interface in io.camunda.zeebe.engine.state.mutable
N
- needsToRun(ZeebeState) - Method in class io.camunda.zeebe.engine.state.migration.MessageSubscriptionSentTimeMigration
- needsToRun(ZeebeState) - Method in interface io.camunda.zeebe.engine.state.migration.MigrationTask
-
Returns whether the migration needs to run
- needsToRun(ZeebeState) - Method in class io.camunda.zeebe.engine.state.migration.ProcessMessageSubscriptionSentTimeMigration
- needsToRun(ZeebeState) - Method in class io.camunda.zeebe.engine.state.migration.TemporaryVariableMigration
- newInstance(long, ProcessInstanceRecord, ProcessInstanceIntent) - Method in class io.camunda.zeebe.engine.state.instance.DbElementInstanceState
- newInstance(long, ProcessInstanceRecord, ProcessInstanceIntent) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableElementInstanceState
- newInstance(ElementInstance, long, ProcessInstanceRecord, ProcessInstanceIntent) - Method in class io.camunda.zeebe.engine.state.instance.DbElementInstanceState
- newInstance(ElementInstance, long, ProcessInstanceRecord, ProcessInstanceIntent) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableElementInstanceState
- nextKey() - Method in interface io.camunda.zeebe.engine.state.KeyGenerator
-
Returns the next key of a record and updates the key generator.
- nextKey() - Method in class io.camunda.zeebe.engine.state.processing.DbKeyGenerator
- NextValue - Class in io.camunda.zeebe.engine.state
- NextValue() - Constructor for class io.camunda.zeebe.engine.state.NextValue
- NextValueManager - Class in io.camunda.zeebe.engine.state
- NextValueManager(long, ZeebeDb<ZbColumnFamilies>, TransactionContext, ZbColumnFamilies) - Constructor for class io.camunda.zeebe.engine.state.NextValueManager
- NO_CATCH_EVENT_FOUND - Static variable in class io.camunda.zeebe.engine.processing.job.JobThrowErrorProcessor
-
Marker element ID.
- NO_ELEMENT_INSTANCE - Static variable in class io.camunda.zeebe.engine.state.instance.TimerInstance
- NO_INCIDENT_FOUND_MSG - Static variable in class io.camunda.zeebe.engine.processing.incident.ResolveIncidentProcessor
- NO_JOB_FOUND_MESSAGE - Static variable in class io.camunda.zeebe.engine.processing.job.JobCancelProcessor
- NO_PARENT - Static variable in interface io.camunda.zeebe.engine.state.immutable.VariableState
-
The value of the parent scope key for scope with no parents.
- NO_TIMER_FOUND_MESSAGE - Static variable in class io.camunda.zeebe.engine.processing.timer.CancelTimerProcessor
- nodeId(int) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorBuilder
- NoopResponseWriter - Class in io.camunda.zeebe.engine.processing.streamprocessor.writers
- NoopResponseWriter() - Constructor for class io.camunda.zeebe.engine.processing.streamprocessor.writers.NoopResponseWriter
- NoopTypedStreamWriter - Class in io.camunda.zeebe.engine.processing.streamprocessor.writers
- NoopTypedStreamWriter() - Constructor for class io.camunda.zeebe.engine.processing.streamprocessor.writers.NoopTypedStreamWriter
- NOT_ACTIVATED_JOB_MESSAGE - Static variable in class io.camunda.zeebe.engine.processing.job.JobTimeOutProcessor
- NOT_FOUND - Enum constant in enum io.camunda.zeebe.engine.state.immutable.JobState.State
- NULL_VAL - Enum constant in enum io.camunda.zeebe.engine.processing.message.command.BooleanType
-
To be used to represent not present or null.
- NUMBER_OF_TAKEN_SEQUENCE_FLOWS - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
O
- offset() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- offset() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- offset() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- offset() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- offset() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- offset() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- offset() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- offset() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- offset() - Method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- offset() - Method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- offset() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- offset() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- offset() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- offset() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- offset() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- offset() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- offset() - Method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- offset() - Method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingEncoder
- onActivate(ExecutableActivity, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.task.ManualTaskProcessor
- onActivate(ExecutableBoundaryEvent, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.event.BoundaryEventProcessor
- onActivate(ExecutableCallActivity, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.CallActivityProcessor
- onActivate(ExecutableCatchEventElement, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.event.IntermediateCatchEventProcessor
- onActivate(ExecutableEndEvent, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.event.EndEventProcessor
- onActivate(ExecutableEventBasedGateway, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.gateway.EventBasedGatewayProcessor
- onActivate(ExecutableExclusiveGateway, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.gateway.ExclusiveGatewayProcessor
- onActivate(ExecutableFlowElementContainer, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.EventSubProcessProcessor
- onActivate(ExecutableFlowElementContainer, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.ProcessProcessor
- onActivate(ExecutableFlowElementContainer, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.SubProcessProcessor
- onActivate(ExecutableFlowNode, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.gateway.ParallelGatewayProcessor
- onActivate(ExecutableIntermediateThrowEvent, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.event.IntermediateThrowEventProcessor
- onActivate(ExecutableJobWorkerTask, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.task.JobWorkerTaskProcessor
- onActivate(ExecutableMultiInstanceBody, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.MultiInstanceBodyProcessor
- onActivate(ExecutableReceiveTask, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.task.ReceiveTaskProcessor
- onActivate(ExecutableStartEvent, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.event.StartEventProcessor
- onActivate(T, BpmnElementContext) - Method in interface io.camunda.zeebe.engine.processing.bpmn.BpmnElementProcessor
-
The element is about to be entered.
- onActorClosed() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- onActorCloseRequested() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- onActorClosing() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- onActorFailed() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- onActorStarted() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- onActorStarting() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- onCalledProcessCompleted(BpmnElementContext, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateTransitionBehavior
- onCalledProcessTerminated(BpmnElementContext, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateTransitionBehavior
- onChildActivating(ExecutableMultiInstanceBody, BpmnElementContext, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.MultiInstanceBodyProcessor
- onChildActivating(T, BpmnElementContext, BpmnElementContext) - Method in interface io.camunda.zeebe.engine.processing.bpmn.BpmnElementContainerProcessor
-
A child element is on activating (but not yet activated).
- onChildCompleting(T, BpmnElementContext, BpmnElementContext) - Method in interface io.camunda.zeebe.engine.processing.bpmn.BpmnElementContainerProcessor
-
A child element is completing (but not yet completed).
- onChildTerminated(ExecutableCallActivity, BpmnElementContext, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.CallActivityProcessor
- onChildTerminated(ExecutableFlowElementContainer, BpmnElementContext, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.EventSubProcessProcessor
- onChildTerminated(ExecutableFlowElementContainer, BpmnElementContext, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.ProcessProcessor
- onChildTerminated(ExecutableFlowElementContainer, BpmnElementContext, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.SubProcessProcessor
- onChildTerminated(ExecutableMultiInstanceBody, BpmnElementContext, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.MultiInstanceBodyProcessor
- onChildTerminated(T, BpmnElementContext, BpmnElementContext) - Method in interface io.camunda.zeebe.engine.processing.bpmn.BpmnElementContainerProcessor
-
A child element is terminated.
- onClose() - Method in class io.camunda.zeebe.engine.processing.job.JobBackoffChecker
- onClose() - Method in class io.camunda.zeebe.engine.processing.job.JobTimeoutTrigger
- onClose() - Method in class io.camunda.zeebe.engine.processing.message.PendingProcessMessageSubscriptionChecker
- onClose() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorLifecycleAware
-
Callback which is called when StreamProcessor is on closing phase.
- onClose() - Method in class io.camunda.zeebe.engine.processing.timer.DueDateTimerChecker
- onClose() - Method in class io.camunda.zeebe.engine.state.migration.DbMigrationController
- onCommand(TypedRecord<JobRecord>, CommandProcessor.CommandControl<JobRecord>) - Method in class io.camunda.zeebe.engine.processing.job.JobCancelProcessor
- onCommand(TypedRecord<JobRecord>, CommandProcessor.CommandControl<JobRecord>) - Method in class io.camunda.zeebe.engine.processing.job.JobCompleteProcessor
- onCommand(TypedRecord<JobRecord>, CommandProcessor.CommandControl<JobRecord>) - Method in class io.camunda.zeebe.engine.processing.job.JobRecurProcessor
- onCommand(TypedRecord<JobRecord>, CommandProcessor.CommandControl<JobRecord>) - Method in class io.camunda.zeebe.engine.processing.job.JobThrowErrorProcessor
- onCommand(TypedRecord<JobRecord>, CommandProcessor.CommandControl<JobRecord>) - Method in class io.camunda.zeebe.engine.processing.job.JobTimeOutProcessor
- onCommand(TypedRecord<JobRecord>, CommandProcessor.CommandControl<JobRecord>) - Method in class io.camunda.zeebe.engine.processing.job.JobUpdateRetriesProcessor
- onCommand(TypedRecord<JobRecord>, CommandProcessor.CommandControl<JobRecord>, Consumer<SideEffectProducer>) - Method in class io.camunda.zeebe.engine.processing.job.JobFailProcessor
- onCommand(TypedRecord<ProcessInstanceCreationRecord>, CommandProcessor.CommandControl<ProcessInstanceCreationRecord>) - Method in class io.camunda.zeebe.engine.processing.processinstance.CreateProcessInstanceProcessor
- onCommand(TypedRecord<ProcessInstanceCreationRecord>, CommandProcessor.CommandControl<ProcessInstanceCreationRecord>, Consumer<SideEffectProducer>) - Method in class io.camunda.zeebe.engine.processing.processinstance.CreateProcessInstanceWithResultProcessor
- onCommand(TypedRecord<T>, CommandProcessor.CommandControl<T>) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.CommandProcessor
- onCommand(TypedRecord<T>, CommandProcessor.CommandControl<T>, Consumer<SideEffectProducer>) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.CommandProcessor
- onCommand(ValueType, Intent, CommandProcessor<T>) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.TypedRecordProcessors
- onCommand(ValueType, Intent, TypedRecordProcessor<?>) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.TypedRecordProcessors
- onComplete(ExecutableActivity, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.task.ManualTaskProcessor
- onComplete(ExecutableBoundaryEvent, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.event.BoundaryEventProcessor
- onComplete(ExecutableCallActivity, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.CallActivityProcessor
- onComplete(ExecutableCatchEventElement, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.event.IntermediateCatchEventProcessor
- onComplete(ExecutableEndEvent, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.event.EndEventProcessor
- onComplete(ExecutableEventBasedGateway, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.gateway.EventBasedGatewayProcessor
- onComplete(ExecutableExclusiveGateway, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.gateway.ExclusiveGatewayProcessor
- onComplete(ExecutableFlowElementContainer, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.EventSubProcessProcessor
- onComplete(ExecutableFlowElementContainer, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.ProcessProcessor
- onComplete(ExecutableFlowElementContainer, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.SubProcessProcessor
- onComplete(ExecutableFlowNode, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.gateway.ParallelGatewayProcessor
- onComplete(ExecutableIntermediateThrowEvent, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.event.IntermediateThrowEventProcessor
- onComplete(ExecutableJobWorkerTask, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.task.JobWorkerTaskProcessor
- onComplete(ExecutableMultiInstanceBody, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.MultiInstanceBodyProcessor
- onComplete(ExecutableReceiveTask, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.task.ReceiveTaskProcessor
- onComplete(ExecutableStartEvent, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.event.StartEventProcessor
- onComplete(T, BpmnElementContext) - Method in interface io.camunda.zeebe.engine.processing.bpmn.BpmnElementProcessor
-
The element is going to be left.
- onElementActivating(ExecutableFlowElement, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateTransitionBehavior
- onElementTerminated(ExecutableFlowElement, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateTransitionBehavior
- onFailed() - Method in class io.camunda.zeebe.engine.processing.job.JobBackoffChecker
- onFailed() - Method in class io.camunda.zeebe.engine.processing.job.JobTimeoutTrigger
- onFailed() - Method in class io.camunda.zeebe.engine.processing.message.PendingProcessMessageSubscriptionChecker
- onFailed() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorLifecycleAware
-
Callback which is called when the StreamProcessor failed, during startup or processing.
- onFailed() - Method in class io.camunda.zeebe.engine.processing.timer.DueDateTimerChecker
- onFailed() - Method in class io.camunda.zeebe.engine.state.migration.DbMigrationController
- onPaused() - Method in class io.camunda.zeebe.engine.processing.job.JobBackoffChecker
- onPaused() - Method in class io.camunda.zeebe.engine.processing.job.JobTimeoutTrigger
- onPaused() - Method in class io.camunda.zeebe.engine.processing.message.PendingProcessMessageSubscriptionChecker
- onPaused() - Method in class io.camunda.zeebe.engine.processing.scheduled.DueDateChecker
- onPaused() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorLifecycleAware
-
Callback which is called when the processing is paused, will only called after onRecovered was called before.
- onPaused() - Method in class io.camunda.zeebe.engine.processing.timer.DueDateTimerChecker
- onProcessed(TypedRecord<?>) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorListener
-
Is called when a command is processed.
- onRecordAvailable() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ReplayStateMachine
- onRecordAvailable() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- onRecovered(ReadonlyProcessingContext) - Method in class io.camunda.zeebe.engine.processing.deployment.distribute.DeploymentRedistributor
- onRecovered(ReadonlyProcessingContext) - Method in class io.camunda.zeebe.engine.processing.job.JobBackoffChecker
- onRecovered(ReadonlyProcessingContext) - Method in class io.camunda.zeebe.engine.processing.job.JobTimeoutTrigger
- onRecovered(ReadonlyProcessingContext) - Method in class io.camunda.zeebe.engine.processing.message.MessageObserver
- onRecovered(ReadonlyProcessingContext) - Method in class io.camunda.zeebe.engine.processing.message.PendingProcessMessageSubscriptionChecker
- onRecovered(ReadonlyProcessingContext) - Method in class io.camunda.zeebe.engine.processing.scheduled.DueDateChecker
- onRecovered(ReadonlyProcessingContext) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorLifecycleAware
-
Callback after reprocessing was successful and before regular processing begins
- onRecovered(ReadonlyProcessingContext) - Method in class io.camunda.zeebe.engine.processing.timer.DueDateTimerChecker
- onRecovered(ReadonlyProcessingContext) - Method in class io.camunda.zeebe.engine.state.message.DbMessageSubscriptionState
- onRecovered(ReadonlyProcessingContext) - Method in class io.camunda.zeebe.engine.state.message.DbProcessMessageSubscriptionState
- onRecovered(ReadonlyProcessingContext) - Method in class io.camunda.zeebe.engine.state.migration.DbMigrationController
- onRecovered(ReadonlyProcessingContext) - Method in class io.camunda.zeebe.engine.state.ZeebeDbState
- onReplayed(long, long) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorListener
-
Is called when one or more events are replayed.
- onResumed() - Method in class io.camunda.zeebe.engine.processing.job.JobBackoffChecker
- onResumed() - Method in class io.camunda.zeebe.engine.processing.job.JobTimeoutTrigger
- onResumed() - Method in class io.camunda.zeebe.engine.processing.message.PendingProcessMessageSubscriptionChecker
- onResumed() - Method in class io.camunda.zeebe.engine.processing.scheduled.DueDateChecker
- onResumed() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorLifecycleAware
-
Callback which is called when the processing is resumed, will only called after onPaused was called before.
- onResumed() - Method in class io.camunda.zeebe.engine.processing.timer.DueDateTimerChecker
- onSkipped(LoggedEvent) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorListener
-
Is called when a record is skipped and not processed.
- onTerminate(ExecutableActivity, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.task.ManualTaskProcessor
- onTerminate(ExecutableBoundaryEvent, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.event.BoundaryEventProcessor
- onTerminate(ExecutableCallActivity, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.CallActivityProcessor
- onTerminate(ExecutableCatchEventElement, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.event.IntermediateCatchEventProcessor
- onTerminate(ExecutableEndEvent, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.event.EndEventProcessor
- onTerminate(ExecutableEventBasedGateway, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.gateway.EventBasedGatewayProcessor
- onTerminate(ExecutableExclusiveGateway, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.gateway.ExclusiveGatewayProcessor
- onTerminate(ExecutableFlowElementContainer, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.EventSubProcessProcessor
- onTerminate(ExecutableFlowElementContainer, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.ProcessProcessor
- onTerminate(ExecutableFlowElementContainer, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.SubProcessProcessor
- onTerminate(ExecutableFlowNode, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.gateway.ParallelGatewayProcessor
- onTerminate(ExecutableIntermediateThrowEvent, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.event.IntermediateThrowEventProcessor
- onTerminate(ExecutableJobWorkerTask, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.task.JobWorkerTaskProcessor
- onTerminate(ExecutableMultiInstanceBody, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.container.MultiInstanceBodyProcessor
- onTerminate(ExecutableReceiveTask, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.task.ReceiveTaskProcessor
- onTerminate(ExecutableStartEvent, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.event.StartEventProcessor
- onTerminate(T, BpmnElementContext) - Method in interface io.camunda.zeebe.engine.processing.bpmn.BpmnElementProcessor
-
The element is going to be terminated.
- openAsync(boolean) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- openMessageSubscription(int, long, long, DirectBuffer, DirectBuffer, DirectBuffer, boolean) - Method in class io.camunda.zeebe.engine.processing.message.command.SubscriptionCommandSender
- OpenMessageSubscriptionCommand - Class in io.camunda.zeebe.engine.processing.message.command
- OpenMessageSubscriptionCommand() - Constructor for class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionCommand
- OpenMessageSubscriptionDecoder - Class in io.camunda.zeebe.engine.processing.message.command
- OpenMessageSubscriptionDecoder() - Constructor for class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- OpenMessageSubscriptionEncoder - Class in io.camunda.zeebe.engine.processing.message.command
- OpenMessageSubscriptionEncoder() - Constructor for class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- openProcessMessageSubscription(long, long, DirectBuffer, boolean) - Method in class io.camunda.zeebe.engine.processing.message.command.SubscriptionCommandSender
- OpenProcessMessageSubscriptionCommand - Class in io.camunda.zeebe.engine.processing.message.command
- OpenProcessMessageSubscriptionCommand() - Constructor for class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionCommand
- OpenProcessMessageSubscriptionDecoder - Class in io.camunda.zeebe.engine.processing.message.command
- OpenProcessMessageSubscriptionDecoder() - Constructor for class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- OpenProcessMessageSubscriptionEncoder - Class in io.camunda.zeebe.engine.processing.message.command
- OpenProcessMessageSubscriptionEncoder() - Constructor for class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
P
- ParallelGatewayProcessor - Class in io.camunda.zeebe.engine.processing.bpmn.gateway
- ParallelGatewayProcessor(BpmnBehaviors) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.gateway.ParallelGatewayProcessor
- ParentScopeKey - Class in io.camunda.zeebe.engine.state.instance
- ParentScopeKey() - Constructor for class io.camunda.zeebe.engine.state.instance.ParentScopeKey
- parseListOfCsv(String) - Static method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.ExpressionTransformer
-
Parses a static value as a list of CSV, trimming any whitespace.
- PartitionCommandSender - Interface in io.camunda.zeebe.engine.processing.message.command
- partitionId(int) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.writers.CommandResponseWriter
- PAUSED - Enum constant in enum io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor.Phase
- pauseProcessing() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- peekEventTrigger(long) - Method in interface io.camunda.zeebe.engine.state.immutable.EventScopeInstanceState
-
Returns the next event trigger for the event scope or null if none exists.
- peekEventTrigger(long) - Method in class io.camunda.zeebe.engine.state.instance.DbEventScopeInstanceState
- PENDING_DEPLOYMENT - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- PendingMessageSubscriptionChecker - Class in io.camunda.zeebe.engine.processing.message
- PendingMessageSubscriptionChecker(SubscriptionCommandSender, MutablePendingMessageSubscriptionState, long) - Constructor for class io.camunda.zeebe.engine.processing.message.PendingMessageSubscriptionChecker
- PendingProcessMessageSubscriptionChecker - Class in io.camunda.zeebe.engine.processing.message
- PendingProcessMessageSubscriptionChecker(SubscriptionCommandSender, MutablePendingProcessMessageSubscriptionState) - Constructor for class io.camunda.zeebe.engine.processing.message.PendingProcessMessageSubscriptionChecker
- PersistedProcess - Class in io.camunda.zeebe.engine.state.deployment
- PersistedProcess() - Constructor for class io.camunda.zeebe.engine.state.deployment.PersistedProcess
- pollEventTrigger(long) - Method in class io.camunda.zeebe.engine.state.instance.DbEventScopeInstanceState
- pollEventTrigger(long) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableEventScopeInstanceState
-
Returns the next event trigger for the event scope or null if none exists.
- PRESENCE - Enum constant in enum io.camunda.zeebe.engine.processing.message.command.MetaAttribute
-
Field presence indication.
- PROCESS_CACHE - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- PROCESS_CACHE_BY_ID_AND_VERSION - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- PROCESS_CACHE_DIGEST_BY_ID - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- PROCESS_PROCESSOR_LOGGER - Static variable in class io.camunda.zeebe.engine.Loggers
- PROCESS_REPOSITORY_LOGGER - Static variable in class io.camunda.zeebe.engine.Loggers
- PROCESS_SUBSCRIPTION_BY_KEY - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- PROCESS_SUBSCRIPTION_BY_SENT_TIME - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
-
Deprecated.
- PROCESS_VERSION - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- ProcessCreatedApplier - Class in io.camunda.zeebe.engine.state.appliers
- ProcessCreatedApplier(MutableZeebeState) - Constructor for class io.camunda.zeebe.engine.state.appliers.ProcessCreatedApplier
- ProcessEngineMetrics - Class in io.camunda.zeebe.engine.metrics
- ProcessEngineMetrics(int) - Constructor for class io.camunda.zeebe.engine.metrics.ProcessEngineMetrics
- ProcessEventProcessors - Class in io.camunda.zeebe.engine.processing
- ProcessEventProcessors() - Constructor for class io.camunda.zeebe.engine.processing.ProcessEventProcessors
- processEventTriggered(long, long, long, long, DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.common.EventTriggerBehavior
-
Marks a process to be triggered by updating the state with a new
ProcessEventIntent.TRIGGERED
event. - PROCESSING - Enum constant in enum io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor.Phase
- PROCESSING - Enum constant in enum io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorMode
-
When in PROCESSING mode, stream processor first replays existing events, and then switch to processing commands.
- ProcessingContext - Class in io.camunda.zeebe.engine.processing.streamprocessor
- ProcessingContext() - Constructor for class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- ProcessingException - Exception in io.camunda.zeebe.engine.processing.streamprocessor
- ProcessingException(String, LoggedEvent, RecordMetadata, Throwable) - Constructor for exception io.camunda.zeebe.engine.processing.streamprocessor.ProcessingException
- processingLatency(long, long) - Method in class io.camunda.zeebe.engine.metrics.StreamProcessorMetrics
- ProcessingStateMachine - Class in io.camunda.zeebe.engine.processing.streamprocessor
-
Represents the processing state machine, which is executed on normal processing.
- ProcessingStateMachine(ProcessingContext, BooleanSupplier) - Constructor for class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingStateMachine
- ProcessInstanceCommandContext - Class in io.camunda.zeebe.engine.processing.processinstance
- ProcessInstanceCommandContext(MutableElementInstanceState) - Constructor for class io.camunda.zeebe.engine.processing.processinstance.ProcessInstanceCommandContext
- ProcessInstanceCommandHandler - Interface in io.camunda.zeebe.engine.processing.processinstance
- ProcessInstanceCommandHandlers - Class in io.camunda.zeebe.engine.processing.processinstance
- ProcessInstanceCommandHandlers() - Constructor for class io.camunda.zeebe.engine.processing.processinstance.ProcessInstanceCommandHandlers
- ProcessInstanceCommandProcessor - Class in io.camunda.zeebe.engine.processing.processinstance
- ProcessInstanceCommandProcessor(MutableElementInstanceState) - Constructor for class io.camunda.zeebe.engine.processing.processinstance.ProcessInstanceCommandProcessor
- processInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- processInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- processInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- processInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- processInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- processInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- processInstanceKey() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- processInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- processInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- processInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- processInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- processInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- processInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- processInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- processInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- processInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- processInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- processInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- processInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- processInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- processInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- processInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- processInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- processInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- processInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- processInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- processInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- processInstanceKeyEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- processInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- processInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- processInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- processInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- processInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- processInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- processInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- processInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- processInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- processInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- processInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- processInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- processInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- processInstanceKeyEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- processInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- processInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- processInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- processInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- processInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- processInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- processInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- processInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- processInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- processInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- processInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- processInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- processInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- processInstanceKeyId() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- processInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- processInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- processInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- processInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- processInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- processInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- processInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- processInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- processInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- processInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- processInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- processInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- processInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- processInstanceKeyMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- processInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- processInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- processInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- processInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- processInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- processInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- processInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- processInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- processInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- processInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- processInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- processInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- processInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- processInstanceKeyMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- processInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- processInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- processInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- processInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- processInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- processInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- processInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- processInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- processInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- processInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- processInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- processInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- processInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- processInstanceKeyMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- processInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- processInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- processInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- processInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- processInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- processInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- processInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- processInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- processInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- processInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- processInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- processInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- processInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- processInstanceKeyNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- processInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- processInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- processInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- processInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- processInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- processInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- processInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- processInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- processInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- processInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- processInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- processInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- processInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- processInstanceKeySinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- ProcessInstanceLifecycle - Class in io.camunda.zeebe.engine.processing.bpmn
- ProcessInstanceStateTransitionGuard - Class in io.camunda.zeebe.engine.processing.bpmn
-
Checks the preconditions of a state transition command.
- ProcessInstanceStateTransitionGuard(BpmnStateBehavior) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.ProcessInstanceStateTransitionGuard
- ProcessMessageSubscription - Class in io.camunda.zeebe.engine.state.message
- ProcessMessageSubscription() - Constructor for class io.camunda.zeebe.engine.state.message.ProcessMessageSubscription
- ProcessMessageSubscriptionCorrelatedApplier - Class in io.camunda.zeebe.engine.state.appliers
- ProcessMessageSubscriptionCorrelatedApplier(MutableProcessMessageSubscriptionState) - Constructor for class io.camunda.zeebe.engine.state.appliers.ProcessMessageSubscriptionCorrelatedApplier
- ProcessMessageSubscriptionCorrelateProcessor - Class in io.camunda.zeebe.engine.processing.message
- ProcessMessageSubscriptionCorrelateProcessor(ProcessMessageSubscriptionState, SubscriptionCommandSender, MutableZeebeState, EventTriggerBehavior, Writers) - Constructor for class io.camunda.zeebe.engine.processing.message.ProcessMessageSubscriptionCorrelateProcessor
- ProcessMessageSubscriptionCreatedApplier - Class in io.camunda.zeebe.engine.state.appliers
- ProcessMessageSubscriptionCreatedApplier(MutableProcessMessageSubscriptionState) - Constructor for class io.camunda.zeebe.engine.state.appliers.ProcessMessageSubscriptionCreatedApplier
- ProcessMessageSubscriptionCreateProcessor - Class in io.camunda.zeebe.engine.processing.message
- ProcessMessageSubscriptionCreateProcessor(ProcessMessageSubscriptionState, Writers) - Constructor for class io.camunda.zeebe.engine.processing.message.ProcessMessageSubscriptionCreateProcessor
- ProcessMessageSubscriptionCreatingApplier - Class in io.camunda.zeebe.engine.state.appliers
- ProcessMessageSubscriptionCreatingApplier(MutableProcessMessageSubscriptionState) - Constructor for class io.camunda.zeebe.engine.state.appliers.ProcessMessageSubscriptionCreatingApplier
- ProcessMessageSubscriptionDeletedApplier - Class in io.camunda.zeebe.engine.state.appliers
- ProcessMessageSubscriptionDeletedApplier(MutableProcessMessageSubscriptionState) - Constructor for class io.camunda.zeebe.engine.state.appliers.ProcessMessageSubscriptionDeletedApplier
- ProcessMessageSubscriptionDeleteProcessor - Class in io.camunda.zeebe.engine.processing.message
- ProcessMessageSubscriptionDeleteProcessor(ProcessMessageSubscriptionState, Writers) - Constructor for class io.camunda.zeebe.engine.processing.message.ProcessMessageSubscriptionDeleteProcessor
- ProcessMessageSubscriptionSentTimeMigration - Class in io.camunda.zeebe.engine.state.migration
-
Migrates pending process message subscriptions by adding them to
PendingProcessMessageSubscriptionState
and removing them fromZbColumnFamilies.PROCESS_SUBSCRIPTION_BY_SENT_TIME
. - ProcessMessageSubscriptionSentTimeMigration() - Constructor for class io.camunda.zeebe.engine.state.migration.ProcessMessageSubscriptionSentTimeMigration
- ProcessMessageSubscriptionState - Interface in io.camunda.zeebe.engine.state.immutable
- ProcessMessageSubscriptionState.ProcessMessageSubscriptionVisitor - Interface in io.camunda.zeebe.engine.state.immutable
- processorMode(StreamProcessorMode) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- processors(KeyGenerator, Writers) - Static method in class io.camunda.zeebe.engine.processing.streamprocessor.TypedRecordProcessors
- ProcessProcessor - Class in io.camunda.zeebe.engine.processing.bpmn.container
- ProcessProcessor(BpmnBehaviors) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.container.ProcessProcessor
- processRecord(long, TypedRecord<DeploymentDistributionRecord>, TypedResponseWriter, TypedStreamWriter, Consumer<SideEffectProducer>) - Method in class io.camunda.zeebe.engine.processing.deployment.distribute.CompleteDeploymentDistributionProcessor
- processRecord(long, TypedRecord<DeploymentRecord>, TypedResponseWriter, TypedStreamWriter, Consumer<SideEffectProducer>) - Method in class io.camunda.zeebe.engine.processing.deployment.distribute.DeploymentDistributeProcessor
- processRecord(long, TypedRecord<T>, TypedResponseWriter, TypedStreamWriter, Consumer<SideEffectProducer>) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.TypedRecordProcessor
- processRecord(TypedRecord<DeploymentRecord>, TypedResponseWriter, TypedStreamWriter, Consumer<SideEffectProducer>) - Method in class io.camunda.zeebe.engine.processing.deployment.DeploymentCreateProcessor
- processRecord(TypedRecord<IncidentRecord>, TypedResponseWriter, TypedStreamWriter, Consumer<SideEffectProducer>) - Method in class io.camunda.zeebe.engine.processing.incident.ResolveIncidentProcessor
- processRecord(TypedRecord<JobBatchRecord>, TypedResponseWriter, TypedStreamWriter) - Method in class io.camunda.zeebe.engine.processing.job.JobBatchActivateProcessor
- processRecord(TypedRecord<MessageRecord>, TypedResponseWriter, TypedStreamWriter) - Method in class io.camunda.zeebe.engine.processing.message.MessageExpireProcessor
- processRecord(TypedRecord<MessageRecord>, TypedResponseWriter, TypedStreamWriter, Consumer<SideEffectProducer>) - Method in class io.camunda.zeebe.engine.processing.message.MessagePublishProcessor
- processRecord(TypedRecord<MessageSubscriptionRecord>, TypedResponseWriter, TypedStreamWriter, Consumer<SideEffectProducer>) - Method in class io.camunda.zeebe.engine.processing.message.MessageSubscriptionCorrelateProcessor
- processRecord(TypedRecord<MessageSubscriptionRecord>, TypedResponseWriter, TypedStreamWriter, Consumer<SideEffectProducer>) - Method in class io.camunda.zeebe.engine.processing.message.MessageSubscriptionCreateProcessor
- processRecord(TypedRecord<MessageSubscriptionRecord>, TypedResponseWriter, TypedStreamWriter, Consumer<SideEffectProducer>) - Method in class io.camunda.zeebe.engine.processing.message.MessageSubscriptionDeleteProcessor
- processRecord(TypedRecord<MessageSubscriptionRecord>, TypedResponseWriter, TypedStreamWriter, Consumer<SideEffectProducer>) - Method in class io.camunda.zeebe.engine.processing.message.MessageSubscriptionRejectProcessor
- processRecord(TypedRecord<ProcessMessageSubscriptionRecord>, TypedResponseWriter, TypedStreamWriter) - Method in class io.camunda.zeebe.engine.processing.message.ProcessMessageSubscriptionCreateProcessor
- processRecord(TypedRecord<ProcessMessageSubscriptionRecord>, TypedResponseWriter, TypedStreamWriter) - Method in class io.camunda.zeebe.engine.processing.message.ProcessMessageSubscriptionDeleteProcessor
- processRecord(TypedRecord<ProcessMessageSubscriptionRecord>, TypedResponseWriter, TypedStreamWriter, Consumer<SideEffectProducer>) - Method in class io.camunda.zeebe.engine.processing.message.ProcessMessageSubscriptionCorrelateProcessor
- processRecord(TypedRecord<ProcessInstanceRecord>, TypedResponseWriter, TypedStreamWriter) - Method in class io.camunda.zeebe.engine.processing.processinstance.ProcessInstanceCommandProcessor
- processRecord(TypedRecord<ProcessInstanceRecord>, TypedResponseWriter, TypedStreamWriter, Consumer<SideEffectProducer>) - Method in class io.camunda.zeebe.engine.processing.bpmn.BpmnStreamProcessor
- processRecord(TypedRecord<TimerRecord>, TypedResponseWriter, TypedStreamWriter) - Method in class io.camunda.zeebe.engine.processing.timer.CancelTimerProcessor
- processRecord(TypedRecord<TimerRecord>, TypedResponseWriter, TypedStreamWriter, Consumer<SideEffectProducer>) - Method in class io.camunda.zeebe.engine.processing.timer.TriggerTimerProcessor
- processRecord(TypedRecord<VariableDocumentRecord>, TypedResponseWriter, TypedStreamWriter) - Method in class io.camunda.zeebe.engine.processing.variable.UpdateVariableDocumentProcessor
- processRecord(TypedRecord<T>, TypedResponseWriter, TypedStreamWriter) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.TypedRecordProcessor
- processRecord(TypedRecord<T>, TypedResponseWriter, TypedStreamWriter, Consumer<SideEffectProducer>) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.CommandProcessorImpl
- processRecord(TypedRecord<T>, TypedResponseWriter, TypedStreamWriter, Consumer<SideEffectProducer>) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.TypedRecordProcessor
- processResultSenderBehavior() - Method in interface io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBehaviors
- processResultSenderBehavior() - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBehaviorsImpl
- ProcessState - Interface in io.camunda.zeebe.engine.state.immutable
- ProcessTransformer - Class in io.camunda.zeebe.engine.processing.deployment.model.transformer
- ProcessTransformer() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.transformer.ProcessTransformer
- propagateVariable(BpmnElementContext, DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateBehavior
- pushDeploymentToPartition(long, int, DirectBuffer) - Method in interface io.camunda.zeebe.engine.processing.deployment.distribute.DeploymentDistributor
- put(long, MessageRecord) - Method in class io.camunda.zeebe.engine.state.message.DbMessageState
- put(long, MessageRecord) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableMessageState
- put(long, MessageStartEventSubscriptionRecord) - Method in class io.camunda.zeebe.engine.state.message.DbMessageStartEventSubscriptionState
- put(long, MessageStartEventSubscriptionRecord) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableMessageStartEventSubscriptionState
- put(long, MessageSubscriptionRecord) - Method in class io.camunda.zeebe.engine.state.message.DbMessageSubscriptionState
- put(long, MessageSubscriptionRecord) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableMessageSubscriptionState
- put(long, ProcessMessageSubscriptionRecord) - Method in class io.camunda.zeebe.engine.state.message.DbProcessMessageSubscriptionState
- put(long, ProcessMessageSubscriptionRecord) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableProcessMessageSubscriptionState
- put(TimerInstance) - Method in class io.camunda.zeebe.engine.state.instance.DbTimerInstanceState
- put(TimerInstance) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableTimerInstanceState
- put(RecordType, ValueType, int, TypedRecordProcessor) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.RecordProcessorMap
- putActiveProcessInstance(DirectBuffer, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.message.DbMessageState
- putActiveProcessInstance(DirectBuffer, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableMessageState
- putBpmnProcessId(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- putBpmnProcessId(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- putBpmnProcessId(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- putBpmnProcessId(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- putBpmnProcessId(DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- putBpmnProcessId(DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- putBpmnProcessId(DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- putBpmnProcessId(DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- putCorrelationKey(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- putCorrelationKey(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- putCorrelationKey(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- putCorrelationKey(DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- putCorrelationKey(DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- putCorrelationKey(DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- putDeployment(DeploymentRecord) - Method in class io.camunda.zeebe.engine.state.deployment.DbProcessState
- putDeployment(DeploymentRecord) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableProcessState
- putLatestVersionDigest(DirectBuffer, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.deployment.DbProcessState
- putLatestVersionDigest(DirectBuffer, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableProcessState
- putMessageCorrelation(long, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.message.DbMessageState
- putMessageCorrelation(long, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableMessageState
- putMessageName(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- putMessageName(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- putMessageName(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- putMessageName(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- putMessageName(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- putMessageName(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- putMessageName(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- putMessageName(DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- putMessageName(DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- putMessageName(DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- putMessageName(DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- putMessageName(DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- putMessageName(DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- putMessageName(DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- putProcess(long, ProcessRecord) - Method in class io.camunda.zeebe.engine.state.deployment.DbProcessState
- putProcess(long, ProcessRecord) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableProcessState
- putProcessInstanceCorrelationKey(long, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.message.DbMessageState
- putProcessInstanceCorrelationKey(long, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableMessageState
- putVariables(byte[], int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- putVariables(DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
Q
- QueryService - Interface in io.camunda.zeebe.engine.state
-
Deprecated, for removal: This API element is subject to removal in a future version.
- QueryService.ClosedServiceException - Exception in io.camunda.zeebe.engine.state
-
Deprecated.
R
- ReadonlyProcessingContext - Interface in io.camunda.zeebe.engine.processing.streamprocessor
- readRecordValue(LoggedEvent, ValueType) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.RecordValues
- ReceiveTaskProcessor - Class in io.camunda.zeebe.engine.processing.bpmn.task
- ReceiveTaskProcessor(BpmnBehaviors) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.task.ReceiveTaskProcessor
- ReceiveTaskTransformer - Class in io.camunda.zeebe.engine.processing.deployment.model.transformer
- ReceiveTaskTransformer() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.transformer.ReceiveTaskTransformer
- recordProcessorMap(RecordProcessorMap) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- RecordProcessorMap - Class in io.camunda.zeebe.engine.processing.streamprocessor
- RecordProcessorMap() - Constructor for class io.camunda.zeebe.engine.processing.streamprocessor.RecordProcessorMap
- RecordProtocolVersionFilter - Class in io.camunda.zeebe.engine.processing.streamprocessor
- RecordProtocolVersionFilter() - Constructor for class io.camunda.zeebe.engine.processing.streamprocessor.RecordProtocolVersionFilter
- recordsWritten(long) - Method in class io.camunda.zeebe.engine.metrics.StreamProcessorMetrics
-
We write various type of records.
- recordType(RecordType) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.writers.CommandResponseWriter
- RecordValues - Class in io.camunda.zeebe.engine.processing.streamprocessor
- RecordValues() - Constructor for class io.camunda.zeebe.engine.processing.streamprocessor.RecordValues
- recurAfterBackoff(long, JobRecord) - Method in class io.camunda.zeebe.engine.state.instance.DbJobState
- recurAfterBackoff(long, JobRecord) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableJobState
- registerHandler(ModelElementTransformer<?>) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformation.TransformationVisitor
- reject(RejectionType, String) - Method in class io.camunda.zeebe.engine.processing.processinstance.ProcessInstanceCommandContext
- reject(RejectionType, String) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.CommandProcessor.CommandControl
- reject(RejectionType, String) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.CommandProcessorImpl
- rejectCorrelateMessageSubscription(long, DirectBuffer, long, DirectBuffer, DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.message.command.SubscriptionCommandSender
- RejectCorrelateMessageSubscriptionCommand - Class in io.camunda.zeebe.engine.processing.message.command
- RejectCorrelateMessageSubscriptionCommand() - Constructor for class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionCommand
- RejectCorrelateMessageSubscriptionDecoder - Class in io.camunda.zeebe.engine.processing.message.command
- RejectCorrelateMessageSubscriptionDecoder() - Constructor for class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- RejectCorrelateMessageSubscriptionEncoder - Class in io.camunda.zeebe.engine.processing.message.command
- RejectCorrelateMessageSubscriptionEncoder() - Constructor for class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- rejection() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.Writers
- rejectionReason(DirectBuffer) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.writers.CommandResponseWriter
- rejectionType(RejectionType) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.writers.CommandResponseWriter
- remove(long) - Method in class io.camunda.zeebe.engine.state.message.DbMessageState
- remove(long) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableMessageState
- remove(long, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.message.DbMessageStartEventSubscriptionState
- remove(long, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.message.DbMessageSubscriptionState
- remove(long, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.message.DbProcessMessageSubscriptionState
- remove(long, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableMessageStartEventSubscriptionState
- remove(long, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableMessageSubscriptionState
- remove(long, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableProcessMessageSubscriptionState
- remove(TimerInstance) - Method in class io.camunda.zeebe.engine.state.instance.DbTimerInstanceState
- remove(TimerInstance) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableTimerInstanceState
- remove(MessageSubscription) - Method in class io.camunda.zeebe.engine.state.message.DbMessageSubscriptionState
- remove(MessageSubscription) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableMessageSubscriptionState
- remove(TransientSubscriptionCommandState.CommandEntry) - Method in class io.camunda.zeebe.engine.state.message.TransientSubscriptionCommandState
- removeActiveProcessInstance(DirectBuffer, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.message.DbMessageState
- removeActiveProcessInstance(DirectBuffer, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableMessageState
- removeAllVariables(long) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableVariableState
- removeAllVariables(long) - Method in class io.camunda.zeebe.engine.state.variable.DbVariableState
- removeDeploymentRecord(long) - Method in class io.camunda.zeebe.engine.state.deployment.DbDeploymentState
- removeDeploymentRecord(long) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableDeploymentState
- removeFailureListener(FailureListener) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- removeInstance(long) - Method in class io.camunda.zeebe.engine.state.instance.DbElementInstanceState
- removeInstance(long) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableElementInstanceState
- removeMessageCorrelation(long, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.message.DbMessageState
- removeMessageCorrelation(long, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableMessageState
- removeMessageLock(ProcessInstanceRecord) - Method in class io.camunda.zeebe.engine.state.appliers.BufferedStartMessageEventStateApplier
-
If a process instance is created by a message then it creates a lock for the instance to avoid that another instance can be created for the same message name and correlation key.
- removePendingDeploymentDistribution(long, int) - Method in class io.camunda.zeebe.engine.state.deployment.DbDeploymentState
- removePendingDeploymentDistribution(long, int) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableDeploymentState
- removeProcessInstanceCorrelationKey(long) - Method in class io.camunda.zeebe.engine.state.message.DbMessageState
- removeProcessInstanceCorrelationKey(long) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableMessageState
- removeScope(long) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableVariableState
- removeScope(long) - Method in class io.camunda.zeebe.engine.state.variable.DbVariableState
- REPLAY - Enum constant in enum io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor.Phase
- REPLAY - Enum constant in enum io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorMode
-
When in REPLAY mode, all events are replayed and commands are never processed.
- ReplayMetrics - Class in io.camunda.zeebe.engine.metrics
- ReplayMetrics(int) - Constructor for class io.camunda.zeebe.engine.metrics.ReplayMetrics
- ReplayStateMachine - Class in io.camunda.zeebe.engine.processing.streamprocessor
-
Represents the state machine to replay events and rebuild the state.
- ReplayStateMachine(ProcessingContext, BooleanSupplier) - Constructor for class io.camunda.zeebe.engine.processing.streamprocessor.ReplayStateMachine
- ReprocessingRecord - Class in io.camunda.zeebe.engine.processing.streamprocessor.writers
- reset() - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.TypedStreamWriterProxy
- reset() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionCommand
- reset() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionCommand
- reset() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionCommand
- reset() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionCommand
- reset() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionCommand
- reset() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionCommand
- reset() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionCommand
- reset() - Method in class io.camunda.zeebe.engine.processing.message.Subscriptions.Subscription
- reset() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.NoopResponseWriter
- reset() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.NoopTypedStreamWriter
- reset() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedCommandWriter
- reset() - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedResponseWriter
- reset() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedResponseWriterImpl
- reset() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedStreamWriterImpl
- resetActiveSequenceFlows() - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- resolve(long, JobRecord) - Method in class io.camunda.zeebe.engine.state.instance.DbJobState
- resolve(long, JobRecord) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableJobState
- ResolveIncidentProcessor - Class in io.camunda.zeebe.engine.processing.incident
- ResolveIncidentProcessor(ZeebeState, TypedRecordProcessor<ProcessInstanceRecord>, Writers, KeyGenerator) - Constructor for class io.camunda.zeebe.engine.processing.incident.ResolveIncidentProcessor
- resolveIncidents(BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnIncidentBehavior
- resolveJobIncident(long) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnIncidentBehavior
- response() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.Writers
-
Note:
flush()
must not be called on the response writer object. - resumeProcessing() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- run() - Method in class io.camunda.zeebe.engine.processing.message.MessageTimeToLiveChecker
- run() - Method in class io.camunda.zeebe.engine.processing.message.PendingMessageSubscriptionChecker
- runMigration(MutableZeebeState) - Method in class io.camunda.zeebe.engine.state.migration.MessageSubscriptionSentTimeMigration
- runMigration(MutableZeebeState) - Method in interface io.camunda.zeebe.engine.state.migration.MigrationTask
-
Implementations of this method perform the actual migration
- runMigration(MutableZeebeState) - Method in class io.camunda.zeebe.engine.state.migration.ProcessMessageSubscriptionSentTimeMigration
- runMigration(MutableZeebeState) - Method in class io.camunda.zeebe.engine.state.migration.TemporaryVariableMigration
- runMigrations() - Method in interface io.camunda.zeebe.engine.state.migration.DbMigrator
- runMigrations() - Method in class io.camunda.zeebe.engine.state.migration.DbMigratorImpl
S
- satisfiesIfStatic(Predicate<Expression>, String) - Method in class io.camunda.zeebe.engine.processing.deployment.model.validation.ZeebeExpressionValidator.ExpressionVerification
- SBE_UNKNOWN - Enum constant in enum io.camunda.zeebe.engine.processing.message.command.BooleanType
-
To be used to represent an unknown value from a later version.
- sbeBlockLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- sbeBlockLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- sbeBlockLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- sbeBlockLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- sbeBlockLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- sbeBlockLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- sbeBlockLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- sbeBlockLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- sbeBlockLength() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- sbeBlockLength() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- sbeBlockLength() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- sbeBlockLength() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- sbeBlockLength() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- sbeBlockLength() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- sbeDecodedLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- sbeDecodedLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- sbeDecodedLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- sbeDecodedLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- sbeDecodedLength() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- sbeDecodedLength() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- sbeDecodedLength() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- sbeRewind() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- sbeRewind() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- sbeRewind() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- sbeRewind() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- sbeRewind() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- sbeRewind() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- sbeRewind() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- sbeSchemaId() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- sbeSchemaId() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- sbeSchemaId() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- sbeSchemaId() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- sbeSchemaId() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- sbeSchemaId() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- sbeSchemaId() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- sbeSchemaId() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- sbeSchemaId() - Method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- sbeSchemaId() - Method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- sbeSchemaId() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- sbeSchemaId() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- sbeSchemaId() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- sbeSchemaId() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- sbeSchemaId() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- sbeSchemaId() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- sbeSchemaId() - Method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- sbeSchemaId() - Method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingEncoder
- sbeSchemaVersion() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- sbeSchemaVersion() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- sbeSchemaVersion() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- sbeSchemaVersion() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- sbeSchemaVersion() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- sbeSchemaVersion() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- sbeSchemaVersion() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- sbeSchemaVersion() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- sbeSchemaVersion() - Method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- sbeSchemaVersion() - Method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- sbeSchemaVersion() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- sbeSchemaVersion() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- sbeSchemaVersion() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- sbeSchemaVersion() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- sbeSchemaVersion() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- sbeSchemaVersion() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- sbeSchemaVersion() - Method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- sbeSchemaVersion() - Method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingEncoder
- sbeSemanticType() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- sbeSemanticType() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- sbeSemanticType() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- sbeSemanticType() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- sbeSemanticType() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- sbeSemanticType() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- sbeSemanticType() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- sbeSemanticType() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- sbeSemanticType() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- sbeSemanticType() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- sbeSemanticType() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- sbeSemanticType() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- sbeSemanticType() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- sbeSemanticType() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- sbeSkip() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- sbeSkip() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- sbeSkip() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- sbeSkip() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- sbeSkip() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- sbeSkip() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- sbeSkip() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- sbeTemplateId() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- sbeTemplateId() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- sbeTemplateId() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- sbeTemplateId() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- sbeTemplateId() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- sbeTemplateId() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- sbeTemplateId() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- sbeTemplateId() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- sbeTemplateId() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- sbeTemplateId() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- sbeTemplateId() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- sbeTemplateId() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- sbeTemplateId() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- sbeTemplateId() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- schedule(long) - Method in class io.camunda.zeebe.engine.processing.scheduled.DueDateChecker
- scheduleBackOff(long) - Method in class io.camunda.zeebe.engine.processing.job.JobBackoffChecker
- scheduleTimer(long) - Method in class io.camunda.zeebe.engine.processing.timer.DueDateTimerChecker
- SCHEMA_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- SCHEMA_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- SCHEMA_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- SCHEMA_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- SCHEMA_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- SCHEMA_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- SCHEMA_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- SCHEMA_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- SCHEMA_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- SCHEMA_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- SCHEMA_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- SCHEMA_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- SCHEMA_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- SCHEMA_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- SCHEMA_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- SCHEMA_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- SCHEMA_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- SCHEMA_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingEncoder
- SCHEMA_VERSION - Static variable in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- SCHEMA_VERSION - Static variable in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- SCHEMA_VERSION - Static variable in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- SCHEMA_VERSION - Static variable in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- SCHEMA_VERSION - Static variable in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- SCHEMA_VERSION - Static variable in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- SCHEMA_VERSION - Static variable in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- SCHEMA_VERSION - Static variable in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- SCHEMA_VERSION - Static variable in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- SCHEMA_VERSION - Static variable in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- SCHEMA_VERSION - Static variable in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- SCHEMA_VERSION - Static variable in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- SCHEMA_VERSION - Static variable in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- SCHEMA_VERSION - Static variable in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- SCHEMA_VERSION - Static variable in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- SCHEMA_VERSION - Static variable in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- SCHEMA_VERSION - Static variable in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- SCHEMA_VERSION - Static variable in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingEncoder
- schemaId() - Method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- schemaId(int) - Method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- schemaIdEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- schemaIdEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- schemaIdEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- schemaIdEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- schemaIdMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- schemaIdMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- schemaIdMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- schemaIdMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- schemaIdNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- schemaIdNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- schemaIdSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- SEMANTIC_TYPE - Enum constant in enum io.camunda.zeebe.engine.processing.message.command.MetaAttribute
-
The type relationship to a FIX tag value encoded type.
- sendCommand(int, BufferWriter) - Method in interface io.camunda.zeebe.engine.processing.message.command.PartitionCommandSender
- sendDeploymentResponse(long, int) - Method in interface io.camunda.zeebe.engine.processing.deployment.DeploymentResponder
- sendResult(BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnProcessResultSenderBehavior
- SequenceFlowTransformer - Class in io.camunda.zeebe.engine.processing.deployment.model.transformer
- SequenceFlowTransformer() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.transformer.SequenceFlowTransformer
- set(long) - Method in class io.camunda.zeebe.engine.state.deployment.LatestProcessVersion
- set(long) - Method in class io.camunda.zeebe.engine.state.instance.IncidentKey
- set(long) - Method in class io.camunda.zeebe.engine.state.instance.ParentScopeKey
- set(long) - Method in class io.camunda.zeebe.engine.state.NextValue
- set(long) - Method in class io.camunda.zeebe.engine.state.processing.LastProcessedPosition
- set(DirectBuffer) - Method in class io.camunda.zeebe.engine.state.deployment.Digest
- set(DirectBuffer) - Method in class io.camunda.zeebe.engine.state.migration.TemporaryVariables
- setAccepting(boolean) - Method in class io.camunda.zeebe.engine.state.instance.EventScopeInstance
- setAssignee(Expression) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.JobWorkerProperties
- setAwaitResultRequestMetadata(long, AwaitProcessInstanceResultMetadata) - Method in class io.camunda.zeebe.engine.state.instance.DbElementInstanceState
- setAwaitResultRequestMetadata(long, AwaitProcessInstanceResultMetadata) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableElementInstanceState
- setCalledChildInstanceKey(long) - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- setCalledElementProcessId(Expression) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCallActivity
- setCandidateGroups(Expression) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.JobWorkerProperties
- setCloseOnCorrelate(boolean) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionCommand
- setCloseOnCorrelate(boolean) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionCommand
- setClosing() - Method in class io.camunda.zeebe.engine.state.message.ProcessMessageSubscription
- setCondition(Expression) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableSequenceFlow
- setConnectedToEventBasedGateway(boolean) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEventElement
- setContext(TransformContext) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformation.TransformationVisitor
- setCorrelating(boolean) - Method in class io.camunda.zeebe.engine.state.message.MessageSubscription
- setCorrelationKeyExpression(Expression) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableMessage
- setCurrentProcess(ExecutableProcess) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformation.TransformContext
- setDefaultFlow(ExecutableSequenceFlow) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableExclusiveGateway
- setDeploymentRecord(DeploymentRecord) - Method in class io.camunda.zeebe.engine.state.deployment.DeploymentRaw
- setDueDate(long) - Method in class io.camunda.zeebe.engine.state.instance.TimerInstance
- setElementId(DirectBuffer) - Method in class io.camunda.zeebe.engine.state.instance.EventTrigger
- setElementInstance(ElementInstance) - Method in class io.camunda.zeebe.engine.processing.processinstance.ProcessInstanceCommandContext
- setElementInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionCommand
- setElementInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionCommand
- setElementInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionCommand
- setElementInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionCommand
- setElementInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionCommand
- setElementInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionCommand
- setElementInstanceKey(long) - Method in class io.camunda.zeebe.engine.state.instance.TimerInstance
- setElementType(BpmnElementType) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.AbstractFlowElement
- setError(ExecutableError) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEventElement
- setError(ExecutableError) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableEndEvent
- setErrorCode(DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableError
- setEventKey(long) - Method in class io.camunda.zeebe.engine.state.instance.EventTrigger
- setEvents(List<ExecutableCatchEvent>) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableEventBasedGateway
- setEventSubProcess(DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableStartEvent
- setExpressionLanguage(ExpressionLanguage) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformation.TransformContext
- setFetchVariables(ArrayProperty<StringValue>) - Method in class io.camunda.zeebe.engine.state.instance.AwaitProcessInstanceResultMetadata
- setFlowScope(ExecutableFlowElement) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.AbstractFlowElement
- setHandlerNodeId(DirectBuffer) - Method in class io.camunda.zeebe.engine.state.instance.TimerInstance
- setInputMappings(Expression) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableFlowNode
- setInterrupting(boolean) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEventElement
- setInterruptingElementId(DirectBuffer) - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- setJobKey(long) - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- setJobsAvailableCallback(Consumer<String>) - Method in interface io.camunda.zeebe.engine.state.immutable.JobState
- setJobsAvailableCallback(Consumer<String>) - Method in class io.camunda.zeebe.engine.state.instance.DbJobState
- setJobWorkerProperties(JobWorkerProperties) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableEndEvent
- setJobWorkerProperties(JobWorkerProperties) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableIntermediateThrowEvent
- setJobWorkerProperties(JobWorkerProperties) - Method in interface io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableJobWorkerElement
- setJobWorkerProperties(JobWorkerProperties) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableJobWorkerTask
- setKey(long) - Method in class io.camunda.zeebe.engine.state.instance.IndexedRecord
- setKey(long) - Method in class io.camunda.zeebe.engine.state.instance.TimerInstance
- setKey(long) - Method in class io.camunda.zeebe.engine.state.message.MessageStartEventSubscription
- setKey(long) - Method in class io.camunda.zeebe.engine.state.message.MessageSubscription
- setKey(long) - Method in class io.camunda.zeebe.engine.state.message.ProcessMessageSubscription
- setKey(long) - Method in class io.camunda.zeebe.engine.state.variable.VariableInstance
- setKeyIfHigher(long) - Method in interface io.camunda.zeebe.engine.state.KeyGeneratorControls
-
Set the given value as the new key if it is higher than the current key.
- setKeyIfHigher(long) - Method in class io.camunda.zeebe.engine.state.processing.DbKeyGenerator
- setLastProcessedPosition(long) - Method in class io.camunda.zeebe.engine.metrics.StreamProcessorMetrics
- setLastSourcePosition(long) - Method in class io.camunda.zeebe.engine.metrics.ReplayMetrics
- setLocalVariable(long, long, long, DirectBuffer, DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.variable.VariableBehavior
-
Publishes a follow up event to create or update the variable with name
name
on the given scope with keyscopeKey
, with additionalprocessDefinitionKey
andprocessInstanceKey
context. - setLocalVariable(BpmnElementContext, DirectBuffer, DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateBehavior
- setLocalVariable(BpmnElementContext, DirectBuffer, DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateBehavior
- setMessage(ExecutableMessage) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEventElement
- setMessage(ExecutableMessage) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableReceiveTask
- setMessage(MessageRecord) - Method in class io.camunda.zeebe.engine.state.message.StoredMessage
- setMessageKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionCommand
- setMessageKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionCommand
- setMessageKey(long) - Method in class io.camunda.zeebe.engine.state.message.StoredMessage
- setMessageName(String) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableMessage
- setMessageName(DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionCommand
- setMessageName(DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionCommand
- setMessageNameExpression(Expression) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableMessage
- setMultiInstanceLoopCounter(int) - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- setOpened() - Method in class io.camunda.zeebe.engine.state.message.ProcessMessageSubscription
- setOutputMappings(Expression) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableFlowNode
- setProcessDefinitionKey(long) - Method in class io.camunda.zeebe.engine.state.instance.TimerInstance
- setProcessInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionCommand
- setProcessInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionCommand
- setProcessInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionCommand
- setProcessInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionCommand
- setProcessInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionCommand
- setProcessInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionCommand
- setProcessInstanceKey(long) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionCommand
- setProcessInstanceKey(long) - Method in class io.camunda.zeebe.engine.state.instance.TimerInstance
- setPropagateAllChildVariablesEnabled(boolean) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCallActivity
- setRecord(TypedRecord<ProcessInstanceRecord>) - Method in class io.camunda.zeebe.engine.processing.processinstance.ProcessInstanceCommandContext
- setRecord(IncidentRecord) - Method in class io.camunda.zeebe.engine.state.instance.Incident
- setRecord(MessageStartEventSubscriptionRecord) - Method in class io.camunda.zeebe.engine.state.message.MessageStartEventSubscription
- setRecord(MessageSubscriptionRecord) - Method in class io.camunda.zeebe.engine.state.message.MessageSubscription
- setRecord(ProcessMessageSubscriptionRecord) - Method in class io.camunda.zeebe.engine.state.message.ProcessMessageSubscription
- setRecordWithoutVariables(JobRecord) - Method in class io.camunda.zeebe.engine.state.instance.JobRecordValue
- setRepetitions(int) - Method in class io.camunda.zeebe.engine.state.instance.TimerInstance
- setRequestId(long) - Method in class io.camunda.zeebe.engine.state.instance.AwaitProcessInstanceResultMetadata
- setRequestStreamId(int) - Method in class io.camunda.zeebe.engine.state.instance.AwaitProcessInstanceResultMetadata
- setResponseWriter(TypedResponseWriter) - Method in class io.camunda.zeebe.engine.processing.processinstance.ProcessInstanceCommandContext
- setRetries(Expression) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.JobWorkerProperties
- setSideEffectProducer(SideEffectProducer) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingStateMachine
- setSource(ExecutableFlowNode) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableSequenceFlow
- setState(JobState.State) - Method in class io.camunda.zeebe.engine.state.instance.JobStateValue
- setState(ProcessInstanceIntent) - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- setState(ProcessInstanceIntent) - Method in class io.camunda.zeebe.engine.state.instance.IndexedRecord
- setStreamWriter(TypedStreamWriter) - Method in class io.camunda.zeebe.engine.processing.processinstance.ProcessInstanceCommandContext
- setSubscriptionPartitionId(int) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionCommand
- setSubscriptionPartitionId(int) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionCommand
- setSubscriptionPartitionId(int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionCommand
- setSubscriptionPartitionId(int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionCommand
- setSubscriptionPartitionId(int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionCommand
- setSubscriptionPartitionId(int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionCommand
- setSubscriptionPartitionId(int) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionCommand
- setTarget(ExecutableFlowNode) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableSequenceFlow
- setTaskHeaders(Map<String, String>) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.JobWorkerProperties
- setTimerFactory(BiFunction<ExpressionProcessor, Long, Either<Failure, Timer>>) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableCatchEventElement
- setType(Expression) - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.JobWorkerProperties
- setValue(ProcessInstanceRecord) - Method in class io.camunda.zeebe.engine.state.instance.ElementInstance
- setValue(ProcessInstanceRecord) - Method in class io.camunda.zeebe.engine.state.instance.IndexedRecord
- setValue(String, long) - Method in class io.camunda.zeebe.engine.state.NextValueManager
- setValue(DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.state.variable.VariableInstance
- setVariableLocal(long, long, long, DirectBuffer, int, int, DirectBuffer, int, int) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableVariableState
-
Creates or updates the variable with
name
within the given scope withscopeKey
, setting its value to the givenvalue
. - setVariableLocal(long, long, long, DirectBuffer, int, int, DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.state.variable.DbVariableState
- setVariableLocal(long, long, long, DirectBuffer, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableVariableState
-
Creates or updates the variable with
name
within the given scope withscopeKey
, setting its value to the givenvalue
. - setVariableLocal(long, long, long, DirectBuffer, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.variable.DbVariableState
- setVariables(DirectBuffer) - Method in class io.camunda.zeebe.engine.state.instance.EventTrigger
- shouldCloseOnCorrelate() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionCommand
- shouldCloseOnCorrelate() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionCommand
- shutdownInstance(long) - Method in class io.camunda.zeebe.engine.state.instance.DbEventScopeInstanceState
- shutdownInstance(long) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableEventScopeInstanceState
-
If the scope exists, sets its accepting property to false.
- SideEffectProducer - Interface in io.camunda.zeebe.engine.processing.streamprocessor.sideeffect
-
An action that is executed at the end of the processing.
- SideEffectQueue - Class in io.camunda.zeebe.engine.processing.streamprocessor.sideeffect
- SideEffectQueue() - Constructor for class io.camunda.zeebe.engine.processing.streamprocessor.sideeffect.SideEffectQueue
- SideEffects - Interface in io.camunda.zeebe.engine.processing.streamprocessor.sideeffect
-
A chain of side effects that are executed/flushed together at the end of the processing.
- skipBpmnProcessId() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- skipBpmnProcessId() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- skipBpmnProcessId() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- skipBpmnProcessId() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- skipCorrelationKey() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- skipCorrelationKey() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- skipCorrelationKey() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- skipMessageName() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- skipMessageName() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- skipMessageName() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- skipMessageName() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- skipMessageName() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- skipMessageName() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- skipMessageName() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- skipVariables() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- StartEventProcessor - Class in io.camunda.zeebe.engine.processing.bpmn.event
- StartEventProcessor(BpmnBehaviors) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.event.StartEventProcessor
- StartEventTransformer - Class in io.camunda.zeebe.engine.processing.deployment.model.transformer
- StartEventTransformer() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.transformer.StartEventTransformer
- startProcessing(LastProcessingPositions) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingStateMachine
- startProcessingDurationTimer(RecordType) - Method in class io.camunda.zeebe.engine.metrics.StreamProcessorMetrics
- startRecoveryTimer() - Method in class io.camunda.zeebe.engine.metrics.StreamProcessorMetrics
- startReplayDurationTimer() - Method in class io.camunda.zeebe.engine.metrics.ReplayMetrics
- state() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.Writers
- stateBehavior() - Method in interface io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBehaviors
- stateBehavior() - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBehaviorsImpl
- StateQueryService - Class in io.camunda.zeebe.engine.state.query
- StateQueryService(ZeebeDb<ZbColumnFamilies>) - Constructor for class io.camunda.zeebe.engine.state.query.StateQueryService
- stateTransitionBehavior() - Method in interface io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBehaviors
- stateTransitionBehavior() - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBehaviorsImpl
- stateTransitionGuard() - Method in interface io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBehaviors
- stateTransitionGuard() - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBehaviorsImpl
- StateWriter - Interface in io.camunda.zeebe.engine.processing.streamprocessor.writers
-
An event writer that alters the state for each events it writes.
- storeDeploymentRecord(long, DeploymentRecord) - Method in class io.camunda.zeebe.engine.state.deployment.DbDeploymentState
- storeDeploymentRecord(long, DeploymentRecord) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableDeploymentState
- StoredMessage - Class in io.camunda.zeebe.engine.state.message
- StoredMessage() - Constructor for class io.camunda.zeebe.engine.state.message.StoredMessage
- STREAM_PROCESSING - Static variable in class io.camunda.zeebe.engine.Loggers
- StreamProcessor - Class in io.camunda.zeebe.engine.processing.streamprocessor
- StreamProcessor(StreamProcessorBuilder) - Constructor for class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- StreamProcessor.Phase - Enum in io.camunda.zeebe.engine.processing.streamprocessor
- StreamProcessorBuilder - Class in io.camunda.zeebe.engine.processing.streamprocessor
- StreamProcessorBuilder() - Constructor for class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorBuilder
- streamProcessorFactory(TypedRecordProcessorFactory) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorBuilder
- StreamProcessorLifecycleAware - Interface in io.camunda.zeebe.engine.processing.streamprocessor
- StreamProcessorListener - Interface in io.camunda.zeebe.engine.processing.streamprocessor
-
A listener for the
StreamProcessor
. - StreamProcessorMetrics - Class in io.camunda.zeebe.engine.metrics
- StreamProcessorMetrics(int) - Constructor for class io.camunda.zeebe.engine.metrics.StreamProcessorMetrics
- streamProcessorMode(StreamProcessorMode) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorBuilder
- StreamProcessorMode - Enum in io.camunda.zeebe.engine.processing.streamprocessor
- SubProcessProcessor - Class in io.camunda.zeebe.engine.processing.bpmn.container
- SubProcessProcessor(BpmnBehaviors) - Constructor for class io.camunda.zeebe.engine.processing.bpmn.container.SubProcessProcessor
- SubProcessTransformer - Class in io.camunda.zeebe.engine.processing.deployment.model.transformer
- SubProcessTransformer() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.transformer.SubProcessTransformer
- subscribeToEvents(BpmnElementContext, ExecutableCatchEventSupplier, SideEffects, TypedCommandWriter) - Method in class io.camunda.zeebe.engine.processing.common.CatchEventBehavior
- subscribeToEvents(T, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnEventSubscriptionBehavior
- subscribeToTimerEvent(long, long, long, DirectBuffer, Timer, TypedCommandWriter, SideEffects) - Method in class io.camunda.zeebe.engine.processing.common.CatchEventBehavior
- Subscription() - Constructor for class io.camunda.zeebe.engine.processing.message.Subscriptions.Subscription
- SUBSCRIPTION_CHECK_INTERVAL - Static variable in class io.camunda.zeebe.engine.processing.message.MessageObserver
- SUBSCRIPTION_TIMEOUT - Static variable in class io.camunda.zeebe.engine.processing.message.MessageObserver
- SubscriptionCommandMessageHandler - Class in io.camunda.zeebe.engine.processing.message.command
- SubscriptionCommandMessageHandler(Consumer<Runnable>, IntFunction<LogStreamRecordWriter>) - Constructor for class io.camunda.zeebe.engine.processing.message.command.SubscriptionCommandMessageHandler
- SubscriptionCommandSender - Class in io.camunda.zeebe.engine.processing.message.command
-
Send commands via the subscription endpoint.
- SubscriptionCommandSender(int, PartitionCommandSender) - Constructor for class io.camunda.zeebe.engine.processing.message.command.SubscriptionCommandSender
- subscriptionPartitionId() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- subscriptionPartitionId() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- subscriptionPartitionId() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- subscriptionPartitionId() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- subscriptionPartitionId() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- subscriptionPartitionId() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- subscriptionPartitionId() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- subscriptionPartitionId(int) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- subscriptionPartitionId(int) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- subscriptionPartitionId(int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- subscriptionPartitionId(int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- subscriptionPartitionId(int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- subscriptionPartitionId(int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- subscriptionPartitionId(int) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- subscriptionPartitionIdEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- subscriptionPartitionIdEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- subscriptionPartitionIdEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- subscriptionPartitionIdEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- subscriptionPartitionIdEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- subscriptionPartitionIdEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- subscriptionPartitionIdEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- subscriptionPartitionIdEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- subscriptionPartitionIdEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- subscriptionPartitionIdEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- subscriptionPartitionIdEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- subscriptionPartitionIdEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- subscriptionPartitionIdEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- subscriptionPartitionIdEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- subscriptionPartitionIdEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- subscriptionPartitionIdEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- subscriptionPartitionIdEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- subscriptionPartitionIdEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- subscriptionPartitionIdEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- subscriptionPartitionIdEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- subscriptionPartitionIdEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- subscriptionPartitionIdEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- subscriptionPartitionIdEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- subscriptionPartitionIdEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- subscriptionPartitionIdEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- subscriptionPartitionIdEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- subscriptionPartitionIdEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- subscriptionPartitionIdEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- subscriptionPartitionIdId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- subscriptionPartitionIdId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- subscriptionPartitionIdId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- subscriptionPartitionIdId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- subscriptionPartitionIdId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- subscriptionPartitionIdId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- subscriptionPartitionIdId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- subscriptionPartitionIdId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- subscriptionPartitionIdId() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- subscriptionPartitionIdId() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- subscriptionPartitionIdId() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- subscriptionPartitionIdId() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- subscriptionPartitionIdId() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- subscriptionPartitionIdId() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- subscriptionPartitionIdMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- subscriptionPartitionIdMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- subscriptionPartitionIdMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- subscriptionPartitionIdMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- subscriptionPartitionIdMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- subscriptionPartitionIdMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- subscriptionPartitionIdMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- subscriptionPartitionIdMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- subscriptionPartitionIdMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- subscriptionPartitionIdMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- subscriptionPartitionIdMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- subscriptionPartitionIdMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- subscriptionPartitionIdMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- subscriptionPartitionIdMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- subscriptionPartitionIdMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- subscriptionPartitionIdMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- subscriptionPartitionIdMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- subscriptionPartitionIdMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- subscriptionPartitionIdMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- subscriptionPartitionIdMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- subscriptionPartitionIdMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- subscriptionPartitionIdMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- subscriptionPartitionIdMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- subscriptionPartitionIdMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- subscriptionPartitionIdMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- subscriptionPartitionIdMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- subscriptionPartitionIdMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- subscriptionPartitionIdMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- subscriptionPartitionIdMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- subscriptionPartitionIdMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- subscriptionPartitionIdMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- subscriptionPartitionIdMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- subscriptionPartitionIdMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- subscriptionPartitionIdMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- subscriptionPartitionIdMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- subscriptionPartitionIdMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- subscriptionPartitionIdMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- subscriptionPartitionIdMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- subscriptionPartitionIdMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- subscriptionPartitionIdMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- subscriptionPartitionIdMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- subscriptionPartitionIdMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- subscriptionPartitionIdNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- subscriptionPartitionIdNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- subscriptionPartitionIdNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- subscriptionPartitionIdNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- subscriptionPartitionIdNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- subscriptionPartitionIdNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- subscriptionPartitionIdNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- subscriptionPartitionIdNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- subscriptionPartitionIdNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- subscriptionPartitionIdNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- subscriptionPartitionIdNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- subscriptionPartitionIdNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- subscriptionPartitionIdNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- subscriptionPartitionIdNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- subscriptionPartitionIdSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- subscriptionPartitionIdSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- subscriptionPartitionIdSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- subscriptionPartitionIdSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- subscriptionPartitionIdSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- subscriptionPartitionIdSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- subscriptionPartitionIdSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- subscriptionPartitionIdSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- subscriptionPartitionIdSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- subscriptionPartitionIdSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- subscriptionPartitionIdSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- subscriptionPartitionIdSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- subscriptionPartitionIdSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- subscriptionPartitionIdSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- Subscriptions - Class in io.camunda.zeebe.engine.processing.message
- Subscriptions() - Constructor for class io.camunda.zeebe.engine.processing.message.Subscriptions
- Subscriptions.Subscription - Class in io.camunda.zeebe.engine.processing.message
- Subscriptions.SubscriptionVisitor - Interface in io.camunda.zeebe.engine.processing.message
T
- takeOutgoingSequenceFlows(T, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateTransitionBehavior
- takeSequenceFlow(BpmnElementContext, ExecutableSequenceFlow) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateTransitionBehavior
- TEMPLATE_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- TEMPLATE_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- TEMPLATE_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- TEMPLATE_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- TEMPLATE_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- TEMPLATE_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- TEMPLATE_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- TEMPLATE_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- TEMPLATE_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- TEMPLATE_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- TEMPLATE_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- TEMPLATE_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- TEMPLATE_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- TEMPLATE_ID - Static variable in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- templateId() - Method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- templateId(int) - Method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- templateIdEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- templateIdEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- templateIdEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- templateIdEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- templateIdMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- templateIdMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- templateIdMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- templateIdMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- templateIdNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- templateIdNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- templateIdSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- TEMPORARY_VARIABLE_STORE - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
-
Deprecated.
- TemporaryVariableMigration - Class in io.camunda.zeebe.engine.state.migration
-
Reads out the temporary variable column and creates an EventTrigger for reach of them.
- TemporaryVariableMigration() - Constructor for class io.camunda.zeebe.engine.state.migration.TemporaryVariableMigration
- TemporaryVariables - Class in io.camunda.zeebe.engine.state.migration
- TemporaryVariables() - Constructor for class io.camunda.zeebe.engine.state.migration.TemporaryVariables
- terminateChildInstances(BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateTransitionBehavior
-
Terminate all child instances of the given scope.
- terminateChildProcessInstance(BpmnElementContainerProcessor<T>, T, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateTransitionBehavior
- terminateElement(BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateTransitionBehavior
- throwError(long, JobRecord) - Method in class io.camunda.zeebe.engine.state.instance.DbJobState
- throwError(long, JobRecord) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableJobState
- throwErrorEvent(CatchEventAnalyzer.CatchEventTuple) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnEventPublicationBehavior
-
Throws an error event to the given element instance/catch event pair.
- TIME_OUT_POLLING_INTERVAL - Static variable in class io.camunda.zeebe.engine.processing.job.JobTimeoutTrigger
- TIME_UNIT - Enum constant in enum io.camunda.zeebe.engine.processing.message.command.MetaAttribute
-
Time unit applied to the epoch.
- timeout(long, JobRecord) - Method in class io.camunda.zeebe.engine.state.instance.DbJobState
- timeout(long, JobRecord) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableJobState
- TIMER_DUE_DATES - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- TimerCatchEventExpressionValidator - Class in io.camunda.zeebe.engine.processing.deployment.model.validation
- TimerCatchEventExpressionValidator(ExpressionLanguage, ExpressionProcessor) - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.validation.TimerCatchEventExpressionValidator
- TimerInstance - Class in io.camunda.zeebe.engine.state.instance
- TimerInstance() - Constructor for class io.camunda.zeebe.engine.state.instance.TimerInstance
- TimerInstanceState - Interface in io.camunda.zeebe.engine.state.immutable
- TimerInstanceState.TimerVisitor - Interface in io.camunda.zeebe.engine.state.immutable
- TIMERS - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- toJson() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.TypedEventImpl
- toString() - Method in class io.camunda.zeebe.engine.processing.bpmn.BpmnElementContextImpl
- toString() - Method in class io.camunda.zeebe.engine.processing.common.Failure
- toString() - Method in class io.camunda.zeebe.engine.processing.deployment.model.element.ExecutableLoopCharacteristics
- toString() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- toString() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- toString() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- toString() - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- toString() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- toString() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- toString() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- toString() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- toString() - Method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- toString() - Method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- toString() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- toString() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- toString() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- toString() - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- toString() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- toString() - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- toString() - Method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- toString() - Method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingEncoder
- toString() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.LastProcessingPositions
- toString() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.TypedEventImpl
- toString() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.ReprocessingRecord
- toString() - Method in class io.camunda.zeebe.engine.state.deployment.DeployedProcess
- toString() - Method in class io.camunda.zeebe.engine.state.message.TransientSubscriptionCommandState.CommandEntry
- toString() - Method in class io.camunda.zeebe.engine.state.variable.DocumentEntry
- transactionContext(TransactionContext) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- transform(Activity, TransformContext) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.MultiInstanceActivityTransformer
- transform(BoundaryEvent, TransformContext) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.BoundaryEventTransformer
- transform(CallActivity, TransformContext) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.CallActivityTransformer
- transform(CatchEvent, TransformContext) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.CatchEventTransformer
- transform(EndEvent, TransformContext) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.EndEventTransformer
- transform(Error, TransformContext) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.ErrorTransformer
- transform(EventBasedGateway, TransformContext) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.EventBasedGatewayTransformer
- transform(ExclusiveGateway, TransformContext) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.ExclusiveGatewayTransformer
- transform(FlowElement, TransformContext) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.FlowElementInstantiationTransformer
- transform(FlowNode, TransformContext) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.FlowNodeTransformer
- transform(IntermediateCatchEvent, TransformContext) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.IntermediateCatchEventTransformer
- transform(IntermediateThrowEvent, TransformContext) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.IntermediateThrowEventTransformer
- transform(Message, TransformContext) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.MessageTransformer
- transform(Process, TransformContext) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.ContextProcessTransformer
- transform(Process, TransformContext) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.ProcessTransformer
- transform(ReceiveTask, TransformContext) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.ReceiveTaskTransformer
- transform(SequenceFlow, TransformContext) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.SequenceFlowTransformer
- transform(StartEvent, TransformContext) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.StartEventTransformer
- transform(SubProcess, TransformContext) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.SubProcessTransformer
- transform(UserTask, TransformContext) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.UserTaskTransformer
- transform(DeploymentRecord) - Method in class io.camunda.zeebe.engine.processing.deployment.transform.DeploymentTransformer
- transform(T, TransformContext) - Method in interface io.camunda.zeebe.engine.processing.deployment.model.transformation.ModelElementTransformer
- transform(T, TransformContext) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.JobWorkerElementTransformer
- TransformationVisitor - Class in io.camunda.zeebe.engine.processing.deployment.model.transformation
- TransformationVisitor() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.transformation.TransformationVisitor
- TransformContext - Class in io.camunda.zeebe.engine.processing.deployment.model.transformation
- TransformContext() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.transformation.TransformContext
- transformDefinitions(BpmnModelInstance) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformation.BpmnTransformer
- transformInputMappings(Collection<? extends ZeebeMapping>, ExpressionLanguage) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.VariableMappingTransformer
- transformOutputMappings(Collection<? extends ZeebeMapping>, ExpressionLanguage) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformer.VariableMappingTransformer
- TransientSubscriptionCommandState - Class in io.camunda.zeebe.engine.state.message
-
This class keeps track of the last sent time of commands related to either message subscriptions or process message subscriptions.
- TransientSubscriptionCommandState() - Constructor for class io.camunda.zeebe.engine.state.message.TransientSubscriptionCommandState
- TransientSubscriptionCommandState.CommandEntry - Class in io.camunda.zeebe.engine.state.message
- transitionToActivated(BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateTransitionBehavior
- transitionToActivating(BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateTransitionBehavior
- transitionToCompleted(T, BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateTransitionBehavior
- transitionToCompleting(BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateTransitionBehavior
- transitionToTerminated(BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateTransitionBehavior
- transitionToTerminating(BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnStateTransitionBehavior
- triggerEvent(long, long, DirectBuffer, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.instance.DbEventScopeInstanceState
- triggerEvent(long, long, DirectBuffer, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableEventScopeInstanceState
-
Creates a new event trigger for the given event scope.
- triggerEventSubProcess(ExecutableStartEvent, long, ProcessInstanceRecord, DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.common.EventTriggerBehavior
- triggeringProcessEvent(long, long, long, DirectBuffer, DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.common.EventTriggerBehavior
-
Triggers a process by updating the state with a new
ProcessEventIntent.TRIGGERING
event. - triggeringProcessEvent(JobRecord) - Method in class io.camunda.zeebe.engine.processing.common.EventHandle
- triggerMessageStartEvent(long, MessageStartEventSubscriptionRecord, long, MessageRecord) - Method in class io.camunda.zeebe.engine.processing.common.EventHandle
- triggerStartEvent(long, long, DirectBuffer, DirectBuffer) - Method in class io.camunda.zeebe.engine.state.instance.DbEventScopeInstanceState
- triggerStartEvent(long, long, DirectBuffer, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableEventScopeInstanceState
-
Creates an event trigger for a process start event.
- TriggerTimerProcessor - Class in io.camunda.zeebe.engine.processing.timer
- TriggerTimerProcessor(MutableZeebeState, CatchEventBehavior, EventTriggerBehavior, ExpressionProcessor, Writers) - Constructor for class io.camunda.zeebe.engine.processing.timer.TriggerTimerProcessor
- TRUE - Enum constant in enum io.camunda.zeebe.engine.processing.message.command.BooleanType
- tryReOpenMessageStartEventSubscription(DeploymentRecord, StateWriter) - Method in class io.camunda.zeebe.engine.processing.deployment.MessageStartEventSubscriptionManager
- tryToBlacklist(TypedRecord<?>, Consumer<Long>) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableBlackListState
- tryToBlacklist(TypedRecord<?>, Consumer<Long>) - Method in class io.camunda.zeebe.engine.state.processing.DbBlackListState
- tryWriteResponse(int, long) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.writers.CommandResponseWriter
- TypedCommandWriter - Interface in io.camunda.zeebe.engine.processing.streamprocessor.writers
-
Things that any actor can write to a partition.
- TypedEventApplier<I extends Intent,
V extends RecordValue> - Interface in io.camunda.zeebe.engine.state -
Applies state changes for a specific event to the
MutableZeebeState
. - TypedEventImpl - Class in io.camunda.zeebe.engine.processing.streamprocessor
- TypedEventImpl(int) - Constructor for class io.camunda.zeebe.engine.processing.streamprocessor.TypedEventImpl
- TypedEventRegistry - Class in io.camunda.zeebe.engine.processing.streamprocessor
- TypedEventRegistry() - Constructor for class io.camunda.zeebe.engine.processing.streamprocessor.TypedEventRegistry
- TypedEventWriter - Interface in io.camunda.zeebe.engine.processing.streamprocessor.writers
- TypedRecord<T extends UnifiedRecordValue> - Interface in io.camunda.zeebe.engine.processing.streamprocessor
- TypedRecordProcessor<T extends UnifiedRecordValue> - Interface in io.camunda.zeebe.engine.processing.streamprocessor
- TypedRecordProcessorFactory - Interface in io.camunda.zeebe.engine.processing.streamprocessor
- TypedRecordProcessors - Class in io.camunda.zeebe.engine.processing.streamprocessor
- TypedRejectionWriter - Interface in io.camunda.zeebe.engine.processing.streamprocessor.writers
- TypedResponseWriter - Interface in io.camunda.zeebe.engine.processing.streamprocessor.writers
- TypedResponseWriterImpl - Class in io.camunda.zeebe.engine.processing.streamprocessor.writers
- TypedResponseWriterImpl(CommandResponseWriter, int) - Constructor for class io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedResponseWriterImpl
- TypedStreamWriter - Interface in io.camunda.zeebe.engine.processing.streamprocessor.writers
-
Things that only a stream processor should write to the log stream (+ commands)
- TypedStreamWriterImpl - Class in io.camunda.zeebe.engine.processing.streamprocessor.writers
- TypedStreamWriterImpl(LogStreamBatchWriter) - Constructor for class io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedStreamWriterImpl
- TypedStreamWriterProxy - Class in io.camunda.zeebe.engine.processing.bpmn.behavior
- TypedStreamWriterProxy() - Constructor for class io.camunda.zeebe.engine.processing.bpmn.behavior.TypedStreamWriterProxy
U
- UNSET_POSITION - Static variable in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor
- unsubscribeFromEvents(BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnEventSubscriptionBehavior
- unsubscribeFromEvents(BpmnElementContext) - Method in class io.camunda.zeebe.engine.processing.common.EventTriggerBehavior
- unsubscribeFromEvents(BpmnElementContext, TypedCommandWriter, SideEffects) - Method in class io.camunda.zeebe.engine.processing.common.CatchEventBehavior
- unsubscribeFromTimerEvent(TimerInstance, TypedCommandWriter) - Method in class io.camunda.zeebe.engine.processing.common.CatchEventBehavior
- updateCommandSentTime(TransientSubscriptionCommandState.CommandEntry) - Method in class io.camunda.zeebe.engine.state.message.TransientSubscriptionCommandState
- updateCommandSentTime(MessageSubscriptionRecord, long) - Method in class io.camunda.zeebe.engine.state.message.DbMessageSubscriptionState
- updateCommandSentTime(MessageSubscriptionRecord, long) - Method in interface io.camunda.zeebe.engine.state.mutable.MutablePendingMessageSubscriptionState
- updateInstance(long, Consumer<ElementInstance>) - Method in class io.camunda.zeebe.engine.state.instance.DbElementInstanceState
- updateInstance(long, Consumer<ElementInstance>) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableElementInstanceState
- updateInstance(ElementInstance) - Method in class io.camunda.zeebe.engine.state.instance.DbElementInstanceState
- updateInstance(ElementInstance) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableElementInstanceState
- updateJobRetries(long, int) - Method in class io.camunda.zeebe.engine.state.instance.DbJobState
- updateJobRetries(long, int) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableJobState
- updateSentTime(ProcessMessageSubscriptionRecord, long) - Method in class io.camunda.zeebe.engine.state.message.DbProcessMessageSubscriptionState
- updateSentTime(ProcessMessageSubscriptionRecord, long) - Method in interface io.camunda.zeebe.engine.state.mutable.MutablePendingProcessMessageSubscriptionState
- updateToClosingState(ProcessMessageSubscriptionRecord) - Method in class io.camunda.zeebe.engine.state.message.DbProcessMessageSubscriptionState
- updateToClosingState(ProcessMessageSubscriptionRecord) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableProcessMessageSubscriptionState
- updateToCorrelatedState(MessageSubscription) - Method in class io.camunda.zeebe.engine.state.message.DbMessageSubscriptionState
- updateToCorrelatedState(MessageSubscription) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableMessageSubscriptionState
- updateToCorrelatingState(MessageSubscriptionRecord) - Method in class io.camunda.zeebe.engine.state.message.DbMessageSubscriptionState
- updateToCorrelatingState(MessageSubscriptionRecord) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableMessageSubscriptionState
- updateToOpenedState(ProcessMessageSubscriptionRecord) - Method in class io.camunda.zeebe.engine.state.message.DbProcessMessageSubscriptionState
- updateToOpenedState(ProcessMessageSubscriptionRecord) - Method in interface io.camunda.zeebe.engine.state.mutable.MutableProcessMessageSubscriptionState
- UpdateVariableDocumentProcessor - Class in io.camunda.zeebe.engine.processing.variable
- UpdateVariableDocumentProcessor(ElementInstanceState, KeyGenerator, VariableBehavior, StateWriter) - Constructor for class io.camunda.zeebe.engine.processing.variable.UpdateVariableDocumentProcessor
- UserTaskTransformer - Class in io.camunda.zeebe.engine.processing.deployment.model.transformer
- UserTaskTransformer(ExpressionLanguage) - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.transformer.UserTaskTransformer
V
- validate(BpmnModelInstance) - Method in class io.camunda.zeebe.engine.processing.deployment.transform.BpmnValidator
- validate(CatchEvent, ValidationResultCollector) - Method in class io.camunda.zeebe.engine.processing.deployment.model.validation.TimerCatchEventExpressionValidator
- validate(ZeebeTaskHeaders, ValidationResultCollector) - Method in class io.camunda.zeebe.engine.processing.deployment.model.validation.ZeebeTaskHeadersValidator
- validate(T, ValidationResultCollector) - Method in class io.camunda.zeebe.engine.processing.deployment.model.validation.ZeebeExpressionValidator
- ValidationErrorFormatter - Class in io.camunda.zeebe.engine.processing.deployment.transform
- ValidationErrorFormatter() - Constructor for class io.camunda.zeebe.engine.processing.deployment.transform.ValidationErrorFormatter
- value() - Method in enum io.camunda.zeebe.engine.processing.message.command.BooleanType
-
The raw encoded value in the Java type representation.
- valueOf(String) - Static method in enum io.camunda.zeebe.engine.processing.message.command.BooleanType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.camunda.zeebe.engine.processing.message.command.MetaAttribute
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor.Phase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.camunda.zeebe.engine.state.immutable.JobState.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum io.camunda.zeebe.engine.processing.message.command.BooleanType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.camunda.zeebe.engine.processing.message.command.MetaAttribute
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class io.camunda.zeebe.engine.processing.streamprocessor.RecordProcessorMap
-
BEWARE: does not detect concurrent modifications and behaves incorrectly in this case
- values() - Static method in enum io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessor.Phase
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.camunda.zeebe.engine.state.immutable.JobState.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
-
Returns an array containing the constants of this enum type, in the order they are declared.
- valueType(ValueType) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.writers.CommandResponseWriter
- valueWriter(BufferWriter) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.writers.CommandResponseWriter
- VarDataEncodingDecoder - Class in io.camunda.zeebe.engine.processing.message.command
- VarDataEncodingDecoder() - Constructor for class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- VarDataEncodingEncoder - Class in io.camunda.zeebe.engine.processing.message.command
- VarDataEncodingEncoder() - Constructor for class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingEncoder
- varDataEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- varDataEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingEncoder
- varDataEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- varDataEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingEncoder
- varDataMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- varDataMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingEncoder
- varDataMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- varDataMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingEncoder
- varDataNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- varDataNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingEncoder
- varDataSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- VariableBehavior - Class in io.camunda.zeebe.engine.processing.variable
-
A behavior which allows processors to mutate the variable state.
- VariableBehavior(VariableState, StateWriter, KeyGenerator) - Constructor for class io.camunda.zeebe.engine.processing.variable.VariableBehavior
- VariableInstance - Class in io.camunda.zeebe.engine.state.variable
- VariableInstance() - Constructor for class io.camunda.zeebe.engine.state.variable.VariableInstance
- variableMappingBehavior() - Method in interface io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBehaviors
- variableMappingBehavior() - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.BpmnBehaviorsImpl
- VariableMappingTransformer - Class in io.camunda.zeebe.engine.processing.deployment.model.transformer
-
Transform variable mappings into an expression.
- VariableMappingTransformer() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.transformer.VariableMappingTransformer
- variables() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- variables(String) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- VARIABLES - Enum constant in enum io.camunda.zeebe.engine.state.ZbColumnFamilies
- variablesCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- variablesCharacterEncoding() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- variablesHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- variablesHeaderLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- variablesId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- variablesId() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- variablesLength() - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- variablesMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- variablesMetaAttribute(MetaAttribute) - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- variablesSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- VariableState - Interface in io.camunda.zeebe.engine.state.immutable
- verifyThat(Class<T>) - Static method in class io.camunda.zeebe.engine.processing.deployment.model.validation.ZeebeExpressionValidator
- version() - Method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- version(int) - Method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- versionEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- versionEncodingLength() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- versionEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- versionEncodingOffset() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- versionMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- versionMaxValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- versionMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- versionMinValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- versionNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- versionNullValue() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- versionSinceVersion() - Static method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- visit(long, int, DirectBuffer) - Method in interface io.camunda.zeebe.engine.state.immutable.DeploymentState.PendingDeploymentVisitor
- visit(TimerInstance) - Method in interface io.camunda.zeebe.engine.state.immutable.TimerInstanceState.TimerVisitor
- visit(MessageStartEventSubscription) - Method in interface io.camunda.zeebe.engine.state.immutable.MessageStartEventSubscriptionState.MessageStartEventSubscriptionVisitor
- visit(MessageSubscription) - Method in interface io.camunda.zeebe.engine.state.immutable.MessageSubscriptionState.MessageSubscriptionVisitor
- visit(ProcessMessageSubscription) - Method in interface io.camunda.zeebe.engine.state.immutable.ProcessMessageSubscriptionState.ProcessMessageSubscriptionVisitor
- visit(StoredMessage) - Method in interface io.camunda.zeebe.engine.state.immutable.MessageState.MessageVisitor
- visit(ModelElementType, BpmnModelElementInstance) - Method in class io.camunda.zeebe.engine.processing.deployment.model.transformation.TransformationVisitor
- visitBpmnProcessIds(Consumer<DirectBuffer>) - Method in class io.camunda.zeebe.engine.processing.message.Subscriptions
- visitElementSubscriptions(long, ProcessMessageSubscriptionState.ProcessMessageSubscriptionVisitor) - Method in interface io.camunda.zeebe.engine.state.immutable.ProcessMessageSubscriptionState
- visitElementSubscriptions(long, ProcessMessageSubscriptionState.ProcessMessageSubscriptionVisitor) - Method in class io.camunda.zeebe.engine.state.message.DbProcessMessageSubscriptionState
- visitMessages(DirectBuffer, DirectBuffer, MessageState.MessageVisitor) - Method in interface io.camunda.zeebe.engine.state.immutable.MessageState
- visitMessages(DirectBuffer, DirectBuffer, MessageState.MessageVisitor) - Method in class io.camunda.zeebe.engine.state.message.DbMessageState
- visitMessagesWithDeadlineBefore(long, MessageState.MessageVisitor) - Method in interface io.camunda.zeebe.engine.state.immutable.MessageState
- visitMessagesWithDeadlineBefore(long, MessageState.MessageVisitor) - Method in class io.camunda.zeebe.engine.state.message.DbMessageState
- visitRecord(IndexedRecord) - Method in interface io.camunda.zeebe.engine.state.instance.DbElementInstanceState.RecordVisitor
- visitSubscriptionBefore(long, MessageSubscriptionState.MessageSubscriptionVisitor) - Method in class io.camunda.zeebe.engine.state.message.DbMessageSubscriptionState
- visitSubscriptionBefore(long, MessageSubscriptionState.MessageSubscriptionVisitor) - Method in interface io.camunda.zeebe.engine.state.mutable.MutablePendingMessageSubscriptionState
- visitSubscriptionBefore(long, ProcessMessageSubscriptionState.ProcessMessageSubscriptionVisitor) - Method in class io.camunda.zeebe.engine.state.message.DbProcessMessageSubscriptionState
- visitSubscriptionBefore(long, ProcessMessageSubscriptionState.ProcessMessageSubscriptionVisitor) - Method in interface io.camunda.zeebe.engine.state.mutable.MutablePendingProcessMessageSubscriptionState
- visitSubscriptions(Subscriptions.SubscriptionVisitor) - Method in class io.camunda.zeebe.engine.processing.message.Subscriptions
- visitSubscriptions(DirectBuffer, DirectBuffer, MessageSubscriptionState.MessageSubscriptionVisitor) - Method in interface io.camunda.zeebe.engine.state.immutable.MessageSubscriptionState
- visitSubscriptions(DirectBuffer, DirectBuffer, MessageSubscriptionState.MessageSubscriptionVisitor) - Method in class io.camunda.zeebe.engine.state.message.DbMessageSubscriptionState
- visitSubscriptionsByMessageName(DirectBuffer, MessageStartEventSubscriptionState.MessageStartEventSubscriptionVisitor) - Method in interface io.camunda.zeebe.engine.state.immutable.MessageStartEventSubscriptionState
- visitSubscriptionsByMessageName(DirectBuffer, MessageStartEventSubscriptionState.MessageStartEventSubscriptionVisitor) - Method in class io.camunda.zeebe.engine.state.message.DbMessageStartEventSubscriptionState
- visitSubscriptionsByProcessDefinition(long, MessageStartEventSubscriptionState.MessageStartEventSubscriptionVisitor) - Method in interface io.camunda.zeebe.engine.state.immutable.MessageStartEventSubscriptionState
-
Visit all subscriptions with the given process definition key.
- visitSubscriptionsByProcessDefinition(long, MessageStartEventSubscriptionState.MessageStartEventSubscriptionVisitor) - Method in class io.camunda.zeebe.engine.state.message.DbMessageStartEventSubscriptionState
W
- withListener(StreamProcessorLifecycleAware) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.TypedRecordProcessors
- wrap(TypedStreamWriter) - Method in class io.camunda.zeebe.engine.processing.bpmn.behavior.TypedStreamWriterProxy
- wrap(LoggedEvent, RecordMetadata, UnifiedRecordValue) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.TypedEventImpl
- wrap(ProcessRecord, long) - Method in class io.camunda.zeebe.engine.state.deployment.PersistedProcess
- wrap(DirectBuffer, int) - Method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderDecoder
- wrap(DirectBuffer, int) - Method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingDecoder
- wrap(DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionCommand
- wrap(DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionCommand
- wrap(DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionCommand
- wrap(DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionCommand
- wrap(DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionCommand
- wrap(DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionCommand
- wrap(DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionCommand
- wrap(DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.state.instance.IndexedRecord
- wrap(DirectBuffer, int, int) - Method in class io.camunda.zeebe.engine.state.instance.TimerInstance
- wrap(DirectBuffer, int, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- wrap(DirectBuffer, int, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- wrap(DirectBuffer, int, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- wrap(DirectBuffer, int, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- wrap(DirectBuffer, int, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- wrap(DirectBuffer, int, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- wrap(DirectBuffer, int, int, int) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- wrap(MutableDirectBuffer, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- wrap(MutableDirectBuffer, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- wrap(MutableDirectBuffer, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- wrap(MutableDirectBuffer, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- wrap(MutableDirectBuffer, int) - Method in class io.camunda.zeebe.engine.processing.message.command.MessageHeaderEncoder
- wrap(MutableDirectBuffer, int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- wrap(MutableDirectBuffer, int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- wrap(MutableDirectBuffer, int) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- wrap(MutableDirectBuffer, int) - Method in class io.camunda.zeebe.engine.processing.message.command.VarDataEncodingEncoder
- wrapAndApplyHeader(DirectBuffer, int, MessageHeaderDecoder) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- wrapAndApplyHeader(DirectBuffer, int, MessageHeaderDecoder) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- wrapAndApplyHeader(DirectBuffer, int, MessageHeaderDecoder) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- wrapAndApplyHeader(DirectBuffer, int, MessageHeaderDecoder) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- wrapAndApplyHeader(DirectBuffer, int, MessageHeaderDecoder) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- wrapAndApplyHeader(DirectBuffer, int, MessageHeaderDecoder) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- wrapAndApplyHeader(DirectBuffer, int, MessageHeaderDecoder) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- wrapAndApplyHeader(MutableDirectBuffer, int, MessageHeaderEncoder) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionEncoder
- wrapAndApplyHeader(MutableDirectBuffer, int, MessageHeaderEncoder) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionEncoder
- wrapAndApplyHeader(MutableDirectBuffer, int, MessageHeaderEncoder) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionEncoder
- wrapAndApplyHeader(MutableDirectBuffer, int, MessageHeaderEncoder) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionEncoder
- wrapAndApplyHeader(MutableDirectBuffer, int, MessageHeaderEncoder) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionEncoder
- wrapAndApplyHeader(MutableDirectBuffer, int, MessageHeaderEncoder) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionEncoder
- wrapAndApplyHeader(MutableDirectBuffer, int, MessageHeaderEncoder) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionEncoder
- wrapBpmnProcessId(DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- wrapBpmnProcessId(DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- wrapBpmnProcessId(DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- wrapBpmnProcessId(DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- wrapCorrelationKey(DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- wrapCorrelationKey(DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- wrapCorrelationKey(DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- wrapMessageName(DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionDecoder
- wrapMessageName(DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionDecoder
- wrapMessageName(DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionDecoder
- wrapMessageName(DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- wrapMessageName(DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionDecoder
- wrapMessageName(DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionDecoder
- wrapMessageName(DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionDecoder
- wrapVariables(DirectBuffer) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionDecoder
- write(MutableDirectBuffer, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseMessageSubscriptionCommand
- write(MutableDirectBuffer, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CloseProcessMessageSubscriptionCommand
- write(MutableDirectBuffer, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateMessageSubscriptionCommand
- write(MutableDirectBuffer, int) - Method in class io.camunda.zeebe.engine.processing.message.command.CorrelateProcessMessageSubscriptionCommand
- write(MutableDirectBuffer, int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenMessageSubscriptionCommand
- write(MutableDirectBuffer, int) - Method in class io.camunda.zeebe.engine.processing.message.command.OpenProcessMessageSubscriptionCommand
- write(MutableDirectBuffer, int) - Method in class io.camunda.zeebe.engine.processing.message.command.RejectCorrelateMessageSubscriptionCommand
- writeEvent(TypedRecord<?>) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.NoopResponseWriter
- writeEvent(TypedRecord<?>) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedResponseWriter
- writeEvent(TypedRecord<?>) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedResponseWriterImpl
- writeEventOnCommand(long, Intent, UnpackedObject, TypedRecord<?>) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.NoopResponseWriter
- writeEventOnCommand(long, Intent, UnpackedObject, TypedRecord<?>) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedResponseWriter
- writeEventOnCommand(long, Intent, UnpackedObject, TypedRecord<?>) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedResponseWriterImpl
- writeRejectionOnCommand(TypedRecord<?>, RejectionType, String) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.NoopResponseWriter
- writeRejectionOnCommand(TypedRecord<?>, RejectionType, String) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedResponseWriter
- writeRejectionOnCommand(TypedRecord<?>, RejectionType, String) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedResponseWriterImpl
- writeResponse(long, Intent, UnpackedObject, ValueType, long, int) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.NoopResponseWriter
- writeResponse(long, Intent, UnpackedObject, ValueType, long, int) - Method in interface io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedResponseWriter
- writeResponse(long, Intent, UnpackedObject, ValueType, long, int) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.writers.TypedResponseWriterImpl
- Writers - Class in io.camunda.zeebe.engine.processing.streamprocessor.writers
-
Convenience class to aggregate all the writers
- Writers(TypedStreamWriter, StateWriter, TypedResponseWriter) - Constructor for class io.camunda.zeebe.engine.processing.streamprocessor.writers.Writers
Z
- ZbColumnFamilies - Enum in io.camunda.zeebe.engine.state
- zeebeDb(ZeebeDb) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.StreamProcessorBuilder
- ZeebeDbState - Class in io.camunda.zeebe.engine.state
- ZeebeDbState(int, ZeebeDb<ZbColumnFamilies>, TransactionContext) - Constructor for class io.camunda.zeebe.engine.state.ZeebeDbState
- ZeebeDbState(ZeebeDb<ZbColumnFamilies>, TransactionContext) - Constructor for class io.camunda.zeebe.engine.state.ZeebeDbState
- ZeebeExpressionValidator<T extends org.camunda.bpm.model.xml.instance.ModelElementInstance> - Class in io.camunda.zeebe.engine.processing.deployment.model.validation
- ZeebeExpressionValidator.Builder<T extends org.camunda.bpm.model.xml.instance.ModelElementInstance> - Class in io.camunda.zeebe.engine.processing.deployment.model.validation
- ZeebeExpressionValidator.ExpressionVerification - Class in io.camunda.zeebe.engine.processing.deployment.model.validation
- ZeebeRuntimeValidators - Class in io.camunda.zeebe.engine.processing.deployment.model.validation
- ZeebeRuntimeValidators() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.validation.ZeebeRuntimeValidators
- zeebeState(ZeebeDbState) - Method in class io.camunda.zeebe.engine.processing.streamprocessor.ProcessingContext
- ZeebeState - Interface in io.camunda.zeebe.engine.state.immutable
- ZeebeTaskHeadersValidator - Class in io.camunda.zeebe.engine.processing.deployment.model.validation
- ZeebeTaskHeadersValidator() - Constructor for class io.camunda.zeebe.engine.processing.deployment.model.validation.ZeebeTaskHeadersValidator
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form