Skip navigation links
A B C D E F G H I J L M N P Q R S T U V W Z 

A

addingTaskExecutor(TaskExecutor, int, TaskType) - Method in class com.nirmata.workflow.WorkflowManagerBuilder
Adds a pool of task executors for a given task type to this instance of the workflow.
AutoCleaner - Interface in com.nirmata.workflow.admin
 
AutoCleanerHolder - Class in com.nirmata.workflow.details
 
AutoCleanerHolder(AutoCleaner, Duration) - Constructor for class com.nirmata.workflow.details.AutoCleanerHolder
 

B

build() - Method in class com.nirmata.workflow.WorkflowManagerBuilder
Return a new WorkflowManager using the current builder values
builder() - Static method in class com.nirmata.workflow.WorkflowManagerBuilder
Return a new builder

C

canBeCleaned(RunInfo) - Method in interface com.nirmata.workflow.admin.AutoCleaner
Called for each potential run to determine if it can be cleaned
canBeCleaned(RunInfo) - Method in class com.nirmata.workflow.admin.StandardAutoCleaner
 
cancelRun(RunId) - Method in class com.nirmata.workflow.details.WorkflowManagerImpl
 
cancelRun(RunId) - Method in interface com.nirmata.workflow.WorkflowManager
Attempt to cancel the given run.
clean(RunId) - Method in interface com.nirmata.workflow.admin.WorkflowAdmin
Delete all saved data for the given run.
clean(RunId) - Method in class com.nirmata.workflow.details.WorkflowManagerImpl
 
close() - Method in class com.nirmata.workflow.details.SchedulerSelector
 
close() - Method in class com.nirmata.workflow.details.WorkflowListenerManagerImpl
 
close() - Method in class com.nirmata.workflow.details.WorkflowManagerImpl
 
close() - Method in interface com.nirmata.workflow.queue.Queue
 
close() - Method in interface com.nirmata.workflow.queue.QueueConsumer
 
close() - Method in class com.nirmata.workflow.queue.zookeeper.SimpleQueue
 
close() - Method in class com.nirmata.workflow.queue.zookeeper.ZooKeeperSimpleQueue
 
com.nirmata.workflow - package com.nirmata.workflow
 
com.nirmata.workflow.admin - package com.nirmata.workflow.admin
 
com.nirmata.workflow.details - package com.nirmata.workflow.details
 
com.nirmata.workflow.details.internalmodels - package com.nirmata.workflow.details.internalmodels
 
com.nirmata.workflow.events - package com.nirmata.workflow.events
 
com.nirmata.workflow.executor - package com.nirmata.workflow.executor
 
com.nirmata.workflow.models - package com.nirmata.workflow.models
 
com.nirmata.workflow.queue - package com.nirmata.workflow.queue
 
com.nirmata.workflow.queue.zookeeper - package com.nirmata.workflow.queue.zookeeper
 
com.nirmata.workflow.serialization - package com.nirmata.workflow.serialization
 
createQueue(WorkflowManagerImpl, TaskType) - Method in interface com.nirmata.workflow.queue.QueueFactory
 
createQueue(WorkflowManagerImpl, TaskType) - Method in class com.nirmata.workflow.queue.zookeeper.ZooKeeperSimpleQueueFactory
 
createQueueConsumer(WorkflowManagerImpl, TaskRunner, TaskType) - Method in interface com.nirmata.workflow.queue.QueueFactory
 
createQueueConsumer(WorkflowManagerImpl, TaskRunner, TaskType) - Method in class com.nirmata.workflow.queue.zookeeper.ZooKeeperSimpleQueueFactory
 

D

debugLastSubmittedTimeMs - Variable in class com.nirmata.workflow.details.WorkflowManagerImpl
 
debugQueuedTasks - Static variable in class com.nirmata.workflow.queue.zookeeper.SimpleQueue
 
debugValidateClosed() - Method in class com.nirmata.workflow.details.WorkflowManagerImpl
 
debugValidateClosed() - Method in interface com.nirmata.workflow.queue.QueueConsumer
 
debugValidateClosed() - Method in class com.nirmata.workflow.queue.zookeeper.SimpleQueue
 
