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

A

accept(T1) - Method in interface com.linkedin.parseq.function.Consumer1
 
accept(T1, T2) - Method in interface com.linkedin.parseq.function.Consumer2
 
accept(T1, T2, T3) - Method in interface com.linkedin.parseq.function.Consumer3
 
accept(T1, T2, T3, T4) - Method in interface com.linkedin.parseq.function.Consumer4
 
accept(T1, T2, T3, T4, T5) - Method in interface com.linkedin.parseq.function.Consumer5
 
accept(T1, T2, T3, T4, T5, T6) - Method in interface com.linkedin.parseq.function.Consumer6
 
accept(T1, T2, T3, T4, T5, T6, T7) - Method in interface com.linkedin.parseq.function.Consumer7
 
accept(T1, T2, T3, T4, T5, T6, T7, T8) - Method in interface com.linkedin.parseq.function.Consumer8
 
accept(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in interface com.linkedin.parseq.function.Consumer9
 
accept(Promise<S>, Settable<T>) - Method in class com.linkedin.parseq.promise.PromiseTransformer
 
Action - Interface in com.linkedin.parseq.function
 
action(String, Action) - Static method in interface com.linkedin.parseq.Task
Creates a new task that have a value of type Void.
action(Action) - Static method in interface com.linkedin.parseq.Task
Equivalent to action("action", action).
action(String, Runnable) - Static method in class com.linkedin.parseq.Tasks
Deprecated.
As of 2.0.0, replaced by Task.action
ActionTask - Class in com.linkedin.parseq
Deprecated.
As of 2.0.0, replaced by Task.action.
ActionTask(String, Runnable) - Constructor for class com.linkedin.parseq.ActionTask
Deprecated.
 
addAttribute(String, String) - Method in class com.linkedin.parseq.trace.ShallowTraceBuilder
 
addListener(PromiseListener<T>) - Method in class com.linkedin.parseq.promise.DelegatingPromise
 
addListener(PromiseListener<P>) - Method in interface com.linkedin.parseq.promise.Promise
Adds a listener to this promise that will be notified when the promise is resolved.
addListener(PromiseListener<T>) - Method in class com.linkedin.parseq.promise.ResolvedError
 
addListener(PromiseListener<T>) - Method in class com.linkedin.parseq.promise.ResolvedValue
 
addListener(PromiseListener<Tuple2<T1, T2>>) - Method in class com.linkedin.parseq.Tuple2TaskDelegate
Adds a listener to this promise that will be notified when the promise is resolved.
addListener(PromiseListener<Tuple3<T1, T2, T3>>) - Method in class com.linkedin.parseq.Tuple3TaskDelegate
Adds a listener to this promise that will be notified when the promise is resolved.
addListener(PromiseListener<Tuple4<T1, T2, T3, T4>>) - Method in class com.linkedin.parseq.Tuple4TaskDelegate
Adds a listener to this promise that will be notified when the promise is resolved.
addListener(PromiseListener<Tuple5<T1, T2, T3, T4, T5>>) - Method in class com.linkedin.parseq.Tuple5TaskDelegate
Adds a listener to this promise that will be notified when the promise is resolved.
addListener(PromiseListener<Tuple6<T1, T2, T3, T4, T5, T6>>) - Method in class com.linkedin.parseq.Tuple6TaskDelegate
Adds a listener to this promise that will be notified when the promise is resolved.
addListener(PromiseListener<Tuple7<T1, T2, T3, T4, T5, T6, T7>>) - Method in class com.linkedin.parseq.Tuple7TaskDelegate
Adds a listener to this promise that will be notified when the promise is resolved.
addListener(PromiseListener<Tuple8<T1, T2, T3, T4, T5, T6, T7, T8>>) - Method in class com.linkedin.parseq.Tuple8TaskDelegate
Adds a listener to this promise that will be notified when the promise is resolved.
addListener(PromiseListener<Tuple9<T1, T2, T3, T4, T5, T6, T7, T8, T9>>) - Method in class com.linkedin.parseq.Tuple9TaskDelegate
Adds a listener to this promise that will be notified when the promise is resolved.
addRelationship(Relationship, ShallowTraceBuilder, ShallowTraceBuilder) - Method in class com.linkedin.parseq.trace.TraceBuilder
 
addShallowTrace(ShallowTraceBuilder) - Method in class com.linkedin.parseq.trace.TraceBuilder
 
After - Interface in com.linkedin.parseq
An object that invokes tasks after as set of Promises and Tasks have completed.
after(Promise<?>...) - Method in interface com.linkedin.parseq.Context
Provides a mechanism of ordering the execution of some child tasks after the resolution of the given promises (which may also be tasks).
alwaysTerminate() - Static method in interface com.linkedin.parseq.retry.termination.TerminationPolicy
A termination policy that always signals for termination.
andThen(Function1<? super R, ? extends V>) - Method in interface com.linkedin.parseq.function.Function1
 
andThen(Function1<? super R, ? extends V>) - Method in interface com.linkedin.parseq.function.Function2
 
andThen(Function1<? super R, ? extends V>) - Method in interface com.linkedin.parseq.function.Function3
 
andThen(Function1<? super R, ? extends V>) - Method in interface com.linkedin.parseq.function.Function4
 
andThen(Function1<? super R, ? extends V>) - Method in interface com.linkedin.parseq.function.Function5
 
andThen(Function1<? super R, ? extends V>) - Method in interface com.linkedin.parseq.function.Function6
 
andThen(Function1<? super R, ? extends V>) - Method in interface com.linkedin.parseq.function.Function7
 
andThen(Function1<? super R, ? extends V>) - Method in interface com.linkedin.parseq.function.Function8
 
andThen(Function1<? super R, ? extends V>) - Method in interface com.linkedin.parseq.function.Function9
 
andThen(String, Consumer1<? super T>) - Method in interface com.linkedin.parseq.Task
Creates a new task which applies a consumer to the result of this task and completes with a result of this task.
andThen(Consumer1<? super T>) - Method in interface com.linkedin.parseq.Task
Equivalent to andThen("andThen", consumer).
andThen(String, Task<R>) - Method in interface com.linkedin.parseq.Task
Creates a new task which runs given task after completion of this task and completes with a result of that task.
andThen(Task<R>) - Method in interface com.linkedin.parseq.Task
Equivalent to andThen("andThen", task).
andThen(Consumer2<T1, T2>) - Method in interface com.linkedin.parseq.Tuple2Task
Equivalent to andThen("andThen", consumer).
andThen(String, Consumer2<T1, T2>) - Method in interface com.linkedin.parseq.Tuple2Task
Creates a new task which applies a consumer to the result of this task and completes with a result of this task.
andThen(Consumer3<T1, T2, T3>) - Method in interface com.linkedin.parseq.Tuple3Task
Equivalent to andThen("andThen", consumer).
andThen(String, Consumer3<T1, T2, T3>) - Method in interface com.linkedin.parseq.Tuple3Task
Creates a new task which applies a consumer to the result of this task and completes with a result of this task.
andThen(Consumer4<T1, T2, T3, T4>) - Method in interface com.linkedin.parseq.Tuple4Task
Equivalent to andThen("andThen", consumer).
andThen(String, Consumer4<T1, T2, T3, T4>) - Method in interface com.linkedin.parseq.Tuple4Task
Creates a new task which applies a consumer to the result of this task and completes with a result of this task.
andThen(Consumer5<T1, T2, T3, T4, T5>) - Method in interface com.linkedin.parseq.Tuple5Task
Equivalent to andThen("andThen", consumer).
andThen(String, Consumer5<T1, T2, T3, T4, T5>) - Method in interface com.linkedin.parseq.Tuple5Task
Creates a new task which applies a consumer to the result of this task and completes with a result of this task.
andThen(Consumer6<T1, T2, T3, T4, T5, T6>) - Method in interface com.linkedin.parseq.Tuple6Task
Equivalent to andThen("andThen", consumer).
andThen(String, Consumer6<T1, T2, T3, T4, T5, T6>) - Method in interface com.linkedin.parseq.Tuple6Task
Creates a new task which applies a consumer to the result of this task and completes with a result of this task.
andThen(Consumer7<T1, T2, T3, T4, T5, T6, T7>) - Method in interface com.linkedin.parseq.Tuple7Task
Equivalent to andThen("andThen", consumer).
andThen(String, Consumer7<T1, T2, T3, T4, T5, T6, T7>) - Method in interface com.linkedin.parseq.Tuple7Task
Creates a new task which applies a consumer to the result of this task and completes with a result of this task.
andThen(Consumer8<T1, T2, T3, T4, T5, T6, T7, T8>) - Method in interface com.linkedin.parseq.Tuple8Task
Equivalent to andThen("andThen", consumer).
andThen(String, Consumer8<T1, T2, T3, T4, T5, T6, T7, T8>) - Method in interface com.linkedin.parseq.Tuple8Task
Creates a new task which applies a consumer to the result of this task and completes with a result of this task.
andThen(Consumer9<T1, T2, T3, T4, T5, T6, T7, T8, T9>) - Method in interface com.linkedin.parseq.Tuple9Task
Equivalent to andThen("andThen", consumer).
andThen(String, Consumer9<T1, T2, T3, T4, T5, T6, T7, T8, T9>) - Method in interface com.linkedin.parseq.Tuple9Task
Creates a new task which applies a consumer to the result of this task and completes with a result of this task.
apply(T1) - Method in interface com.linkedin.parseq.function.Function1
 
apply(T1) - Method in interface com.linkedin.parseq.function.Function1to2
 
apply(T1, T2) - Method in interface com.linkedin.parseq.function.Function2
 
apply(T1, T2, T3) - Method in interface com.linkedin.parseq.function.Function3
 
apply(T1, T2, T3, T4) - Method in interface com.linkedin.parseq.function.Function4
 
apply(T1, T2, T3, T4, T5) - Method in interface com.linkedin.parseq.function.Function5
 
apply(T1, T2, T3, T4, T5, T6) - Method in interface com.linkedin.parseq.function.Function6
 
apply(T1, T2, T3, T4, T5, T6, T7) - Method in interface com.linkedin.parseq.function.Function7
 
apply(T1, T2, T3, T4, T5, T6, T7, T8) - Method in interface com.linkedin.parseq.function.Function8
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in interface com.linkedin.parseq.function.Function9
 
apply(String, PromisePropagator<T, R>) - Method in interface com.linkedin.parseq.Task
 
arity() - Method in interface com.linkedin.parseq.function.Tuple
 
arity() - Method in class com.linkedin.parseq.function.Tuple2
 
arity() - Method in class com.linkedin.parseq.function.Tuple3
 
arity() - Method in class com.linkedin.parseq.function.Tuple4
 
arity() - Method in class com.linkedin.parseq.function.Tuple5
 
arity() - Method in class com.linkedin.parseq.function.Tuple6
 
arity() - Method in class com.linkedin.parseq.function.Tuple7
 
arity() - Method in class com.linkedin.parseq.function.Tuple8
 
arity() - Method in class com.linkedin.parseq.function.Tuple9
 
async(String, Callable<Promise<? extends T>>) - Static method in interface com.linkedin.parseq.Task
Creates a new task from a callable that returns a Promise.
async(Callable<Promise<? extends T>>) - Static method in interface com.linkedin.parseq.Task
Equivalent to async("async", callable).
async(String, Function1<Context, Promise<? extends T>>) - Static method in interface com.linkedin.parseq.Task
Creates a new task from a callable that returns a Promise.
async(Function1<Context, Promise<? extends T>>) - Static method in interface com.linkedin.parseq.Task
Equivalent to async("async", func).
AsyncCallableTask<R> - Class in com.linkedin.parseq
Deprecated.
As of 2.0.0, replaced by Task.blocking.
AsyncCallableTask(Callable<R>) - Constructor for class com.linkedin.parseq.AsyncCallableTask
Deprecated.
As of 2.0.0, replaced by Task.blocking.
AsyncCallableTask(String, Callable<R>) - Constructor for class com.linkedin.parseq.AsyncCallableTask
Deprecated.
As of 2.0.0, replaced by Task.blocking.
attempts(int, long) - Static method in interface com.linkedin.parseq.retry.RetryPolicy
Retry policy with configurable number of attempts.
attemptsAndDuration(int, long, long) - Static method in interface com.linkedin.parseq.retry.RetryPolicy
Retry policy with configurable number of retries and limited total duration of the encompassing task.
await() - Method in class com.linkedin.parseq.promise.DelegatingPromise
 
await(long, TimeUnit) - Method in class com.linkedin.parseq.promise.DelegatingPromise
 
await() - Method in interface com.linkedin.parseq.promise.Promise
Blocks the current thread for an unbounded amount of time until the promise has be resolved.
await(long, TimeUnit) - Method in interface com.linkedin.parseq.promise.Promise
Blocks the current thread for up to the specified amount of time or until the promise has been resolved.
await() - Method in class com.linkedin.parseq.promise.ResolvedError
 
await(long, TimeUnit) - Method in class com.linkedin.parseq.promise.ResolvedError
 
await() - Method in class com.linkedin.parseq.promise.ResolvedValue
 
await(long, TimeUnit) - Method in class com.linkedin.parseq.promise.ResolvedValue
 
await() - Method in class com.linkedin.parseq.Tuple2TaskDelegate
Blocks the current thread for an unbounded amount of time until the promise has be resolved.
await(long, TimeUnit) - Method in class com.linkedin.parseq.Tuple2TaskDelegate
Blocks the current thread for up to the specified amount of time or until the promise has been resolved.
await() - Method in class com.linkedin.parseq.Tuple3TaskDelegate
Blocks the current thread for an unbounded amount of time until the promise has be resolved.
await(long, TimeUnit) - Method in class com.linkedin.parseq.Tuple3TaskDelegate
Blocks the current thread for up to the specified amount of time or until the promise has been resolved.
await() - Method in class com.linkedin.parseq.Tuple4TaskDelegate
Blocks the current thread for an unbounded amount of time until the promise has be resolved.
await(long, TimeUnit) - Method in class com.linkedin.parseq.Tuple4TaskDelegate
Blocks the current thread for up to the specified amount of time or until the promise has been resolved.
await() - Method in class com.linkedin.parseq.Tuple5TaskDelegate
Blocks the current thread for an unbounded amount of time until the promise has be resolved.
await(long, TimeUnit) - Method in class com.linkedin.parseq.Tuple5TaskDelegate
Blocks the current thread for up to the specified amount of time or until the promise has been resolved.
await() - Method in class com.linkedin.parseq.Tuple6TaskDelegate
Blocks the current thread for an unbounded amount of time until the promise has be resolved.
await(long, TimeUnit) - Method in class com.linkedin.parseq.Tuple6TaskDelegate
Blocks the current thread for up to the specified amount of time or until the promise has been resolved.
await() - Method in class com.linkedin.parseq.Tuple7TaskDelegate
Blocks the current thread for an unbounded amount of time until the promise has be resolved.
await(long, TimeUnit) - Method in class com.linkedin.parseq.Tuple7TaskDelegate
Blocks the current thread for up to the specified amount of time or until the promise has been resolved.
await() - Method in class com.linkedin.parseq.Tuple8TaskDelegate
Blocks the current thread for an unbounded amount of time until the promise has be resolved.
await(long, TimeUnit) - Method in class com.linkedin.parseq.Tuple8TaskDelegate
Blocks the current thread for up to the specified amount of time or until the promise has been resolved.
await() - Method in class com.linkedin.parseq.Tuple9TaskDelegate
Blocks the current thread for an unbounded amount of time until the promise has be resolved.
await(long, TimeUnit) - Method in class com.linkedin.parseq.Tuple9TaskDelegate
Blocks the current thread for up to the specified amount of time or until the promise has been resolved.
awaitTermination(int, TimeUnit) - Method in class com.linkedin.parseq.Engine
Waits for the engine to stop.

B

BackoffPolicy - Interface in com.linkedin.parseq.retry.backoff
A strategy for computing a sequence of wait durations for use between retry attempts.
BaseTask<T> - Class in com.linkedin.parseq
An abstract base class that can be used to build implementations of Task.
BaseTask() - Constructor for class com.linkedin.parseq.BaseTask
Constructs a base task without a specified name.
BaseTask(String) - Constructor for class com.linkedin.parseq.BaseTask
Constructs a base task with a name.
BaseTask(String, String) - Constructor for class com.linkedin.parseq.BaseTask
Constructs a base task with a name and type of task
BaseTask.State - Class in com.linkedin.parseq
 
blocking(String, Callable<? extends T>, Executor) - Static method in interface com.linkedin.parseq.Task
This method provides a way to create an asynchronous task from a blocking or long running callables like JDBC requests.
blocking(Callable<? extends T>, Executor) - Static method in interface com.linkedin.parseq.Task
Equivalent to blocking("blocking", callable, executor).
blockingRun(Task<?>) - Method in class com.linkedin.parseq.Engine
Runs the given task.
blockingRun(Task<?>, String) - Method in class com.linkedin.parseq.Engine
Runs the given task.
build() - Method in class com.linkedin.parseq.EngineBuilder
Checks that the require configuration has been set and then constructs and returns a new Engine.
build() - Method in class com.linkedin.parseq.retry.RetryPolicyBuilder
 
build() - Method in class com.linkedin.parseq.trace.ShallowTraceBuilder
 
build() - Method in class com.linkedin.parseq.trace.TraceBuilder
 

C

call() - Method in interface com.linkedin.parseq.ThrowableCallable
Deprecated.
Computes a value of type T or throws a Throwable if an error occurred during the computation.
callable(String, Callable<? extends T>) - Static method in interface com.linkedin.parseq.Task
Creates a new task that's value will be set to the value returned from the supplied callable.
callable(Callable<? extends T>) - Static method in interface com.linkedin.parseq.Task
Equivalent to callable("callable", callable).
callable(String, Callable<? extends T>) - Static method in class com.linkedin.parseq.Tasks
Deprecated.
As of 2.0.0, replaced by Task.callable
callable(String, ThrowableCallable<? extends T>) - Static method in class com.linkedin.parseq.Tasks
Deprecated.
As of 2.0.0, replaced by Task.callable
CallableTask<T> - Class in com.linkedin.parseq
Deprecated.
As of 2.0.0, replaced by Task.callable.
CallableTask(String, Callable<? extends T>) - Constructor for class com.linkedin.parseq.CallableTask
Deprecated.
 
CallableTask(String, ThrowableCallable<? extends T>) - Constructor for class com.linkedin.parseq.CallableTask
Deprecated.
 
cancel(Exception) - Method in class com.linkedin.parseq.BaseTask
 
cancel(Exception) - Method in interface com.linkedin.parseq.Cancellable
Attempts to cancel the object with the given reason.
cancel(Exception) - Method in class com.linkedin.parseq.Tuple2TaskDelegate
Attempts to cancel the object with the given reason.
cancel(Exception) - Method in class com.linkedin.parseq.Tuple3TaskDelegate
Attempts to cancel the object with the given reason.
cancel(Exception) - Method in class com.linkedin.parseq.Tuple4TaskDelegate
Attempts to cancel the object with the given reason.
cancel(Exception) - Method in class com.linkedin.parseq.Tuple5TaskDelegate
Attempts to cancel the object with the given reason.
cancel(Exception) - Method in class com.linkedin.parseq.Tuple6TaskDelegate
Attempts to cancel the object with the given reason.
cancel(Exception) - Method in class com.linkedin.parseq.Tuple7TaskDelegate
Attempts to cancel the object with the given reason.
cancel(Exception) - Method in class com.linkedin.parseq.Tuple8TaskDelegate
Attempts to cancel the object with the given reason.
cancel(Exception) - Method in class com.linkedin.parseq.Tuple9TaskDelegate
Attempts to cancel the object with the given reason.
Cancellable - Interface in com.linkedin.parseq
An object that can be cancelled with a reason.
cast(Task<Tuple2<T1, T2>>) - Static method in interface com.linkedin.parseq.Tuple2Task
 
cast(Task<Tuple3<T1, T2, T3>>) - Static method in interface com.linkedin.parseq.Tuple3Task
 
cast(Task<Tuple4<T1, T2, T3, T4>>) - Static method in interface com.linkedin.parseq.Tuple4Task
 
cast(Task<Tuple5<T1, T2, T3, T4, T5>>) - Static method in interface com.linkedin.parseq.Tuple5Task
 
cast(Task<Tuple6<T1, T2, T3, T4, T5, T6>>) - Static method in interface com.linkedin.parseq.Tuple6Task
 
cast(Task<Tuple7<T1, T2, T3, T4, T5, T6, T7>>) - Static method in interface com.linkedin.parseq.Tuple7Task
 
cast(Task<Tuple8<T1, T2, T3, T4, T5, T6, T7, T8>>) - Static method in interface com.linkedin.parseq.Tuple8Task
 
cast(Task<Tuple9<T1, T2, T3, T4, T5, T6, T7, T8, T9>>) - Static method in interface com.linkedin.parseq.Tuple9Task
 
com.linkedin.parseq - package com.linkedin.parseq
Core ParSeq classes.
com.linkedin.parseq.function - package com.linkedin.parseq.function
 
com.linkedin.parseq.promise - package com.linkedin.parseq.promise
Promises are like Futures, but they provide a listener mechanism to wait for completion asynchronously.
com.linkedin.parseq.retry - package com.linkedin.parseq.retry
 
com.linkedin.parseq.retry.backoff - package com.linkedin.parseq.retry.backoff
 
com.linkedin.parseq.retry.termination - package com.linkedin.parseq.retry.termination
 
com.linkedin.parseq.trace - package com.linkedin.parseq.trace
Tracing related APIs and functionality.
com.linkedin.parseq.trace.codec - package com.linkedin.parseq.trace.codec
Trace codec API.
com.linkedin.parseq.trace.codec.json - package com.linkedin.parseq.trace.codec.json
Trace codec specific to the JSON format.
compose(PromisePropagator<T, R>) - Method in interface com.linkedin.parseq.promise.PromisePropagator
 
compose(PromisePropagator<T, R>) - Method in class com.linkedin.parseq.promise.PromiseTransformer
 
constant(long) - Static method in interface com.linkedin.parseq.retry.backoff.BackoffPolicy
A policy that uses the same backoff after every retry.
ConstantBackoff - Class in com.linkedin.parseq.retry.backoff
A policy that uses the same backoff after every retry.
ConstantBackoff(long) - Constructor for class com.linkedin.parseq.retry.backoff.ConstantBackoff
A policy that uses the same backoff after every retry.
Consumer1<T1> - Interface in com.linkedin.parseq.function
 
Consumer2<T1,T2> - Interface in com.linkedin.parseq.function
 
Consumer3<T1,T2,T3> - Interface in com.linkedin.parseq.function
 
Consumer4<T1,T2,T3,T4> - Interface in com.linkedin.parseq.function
 
Consumer5<T1,T2,T3,T4,T5> - Interface in com.linkedin.parseq.function
 
Consumer6<T1,T2,T3,T4,T5,T6> - Interface in com.linkedin.parseq.function
 
Consumer7<T1,T2,T3,T4,T5,T6,T7> - Interface in com.linkedin.parseq.function
 
Consumer8<T1,T2,T3,T4,T5,T6,T7,T8> - Interface in com.linkedin.parseq.function
 
Consumer9<T1,T2,T3,T4,T5,T6,T7,T8,T9> - Interface in com.linkedin.parseq.function
 
Context - Interface in com.linkedin.parseq
A context provides an API to Tasks for the purpose of scheduling other tasks.
contextRun(Context, Task<?>, Collection<Task<?>>) - Method in class com.linkedin.parseq.BaseTask
 
contextRun(Context, Task<?>, Collection<Task<?>>) - Method in interface com.linkedin.parseq.Task
Attempts to run the task with the given context.
contextRun(Context, Task<?>, Collection<Task<?>>) - Method in class com.linkedin.parseq.Tuple2TaskDelegate
Attempts to run the task with the given context.
contextRun(Context, Task<?>, Collection<Task<?>>) - Method in class com.linkedin.parseq.Tuple3TaskDelegate
Attempts to run the task with the given context.
contextRun(Context, Task<?>, Collection<Task<?>>) - Method in class com.linkedin.parseq.Tuple4TaskDelegate
Attempts to run the task with the given context.
contextRun(Context, Task<?>, Collection<Task<?>>) - Method in class com.linkedin.parseq.Tuple5TaskDelegate
Attempts to run the task with the given context.
contextRun(Context, Task<?>, Collection<Task<?>>) - Method in class com.linkedin.parseq.Tuple6TaskDelegate
Attempts to run the task with the given context.
contextRun(Context, Task<?>, Collection<Task<?>>) - Method in class com.linkedin.parseq.Tuple7TaskDelegate
Attempts to run the task with the given context.
contextRun(Context, Task<?>, Collection<Task<?>>) - Method in class com.linkedin.parseq.Tuple8TaskDelegate
Attempts to run the task with the given context.
contextRun(Context, Task<?>, Collection<Task<?>>) - Method in class com.linkedin.parseq.Tuple9TaskDelegate
Attempts to run the task with the given context.
CountDownPromiseListener<T> - Class in com.linkedin.parseq.promise
Sets a value on a SettablePromise after this listener has been notified of a specified number of promise resolutions.
CountDownPromiseListener(int, SettablePromise<T>, T) - Constructor for class com.linkedin.parseq.promise.CountDownPromiseListener
 
createTimer(long, TimeUnit, Task<?>) - Method in interface com.linkedin.parseq.Context
Creates a timer that will invoke the given task if the calling task has not yet finished.

D

decode(InputStream) - Method in class com.linkedin.parseq.trace.codec.json.JsonTraceCodec
 
decode(String) - Method in class com.linkedin.parseq.trace.codec.json.JsonTraceCodec
 
decode(InputStream) - Method in interface com.linkedin.parseq.trace.codec.TraceCodec
Decode the InputStream to an Trace.
decode(String) - Method in interface com.linkedin.parseq.trace.codec.TraceCodec
Similar to TraceCodec.decode(java.io.InputStream) but takes a String instead of an InputStream.
DEFAULT - Static variable in enum com.linkedin.parseq.retry.ErrorClassification
Default error classification: non-fatal errors are recoverable, and fatal errors are not recoverable.
DEFAULT_PRIORITY - Static variable in class com.linkedin.parseq.Priority
Tasks with default priority can be run in any arbitrary order w.r.t to other tasks of default priority.
DEFAULT_TASK_QUEUE - Static variable in class com.linkedin.parseq.Engine
 
DelayedExecutor - Interface in com.linkedin.parseq
An object that allows a task to be scheduled for execution after some delay.
DelayedExecutorAdapter - Class in com.linkedin.parseq
Adapts a ScheduledExecutorService to the simpler DelayedExecutor interface.
DelayedExecutorAdapter(ScheduledExecutorService) - Constructor for class com.linkedin.parseq.DelayedExecutorAdapter
 
DelegatingPromise<T> - Class in com.linkedin.parseq.promise
An abstract class that makes it easy to delegate Promise method invocations to a delegate promise.
DelegatingPromise(Promise<T>) - Constructor for class com.linkedin.parseq.promise.DelegatingPromise
 
DONE - Static variable in class com.linkedin.parseq.BaseTask.State
 
done(P) - Method in interface com.linkedin.parseq.promise.Settable
Sets the value for this promise to the given value.
DRAIN_SERIAL_EXECUTOR_QUEUE - Static variable in class com.linkedin.parseq.Engine
 
duration(long, long) - Static method in interface com.linkedin.parseq.retry.RetryPolicy
Retry policy with limited total duration of the encompassing task (including unlimited retries).

E

EARLY_FINISH_EXCEPTION - Static variable in class com.linkedin.parseq.Exceptions
 
EarlyFinishException - Exception in com.linkedin.parseq
This exception indicates that a task was cancelled because its parent was resolved (a value was set for the parent) before the task itself was resolved.
EarlyFinishException() - Constructor for exception com.linkedin.parseq.EarlyFinishException
 
EarlyFinishException(String) - Constructor for exception com.linkedin.parseq.EarlyFinishException
 
encode(Trace, OutputStream) - Method in class com.linkedin.parseq.trace.codec.json.JsonTraceCodec
 
encode(Trace) - Method in class com.linkedin.parseq.trace.codec.json.JsonTraceCodec
 
encode(Trace, OutputStream) - Method in interface com.linkedin.parseq.trace.codec.TraceCodec
Encodes a Trace to an OutputStream.
encode(Trace) - Method in interface com.linkedin.parseq.trace.codec.TraceCodec
Similar to TraceCodec.encode(com.linkedin.parseq.trace.Trace, java.io.OutputStream) but produces a String that contains the trace instead of writing it to an OutputStream.
Engine - Class in com.linkedin.parseq
An object that can run a set Tasks.
EngineBuilder - Class in com.linkedin.parseq
A configurable builder that makes Engines.
EngineBuilder() - Constructor for class com.linkedin.parseq.EngineBuilder
 
EngineShutdownException - Exception in com.linkedin.parseq
This exception is raised when a Task is submitted to an engine after the engine has been shutdown.
EngineShutdownException(String) - Constructor for exception com.linkedin.parseq.EngineShutdownException
 
equals(Object) - Method in class com.linkedin.parseq.function.Failure
 
equals(Object) - Method in class com.linkedin.parseq.function.Success
 
equals(Object) - Method in class com.linkedin.parseq.function.Tuple2
 
equals(Object) - Method in class com.linkedin.parseq.function.Tuple3
 
equals(Object) - Method in class com.linkedin.parseq.function.Tuple4
 
equals(Object) - Method in class com.linkedin.parseq.function.Tuple5
 
equals(Object) - Method in class com.linkedin.parseq.function.Tuple6
 
equals(Object) - Method in class com.linkedin.parseq.function.Tuple7
 
equals(Object) - Method in class com.linkedin.parseq.function.Tuple8
 
equals(Object) - Method in class com.linkedin.parseq.function.Tuple9
 
equals(Object) - Method in class com.linkedin.parseq.trace.ShallowTraceImp
 
equals(Object) - Method in class com.linkedin.parseq.trace.Trace
 
equals(Object) - Method in class com.linkedin.parseq.trace.TraceRelationship
 
error(Throwable) - Static method in class com.linkedin.parseq.promise.Promises
Creates a new promise that is already resolved with the given error.
ErrorClassification - Enum in com.linkedin.parseq.retry
Definitions of the supported error classifications and the default classification function.
Exceptions - Class in com.linkedin.parseq
 
EXECUTION_MONITOR_CHECK_INTERVAL_NANO - Static variable in class com.linkedin.parseq.Engine
 
EXECUTION_MONITOR_DURATION_THRESHOLD_NANO - Static variable in class com.linkedin.parseq.Engine
 
EXECUTION_MONITOR_IDLE_DURATION_NANO - Static variable in class com.linkedin.parseq.Engine
 
EXECUTION_MONITOR_LOG_LEVEL - Static variable in class com.linkedin.parseq.Engine
 
EXECUTION_MONITOR_LOGGING_INTERVAL_NANO - Static variable in class com.linkedin.parseq.Engine
 
EXECUTION_MONITOR_MIN_STALL_NANO - Static variable in class com.linkedin.parseq.Engine
 
EXECUTION_MONITOR_STALLS_HISTORY_SIZE - Static variable in class com.linkedin.parseq.Engine
 
exponential(long) - Static method in interface com.linkedin.parseq.retry.backoff.BackoffPolicy
A policy that doubles the backoff duration after every attempt.
ExponentialBackoff - Class in com.linkedin.parseq.retry.backoff
A policy that doubles the backoff duration after every attempt.
ExponentialBackoff(long) - Constructor for class com.linkedin.parseq.retry.backoff.ExponentialBackoff
A policy that doubles the backoff duration after every attempt.

F

fail(Throwable) - Method in interface com.linkedin.parseq.promise.Settable
Sets an error on this promise.
Failure<T> - Class in com.linkedin.parseq.function
 
failure(String, Throwable) - Static method in interface com.linkedin.parseq.Task
Creates a new task that will be fail with given exception when it is executed.
failure(Throwable) - Static method in interface com.linkedin.parseq.Task
Equivalent to failure("failure", failure).
failureToString(Throwable) - Static method in class com.linkedin.parseq.Exceptions
 
FastFailCountDownPromiseListener<T> - Class in com.linkedin.parseq.promise
Sets a value on a SettablePromise after this listener has been notified of a specified number of promise resolutions.
FastFailCountDownPromiseListener(int, SettablePromise<T>, T) - Constructor for class com.linkedin.parseq.promise.FastFailCountDownPromiseListener
 
fibonacci(long) - Static method in interface com.linkedin.parseq.retry.backoff.BackoffPolicy
A policy that increases the initial backoff duration by repeatedly multiplying by an approximation of the golden ratio (8 / 5, the sixth and fifth fibonacci numbers) (in milliseconds).
FibonacciBackoff - Class in com.linkedin.parseq.retry.backoff
A policy that increases the initial backoff duration by repeatedly multiplying by an approximation of the golden ratio (8 / 5, the sixth and fifth fibonacci numbers).
FibonacciBackoff(long) - Constructor for class com.linkedin.parseq.retry.backoff.FibonacciBackoff
A policy that increases the initial backoff duration by repeatedly multiplying by an approximation of the golden ratio (8 / 5, the sixth and fifth fibonacci numbers).
flatMap(String, Function1<? super T, Task<R>>) - Method in interface com.linkedin.parseq.Task
Creates a new task by applying a function to the successful result of this task and returns the result of a function as the new task.
flatMap(Function1<? super T, Task<R>>) - Method in interface com.linkedin.parseq.Task
Equivalent to flatMap("flatMap", func).
flatMap(Function2<T1, T2, Task<R>>) - Method in interface com.linkedin.parseq.Tuple2Task
Equivalent to flatMap("flatMap", f).
flatMap(String, Function2<T1, T2, Task<R>>) - Method in interface com.linkedin.parseq.Tuple2Task
Creates a new task by applying a function to the successful result of this task and returns the result of a function as the new task.
flatMap(Function3<T1, T2, T3, Task<R>>) - Method in interface com.linkedin.parseq.Tuple3Task
Equivalent to flatMap("flatMap", f).
flatMap(String, Function3<T1, T2, T3, Task<R>>) - Method in interface com.linkedin.parseq.Tuple3Task
Creates a new task by applying a function to the successful result of this task and returns the result of a function as the new task.
flatMap(Function4<T1, T2, T3, T4, Task<R>>) - Method in interface com.linkedin.parseq.Tuple4Task
Equivalent to flatMap("flatMap", f).
flatMap(String, Function4<T1, T2, T3, T4, Task<R>>) - Method in interface com.linkedin.parseq.Tuple4Task
Creates a new task by applying a function to the successful result of this task and returns the result of a function as the new task.
flatMap(Function5<T1, T2, T3, T4, T5, Task<R>>) - Method in interface com.linkedin.parseq.Tuple5Task
Equivalent to flatMap("flatMap", f).
flatMap(String, Function5<T1, T2, T3, T4, T5, Task<R>>) - Method in interface com.linkedin.parseq.Tuple5Task
Creates a new task by applying a function to the successful result of this task and returns the result of a function as the new task.
flatMap(Function6<T1, T2, T3, T4, T5, T6, Task<R>>) - Method in interface com.linkedin.parseq.Tuple6Task
Equivalent to flatMap("flatMap", f).
flatMap(String, Function6<T1, T2, T3, T4, T5, T6, Task<R>>) - Method in interface com.linkedin.parseq.Tuple6Task
Creates a new task by applying a function to the successful result of this task and returns the result of a function as the new task.
flatMap(Function7<T1, T2, T3, T4, T5, T6, T7, Task<R>>) - Method in interface com.linkedin.parseq.Tuple7Task
Equivalent to flatMap("flatMap", f).
flatMap(String, Function7<T1, T2, T3, T4, T5, T6, T7, Task<R>>) - Method in interface com.linkedin.parseq.Tuple7Task
Creates a new task by applying a function to the successful result of this task and returns the result of a function as the new task.
flatMap(Function8<T1, T2, T3, T4, T5, T6, T7, T8, Task<R>>) - Method in interface com.linkedin.parseq.Tuple8Task
Equivalent to flatMap("flatMap", f).
flatMap(String, Function8<T1, T2, T3, T4, T5, T6, T7, T8, Task<R>>) - Method in interface com.linkedin.parseq.Tuple8Task
Creates a new task by applying a function to the successful result of this task and returns the result of a function as the new task.
flatMap(Function9<T1, T2, T3, T4, T5, T6, T7, T8, T9, Task<R>>) - Method in interface com.linkedin.parseq.Tuple9Task
Equivalent to flatMap("flatMap", f).
flatMap(String, Function9<T1, T2, T3, T4, T5, T6, T7, T8, T9, Task<R>>) - Method in interface com.linkedin.parseq.Tuple9Task
Creates a new task by applying a function to the successful result of this task and returns the result of a function as the new task.
flatten(String, Task<Task<R>>) - Static method in interface com.linkedin.parseq.Task
Converts Task<Task<R>> into Task<R>.
flatten(Task<Task<R>>) - Static method in interface com.linkedin.parseq.Task
Equivalent to flatten("flatten", task).
fromTask(Task<?>) - Static method in enum com.linkedin.parseq.trace.ResultType
Given a task this method will return a ResultType classification.
Function1<T1,R> - Interface in com.linkedin.parseq.function
 
Function1to2<T1,A,B> - Interface in com.linkedin.parseq.function
 
Function2<T1,T2,R> - Interface in com.linkedin.parseq.function
 
Function3<T1,T2,T3,R> - Interface in com.linkedin.parseq.function
 
Function4<T1,T2,T3,T4,R> - Interface in com.linkedin.parseq.function
 
Function5<T1,T2,T3,T4,T5,R> - Interface in com.linkedin.parseq.function
 
Function6<T1,T2,T3,T4,T5,T6,R> - Interface in com.linkedin.parseq.function
 
Function7<T1,T2,T3,T4,T5,T6,T7,R> - Interface in com.linkedin.parseq.function
 
Function8<T1,T2,T3,T4,T5,T6,T7,T8,R> - Interface in com.linkedin.parseq.function
 
Function9<T1,T2,T3,T4,T5,T6,T7,T8,T9,R> - Interface in com.linkedin.parseq.function
 

G

get() - Method in class com.linkedin.parseq.function.Failure
 
get() - Method in class com.linkedin.parseq.function.Success
 
get() - Method in interface com.linkedin.parseq.function.Try
Returns value associated with successful completion or NoSuchElementException if result represents a failure.
get() - Method in class com.linkedin.parseq.promise.DelegatingPromise
 
get() - Method in interface com.linkedin.parseq.promise.Promise
If the promise's value is set, then this method returns the value.
get() - Method in class com.linkedin.parseq.promise.ResolvedError
 
get() - Method in class com.linkedin.parseq.promise.ResolvedValue
 
get() - Method in class com.linkedin.parseq.Tuple2TaskDelegate
If the promise's value is set, then this method returns the value.
get() - Method in class com.linkedin.parseq.Tuple3TaskDelegate
If the promise's value is set, then this method returns the value.
get() - Method in class com.linkedin.parseq.Tuple4TaskDelegate
If the promise's value is set, then this method returns the value.
get() - Method in class com.linkedin.parseq.Tuple5TaskDelegate
If the promise's value is set, then this method returns the value.
get() - Method in class com.linkedin.parseq.Tuple6TaskDelegate
If the promise's value is set, then this method returns the value.
get() - Method in class com.linkedin.parseq.Tuple7TaskDelegate
If the promise's value is set, then this method returns the value.
get() - Method in class com.linkedin.parseq.Tuple8TaskDelegate
If the promise's value is set, then this method returns the value.
get() - Method in class com.linkedin.parseq.Tuple9TaskDelegate
If the promise's value is set, then this method returns the value.
getAttributes() - Method in interface com.linkedin.parseq.trace.ShallowTrace
Get the set of attributes related to this trace.
getAttributes() - Method in class com.linkedin.parseq.trace.ShallowTraceBuilder
 
getAttributes() - Method in class com.linkedin.parseq.trace.ShallowTraceImp
 
getBackoffPolicy() - Method in interface com.linkedin.parseq.retry.RetryPolicy
 
getCauses() - Method in exception com.linkedin.parseq.MultiException
 
getDelegate() - Method in class com.linkedin.parseq.promise.DelegatingPromise
 
getDescription(String) - Method in interface com.linkedin.parseq.TaskDescriptor
Give class name which could correspond to generated lambda expressions etc infer appropriate description for it If it is unable to infer description, it returns className
getEndNanos() - Method in interface com.linkedin.parseq.trace.ShallowTrace
Returns the time at which the task was finished in nanoseconds.
getEndNanos() - Method in class com.linkedin.parseq.trace.ShallowTraceBuilder
 
getEndNanos() - Method in class com.linkedin.parseq.trace.ShallowTraceImp
 
getEngineProperty(String) - Method in interface com.linkedin.parseq.Context
Provides a mechanism for "plugins" to generate data which should be passed in via the context.
getError() - Method in class com.linkedin.parseq.function.Failure
 
getError() - Method in class com.linkedin.parseq.function.Success
 
getError() - Method in interface com.linkedin.parseq.function.Try
Returns Throwable associated with this failure or null if result represents successful completion.
getError() - Method in class com.linkedin.parseq.promise.DelegatingPromise
 
getError() - Method in interface com.linkedin.parseq.promise.Promise
Returns the error in this promise, if there is one.
getError() - Method in class com.linkedin.parseq.promise.ResolvedError
 
getError() - Method in class com.linkedin.parseq.promise.ResolvedValue
 
getError() - Method in class com.linkedin.parseq.Tuple2TaskDelegate
Returns the error in this promise, if there is one.
getError() - Method in class com.linkedin.parseq.Tuple3TaskDelegate
Returns the error in this promise, if there is one.
getError() - Method in class com.linkedin.parseq.Tuple4TaskDelegate
Returns the error in this promise, if there is one.
getError() - Method in class com.linkedin.parseq.Tuple5TaskDelegate
Returns the error in this promise, if there is one.
getError() - Method in class com.linkedin.parseq.Tuple6TaskDelegate
Returns the error in this promise, if there is one.
getError() - Method in class com.linkedin.parseq.Tuple7TaskDelegate
Returns the error in this promise, if there is one.
getError() - Method in class com.linkedin.parseq.Tuple8TaskDelegate
Returns the error in this promise, if there is one.
getError() - Method in class com.linkedin.parseq.Tuple9TaskDelegate
Returns the error in this promise, if there is one.
getErrorClassifier() - Method in interface com.linkedin.parseq.retry.RetryPolicy
 
getFrom() - Method in class com.linkedin.parseq.trace.TraceRelationship
 
getHidden() - Method in interface com.linkedin.parseq.trace.ShallowTrace
Returns if the trace will be hidden from the visualizations.
getHidden() - Method in class com.linkedin.parseq.trace.ShallowTraceBuilder
 
getHidden() - Method in class com.linkedin.parseq.trace.ShallowTraceImp
 
getId() - Method in class com.linkedin.parseq.BaseTask
 
getId() - Method in interface com.linkedin.parseq.Task
Unique identifier of the task.
getId() - Method in interface com.linkedin.parseq.trace.ShallowTrace
Id of this trace.
getId() - Method in class com.linkedin.parseq.trace.ShallowTraceBuilder
 
getId() - Method in class com.linkedin.parseq.trace.ShallowTraceImp
 
getId() - Method in class com.linkedin.parseq.Tuple2TaskDelegate
Unique identifier of the task.
getId() - Method in class com.linkedin.parseq.Tuple3TaskDelegate
Unique identifier of the task.
getId() - Method in class com.linkedin.parseq.Tuple4TaskDelegate
Unique identifier of the task.
getId() - Method in class com.linkedin.parseq.Tuple5TaskDelegate
Unique identifier of the task.
getId() - Method in class com.linkedin.parseq.Tuple6TaskDelegate
Unique identifier of the task.
getId() - Method in class com.linkedin.parseq.Tuple7TaskDelegate
Unique identifier of the task.
getId() - Method in class com.linkedin.parseq.Tuple8TaskDelegate
Unique identifier of the task.
getId() - Method in class com.linkedin.parseq.Tuple9TaskDelegate
Unique identifier of the task.
getJsonTrace(Task<?>) - Static method in class com.linkedin.parseq.trace.TraceUtil
Returns trace of a task serialized to a JSON string.
getJsonTrace(Trace) - Static method in class com.linkedin.parseq.trace.TraceUtil
Returns trace serialized to a JSON string.
getName() - Method in class com.linkedin.parseq.BaseTask
Returns the name of this task.
getName() - Method in interface com.linkedin.parseq.retry.RetryPolicy
 
getName() - Method in interface com.linkedin.parseq.Task
Returns the name of this task.
getName() - Method in enum com.linkedin.parseq.TaskType
 
getName() - Method in interface com.linkedin.parseq.trace.ShallowTrace
Returns the task name for this trace
getName() - Method in class com.linkedin.parseq.trace.ShallowTraceBuilder
 
getName() - Method in class com.linkedin.parseq.trace.ShallowTraceImp
 
getName() - Method in class com.linkedin.parseq.Tuple2TaskDelegate
Returns the name of this task.
getName() - Method in class com.linkedin.parseq.Tuple3TaskDelegate
Returns the name of this task.
getName() - Method in class com.linkedin.parseq.Tuple4TaskDelegate
Returns the name of this task.
getName() - Method in class com.linkedin.parseq.Tuple5TaskDelegate
Returns the name of this task.
getName() - Method in class com.linkedin.parseq.Tuple6TaskDelegate
Returns the name of this task.
getName() - Method in class com.linkedin.parseq.Tuple7TaskDelegate
Returns the name of this task.
getName() - Method in class com.linkedin.parseq.Tuple8TaskDelegate
Returns the name of this task.
getName() - Method in class com.linkedin.parseq.Tuple9TaskDelegate
Returns the name of this task.
getOrDefault(T) - Method in class com.linkedin.parseq.promise.DelegatingPromise
 
getOrDefault(P) - Method in interface com.linkedin.parseq.promise.Promise
Gets the value in this promise or, if the promise contains an error, returns the given default value.
getOrDefault(T) - Method in class com.linkedin.parseq.promise.ResolvedError
 
getOrDefault(T) - Method in class com.linkedin.parseq.promise.ResolvedValue
 
getOrDefault(Tuple2<T1, T2>) - Method in class com.linkedin.parseq.Tuple2TaskDelegate
Gets the value in this promise or, if the promise contains an error, returns the given default value.
getOrDefault(Tuple3<T1, T2, T3>) - Method in class com.linkedin.parseq.Tuple3TaskDelegate
Gets the value in this promise or, if the promise contains an error, returns the given default value.
getOrDefault(Tuple4<T1, T2, T3, T4>) - Method in class com.linkedin.parseq.Tuple4TaskDelegate
Gets the value in this promise or, if the promise contains an error, returns the given default value.
getOrDefault(Tuple5<T1, T2, T3, T4, T5>) - Method in class com.linkedin.parseq.Tuple5TaskDelegate
Gets the value in this promise or, if the promise contains an error, returns the given default value.
getOrDefault(Tuple6<T1, T2, T3, T4, T5, T6>) - Method in class com.linkedin.parseq.Tuple6TaskDelegate
Gets the value in this promise or, if the promise contains an error, returns the given default value.
getOrDefault(Tuple7<T1, T2, T3, T4, T5, T6, T7>) - Method in class com.linkedin.parseq.Tuple7TaskDelegate
Gets the value in this promise or, if the promise contains an error, returns the given default value.
getOrDefault(Tuple8<T1, T2, T3, T4, T5, T6, T7, T8>) - Method in class com.linkedin.parseq.Tuple8TaskDelegate
Gets the value in this promise or, if the promise contains an error, returns the given default value.
getOrDefault(Tuple9<T1, T2, T3, T4, T5, T6, T7, T8, T9>) - Method in class com.linkedin.parseq.Tuple9TaskDelegate
Gets the value in this promise or, if the promise contains an error, returns the given default value.
getPendingNanos() - Method in interface com.linkedin.parseq.trace.ShallowTrace
Returns the time at which the task finished its run method in nanoseconds.
getPendingNanos() - Method in class com.linkedin.parseq.trace.ShallowTraceBuilder
 
getPendingNanos() - Method in class com.linkedin.parseq.trace.ShallowTraceImp
 
getPlanClass() - Method in interface com.linkedin.parseq.Context
 
getPlanClass() - Method in class com.linkedin.parseq.trace.Trace
 
getPlanId() - Method in interface com.linkedin.parseq.Context
 
getPlanId() - Method in class com.linkedin.parseq.trace.Trace
 
getPriority() - Method in class com.linkedin.parseq.BaseTask
 
getPriority() - Method in class com.linkedin.parseq.BaseTask.State
 
getPriority() - Method in interface com.linkedin.parseq.Task
Returns the priority for this task.
getPriority() - Method in class com.linkedin.parseq.Tuple2TaskDelegate
Returns the priority for this task.
getPriority() - Method in class com.linkedin.parseq.Tuple3TaskDelegate
Returns the priority for this task.
getPriority() - Method in class com.linkedin.parseq.Tuple4TaskDelegate
Returns the priority for this task.
getPriority() - Method in class com.linkedin.parseq.Tuple5TaskDelegate
Returns the priority for this task.
getPriority() - Method in class com.linkedin.parseq.Tuple6TaskDelegate
Returns the priority for this task.
getPriority() - Method in class com.linkedin.parseq.Tuple7TaskDelegate
Returns the priority for this task.
getPriority() - Method in class com.linkedin.parseq.Tuple8TaskDelegate
Returns the priority for this task.
getPriority() - Method in class com.linkedin.parseq.Tuple9TaskDelegate
Returns the priority for this task.
getProperty(String) - Method in class com.linkedin.parseq.Engine
 
getRelationhsip() - Method in class com.linkedin.parseq.trace.TraceRelationship
 
getRelationships() - Method in class com.linkedin.parseq.trace.Trace
 
getResultType() - Method in interface com.linkedin.parseq.trace.ShallowTrace
Returns the result type of the task.
getResultType() - Method in class com.linkedin.parseq.trace.ShallowTraceBuilder
 
getResultType() - Method in class com.linkedin.parseq.trace.ShallowTraceImp
 
getSettableDelegate() - Method in class com.linkedin.parseq.BaseTask
 
getShallowTrace() - Method in class com.linkedin.parseq.BaseTask
 
getShallowTrace() - Method in interface com.linkedin.parseq.Task
Returns the ShallowTrace for this task.
getShallowTrace() - Method in class com.linkedin.parseq.Tuple2TaskDelegate
Returns the ShallowTrace for this task.
getShallowTrace() - Method in class com.linkedin.parseq.Tuple3TaskDelegate
Returns the ShallowTrace for this task.
getShallowTrace() - Method in class com.linkedin.parseq.Tuple4TaskDelegate
Returns the ShallowTrace for this task.
getShallowTrace() - Method in class com.linkedin.parseq.Tuple5TaskDelegate
Returns the ShallowTrace for this task.
getShallowTrace() - Method in class com.linkedin.parseq.Tuple6TaskDelegate
Returns the ShallowTrace for this task.
getShallowTrace() - Method in class com.linkedin.parseq.Tuple7TaskDelegate
Returns the ShallowTrace for this task.
getShallowTrace() - Method in class com.linkedin.parseq.Tuple8TaskDelegate
Returns the ShallowTrace for this task.
getShallowTrace() - Method in class com.linkedin.parseq.Tuple9TaskDelegate
Returns the ShallowTrace for this task.
getShallowTraceBuilder() - Method in class com.linkedin.parseq.BaseTask
 
getShallowTraceBuilder() - Method in interface com.linkedin.parseq.Context
 
getShallowTraceBuilder() - Method in interface com.linkedin.parseq.Task
 
getShallowTraceBuilder() - Method in class com.linkedin.parseq.Tuple2TaskDelegate
 
getShallowTraceBuilder() - Method in class com.linkedin.parseq.Tuple3TaskDelegate
 
getShallowTraceBuilder() - Method in class com.linkedin.parseq.Tuple4TaskDelegate
 
getShallowTraceBuilder() - Method in class com.linkedin.parseq.Tuple5TaskDelegate
 
getShallowTraceBuilder() - Method in class com.linkedin.parseq.Tuple6TaskDelegate
 
getShallowTraceBuilder() - Method in class com.linkedin.parseq.Tuple7TaskDelegate
 
getShallowTraceBuilder() - Method in class com.linkedin.parseq.Tuple8TaskDelegate
 
getShallowTraceBuilder() - Method in class com.linkedin.parseq.Tuple9TaskDelegate
 
getStartNanos() - Method in interface com.linkedin.parseq.trace.ShallowTrace
Returns the time at which the task was started in nanoseconds.
getStartNanos() - Method in class com.linkedin.parseq.trace.ShallowTraceBuilder
 
getStartNanos() - Method in class com.linkedin.parseq.trace.ShallowTraceImp
 
getSuccessful() - Method in interface com.linkedin.parseq.ParTask
Get the list of successful values.
getSystemHidden() - Method in interface com.linkedin.parseq.trace.ShallowTrace
Returns if the trace will be system hidden from the visualizations.
getSystemHidden() - Method in class com.linkedin.parseq.trace.ShallowTraceBuilder
 
getSystemHidden() - Method in class com.linkedin.parseq.trace.ShallowTraceImp
 
getTaskId() - Method in interface com.linkedin.parseq.Context
 
getTaskLogger() - Method in interface com.linkedin.parseq.Context
 
getTasks() - Method in interface com.linkedin.parseq.ParTask
Return the list of tasks that were related to this task.
getTaskType() - Method in interface com.linkedin.parseq.trace.ShallowTrace
Returns type (sideEffect, seq, par, timer etc) of the task
getTaskType() - Method in class com.linkedin.parseq.trace.ShallowTraceBuilder
 
getTaskType() - Method in class com.linkedin.parseq.trace.ShallowTraceImp
 
getTerminationPolicy() - Method in interface com.linkedin.parseq.retry.RetryPolicy
 
getTo() - Method in class com.linkedin.parseq.trace.TraceRelationship
 
getTrace() - Method in class com.linkedin.parseq.BaseTask
 
getTrace() - Method in interface com.linkedin.parseq.Task
Returns the Trace for this task.
getTrace() - Method in class com.linkedin.parseq.Tuple2TaskDelegate
Returns the Trace for this task.
getTrace() - Method in class com.linkedin.parseq.Tuple3TaskDelegate
Returns the Trace for this task.
getTrace() - Method in class com.linkedin.parseq.Tuple4TaskDelegate
Returns the Trace for this task.
getTrace() - Method in class com.linkedin.parseq.Tuple5TaskDelegate
Returns the Trace for this task.
getTrace() - Method in class com.linkedin.parseq.Tuple6TaskDelegate
Returns the Trace for this task.
getTrace() - Method in class com.linkedin.parseq.Tuple7TaskDelegate
Returns the Trace for this task.
getTrace() - Method in class com.linkedin.parseq.Tuple8TaskDelegate
Returns the Trace for this task.
getTrace() - Method in class com.linkedin.parseq.Tuple9TaskDelegate
Returns the Trace for this task.
getTraceBuilder() - Method in class com.linkedin.parseq.BaseTask
 
getTraceBuilder() - Method in interface com.linkedin.parseq.Context
 
getTraceBuilder() - Method in interface com.linkedin.parseq.Task
 
getTraceBuilder() - Method in class com.linkedin.parseq.Tuple2TaskDelegate
 
getTraceBuilder() - Method in class com.linkedin.parseq.Tuple3TaskDelegate
 
getTraceBuilder() - Method in class com.linkedin.parseq.Tuple4TaskDelegate
 
getTraceBuilder() - Method in class com.linkedin.parseq.Tuple5TaskDelegate
 
getTraceBuilder() - Method in class com.linkedin.parseq.Tuple6TaskDelegate
 
getTraceBuilder() - Method in class com.linkedin.parseq.Tuple7TaskDelegate
 
getTraceBuilder() - Method in class com.linkedin.parseq.Tuple8TaskDelegate
 
getTraceBuilder() - Method in class com.linkedin.parseq.Tuple9TaskDelegate
 
getTraceMap() - Method in class com.linkedin.parseq.trace.Trace
 
getType() - Method in class com.linkedin.parseq.BaseTask.State
 
getValue() - Method in interface com.linkedin.parseq.trace.ShallowTrace
Returns a String representation of the value or error produced by the traced task.
getValue() - Method in class com.linkedin.parseq.trace.ShallowTraceBuilder
 
getValue() - Method in class com.linkedin.parseq.trace.ShallowTraceImp
 

H

hashCode() - Method in class com.linkedin.parseq.function.Failure
 
hashCode() - Method in class com.linkedin.parseq.function.Success
 
hashCode() - Method in class com.linkedin.parseq.function.Tuple2
 
hashCode() - Method in class com.linkedin.parseq.function.Tuple3
 
hashCode() - Method in class com.linkedin.parseq.function.Tuple4
 
hashCode() - Method in class com.linkedin.parseq.function.Tuple5
 
hashCode() - Method in class com.linkedin.parseq.function.Tuple6
 
hashCode() - Method in class com.linkedin.parseq.function.Tuple7
 
hashCode() - Method in class com.linkedin.parseq.function.Tuple8
 
hashCode() - Method in class com.linkedin.parseq.function.Tuple9
 
hashCode() - Method in class com.linkedin.parseq.trace.ShallowTraceImp
 
hashCode() - Method in class com.linkedin.parseq.trace.Trace
 
hashCode() - Method in class com.linkedin.parseq.trace.TraceRelationship
 

I

identity() - Static method in interface com.linkedin.parseq.function.Function1
Returns a function that always returns its input argument.
identity() - Static method in class com.linkedin.parseq.promise.PromiseTransformer
 
INIT - Static variable in class com.linkedin.parseq.BaseTask.State
 
isCancellation(Throwable) - Static method in class com.linkedin.parseq.Exceptions
 
isCrossThreadStackTracesEnabled() - Static method in class com.linkedin.parseq.ParSeqGlobalConfiguration
Returns current state of cross-thread (cross-task) stack tracing.
isDone() - Method in class com.linkedin.parseq.promise.DelegatingPromise
 
isDone() - Method in interface com.linkedin.parseq.promise.Promise
Returns true if this promise is resolved.
isDone() - Method in class com.linkedin.parseq.promise.ResolvedError
 
isDone() - Method in class com.linkedin.parseq.promise.ResolvedValue
 
isDone() - Method in class com.linkedin.parseq.Tuple2TaskDelegate
Returns true if this promise is resolved.
isDone() - Method in class com.linkedin.parseq.Tuple3TaskDelegate
Returns true if this promise is resolved.
isDone() - Method in class com.linkedin.parseq.Tuple4TaskDelegate
Returns true if this promise is resolved.
isDone() - Method in class com.linkedin.parseq.Tuple5TaskDelegate
Returns true if this promise is resolved.
isDone() - Method in class com.linkedin.parseq.Tuple6TaskDelegate
Returns true if this promise is resolved.
isDone() - Method in class com.linkedin.parseq.Tuple7TaskDelegate
Returns true if this promise is resolved.
isDone() - Method in class com.linkedin.parseq.Tuple8TaskDelegate
Returns true if this promise is resolved.
isDone() - Method in class com.linkedin.parseq.Tuple9TaskDelegate
Returns true if this promise is resolved.
isEarlyFinish(Throwable) - Static method in class com.linkedin.parseq.Exceptions
 
isFailed() - Method in class com.linkedin.parseq.function.Failure
 
isFailed() - Method in class com.linkedin.parseq.function.Success
 
isFailed() - Method in interface com.linkedin.parseq.function.Try
 
isFailed() - Method in class com.linkedin.parseq.promise.DelegatingPromise
 
isFailed() - Method in interface com.linkedin.parseq.promise.Promise
Returns true if the promise has an error.
isFailed() - Method in class com.linkedin.parseq.promise.ResolvedError
 
isFailed() - Method in class com.linkedin.parseq.promise.ResolvedValue
 
isFailed() - Method in class com.linkedin.parseq.Tuple2TaskDelegate
Returns true if the promise has an error.
isFailed() - Method in class com.linkedin.parseq.Tuple3TaskDelegate
Returns true if the promise has an error.
isFailed() - Method in class com.linkedin.parseq.Tuple4TaskDelegate
Returns true if the promise has an error.
isFailed() - Method in class com.linkedin.parseq.Tuple5TaskDelegate
Returns true if the promise has an error.
isFailed() - Method in class com.linkedin.parseq.Tuple6TaskDelegate
Returns true if the promise has an error.
isFailed() - Method in class com.linkedin.parseq.Tuple7TaskDelegate
Returns true if the promise has an error.
isFailed() - Method in class com.linkedin.parseq.Tuple8TaskDelegate
Returns true if the promise has an error.
isFailed() - Method in class com.linkedin.parseq.Tuple9TaskDelegate
Returns true if the promise has an error.
isShutdown() - Method in class com.linkedin.parseq.Engine
Returns true if engine shutdown has been started or if the engine is terminated.
isTerminated() - Method in class com.linkedin.parseq.Engine
Returns true if the engine has completely stopped.
isTrampolineEnabled() - Static method in class com.linkedin.parseq.ParSeqGlobalConfiguration
Returns true if trampoline is currently enabled.
iterator() - Method in class com.linkedin.parseq.function.Tuple2
 
iterator() - Method in class com.linkedin.parseq.function.Tuple3
 
iterator() - Method in class com.linkedin.parseq.function.Tuple4
 
iterator() - Method in class com.linkedin.parseq.function.Tuple5
 
iterator() - Method in class com.linkedin.parseq.function.Tuple6
 
iterator() - Method in class com.linkedin.parseq.function.Tuple7
 
iterator() - Method in class com.linkedin.parseq.function.Tuple8
 
iterator() - Method in class com.linkedin.parseq.function.Tuple9
 

J

JsonTraceCodec - Class in com.linkedin.parseq.trace.codec.json
JSON implementation of TraceCodec
JsonTraceCodec() - Constructor for class com.linkedin.parseq.trace.codec.json.JsonTraceCodec
 

L

LimitAttempts - Class in com.linkedin.parseq.retry.termination
A termination policy that limits the number of attempts made.
LimitAttempts(int) - Constructor for class com.linkedin.parseq.retry.termination.LimitAttempts
A termination policy that limits the number of attempts made.
limitAttempts(int) - Static method in interface com.linkedin.parseq.retry.termination.TerminationPolicy
A termination policy that limits the number of attempts made.
LimitDuration - Class in com.linkedin.parseq.retry.termination
A termination policy that limits the amount of time spent retrying.
LimitDuration(long) - Constructor for class com.linkedin.parseq.retry.termination.LimitDuration
A termination policy that limits the amount of time spent retrying.
limitDuration(long) - Static method in interface com.linkedin.parseq.retry.termination.TerminationPolicy
A termination policy that limits the amount of time spent retrying.
linear(long) - Static method in interface com.linkedin.parseq.retry.backoff.BackoffPolicy
A policy that increases the backoff duration by the same amount after every retry.
LinearBackoff - Class in com.linkedin.parseq.retry.backoff
A policy that increases the backoff duration by the same amount after every retry.
LinearBackoff(long) - Constructor for class com.linkedin.parseq.retry.backoff.LinearBackoff
A policy that increases the backoff duration by the same amount after every retry.
LOGGER - Static variable in interface com.linkedin.parseq.Task
 
LOGGER_BASE - Static variable in class com.linkedin.parseq.Engine
 

M

map(Function2<T1, T2, C>) - Method in class com.linkedin.parseq.function.Tuple2
 
map(Function3<T1, T2, T3, C>) - Method in class com.linkedin.parseq.function.Tuple3
 
map(Function4<T1, T2, T3, T4, C>) - Method in class com.linkedin.parseq.function.Tuple4
 
map(Function5<T1, T2, T3, T4, T5, C>) - Method in class com.linkedin.parseq.function.Tuple5
 
map(Function6<T1, T2, T3, T4, T5, T6, C>) - Method in class com.linkedin.parseq.function.Tuple6
 
map(Function7<T1, T2, T3, T4, T5, T6, T7, C>) - Method in class com.linkedin.parseq.function.Tuple7
 
map(Function8<T1, T2, T3, T4, T5, T6, T7, T8, C>) - Method in class com.linkedin.parseq.function.Tuple8
 
map(Function9<T1, T2, T3, T4, T5, T6, T7, T8, T9, C>) - Method in class com.linkedin.parseq.function.Tuple9
 
map(String, Function1<? super T, ? extends R>) - Method in interface com.linkedin.parseq.Task
Creates a new task by applying a function to the successful result of this task.
map(Function1<? super T, ? extends R>) - Method in interface com.linkedin.parseq.Task
Equivalent to map("map", func).
map(Function2<T1, T2, R>) - Method in interface com.linkedin.parseq.Tuple2Task
Equivalent to map("map", f).
map(String, Function2<T1, T2, R>) - Method in interface com.linkedin.parseq.Tuple2Task
Creates a new task by applying a function to the successful result of this task.
map(Function3<T1, T2, T3, R>) - Method in interface com.linkedin.parseq.Tuple3Task
Equivalent to map("map", f).
map(String, Function3<T1, T2, T3, R>) - Method in interface com.linkedin.parseq.Tuple3Task
Creates a new task by applying a function to the successful result of this task.
map(Function4<T1, T2, T3, T4, R>) - Method in interface com.linkedin.parseq.Tuple4Task
Equivalent to map("map", f).
map(String, Function4<T1, T2, T3, T4, R>) - Method in interface com.linkedin.parseq.Tuple4Task
Creates a new task by applying a function to the successful result of this task.
map(Function5<T1, T2, T3, T4, T5, R>) - Method in interface com.linkedin.parseq.Tuple5Task
Equivalent to map("map", f).
map(String, Function5<T1, T2, T3, T4, T5, R>) - Method in interface com.linkedin.parseq.Tuple5Task
Creates a new task by applying a function to the successful result of this task.
map(Function6<T1, T2, T3, T4, T5, T6, R>) - Method in interface com.linkedin.parseq.Tuple6Task
Equivalent to map("map", f).
map(String, Function6<T1, T2, T3, T4, T5, T6, R>) - Method in interface com.linkedin.parseq.Tuple6Task
Creates a new task by applying a function to the successful result of this task.
map(Function7<T1, T2, T3, T4, T5, T6, T7, R>) - Method in interface com.linkedin.parseq.Tuple7Task
Equivalent to map("map", f).
map(String, Function7<T1, T2, T3, T4, T5, T6, T7, R>) - Method in interface com.linkedin.parseq.Tuple7Task
Creates a new task by applying a function to the successful result of this task.
map(Function8<T1, T2, T3, T4, T5, T6, T7, T8, R>) - Method in interface com.linkedin.parseq.Tuple8Task
Equivalent to map("map", f).
map(String, Function8<T1, T2, T3, T4, T5, T6, T7, T8, R>) - Method in interface com.linkedin.parseq.Tuple8Task
Creates a new task by applying a function to the successful result of this task.
map(Function9<T1, T2, T3, T4, T5, T6, T7, T8, T9, R>) - Method in interface com.linkedin.parseq.Tuple9Task
Equivalent to map("map", f).
map(String, Function9<T1, T2, T3, T4, T5, T6, T7, T8, T9, R>) - Method in interface com.linkedin.parseq.Tuple9Task
Creates a new task by applying a function to the successful result of this task.
markTaskPending() - Method in class com.linkedin.parseq.BaseTask
 
markTaskStarted() - Method in class com.linkedin.parseq.BaseTask
 
MAX_CONCURRENT_PLANS - Static variable in class com.linkedin.parseq.Engine
 
MAX_EXECUTION_MONITORS - Static variable in class com.linkedin.parseq.Engine
 
MAX_PRIORITY - Static variable in class com.linkedin.parseq.Priority
Tasks with maximum priority will be executed before all other tasks.
MAX_RELATIONSHIPS_PER_TRACE - Static variable in class com.linkedin.parseq.Engine
 
MIN_PRIORITY - Static variable in class com.linkedin.parseq.Priority
Tasks with minimum priority will only be executed after all other tasks have been executed.
MONITOR_EXECUTION - Static variable in class com.linkedin.parseq.Engine
 
MultiException - Exception in com.linkedin.parseq
An exception representing multiple exceptions.
MultiException(String, Collection<? extends Throwable>) - Constructor for exception com.linkedin.parseq.MultiException
 
MultiException(Collection<? extends Throwable>) - Constructor for exception com.linkedin.parseq.MultiException
 

N

neverTerminate() - Static method in interface com.linkedin.parseq.retry.termination.TerminationPolicy
A termination policy that never signals for termination.
newTaskQueue() - Method in interface com.linkedin.parseq.TaskQueueFactory
 
nextBackoff(int, Throwable) - Method in interface com.linkedin.parseq.retry.backoff.BackoffPolicy
Computes the next backoff duration using the specified number of attempts and the error that caused the operation to consider another attempt.
nextBackoff(int, Throwable) - Method in class com.linkedin.parseq.retry.backoff.ConstantBackoff
Computes the next backoff duration using the specified number of attempts and the error that caused the operation to consider another attempt.
nextBackoff(int, Throwable) - Method in class com.linkedin.parseq.retry.backoff.ExponentialBackoff
Computes the next backoff duration using the specified number of attempts and the error that caused the operation to consider another attempt.
nextBackoff(int, Throwable) - Method in class com.linkedin.parseq.retry.backoff.FibonacciBackoff
Computes the next backoff duration using the specified number of attempts and the error that caused the operation to consider another attempt.
nextBackoff(int, Throwable) - Method in class com.linkedin.parseq.retry.backoff.LinearBackoff
Computes the next backoff duration using the specified number of attempts and the error that caused the operation to consider another attempt.
nextBackoff(int, Throwable) - Method in class com.linkedin.parseq.retry.backoff.RandomizedBackoff
Computes the next backoff duration using the specified number of attempts and the error that caused the operation to consider another attempt.
nextBackoff(int, Throwable) - Method in class com.linkedin.parseq.retry.backoff.SelectedBackoff
Computes the next backoff duration using the specified number of attempts and the error that caused the operation to consider another attempt.
NO_SUCH_ELEMENT_EXCEPTION - Static variable in class com.linkedin.parseq.Exceptions
 
noBackoff() - Static method in interface com.linkedin.parseq.retry.backoff.BackoffPolicy
A policy that doesn't do any backoff, so the retry happens immediately.
nonFatal(Throwable) - Static method in enum com.linkedin.parseq.retry.ErrorClassification
 
noSuchElement() - Static method in class com.linkedin.parseq.Exceptions
 
noSuchElement(Throwable) - Static method in class com.linkedin.parseq.Exceptions
 

O

of(Throwable) - Static method in class com.linkedin.parseq.function.Failure
 
of(R) - Static method in class com.linkedin.parseq.function.Success
 
onFailure(String, Consumer1<Throwable>) - Method in interface com.linkedin.parseq.Task
Creates a new task which applies a consumer to the exception this task may fail with.
onFailure(Consumer1<Throwable>) - Method in interface com.linkedin.parseq.Task
Equivalent to onFailure("onFailure", consumer).
onFailure(Consumer1<Throwable>) - Method in interface com.linkedin.parseq.Tuple2Task
Equivalent to onFailure("onFailure", consumer).
onFailure(String, Consumer1<Throwable>) - Method in interface com.linkedin.parseq.Tuple2Task
Creates a new task which applies a consumer to the exception this task may fail with.
onFailure(Consumer1<Throwable>) - Method in interface com.linkedin.parseq.Tuple3Task
Equivalent to onFailure("onFailure", consumer).
onFailure(String, Consumer1<Throwable>) - Method in interface com.linkedin.parseq.Tuple3Task
Creates a new task which applies a consumer to the exception this task may fail with.
onFailure(Consumer1<Throwable>) - Method in interface com.linkedin.parseq.Tuple4Task
Equivalent to onFailure("onFailure", consumer).
onFailure(String, Consumer1<Throwable>) - Method in interface com.linkedin.parseq.Tuple4Task
Creates a new task which applies a consumer to the exception this task may fail with.
onFailure(Consumer1<Throwable>) - Method in interface com.linkedin.parseq.Tuple5Task
Equivalent to onFailure("onFailure", consumer).
onFailure(String, Consumer1<Throwable>) - Method in interface com.linkedin.parseq.Tuple5Task
Creates a new task which applies a consumer to the exception this task may fail with.
onFailure(Consumer1<Throwable>) - Method in interface com.linkedin.parseq.Tuple6Task
Equivalent to onFailure("onFailure", consumer).
onFailure(String, Consumer1<Throwable>) - Method in interface com.linkedin.parseq.Tuple6Task
Creates a new task which applies a consumer to the exception this task may fail with.
onFailure(Consumer1<Throwable>) - Method in interface com.linkedin.parseq.Tuple7Task
Equivalent to onFailure("onFailure", consumer).
onFailure(String, Consumer1<Throwable>) - Method in interface com.linkedin.parseq.Tuple7Task
Creates a new task which applies a consumer to the exception this task may fail with.
onFailure(Consumer1<Throwable>) - Method in interface com.linkedin.parseq.Tuple8Task
Equivalent to onFailure("onFailure", consumer).
onFailure(String, Consumer1<Throwable>) - Method in interface com.linkedin.parseq.Tuple8Task
Creates a new task which applies a consumer to the exception this task may fail with.
onFailure(Consumer1<Throwable>) - Method in interface com.linkedin.parseq.Tuple9Task
Equivalent to onFailure("onFailure", consumer).
onFailure(String, Consumer1<Throwable>) - Method in interface com.linkedin.parseq.Tuple9Task
Creates a new task which applies a consumer to the exception this task may fail with.
onResolved(Promise<T>) - Method in class com.linkedin.parseq.promise.CountDownPromiseListener
 
onResolved(Promise<T>) - Method in class com.linkedin.parseq.promise.FastFailCountDownPromiseListener
 
onResolved(Promise<P>) - Method in interface com.linkedin.parseq.promise.PromiseListener
A callback method that is invoked when the promise completes.
onResolved(Promise<S>) - Method in class com.linkedin.parseq.promise.TransformingPromiseListener
 

P

par(Task<T1>, Task<T2>) - Static method in interface com.linkedin.parseq.Task
Creates a new task that will run given tasks in parallel.
par(Task<T1>, Task<T2>, Task<T3>) - Static method in interface com.linkedin.parseq.Task
Creates a new task that will run given tasks in parallel.
par(Task<T1>, Task<T2>, Task<T3>, Task<T4>) - Static method in interface com.linkedin.parseq.Task
Creates a new task that will run given tasks in parallel.
par(Task<T1>, Task<T2>, Task<T3>, Task<T4>, Task<T5>) - Static method in interface com.linkedin.parseq.Task
Creates a new task that will run given tasks in parallel.
par(Task<T1>, Task<T2>, Task<T3>, Task<T4>, Task<T5>, Task<T6>) - Static method in interface com.linkedin.parseq.Task
Creates a new task that will run given tasks in parallel.
par(Task<T1>, Task<T2>, Task<T3>, Task<T4>, Task<T5>, Task<T6>, Task<T7>) - Static method in interface com.linkedin.parseq.Task
Creates a new task that will run given tasks in parallel.
par(Task<T1>, Task<T2>, Task<T3>, Task<T4>, Task<T5>, Task<T6>, Task<T7>, Task<T8>) - Static method in interface com.linkedin.parseq.Task
Creates a new task that will run given tasks in parallel.
par(Task<T1>, Task<T2>, Task<T3>, Task<T4>, Task<T5>, Task<T6>, Task<T7>, Task<T8>, Task<T9>) - Static method in interface com.linkedin.parseq.Task
Creates a new task that will run given tasks in parallel.
par(Iterable<? extends Task<? extends T>>) - Static method in interface com.linkedin.parseq.Task
Creates a new task that will run each of the supplied tasks in parallel (e.g.
par(Task<? extends T>, Task<? extends T>) - Static method in class com.linkedin.parseq.Tasks
Deprecated.
As of 2.0.0, replaced by Task.par
par(Task<? extends T>, Task<? extends T>, Task<? extends T>) - Static method in class com.linkedin.parseq.Tasks
Deprecated.
As of 2.0.0, replaced by Task.par
par(Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>) - Static method in class com.linkedin.parseq.Tasks
Deprecated.
As of 2.0.0, replaced by Task.par
par(Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>) - Static method in class com.linkedin.parseq.Tasks
Deprecated.
As of 2.0.0, replaced by Task.par
par(Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>) - Static method in class com.linkedin.parseq.Tasks
Deprecated.
As of 2.0.0, replaced by Task.par
par(Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>) - Static method in class com.linkedin.parseq.Tasks
Deprecated.
As of 2.0.0, replaced by Task.par
par(Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>) - Static method in class com.linkedin.parseq.Tasks
Deprecated.
As of 2.0.0, replaced by Task.par
par(Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>) - Static method in class com.linkedin.parseq.Tasks
Deprecated.
As of 2.0.0, replaced by Task.par
par(Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>, Task<? extends T>) - Static method in class com.linkedin.parseq.Tasks
Deprecated.
As of 2.0.0, replaced by Task.par
par(Iterable<? extends Task<? extends T>>) - Static method in class com.linkedin.parseq.Tasks
Deprecated.
As of 2.0.0, replaced by Task.par as a safer alternative that does not throw an IllegalArgumentException for an empty Iterable of tasks.
Par2Task<T1,T2> - Class in com.linkedin.parseq
 
Par2Task(String, Task<T1>, Task<T2>) - Constructor for class com.linkedin.parseq.Par2Task
 
Par3Task<T1,T2,T3> - Class in com.linkedin.parseq
 
Par3Task(String, Task<T1>, Task<T2>, Task<T3>) - Constructor for class com.linkedin.parseq.Par3Task
 
Par4Task<T1,T2,T3,T4> - Class in com.linkedin.parseq
 
Par4Task(String, Task<T1>, Task<T2>, Task<T3>, Task<T4>) - Constructor for class com.linkedin.parseq.Par4Task
 
Par5Task<T1,T2,T3,T4,T5> - Class in com.linkedin.parseq
 
Par5Task(String, Task<T1>, Task<T2>, Task<T3>, Task<T4>, Task<T5>) - Constructor for class com.linkedin.parseq.Par5Task
 
Par6Task<T1,T2,T3,T4,T5,T6> - Class in com.linkedin.parseq
 
Par6Task(String, Task<T1>, Task<T2>, Task<T3>, Task<T4>, Task<T5>, Task<T6>) - Constructor for class com.linkedin.parseq.Par6Task
 
Par7Task<T1,T2,T3,T4,T5,T6,T7> - Class in com.linkedin.parseq
 
Par7Task(String, Task<T1>, Task<T2>, Task<T3>, Task<T4>, Task<T5>, Task<T6>, Task<T7>) - Constructor for class com.linkedin.parseq.Par7Task
 
Par8Task<T1,T2,T3,T4,T5,T6,T7,T8> - Class in com.linkedin.parseq
 
Par8Task(String, Task<T1>, Task<T2>, Task<T3>, Task<T4>, Task<T5>, Task<T6>, Task<T7>, Task<T8>) - Constructor for class com.linkedin.parseq.Par8Task
 
Par9Task<T1,T2,T3,T4,T5,T6,T7,T8,T9> - Class in com.linkedin.parseq
 
Par9Task(String, Task<T1>, Task<T2>, Task<T3>, Task<T4>, Task<T5>, Task<T6>, Task<T7>, Task<T8>, Task<T9>) - Constructor for class com.linkedin.parseq.Par9Task
 
ParSeqGlobalConfiguration - Class in com.linkedin.parseq
Global parseq configuration, applies to all Engine and Task instances
ParTask<T> - Interface in com.linkedin.parseq
A ParTask will execute the list of tasks in parallel and contains the result of the complete set.
PENDING - Static variable in class com.linkedin.parseq.BaseTask.State
 
Priority - Class in com.linkedin.parseq
Priority describes the order in which tasks should be executed when there is more than one task available for execution.
Promise<P> - Interface in com.linkedin.parseq.promise
A Promise, like a Future, represents the result of an asynchronous computation.
PromiseException - Exception in com.linkedin.parseq.promise
A general exception indicating that there was a Promise related error.
PromiseException(String) - Constructor for exception com.linkedin.parseq.promise.PromiseException
 
PromiseException(Throwable) - Constructor for exception com.linkedin.parseq.promise.PromiseException
 
PromiseListener<P> - Interface in com.linkedin.parseq.promise
A listener that can be registered with a promise.
PromisePropagator<S,T> - Interface in com.linkedin.parseq.promise
 
PromiseResolvedException - Exception in com.linkedin.parseq.promise
This exception is thrown when attempting to set a value or error on a promise that is already resolved (i.e.
PromiseResolvedException(String) - Constructor for exception com.linkedin.parseq.promise.PromiseResolvedException
 
Promises - Class in com.linkedin.parseq.promise
This class provides a set of static helper methods that make it easier to work with Promises.
PromiseTransformer<S,T> - Class in com.linkedin.parseq.promise
 
PromiseTransformer(Function1<? super S, ? extends T>) - Constructor for class com.linkedin.parseq.promise.PromiseTransformer
 
PromiseUnresolvedException - Exception in com.linkedin.parseq.promise
This exception is thrown when attempting to get a value from a promise that has not yet finished.
PromiseUnresolvedException(String) - Constructor for exception com.linkedin.parseq.promise.PromiseUnresolvedException
 
propagateResult(Promise<T>, Settable<T>) - Static method in class com.linkedin.parseq.promise.Promises
Copies the value or error from the source promise to the destination promise.
propagateResult(Promise<T>, SettablePromise<T>) - Static method in class com.linkedin.parseq.promise.Promises
 

R

randomized(BackoffPolicy, long, long) - Static method in interface com.linkedin.parseq.retry.backoff.BackoffPolicy
A policy that randomizes the result of another policy by adding a random duration in the specified range (in milliseconds).
RandomizedBackoff - Class in com.linkedin.parseq.retry.backoff
A policy that randomizes the result of another policy by adding a random duration in the specified range.
RandomizedBackoff(BackoffPolicy, long, long) - Constructor for class com.linkedin.parseq.retry.backoff.RandomizedBackoff
A policy that randomizes the result of another policy by adding a random duration in the specified range.
recover(String, Function1<Throwable, T>) - Method in interface com.linkedin.parseq.Task
Creates a new task that will handle failure of this task.
recover(Function1<Throwable, T>) - Method in interface com.linkedin.parseq.Task
Equivalent to recover("recover", func).
recover(Function1<Throwable, Tuple2<T1, T2>>) - Method in interface com.linkedin.parseq.Tuple2Task
Equivalent to recover("recover", func).
recover(String, Function1<Throwable, Tuple2<T1, T2>>) - Method in interface com.linkedin.parseq.Tuple2Task
Creates a new task that will handle failure of this task.
recover(Function1<Throwable, Tuple3<T1, T2, T3>>) - Method in interface com.linkedin.parseq.Tuple3Task
Equivalent to recover("recover", func).
recover(String, Function1<Throwable, Tuple3<T1, T2, T3>>) - Method in interface com.linkedin.parseq.Tuple3Task
Creates a new task that will handle failure of this task.
recover(Function1<Throwable, Tuple4<T1, T2, T3, T4>>) - Method in interface com.linkedin.parseq.Tuple4Task
Equivalent to recover("recover", func).
recover(String, Function1<Throwable, Tuple4<T1, T2, T3, T4>>) - Method in interface com.linkedin.parseq.Tuple4Task
Creates a new task that will handle failure of this task.
recover(Function1<Throwable, Tuple5<T1, T2, T3, T4, T5>>) - Method in interface com.linkedin.parseq.Tuple5Task
Equivalent to recover("recover", func).
recover(String, Function1<Throwable, Tuple5<T1, T2, T3, T4, T5>>) - Method in interface com.linkedin.parseq.Tuple5Task
Creates a new task that will handle failure of this task.
recover(Function1<Throwable, Tuple6<T1, T2, T3, T4, T5, T6>>) - Method in interface com.linkedin.parseq.Tuple6Task
Equivalent to recover("recover", func).
recover(String, Function1<Throwable, Tuple6<T1, T2, T3, T4, T5, T6>>) - Method in interface com.linkedin.parseq.Tuple6Task
Creates a new task that will handle failure of this task.
recover(Function1<Throwable, Tuple7<T1, T2, T3, T4, T5, T6, T7>>) - Method in interface com.linkedin.parseq.Tuple7Task
Equivalent to recover("recover", func).
recover(String, Function1<Throwable, Tuple7<T1, T2, T3, T4, T5, T6, T7>>) - Method in interface com.linkedin.parseq.Tuple7Task
Creates a new task that will handle failure of this task.
recover(Function1<Throwable, Tuple8<T1, T2, T3, T4, T5, T6, T7, T8>>) - Method in interface com.linkedin.parseq.Tuple8Task
Equivalent to recover("recover", func).
recover(String, Function1<Throwable, Tuple8<T1, T2, T3, T4, T5, T6, T7, T8>>) - Method in interface com.linkedin.parseq.Tuple8Task
Creates a new task that will handle failure of this task.
recover(Function1<Throwable, Tuple9<T1, T2, T3, T4, T5, T6, T7, T8, T9>>) - Method in interface com.linkedin.parseq.Tuple9Task
Equivalent to recover("recover", func).
recover(String, Function1<Throwable, Tuple9<T1, T2, T3, T4, T5, T6, T7, T8, T9>>) - Method in interface com.linkedin.parseq.Tuple9Task
Creates a new task that will handle failure of this task.
recoverWith(String, Function1<Throwable, Task<T>>) - Method in interface com.linkedin.parseq.Task
Creates a new task that will handle failure of this task.
recoverWith(Function1<Throwable, Task<T>>) - Method in interface com.linkedin.parseq.Task
Equivalent to recoverWith("recoverWith", func).
recoverWith(Function1<Throwable, Task<Tuple2<T1, T2>>>) - Method in interface com.linkedin.parseq.Tuple2Task
Equivalent to recoverWith("recoverWith", func).
recoverWith(String, Function1<Throwable, Task<Tuple2<T1, T2>>>) - Method in interface com.linkedin.parseq.Tuple2Task
Creates a new task that will handle failure of this task.
recoverWith(Function1<Throwable, Task<Tuple3<T1, T2, T3>>>) - Method in interface com.linkedin.parseq.Tuple3Task
Equivalent to recoverWith("recoverWith", func).
recoverWith(String, Function1<Throwable, Task<Tuple3<T1, T2, T3>>>) - Method in interface com.linkedin.parseq.Tuple3Task
Creates a new task that will handle failure of this task.
recoverWith(Function1<Throwable, Task<Tuple4<T1, T2, T3, T4>>>) - Method in interface com.linkedin.parseq.Tuple4Task
Equivalent to recoverWith("recoverWith", func).
recoverWith(String, Function1<Throwable, Task<Tuple4<T1, T2, T3, T4>>>) - Method in interface com.linkedin.parseq.Tuple4Task
Creates a new task that will handle failure of this task.
recoverWith(Function1<Throwable, Task<Tuple5<T1, T2, T3, T4, T5>>>) - Method in interface com.linkedin.parseq.Tuple5Task
Equivalent to recoverWith("recoverWith", func).
recoverWith(String, Function1<Throwable, Task<Tuple5<T1, T2, T3, T4, T5>>>) - Method in interface com.linkedin.parseq.Tuple5Task
Creates a new task that will handle failure of this task.
recoverWith(Function1<Throwable, Task<Tuple6<T1, T2, T3, T4, T5, T6>>>) - Method in interface com.linkedin.parseq.Tuple6Task
Equivalent to recoverWith("recoverWith", func).
recoverWith(String, Function1<Throwable, Task<Tuple6<T1, T2, T3, T4, T5, T6>>>) - Method in interface com.linkedin.parseq.Tuple6Task
Creates a new task that will handle failure of this task.
recoverWith(Function1<Throwable, Task<Tuple7<T1, T2, T3, T4, T5, T6, T7>>>) - Method in interface com.linkedin.parseq.Tuple7Task
Equivalent to recoverWith("recoverWith", func).
recoverWith(String, Function1<Throwable, Task<Tuple7<T1, T2, T3, T4, T5, T6, T7>>>) - Method in interface com.linkedin.parseq.Tuple7Task
Creates a new task that will handle failure of this task.
recoverWith(Function1<Throwable, Task<Tuple8<T1, T2, T3, T4, T5, T6, T7, T8>>>) - Method in interface com.linkedin.parseq.Tuple8Task
Equivalent to recoverWith("recoverWith", func).
recoverWith(String, Function1<Throwable, Task<Tuple8<T1, T2, T3, T4, T5, T6, T7, T8>>>) - Method in interface com.linkedin.parseq.Tuple8Task
Creates a new task that will handle failure of this task.
recoverWith(Function1<Throwable, Task<Tuple9<T1, T2, T3, T4, T5, T6, T7, T8, T9>>>) - Method in interface com.linkedin.parseq.Tuple9Task
Equivalent to recoverWith("recoverWith", func).
recoverWith(String, Function1<Throwable, Task<Tuple9<T1, T2, T3, T4, T5, T6, T7, T8, T9>>>) - Method in interface com.linkedin.parseq.Tuple9Task
Creates a new task that will handle failure of this task.
register(EngineBuilder, Executor) - Static method in class com.linkedin.parseq.AsyncCallableTask
Deprecated.
 
Relationship - Enum in com.linkedin.parseq.trace
A list of relationship types used by the trace system.
removeAttribute(String) - Method in class com.linkedin.parseq.trace.ShallowTraceBuilder
 
RequireBoth - Class in com.linkedin.parseq.retry.termination
A termination policy that signals for termination after both of the specified policies terminate.
RequireBoth(TerminationPolicy, TerminationPolicy) - Constructor for class com.linkedin.parseq.retry.termination.RequireBoth
A termination policy that signals for termination after both of the specified policies terminate.
requireBoth(TerminationPolicy, TerminationPolicy) - Static method in interface com.linkedin.parseq.retry.termination.TerminationPolicy
A termination policy that signals for termination after both of the specified policies terminate.
RequireEither - Class in com.linkedin.parseq.retry.termination
A termination policy that signals for termination after either of the specified policies terminate.
RequireEither(TerminationPolicy, TerminationPolicy) - Constructor for class com.linkedin.parseq.retry.termination.RequireEither
A termination policy that signals for termination after either of the specified policies terminate.
requireEither(TerminationPolicy, TerminationPolicy) - Static method in interface com.linkedin.parseq.retry.termination.TerminationPolicy
A termination policy that signals for termination after either of the specified policies terminate.
ResolvedError<T> - Class in com.linkedin.parseq.promise
 
ResolvedError(Throwable) - Constructor for class com.linkedin.parseq.promise.ResolvedError
 
ResolvedValue<T> - Class in com.linkedin.parseq.promise
 
ResolvedValue(T) - Constructor for class com.linkedin.parseq.promise.ResolvedValue
 
resultType() - Method in class com.linkedin.parseq.function.Failure
 
resultType() - Method in class com.linkedin.parseq.function.Success
 
resultType() - Method in interface com.linkedin.parseq.function.Try
Returns either success or failure.
ResultType - Enum in com.linkedin.parseq.trace
An enumeration that classifies the state of a Task.
RetriableTask<T> - Class in com.linkedin.parseq.retry
A parseq task wrapper that supports arbitrary retry policies.
RetryPolicy - Interface in com.linkedin.parseq.retry
An interface for policies that enable customizable retries for arbitrary parseq tasks.
RetryPolicyBuilder - Class in com.linkedin.parseq.retry
A policy builder that enables customizable retries for arbitrary parseq tasks.
RetryPolicyBuilder() - Constructor for class com.linkedin.parseq.retry.RetryPolicyBuilder
 
run(Context) - Method in class com.linkedin.parseq.ActionTask
Deprecated.
 
run(Task<?>) - Method in interface com.linkedin.parseq.After
When all promises and tasks have been resolved then the given task is run.
run(Supplier<Task<?>>) - Method in interface com.linkedin.parseq.After
When all promises and tasks have been resolved then task provided by given Supplier is run.
run(Context) - Method in class com.linkedin.parseq.AsyncCallableTask
Deprecated.
 
run(Context) - Method in class com.linkedin.parseq.BaseTask
This template method is invoked when the task is run.
RUN - Static variable in class com.linkedin.parseq.BaseTask.State
 
run(Context) - Method in class com.linkedin.parseq.CallableTask
Deprecated.
 
run(Task<?>...) - Method in interface com.linkedin.parseq.Context
Runs one or more tasks in parallel.
run(Task<?>) - Method in class com.linkedin.parseq.Engine
Runs the given task.
run(Task<?>, String) - Method in class com.linkedin.parseq.Engine
Runs the given task.
run() - Method in interface com.linkedin.parseq.function.Action
 
run(Context) - Method in class com.linkedin.parseq.Par2Task
 
run(Context) - Method in class com.linkedin.parseq.Par3Task
 
run(Context) - Method in class com.linkedin.parseq.Par4Task
 
run(Context) - Method in class com.linkedin.parseq.Par5Task
 
run(Context) - Method in class com.linkedin.parseq.Par6Task
 
run(Context) - Method in class com.linkedin.parseq.Par7Task
 
run(Context) - Method in class com.linkedin.parseq.Par8Task
 
run(Context) - Method in class com.linkedin.parseq.Par9Task
 
runSideEffect(Task<?>...) - Method in interface com.linkedin.parseq.Context
 

S

schedule(long, TimeUnit, Runnable) - Method in interface com.linkedin.parseq.DelayedExecutor
Schedules a command to execute after some period of delay.
schedule(long, TimeUnit, Runnable) - Method in class com.linkedin.parseq.DelayedExecutorAdapter
 
selected(Function<Throwable, BackoffPolicy>) - Static method in interface com.linkedin.parseq.retry.backoff.BackoffPolicy
A policy that delegates to another policy that is selected based on the most recent error.
SelectedBackoff - Class in com.linkedin.parseq.retry.backoff
A policy that delegates to another policy that is selected based on the most recent error.
SelectedBackoff(Function<Throwable, BackoffPolicy>) - Constructor for class com.linkedin.parseq.retry.backoff.SelectedBackoff
A policy that delegates to another policy that is selected based on the most recent error.
seq(Task<?>, Task<T>) - Static method in class com.linkedin.parseq.Tasks
Deprecated.
As of 2.0.0, replaced by Task.map, Task.flatMap, Task.andThen and other methods in Task.
seq(Task<?>, Task<?>, Task<T>) - Static method in class com.linkedin.parseq.Tasks
Deprecated.
As of 2.0.0, replaced by Task.map, Task.flatMap, Task.andThen and other methods in Task.
seq(Task<?>, Task<?>, Task<?>, Task<T>) - Static method in class com.linkedin.parseq.Tasks
Deprecated.
As of 2.0.0, replaced by Task.map, Task.flatMap, Task.andThen and other methods in Task.
seq(Task<?>, Task<?>, Task<?>, Task<?>, Task<T>) - Static method in class com.linkedin.parseq.Tasks
Deprecated.
As of 2.0.0, replaced by Task.map, Task.flatMap, Task.andThen and other methods in Task.
seq(Task<?>, Task<?>, Task<?>, Task<?>, Task<?>, Task<T>) - Static method in class com.linkedin.parseq.Tasks
Deprecated.
As of 2.0.0, replaced by Task.map, Task.flatMap, Task.andThen and other methods in Task.
seq(Task<?>, Task<?>, Task<?>, Task<?>, Task<?>, Task<?>, Task<T>) - Static method in class com.linkedin.parseq.Tasks
Deprecated.
As of 2.0.0, replaced by Task.map, Task.flatMap, Task.andThen and other methods in Task.
seq(Task<?>, Task<?>, Task<?>, Task<?>, Task<?>, Task<?>, Task<?>, Task<T>) - Static method in class com.linkedin.parseq.Tasks
Deprecated.
As of 2.0.0, replaced by Task.map, Task.flatMap, Task.andThen and other methods in Task.
seq(Task<?>, Task<?>, Task<?>, Task<?>, Task<?>, Task<?>, Task<?>, Task<?>, Task<T>) - Static method in class com.linkedin.parseq.Tasks
Deprecated.
As of 2.0.0, replaced by Task.map, Task.flatMap, Task.andThen and other methods in Task.
seq(Task<?>, Task<?>, Task<?>, Task<?>, Task<?>, Task<?>, Task<?>, Task<?>, Task<?>, Task<T>) - Static method in class com.linkedin.parseq.Tasks
Deprecated.
As of 2.0.0, replaced by Task.map, Task.flatMap, Task.andThen and other methods in Task.
seq(Iterable<? extends Task<?>>) - Static method in class com.linkedin.parseq.Tasks
Creates a new task that, when run, will run each of the supplied tasks in order.
setBackoffPolicy(BackoffPolicy) - Method in class com.linkedin.parseq.retry.RetryPolicyBuilder
Set a strategy used to calculate delays between retries.
setCrossThreadStackTracesEnabled(boolean) - Static method in class com.linkedin.parseq.ParSeqGlobalConfiguration
Modifies the current state of cross-thread (cross-task) stack tracing.
setEndNanos(Long) - Method in class com.linkedin.parseq.trace.ShallowTraceBuilder
 
setEngineProperty(String, Object) - Method in class com.linkedin.parseq.EngineBuilder
Sets an engine related property on the engine.
setErrorClassifier(Function<Throwable, ErrorClassification>) - Method in class com.linkedin.parseq.retry.RetryPolicyBuilder
Set a classifier for errors raised during retry operations.
setHidden(boolean) - Method in class com.linkedin.parseq.trace.ShallowTraceBuilder
 
setLoggerFactory(ILoggerFactory) - Method in class com.linkedin.parseq.EngineBuilder
Sets the logger factory that will be used by the engine.
setName(String) - Method in class com.linkedin.parseq.retry.RetryPolicyBuilder
Set a name of this policy.
setName(String) - Method in class com.linkedin.parseq.trace.ShallowTraceBuilder
 
setPendingNanos(Long) - Method in class com.linkedin.parseq.trace.ShallowTraceBuilder
 
setPlanCompletionListener(PlanCompletionListener) - Method in class com.linkedin.parseq.EngineBuilder
 
setPlanDeactivationListener(PlanDeactivationListener) - Method in class com.linkedin.parseq.EngineBuilder
Sets plan activity listener for the engine.
setPriority(int) - Method in class com.linkedin.parseq.BaseTask
 
setPriority(int) - Method in interface com.linkedin.parseq.Task
Overrides the priority for this task.
setPriority(int) - Method in class com.linkedin.parseq.Tuple2TaskDelegate
Overrides the priority for this task.
setPriority(int) - Method in class com.linkedin.parseq.Tuple3TaskDelegate
Overrides the priority for this task.
setPriority(int) - Method in class com.linkedin.parseq.Tuple4TaskDelegate
Overrides the priority for this task.
setPriority(int) - Method in class com.linkedin.parseq.Tuple5TaskDelegate
Overrides the priority for this task.
setPriority(int) - Method in class com.linkedin.parseq.Tuple6TaskDelegate
Overrides the priority for this task.
setPriority(int) - Method in class com.linkedin.parseq.Tuple7TaskDelegate
Overrides the priority for this task.
setPriority(int) - Method in class com.linkedin.parseq.Tuple8TaskDelegate
Overrides the priority for this task.
setPriority(int) - Method in class com.linkedin.parseq.Tuple9TaskDelegate
Overrides the priority for this task.
setResultType(ResultType) - Method in class com.linkedin.parseq.trace.ShallowTraceBuilder
 
setStartNanos(Long) - Method in class com.linkedin.parseq.trace.ShallowTraceBuilder
 
setSystemHidden(boolean) - Method in class com.linkedin.parseq.trace.ShallowTraceBuilder
 
settable() - Static method in class com.linkedin.parseq.promise.Promises
Returns a new promise that can have its value set at a later time.
Settable<P> - Interface in com.linkedin.parseq.promise
 
SettablePromise<P> - Interface in com.linkedin.parseq.promise
A Promise that can have its value set.
setTaskExecutor(Executor) - Method in class com.linkedin.parseq.EngineBuilder
Sets the task executor for the engine.
setTaskQueueFactory(TaskQueueFactory) - Method in class com.linkedin.parseq.EngineBuilder
 
setTaskType(String) - Method in class com.linkedin.parseq.trace.ShallowTraceBuilder
 
setTerminationPolicy(TerminationPolicy) - Method in class com.linkedin.parseq.retry.RetryPolicyBuilder
Set a strategy for determining when to abort a retry operation.
setTimerScheduler(DelayedExecutor) - Method in class com.linkedin.parseq.EngineBuilder
Sets the timer scheduler for the engine.
setTimerScheduler(ScheduledExecutorService) - Method in class com.linkedin.parseq.EngineBuilder
Sets the timer scheduler for the engine.
setTraceValueSerializer(Function<T, String>) - Method in class com.linkedin.parseq.BaseTask
 
setTraceValueSerializer(Function<T, String>) - Method in interface com.linkedin.parseq.Task
Allows adding String representation of value computed by this task to trace.
setTraceValueSerializer(Function<Tuple2<T1, T2>, String>) - Method in class com.linkedin.parseq.Tuple2TaskDelegate
 
setTraceValueSerializer(Function<Tuple3<T1, T2, T3>, String>) - Method in class com.linkedin.parseq.Tuple3TaskDelegate
 
setTraceValueSerializer(Function<Tuple4<T1, T2, T3, T4>, String>) - Method in class com.linkedin.parseq.Tuple4TaskDelegate
 
setTraceValueSerializer(Function<Tuple5<T1, T2, T3, T4, T5>, String>) - Method in class com.linkedin.parseq.Tuple5TaskDelegate
 
setTraceValueSerializer(Function<Tuple6<T1, T2, T3, T4, T5, T6>, String>) - Method in class com.linkedin.parseq.Tuple6TaskDelegate
 
setTraceValueSerializer(Function<Tuple7<T1, T2, T3, T4, T5, T6, T7>, String>) - Method in class com.linkedin.parseq.Tuple7TaskDelegate
 
setTraceValueSerializer(Function<Tuple8<T1, T2, T3, T4, T5, T6, T7, T8>, String>) - Method in class com.linkedin.parseq.Tuple8TaskDelegate
 
setTraceValueSerializer(Function<Tuple9<T1, T2, T3, T4, T5, T6, T7, T8, T9>, String>) - Method in class com.linkedin.parseq.Tuple9TaskDelegate
 
setTrampolineEnabled(boolean) - Static method in class com.linkedin.parseq.ParSeqGlobalConfiguration
Enables or disables trampoline.
setValue(String) - Method in class com.linkedin.parseq.trace.ShallowTraceBuilder
 
ShallowTrace - Interface in com.linkedin.parseq.trace
A shallow trace is a trace without any relationship information.
ShallowTraceBuilder - Class in com.linkedin.parseq.trace
Use this class to build new ShallowTraceImp instances.
ShallowTraceBuilder(Long) - Constructor for class com.linkedin.parseq.trace.ShallowTraceBuilder
 
ShallowTraceBuilder(ShallowTrace) - Constructor for class com.linkedin.parseq.trace.ShallowTraceBuilder
 
ShallowTraceImp - Class in com.linkedin.parseq.trace
A shallow trace is a trace without any relationship information.
shareable() - Method in interface com.linkedin.parseq.Task
Creates a new task that can be safely shared within a plan or between multiple plans.
shareable() - Method in interface com.linkedin.parseq.Tuple2Task
Creates a new task that can be safely shared within a plan or between multiple plans.
shareable() - Method in interface com.linkedin.parseq.Tuple3Task
Creates a new task that can be safely shared within a plan or between multiple plans.
shareable() - Method in interface com.linkedin.parseq.Tuple4Task
Creates a new task that can be safely shared within a plan or between multiple plans.
shareable() - Method in interface com.linkedin.parseq.Tuple5Task
Creates a new task that can be safely shared within a plan or between multiple plans.
shareable() - Method in interface com.linkedin.parseq.Tuple6Task
Creates a new task that can be safely shared within a plan or between multiple plans.
shareable() - Method in interface com.linkedin.parseq.Tuple7Task
Creates a new task that can be safely shared within a plan or between multiple plans.
shareable() - Method in interface com.linkedin.parseq.Tuple8Task
Creates a new task that can be safely shared within a plan or between multiple plans.
shareable() - Method in interface com.linkedin.parseq.Tuple9Task
Creates a new task that can be safely shared within a plan or between multiple plans.
shouldTerminate(int, long) - Method in class com.linkedin.parseq.retry.termination.LimitAttempts
Returns true if the retry operation with the specified properties should terminate.
shouldTerminate(int, long) - Method in class com.linkedin.parseq.retry.termination.LimitDuration
Returns true if the retry operation with the specified properties should terminate.
shouldTerminate(int, long) - Method in class com.linkedin.parseq.retry.termination.RequireBoth
Returns true if the retry operation with the specified properties should terminate.
shouldTerminate(int, long) - Method in class com.linkedin.parseq.retry.termination.RequireEither
Returns true if the retry operation with the specified properties should terminate.
shouldTerminate(int, long) - Method in interface com.linkedin.parseq.retry.termination.TerminationPolicy
Returns true if the retry operation with the specified properties should terminate.
shutdown() - Method in class com.linkedin.parseq.Engine
If the engine is currently running, this method will initiate an orderly shutdown.
single(ShallowTrace) - Static method in class com.linkedin.parseq.trace.Trace
 
single(ShallowTrace, String, Long) - Static method in class com.linkedin.parseq.trace.Trace
 
Success<T> - Class in com.linkedin.parseq.function
 

T

Task<T> - Interface in com.linkedin.parseq
A task represents a deferred execution that also contains its resulting value.
TaskDescriptor - Interface in com.linkedin.parseq
An API to provide description for task.
TaskQueueFactory - Interface in com.linkedin.parseq
A factory to create SerialExecutor.TaskQueues.
Tasks - Class in com.linkedin.parseq
This class provides a set of factory methods for create common Tasks.
TaskType - Enum in com.linkedin.parseq
Different types of parseq tasks.
TerminationPolicy - Interface in com.linkedin.parseq.retry.termination
Strategy for determining when to abort a retry operation.
ThrowableCallable<T> - Interface in com.linkedin.parseq
Deprecated.
As of 2.0.0, replaced by Callable.
TIMEOUT_EXCEPTION - Static variable in class com.linkedin.parseq.Exceptions
 
timeoutException(String) - Static method in class com.linkedin.parseq.Exceptions
 
timeoutWithError(long, TimeUnit, Task<T>) - Static method in class com.linkedin.parseq.Tasks
Deprecated.
As of 2.0.0, replaced by Task.withTimeout.
timeoutWithError(String, long, TimeUnit, Task<T>) - Static method in class com.linkedin.parseq.Tasks
Deprecated.
As of 2.0.0, replaced by Task.withTimeout.
toString() - Method in class com.linkedin.parseq.BaseTask
 
toString() - Method in class com.linkedin.parseq.function.Failure
 
toString() - Method in class com.linkedin.parseq.function.Success
 
toString() - Method in class com.linkedin.parseq.function.Tuple2
 
toString() - Method in class com.linkedin.parseq.function.Tuple3
 
toString() - Method in class com.linkedin.parseq.function.Tuple4
 
toString() - Method in class com.linkedin.parseq.function.Tuple5
 
toString() - Method in class com.linkedin.parseq.function.Tuple6
 
toString() - Method in class com.linkedin.parseq.function.Tuple7
 
toString() - Method in class com.linkedin.parseq.function.Tuple8
 
toString() - Method in class com.linkedin.parseq.function.Tuple9
 
toString() - Method in exception com.linkedin.parseq.MultiException
 
toString() - Method in class com.linkedin.parseq.trace.ShallowTraceImp
 
toString() - Method in class com.linkedin.parseq.trace.Trace
 
toString() - Method in class com.linkedin.parseq.trace.TraceRelationship
 
toTry(Promise<T>) - Static method in class com.linkedin.parseq.promise.Promises
Returns instance of Try that represents result a promise has completed with.
toTry(String) - Method in interface com.linkedin.parseq.Task
This method transforms Task<T> into Task<Try<T>>.
toTry() - Method in interface com.linkedin.parseq.Task
Equivalent to toTry("toTry").
Trace - Class in com.linkedin.parseq.trace
 
Trace(Map<Long, ShallowTrace>, Set<TraceRelationship>) - Constructor for class com.linkedin.parseq.trace.Trace
 
Trace(Map<Long, ShallowTrace>, Set<TraceRelationship>, String, Long) - Constructor for class com.linkedin.parseq.trace.Trace
 
TraceBuilder - Class in com.linkedin.parseq.trace
 
TraceBuilder(int) - Constructor for class com.linkedin.parseq.trace.TraceBuilder
 
TraceBuilder(int, String, Long) - Constructor for class com.linkedin.parseq.trace.TraceBuilder
 
TraceCodec - Interface in com.linkedin.parseq.trace.codec
Interface for encoding/decoding the Trace
traceFailure(Throwable) - Method in class com.linkedin.parseq.BaseTask
 
TraceRelationship - Class in com.linkedin.parseq.trace
 
TraceRelationship(ShallowTraceBuilder, ShallowTraceBuilder, Relationship) - Constructor for class com.linkedin.parseq.trace.TraceRelationship
 
TraceUtil - Class in com.linkedin.parseq.trace
 
TraceUtil() - Constructor for class com.linkedin.parseq.trace.TraceUtil
 
transform(String, Function1<Try<T>, Try<R>>) - Method in interface com.linkedin.parseq.Task
Creates a new task that applies a transformation to the result of this task.
transform(Function1<Try<T>, Try<R>>) - Method in interface com.linkedin.parseq.Task
Equivalent to transform("transform", func).
TransformingPromiseListener<S,T> - Class in com.linkedin.parseq.promise
 
TransformingPromiseListener(Settable<T>, PromisePropagator<S, T>) - Constructor for class com.linkedin.parseq.promise.TransformingPromiseListener
 
transitionCancel(Exception) - Method in class com.linkedin.parseq.BaseTask
 
transitionDone() - Method in class com.linkedin.parseq.BaseTask.State
 
transitionDone() - Method in class com.linkedin.parseq.BaseTask
 
transitionPending() - Method in class com.linkedin.parseq.BaseTask.State
 
transitionPending() - Method in class com.linkedin.parseq.BaseTask
 
transitionRun() - Method in class com.linkedin.parseq.BaseTask.State
 
transitionRun(TraceBuilder) - Method in class com.linkedin.parseq.BaseTask
 
Try<T> - Interface in com.linkedin.parseq.function
The Try interface represents result that may either be a successful completion or a failure.
Try.ResultType - Enum in com.linkedin.parseq.function
 
tryRun(Task<?>) - Method in class com.linkedin.parseq.Engine
Runs the given task if Engine has a capacity to start new plan as specified by "_MaxConcurrentPlans_" configuration parameter.
tryRun(Task<?>, String) - Method in class com.linkedin.parseq.Engine
Runs the given task if Engine has a capacity to start new plan as specified by "_MaxConcurrentPlans_" configuration parameter.
tryRun(Task<?>, long, TimeUnit) - Method in class com.linkedin.parseq.Engine
Runs the given task if Engine has a capacity to start new plan as specified by "_MaxConcurrentPlans_" configuration parameter within specified amount of time.
tryRun(Task<?>, String, long, TimeUnit) - Method in class com.linkedin.parseq.Engine
Runs the given task if Engine has a capacity to start new plan as specified by "_MaxConcurrentPlans_" configuration parameter within specified amount of time.
Tuple - Interface in com.linkedin.parseq.function
 
tuple(T1, T2) - Static method in class com.linkedin.parseq.function.Tuples
 
tuple(T1, T2, T3) - Static method in class com.linkedin.parseq.function.Tuples
 
tuple(T1, T2, T3, T4) - Static method in class com.linkedin.parseq.function.Tuples
 
tuple(T1, T2, T3, T4, T5) - Static method in class com.linkedin.parseq.function.Tuples
 
tuple(T1, T2, T3, T4, T5, T6) - Static method in class com.linkedin.parseq.function.Tuples
 
tuple(T1, T2, T3, T4, T5, T6, T7) - Static method in class com.linkedin.parseq.function.Tuples
 
tuple(T1, T2, T3, T4, T5, T6, T7, T8) - Static method in class com.linkedin.parseq.function.Tuples
 
tuple(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Static method in class com.linkedin.parseq.function.Tuples
 
Tuple1Task<T> - Interface in com.linkedin.parseq
 
Tuple2<T1,T2> - Class in com.linkedin.parseq.function
 
Tuple2(T1, T2) - Constructor for class com.linkedin.parseq.function.Tuple2
 
Tuple2Task<T1,T2> - Interface in com.linkedin.parseq
 
Tuple2TaskDelegate<T1,T2> - Class in com.linkedin.parseq
 
Tuple2TaskDelegate(Task<Tuple2<T1, T2>>) - Constructor for class com.linkedin.parseq.Tuple2TaskDelegate
 
Tuple3<T1,T2,T3> - Class in com.linkedin.parseq.function
 
Tuple3(T1, T2, T3) - Constructor for class com.linkedin.parseq.function.Tuple3
 
Tuple3Task<T1,T2,T3> - Interface in com.linkedin.parseq
 
Tuple3TaskDelegate<T1,T2,T3> - Class in com.linkedin.parseq
 
Tuple3TaskDelegate(Task<Tuple3<T1, T2, T3>>) - Constructor for class com.linkedin.parseq.Tuple3TaskDelegate
 
Tuple4<T1,T2,T3,T4> - Class in com.linkedin.parseq.function
 
Tuple4(T1, T2, T3, T4) - Constructor for class com.linkedin.parseq.function.Tuple4
 
Tuple4Task<T1,T2,T3,T4> - Interface in com.linkedin.parseq
 
Tuple4TaskDelegate<T1,T2,T3,T4> - Class in com.linkedin.parseq
 
Tuple4TaskDelegate(Task<Tuple4<T1, T2, T3, T4>>) - Constructor for class com.linkedin.parseq.Tuple4TaskDelegate
 
Tuple5<T1,T2,T3,T4,T5> - Class in com.linkedin.parseq.function
 
Tuple5(T1, T2, T3, T4, T5) - Constructor for class com.linkedin.parseq.function.Tuple5
 
Tuple5Task<T1,T2,T3,T4,T5> - Interface in com.linkedin.parseq
 
Tuple5TaskDelegate<T1,T2,T3,T4,T5> - Class in com.linkedin.parseq
 
Tuple5TaskDelegate(Task<Tuple5<T1, T2, T3, T4, T5>>) - Constructor for class com.linkedin.parseq.Tuple5TaskDelegate
 
Tuple6<T1,T2,T3,T4,T5,T6> - Class in com.linkedin.parseq.function
 
Tuple6(T1, T2, T3, T4, T5, T6) - Constructor for class com.linkedin.parseq.function.Tuple6
 
Tuple6Task<T1,T2,T3,T4,T5,T6> - Interface in com.linkedin.parseq
 
Tuple6TaskDelegate<T1,T2,T3,T4,T5,T6> - Class in com.linkedin.parseq
 
Tuple6TaskDelegate(Task<Tuple6<T1, T2, T3, T4, T5, T6>>) - Constructor for class com.linkedin.parseq.Tuple6TaskDelegate
 
Tuple7<T1,T2,T3,T4,T5,T6,T7> - Class in com.linkedin.parseq.function
 
Tuple7(T1, T2, T3, T4, T5, T6, T7) - Constructor for class com.linkedin.parseq.function.Tuple7
 
Tuple7Task<T1,T2,T3,T4,T5,T6,T7> - Interface in com.linkedin.parseq
 
Tuple7TaskDelegate<T1,T2,T3,T4,T5,T6,T7> - Class in com.linkedin.parseq
 
Tuple7TaskDelegate(Task<Tuple7<T1, T2, T3, T4, T5, T6, T7>>) - Constructor for class com.linkedin.parseq.Tuple7TaskDelegate
 
Tuple8<T1,T2,T3,T4,T5,T6,T7,T8> - Class in com.linkedin.parseq.function
 
Tuple8(T1, T2, T3, T4, T5, T6, T7, T8) - Constructor for class com.linkedin.parseq.function.Tuple8
 
Tuple8Task<T1,T2,T3,T4,T5,T6,T7,T8> - Interface in com.linkedin.parseq
 
Tuple8TaskDelegate<T1,T2,T3,T4,T5,T6,T7,T8> - Class in com.linkedin.parseq
 
Tuple8TaskDelegate(Task<Tuple8<T1, T2, T3, T4, T5, T6, T7, T8>>) - Constructor for class com.linkedin.parseq.Tuple8TaskDelegate
 
Tuple9<T1,T2,T3,T4,T5,T6,T7,T8,T9> - Class in com.linkedin.parseq.function
 
Tuple9(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Constructor for class com.linkedin.parseq.function.Tuple9
 
Tuple9Task<T1,T2,T3,T4,T5,T6,T7,T8,T9> - Interface in com.linkedin.parseq
 
Tuple9TaskDelegate<T1,T2,T3,T4,T5,T6,T7,T8,T9> - Class in com.linkedin.parseq
 
Tuple9TaskDelegate(Task<Tuple9<T1, T2, T3, T4, T5, T6, T7, T8, T9>>) - Constructor for class com.linkedin.parseq.Tuple9TaskDelegate
 
Tuples - Class in com.linkedin.parseq.function
 

V

value(T) - Static method in class com.linkedin.parseq.promise.Promises
Creates a new promise that is already resolved with the given value.
value(String, T) - Static method in interface com.linkedin.parseq.Task
Creates a new task that will be resolved with given value when it is executed.
value(T) - Static method in interface com.linkedin.parseq.Task
Equivalent to value("value", value).
valueOf(String) - Static method in enum com.linkedin.parseq.function.Try.ResultType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.parseq.retry.ErrorClassification
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.parseq.TaskType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.parseq.trace.Relationship
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.parseq.trace.ResultType
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.linkedin.parseq.function.Try.ResultType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.parseq.retry.ErrorClassification
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.parseq.TaskType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.parseq.trace.Relationship
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.parseq.trace.ResultType
Returns an array containing the constants of this enum type, in the order they are declared.
VOID - Static variable in class com.linkedin.parseq.promise.Promises
 

W

withRetryPolicy(String, RetryPolicy, Function1<Integer, Task<U>>) - Static method in class com.linkedin.parseq.retry.RetriableTask
A helper for creating task wrapper with associated retry policy.
withRetryPolicy(RetryPolicy, Callable<Task<T>>) - Static method in interface com.linkedin.parseq.Task
Equivalent to withRetryPolicy("operation", policy, taskSupplier).
withRetryPolicy(RetryPolicy, Function1<Integer, Task<T>>) - Static method in interface com.linkedin.parseq.Task
Equivalent to withRetryPolicy("operation", policy, taskSupplier).
withRetryPolicy(String, RetryPolicy, Callable<Task<T>>) - Static method in interface com.linkedin.parseq.Task
Creates a new task that will run and potentially retry task returned by a taskSupplier.
withRetryPolicy(String, RetryPolicy, Function1<Integer, Task<T>>) - Static method in interface com.linkedin.parseq.Task
Creates a new task that will run and potentially retry task returned by a taskSupplier.
withSideEffect(String, Function1<? super T, Task<?>>) - Method in interface com.linkedin.parseq.Task
Creates a new task that will run another task as a side effect once the primary task completes successfully.
withSideEffect(Function1<? super T, Task<?>>) - Method in interface com.linkedin.parseq.Task
Equivalent to withSideEffect("sideEffect", func).
withSideEffect(Task<T>, Task<?>) - Static method in class com.linkedin.parseq.Tasks
Deprecated.
As of 2.0.0, replaced by Task.withSideEffect
withSideEffect(Function2<T1, T2, Task<?>>) - Method in interface com.linkedin.parseq.Tuple2Task
Equivalent to withSideEffect("sideEffect", func).
withSideEffect(String, Function2<T1, T2, Task<?>>) - Method in interface com.linkedin.parseq.Tuple2Task
Creates a new task that will run another task as a side effect once the primary task completes successfully.
withSideEffect(Function3<T1, T2, T3, Task<?>>) - Method in interface com.linkedin.parseq.Tuple3Task
Equivalent to withSideEffect("sideEffect", func).
withSideEffect(String, Function3<T1, T2, T3, Task<?>>) - Method in interface com.linkedin.parseq.Tuple3Task
Creates a new task that will run another task as a side effect once the primary task completes successfully.
withSideEffect(Function4<T1, T2, T3, T4, Task<?>>) - Method in interface com.linkedin.parseq.Tuple4Task
Equivalent to withSideEffect("sideEffect", func).
withSideEffect(String, Function4<T1, T2, T3, T4, Task<?>>) - Method in interface com.linkedin.parseq.Tuple4Task
Creates a new task that will run another task as a side effect once the primary task completes successfully.
withSideEffect(Function5<T1, T2, T3, T4, T5, Task<?>>) - Method in interface com.linkedin.parseq.Tuple5Task
Equivalent to withSideEffect("sideEffect", func).
withSideEffect(String, Function5<T1, T2, T3, T4, T5, Task<?>>) - Method in interface com.linkedin.parseq.Tuple5Task
Creates a new task that will run another task as a side effect once the primary task completes successfully.
withSideEffect(Function6<T1, T2, T3, T4, T5, T6, Task<?>>) - Method in interface com.linkedin.parseq.Tuple6Task
Equivalent to withSideEffect("sideEffect", func).
withSideEffect(String, Function6<T1, T2, T3, T4, T5, T6, Task<?>>) - Method in interface com.linkedin.parseq.Tuple6Task
Creates a new task that will run another task as a side effect once the primary task completes successfully.
withSideEffect(Function7<T1, T2, T3, T4, T5, T6, T7, Task<?>>) - Method in interface com.linkedin.parseq.Tuple7Task
Equivalent to withSideEffect("sideEffect", func).
withSideEffect(String, Function7<T1, T2, T3, T4, T5, T6, T7, Task<?>>) - Method in interface com.linkedin.parseq.Tuple7Task
Creates a new task that will run another task as a side effect once the primary task completes successfully.
withSideEffect(Function8<T1, T2, T3, T4, T5, T6, T7, T8, Task<?>>) - Method in interface com.linkedin.parseq.Tuple8Task
Equivalent to withSideEffect("sideEffect", func).
withSideEffect(String, Function8<T1, T2, T3, T4, T5, T6, T7, T8, Task<?>>) - Method in interface com.linkedin.parseq.Tuple8Task
Creates a new task that will run another task as a side effect once the primary task completes successfully.
withSideEffect(Function9<T1, T2, T3, T4, T5, T6, T7, T8, T9, Task<?>>) - Method in interface com.linkedin.parseq.Tuple9Task
Equivalent to withSideEffect("sideEffect", func).
withSideEffect(String, Function9<T1, T2, T3, T4, T5, T6, T7, T8, T9, Task<?>>) - Method in interface com.linkedin.parseq.Tuple9Task
Creates a new task that will run another task as a side effect once the primary task completes successfully.
withTimeout(long, TimeUnit) - Method in interface com.linkedin.parseq.Task
Equivalent to withTimeout(null, time, unit).
withTimeout(String, long, TimeUnit) - Method in interface com.linkedin.parseq.Task
Creates a new task that has a timeout associated with it.
withTimeout(long, TimeUnit) - Method in interface com.linkedin.parseq.Tuple2Task
Equivalent to withTimeout(null, time, unit).
withTimeout(long, TimeUnit) - Method in interface com.linkedin.parseq.Tuple3Task
Equivalent to withTimeout(null, time, unit).
withTimeout(long, TimeUnit) - Method in interface com.linkedin.parseq.Tuple4Task
Equivalent to withTimeout(null, time, unit).
withTimeout(long, TimeUnit) - Method in interface com.linkedin.parseq.Tuple5Task
Equivalent to withTimeout(null, time, unit).
withTimeout(long, TimeUnit) - Method in interface com.linkedin.parseq.Tuple6Task
Equivalent to withTimeout(null, time, unit).
withTimeout(long, TimeUnit) - Method in interface com.linkedin.parseq.Tuple7Task
Equivalent to withTimeout(null, time, unit).
withTimeout(long, TimeUnit) - Method in interface com.linkedin.parseq.Tuple8Task
Equivalent to withTimeout(null, time, unit).
withTimeout(long, TimeUnit) - Method in interface com.linkedin.parseq.Tuple9Task
Equivalent to withTimeout(null, time, unit).

_

_1() - Method in class com.linkedin.parseq.function.Tuple2
 
_1() - Method in class com.linkedin.parseq.function.Tuple3
 
_1() - Method in class com.linkedin.parseq.function.Tuple4
 
_1() - Method in class com.linkedin.parseq.function.Tuple5
 
_1() - Method in class com.linkedin.parseq.function.Tuple6
 
_1() - Method in class com.linkedin.parseq.function.Tuple7
 
_1() - Method in class com.linkedin.parseq.function.Tuple8
 
_1() - Method in class com.linkedin.parseq.function.Tuple9
 
_2() - Method in class com.linkedin.parseq.function.Tuple2
 
_2() - Method in class com.linkedin.parseq.function.Tuple3
 
_2() - Method in class com.linkedin.parseq.function.Tuple4
 
_2() - Method in class com.linkedin.parseq.function.Tuple5
 
_2() - Method in class com.linkedin.parseq.function.Tuple6
 
_2() - Method in class com.linkedin.parseq.function.Tuple7
 
_2() - Method in class com.linkedin.parseq.function.Tuple8
 
_2() - Method in class com.linkedin.parseq.function.Tuple9
 
_3() - Method in class com.linkedin.parseq.function.Tuple3
 
_3() - Method in class com.linkedin.parseq.function.Tuple4
 
_3() - Method in class com.linkedin.parseq.function.Tuple5
 
_3() - Method in class com.linkedin.parseq.function.Tuple6
 
_3() - Method in class com.linkedin.parseq.function.Tuple7
 
_3() - Method in class com.linkedin.parseq.function.Tuple8
 
_3() - Method in class com.linkedin.parseq.function.Tuple9
 
_4() - Method in class com.linkedin.parseq.function.Tuple4
 
_4() - Method in class com.linkedin.parseq.function.Tuple5
 
_4() - Method in class com.linkedin.parseq.function.Tuple6
 
_4() - Method in class com.linkedin.parseq.function.Tuple7
 
_4() - Method in class com.linkedin.parseq.function.Tuple8
 
_4() - Method in class com.linkedin.parseq.function.Tuple9
 
_5() - Method in class com.linkedin.parseq.function.Tuple5
 
_5() - Method in class com.linkedin.parseq.function.Tuple6
 
_5() - Method in class com.linkedin.parseq.function.Tuple7
 
_5() - Method in class com.linkedin.parseq.function.Tuple8
 
_5() - Method in class com.linkedin.parseq.function.Tuple9
 
_6() - Method in class com.linkedin.parseq.function.Tuple6
 
_6() - Method in class com.linkedin.parseq.function.Tuple7
 
_6() - Method in class com.linkedin.parseq.function.Tuple8
 
_6() - Method in class com.linkedin.parseq.function.Tuple9
 
_7() - Method in class com.linkedin.parseq.function.Tuple7
 
_7() - Method in class com.linkedin.parseq.function.Tuple8
 
_7() - Method in class com.linkedin.parseq.function.Tuple9
 
_8() - Method in class com.linkedin.parseq.function.Tuple8
 
_8() - Method in class com.linkedin.parseq.function.Tuple9
 
_9() - Method in class com.linkedin.parseq.function.Tuple9
 
_backoff - Variable in class com.linkedin.parseq.retry.backoff.ConstantBackoff
 
_backoff - Variable in class com.linkedin.parseq.retry.backoff.ExponentialBackoff
 
_backoff - Variable in class com.linkedin.parseq.retry.backoff.FibonacciBackoff
 
_backoff - Variable in class com.linkedin.parseq.retry.backoff.LinearBackoff
 
_first - Variable in class com.linkedin.parseq.retry.termination.RequireBoth
 
_first - Variable in class com.linkedin.parseq.retry.termination.RequireEither
 
_maxAttempts - Variable in class com.linkedin.parseq.retry.termination.LimitAttempts
 
_maxDuration - Variable in class com.linkedin.parseq.retry.termination.LimitDuration
 
_maxRange - Variable in class com.linkedin.parseq.retry.backoff.RandomizedBackoff
 
_minRange - Variable in class com.linkedin.parseq.retry.backoff.RandomizedBackoff
 
_policy - Variable in class com.linkedin.parseq.retry.backoff.RandomizedBackoff
 
_policyFunction - Variable in class com.linkedin.parseq.retry.backoff.SelectedBackoff
 
_second - Variable in class com.linkedin.parseq.retry.termination.RequireBoth
 
_second - Variable in class com.linkedin.parseq.retry.termination.RequireEither
 
_shallowTraceBuilder - Variable in class com.linkedin.parseq.BaseTask
 
_taskDescriptor - Static variable in interface com.linkedin.parseq.Task
 
_traceValueProvider - Variable in class com.linkedin.parseq.BaseTask
 
A B C D E F G H I J L M N O P R S T V W _ 
Skip navigation links