Index

_ | A | B | C | D | E | F | G | H | I | J | K | L | M | N | O | P | R | S | T | U | V | W | Z

_

__call__() (taskflow.types.notifier.Listener method)
__iter__() (taskflow.engines.action_engine.scopes.ScopeWalker method)

A

abandon() (taskflow.jobs.base.JobBoard method)
ActionEngine (class in taskflow.engines.action_engine.engine)
add() (taskflow.flow.Flow method)
(taskflow.patterns.graph_flow.Flow method)
(taskflow.patterns.graph_flow.TargetedFlow method)
(taskflow.patterns.linear_flow.Flow method)
(taskflow.patterns.unordered_flow.Flow method)
(taskflow.persistence.models.FlowDetail method)
(taskflow.persistence.models.LogBook method)
(taskflow.types.tree.Node method)
adjlist_dict_factory (taskflow.types.graph.OrderedDiGraph attribute)
affect() (taskflow.engines.action_engine.deciders.Decider method)
(taskflow.engines.action_engine.deciders.NoOpDecider method)
ALL (taskflow.deciders.Depth attribute)
AlwaysRevert (class in taskflow.retry)
AlwaysRevertAll (class in taskflow.retry)
AmbiguousDependency
Analyzer (class in taskflow.engines.action_engine.analyzer)
ANY (taskflow.types.notifier.Notifier attribute)
apply() (taskflow.engines.action_engine.completer.Strategy method)
apply_expiry() (in module taskflow.utils.redis_utils)
args (taskflow.types.notifier.Listener attribute)
as_int() (in module taskflow.utils.misc)
Atom (class in taskflow.atom)
ATOM (taskflow.deciders.Depth attribute)
atom_notifier (taskflow.engines.base.Engine attribute)
AtomDetail (class in taskflow.persistence.models)

B

Backend (class in taskflow.persistence.base)
backend (taskflow.persistence.base.Connection attribute)
(taskflow.storage.Storage attribute)
backend() (in module taskflow.jobs.backends)
(in module taskflow.persistence.backends)
BACKWARD (taskflow.engines.action_engine.traversal.Direction attribute)
BASE_EXCEPTIONS (taskflow.types.failure.Failure attribute)
BaseTask (class in taskflow.task)
bfs_iter() (taskflow.types.tree.Node method)
bfs_predecessors_iter() (taskflow.types.graph.DiGraph method)
binary_decode() (in module taskflow.utils.misc)
binary_encode() (in module taskflow.utils.misc)
bind() (taskflow.utils.threading_utils.ThreadBundle method)
BlockingConductor (class in taskflow.conductors.backends.impl_blocking)
board (taskflow.jobs.base.Job attribute)
(taskflow.jobs.base.JobBoardIterator attribute)
book (taskflow.jobs.base.Job attribute)
book_name (taskflow.jobs.base.Job attribute)
book_uuid (taskflow.jobs.base.Job attribute)
breadth_first_iterate() (in module taskflow.engines.action_engine.traversal)
browse_atoms_for_execute() (taskflow.engines.action_engine.analyzer.Analyzer method)
browse_atoms_for_revert() (taskflow.engines.action_engine.analyzer.Analyzer method)
build() (taskflow.engines.action_engine.builder.MachineBuilder method)

C

cachedproperty (class in taskflow.utils.misc)
callback (taskflow.types.notifier.Listener attribute)
can_be_registered() (taskflow.types.notifier.Notifier method)
(taskflow.types.notifier.RestrictedNotifier method)
can_trigger_notification() (taskflow.types.notifier.Notifier method)
capture_failure() (in module taskflow.utils.misc)
CaptureListener (class in taskflow.listeners.capturing)
caused_by() (taskflow.retry.History method)
causes (taskflow.types.failure.Failure attribute)
check() (taskflow.exceptions.WrappedFailure method)
(taskflow.types.failure.Failure method)
check_and_affect() (taskflow.engines.action_engine.deciders.Decider method)
check_atom_transition() (taskflow.engines.action_engine.runtime.Runtime method)
check_compatible() (in module taskflow.utils.kazoo_utils)
check_for_eventlet() (in module taskflow.utils.eventlet_utils)
checked_commit() (in module taskflow.utils.kazoo_utils)
CheckingClaimListener (class in taskflow.listeners.claims)
child_count() (taskflow.types.tree.Node method)
claim() (taskflow.jobs.base.JobBoard method)
clamp() (in module taskflow.utils.misc)
clean() (taskflow.engines.worker_based.types.ProxyWorkerFinder method)
cleanup_retry_history() (taskflow.storage.Storage method)
clear() (taskflow.persistence.backends.impl_memory.FakeFilesystem method)
clear_all() (taskflow.persistence.base.Connection method)
CLIENT_CONF_TRANSFERS (taskflow.jobs.backends.impl_redis.RedisJobBoard attribute)
close() (taskflow.conductors.base.Conductor method)
(taskflow.jobs.base.JobBoard method)
(taskflow.persistence.base.Backend method)
(taskflow.persistence.base.Connection method)
Compilation (class in taskflow.engines.action_engine.compiler)
compilation (taskflow.engines.action_engine.engine.ActionEngine attribute)
CompilationFailure
compile() (taskflow.engines.action_engine.compiler.FlowCompiler method)
(taskflow.engines.action_engine.compiler.PatternCompiler method)
(taskflow.engines.action_engine.runtime.Runtime method)
(taskflow.engines.base.Engine method)
complete() (taskflow.engines.action_engine.completer.Completer method)
complete_failure() (taskflow.engines.action_engine.completer.Completer method)
Completer (class in taskflow.engines.action_engine.completer)
Conductor (class in taskflow.conductors.base)
conductor (taskflow.conductors.base.Conductor attribute)
ConductorFailure
connect() (taskflow.conductors.base.Conductor method)
(taskflow.jobs.base.JobBoard method)
connected (taskflow.jobs.base.JobBoard attribute)
Connection (class in taskflow.persistence.base)
connection_details (taskflow.engines.worker_based.proxy.Proxy attribute)
constructor_options (taskflow.engines.action_engine.executor.ParallelProcessTaskExecutor attribute)
(taskflow.engines.action_engine.executor.ParallelTaskExecutor attribute)
consume() (taskflow.jobs.base.JobBoard method)
convert_to_timeout() (in module taskflow.types.timing)
copy() (taskflow.persistence.models.AtomDetail method)
(taskflow.persistence.models.FlowDetail method)
(taskflow.persistence.models.LogBook method)
(taskflow.persistence.models.RetryDetail method)
(taskflow.persistence.models.TaskDetail method)
(taskflow.task.BaseTask method)
(taskflow.types.failure.Failure method)
(taskflow.types.sets.OrderedSet method)
count() (in module taskflow.utils.iter_utils)
countdown_iter() (in module taskflow.utils.misc)
create_flow_detail() (in module taskflow.utils.persistence_utils)
created_on (taskflow.jobs.base.Job attribute)