deserialize(byte[], Class<T>) - Method in interface com.nirmata.workflow.serialization.Serializer
Deserialize the given bytes into an object
deserialize(byte[], Class<T>) - Method in class com.nirmata.workflow.serialization.StandardSerializer
 

E

equals(Object) - Method in class com.nirmata.workflow.admin.RunInfo
 
equals(Object) - Method in class com.nirmata.workflow.admin.TaskDetails
 
equals(Object) - Method in class com.nirmata.workflow.admin.TaskInfo
 
equals(Object) - Method in class com.nirmata.workflow.admin.WorkflowManagerState
 
equals(Object) - Method in class com.nirmata.workflow.details.internalmodels.RunnableTask
 
equals(Object) - Method in class com.nirmata.workflow.details.internalmodels.RunnableTaskDag
 
equals(Object) - Method in class com.nirmata.workflow.details.internalmodels.StartedTask
 
equals(Object) - Method in class com.nirmata.workflow.events.WorkflowEvent
 
equals(Object) - Method in class com.nirmata.workflow.models.ExecutableTask
 
equals(Object) - Method in class com.nirmata.workflow.models.Id
 
equals(Object) - Method in class com.nirmata.workflow.models.Task
 
equals(Object) - Method in class com.nirmata.workflow.models.TaskExecutionResult
 
equals(Object) - Method in class com.nirmata.workflow.models.TaskType
 
ExecutableTask - Class in com.nirmata.workflow.models
Models a task that has been scheduled for execution as part of a run
ExecutableTask(RunId, TaskId, TaskType, Map<String, String>, boolean) - Constructor for class com.nirmata.workflow.models.ExecutableTask
 
execute() - Method in interface com.nirmata.workflow.executor.TaskExecution
Execute the task and return the result when complete
executeTask(ExecutableTask) - Method in interface com.nirmata.workflow.queue.TaskRunner
 

F

fromCode(int) - Static method in enum com.nirmata.workflow.models.TaskMode
 

G

get(JsonNode, Class<T>) - Method in class com.nirmata.workflow.serialization.JsonSerializerMapper
 
getAdmin() - Method in class com.nirmata.workflow.details.WorkflowManagerImpl
 
getAdmin() - Method in interface com.nirmata.workflow.WorkflowManager
Return administration operations
getChildrenTasks() - Method in class com.nirmata.workflow.models.Task
 
getCode() - Method in enum com.nirmata.workflow.models.TaskMode
 
getCompletedTaskParentPath() - Static method in class com.nirmata.workflow.details.ZooKeeperConstants
 
getCompletedTaskPath(RunId, TaskId) - Static method in class com.nirmata.workflow.details.ZooKeeperConstants
 
getCompletionTimeUtc() - Method in class com.nirmata.workflow.admin.RunInfo
 
getCompletionTimeUtc() - Method in class com.nirmata.workflow.details.internalmodels.RunnableTask
 
getCompletionTimeUtc() - Method in class com.nirmata.workflow.models.TaskExecutionResult
 
getCurator() - Method in class com.nirmata.workflow.details.WorkflowManagerImpl
 
getDependencies() - Method in class com.nirmata.workflow.details.internalmodels.RunnableTaskDag
 
getEntries() - Method in class com.nirmata.workflow.details.RunnableTaskDagBuilder
 
getExecutorsState() - Method in class com.nirmata.workflow.admin.WorkflowManagerState
Return state info for each task executor in this manager
getId() - Method in class com.nirmata.workflow.models.Id
 
getInstanceName() - Method in class com.nirmata.workflow.admin.TaskInfo
 
getInstanceName() - Method in class com.nirmata.workflow.details.internalmodels.StartedTask
 
getInstanceName() - Method in class com.nirmata.workflow.details.WorkflowManagerImpl
 
getListenable() - Method in class com.nirmata.workflow.details.WorkflowListenerManagerImpl
 
getListenable() - Method in interface com.nirmata.workflow.events.WorkflowListenerManager
Return the container to add/remove event listeners
getMapper() - Method in class com.nirmata.workflow.serialization.JsonSerializerMapper
 
