All Classes Interface Summary Class Summary Enum Summary Exception Summary Annotation Types Summary
Class |
Description |
AbstractAdvanceRuntimeDataServiceImpl |
|
AbstractAdvanceRuntimeDataServiceImpl.ProcessComparator |
|
AbstractAdvanceRuntimeDataServiceImpl.TaskComparator |
|
AbstractAuditDeleteBuilderImpl<T> |
|
AbstractAuditDeleteBuilderImpl.Subquery |
|
AbstractAuditLogger |
|
AbstractAuditLoggerAdapter |
|
AbstractAuditQueryBuilderImpl<T,R> |
|
AbstractAvailableJobsExecutor |
Heart of the executor component - executes the actual tasks.
|
AbstractBaseTest |
|
AbstractCaseServicesTest |
|
AbstractCompositeNodeHandler |
|
AbstractContext |
|
AbstractContextInstance |
|
AbstractDeploymentService |
|
AbstractExceptionHandlingTaskHandler |
|
AbstractExecutionErrorFilter |
|
AbstractFormProvider |
|
AbstractHTWorkItemHandler |
|
AbstractJavaProcessBuilder |
|
AbstractJaxbTaskObject<T> |
|
AbstractKieServicesTest |
|
AbstractLoadCalculator |
|
AbstractLogOrThrowWorkItemHandler |
|
AbstractMVELBuilder |
|
AbstractNodeHandler |
|
AbstractNodeHandler |
|
AbstractProcessAssembler |
|
AbstractProcessInstanceFactory |
|
AbstractProcessInstanceMarshaller |
Default implementation of a process instance marshaller.
|
AbstractProtobufProcessInstanceMarshaller |
Default implementation of a process instance marshaller.
|
AbstractQueryMapper<T> |
|
AbstractRemoteObject |
|
AbstractRuleTaskHandler |
Additional BusinessRuleTask support that allows to decouple rules from processes - as default BusinessRuleTask
uses exact same working memory (kie session) as process which essentially means same kbase.
|
AbstractRuntimeManager |
Common implementation that all RuntimeManager implementations should inherit from.
|
AbstractServicesTest |
|
AbstractTaskAuditQueryBuilderImpl<Q,R> |
|
AbstractTaskAuditQueryCommand<R,Q> |
|
AbstractTaskQueryCriteriaUtil |
|
AbstractUserGroupInfo |
|
AbstractWeaverService |
|
AbstractWorkItemHandler |
|
Action |
|
ActionBuilder |
|
ActionExceptionHandler |
|
ActionNode |
Default implementation of an action node.
|
ActionNodeBuilder |
|
ActionNodeFactory<T extends org.kie.api.fluent.NodeContainerBuilder<T,?>> |
|
ActionNodeHandler |
|
ActionNodeHandler |
|
ActionNodeInstance |
Runtime counterpart of an action node.
|
Activate |
|
ActivateTaskCommand |
Operation.Activate : [ new OperationCommand().{ status = [ Status.Created ],
allowed = [ Allowed.Owner, Allowed.BusinessAdministrator ], newStatus =
Status.Ready } ],
|
Activator |
|
Activator |
|
Activator |
|
Activator |
|
AddAttachmentCommand |
|
AddCommentCommand |
|
AddContentCommand |
|
AddContentFromUserCommand |
|
AddDataCaseFileInstanceCommand |
Updates case file with new data
|
AddDynamicProcessCommand |
Adds subprocess (identified by processId) to selected ad hoc process instance with given parameters
|
AddDynamicProcessToStageCommand |
Adds subprocess (identified by processId) to selected ad hoc process instance with given parameters
|
AddDynamicTaskCommand |
Adds task to selected ad hoc process instance with given parameters
|
AddDynamicTaskToStageCommand |
Adds task to given stage within selected ad hoc process instance with given parameters
|
AddGroupCommand |
|
AddPeopleAssignmentsCommand |
|
AddTaskCommand |
Operation.Start : [ new OperationCommand().{ status = [ Status.Ready ],
allowed = [ Allowed.PotentialOwner ], setNewOwnerToUser = true, newStatus =
Status.InProgress }, new OperationCommand().{ status = [ Status.Reserved ],
allowed = [ Allowed.Owner ], newStatus = Status.InProgress } ], *
|
AddTaskInputsCommand |
|
AddUserCommand |
|
AddUsersGroupsCommand |
|
AdHocFragment |
Represents single ad hoc fragment that can be triggered.
|
AdHocFragmentImpl |
|
AdHocFragmentNotFoundException |
Thrown when accessing ad hoc fragment that does not exist
|
AdHocProcessService |
Service for starting ad-hoc processes.
|
AdHocProcessServiceCDIImpl |
|
AdHocProcessServiceImpl |
|
AdHocSubProcessHandler |
|
AdHocUserTaskService |
Service for adding and updating ad-hoc user tasks.
|
AdHocUserTaskServiceCDIImpl |
|
AdHocUserTaskServiceImpl |
|
AdvanceCaseRuntimeDataService |
|
AdvanceCaseRuntimeDataServiceImpl |
|
AdvanceRuntimeDataService |
|
AdvanceRuntimeDataServiceImpl |
|
Agenda |
Defines a annotated element that is of type Agenda
and that's used with EventListenerProducer
|
AggregateColumnFilter |
|
Allowed |
|
ArchiveLoggerProvider |
|
ArchiveTasksCommand |
|
Assignment |
|
AssignmentAction |
|
AssignmentBuilder |
|
AssignmentImpl |
|
AssignmentProducer |
|
AssignmentService |
|
AssignmentServiceImpl |
|
AssignmentServiceProvider |
|
AssignmentServiceRegistry |
|
AssignmentTaskEventListener |
|
Association |
|
AssociationHandler |
|
AsyncAuditLogProducer |
Asynchronous log producer that puts audit log events into JMS queue.
|
AsyncAuditLogReceiver |
Asynchronous audit event receiver.
|
AsyncCaseInstanceAuditEventProducer |
|
AsyncCaseInstanceAuditEventReceiver |
|
AsyncEventNode |
|
AsyncEventNodeInstance |
Runtime counterpart of an event node.
|
AsyncExecutionMarker |
Allows different component to mark the execution as async (timer or jbpm executor)
to hint other parts about some limitation e.g. security checks based on authentication
-security context which might not be available.
|
AsynchronousJobEvent |
|
AsynchronousJobEventImpl |
|
AsynchronousJobListener |
|
AsyncJobException |
|
AsyncSignalEventCommand |
|
AsyncStartProcessCommand |
Executor command that allows asynchronously start process instance based on given parameters:
DeploymentId - either given explicitly or will be used same as the project this command is triggered from
ProcessId - identifier of the process to start - required
CorrelationKey - correlation key to be associated with new process instance - optional
Variables - Map of process variables to be given to new process instance
|
AsyncTaskLifeCycleEventProducer |
|
AsyncTaskLifeCycleEventReceiver |
|
AsyncWorkItemHandler |
Asynchronous work item handler that utilizes power of ExecutorService .
|
AsyncWorkItemHandlerCmdCallback |
Dedicated callback for AsyncWorkItemHandler that is responsible for:
completing work item in case of successful execution
attempting to handle exception (by utilizing ExceptionScope mechanism) in case of unsuccessful execution
|
AttachmentImpl |
|
AttachmentImpl_ |
|
AttributesAware |
|
Audit |
|
AuditCaseInstanceData |
|
AuditCommand<T> |
|
AuditEvent |
|
AuditEventBuilder |
|
AuditJbpmEntityContributor |
|
AuditJMSProcessor |
Extension of default AsyncAuditLogReceiver that is MessageListener
to allow entity manager factory to be injected.
|
AuditJMSProcessor |
Extension of default AsyncAuditLogReceiver that is MessageListener
to allow entity manager factory to be injected.
|
AuditLoggerArchiveTreat |
|
AuditLoggerFactory |
Factory for producing support audit loggers.
|
AuditLoggerFactory.Type |
|
AuditLogService |
|
AuditNodeInstanceLogQueryCommand |
|
AuditProcessInstanceLogQueryCommand |
|
AuditQueryCriteriaUtil |
|
AuditTaskData |
|
AuditTaskDeleteBuilderImpl |
|
AuditTaskImpl |
|
AuditTaskImpl_ |
|
AuditTaskQueryBuilderImpl |
|
AuditTaskQueryCommand |
|
AuditTransactionalCommandServiceEJBImpl |
|
AuditVariableInstanceLogQueryCommand |
|
AuthorizationManager |
Responsible for authorizing access to case instances based on the context.
|
AuthorizationManager.ProtectedOperation |
|
AuthorizationManagerImpl |
|
AutoAckErrorCommand |
|
AvailableJobsExecutor |
|
BAMTaskEventListener |
BAMTaskEventListener.BAMTaskWorker |
Interface for performing additional operations to a org.jbpm.services.task.impl.model.BAMTaskSummaryImpl instance.
|
BAMTaskSummaryImpl |
|
BAMTaskSummaryImpl_ |
|
BAMTaskSummaryQueryBuilder |
|
BAMTaskSummaryQueryBuilder.OrderBy |
|
BAMTaskSummaryQueryBuilderImpl |
|
BAMTaskSummaryQueryCommand |
|
BooleanDataType |
Representation of a boolean datatype.
|
BooleanExpressionImpl |
|
BooleanExpressionImpl_ |
|
BoundaryEventHandler |
|
BoundaryEventNode |
|
BoundaryEventNodeFactory<T extends org.kie.api.fluent.NodeContainerBuilder<T,?>> |
|
BoundaryEventNodeInstance |
|
BPMN2AssemblerService |
|
BPMN2DataServiceCDIImpl |
|
BPMN2DataServiceImpl |
|
Bpmn2Import |
|
Bpmn2ImportHandler |
|
BPMN2ProcessProviderImpl |
|
BPMN2WeaverService |
|
BPMNDISemanticModule |
|
BPMNEdgeHandler |
|
BPMNEdgeHandler.ConnectionInfo |
|
BPMNExtensionsSemanticModule |
|
BPMNPlaneHandler |
|
BPMNPlaneHandler.ProcessInfo |
|
BPMNSemanticModule |
|
BPMNShapeHandler |
|
BPMNShapeHandler.NodeInfo |
|
BroadcastEventTypeFilter |
This variant of the EventTypeFilter can be used with structures such
as Escalations, for which Intermediate (Catching) Events can be triggered
by both
|
BusinessAdminTasksPreprocessor |
|
BusinessCalendar |
BusinessCalendar allows for defining custom definitions of working days, hours and holidays
to be taken under consideration when scheduling time based activities such as timers or deadlines.
|
BusinessCalendarImpl |
Default implementation of BusinessCalendar interface that is configured with properties.
|
BusinessRuleAssignmentStrategy |
|
BusinessRuleTaskHandler |
|
BusinessRuleTaskHandler |
Additional BusinessRuleTask support that allows to decouple rules from processes - as default BusinessRuleTask
uses exact same working memory (kie session) as process which essentially means same kbase.
|
CacheManagerImpl |
Default implementation of CacheManager that is backed by ConcurrentHashMap .
|
CallActivityHandler |
|
CancelCaseCommand |
|
CancelDeadlineCommand |
|
CancelNodeInstanceAction |
|
CancelNodeInstanceCommand |
|
CancelTaskDeadlineCommand |
|
CannotAddTaskException |
Exception thrown from the TaskServiceSession when there is a problem adding task.
|
CaseActiveException |
Thrown then reopening a case that is already started/reopened
|
CaseAuditJbpmEntityContributor |
|
CaseCancelEvent |
Represents occurrence of case close operation
|
CaseCloseEvent |
Represents occurrence of case close operation
|
CaseCommand<T> |
|
CaseCommentCommand |
Adds or removes comment to/from case
|
CaseCommentEvent |
Represents occurrence of case comment related operation
|
CaseCommentNotFoundException |
Thrown then accessing or manipulating case comment that does not exist
|
CaseConfigurationDeploymentListener |
Configuration listener that must be attached to DeploymentService so it can react
to deployed units so it can register case event listeners per deployment unit.
|
CaseDataEvent |
Represents occurrence of case data (that is part of case file) related operation
|
CaseDefinition |
Describes case structure and requirements.
|
CaseDefinitionComparator |
Comparator used for sorting of CaseDefinitions - currently by:
name - gives as CaseName
id - gives as CaseId
deploymentId - gives as Project
|
CaseDefinitionImpl |
|
CaseDefinitionNotFoundException |
Thrown then accessing case definition that does not exist
|
CaseDestroyEvent |
Represents occurrence of case destroy operation
|
CaseDynamicSubprocessEvent |
Represents occurrence of dynamic subprocess add to case operation
|
CaseDynamicTaskEvent |
Represents occurrence of dynamic task add to case operation
|
CaseEvent |
Represents generic event of case operation
|
CaseEventListener |
Case event listener that is invoked upon various
operation related to a case.
|
CaseEventSupport |
Responsible for firing case related events to notify registered CaseEventListeners
|
CaseFileData |
|
CaseFileDataFilter |
Provides mechanism to filter case file data to return only expected results.
|
CaseFileDataLog |
|
CaseFileDataLogDeleteBuilder |
|
CaseFileDataLogDeleteBuilderImpl |
|
CaseFileInstance |
Represent contextual data of a given Case
|
CaseFileInstanceImpl |
|
CaseFileInstanceMarshallingStrategy |
|
CaseFileItem |
Simple view on individual CaseFile data item.
|
CaseFileItemImpl |
|
CaseIdExpressionFunctions |
|
CaseIdGenerator |
Responsible for generating and keeping track of generated case identifiers.
|
CaseIdInfo |
|
CaseIndexerManager |
Represents logic behind mechanism to index task variables.
|
CaseInstance |
Describes case structure and requirements.
|
CaseInstanceAuditConstants |
|
CaseInstanceAuditEventListener |
|
CaseInstanceAuditLoggerFactory |
|
CaseInstanceImpl |
|
CaseInstanceMigrationService |
|
CaseInstanceMigrationServiceImpl |
|
CaseLogCleanupCommand |
Case Log clean up command that aims at doing house keeping of audit/log tables used in jBPM extending
LogCleanupCommand for current behavior.
|
CaseMarshallerFactory |
Utility class to help with creating properly setup CaseFileInstanceMarshallerStrategy
|
CaseMigrationReport |
|
CaseMilestone |
Represents intermediate goal within a case
|
CaseMilestoneImpl |
|
CaseMilestoneInstance |
Represents single instance of a milestone in a case.
|
CaseMilestoneInstanceImpl |
|
CaseNotFoundException |
Thrown then accessing case that does not exist
|
CasePrefixCannotBeGeneratedException |
|
CasePrefixNotFoundException |
|
CaseReopenEvent |
Represents occurrence of start case operation
|
CaseRole |
Represents single role assigned to a given case.
|
CaseRoleAssignmentEvent |
Represents occurrence of role assignment on a case operation
|
CaseRoleAssignmentLog |
|
CaseRoleAssignmentLogDeleteBuilder |
|
CaseRoleAssignmentLogDeleteBuilderImpl |
|
CaseRoleImpl |
|
CaseRoleInstance |
Defines single role instance with currently available assignments.
|
CaseRoleInstanceImpl |
|
CaseRuntimeDataService |
Provides access to case(s) and its runtime data such as:
available cases
available milestones
available stages
|
CaseRuntimeDataServiceImpl |
|
CaseService |
Provides case management operations.
|
CaseServiceConfigurator |
|
CaseServiceImpl |
|
CaseStage |
Represents self contained part of case that does include
number of other activities and potentially other stages
|
CaseStageImpl |
|
CaseStageInstance |
Represents stage within case on runtime, provides information about
active tasks, subprocesses etc.
|
CaseStageInstanceImpl |
|
CaseStartEvent |
Represents occurrence of start case operation
|
CaseStatus |
|
CaseUtils |
|
CaseVariableIndexer |
Dedicated type for custom implementations of VariableIndexer for case variables
|
CatchLinkNode |
|
CatchLinkNodeHandler |
|
CatchLinkNodeInstance |
|
CDITaskServiceFactory |
CDI based task service factory that will always deliver the same instance of the
TaskService that was injected into it.
|
ChecklistContext |
|
ChecklistContextConstraint |
|
ChecklistExample |
|
ChecklistItem |
|
ChecklistItem.Status |
|
ChecklistItemFactory |
|
ChecklistManager |
|
ChecklistUI |
|
ClaimNextAvailableTaskCommand |
|
ClaimTaskCommand |
Operation.Claim
: [ new OperationCommand().{
status = [ Status.Ready ],
allowed = [ Allowed.PotentialOwner, Allowed.BusinessAdministrator ],
setNewOwnerToUser = true,
newStatus = Status.Reserved
} ],
|
ClassCacheManager |
Simple cache to keep classes of commands and callback to not attempt to load them every time.
|
ClasspathFormProvider |
|
ClasspathFormProviderCDI |
|
ClassUtil |
|
ClearHistoryLogsCommand |
|
ClientServiceFactory |
Generic service factory used for remote look ups that are usually container specific.
|
CloseCaseCommand |
|
Collaboration |
|
CollaborationHandler |
|
CollectionUtils |
|
CommandBasedAuditLogService |
|
CommandBasedTaskService |
|
CommandsUtil |
|
CommentImpl |
|
CommentImpl_ |
|
CommentInstance |
Represents single case comment instance that can be attached
to a case at any time by case participants
|
CommentInstanceImpl |
|
CommentNotificationEventListener |
Event listener that allows to fire notification based on mentions in the case comments
that refer to case roles - meaning all role assignments (users or groups) will be notified
whenever mentioned.
|
CommentSortBy |
|
CommonUtils |
|
ComparablePeriodSerializer |
|
CompensationHandler |
|
CompensationScope |
This scope represents the collection of compensation handlers in a (sub)process.
|
CompensationScopeInstance |
|
CompleteTaskCommand |
Operation.Start : [ new OperationCommand().{ status = [ Status.Ready ],
allowed = [ Allowed.PotentialOwner ], setNewOwnerToUser = true, newStatus =
Status.InProgress }, new OperationCommand().{ status = [ Status.Reserved ],
allowed = [ Allowed.Owner ], newStatus = Status.InProgress } ], *
|
ComplexGatewayHandler |
|
CompositeAsyncAuditLogReceiver |
|
CompositeCommand<T> |
|
CompositeCommand |
|
CompositeContextNode |
|
CompositeContextNodeHandler |
|
CompositeContextNodeInstance |
|
CompositeNode |
|
CompositeNode.CompositeNodeEnd |
|
CompositeNode.CompositeNodeStart |
|
CompositeNode.NodeAndType |
|
CompositeNodeFactory<T extends org.kie.api.fluent.NodeContainerBuilder<T,?>> |
|
CompositeNodeHandler |
|
CompositeNodeInstance |
Runtime counterpart of a composite node.
|
Connection |
|
Connection |
Represents a connection between two nodes in a workflow.
|
ConnectionHandler |
|
ConnectionImpl |
Default implementation of a connection.
|
ConnectionRef |
|
Constrainable |
|
Constraint |
Represents a constraint in a RuleFlow.
|
ConstraintEvaluator |
|
ConstraintHandler |
|
ConstraintImpl |
Default implementation of a constraint.
|
ConstraintTrigger |
|
ContainerManagedTransactionDisposeCommand |
Dispose command that is dedicated to be used in container managed environments instead of
default way of disposing ksession
ksession.dispose() .
|
ContainerManagedTransactionManager |
Dedicated implementation of TransactionManager that should be used when:
jBPM engine is embedded in Container Managed Transaction (CMT) environment like EJB container
container that does not allow accessing UserTransaction (when running in CMT mode)
- e.g.
|
ContentDataImpl |
|
ContentImpl |
|
ContentImpl_ |
|
ContentMarshallerHelper |
|
Context |
|
Contextable |
|
ContextableInstance |
|
ContextContainer |
|
ContextContainerImpl |
|
ContextInstance |
|
ContextInstanceContainer |
|
ContextInstanceFactory |
|
ContextInstanceFactoryRegistry |
|
ContextMappingInfo |
The main entity that helps the runtime manager keep track of which context is bound to which KieSession .
|
ContextResolver |
|
CoreFunctionQueryParamBuilder |
|
Correlation |
|
CorrelationExpressionEvaluator |
|
CorrelationInstance |
|
CorrelationKey |
|
CorrelationKeyInfo |
|
CorrelationManager |
|
CorrelationProperties |
|
CorrelationProperty |
|
CorrelationPropertyHandler |
|
CorrelationPropertyInfo |
|
CorrelationSubscription |
|
CorrelationSubscriptionHandler |
|
CreateItemDialog |
|
CreateNewNodeFactory |
|
CustomIdKModuleDeploymentUnit |
|
DataAssociation |
|
DataAssociationFactory |
|
DataObjectHandler |
|
DataStore |
|
DataStoreHandler |
|
DataTransformerRegistry |
Registry for all available on runtime DataTransformer s for performing
data input and output transformation.
|
DataType |
Abstract representation of a datatype.
|
DataTypeFactory |
A factory for creating a datatype.
|
DateTimeUtils |
|
DBExecutionErrorFilter |
|
DBUserGroupCallbackImpl |
Data base server user group callback implementation that utilizes SQL queries
to get information about user, groups and relationship of these two.
|
DBUserGroupInfoProducer |
|
DBUserInfoImpl |
|
Deactivate |
|
DeadlineImpl |
|
DeadlineImpl_ |
|
DeadlineSchedulerHelper |
|
DeadlinesImpl |
|
DeadlinesImpl_ |
|
DeadlineSummaryImpl |
|
DebugRuntimeManagerLock |
|
DebugRuntimeManagerLockFactory |
|
DecisionTaskHandler |
Additional BusinessRuleTask support that allows to decouple rules from processes - as default BusinessRuleTask
uses exact same working memory (kie session) as process which essentially means same kbase.
|
DefaultAuditEventBuilderImpl |
|
DefaultCaseServiceConfigurator |
|
DefaultChecklistContext |
|
DefaultChecklistItem |
|
DefaultChecklistManager |
|
DefaultExceptionScopeInstance |
|
DefaultExecutionErrorStorage |
|
DefaultKieServiceConfigurator |
|
DefaultProcessInstanceManager |
|
DefaultProcessInstanceManagerFactory |
|
DefaultRegisterableItemsFactory |
Default implementation of the RegisterableItemsFactory responsible for providing
a common set of WorkItemHandlers and EventListeners.
|
DefaultRuntimeEnvironment |
Default implementation of the RuntimeEnvironment that aims at providing all
common settings with a minimum need for configuration.
|
DefaultRuntimeManagerLock |
|
DefaultRuntimeManagerLockFactory |
|
DefaultSignalManager |
|
DefaultSignalManager.SignalAction |
|
DefaultSignalManager.SignalProcessInstanceAction |
|
DefaultSignalManagerFactory |
|
DefaultSingletonProcessInstanceManagerFactory |
|
DefaultTaskEventListener |
|
DefaultUserGroupInfoProducer |
|
DefaultUserInfo |
|
Definitions |
|
DefinitionService |
Provides details from definition point of view which is extracted from BPMN2 definitions.
|
DefinitionServiceEJBImpl |
|
DefinitionServiceEJBLocal |
|
DefinitionServiceEJBRemote |
|
DefinitionsHandler |
|
DelayedPrintOutCommand |
Simple command to log the contextual data after given (10 sec by default) delay and return empty results.
|
DelegateSchedulerServiceInterceptor |
Simple delegate that is default implementation used if none other has been given.
|
DelegateTaskCommand |
Operation.Delegate
: [ new OperationCommand().{
status = [ Status.Ready ],
allowed = [ Allowed.PotentialOwner, Allowed.BusinessAdministrator ],
addTargetUserToPotentialOwners = true,
newStatus = Status.Ready,
exec = Operation.Claim
},
new OperationCommand().{
status = [ Status.Reserved, Status.InProgress ],
allowed = [ Allowed.Owner, Allowed.BusinessAdministrator ],
addTargetUserToPotentialOwners = true,
newStatus = Status.Ready,
exec = Operation.Claim
} ],
|
DelegationImpl |
|
DelegationImpl_ |
|
DeleteAttachmentCommand |
|
DeleteAuditEventsCommand |
|
DeleteBAMTaskSummariesCommand |
|
DeleteCommentCommand |
|
DeleteContentCommand |
|
DeleteFaultCommand |
|
DeleteOutputCommand |
|
Deploy |
|
DeployedAsset |
|
DeployedUnit |
|
DeployedUnitImpl |
|
DeploymentDescriptorManagerUtil |
|
DeploymentDescriptorMerger |
|
DeploymentEvent |
Event containing information about a deployment.
|
DeploymentEventListener |
|
DeploymentIdResolver |
Deployment id resolver that allows to find out latest version of given deployment id.
|
DeploymentIdsPreprocessor |
|
DeploymentNotActiveException |
|
DeploymentNotFoundException |
|
DeploymentRolesManager |
|
DeploymentRolesManagerCDIImpl |
|
DeploymentRolesManagerEJBImpl |
|
DeploymentsAwarePostgreSQLDelegate |
|
DeploymentsAwareStdJDBCDelegate |
|
DeploymentService |
Deploys DeploymentUnit s into the runtime engine by building
RuntimeManager instance for the deployment unit.
|
DeploymentServiceCDIImpl |
|
DeploymentServiceEJBImpl |
|
DeploymentServiceEJBLocal |
|
DeploymentServiceEJBRemote |
|
DeploymentStore |
|
DeploymentStoreEntry |
|
DeploymentSynchronizer |
|
DeploymentSynchronizerCDIImpl |
|
DeploymentSynchronizerCDInvoker |
|
DeploymentSynchronizerEJBImpl |
|
DeploymentSyncInvoker |
|
DeploymentSyncManager |
|
DeploymentUnit |
|
DeployTaskDefCommand |
|
DestroySessionTransactionSynchronization |
Transaction synchronization implementation that destroys the KieSession instance
in the beforeCompletion call executed for the current transaction.
|
DialectConverter |
|
DisabledFollowOnLockOracle10gDialect |
Customized Oracle10gDialect to avoid race conditions when using select for update with paging.
|
DisposableRuntimeEngine |
|
DisposeSessionTransactionSynchronization |
Transaction synchronization that disposes of the KieSession instance on transaction completion during
the afterCompletion phase.
|
DocumentationHandler |
|
DoNothingWorkItemHandler |
|
DRFAssemblerService |
|
DRFWeaverService |
|
DroolsAction |
|
DroolsConsequenceAction |
|
DummyEventListener |
|
DynamicNode |
|
DynamicNodeFactory<T extends org.kie.api.fluent.NodeContainerBuilder<T,?>> |
|
DynamicNodeHandler |
|
DynamicNodeInstance |
|
DynamicUtils |
|
EJBContextIdentityProvider |
|
EjbObjectModelResolver |
|
Email |
|
EmailImpl |
|
EmailImpl_ |
|
EmailNotificationHeaderImpl |
|
EmailNotificationHeaderImpl_ |
|
EmailNotificationImpl |
|
EmailNotificationImpl_ |
|
EmailNotificationListener |
|
EmailNotificationPublisher |
|
EmailSessionProducer |
|
EmailWorkItemHandler |
WorkItemHandler for sending email.
|
EndEventHandler |
|
EndNode |
Default implementation of an end node.
|
EndNodeFactory<T extends org.kie.api.fluent.NodeContainerBuilder<T,?>> |
|
EndNodeHandler |
|
EndNodeHandler |
|
EndNodeInstance |
Runtime counterpart of an end node.
|
EntityManagerFactoryManager |
|
EnumDataType |
Representation of an Enum datatype.
|
EnvironmentAwareProcessInstanceContext |
|
Error |
|
ErrorHandler |
|
ErrorInfo |
|
ErrorInfo_ |
|
ErrorInfoDeleteBuilderImpl |
|
ErrorInfoQueryBuilderImpl |
|
EscalateToAdminSLAViolationListener |
|
Escalation |
|
EscalationHandler |
|
EscalationImpl |
|
EscalationImpl_ |
|
EvaluationExample |
|
EvaluationExample2 |
This is a sample file to launch a process.
|
EventBasedGatewayHandler |
|
EventBasedNodeBuilder |
|
EventBasedNodeInstanceInterface |
|
EventFilter |
|
EventFilterHandler |
|
EventListenerProducer<T> |
Deprecated.
|
EventNode |
|
EventNodeBuilder |
|
EventNodeFactory<T extends org.kie.api.fluent.NodeContainerBuilder<T,?>> |
|
EventNodeHandler |
|
EventNodeHandler |
|
EventNodeInstance |
Runtime counterpart of an event node.
|
EventNodeInstanceInterface |
|
EventNodeInterface |
|
EventSubProcessNode |
|
EventSubProcessNodeInstance |
|
EventTransformer |
|
EventTransformerImpl |
|
EventTrigger |
|
EventTypeFilter |
|
ExceptionHandler |
|
ExceptionHandlerHandler |
|
ExceptionHandlingErrorExample |
|
ExceptionHandlingSignalExample |
|
ExceptionScope |
|
ExceptionScopeInstance |
|
ExceptionService |
|
ExcludeNonCDIImplExtension |
|
ExclusiveGatewayHandler |
|
ExclusiveGroup |
|
ExclusiveGroupInstance |
|
ExecuteDeadlinesCommand |
|
ExecuteReminderCommand |
|
ExecuteSQLQueryCommand |
|
ExecuteTaskRulesCommand |
|
ExecutionErrorCleanupCommand |
Execution error clean up command that aims at doing house keeping of execution error table used in jBPM:
Command by default is auto configured to run once a day from the time it was initially scheduled though it can be reconfigured
in terms of frequency when it is executed and if it shall run multiple times at all.
Following is a complete list of accepted parameters:
DateFormat - date format for further date related params - if not given yyyy-MM-dd is used (pattern of SimpleDateFormat class)
EmfName - name of entity manager factory to be used for queries (valid persistence unit name)
SingleRun - indicates if execution should be single run only (true|false)
NextRun - provides next execution time (valid time expression e.g. 1d, 5h, etc)
OlderThan - indicates what errors should be deleted - older than given date
OlderThanPeriod - indicated what errors should be deleted older than given time expression (valid time expression e.g. 1d, 5h, etc)
ForProcess - indicates errors to be deleted only for given process definition
ForProcessInstance - indicates errors to be deleted only for given process instance
ForDeployment - indicates errors to be deleted that are from given deployment id
|
ExecutionErrorHandlerImpl |
|
ExecutionErrorHandlerInterceptor |
|
ExecutionErrorInfo |
|
ExecutionErrorInfoDeleteBuilderImpl |
|
ExecutionErrorManagerImpl |
|
ExecutionErrorNotFoundException |
|
ExecutionErrorQueryMapper |
Dedicated mapper that transforms DataSet to ExecutionError.
|
ExecutorEventSupport |
Interface for ExecutorEventSupportImpl and ExecutorEventSupportEJBImpl so they both can be referenced by
one type because the ExecutorEventSupportEJBImpl is no longer a subtype of ExecutorEventSupportImpl since it would
violate EJB public methods specification like no final and synchronized public methods.
|
ExecutorEventSupportImpl |
|
ExecutorImpl |
Default implementation of the Executor that is baced by
ScheduledExecutorService for background task execution.
|
ExecutorJPAAuditService |
|
ExecutorNotStartedException |
|
ExecutorQueryCriteriaUtil |
|
ExecutorQueryServiceImpl |
Default implementation of ExecutorQueryService that is backed with JPA
IMPORTANT: please keep all classes from package org.jbpm.shared.services.impl as FQCN
inside method body to avoid exception logged by CDI when used with in memory mode
|
ExecutorRequestAdminServiceImpl |
Default implementation of ExecutorAdminService backed with JPA
IMPORTANT: please keep all classes from package org.jbpm.shared.services.impl as FQCN
inside method body to avoid exception logged by CDI when used with in memory mode
|
ExecutorServiceEJB |
|
ExecutorServiceFactory |
Creates singleton instance of ExecutorService that shall be used outside of CDI
environment.
|
ExecutorServiceImpl |
Entry point of the executor component.
|
ExitTaskCommand |
Operation.Exit
: [ new OperationCommand().{
status = [ Status.Created, Status.Ready, Status.Reserved, Status.InProgress, Status.Suspended ],
allowed = [ Allowed.BusinessAdministrator ],
newStatus = Status.Exited
} ]
|
Expression |
|
ExtendedNodeBuilder |
|
ExtendedNodeImpl |
|
ExtendedNodeInstanceImpl |
|
ExtendedRuleFlowLogEvent |
|
ExternalTaskEventListener |
|
ExtraColumnFilter |
|
FailTaskCommand |
Operation.Fail : [ new OperationCommand().{ status = [ Status.InProgress ],
allowed = [ Allowed.Owner ], newStatus = Status.Failed } ],
|
FaultDataImpl |
|
FaultNode |
Default implementation of a fault node.
|
FaultNodeFactory<T extends org.kie.api.fluent.NodeContainerBuilder<T,?>> |
|
FaultNodeHandler |
|
FaultNodeHandler |
|
FaultNodeInstance |
Runtime counterpart of a fault node.
|
FeelErrorEvaluatorListener |
|
FeelProcessDialect |
|
FeelReturnValueEvaluator |
|
FeelReturnValueEvaluatorBuilder |
|
FeelReturnValueEvaluatorException |
|
FindActiveProcessInstancesCommand |
|
FindNodeInstancesCommand |
|
FindObjectCommand<T> |
|
FindProcessInstanceCommand |
|
FindProcessInstancesCommand |
|
FindSubProcessInstancesCommand |
|
FindVariableInstancesByNameCommand |
|
FindVariableInstancesCommand |
|
FloatDataType |
Representation of a float datatype.
|
ForEachNode |
A for each node.
|
ForEachNode.ForEachJoinNode |
|
ForEachNode.ForEachSplitNode |
|
ForEachNodeFactory<T extends org.kie.api.fluent.NodeContainerBuilder<T,?>> |
|
ForEachNodeHandler |
|
ForEachNodeHandler |
|
ForEachNodeInstance |
Runtime counterpart of a for each node.
|
FormManagerService |
|
FormManagerServiceCDIImpl |
|
FormManagerServiceEJBImpl |
|
FormManagerServiceImpl |
|
FormProvider |
|
FormProviderService |
|
FormProviderServiceImpl |
|
FormProvidesServiceCDIImpl |
|
ForwardTaskCommand |
Operation.Forward
: [ new OperationCommand().{
status = [ Status.Ready ],
allowed = [ Allowed.PotentialOwner, Allowed.BusinessAdministrator ],
userIsExplicitPotentialOwner = true,
addTargetUserToPotentialOwners = true,
removeUserFromPotentialOwners = true,
setNewOwnerToNull = true,
newStatus = Status.Ready
},
new OperationCommand().{
status = [ Status.Reserved, Status.InProgress ],
allowed = [ Allowed.Owner, Allowed.BusinessAdministrator ],
userIsExplicitPotentialOwner = true,
addTargetUserToPotentialOwners = true,
removeUserFromPotentialOwners = true,
setNewOwnerToNull = true,
newStatus = Status.Ready
}],
|
FreemakerFormProvider |
|
FreeRuntimeManagerLockStrategy |
|
FunctionCommand |
|
FunctionImportHandler |
|
GetActiveTasksCommand |
|
GetAllAdminAuditTasksByUserCommand |
|
GetAllAttachmentsCommand |
|
GetAllAuditTasksByStatusCommand |
|
GetAllCommentsCommand |
|
GetAllContentCommand |
|
GetAllGroupAuditTasksByUserCommand |
|
GetAllHistoryAuditTasksByUserCommand |
|
GetAllHistoryAuditTasksCommand |
|
GetAllTaskDefinitionsCommand |
|
GetArchivedTasksCommand |
|
GetAttachmentCommand |
|
GetAuditEventsByProcessInstanceIdCommand |
|
GetAuditEventsCommand |
|
GetBAMTaskSummariesCommand |
|
GetCommentCommand |
|
GetCompletedTasksByUserCommand |
|
GetCompletedTasksCommand |
|
GetContentByIdCommand |
|
GetContentByIdForUserCommand |
|
GetContentMapForUserCommand |
|
GetCurrentTxTasksCommand |
|
GetGroupCommand |
|
GetGroupsCommand |
|
GetOrgEntityCommand |
|
GetPendingSubTasksCommand |
|
GetPendingTasksByUserCommand |
|
GetPotentialOwnersForTaskCommand |
|
GetProcessInstanceVariableCommand |
|
GetSubTasksCommand |
|
GetTaskAssignedAsBusinessAdminCommand |
|
GetTaskAssignedAsExcludedOwnerCommand |
|
GetTaskAssignedAsInitiatorCommand |
|
GetTaskAssignedAsPotentialOwnerByExpDateCommand |
|
GetTaskAssignedAsPotentialOwnerCommand |
|
GetTaskAssignedAsPotentialOwnerPagingCommand |
|
GetTaskAssignedAsRecipientCommand |
|
GetTaskAssignedAsStakeholderCommand |
|
GetTaskAssignedByGroupsCommand |
|
GetTaskByWorkItemIdCommand |
|
GetTaskCommand |
|
GetTaskContentCommand |
|
GetTaskDefinitionCommand |
|
GetTaskInputVariablesCommand |
|
GetTaskOutputVariablesCommand |
|
GetTaskOwnedByExpDateBeforeDateCommand |
|
GetTaskOwnedByExpDateCommand |
|
GetTaskPropertyCommand |
|
GetTasksByProcessInstanceIdCommand |
|
GetTasksByStatusByProcessInstanceIdCommand |
|
GetTasksByVariableNameAndValueCommand |
|
GetTasksByVariableNameCommand |
|
GetTasksForProcessCommand |
|
GetTasksOwnedCommand |
|
GetUserCommand |
|
GetUserInfoCommand |
|
GetUsersCommand |
|
GetUserTaskCommand |
|
GlobalHandler |
|
GlobalHandler |
|
GlobalJPATimerJobFactoryManager |
|
GlobalJpaTimerJobInstance |
Extension to the regular JpaTimerJobInstance that makes use of
GlobalTimerService to allow auto reactivate session.
|
GlobalProducer |
Deprecated.
|
GlobalSchedulerService |
Implementations of these interface are responsible for scheduled jobs in global manner,
meaning not knowledge session scoped but global accessible for all the sessions that will
be configured to use this GlobalSchedulerService
|
GlobalTimerService |
|
GlobalTimerService.DisposableCommandService |
|
GlobalTimerService.GlobalJobHandle |
|
GroupColumnFilter |
|
GroupImpl |
|
GroupImpl_ |
|
HandlerUtil |
|
HelloService |
|
HelloService |
|
HumanTaskConfigurator |
Task service configurator that provides fluent API approach to building TaskService
instances.
|
HumanTaskDialog |
|
HumanTaskDialog.Result |
|
HumanTaskExample |
|
HumanTaskHandler |
|
HumanTaskHandlerHelper |
|
HumanTaskNode |
|
HumanTaskNodeFactory<T extends org.kie.api.fluent.NodeContainerBuilder<T,?>> |
|
HumanTaskNodeHandler |
|
HumanTaskNodeInstance |
|
HumanTaskServiceFactory |
Factory that allows to produce TaskService instances via fluent API
provided by HumanTaskConfigurator
|
HumanTaskServiceProducer |
CDI producer for TaskService instances.
|
HumanTaskSpecification |
Defines human task specification to create new user task in ad hoc (dynamic) process instance
Expected parameters are:
NodeName - is a mandatory name of the task - accept variable expressions
TaskName - is a optional look up name of the task's form - accept variable expressions
ActorId - is an optional list of actors to be assigned - accept variable expressions
GroupId - is an optional list of groups to be assigned - accept variable expressions
Comment - is an optional comment/description of the task - accept variable expressions
|
I18NTextImpl |
|
I18NTextImpl_ |
|
IdentityProviderAwareProcessListener |
|
IdentityProviderCDIWrapper |
Wrapper to allow to use backup providers in case of given context is not available
|
IdentityRolesSecurityManager |
|
ImportHandler |
|
ImportHandler |
|
InclusiveGatewayHandler |
|
IncorrectParametersException |
Exception that is thrown when the parameters to a query are incorrect, with regard to either the number or type.
|
InitDeadlinesCommand |
|
InjectableRegisterableItemsFactory |
Implementation of RegisterableItemsFactory dedicated to CDI environments that allows us to get
injections of following components:
ExternalTaskEventListener - required bean
WorkItemHandlerProducer - optional bean (0 or more)
EventListenerProducer> - optional bean (0 or more)
EventListenerProducer> - optional bean (0 or more)
EventListenerProducer> - optional bean (0 or more)
RuntimeFinder - optional required only when single CDI bean is going to manage many
RuntimeManager instances
In addition to that, AbstractAuditLogger can be set after the bean has been injected if the default
is not sufficient.
|
InMemoryCaseIdGenerator |
Simple in memory (usually for test or demo purpose) case id generator.
|
InMemoryFormProvider |
|
InMemoryFormProviderCDI |
|
InMemoryMapper |
An in-memory implementation of the context to KieSession identifier mapping.
|
InMemorySessionFactory |
SessionFactory implementation backed with an in-memory store of used sessions.
|
InMessageRefHandler |
|
InPortHandler |
|
InstanceDataTypeFactory |
A data type factory that always returns the same instance of a given class.
|
IntegerDataType |
Representation of an integer datatype.
|
Interface |
|
InterfaceHandler |
|
IntermediateCatchEventHandler |
|
IntermediateLink |
|
IntermediateThrowEventHandler |
|
InternalMapper |
|
InternalProcessRuntime |
|
InterruptibleRuntimeManagerLockStrategy |
|
ItemDefinition |
|
ItemDefinitionHandler |
|
JAASUserGroupCallbackImpl |
JAAS based implementation of user group callback dedicated when using LocalTaskService
in container such as JBoss AS.
|
JAASUserGroupInfoProducer |
|
JavaAction |
|
JavaActionBuilder |
|
JavaDroolsAction |
|
JavaProcessClassBuilder |
|
JavaProcessDialect |
|
JavaReturnValueEvaluatorBuilder |
|
JavaScriptAction |
|
JavaScriptActionBuilder |
|
JavaScriptingDataTransformer |
Implementation of DataTransformer that is based on standard
Java scripting capabilities (javax.script).
|
JavaScriptProcessDialect |
|
JavaScriptReturnValueEvaluator |
|
JavaScriptReturnValueEvaluatorBuilder |
|
JaxbAttachment |
|
JaxbComment |
|
JaxbContent |
|
JaxbContentData |
|
JaxbDeadlines |
This is a "dummy" object which does *NOT* contain any information
|
JaxbFaultData |
|
JaxbI18NText |
|
JaxbOrganizationalEntity |
|
JaxbOrganizationalEntity.Type |
|
JaxbPeopleAssignments |
|
JaxbTask |
|
JaxbTaskData |
|
JBossEJBClientServiceFactory |
JBoss specific (AS 7 / EAP6 / WildFly 8) implementation of ClientServiceFactory
that is responsible for remote EJB look up.
|
JBossUserGroupCallbackImpl |
|
JbpmJUnitBaseTestCase |
Base test case class that shall be used for jBPM related tests.
|
JbpmJUnitBaseTestCase.Strategy |
Currently supported RuntimeEngine strategies
|
JbpmJUnitBaseTestCase.TestWorkItemHandler |
|
JbpmJUnitTestCase |
Deprecated. |
JbpmJUnitTestCase.TestWorkItemHandler |
|
JBPMMessages |
|
JBPMMessages.IterationLevel |
Protobuf type org.jbpm.marshalling.IterationLevel
|
JBPMMessages.IterationLevel.Builder |
Protobuf type org.jbpm.marshalling.IterationLevel
|
JBPMMessages.IterationLevelOrBuilder |
|
JBPMMessages.ProcessInstance |
Protobuf type org.jbpm.marshalling.ProcessInstance
|
JBPMMessages.ProcessInstance.Builder |
Protobuf type org.jbpm.marshalling.ProcessInstance
|
JBPMMessages.ProcessInstance.ExclusiveGroupInstance |
Protobuf type org.jbpm.marshalling.ProcessInstance.ExclusiveGroupInstance
|
JBPMMessages.ProcessInstance.ExclusiveGroupInstance.Builder |
Protobuf type org.jbpm.marshalling.ProcessInstance.ExclusiveGroupInstance
|
JBPMMessages.ProcessInstance.ExclusiveGroupInstanceOrBuilder |
|
JBPMMessages.ProcessInstance.NodeInstance |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstance
|
JBPMMessages.ProcessInstance.NodeInstance.Builder |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstance
|
JBPMMessages.ProcessInstance.NodeInstanceContent |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent
|
JBPMMessages.ProcessInstance.NodeInstanceContent.AsyncEventNode |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.AsyncEventNode
|
JBPMMessages.ProcessInstance.NodeInstanceContent.AsyncEventNode.Builder |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.AsyncEventNode
|
JBPMMessages.ProcessInstance.NodeInstanceContent.AsyncEventNodeOrBuilder |
|
JBPMMessages.ProcessInstance.NodeInstanceContent.Builder |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent
|
JBPMMessages.ProcessInstance.NodeInstanceContent.CompositeContextNode |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.CompositeContextNode
|
JBPMMessages.ProcessInstance.NodeInstanceContent.CompositeContextNode.Builder |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.CompositeContextNode
|
JBPMMessages.ProcessInstance.NodeInstanceContent.CompositeContextNodeOrBuilder |
|
JBPMMessages.ProcessInstance.NodeInstanceContent.EventNode |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.EventNode
|
JBPMMessages.ProcessInstance.NodeInstanceContent.EventNode.Builder |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.EventNode
|
JBPMMessages.ProcessInstance.NodeInstanceContent.EventNodeOrBuilder |
|
JBPMMessages.ProcessInstance.NodeInstanceContent.ForEachNode |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.ForEachNode
|
JBPMMessages.ProcessInstance.NodeInstanceContent.ForEachNode.Builder |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.ForEachNode
|
JBPMMessages.ProcessInstance.NodeInstanceContent.ForEachNodeOrBuilder |
|
JBPMMessages.ProcessInstance.NodeInstanceContent.HumanTaskNode |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.HumanTaskNode
|
JBPMMessages.ProcessInstance.NodeInstanceContent.HumanTaskNode.Builder |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.HumanTaskNode
|
JBPMMessages.ProcessInstance.NodeInstanceContent.HumanTaskNodeOrBuilder |
|
JBPMMessages.ProcessInstance.NodeInstanceContent.JoinNode |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.JoinNode
|
JBPMMessages.ProcessInstance.NodeInstanceContent.JoinNode.Builder |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.JoinNode
|
JBPMMessages.ProcessInstance.NodeInstanceContent.JoinNode.JoinTrigger |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.JoinNode.JoinTrigger
|
JBPMMessages.ProcessInstance.NodeInstanceContent.JoinNode.JoinTrigger.Builder |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.JoinNode.JoinTrigger
|
JBPMMessages.ProcessInstance.NodeInstanceContent.JoinNode.JoinTriggerOrBuilder |
|
JBPMMessages.ProcessInstance.NodeInstanceContent.JoinNodeOrBuilder |
|
JBPMMessages.ProcessInstance.NodeInstanceContent.MilestoneNode |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.MilestoneNode
|
JBPMMessages.ProcessInstance.NodeInstanceContent.MilestoneNode.Builder |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.MilestoneNode
|
JBPMMessages.ProcessInstance.NodeInstanceContent.MilestoneNodeOrBuilder |
|
JBPMMessages.ProcessInstance.NodeInstanceContent.RuleSetNode |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.RuleSetNode
|
JBPMMessages.ProcessInstance.NodeInstanceContent.RuleSetNode.Builder |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.RuleSetNode
|
JBPMMessages.ProcessInstance.NodeInstanceContent.RuleSetNode.TextMapEntry |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.RuleSetNode.TextMapEntry
|
JBPMMessages.ProcessInstance.NodeInstanceContent.RuleSetNode.TextMapEntry.Builder |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.RuleSetNode.TextMapEntry
|
JBPMMessages.ProcessInstance.NodeInstanceContent.RuleSetNode.TextMapEntryOrBuilder |
|
JBPMMessages.ProcessInstance.NodeInstanceContent.RuleSetNodeOrBuilder |
|
JBPMMessages.ProcessInstance.NodeInstanceContent.StateNode |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.StateNode
|
JBPMMessages.ProcessInstance.NodeInstanceContent.StateNode.Builder |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.StateNode
|
JBPMMessages.ProcessInstance.NodeInstanceContent.StateNodeOrBuilder |
|
JBPMMessages.ProcessInstance.NodeInstanceContent.SubProcessNode |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.SubProcessNode
|
JBPMMessages.ProcessInstance.NodeInstanceContent.SubProcessNode.Builder |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.SubProcessNode
|
JBPMMessages.ProcessInstance.NodeInstanceContent.SubProcessNodeOrBuilder |
|
JBPMMessages.ProcessInstance.NodeInstanceContent.TimerNode |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.TimerNode
|
JBPMMessages.ProcessInstance.NodeInstanceContent.TimerNode.Builder |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.TimerNode
|
JBPMMessages.ProcessInstance.NodeInstanceContent.TimerNodeOrBuilder |
|
JBPMMessages.ProcessInstance.NodeInstanceContent.WorkItemNode |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.WorkItemNode
|
JBPMMessages.ProcessInstance.NodeInstanceContent.WorkItemNode.Builder |
Protobuf type org.jbpm.marshalling.ProcessInstance.NodeInstanceContent.WorkItemNode
|
JBPMMessages.ProcessInstance.NodeInstanceContent.WorkItemNodeOrBuilder |
|
JBPMMessages.ProcessInstance.NodeInstanceContentOrBuilder |
|
JBPMMessages.ProcessInstance.NodeInstanceOrBuilder |
|
JBPMMessages.ProcessInstance.NodeInstanceType |
Protobuf enum org.jbpm.marshalling.ProcessInstance.NodeInstanceType
|
JBPMMessages.ProcessInstance.SwimlaneContextInstance |
Protobuf type org.jbpm.marshalling.ProcessInstance.SwimlaneContextInstance
|
JBPMMessages.ProcessInstance.SwimlaneContextInstance.Builder |
Protobuf type org.jbpm.marshalling.ProcessInstance.SwimlaneContextInstance
|
JBPMMessages.ProcessInstance.SwimlaneContextInstanceOrBuilder |
|
JBPMMessages.ProcessInstanceOrBuilder |
|
JBPMMessages.ProcessTimer |
Protobuf type org.jbpm.marshalling.ProcessTimer
|
JBPMMessages.ProcessTimer.Builder |
Protobuf type org.jbpm.marshalling.ProcessTimer
|
JBPMMessages.ProcessTimer.TimerInstance |
Protobuf type org.jbpm.marshalling.ProcessTimer.TimerInstance
|
JBPMMessages.ProcessTimer.TimerInstance.Builder |
Protobuf type org.jbpm.marshalling.ProcessTimer.TimerInstance
|
JBPMMessages.ProcessTimer.TimerInstanceOrBuilder |
|
JBPMMessages.ProcessTimerOrBuilder |
|
JBPMMessages.Variable |
Protobuf type org.jbpm.marshalling.Variable
|
JBPMMessages.Variable.Builder |
Protobuf type org.jbpm.marshalling.Variable
|
JBPMMessages.VariableContainer |
Protobuf type org.jbpm.marshalling.VariableContainer
|
JBPMMessages.VariableContainer.Builder |
Protobuf type org.jbpm.marshalling.VariableContainer
|
JBPMMessages.VariableContainerOrBuilder |
|
JBPMMessages.VariableOrBuilder |
|
JBPMMessages.WorkItem |
Protobuf type org.jbpm.marshalling.WorkItem
|
JBPMMessages.WorkItem.Builder |
Protobuf type org.jbpm.marshalling.WorkItem
|
JBPMMessages.WorkItemOrBuilder |
|
JbpmMetadataContributor |
|
JmsAvailableJobsExecutor |
|
JMSSendTaskWorkItemHandler |
|
JMSSignalReceiver |
|
JobAutoAckErrorCommand |
Command that will auto acknowledge async jobs errors based on their status:
- if job that previously failed is completed it will be eligible for auto ack
- if job that previously failed is cancelled it will be eligible for auto ack
- if job that previously failed is rescheduled it will be eligible for auto ack
Following parameters are supported by this command:
EmfName - name of entity manager factory to be used for queries (valid persistence unit name)
SingleRun - indicates if execution should be single run only (true|false)
NextRun - provides next execution time (valid time expression e.g. 1d, 5h, etc)
|
JobExecutionErrorCommand |
Simple command to throw runtime exception
Just for testing purpose.
|
JobExecutionErrorFilter |
|
JobNameHelper |
|
Join |
Default implementation of a join.
|
JoinFactory<T extends org.kie.api.fluent.NodeContainerBuilder<T,?>> |
|
JoinHandler |
|
JoinInstance |
Runtime counterpart of a join node.
|
JoinNodeHandler |
|
JPAAuditLogService |
|
JPACorrelationKeyFactory |
|
JPAExecutorStoreService |
IMPORTANT: please keep all classes from package org.jbpm.shared.services.impl as FQCN
inside method body to avoid exception logged by CDI when used with in memory mode
|
JPAMapper |
Database based mapper implementation backed by JPA to store
the context to KieSession id mapping.
|
JpaPersistenceContext |
|
JPAProcessInstanceManager |
|
JPAProcessInstanceManagerFactory |
|
JpaProcessPersistenceContext |
|
JpaProcessPersistenceContextManager |
|
JPAService |
The idea here is that we have a entity manager factory (similar to a session
factory) that we repeatedly use to generate an entity manager (which is a
persistence context) for the specific service command.
|
JPASessionFactory |
SessionFactory implementation that is backed by a database for storing KieSession data.
|
JpaSettings |
Utility class which gives access to some JPA's settings like, for instance, the JDI datasource name.
|
JPASignalManager |
|
JPASignalManagerFactory |
|
JPATaskLifeCycleEventListener |
|
JPATaskModelFactory |
|
JPATaskPersistenceContext |
|
JPATaskPersistenceContextManager |
|
JPAWorkingMemoryDbLogger |
Enables history log via JPA.
|
JsonWorkItemParser |
|
KieServiceConfigurator |
Configurator for kie service.
|
KieSessionCommandScopedStrategy |
This strategy is used by instances that are
used inside the KieSession
use the same (command-scoped) EntityManager instance as the KieSession
|
Kjar |
|
KModuleDeploymentService |
|
KModuleDeploymentUnit |
|
KModuleRegisterableItemsFactory |
This implementation extends the DefaultRegisterableItemsFactory
and relies on definitions of work item handlers and
listeners that come from kmodule.xml from kjar.
|
KnowledgeSessionCleanup |
|
Lane |
|
LaneHandler |
|
LanguageImpl |
|
LanguageImpl_ |
|
LdapSearcher |
Utility class providing LDAP search capabilities.
|
LdapSearcher.SearchScope |
|
LDAPUserGroupCallbackImpl |
LDAP integration for Task Service to collect user and role/group information.
|
LDAPUserGroupInfoProducer |
|
LDAPUserInfoImpl |
|
LegacyRuntimeManagerLockStrategy |
|
LifeCycleManager |
|
ListDataType |
Representation of a list datatype.
|
ListenerSupport |
Provides means to add deployment event listeners to deployment service.
|
ListNodesCommand |
|
ListTaskNotificationsCommand |
|
ListTaskReassignmentsCommand |
|
ListTimersCommand |
|
LoadAndScheduleRequestsTask |
|
LoadBalanceAssignmentStrategy |
Assignment strategy that uses a plug-able approach for calculating
the load that potential task owners have.
|
LoadCalculator |
|
LocalHTWorkItemHandler |
|
LocalHTWorkItemHandlerUtil |
|
LocalTaskServiceFactory |
A regular TaskServiceFactory implementation that is intended to be used in non CDI environments.
|
LogCleanupCommand |
Log clean up command that aims at doing house keeping of audit/log tables used in jBPM:
process related audit logs (process instance, node instance, variables)
task related audit logs (audit task, task events)
executor related data (requests and errors)
Command by default is auto configured to run once a day from the time it was initially scheduled though it can be reconfigured
in terms of frequency when it is executed and if it shall run multiple times at all.
Following is a complete list of accepted parameters:
SkipProcessLog - indicates if clean up of process logs should be omitted (true|false)
SkipTaskLog - indicates if clean up of task logs should be omitted (true|false)
SkipExecutorLog - indicates if clean up of executor logs should be omitted (true|false)
DateFormat - date format for further date related params - if not given yyyy-MM-dd is used (pattern of SimpleDateFormat class)
EmfName - name of entity manager factory to be used for queries (valid persistence unit name)
SingleRun - indicates if execution should be single run only (true|false)
RepeatMode - defines how the next execution time is calculated
FIXED - Scheduled time + NextRun parameter value
INTERVAL (or not present) - End of execution + NextRun parameter value (default)
NextRun - provides next execution time (valid time expression e.g. 1d, 5h, etc)
OlderThan - indicates what logs should be deleted - older than given date
OlderThanPeriod - indicated what logs should be deleted older than given time expression (valid time expression e.g. 1d, 5h, etc)
ForProcess - indicates logs to be deleted only for given process definition
ForDeployment - indicates logs to be deleted that are from given deployment id
RecordsPerTransaction - indicates number of records to be included in each DB transaction (default is 0 which means do the delete in one single transaction)
|
LoggingPrintStream |
|
LoggingTaskHandlerDecorator |
This class is a WorkItemHandler implementation that is meant to wrap
other WorkItemHandler implementations.
|
LoggingTaskHandlerDecorator.InputParameter |
|
LoopingExample |
|
ManagedAuditEventBuilderImpl |
|
ManualProcessTransactionManager |
|
ManualTaskHandler |
|
MapBasedProcessPersistenceContext |
|
Mappable |
|
MappingHandler |
|
MapProcessPersistenceContextManager |
|
MapResolverFactory |
|
MarshalVariablesProcessEventListener |
Process event listener to be used with plugable variable strategies to make sure that upon process instance completion
process variables will be persisted in back end store.
|
MergeObjectCommand |
|
Message |
|
Message |
|
Message |
|
MessageDesc |
|
MessageDescImpl |
|
MessageHandler |
|
MetaDataHandler |
|
MetaDataHandler |
|
MetaValueHandler |
|
MigrateProcessInstanceCommand |
|
MigrationEntry |
Represent single entry of the process instance migration.
|
MigrationEntry |
Single migration step information.
|
MigrationEntry.Type |
|
MigrationEntryImpl |
|
MigrationException |
Global migration exception thrown directly upon first failure - fail fast approach.
|
MigrationManager |
MigrationManager is responsible for updating all required components during process instance migration.
|
MigrationReport |
Represents complete (might be unfinished in case of an error)
process instance migration.
|
MigrationReport |
MigrationReport that provides details
about performed steps during process instance migration.
|
MigrationReportImpl |
|
MigrationSpec |
|
MilestoneNode |
Default implementation of a milestone node.
|
MilestoneNodeFactory<T extends org.kie.api.fluent.NodeContainerBuilder<T,?>> |
|
MilestoneNodeHandler |
|
MilestoneNodeInstance |
Runtime counterpart of a milestone node.
|
MilestoneStatus |
Represents possible states of a case milestone
|
MockDataWorkItemHandler |
Simple work item handler that allows to provide output data or supplier
that can provide data based on supplied function.
|
ModifyRoleAssignmentCommand |
Modifies case role assignments
|
MultiConditionalSequenceFlowNodeBuilder |
|
MultipleInstanceExample |
|
MVELAction |
|
MVELActionBuilder |
|
MVELAssignmentAction |
|
MVELAssignmentBuilder |
|
MVELDataTransformer |
MVEL based DataTransformer implementation
|
MVELLifeCycleManager |
|
MVELMessageExpressionEvaluator |
|
MVELObjectModelResolver |
|
MVELProcessDialect |
Please make sure to use the getter methods when referring to the static final fields,
because this class is extended in other modules (jbpm-kie-services).
|
MVELResolverFactory |
|
MVELReturnValueEvaluator |
|
MVELReturnValueEvaluatorBuilder |
|
MvelUserGroupCallbackImpl |
|
MVELUtils |
|
NamedJobContext |
|
NamedQueryMapper<T> |
A delegate mapper that will delay look up of actual mapper to the time its
map method is invoked.
|
NativeQueryStringCommand |
|
NewInstanceDataTypeFactory |
A data type factory that always returns a new instance of a given class.
|
Node |
Represents a node in a RuleFlow.
|
NodeContainer |
|
NodeContainerImpl |
|
NodeDesc |
|
NodeDesc |
|
NodeExtension |
|
NodeFactory<T extends org.kie.api.fluent.NodeBuilder<T,P>,P extends org.kie.api.fluent.NodeContainerBuilder<P,?>> |
|
NodeImpl |
Default implementation of a node.
|
NodeInstance |
Represents a node instance in a RuleFlow.
|
NodeInstance.CancelType |
|
NodeInstanceContainer |
|
NodeInstanceDesc |
|
NodeInstanceDesc |
|
NodeInstanceEvent |
|
NodeInstanceFactory |
|
NodeInstanceFactoryRegistry |
|
NodeInstanceImpl |
Default implementation of a RuleFlow node instance.
|
NodeInstanceLeftEvent |
|
NodeInstanceLog |
|
NodeInstanceLog_ |
|
NodeInstanceLogDeleteBuilderImpl |
|
NodeInstanceNotFoundException |
|
NodeInstanceResolverFactory |
|
NodeInstanceTriggeredEvent |
|
NodeInstLogQueryBuilderImpl |
|
NodeNotFoundException |
|
NominateTaskCommand |
Operation.Skip : [ new OperationCommand().{ status = [ Status.Created ],
allowed = [ Allowed.Initiator, Allowed.BusinessAdministrator ], newStatus =
Status.Obsolete, skipable = true }, new OperationCommand().{ status = [
Status.Ready ], allowed = [ Allowed.PotentialOwner,
Allowed.BusinessAdministrator ], newStatus = Status.Obsolete, skipable = true
}, new OperationCommand().{ status = [ Status.Reserved, Status.InProgress ],
allowed = [ Allowed.Owner, Allowed.BusinessAdministrator ], newStatus =
Status.Obsolete, skipable = true } ],
|
NonAcceptingEventTypeFilter |
|
NoneCaseIdGenerator |
Generator that in general does not generate but rely on given case ids.
|
NonManagedLocalHTWorkItemHandler |
LocalHumanTaskHandler that is intended to be used when RuntimeManager is not used, most likely
in backward compatible cases where simply providing:
KieSession
TaskService
is usual case.
|
NonManagedTaskEventListener |
|
NonTransactionalProcessPersistentSession |
|
NoOpExecutionErrorHandler |
|
NoOpPredictionService |
Implementation of a no-op prediction service
|
NoOpTransactionManager |
|
NotificationImpl |
|
NotificationImpl_ |
|
NotificationListener |
Listener that is called when Task notification is about to be sent.
|
NotificationListenerManager |
Manages broadcasting of notification events to all found listeners
|
NotifyOwnerSLAViolationListener |
|
NotifyParentCaseEventListener |
|
NoTransactionalTimerResourcesCleanupAwareSchedulerServiceInterceptor |
This is for transactional global service so it could remove non-transactional resources
when the tx is rolled back
|
ObjectCloner |
|
ObjectCloner.Config |
|
ObjectDataType |
Representation of an object datatype.
|
OnErrorAction |
Defines possible actions in case an error was encountered.
|
OperationCommand |
|
OperationHandler |
|
OrganizationalEntityImpl |
|
OrganizationalEntityImpl_ |
|
OutPortHandler |
|
ParallelGatewayHandler |
|
ParameterDefinition |
|
ParameterDefinitionImpl |
|
ParameterHandler |
|
PatternConstants |
|
PeopleAssignmentHelper |
A class responsible for assigning the various ownerships (actors, groups, business
administrators, and task stakeholders) from a WorkItem to a Task .
|
PeopleAssignmentsImpl |
|
PeopleAssignmentsImpl_ |
|
PerCaseRuntimeManager |
A RuntimeManager implementation that is backed by the "Per Case" strategy.
|
PermissionDeniedException |
Exception that is thrown when a User try to perform an Operation on a Task
|
PerProcessInstanceRuntimeManager |
A RuntimeManager implementation that is backed by the "Per Process Instance" strategy.
|
PerRequestRuntimeManager |
A RuntimeManager implementation that is backed by the "Per Request" strategy.
|
PersistableEventListener |
|
PersistDataSetCDIListener |
|
PersistDataSetListener |
|
PersistenceStrategy |
|
PersistenceStrategyType |
|
PersistObjectCommand |
|
Person |
|
Person |
|
Person |
|
PostgreSQLLobTypeContributor |
|
PotentialOwnerBusynessAssignmentStrategy |
Assignment strategy that assigns tasks to least occupied user from potential owners.
|
PotentialOwnerContextConstraint |
|
PotOwnerTasksPreprocessor |
|
PredictionServiceRegistry |
|
PreUndeployOperations |
Utility class to provide default functions to use on DeploymentService#undeploy(DeploymentUnit, Function)
|
PrintOutCommand |
Simple command to log the contextual data and return empty results.
|
PrioritisedRunnable |
|
PrioritisedScheduledFutureTask<V> |
|
PrioritisedScheduledThreadPoolExecutor |
|
Process |
|
Process |
Defines a annotated element that is of type Process and is used with
EventListenerProducer
|
ProcessAssetDesc |
|
ProcessAutoAckErrorCommand |
Command that will auto acknowledge process instance errors
based on the last initial node instance when the error happened.
|
ProcessBuildContext |
|
ProcessBuildData |
|
ProcessBuilderFactoryServiceImpl |
|
ProcessBuilderImpl |
A ProcessBuilder can be used to build processes based on XML files
containing a process definition.
|
ProcessBuildError |
|
ProcessClassBuilder |
|
ProcessDataEventListener |
|
ProcessDataEventListenerProvider |
|
ProcessDefinition |
|
ProcessDefinitionComparator |
Comparator used for sorting of ProcessDefinitions - currently by:
name - gives as name
id - gives as processId
deploymentId - gives as Project
|
ProcessDefinitionNotFoundException |
|
ProcessDesc |
|
ProcessDescriptor |
This is a package level class that is used by different BPMN2 handlers ( in this package) to store information
about a BPMN2 process.
|
ProcessDialect |
|
ProcessDialectRegistry |
|
ProcessErrorHandler |
|
ProcessEvent |
|
ProcessExecutionErrorFilter |
|
ProcessHandler |
|
ProcessHandler |
|
ProcessIdContextConstraint |
|
ProcessImpl |
Default implementation of a Process
|
ProcessIndexerManager |
Represents logic behind mechanism to index task variables.
|
ProcessInstance |
A process instance is the representation of a process during its execution.
|
ProcessInstanceAdminService |
Admin Service - provides runtime modifications capabilities
for active process instances.
|
ProcessInstanceAdminServiceImpl |
|
ProcessInstanceCompletedEvent |
|
ProcessInstanceCustomDesc |
|
ProcessInstanceCustomDesc |
|
ProcessInstanceCustomQueryMapper |
|
ProcessInstanceDesc |
|
ProcessInstanceDesc |
|
ProcessInstanceFactory |
|
ProcessInstanceFactoryRegistry |
|
ProcessInstanceIdContextConstraint |
|
ProcessInstanceImpl |
Default implementation of a process instance.
|
ProcessInstanceInfo |
|
ProcessInstanceLog |
|
ProcessInstanceLog_ |
|
ProcessInstanceLogDeleteBuilderImpl |
|
ProcessInstanceManager |
|
ProcessInstanceManagerFactory |
|
ProcessInstanceMarshaller |
A ProcessInstanceMarshaller must contain all the write/read logic for nodes
of a specific ProcessInstance.
|
ProcessInstanceMigrationService |
Provides migration service for process instances.
|
ProcessInstanceMigrationServiceCDIImpl |
|
ProcessInstanceMigrationServiceEJBImpl |
|
ProcessInstanceMigrationServiceEJBLocal |
|
ProcessInstanceMigrationServiceEJBRemote |
|
ProcessInstanceMigrationServiceImpl |
Default implementation of org.jbpm.services.api.admin.ProcessInstanceMigrationService
that delegates complete migration to org.jbpm.runtime.manager.impl.migration.MigrationManager
|
ProcessInstanceNotFoundException |
|
ProcessInstanceQueryMapper |
Dedicated mapper that transforms DataSet to ProcessInstanceDesc.
|
ProcessInstanceResolverFactory |
|
ProcessInstanceResolverStrategy |
When using this strategy, knowledge session de/marshalling process will make sure that
the processInstance is not serialized as a part of the the session/network.
|
ProcessInstanceStartedEvent |
|
ProcessInstanceWithCustomVarsQueryMapper |
Dedicated mapper to transform data set into list of ProcessInstanceWithVarsDesc
|
ProcessInstanceWithVarsDesc |
|
ProcessInstanceWithVarsDesc |
|
ProcessInstanceWithVarsQueryMapper |
Dedicated mapper to transform data set into list of ProcessInstanceWithVarsDesc
|
ProcessInvokerErrorHandler |
|
ProcessKnowledgeHelperFixer |
|
ProcessMarshallerFactoryServiceImpl |
|
ProcessMarshallerRegistry |
Registry for Process/ProcessMarshaller
|
ProcessNode |
Describes process node taken from process definition.
|
ProcessNodeBuilder |
|
ProcessNodeBuilderRegistry |
|
ProcessNodeImpl |
|
ProcessNodeValidationErrorImpl |
|
ProcessRuntimeFactoryServiceImpl |
|
ProcessRuntimeImpl |
|
ProcessRuntimeImpl.RegisterStartTimerAction |
|
ProcessSemanticModule |
|
ProcessService |
|
ProcessServiceCDIImpl |
|
ProcessServiceEJBImpl |
|
ProcessServiceEJBLocal |
|
ProcessServiceEJBRemote |
|
ProcessServiceImpl |
|
ProcessStorage |
|
ProcessStorageEnvironmentBuilder |
|
ProcessSubTaskCommand |
|
ProcessTest |
This is a sample file to launch a process.
|
ProcessValidationError |
Represents a RuleFlow validation error.
|
ProcessValidationErrorImpl |
|
ProcessValidator |
A validator for validating a RuleFlow process.
|
ProcessValidatorRegistry |
|
ProcInstLogQueryBuilderImpl |
|
PropertyHandler |
|
PropertyUserInfoImpl |
|
ProtobufProcessMarshaller |
|
ProtobufRuleFlowProcessInstanceMarshaller |
Marshaller class for RuleFlowProcessInstances
|
QuartzSchedulerService |
Quartz based GlobalSchedulerService that is configured according
to Quartz rules and allows to store jobs in data base.
|
QuartzSchedulerService.GlobalQuartzJobHandle |
|
QuartzSchedulerService.InmemoryTimerJobInstanceDelegate |
|
QuartzSchedulerService.QuartzJob |
|
QuartzUtils |
|
QueryAlreadyRegisteredException |
|
QueryDefinition |
Definition of a query that can be registered in the query service.
|
QueryDefinition.Target |
|
QueryDefinitionEntity |
|
QueryHelper |
|
QueryLockNameCommand<T> |
|
QueryLockStringCommand<T> |
|
QueryManager |
|
QueryMapperRegistry |
Allow to find mappers by name instead of using their instances
Mappers are discovered by ServiceLoader mechanism - meaning must be defined
in services file:
META-INF/services/org.jbpm.services.api.query.QueryResultMapper
as fully qualified class names that implement org.jbpm.services.api.query.QueryResultMapper
|
QueryNameCommand<T> |
|
QueryNotFoundException |
|
QueryParam |
Basic data carrier to provide filtering capabilities on top of query definition.
|
QueryParam.Builder |
Query Parameter Builder.
|
QueryParamBuilder<T> |
QueryParamBuilder is responsible for building up one or more filter parameters.
|
QueryParamBuilderFactory |
Factory for query param builders that can be constructed based on:
identifier
set of parameters - key value pairs
|
QueryResultMapper<T> |
Maps raw data set into object instances.
|
QueryService |
Advanced queries service that allows to register custom queries
that will be equipped with tailored capabilities of querying data.
|
QueryServiceCDIImpl |
|
QueryServiceEJBImpl |
|
QueryServiceEJBLocal |
|
QueryServiceEJBRemote |
|
QueryServiceImpl |
|
QueryStringCommand<T> |
|
RawListQueryMapper |
Dedicated mapper that transforms DataSet to List of lists where each
nested list represents all values of given row.
|
RawWriterInterceptor |
|
RawXMLStreamWriter |
|
ReassignmentImpl |
|
ReassignmentImpl_ |
|
ReceiveTaskHandler |
|
ReceiveTaskHandler |
|
Recipient |
|
Recipients |
|
ReflectionObjectModelResolver |
Java reflection based ObjectModelResolver that creates class instances
using supplied class loader and definition in the object model structure.
|
RegExRuntimeManagerIdFilter |
Regular expression based filtering for runtime manager identifiers
|
RegisteredTimerServiceDelegate |
Simple delegate for timer service that fetches the real instance of timer service from
TimerServiceRegistry under "default" key.
|
RelativeUpdateTimerCommand |
|
ReleaseTaskCommand |
Operation.Release
: [ new OperationCommand().{
status = [ Status.Reserved, Status.InProgress ],
allowed = [Allowed.Owner, Allowed.BusinessAdministrator ],
setNewOwnerToNull = true,
newStatus = Status.Ready
} ],
|
RemoteMap |
Dedicated Map implementation to simplify remote invocation of service methods that accept custom object input.
|
RemoteObject |
Similar to a RemoteMap acts as a wrapper for object instances to be send over wire.
|
RemoteObjectProcessor |
|
RemoveAllTasksCommand |
|
RemoveDataCaseFileInstanceCommand |
Updates case file with new data
|
RemoveGroupCommand |
|
RemoveObjectCommand |
|
RemovePeopleAssignmentsCommand |
|
RemoveTaskCommand |
|
RemoveTaskDataCommand |
|
RemoveTasksCommand |
|
RemoveUserCommand |
|
ReoccurringPrintOutCommand |
Simple command to log the contextual data and return empty results as reoccurring job.
|
ReopenCaseCommand |
|
Request |
|
RequestInfo |
|
RequestInfo_ |
|
RequestInfoDeleteBuilderImpl |
|
RequestInfoQueryBuilderImpl |
|
RequestScopedBackupIdentityProvider |
This class is a "backup" version of the IdentityProvider, for
situations in which the IdentityProvider CDI proxy is not available.
|
RequestUI |
|
RequeueAware |
|
RequeueRunningJobsCommand |
|
RequiredParameterValidator |
|
RESTServiceException |
Dedicated exception to provide information about failed REST service invocation.
|
RESTWorkItemHandler |
WorkItemHandler that is capable of interacting with REST service.
|
RESTWorkItemHandler.AuthenticationType |
|
ResumeProcessInstanceCommand |
|
ResumeTaskCommand |
Operation.Resume : [ new OperationCommand().{ previousStatus = [ Status.Ready
], allowed = [ Allowed.PotentialOwner, Allowed.BusinessAdministrator ],
setToPreviousStatus = true }, new OperationCommand().{ previousStatus = [
Status.Reserved, Status.InProgress ], allowed = [ Allowed.Owner,
Allowed.BusinessAdministrator ], setToPreviousStatus = true } ],
|
RetriggerNodeInstanceCommand |
|
ReturnValueConstraintEvaluator |
Default implementation of a constraint.
|
ReturnValueEvaluator |
|
ReturnValueEvaluatorBuilder |
|
ReuseContextInstanceFactory |
|
ReuseNodeFactory |
|
RoleCardinalityReachedException |
Thrown when assigning entities (user or group) to role instance where assigned already
entities reached defined cardinality.
|
RoundRobinAssignmentStrategy |
|
RuleAwareProcessEventLister |
Process event listener that is responsible for managing process instance as fact
so rules can reason over it.
|
RuleConstraintEvaluator |
Default implementation of a constraint.
|
RuleContextProvider |
|
RuleContextProviderImpl |
|
RuleFlowMigrator |
Class the migrates drools version 4 .rfm and .rf ruleflow files to version
5 .rf and .rfm ruleflows.
|
RuleFlowNodeContainerFactory<T extends org.kie.api.fluent.NodeContainerBuilder<T,P>,P extends org.kie.api.fluent.NodeContainerBuilder<P,?>> |
|
RuleFlowProcess |
|
RuleFlowProcessFactory |
|
RuleFlowProcessFactoryBuilder |
|
RuleFlowProcessInstance |
|
RuleFlowProcessInstanceFactory |
|
RuleFlowProcessInstanceMarshaller |
Marshaller class for RuleFlowProcessInstances
|
RuleFlowProcessValidator |
Default implementation of a RuleFlow validator.
|
RuleSetNode |
Default implementation of a RuleSet node.
|
RuleSetNodeBuilder |
|
RuleSetNodeFactory<T extends org.kie.api.fluent.NodeContainerBuilder<T,?>> |
|
RuleSetNodeHandler |
|
RuleSetNodeInstance |
Runtime counterpart of a ruleset node.
|
RuntimeDataService |
This service provides an interface to retrieve data about the runtime, including the following:
process instances
process definitions
node instance information
variable information
|
RuntimeDataService.EntryType |
Represents type of node instance log entries.
|
RuntimeDataServiceCDIImpl |
|
RuntimeDataServiceEJBImpl |
|
RuntimeDataServiceEJBLocal |
|
RuntimeDataServiceEJBRemote |
|
RuntimeDataServiceImpl |
|
RuntimeEngineImpl |
An implementation of the RuntimeEngine that additionally implements the Disposable
interface to allow other components to register listeners on it.
|
RuntimeEngineInitlializer |
|
RuntimeEnvironmentBuilder |
A builder implementation that follows the fluent approach to build RuntimeEnvironments .
|
RuntimeManagerFactoryCDIImpl |
|
RuntimeManagerFactoryImpl |
This is the main entry point class for the RuntimeManager module responsible for delivering RuntimeManager
instances based on given RuntimeEnvironment .
|
RuntimeManagerLock |
|
RuntimeManagerLockFactory |
|
RuntimeManagerLockStrategy |
|
RuntimeManagerLockStrategyFactory |
|
RuntimeManagerLockWatcherSingletonService |
|
RuntimeManagerProducer |
Producer method used to build instances of RuntimeManager automatically by CDI container.
|
SchedulerProvider |
Marker interface to indicate that a given component provides a SchedulerService
This is especially important for RuntimeEnvironment implementations that might not provide such capabilities.
|
SchedulerServiceInterceptor |
Interceptor dedicated to GlobalSchedulerService to be able to react and
optionally alter default behavior.
|
ScheduleTaskDeadlineCommand |
|
ScheduleTaskTransactionSynchronization |
|
ScriptTaskExceptionExample |
|
ScriptTaskHandler |
|
Selectable |
|
SelfReleaseRuntimeManagerLock |
|
SelfReleaseRuntimeManagerLockFactory |
|
SendHtml |
|
SendMessageAction |
|
SendSignalAction |
|
SendTaskHandler |
|
SendTaskHandler |
|
SequenceFlow |
|
SequenceFlowHandler |
|
SerializableRuntimeManagerLockStrategy |
|
SerializableUtil |
|
SerializedContent |
Represents individual content that is part of CaseFileInstance that is persisted
by independent marshaller.
|
ServiceFactoryProvider |
|
ServiceRegistry |
Single ServiceRegistry that allows any service to register itself
so other components can easily look them up.
|
ServicesAwareAuditEventBuilder |
|
ServicesProcessDataEventListener |
|
ServicesProcessDataEventListenerProvider |
|
ServiceTaskHandler |
|
ServiceTaskHandler |
|
ServiceTaskHandler |
|
SetTaskPropertyCommand |
|
Signal |
|
SignalDesc |
|
SignalDescBase |
|
SignalDescImpl |
|
SignalHandler |
This class isn't currently used because we don't really check thrown or caught event content
(itemDefiniton references) to see if it matches the definition in the process.
|
SignallingTaskHandlerDecorator |
This class will wrap a WorkItemHandler instance so that an event (signal, error or other) can be sent to the process
instance if and when the wrapped WorkItemHandler instance throws an exception (during a
WorkItemHandler.executeWorkItem(WorkItem, WorkItemManager) or
WorkItemHandler.abortWorkItem(WorkItem, WorkItemManager) method.
|
SignalManager |
|
SignalManagerFactory |
|
SignalNodeInstanceAction |
|
SimpleRegisterableItemsFactory |
The most basic RegisterableItemsFactory implementation that allows us to define listeners and work
item handlers by their class.
|
SimpleRuntimeEnvironment |
The most basic implementation of the RuntimeEnvironment that, at the same time, serves as base
implementation for all extensions.
|
SingletonRuntimeManager |
This RuntimeManager is backed by a "Singleton" strategy, meaning that only one RuntimeEngine instance will
exist for for the given RuntimeManager instance.
|
SkipTaskCommand |
Operation.Skip : [ new OperationCommand().{ status = [ Status.Created ],
allowed = [ Allowed.Initiator, Allowed.BusinessAdministrator ], newStatus =
Status.Obsolete, skipable = true }, new OperationCommand().{ status = [
Status.Ready ], allowed = [ Allowed.PotentialOwner,
Allowed.BusinessAdministrator ], newStatus = Status.Obsolete, skipable = true
}, new OperationCommand().{ status = [ Status.Reserved, Status.InProgress ],
allowed = [ Allowed.Owner, Allowed.BusinessAdministrator ], newStatus =
Status.Obsolete, skipable = true } ],
|
SLATrackingCommand |
SLA Tracking command that aims at looking up for process or node instances with SLA violations:
Command by default is auto configured to run once an hour from the time it was initially scheduled though it can be reconfigured
in terms of frequency when it is executed and if it shall run multiple times at all.
Following is a complete list of accepted parameters:
EmfName - name of entity manager factory to be used for queries (valid persistence unit name)
SingleRun - indicates if execution should be single run only (true|false)
NextRun - provides next execution time (valid time expression e.g. 1d, 5h, etc)
ForDeployment - indicates errors to be deleted that are from given deployment id
|
Split |
Default implementation of a split node.
|
SplitFactory<T extends org.kie.api.fluent.NodeContainerBuilder<T,?>> |
|
SplitHandler |
|
SplitInstance |
Runtime counterpart of a split node.
|
SplitNodeBuilder |
|
SplitNodeHandler |
|
SpringStandaloneJtaSharedEntityManagerStrategy |
|
SpringStandaloneLocalSharedEntityManagerStrategy |
|
SqlQueryDefinition |
|
StageNotFoundException |
Thrown when accessing stage that does not exist
|
StageStatus |
Represents possible states of a case stage
|
StandaloneJtaStrategy |
This strategy is used by instances that are
used outside the KieSession
use their own EntityManager instance per operation
|
StandaloneLocalStrategy |
This strategy is used by instances that are
used outside the KieSession
use their own EntityManager instance per operation
|
StartCaseCommand |
|
StartCaseWorkItemHandler |
Work item handler that allows to start new case instance based on following parameters:
DeploymentId - deployment id where that case definition belongs to (if not given deployment id of the work item will be used)
CaseDefinitionId - identifier of the case definition a new case instance should be started for
Data_NAME - case file data to be given when starting a case - NAME is the name of the case file input, can be given as many times as needed
UserRole_NAME - case role assignment as user entity where NAME is the name of the role that given user should be assigned to
GroupRole_NAME - case role assignment as group entity where NAME is the name of the role that given group should be assigned to
DataAccess_NAME - case file data access restriction where NAME is the name of the data that given roles should have access to, supports list of roles (comma separated)
Independent - indicates if the case instance is independent of the node that starts it - default is false
DestroyOnAbort - indicates if the case instance should be destroyed in case the work item is aborted, defaults to true
This work item allows to be executed in independent mode which means once the case instance is started it will complete work item without waiting for case instance completion.
|
StartEventHandler |
|
StartNode |
Default implementation of a start node.
|
StartNodeBuilder |
|
StartNodeFactory<T extends org.kie.api.fluent.NodeContainerBuilder<T,?>> |
|
StartNodeHandler |
|
StartNodeInstance |
Runtime counterpart of a start node.
|
StartProcessHelper |
|
StartProcessInstanceWithParentCommand |
|
StartProcessSLAViolationListener |
|
StartTaskCommand |
Operation.Start : [ new OperationCommand().{ status = [ Status.Ready ],
allowed = [ Allowed.PotentialOwner ], setNewOwnerToUser = true, newStatus =
Status.InProgress }, new OperationCommand().{ status = [ Status.Reserved ],
allowed = [ Allowed.Owner ], newStatus = Status.InProgress } ], *
|
StateBasedNode |
|
StateBasedNodeInstance |
|
StateNode |
|
StateNodeHandler |
|
StateNodeHandler |
|
StateNodeInstance |
|
StopTaskCommand |
Operation.Stop
: [ new OperationCommand().{
status = [ Status.InProgress ],
allowed = [ Allowed.Owner, Allowed.BusinessAdministrator ],
newStatus = Status.Reserved
} ],
|
StoreNodeBuilder |
|
StringCaseVariableIndexer |
Simple and default indexer for all case variables.
|
StringDataType |
Representation of a string datatype.
|
StringProcessVariableIndexer |
Simple and default indexer for all process variables.
|
StringTaskVariableIndexer |
Simple and default indexer for all task variables.
|
SubProcessHandler |
|
SubProcessNode |
Default implementation of a sub-flow node.
|
SubProcessNodeBuilder |
|
SubProcessNodeFactory<T extends org.kie.api.fluent.NodeContainerBuilder<T,?>> |
|
SubProcessNodeHandler |
|
SubProcessNodeInstance |
Runtime counterpart of a SubFlow node.
|
SuspendProcessInstanceCommand |
|
SuspendTaskCommand |
Operation.Suspend : [ new OperationCommand().{ status = [ Status.Ready ],
allowed = [ Allowed.PotentialOwner, Allowed.BusinessAdministrator ],
newStatus = Status.Suspended }, new OperationCommand().{ status = [
Status.Reserved, Status.InProgress ], allowed = [Allowed.Owner,
Allowed.BusinessAdministrator ], newStatus = Status.Suspended } ],
|
Swimlane |
|
SwimlaneContext |
|
SwimlaneContextInstance |
|
SwimlaneHandler |
|
SwimlaneInstance |
|
SwimlaneInstance |
|
SynchronizedRuntimeImpl |
This is an extension of the regular RuntimeEngine implementation strictly dedicated to
SingletonRuntimeManager to ensure that access to RuntimeEngine
resources, such as KieSession and TaskService , remains synchronized.
|
SynchronizedTaskService |
Fully synchronized TaskService implementation used by the SingletonRuntimeManager .
|
SystemOutWorkItemHandler |
|
TableCaseIdGenerator |
Data base tabled backed case id generator.
|
Task |
Defines that a annotated element is of type Task, used with
EventListenerProducer
|
TaskAdminServiceImpl |
|
TaskAttachmentServiceImpl |
|
TaskAuditConfigurator |
|
TaskAuditJbpmEntityContributor |
|
TaskAuditLoggerFactory |
|
TaskAuditQueryCriteriaUtil |
|
TaskAuditQueryModificationService |
A QueryModificationService instace for the jbpm-human-task-audit module
|
TaskAuditService |
|
TaskAuditServiceFactory |
Factory that allows to produce TaskService instances via fluent API
provided by HumanTaskConfigurator
|
TaskAuditServiceImpl |
|
TaskAutoAckErrorCommand |
Command that will auto acknowledge task errors based on their status -
completed, failed, exited, obsolete, error - will be considered as eligible for ack
Following parameters are supported by this command:
EmfName - name of entity manager factory to be used for queries (valid persistence unit name)
SingleRun - indicates if execution should be single run only (true|false)
NextRun - provides next execution time (valid time expression e.g. 1d, 5h, etc)
|
TaskAverageDuration |
|
TaskCleanUpProcessEventListener |
|
TaskCommand<T> |
|
TaskCommandExecutorImpl |
|
TaskCommentServiceImpl |
|
TaskContentRegistry |
|
TaskContentServiceImpl |
|
TaskContext |
|
TaskCountLoadCalculator |
|
TaskDataImpl |
|
TaskDataImpl_ |
|
TaskDeadlinesServiceImpl |
|
TaskDeadlinesServiceImpl.ScheduledTaskDeadline |
|
TaskDefImpl |
|
TaskDefImpl_ |
|
TaskDefServiceImpl |
|
TaskEventDeleteBuilderImpl |
|
TaskEventImpl |
|
TaskEventImpl |
|
TaskEventImpl_ |
|
TaskEventQueryBuilderImpl |
|
TaskEventQueryCommand |
|
TaskEventsServiceImpl |
|
TaskEventSupport |
|
TaskExecutionErrorFilter |
|
TaskExecutionException |
|
TaskFactory |
|
TaskFluent |
|
TaskHandler |
|
TaskIdentityServiceImpl |
|
TaskImpl |
|
TaskImpl_ |
|
TaskIndexerManager |
Represents logic behind mechanism to index task variables.
|
TaskInfo |
|
TaskInstanceServiceImpl |
|
TaskJPAAuditService |
|
TaskLifeCycleEventConstants |
|
TaskLifeCycleEventListener |
|
TaskModelProviderImpl |
|
TaskNotFoundException |
|
TaskNotification |
|
TaskNotificationImpl |
|
TaskQueryManager |
|
TaskQueryServiceImpl |
|
TaskReassignment |
|
TaskReassignmentImpl |
|
TaskResolverFactory |
|
TaskRuleService |
|
TaskRuleServiceImpl |
|
TaskServiceEJBImpl |
|
TaskServiceEJBLocal |
|
TaskServiceRequest |
|
TaskSpecification |
Provides all required information about a dynamic task so it can be represented as correct
node type when added to case/process instance.
|
TaskStatusContextConstraint |
|
TaskSummaryImpl |
|
TaskSummaryQueryBuilderImpl |
Main Implementation of the TaskSummaryQueryBuilder .
|
TaskSummaryQueryCommand |
|
TaskSummaryQueryCriteriaUtil |
|
TaskSummaryQueryMapper |
Dedicated mapper that transform data set into List of TaskSummary
|
TaskTransactionInterceptor |
|
TaskVariableDeleteBuilderImpl |
|
TaskVariableImpl |
|
TaskVariableImpl_ |
|
TaskVariableQueryBuilderImpl |
|
TaskVariableQueryCommand |
|
TemplateManager |
|
TestIdentityProvider |
|
TestUserGroupCallbackImpl |
|
ThreadPoolSchedulerService |
ThreadPool based scheduler service backed by ThreadPoolSchedulerService
|
ThreadPoolSchedulerService.GlobalJDKJobHandle |
|
ThrowLinkNode |
|
ThrowLinkNodeHandler |
|
ThrowLinkNodeInstance |
|
TimeoutRuntimeManagerLockStrategy |
|
Timer |
|
TimerDesc |
|
TimerDesc |
|
TimerHandler |
|
TimerInstance |
|
TimerInstance |
Describes timer instance that is active with
details about the timer and the owner (such as process instance).
|
TimerInstanceImpl |
|
TimerListener |
|
TimerManager |
|
TimerManager.OverdueTrigger |
Overdue aware trigger that introduces fixed delay to allow completion of session initialization
|
TimerManager.ProcessJob |
|
TimerManager.ProcessJobContext |
|
TimerManager.ProcessTimerInputMarshaller |
|
TimerManager.ProcessTimerOutputMarshaller |
|
TimerManager.StartProcessJob |
|
TimerManager.StartProcessJobContext |
|
TimerMappingInfo |
|
TimerNode |
|
TimerNodeFactory<T extends org.kie.api.fluent.NodeContainerBuilder<T,?>> |
|
TimerNodeHandler |
|
TimerNodeHandler |
|
TimerNodeInstance |
|
TimerServiceListener |
|
TimerServiceRegistry |
Simple TimerService registry used for single point registration of TimerService
instances used by sessions.
|
TotalCompletionTimeLoadCalculator |
|
TransactionalCommandService |
|
TransactionalCommandServiceEJBImpl |
|
TransactionalCommandServiceProducer |
|
TransactionAwareSchedulerServiceInterceptor |
Transaction aware scheduler service interceptor that will delay actual scheduling of the
timer job instance to the afterCompletion phase of JTA transaction.
|
TransactionHandler |
|
Transformation |
|
TransformationBuilder |
|
TransientObjectConverter |
|
Trigger |
|
TriggerAdHocNodeInStageCommand |
Triggers a ad hoc activity within given stage (adhoc subprocess)
|
TriggerHandler |
|
TriggerNodeCommand |
|
TriggerRulesEventListener |
Dedicated AgendaEventListener that will fireAllRules as soon as:
match is created
after rule flow group is activated
This listener should be used to automatically fire rules as soon as they get activated.
|
TypeConverter |
|
TypeHandler |
|
TypeObject |
|
TypeTransformer |
|
UIWorkItemHandler |
|
UIWorkItemHandler |
|
UIWorkItemHandlerDialog |
|
UIWorkItemHandlerDialog |
|
UndefinedDataType |
Representation of an undefined datatype.
|
Undeploy |
|
UndeployTaskDefCommand |
|
UpdateCaseFileInstanceCommand |
Updates case file meta data
|
UpdateProcessCommand |
|
UpdateStringCommand |
|
UpdateTaskCommand |
|
UpdateTimerCommand |
|
UserAndGroupsTasksPreprocessor |
|
UserDataServiceProvider |
Provider of User/Group info services such as:
UserGroupCallback
UserInfo
It delivers various implementation depending on configuration of system properties where:
org.jbpm.ht.callback - specify what implementation of user group callback will be selected,one of:
mvel - default mostly used for testing
ldap - ldap backed implementation - requires additional configuration via jbpm.usergroup.callback.properties file
db - data base backed implementation - requires additional configuration via jbpm.usergroup.callback.properties file
jaas - delegates to container to fetch information about user data
props - simple property based callback - requires additional file that will keep all information (users and groups)
custom - custom implementation that requires to have additional system property set (FQCN of the implementation) - org.jbpm.ht.custom.callback
org.jbpm.ht.userinfo - specify what implementation of UserInfo shall be used, one of:
ldap - backed by ldap - requires configuration via jbpm-user.info.properties file
db - backed by data base - requires configuration via jbpm-user.info.properties file
props - backed by simple property file
custom - custom implementation that requires to have additional system property set (FQCN of the implementation) - org.jbpm.ht.custom.userinfo
|
UserGroupAdapter |
|
UserGroupCallbackTaskCommand<T> |
|
UserGroupInfoProducer |
|
UserImpl |
|
UserImpl_ |
|
UserTaskAdminService |
Provides administrative operations on top of active tasks.
|
UserTaskAdminServiceImpl |
|
UserTaskDefinition |
|
UserTaskDefinitionImpl |
|
UserTaskHandler |
|
UserTaskInstanceDesc |
|
UserTaskInstanceDesc |
|
UserTaskInstanceQueryMapper |
Dedicated mapper that transform data set into List of UserTaskInstanceDesc
|
UserTaskInstanceWithCustomVarsQueryMapper |
Dedicated mapper that transforms data set into UserTaskInstanceWithVarsDesc based on given mapping of custom variables
|
UserTaskInstanceWithModifVarsQueryMapper |
|
UserTaskInstanceWithPotOwnerDesc |
|
UserTaskInstanceWithPotOwnerDesc |
|
UserTaskInstanceWithPotOwnerQueryMapper |
|
UserTaskInstanceWithVarsDesc |
|
UserTaskInstanceWithVarsDesc |
|
UserTaskInstanceWithVarsQueryMapper |
Dedicated mapper that transforms data set to list of UserTaskInstanceWithVars
|
UserTaskLoad |
|
UserTaskPotOwnerQueryBuilder |
|
UserTaskPotOwnerQueryBuilderFactory |
|
UserTaskService |
|
UserTaskServiceCDIImpl |
|
UserTaskServiceEJBImpl |
|
UserTaskServiceEJBLocal |
|
UserTaskServiceEJBRemote |
|
UserTaskServiceImpl |
|
UserTasksPreprocessor |
|
ValueHandler |
|
ValueObject |
|
Variable |
Default implementation of a variable.
|
VariableDesc |
|
VariableGuardProcessEventListener |
|
VariableHandler |
|
VariableInstanceLog |
|
VariableInstanceLog_ |
|
VariablesAware |
Provides additional hook to process variables before they will be used by services.
|
VariableScope |
|
VariableScopeInstance |
|
VariableScopeResolverFactory |
|
VariableStateDesc |
|
VariableUtil |
|
VariableViolationException |
Thrown when there is any kind of variable violation such as missing required variable
or attempt to set already defined readonly variable.
|
VarInstanceLogDeleteBuilderImpl |
|
VarInstLogQueryBuilderImpl |
|
WeblogicUserGroupAdapter |
|
WebServiceCommand |
Web Service executor command that executes web service call using Apache CXF.
|
WebServiceWorkItemHandler |
Web Service Work Item Handler that performs a WebService call.
|
WebSphereUserGroupAdapter |
|
Wid |
Defines an annotated class that is of type Wid.
|
WidAction |
Used within the Service annotation to define
the action this workitem handler exposes.
|
WidAuth |
Used within the Service annotation to describe
the authentication needed for this workitem handler.
|
WidInfo |
|
WidMavenDepends |
Used within the Wid annotation to define
the maven dependencies to be placed within the
workitem configuration.
|
WidMVELEvaluator |
|
WidParameter |
Used within the Wid annotation to define
the workitem input parameters to be placed within the
workitem configuration.
|
WidParameterValues |
Used within the Wid annotation to define
the workitem input parameter values.
|
WidProcessor |
|
WidResult |
Used within the Wid annotation to define
the workitem result objects to be placed within the
workitem configuration.
|
WidService |
Defines an annotated class that is of type Service.
|
WidTrigger |
Used within the Service annotation to define
the trigger this workitem handler exposes.
|
Work |
|
WorkDefinition |
|
WorkDefinitionExtension |
|
WorkDefinitionExtensionImpl |
|
WorkDefinitionImpl |
|
WorkDefinitionImpl |
|
WorkEditor |
|
WorkflowBridgeTaskLifeCycleEventListener |
|
WorkflowContextInstance |
|
WorkflowProcess |
Represents a RuleFlow process.
|
WorkflowProcessImpl |
Default implementation of a RuleFlow process.
|
WorkflowProcessInstance |
|
WorkflowProcessInstanceImpl |
Default implementation of a RuleFlow process instance.
|
WorkflowProcessInstanceUpgrader |
|
WorkflowReuseContextInstanceFactory |
|
WorkflowRuntimeException |
This exception provides the context information of the error in execution of the flow.
|
WorkHandler |
|
WorkImpl |
|
WorkingMemory |
Defines a annotated element that is of type WorkingMemeory and is used with
EventListenerProducer
|
WorkItemHandlerProducer |
Deprecated.
|
WorkItemHandlerRuntimeException |
This exception provides extra information about the WorkItemHandler operation called to catchers of this exception.
|
WorkItemHeaderInfo |
|
WorkItemHeaderInfo.Builder |
|
WorkItemHeaderUtils |
|
WorkItemNode |
Default implementation of a task node.
|
WorkItemNodeBuilder |
|
WorkItemNodeFactory<T extends org.kie.api.fluent.NodeContainerBuilder<T,?>> |
|
WorkItemNodeHandler |
|
WorkItemNodeHandler |
|
WorkItemNodeInstance |
Runtime counterpart of a work item node.
|
WorkItemNotFoundException |
|
WorkItemRepository |
|
WorkItemTaskSpecification |
Defines work item task specification to create new "service" task in ad hoc (dynamic) process instance
|
XmlBPMNProcessDumper |
|
XmlProcessDumper |
|
XmlProcessDumperFactory |
|
XmlProcessDumperFactoryService |
|
XmlProcessDumperFactoryServiceImpl |
|
XmlProcessReader |
|
XmlRuleFlowProcessDumper |
|
XmlWorkflowProcessDumper |
|
XPATHActionBuilder |
|
XPATHAssignmentAction |
|
XPATHAssignmentBuilder |
|
XPATHExpressionModifier |
A helper utility that modifies XPath Expression in-place.
|
XPATHProcessDialect |
Please make sure to use the getter methods when referring to the static final fields,
because this class is extended in other modules (jbpm-kie-services).
|
XPATHReturnValueEvaluator |
|
XPATHReturnValueEvaluatorBuilder |
|