D

daemon_thread() (in module taskflow.utils.threading_utils)
Decider (class in taskflow.engines.action_engine.deciders)
Decision (class in taskflow.retry)
decode_json() (in module taskflow.utils.misc)
decode_msgpack() (in module taskflow.utils.misc)
DEFAULT_FILE_ENCODING (taskflow.persistence.backends.impl_dir.DirBackend attribute)
DEFAULT_LISTEN_FOR (in module taskflow.listeners.base)
DEFAULT_NAMESPACE (taskflow.jobs.backends.impl_redis.RedisJobBoard attribute)
DEFAULT_PATH (taskflow.jobs.backends.impl_zookeeper.ZookeeperJobBoard attribute)
(taskflow.persistence.backends.impl_memory.MemoryBackend attribute)
(taskflow.persistence.backends.impl_zookeeper.ZkBackend attribute)
(taskflow.persistence.path_based.PathBasedBackend attribute)
DEFAULT_RETRY_OPTIONS (taskflow.engines.worker_based.proxy.Proxy attribute)
DelayedPretty (class in taskflow.utils.kombu_utils)
delete() (taskflow.persistence.backends.impl_memory.FakeFilesystem method)
DependencyFailure
deprecation() (in module taskflow.utils.deprecation)
Depth (class in taskflow.deciders)
depth_first_iterate() (in module taskflow.engines.action_engine.traversal)
depth_first_reverse_iterate() (in module taskflow.engines.action_engine.traversal)
deregister() (taskflow.types.notifier.Notifier method)
deregister_event() (taskflow.types.notifier.Notifier method)
destroy_logbook() (taskflow.persistence.base.Connection method)
details (taskflow.jobs.base.Job attribute)
details_filter (taskflow.types.notifier.Listener attribute)
dfs_iter() (taskflow.types.tree.Node method)
difference() (taskflow.types.sets.OrderedSet method)
DiGraph (class in taskflow.types.graph)
DirBackend (class in taskflow.persistence.backends.impl_dir)
Direction (class in taskflow.engines.action_engine.traversal)
disallow_when_frozen() (in module taskflow.utils.misc)
DisallowedAccess
disassociate() (taskflow.types.tree.Node method)
dispatcher (taskflow.engines.worker_based.proxy.Proxy attribute)
dispatching (taskflow.conductors.backends.impl_executor.ExecutorConductor attribute)
DOES_NOT_EXPIRE (taskflow.utils.redis_utils.UnknownExpire attribute)
DumpingListener (class in taskflow.listeners.base)
Duplicate
DurationListener (class in taskflow.listeners.timing)
DynamicLoggingListener (class in taskflow.listeners.logging)

E

edge_attr_dict_factory (taskflow.types.graph.OrderedDiGraph attribute)
Empty
empty() (taskflow.types.tree.Node method)
EMPTY_SPACE_SEP (taskflow.types.tree.Node attribute)
Endpoint (class in taskflow.engines.worker_based.endpoint)
Engine (class in taskflow.engines.base)
ensure_atom() (taskflow.storage.Storage method)
ensure_atoms() (taskflow.storage.Storage method)
ensure_path() (taskflow.persistence.backends.impl_memory.FakeFilesystem method)
ensure_tree() (in module taskflow.utils.misc)
Entity (class in taskflow.types.entity)
ENTITY_FOLDER (taskflow.jobs.backends.impl_zookeeper.ZookeeperJobBoard attribute)
ENTITY_KIND (taskflow.conductors.base.Conductor attribute)
entity_path (taskflow.jobs.backends.impl_zookeeper.ZookeeperJobBoard attribute)
EVENTS_EMITTED (taskflow.conductors.backends.impl_executor.ExecutorConductor attribute)
events_iter() (taskflow.types.notifier.RestrictedNotifier method)
EventTimeListener (class in taskflow.listeners.timing)
exc_info (taskflow.types.failure.Failure attribute)
exception (taskflow.types.failure.Failure attribute)
exception_args (taskflow.types.failure.Failure attribute)
exception_str (taskflow.types.failure.Failure attribute)
execute() (taskflow.atom.Atom method)
(taskflow.retry.Retry method)
(taskflow.task.BaseTask method)
execute_command() (taskflow.utils.redis_utils.RedisClient method)
execute_retry() (taskflow.engines.action_engine.executor.SerialRetryExecutor method)
execute_task() (taskflow.engines.action_engine.executor.TaskExecutor method)
execution_graph (taskflow.engines.action_engine.compiler.Compilation attribute)
ExecutionFailure
ExecutorConductor (class in taskflow.conductors.backends.impl_executor)
expired (taskflow.engines.worker_based.protocol.Request attribute)
expires_in() (taskflow.jobs.backends.impl_redis.RedisJob method)
export_to_dot() (taskflow.types.graph.DiGraph method)
(taskflow.types.graph.Graph method)
extend_expiry() (taskflow.jobs.backends.impl_redis.RedisJob method)
extract_driver_and_conf() (in module taskflow.utils.misc)