getMessage() - Method in class com.nirmata.workflow.models.TaskExecutionResult
 
getMetaData() - Method in class com.nirmata.workflow.admin.TaskDetails
 
getMetaData() - Method in class com.nirmata.workflow.models.ExecutableTask
 
getMetaData() - Method in class com.nirmata.workflow.models.Task
 
getMode() - Method in class com.nirmata.workflow.models.TaskType
 
getParentRunId() - Method in class com.nirmata.workflow.details.internalmodels.RunnableTask
 
getProgress() - Method in class com.nirmata.workflow.admin.TaskInfo
 
getProgress() - Method in class com.nirmata.workflow.details.internalmodels.StartedTask
 
getQueueLockPath(TaskType) - Static method in class com.nirmata.workflow.details.ZooKeeperConstants
 
getQueuePath(TaskType) - Static method in class com.nirmata.workflow.details.ZooKeeperConstants
 
getQueuePathBase() - Static method in class com.nirmata.workflow.details.ZooKeeperConstants
 
getResult() - Method in class com.nirmata.workflow.admin.TaskInfo
 
getResultData() - Method in class com.nirmata.workflow.models.TaskExecutionResult
 
getRunId() - Method in class com.nirmata.workflow.admin.RunInfo
 
getRunId() - Method in class com.nirmata.workflow.events.WorkflowEvent
 
getRunId() - Method in class com.nirmata.workflow.models.ExecutableTask
 
getRunIdFromCompletedTasksPath(String) - Static method in class com.nirmata.workflow.details.ZooKeeperConstants
 
getRunIdFromRunPath(String) - Static method in class com.nirmata.workflow.details.ZooKeeperConstants
 
getRunIdFromStartedTasksPath(String) - Static method in class com.nirmata.workflow.details.ZooKeeperConstants
 
getRunIds() - Method in interface com.nirmata.workflow.admin.WorkflowAdmin
Return all run IDs completed or currently executing in the workflow manager
getRunIds() - Method in class com.nirmata.workflow.details.WorkflowManagerImpl
 
getRunInfo() - Method in interface com.nirmata.workflow.admin.WorkflowAdmin
Return info about all runs completed or currently executing in the workflow manager
getRunInfo(RunId) - Method in interface com.nirmata.workflow.admin.WorkflowAdmin
Return info about the given run
getRunInfo(RunId) - Method in class com.nirmata.workflow.details.WorkflowManagerImpl
 
getRunInfo() - Method in class com.nirmata.workflow.details.WorkflowManagerImpl
 
getRunParentPath() - Static method in class com.nirmata.workflow.details.ZooKeeperConstants
 
getRunPath(RunId) - Static method in class com.nirmata.workflow.details.ZooKeeperConstants
 
getRunPeriod() - Method in class com.nirmata.workflow.details.AutoCleanerHolder
 
getSchedulerLeaderPath() - Static method in class com.nirmata.workflow.details.ZooKeeperConstants
 
getSchedulerState() - Method in class com.nirmata.workflow.admin.WorkflowManagerState
Return the state of the scheduler for this manager instance.
getSerializer() - Method in class com.nirmata.workflow.details.WorkflowManagerImpl
 
getStartDateUtc() - Method in class com.nirmata.workflow.admin.TaskInfo
 
getStartDateUtc() - Method in class com.nirmata.workflow.details.internalmodels.StartedTask
 
getStartedTaskPath(RunId, TaskId) - Static method in class com.nirmata.workflow.details.ZooKeeperConstants
 
getStartedTasksParentPath() - Static method in class com.nirmata.workflow.details.ZooKeeperConstants
 
getStartTimeUtc() - Method in class com.nirmata.workflow.admin.RunInfo
 
getStartTimeUtc() - Method in class com.nirmata.workflow.details.internalmodels.RunnableTask
 
getState() - Method in class com.nirmata.workflow.details.SchedulerSelector
 
getState() - Method in interface com.nirmata.workflow.queue.QueueConsumer
 
getState() - Method in class com.nirmata.workflow.queue.zookeeper.SimpleQueue
 
getStatus() - Method in class com.nirmata.workflow.models.TaskExecutionResult
 
getSubTaskRunId() - Method in class com.nirmata.workflow.models.TaskExecutionResult
 
getTaskDags() - Method in class com.nirmata.workflow.details.internalmodels.RunnableTask
 
getTaskDetails(RunId) - Method in interface com.nirmata.workflow.admin.WorkflowAdmin
Returns a map of all task details for the given run
getTaskDetails(RunId) - Method in class com.nirmata.workflow.details.WorkflowManagerImpl
 
getTaskExecutionResult(RunId, TaskId) - Method in class com.nirmata.workflow.details.WorkflowManagerImpl
 
getTaskExecutionResult(RunId, TaskId) - Method in interface com.nirmata.workflow.WorkflowManager
Return the result for a given task of a given run
getTaskId() - Method in class com.nirmata.workflow.admin.TaskDetails
 
getTaskId() - Method in class com.nirmata.workflow.admin.TaskInfo
 
getTaskId() - Method in class com.nirmata.workflow.details.internalmodels.RunnableTaskDag
 
getTaskId() - Method in class com.nirmata.workflow.events.WorkflowEvent
 
getTaskId() - Method in class com.nirmata.workflow.models.ExecutableTask
 
getTaskId() - Method in class com.nirmata.workflow.models.Task
 
getTaskIdFromCompletedTasksPath(String) - Static method in class com.nirmata.workflow.details.ZooKeeperConstants
 
getTaskIdFromStartedTasksPath(String) - Static method in class com.nirmata.workflow.details.ZooKeeperConstants
 
getTaskInfo(RunId) - Method in interface com.nirmata.workflow.admin.WorkflowAdmin
Return info about all the tasks completed, started or waiting for the given run
getTaskInfo(RunId) - Method in class com.nirmata.workflow.details.WorkflowManagerImpl
 
getTasks() - Method in class com.nirmata.workflow.details.internalmodels.RunnableTask
 
getTasks() - Method in class com.nirmata.workflow.details.RunnableTaskDagBuilder
 
getTaskType() - Method in class com.nirmata.workflow.admin.TaskDetails
 
getTaskType() - Method in class com.nirmata.workflow.models.ExecutableTask
 
getTaskType() - Method in class com.nirmata.workflow.models.Task
 
getType() - Method in class com.nirmata.workflow.events.WorkflowEvent
 
getType() - Method in class com.nirmata.workflow.models.TaskType
 
getVersion() - Method in class com.nirmata.workflow.models.TaskType
 
getWorkflowManagerState() - Method in interface com.nirmata.workflow.admin.WorkflowAdmin
Return information about the internal run/state of the workflow manager
getWorkflowManagerState() - Method in class com.nirmata.workflow.details.WorkflowManagerImpl
 

H

hashCode() - Method in class com.nirmata.workflow.admin.RunInfo
 
hashCode() - Method in class com.nirmata.workflow.admin.TaskDetails
 
hashCode() - Method in class com.nirmata.workflow.admin.TaskInfo
 
hashCode() - Method in class com.nirmata.workflow.admin.WorkflowManagerState
 
hashCode() - Method in class com.nirmata.workflow.details.internalmodels.RunnableTask
 
hashCode() - Method in class com.nirmata.workflow.details.internalmodels.RunnableTaskDag
 
hashCode() - Method in class com.nirmata.workflow.details.internalmodels.StartedTask
 
hashCode() - Method in class com.nirmata.workflow.events.WorkflowEvent
 
hashCode() - Method in class com.nirmata.workflow.models.ExecutableTask
 
hashCode() - Method in class com.nirmata.workflow.models.Id
 
hashCode() - Method in class com.nirmata.workflow.models.Task
 
hashCode() - Method in class com.nirmata.workflow.models.TaskExecutionResult
 
hashCode() - Method in class com.nirmata.workflow.models.TaskType
 
hasStarted() - Method in class com.nirmata.workflow.admin.TaskInfo
 

I

Id - Class in com.nirmata.workflow.models
Base for IDs
Id() - Constructor for class com.nirmata.workflow.models.Id
 
Id(String) - Constructor for class com.nirmata.workflow.models.Id
 