F

Failure (class in taskflow.types.failure)
failure (taskflow.retry.History attribute)
FailureFormatter (class in taskflow.formatters)
FakeFilesystem (class in taskflow.persistence.backends.impl_memory)
FakeInode (class in taskflow.persistence.backends.impl_memory)
fetch() (in module taskflow.conductors.backends)
(in module taskflow.jobs.backends)
(in module taskflow.persistence.backends)
(taskflow.storage.Storage method)
fetch_action() (taskflow.engines.action_engine.runtime.Runtime method)
fetch_all() (taskflow.storage.Storage method)
fetch_edge_deciders() (taskflow.engines.action_engine.runtime.Runtime method)
fetch_mapped_args() (taskflow.storage.Storage method)
fetch_scheduler() (taskflow.engines.action_engine.runtime.Runtime method)
fetch_scopes_for() (taskflow.engines.action_engine.runtime.Runtime method)
fetch_unsatisfied_args() (taskflow.storage.Storage method)
fill() (in module taskflow.utils.iter_utils)
finalize_client() (in module taskflow.utils.kazoo_utils)
find() (taskflow.persistence.models.FlowDetail method)
(taskflow.persistence.models.LogBook method)
(taskflow.types.tree.Node method)
find_first_match() (in module taskflow.utils.iter_utils)
(taskflow.types.tree.Node method)
find_owner() (taskflow.jobs.base.JobBoard method)
find_retry() (taskflow.engines.action_engine.analyzer.Analyzer method)
find_subclasses() (in module taskflow.utils.misc)
FINISH_STATES (in module taskflow.listeners.base)
fix_newlines() (in module taskflow.utils.misc)
Flow (class in taskflow.flow)
(class in taskflow.patterns.graph_flow)
(class in taskflow.patterns.linear_flow)
(class in taskflow.patterns.unordered_flow)
FLOW (taskflow.deciders.Depth attribute)
(taskflow.engines.action_engine.compiler.Compilation attribute)
flow (taskflow.engines.action_engine.compiler.Terminator attribute)
FLOW (taskflow.listeners.capturing.CaptureListener attribute)
FLOW_END (taskflow.engines.action_engine.compiler.Compilation attribute)
flow_from_detail() (in module taskflow.engines.helpers)
flow_meta (taskflow.storage.Storage attribute)
flow_name (taskflow.storage.Storage attribute)
flow_uuid (taskflow.storage.Storage attribute)
FlowCompiler (class in taskflow.engines.action_engine.compiler)
FlowDetail (class in taskflow.persistence.models)
ForEach (class in taskflow.retry)
format() (taskflow.formatters.FailureFormatter method)
FORWARD (taskflow.engines.action_engine.traversal.Direction attribute)
freeze() (taskflow.types.graph.DiGraph method)
(taskflow.types.graph.Graph method)
from_dict() (taskflow.engines.worker_based.protocol.Request static method)
(taskflow.persistence.models.AtomDetail class method)
(taskflow.persistence.models.FlowDetail class method)
(taskflow.persistence.models.LogBook class method)
(taskflow.persistence.models.RetryDetail class method)
(taskflow.types.failure.Failure class method)
from_exception() (taskflow.types.failure.Failure class method)
FrozenNode
FunctorTask (class in taskflow.task)

G

generate_delays() (in module taskflow.utils.iter_utils)
get() (taskflow.persistence.backends.impl_memory.FakeFilesystem method)
(taskflow.storage.Storage method)
get_atom_details() (taskflow.persistence.base.Connection method)
get_atom_intention() (taskflow.storage.Storage method)
get_atom_state() (taskflow.storage.Storage method)
get_atom_uuid() (taskflow.storage.Storage method)
get_atoms_for_flow() (taskflow.persistence.base.Connection method)
get_atoms_states() (taskflow.storage.Storage method)
get_connection() (taskflow.persistence.base.Backend method)
get_edge_data() (taskflow.types.graph.DiGraph method)
get_execute_failures() (taskflow.storage.Storage method)
get_execute_result() (taskflow.storage.Storage method)
get_expiry() (in module taskflow.utils.redis_utils)
get_failures() (taskflow.storage.Storage method)
get_flow_details() (taskflow.persistence.base.Connection method)
get_flow_state() (taskflow.storage.Storage method)
get_flows_for_book() (taskflow.persistence.base.Connection method)
get_hostname() (in module taskflow.utils.misc)
get_ident() (in module taskflow.utils.threading_utils)
get_logbook() (taskflow.persistence.base.Connection method)
get_logbooks() (taskflow.persistence.base.Connection method)
get_optimal_thread_count() (in module taskflow.utils.threading_utils)
get_retry_histories() (taskflow.storage.Storage method)
get_retry_history() (taskflow.storage.Storage method)
get_revert_failures() (taskflow.storage.Storage method)
get_revert_result() (taskflow.storage.Storage method)
get_task_progress() (taskflow.storage.Storage method)
get_task_progress_details() (taskflow.storage.Storage method)
get_version_string() (in module taskflow.utils.misc)
get_worker_for_task() (taskflow.engines.worker_based.types.ProxyWorkerFinder method)
Graph (class in taskflow.types.graph)

H

Handler (class in taskflow.engines.worker_based.dispatcher)
has_failures() (taskflow.storage.Storage method)
hierarchy (taskflow.engines.action_engine.compiler.Compilation attribute)
History (class in taskflow.retry)
HORIZONTAL_CONN (taskflow.types.tree.Node attribute)

I

IGNORABLE_STATES (taskflow.engines.action_engine.engine.ActionEngine attribute)
IgnoreDecider (class in taskflow.engines.action_engine.deciders)
IncompatibleVersion
index() (taskflow.types.tree.Node method)
inject() (taskflow.storage.Storage method)
inject_atom_args() (taskflow.storage.Storage method)
injector_name (taskflow.storage.Storage attribute)
interrupt() (taskflow.types.timing.Timeout method)
intersection() (taskflow.types.sets.OrderedSet method)
InvalidFormat
InvalidState
is_alive() (in module taskflow.utils.threading_utils)
is_directed_acyclic() (taskflow.types.graph.DiGraph method)
is_equivalent() (taskflow.types.notifier.Listener method)
is_iterable() (in module taskflow.utils.misc)
is_registered() (taskflow.types.notifier.Notifier method)
is_running (taskflow.engines.worker_based.proxy.Proxy attribute)
is_server_new_enough() (in module taskflow.utils.redis_utils)
is_stopped() (taskflow.types.timing.Timeout method)
is_success() (taskflow.engines.action_engine.analyzer.Analyzer method)
issubset() (taskflow.types.sets.OrderedSet method)
issuperset() (taskflow.types.sets.OrderedSet method)
iter_forever() (in module taskflow.utils.iter_utils)
iter_links() (taskflow.flow.Flow method)
iter_next_atoms() (taskflow.engines.action_engine.analyzer.Analyzer method)
iter_nodes() (taskflow.flow.Flow method)
iterate_nodes() (taskflow.engines.action_engine.analyzer.Analyzer method)
iterate_retries() (taskflow.engines.action_engine.analyzer.Analyzer method)
iterjobs() (taskflow.jobs.base.JobBoard method)

J

Job (class in taskflow.jobs.base)
job_count (taskflow.jobs.base.JobBoard attribute)
JOB_PREFIX (taskflow.jobs.backends.impl_zookeeper.ZookeeperJobBoard attribute)
JobBoard (class in taskflow.jobs.base)
JobBoardIterator (class in taskflow.jobs.base)
JobFailure
join() (taskflow.jobs.backends.impl_redis.RedisJobBoard method)
(taskflow.persistence.backends.impl_memory.FakeFilesystem static method)

K

KazooTransactionException
key (taskflow.jobs.backends.impl_redis.RedisJob attribute)
KEY_NOT_FOUND (taskflow.utils.redis_utils.UnknownExpire attribute)
KEY_PIECE_SEP (taskflow.jobs.backends.impl_redis.RedisJobBoard attribute)
kwargs (taskflow.types.notifier.Listener attribute)

L

last_failures (taskflow.persistence.models.RetryDetail attribute)
last_modified (taskflow.jobs.base.Job attribute)
last_modified_key (taskflow.jobs.backends.impl_redis.RedisJob attribute)
LAST_MODIFIED_POSTFIX (taskflow.jobs.backends.impl_redis.RedisJobBoard attribute)
last_results (taskflow.persistence.models.AtomDetail attribute)
(taskflow.persistence.models.RetryDetail attribute)
LINE_SEP (taskflow.types.tree.Node attribute)
link() (taskflow.patterns.graph_flow.Flow method)
(taskflow.patterns.graph_flow.TargetedFlow method)
Listener (class in taskflow.listeners.base)
(class in taskflow.types.notifier)
listeners_iter() (taskflow.types.notifier.Notifier method)
listings_key (taskflow.jobs.backends.impl_redis.RedisJobBoard attribute)
load() (in module taskflow.engines.helpers)
load_from_detail() (in module taskflow.engines.helpers)
load_from_factory() (in module taskflow.engines.helpers)
lock_path (taskflow.jobs.backends.impl_zookeeper.ZookeeperJob attribute)
LOCK_POSTFIX (taskflow.jobs.backends.impl_zookeeper.ZookeeperJobBoard attribute)
LOG (taskflow.conductors.backends.impl_executor.ExecutorConductor attribute)
LogBook (class in taskflow.persistence.models)
LoggingBase (class in taskflow.listeners.base)
LoggingListener (class in taskflow.listeners.logging)
ls() (taskflow.persistence.backends.impl_memory.FakeFilesystem method)
ls_r() (taskflow.persistence.backends.impl_memory.FakeFilesystem method)

M