isCancelingStatus() - Method in enum com.nirmata.workflow.executor.TaskExecutionStatus
 
isComplete() - Method in class com.nirmata.workflow.admin.RunInfo
 
isComplete() - Method in class com.nirmata.workflow.admin.TaskInfo
 
isConnectedToZooKeeper() - Method in class com.nirmata.workflow.admin.WorkflowManagerState
Returns true if the connection to ZooKeeper is active
isExecutable() - Method in class com.nirmata.workflow.admin.TaskDetails
 
isExecutable() - Method in class com.nirmata.workflow.models.ExecutableTask
 
isExecutable() - Method in class com.nirmata.workflow.models.Task
 
isIdempotent() - Method in class com.nirmata.workflow.models.TaskType
 
isValid() - Method in class com.nirmata.workflow.models.Id
 

J

JsonSerializerMapper - Class in com.nirmata.workflow.serialization
 
JsonSerializerMapper() - Constructor for class com.nirmata.workflow.serialization.JsonSerializerMapper
 

L

load(Reader) - Static method in class com.nirmata.workflow.serialization.TaskLoader
Load a complete task with children from a JSON stream
load(String) - Static method in class com.nirmata.workflow.serialization.TaskLoader
Load a complete task with children from a JSON string

M

main(String[]) - Static method in class com.nirmata.workflow.details.ZooKeeperConstants
 
main(String[]) - Static method in class com.nirmata.workflow.models.RunId
 
make(T) - Method in class com.nirmata.workflow.serialization.JsonSerializerMapper
 
makeSpecialMeta(long) - Static method in class com.nirmata.workflow.models.Task
Utility to create a new meta map with the given submit value
matchesTask(Task) - Method in class com.nirmata.workflow.admin.TaskDetails
 
MAX_PAYLOAD - Static variable in class com.nirmata.workflow.details.ZooKeeperConstants
 
META_TASK_SUBMIT_VALUE - Static variable in class com.nirmata.workflow.models.Task
Metadata value used by special purpose executors

N

newRandomIdWithPrefix(String) - Static method in class com.nirmata.workflow.models.RunId
Generate a new, globally unique ID that has the given prefix.
newTaskExecution(WorkflowManager, ExecutableTask) - Method in interface com.nirmata.workflow.executor.TaskExecutor
Create a task execution for the given task
newWorkflowListenerManager() - Method in class com.nirmata.workflow.details.WorkflowManagerImpl
 
newWorkflowListenerManager() - Method in interface com.nirmata.workflow.WorkflowManager
Allocate a new WorkflowListenerManager

P

put(ExecutableTask) - Method in interface com.nirmata.workflow.queue.Queue
 
put(ExecutableTask) - Method in class com.nirmata.workflow.queue.zookeeper.ZooKeeperSimpleQueue
 

Q

Queue - Interface in com.nirmata.workflow.queue
 
QueueConsumer - Interface in com.nirmata.workflow.queue
 
QueueFactory - Interface in com.nirmata.workflow.queue
 

R

receiveEvent(WorkflowEvent) - Method in interface com.nirmata.workflow.events.WorkflowListener
Receive a workflow event
run(WorkflowAdmin) - Method in class com.nirmata.workflow.details.AutoCleanerHolder
 
RunId - Class in com.nirmata.workflow.models
 
RunId() - Constructor for class com.nirmata.workflow.models.RunId
 
RunId(String) - Constructor for class com.nirmata.workflow.models.RunId
 
RunInfo - Class in com.nirmata.workflow.admin
Run information
RunInfo(RunId, LocalDateTime) - Constructor for class com.nirmata.workflow.admin.RunInfo
 
RunInfo(RunId, LocalDateTime, LocalDateTime) - Constructor for class com.nirmata.workflow.admin.RunInfo
 
RunnableTask - Class in com.nirmata.workflow.details.internalmodels
 
RunnableTask(Map<TaskId, ExecutableTask>, List<RunnableTaskDag>, LocalDateTime) - Constructor for class com.nirmata.workflow.details.internalmodels.RunnableTask
 
RunnableTask(Map<TaskId, ExecutableTask>, List<RunnableTaskDag>, LocalDateTime, LocalDateTime) - Constructor for class com.nirmata.workflow.details.internalmodels.RunnableTask
 
RunnableTask(Map<TaskId, ExecutableTask>, List<RunnableTaskDag>, LocalDateTime, LocalDateTime, RunId) - Constructor for class com.nirmata.workflow.details.internalmodels.RunnableTask
 
RunnableTaskDag - Class in com.nirmata.workflow.details.internalmodels
 
RunnableTaskDag(TaskId, Collection<TaskId>) - Constructor for class com.nirmata.workflow.details.internalmodels.RunnableTaskDag
 
RunnableTaskDagBuilder - Class in com.nirmata.workflow.details
 
RunnableTaskDagBuilder(Task) - Constructor for class com.nirmata.workflow.details.RunnableTaskDagBuilder
 

S

SchedulerSelector - Class in com.nirmata.workflow.details
 
SchedulerSelector(WorkflowManagerImpl, QueueFactory, AutoCleanerHolder) - Constructor for class com.nirmata.workflow.details.SchedulerSelector
 
serialize(T) - Method in interface com.nirmata.workflow.serialization.Serializer
Serialize the given object into bytes
serialize(T) - Method in class com.nirmata.workflow.serialization.StandardSerializer
 
Serializer - Interface in com.nirmata.workflow.serialization
 
shouldRun() - Method in class com.nirmata.workflow.details.AutoCleanerHolder
 
SimpleQueue - Class in com.nirmata.workflow.queue.zookeeper
 
StandardAutoCleaner - Class in com.nirmata.workflow.admin
Default auto cleaner.
StandardAutoCleaner(Duration) - Constructor for class com.nirmata.workflow.admin.StandardAutoCleaner
 
StandardSerializer - Class in com.nirmata.workflow.serialization
 
StandardSerializer() - Constructor for class com.nirmata.workflow.serialization.StandardSerializer
 
start() - Method in class com.nirmata.workflow.details.SchedulerSelector
 
start() - Method in class com.nirmata.workflow.details.WorkflowListenerManagerImpl
 
start() - Method in class com.nirmata.workflow.details.WorkflowManagerImpl
 
start() - Method in interface com.nirmata.workflow.events.WorkflowListenerManager
Start listening for events.
start() - Method in interface com.nirmata.workflow.queue.Queue
 
start() - Method in interface com.nirmata.workflow.queue.QueueConsumer
 
start() - Method in class com.nirmata.workflow.queue.zookeeper.SimpleQueue
 
start() - Method in class com.nirmata.workflow.queue.zookeeper.ZooKeeperSimpleQueue
 
start() - Method in interface com.nirmata.workflow.WorkflowManager
The manager must be started before use.
StartedTask - Class in com.nirmata.workflow.details.internalmodels
 
StartedTask(String, LocalDateTime, int) - Constructor for class com.nirmata.workflow.details.internalmodels.StartedTask
 
submitSubTask(RunId, Task) - Method in class com.nirmata.workflow.details.WorkflowManagerImpl
 
submitSubTask(RunId, RunId, Task) - Method in class com.nirmata.workflow.details.WorkflowManagerImpl
 
submitSubTask(RunId, Task) - Method in interface com.nirmata.workflow.WorkflowManager
Same as WorkflowManager.submitTask(Task) except that, when completed, the parent run will be notified.
submitSubTask(RunId, RunId, Task) - Method in interface com.nirmata.workflow.WorkflowManager
Same as WorkflowManager.submitTask(Task) except that, when completed, the parent run will be notified.
submitTask(Task) - Method in class com.nirmata.workflow.details.WorkflowManagerImpl
 
submitTask(RunId, Task) - Method in class com.nirmata.workflow.details.WorkflowManagerImpl
 
submitTask(Task) - Method in interface com.nirmata.workflow.WorkflowManager
Submit a task for execution.
submitTask(RunId, Task) - Method in interface com.nirmata.workflow.WorkflowManager
Submit a task for execution.

T

Task - Class in com.nirmata.workflow.models
Models a task
Task(TaskId, TaskType) - Constructor for class com.nirmata.workflow.models.Task
 