MachineBuilder (class in taskflow.engines.action_engine.builder)
MachineMemory (class in taskflow.engines.action_engine.builder)
make_client() (in module taskflow.utils.kazoo_utils)
make_completed_future() (in module taskflow.utils.async_utils)
MapFunctorTask (class in taskflow.task)
match_type() (in module taskflow.utils.misc)
matches() (taskflow.types.failure.Failure method)
MAX_MACHINE_STATES_RETAINED (taskflow.engines.action_engine.engine.ActionEngine attribute)
MAX_SIMULTANEOUS_JOBS (taskflow.conductors.backends.impl_blocking.BlockingConductor attribute)
(taskflow.conductors.backends.impl_executor.ExecutorConductor attribute)
(taskflow.conductors.backends.impl_nonblocking.NonBlockingConductor attribute)
maybe_publish() (taskflow.engines.worker_based.types.ProxyWorkerFinder method)
MemoryBackend (class in taskflow.persistence.backends.impl_memory)
merge() (taskflow.persistence.models.AtomDetail method)
(taskflow.persistence.models.FlowDetail method)
(taskflow.persistence.models.LogBook method)
(taskflow.persistence.models.RetryDetail method)
(taskflow.persistence.models.TaskDetail method)
merge_graphs() (in module taskflow.types.graph)
merge_uri() (in module taskflow.utils.misc)
Message (class in taskflow.engines.worker_based.protocol)
MESSAGE_TPL (taskflow.exceptions.MissingDependencies attribute)
messages_processed (taskflow.engines.worker_based.types.ProxyWorkerFinder attribute)
millis_to_datetime() (in module taskflow.utils.misc)
MIN_REDIS_VERSION (taskflow.jobs.backends.impl_redis.RedisJobBoard attribute)
MIN_ZK_VERSION (taskflow.jobs.backends.impl_zookeeper.ZookeeperJobBoard attribute)
MissingDependencies
moved_proxy_class() (in module taskflow.utils.deprecation)
MovedClassProxy (class in taskflow.utils.deprecation)
MultipleChoices

N

name (taskflow.engines.action_engine.compiler.Terminator attribute)
(taskflow.flow.Flow attribute)
(taskflow.jobs.base.Job attribute)
(taskflow.jobs.base.JobBoard attribute)
(taskflow.persistence.models.AtomDetail attribute)
(taskflow.persistence.models.FlowDetail attribute)
(taskflow.persistence.models.LogBook attribute)
namespace (taskflow.jobs.backends.impl_redis.RedisJobBoard attribute)
NAMESPACE_SEP (taskflow.jobs.backends.impl_redis.RedisJobBoard attribute)
NEIGHBORS (taskflow.deciders.Depth attribute)
NO_CONSUME_EXCEPTIONS (taskflow.conductors.backends.impl_executor.ExecutorConductor attribute)
no_op() (in module taskflow.utils.threading_utils)
no_predecessors_iter() (taskflow.types.graph.DiGraph method)
NO_RERAISING_STATES (taskflow.engines.action_engine.engine.ActionEngine attribute)
no_successors_iter() (taskflow.types.graph.DiGraph method)
Node (class in taskflow.types.tree)
node_dict_factory (taskflow.types.graph.OrderedDiGraph attribute)
NonBlockingConductor (class in taskflow.conductors.backends.impl_nonblocking)
NoOpDecider (class in taskflow.engines.action_engine.deciders)
normpath() (taskflow.persistence.backends.impl_memory.FakeFilesystem class method)
NotFound
Notifier (class in taskflow.types.notifier)
notifier (taskflow.conductors.base.Conductor attribute)
(taskflow.engines.base.Engine attribute)
(taskflow.task.BaseTask attribute)
Notify (class in taskflow.engines.worker_based.protocol)
notify() (taskflow.types.notifier.Notifier method)
NotifyingJobBoard (class in taskflow.jobs.base)
NotImplementedError

O

on_failure() (taskflow.retry.Retry method)
on_message() (taskflow.engines.worker_based.dispatcher.TypeDispatcher method)
options (taskflow.engines.base.Engine attribute)
OrderedDiGraph (class in taskflow.types.graph)
OrderedSet (class in taskflow.types.sets)
outcomes_iter() (taskflow.retry.History method)
OWNED_POSTFIX (taskflow.jobs.backends.impl_redis.RedisJobBoard attribute)
owner_key (taskflow.jobs.backends.impl_redis.RedisJob attribute)

P

ParallelActionEngine (class in taskflow.engines.action_engine.engine)
ParallelProcessTaskExecutor (class in taskflow.engines.action_engine.executor)
ParallelTaskExecutor (class in taskflow.engines.action_engine.executor)
ParallelThreadTaskExecutor (class in taskflow.engines.action_engine.executor)
ParameterizedForEach (class in taskflow.retry)
parse_uri() (in module taskflow.utils.misc)
path (taskflow.jobs.backends.impl_zookeeper.ZookeeperJob attribute)
(taskflow.jobs.backends.impl_zookeeper.ZookeeperJobBoard attribute)
path_iter() (taskflow.types.tree.Node method)
PathBasedBackend (class in taskflow.persistence.path_based)
PathBasedConnection (class in taskflow.persistence.path_based)
PatternCompiler (class in taskflow.engines.action_engine.compiler)
pformat() (taskflow.exceptions.TaskFlowException method)
(taskflow.persistence.backends.impl_memory.FakeFilesystem method)
(taskflow.persistence.models.AtomDetail method)
(taskflow.persistence.models.FlowDetail method)
(taskflow.persistence.models.LogBook method)
(taskflow.types.failure.Failure method)
(taskflow.types.graph.DiGraph method)
(taskflow.types.graph.Graph method)
(taskflow.types.tree.Node method)
pick_first_not_none() (in module taskflow.utils.misc)
pick_widest() (in module taskflow.deciders)
post() (taskflow.jobs.base.JobBoard method)
post_execute() (taskflow.task.BaseTask method)
post_revert() (taskflow.task.BaseTask method)
pre_execute() (taskflow.task.BaseTask method)
pre_revert() (taskflow.task.BaseTask method)
prepare() (taskflow.engines.base.Engine method)
prettify_failures() (in module taskflow.utils.kazoo_utils)
PrintingDurationListener (class in taskflow.listeners.timing)
PrintingListener (class in taskflow.listeners.printing)
priority (taskflow.atom.Atom attribute)
process_message (taskflow.engines.worker_based.dispatcher.Handler attribute)
process_response() (taskflow.engines.worker_based.types.ProxyWorkerFinder method)
provided_iter() (taskflow.retry.History method)
provides (taskflow.flow.Flow attribute)
Proxy (class in taskflow.engines.worker_based.proxy)
ProxyWorkerFinder (class in taskflow.engines.worker_based.types)
publish() (taskflow.engines.worker_based.proxy.Proxy method)
pubsub() (taskflow.utils.redis_utils.RedisClient method)
put() (taskflow.persistence.models.AtomDetail method)
(taskflow.persistence.models.RetryDetail method)
(taskflow.persistence.models.TaskDetail method)
Python Enhancement Proposals
PEP 0342
PEP 3134, [1], [2]
PEP 3148, [1]
PEP 409
PEP 415

R

raise_with_cause() (in module taskflow.exceptions)
RedisClient (class in taskflow.utils.redis_utils)
RedisJob (class in taskflow.jobs.backends.impl_redis)
RedisJobBoard (class in taskflow.jobs.backends.impl_redis)
ReduceFunctorTask (class in taskflow.task)
register() (taskflow.types.notifier.Notifier method)
register_deregister() (in module taskflow.types.notifier)
register_entity() (taskflow.jobs.base.JobBoard method)
remove() (taskflow.types.tree.Node method)
Request (class in taskflow.engines.worker_based.protocol)
RequestTimeout
requeue_filters (taskflow.engines.worker_based.dispatcher.TypeDispatcher attribute)
requires (taskflow.flow.Flow attribute)
reraise() (taskflow.types.failure.Failure method)
reraise_if_any() (taskflow.types.failure.Failure static method)
RESERVED_KEYS (taskflow.types.notifier.Notifier attribute)
reset() (taskflow.engines.base.Engine method)
(taskflow.engines.worker_based.types.ProxyWorkerFinder method)
(taskflow.persistence.models.AtomDetail method)
(taskflow.persistence.models.RetryDetail method)
(taskflow.persistence.models.TaskDetail method)
(taskflow.storage.Storage method)
(taskflow.types.notifier.Notifier method)
(taskflow.types.timing.Timeout method)
reset_all() (taskflow.engines.action_engine.runtime.Runtime method)
reset_atoms() (taskflow.engines.action_engine.runtime.Runtime method)
reset_subgraph() (taskflow.engines.action_engine.runtime.Runtime method)
reset_target() (taskflow.patterns.graph_flow.TargetedFlow method)
Response (class in taskflow.engines.worker_based.protocol)
RESPONSE_SCHEMA (taskflow.engines.worker_based.protocol.Notify attribute)
RestrictedNotifier (class in taskflow.types.notifier)
resume() (taskflow.engines.action_engine.completer.Completer method)
Retry (class in taskflow.retry)
RETRY (taskflow.engines.action_engine.compiler.Compilation attribute)
retry (taskflow.flow.Flow attribute)
RETRY (taskflow.listeners.capturing.CaptureListener attribute)
(taskflow.retry.Decision attribute)
retry_subflow() (taskflow.engines.action_engine.runtime.Runtime method)
RetryDetail (class in taskflow.persistence.models)
RetryScheduler (class in taskflow.engines.action_engine.scheduler)
reverse_enumerate() (in module taskflow.utils.misc)
reverse_iter() (taskflow.types.tree.Node method)
Revert (class in taskflow.engines.action_engine.completer)
REVERT (taskflow.retry.Decision attribute)
revert() (taskflow.atom.Atom method)
(taskflow.retry.Retry method)
(taskflow.task.BaseTask method)
REVERT_ALL (taskflow.retry.Decision attribute)
revert_retry() (taskflow.engines.action_engine.executor.SerialRetryExecutor method)
revert_task() (taskflow.engines.action_engine.executor.TaskExecutor method)
RevertAll (class in taskflow.engines.action_engine.completer)
RevertAndRetry (class in taskflow.engines.action_engine.completer)
root (taskflow.jobs.backends.impl_zookeeper.ZookeeperJob attribute)
root_path (taskflow.persistence.backends.impl_memory.FakeFilesystem attribute)
run() (in module taskflow.engines.helpers)
(taskflow.conductors.backends.impl_executor.ExecutorConductor method)
(taskflow.conductors.base.Conductor method)
(taskflow.engines.action_engine.engine.ActionEngine method)
(taskflow.engines.base.Engine method)
(taskflow.engines.worker_based.worker.Worker method)
run_iter() (taskflow.engines.action_engine.engine.ActionEngine method)
Runtime (class in taskflow.engines.action_engine.runtime)

S