Task(TaskId, List<Task>) - Constructor for class com.nirmata.workflow.models.Task
This constructor makes a "container only" task.
Task(TaskId, TaskType, List<Task>) - Constructor for class com.nirmata.workflow.models.Task
 
Task(TaskId, TaskType, List<Task>, Map<String, String>) - Constructor for class com.nirmata.workflow.models.Task
 
TaskDetails - Class in com.nirmata.workflow.admin
Contains the meta-data and type from a submitted Task
TaskDetails(TaskId, TaskType, Map<String, String>) - Constructor for class com.nirmata.workflow.admin.TaskDetails
 
TaskExecution - Interface in com.nirmata.workflow.executor
Represents a task execution.
TaskExecutionResult - Class in com.nirmata.workflow.models
Models an execution result.
TaskExecutionResult(TaskExecutionStatus, String) - Constructor for class com.nirmata.workflow.models.TaskExecutionResult
 
TaskExecutionResult(TaskExecutionStatus, String, Map<String, String>) - Constructor for class com.nirmata.workflow.models.TaskExecutionResult
 
TaskExecutionResult(TaskExecutionStatus, String, Map<String, String>, RunId) - Constructor for class com.nirmata.workflow.models.TaskExecutionResult
 
TaskExecutionResult(TaskExecutionStatus, String, Map<String, String>, RunId, LocalDateTime) - Constructor for class com.nirmata.workflow.models.TaskExecutionResult
 
TaskExecutionStatus - Enum in com.nirmata.workflow.executor
Task execution status
TaskExecutor - Interface in com.nirmata.workflow.executor
Factory for creating task executions
TaskExecutorSpec - Class in com.nirmata.workflow.details
 
TaskExecutorSpec(TaskExecutor, int, TaskType) - Constructor for class com.nirmata.workflow.details.TaskExecutorSpec
 
TaskId - Class in com.nirmata.workflow.models
 
TaskId() - Constructor for class com.nirmata.workflow.models.TaskId
 
TaskId(String) - Constructor for class com.nirmata.workflow.models.TaskId
 
TaskInfo - Class in com.nirmata.workflow.admin
Task information
TaskInfo(TaskId) - Constructor for class com.nirmata.workflow.admin.TaskInfo
 
TaskInfo(TaskId, String, LocalDateTime, int) - Constructor for class com.nirmata.workflow.admin.TaskInfo
 
TaskInfo(TaskId, String, LocalDateTime, int, TaskExecutionResult) - Constructor for class com.nirmata.workflow.admin.TaskInfo
 
TaskLoader - Class in com.nirmata.workflow.serialization
Utility for loading Tasks from a file/stream
TaskMode - Enum in com.nirmata.workflow.models
 
TaskRunner - Interface in com.nirmata.workflow.queue
 
TaskType - Class in com.nirmata.workflow.models
Models a task type
TaskType(String, String, boolean) - Constructor for class com.nirmata.workflow.models.TaskType
 
TaskType(String, String, boolean, TaskMode) - Constructor for class com.nirmata.workflow.models.TaskType
 
toString() - Method in class com.nirmata.workflow.admin.RunInfo
 
toString() - Method in class com.nirmata.workflow.admin.TaskDetails
 
toString() - Method in class com.nirmata.workflow.admin.TaskInfo
 
toString() - Method in class com.nirmata.workflow.admin.WorkflowManagerState
 
toString() - Method in class com.nirmata.workflow.details.internalmodels.RunnableTask
 
toString() - Method in class com.nirmata.workflow.details.internalmodels.RunnableTaskDag
 
toString() - Method in class com.nirmata.workflow.details.internalmodels.StartedTask
 
toString() - Method in class com.nirmata.workflow.events.WorkflowEvent
 
toString() - Method in class com.nirmata.workflow.models.ExecutableTask
 
toString() - Method in class com.nirmata.workflow.models.Id
 
toString() - Method in class com.nirmata.workflow.models.Task
 
toString() - Method in class com.nirmata.workflow.models.TaskExecutionResult
 
toString() - Method in class com.nirmata.workflow.models.TaskType
 

U