safe_copy_dict() (in module taskflow.utils.misc)
save() (taskflow.storage.Storage method)
save_factory_details() (in module taskflow.engines.helpers)
save_logbook() (taskflow.persistence.base.Connection method)
save_retry_failure() (taskflow.storage.Storage method)
schedule() (taskflow.engines.action_engine.scheduler.RetryScheduler method)
(taskflow.engines.action_engine.scheduler.Scheduler method)
(taskflow.engines.action_engine.scheduler.TaskScheduler method)
Scheduler (class in taskflow.engines.action_engine.scheduler)
SCHEMA (taskflow.engines.worker_based.protocol.Request attribute)
(taskflow.engines.worker_based.protocol.Response attribute)
(taskflow.types.failure.Failure attribute)
schema_validate() (in module taskflow.utils.schema_utils)
ScopeWalker (class in taskflow.engines.action_engine.scopes)
SCRIPT_ALREADY_CLAIMED (taskflow.jobs.backends.impl_redis.RedisJobBoard attribute)
SCRIPT_NOT_EXPECTED_OWNER (taskflow.jobs.backends.impl_redis.RedisJobBoard attribute)
SCRIPT_STATUS_ERROR (taskflow.jobs.backends.impl_redis.RedisJobBoard attribute)
SCRIPT_STATUS_OK (taskflow.jobs.backends.impl_redis.RedisJobBoard attribute)
SCRIPT_TEMPLATES (taskflow.jobs.backends.impl_redis.RedisJobBoard attribute)
SCRIPT_UNKNOWN_JOB (taskflow.jobs.backends.impl_redis.RedisJobBoard attribute)
SCRIPT_UNKNOWN_OWNER (taskflow.jobs.backends.impl_redis.RedisJobBoard attribute)
SENDER_SCHEMA (taskflow.engines.worker_based.protocol.Notify attribute)
sequence (taskflow.jobs.backends.impl_redis.RedisJob attribute)
(taskflow.jobs.backends.impl_zookeeper.ZookeeperJob attribute)
sequence_key (taskflow.jobs.backends.impl_redis.RedisJobBoard attribute)
sequence_minus() (in module taskflow.utils.misc)
SerialActionEngine (class in taskflow.engines.action_engine.engine)
SerialRetryExecutor (class in taskflow.engines.action_engine.executor)
SerialTaskExecutor (class in taskflow.engines.action_engine.executor)
set_atom_intention() (taskflow.storage.Storage method)
set_atom_state() (taskflow.storage.Storage method)
set_flow_state() (taskflow.storage.Storage method)
set_result() (taskflow.engines.worker_based.protocol.Request method)
set_target() (taskflow.patterns.graph_flow.TargetedFlow method)
set_task_progress() (taskflow.storage.Storage method)
split() (taskflow.persistence.backends.impl_memory.FakeFilesystem static method)
SQLAlchemyBackend (class in taskflow.persistence.backends.impl_sqlalchemy)
start() (taskflow.engines.action_engine.executor.SerialRetryExecutor method)
(taskflow.engines.action_engine.executor.TaskExecutor method)
(taskflow.engines.worker_based.executor.WorkerTaskExecutor method)
(taskflow.engines.worker_based.proxy.Proxy method)
(taskflow.utils.threading_utils.ThreadBundle method)
START_FINISH_EVENTS_EMITTED (taskflow.conductors.backends.impl_executor.ExecutorConductor attribute)
STARTING_PREFIX (taskflow.types.tree.Node attribute)
state (taskflow.jobs.base.Job attribute)
stop() (taskflow.conductors.backends.impl_executor.ExecutorConductor method)
(taskflow.engines.action_engine.executor.SerialRetryExecutor method)
(taskflow.engines.action_engine.executor.TaskExecutor method)
(taskflow.engines.worker_based.executor.WorkerTaskExecutor method)
(taskflow.engines.worker_based.proxy.Proxy method)
(taskflow.engines.worker_based.worker.Worker method)
(taskflow.utils.threading_utils.ThreadBundle method)
Storage (class in taskflow.storage)
storage (taskflow.engines.action_engine.engine.ActionEngine attribute)
(taskflow.engines.base.Engine attribute)
StorageFailure
Strategy (class in taskflow.engines.action_engine.completer)
StrEnum (class in taskflow.utils.misc)
StringIO (class in taskflow.utils.misc)
StrMixin (class in taskflow.utils.mixins)
suspend() (taskflow.engines.base.Engine method)
symlink() (taskflow.persistence.backends.impl_memory.FakeFilesystem method)

T