updateTaskProgress(RunId, TaskId, int) - Method in class com.nirmata.workflow.details.WorkflowManagerImpl
 
updateTaskProgress(RunId, TaskId, int) - Method in interface com.nirmata.workflow.WorkflowManager
Update task progress info.

V

valueOf(String) - Static method in enum com.nirmata.workflow.admin.WorkflowManagerState.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.nirmata.workflow.events.WorkflowEvent.EventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.nirmata.workflow.executor.TaskExecutionStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.nirmata.workflow.models.TaskMode
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.nirmata.workflow.admin.WorkflowManagerState.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.nirmata.workflow.events.WorkflowEvent.EventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.nirmata.workflow.executor.TaskExecutionStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.nirmata.workflow.models.TaskMode
Returns an array containing the constants of this enum type, in the order they are declared.

W

withAutoCleaner(AutoCleaner, Duration) - Method in class com.nirmata.workflow.WorkflowManagerBuilder
optional
Sets an auto-cleaner that will run every given period.
withCurator(CuratorFramework, String, String) - Method in class com.nirmata.workflow.WorkflowManagerBuilder
required
Set the Curator instance to use.
withInstanceName(String) - Method in class com.nirmata.workflow.WorkflowManagerBuilder
optional
withQueueFactory(QueueFactory) - Method in class com.nirmata.workflow.WorkflowManagerBuilder
optional
Pluggable queue factory.
withSerializer(Serializer) - Method in class com.nirmata.workflow.WorkflowManagerBuilder
optional
By default, a JSON serializer is used to store data in ZooKeeper.
withTaskRunnerService(Executor) - Method in class com.nirmata.workflow.WorkflowManagerBuilder
optional
By default, tasks are run in an internal executor service.
WorkflowAdmin - Interface in com.nirmata.workflow.admin
Admin operations
WorkflowEvent - Class in com.nirmata.workflow.events
Models a workflow event
WorkflowEvent(WorkflowEvent.EventType, RunId) - Constructor for class com.nirmata.workflow.events.WorkflowEvent
 
WorkflowEvent(WorkflowEvent.EventType, RunId, TaskId) - Constructor for class com.nirmata.workflow.events.WorkflowEvent
 
WorkflowEvent.EventType - Enum in com.nirmata.workflow.events
 
WorkflowListener - Interface in com.nirmata.workflow.events
 
WorkflowListenerManager - Interface in com.nirmata.workflow.events
A listener manager for events.
WorkflowListenerManagerImpl - Class in com.nirmata.workflow.details
 
WorkflowListenerManagerImpl(WorkflowManagerImpl) - Constructor for class com.nirmata.workflow.details.WorkflowListenerManagerImpl
 
WorkflowManager - Interface in com.nirmata.workflow
Main API - create via WorkflowManagerBuilder
WorkflowManagerBuilder - Class in com.nirmata.workflow
Builds WorkflowManager instances
WorkflowManagerImpl - Class in com.nirmata.workflow.details
 
WorkflowManagerImpl(CuratorFramework, QueueFactory, String, List<TaskExecutorSpec>, AutoCleanerHolder, Serializer, Executor) - Constructor for class com.nirmata.workflow.details.WorkflowManagerImpl
 
WorkflowManagerState - Class in com.nirmata.workflow.admin
 
WorkflowManagerState(boolean, WorkflowManagerState.State, List<WorkflowManagerState.State>) - Constructor for class com.nirmata.workflow.admin.WorkflowManagerState
 
WorkflowManagerState.State - Enum in com.nirmata.workflow.admin
 

Z

ZooKeeperConstants - Class in com.nirmata.workflow.details
 
ZooKeeperSimpleQueue - Class in com.nirmata.workflow.queue.zookeeper
 
ZooKeeperSimpleQueueFactory - Class in com.nirmata.workflow.queue.zookeeper
 
ZooKeeperSimpleQueueFactory() - Constructor for class com.nirmata.workflow.queue.zookeeper.ZooKeeperSimpleQueueFactory
 
A B C D E F G H I J L M N P Q R S T U V W Z 
Skip navigation links

Copyright © 2014–2018 Nirmata. All rights reserved.