tally() (taskflow.engines.action_engine.deciders.Decider method)
(taskflow.engines.action_engine.deciders.NoOpDecider method)
TargetedFlow (class in taskflow.patterns.graph_flow)
Task (class in taskflow.task)
TASK (taskflow.engines.action_engine.compiler.Compilation attribute)
(taskflow.listeners.capturing.CaptureListener attribute)
Task/retry arguments
Task/retry results
task_notifier (taskflow.engines.base.Engine attribute)
TaskCompiler (class in taskflow.engines.action_engine.compiler)
TaskDetail (class in taskflow.persistence.models)
TaskExecutor (class in taskflow.engines.action_engine.executor)
taskflow.atom (module)
taskflow.conductors.backends (module)
taskflow.conductors.backends.impl_blocking (module)
taskflow.conductors.backends.impl_executor (module)
taskflow.conductors.backends.impl_nonblocking (module)
taskflow.conductors.base (module)
taskflow.deciders (module)
taskflow.engines.action_engine.analyzer (module)
taskflow.engines.action_engine.builder (module)
taskflow.engines.action_engine.compiler (module)
taskflow.engines.action_engine.completer (module)
taskflow.engines.action_engine.deciders (module)
taskflow.engines.action_engine.engine (module)
taskflow.engines.action_engine.executor (module)
taskflow.engines.action_engine.runtime (module)
taskflow.engines.action_engine.scheduler (module)
taskflow.engines.action_engine.traversal (module)
taskflow.engines.base (module)
taskflow.engines.helpers (module)
taskflow.engines.worker_based.dispatcher (module)
taskflow.engines.worker_based.endpoint (module)
taskflow.engines.worker_based.engine (module)
taskflow.engines.worker_based.executor (module)
taskflow.engines.worker_based.protocol (module)
taskflow.engines.worker_based.proxy (module)
taskflow.engines.worker_based.types (module)
taskflow.engines.worker_based.worker (module)
taskflow.exceptions (module)
taskflow.flow (module)
taskflow.formatters (module)
taskflow.jobs.backends (module)
taskflow.jobs.backends.impl_redis (module)
taskflow.jobs.backends.impl_zookeeper (module)
taskflow.jobs.base (module)
taskflow.listeners.base (module)
taskflow.patterns.graph_flow (module)
taskflow.patterns.linear_flow (module)
taskflow.patterns.unordered_flow (module)
taskflow.persistence.backends (module)
taskflow.persistence.backends.impl_dir (module)
taskflow.persistence.backends.impl_memory (module)
taskflow.persistence.backends.impl_sqlalchemy (module)
taskflow.persistence.backends.impl_zookeeper (module)
taskflow.persistence.base (module)
taskflow.persistence.models (module)
taskflow.persistence.path_based (module)
taskflow.storage (module)
taskflow.task (module)
taskflow.types.entity (module)
taskflow.types.failure (module)
taskflow.types.graph (module)
taskflow.types.notifier (module)
taskflow.types.sets (module)
taskflow.types.timing (module)
taskflow.types.tree (module)
taskflow.utils.async_utils (module)
taskflow.utils.deprecation (module)
taskflow.utils.eventlet_utils (module)
taskflow.utils.iter_utils (module)
taskflow.utils.kazoo_utils (module)
taskflow.utils.kombu_utils (module)
taskflow.utils.misc (module)
taskflow.utils.mixins (module)
taskflow.utils.persistence_utils (module)
taskflow.utils.redis_utils (module)
taskflow.utils.schema_utils (module)
taskflow.utils.threading_utils (module)
TaskFlowException
TaskScheduler (class in taskflow.engines.action_engine.scheduler)
temporary_flow_detail() (in module taskflow.utils.persistence_utils)
temporary_log_book() (in module taskflow.utils.persistence_utils)
Terminator (class in taskflow.engines.action_engine.compiler)
ThreadBundle (class in taskflow.utils.threading_utils)
Timeout (class in taskflow.types.timing)
Times (class in taskflow.retry)
to_dict() (taskflow.engines.worker_based.protocol.Message method)
(taskflow.engines.worker_based.protocol.Request method)
(taskflow.persistence.models.AtomDetail method)
(taskflow.persistence.models.FlowDetail method)
(taskflow.persistence.models.LogBook method)
(taskflow.persistence.models.RetryDetail method)
(taskflow.types.failure.Failure method)
to_digraph() (taskflow.types.tree.Node method)
TopicWorker (class in taskflow.engines.worker_based.types)
topological_sort() (taskflow.types.graph.DiGraph method)
total_workers (taskflow.engines.worker_based.types.ProxyWorkerFinder attribute)
traceback_str (taskflow.types.failure.Failure attribute)
transaction() (taskflow.utils.redis_utils.RedisClient method)
transition() (taskflow.engines.worker_based.protocol.Request method)
transition_and_log_error() (taskflow.engines.worker_based.protocol.Request method)
translate() (taskflow.deciders.Depth class method)
trash() (taskflow.jobs.base.JobBoard method)
TRASH_FOLDER (taskflow.jobs.backends.impl_zookeeper.ZookeeperJobBoard attribute)
trash_key (taskflow.jobs.backends.impl_redis.RedisJobBoard attribute)
trash_path (taskflow.jobs.backends.impl_zookeeper.ZookeeperJobBoard attribute)
TYPE (taskflow.engines.worker_based.protocol.Notify attribute)
(taskflow.engines.worker_based.protocol.Request attribute)
(taskflow.engines.worker_based.protocol.Response attribute)
type_handlers (taskflow.engines.worker_based.dispatcher.TypeDispatcher attribute)
TypeDispatcher (class in taskflow.engines.worker_based.dispatcher)

U

UnclaimableJob
union() (taskflow.types.sets.OrderedSet method)
unique_seen() (in module taskflow.utils.iter_utils)
UnknownExpire (class in taskflow.utils.redis_utils)
update() (taskflow.persistence.models.AtomDetail method)
(taskflow.persistence.models.FlowDetail method)
update_atom_details() (taskflow.persistence.base.Connection method)
update_atom_metadata() (taskflow.storage.Storage method)
update_flow_details() (taskflow.persistence.base.Connection method)
update_flow_metadata() (taskflow.storage.Storage method)
update_progress() (taskflow.task.BaseTask method)
upgrade() (taskflow.persistence.base.Connection method)
uuid (taskflow.jobs.base.Job attribute)
(taskflow.persistence.models.AtomDetail attribute)
(taskflow.persistence.models.FlowDetail attribute)
(taskflow.persistence.models.LogBook attribute)

V

validate() (taskflow.engines.base.Engine method)
(taskflow.persistence.base.Connection method)
(taskflow.types.failure.Failure class method)
validator (taskflow.engines.worker_based.dispatcher.Handler attribute)
value (taskflow.types.timing.Timeout attribute)
VERTICAL_CONN (taskflow.types.tree.Node attribute)

W

wait() (taskflow.conductors.backends.impl_executor.ExecutorConductor method)
(taskflow.engines.worker_based.proxy.Proxy method)
(taskflow.engines.worker_based.worker.Worker method)
(taskflow.jobs.base.Job method)
(taskflow.jobs.base.JobBoard method)
(taskflow.types.timing.Timeout method)
wait_for_workers() (taskflow.engines.worker_based.executor.WorkerTaskExecutor method)
(taskflow.engines.worker_based.types.ProxyWorkerFinder method)
WAIT_TIMEOUT (taskflow.conductors.backends.impl_executor.ExecutorConductor attribute)
while_is_not() (in module taskflow.utils.iter_utils)
Worker (class in taskflow.engines.worker_based.worker)
WorkerBasedActionEngine (class in taskflow.engines.worker_based.engine)
WorkerTaskExecutor (class in taskflow.engines.worker_based.executor)
WrappedFailure

Z

ZkBackend (class in taskflow.persistence.backends.impl_zookeeper)
ZookeeperJob (class in taskflow.jobs.backends.impl_zookeeper)
ZookeeperJobBoard (class in taskflow.jobs.backends.impl_zookeeper)

Navigation

Project Source