Skip navigation links
A B C G I L M N P Q R S T U V W 

A

awaitTermination(long, TimeUnit) - Method in interface io.temporal.testing.TestWorkflowEnvironment
Blocks until all tasks have completed execution after a shutdown request, or the timeout occurs, or the current thread is interrupted, whichever happens first.
awaitTermination(long, TimeUnit) - Method in class io.temporal.testing.TestWorkflowEnvironmentInternal
 

B

build() - Method in class io.temporal.testing.TestEnvironmentOptions.Builder
 

C

close() - Method in class io.temporal.internal.testservice.TestWorkflowService
 
close() - Method in interface io.temporal.testing.TestActivityEnvironment
 
close() - Method in class io.temporal.testing.TestActivityEnvironmentInternal
 
close() - Method in interface io.temporal.testing.TestWorkflowEnvironment
close() - Method in class io.temporal.testing.TestWorkflowEnvironmentInternal
 
continueAsNew(StartWorkflowExecutionRequest, WorkflowExecutionContinuedAsNewEventAttributes, Optional<TestServiceRetryState>, String, ExecutionId, Optional<TestWorkflowMutableState>, OptionalLong) - Method in class io.temporal.internal.testservice.TestWorkflowService
Creates next run of a workflow execution
createServerOnly(int) - Static method in class io.temporal.internal.testservice.TestWorkflowService
 
currentTimeMillis() - Method in class io.temporal.internal.testservice.TestWorkflowService
 
currentTimeMillis() - Method in interface io.temporal.testing.TestWorkflowEnvironment
Returns the current in-memory test Temporal service time in milliseconds.
currentTimeMillis() - Method in class io.temporal.testing.TestWorkflowEnvironmentInternal
 

G

getDefaultInstance() - Static method in class io.temporal.testing.TestEnvironmentOptions
 
getDiagnostics(StringBuilder) - Method in class io.temporal.internal.testservice.TestWorkflowService
Adds diagnostic data about internal service state to the provided StringBuilder.
getDiagnostics() - Method in interface io.temporal.testing.TestWorkflowEnvironment
Returns the diagnostic data about the internal service state.
getDiagnostics() - Method in class io.temporal.testing.TestWorkflowEnvironmentInternal
 
getInitialTimeMillis() - Method in class io.temporal.testing.TestEnvironmentOptions
 
getMetricsScope() - Method in class io.temporal.testing.TestEnvironmentOptions
 
getNamespace() - Method in interface io.temporal.testing.TestWorkflowEnvironment
 
getNamespace() - Method in class io.temporal.testing.TestWorkflowEnvironmentInternal
 
getTarget() - Method in class io.temporal.testing.TestEnvironmentOptions
 
getWorkerFactory() - Method in interface io.temporal.testing.TestWorkflowEnvironment
 
getWorkerFactory() - Method in class io.temporal.testing.TestWorkflowEnvironmentInternal
 
getWorkerFactoryOptions() - Method in class io.temporal.testing.TestEnvironmentOptions
 
getWorkflowClient() - Method in interface io.temporal.testing.TestWorkflowEnvironment
Creates a WorkflowClient that is connected to the in-memory test Temporal service.
getWorkflowClient() - Method in class io.temporal.testing.TestWorkflowEnvironmentInternal
 
getWorkflowClientOptions() - Method in class io.temporal.testing.TestEnvironmentOptions
 
getWorkflowExecutionHistory(GetWorkflowExecutionHistoryRequest, StreamObserver<GetWorkflowExecutionHistoryResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
getWorkflowService() - Method in interface io.temporal.testing.TestWorkflowEnvironment
Returns the in-memory test Temporal service that is owned by this.
getWorkflowService() - Method in class io.temporal.testing.TestWorkflowEnvironmentInternal
 

I

io.temporal.internal.testservice - package io.temporal.internal.testservice
 
io.temporal.testing - package io.temporal.testing
 
isShutdown() - Method in interface io.temporal.testing.TestWorkflowEnvironment
isShutdown() - Method in class io.temporal.testing.TestWorkflowEnvironmentInternal
 
isStarted() - Method in interface io.temporal.testing.TestWorkflowEnvironment
isStarted() - Method in class io.temporal.testing.TestWorkflowEnvironmentInternal
 
isTerminated() - Method in interface io.temporal.testing.TestWorkflowEnvironment
isTerminated() - Method in class io.temporal.testing.TestWorkflowEnvironmentInternal
 
isUseExternalService() - Method in class io.temporal.testing.TestEnvironmentOptions
 

L

listClosedWorkflowExecutions(ListClosedWorkflowExecutionsRequest, StreamObserver<ListClosedWorkflowExecutionsResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
listOpenWorkflowExecutions(ListOpenWorkflowExecutionsRequest, StreamObserver<ListOpenWorkflowExecutionsResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
lockTimeSkipping(String) - Method in class io.temporal.internal.testservice.TestWorkflowService
Disables time skipping.

M

main(String[]) - Static method in class io.temporal.internal.testservice.TestServiceServer
 

N

newActivityStub(Class<T>) - Method in interface io.temporal.testing.TestActivityEnvironment
Creates a stub that can be used to invoke activities registered through TestActivityEnvironment.registerActivitiesImplementations(Object...).
newActivityStub(Class<T>, ActivityOptions) - Method in interface io.temporal.testing.TestActivityEnvironment
Creates a stub that can be used to invoke activities registered through TestActivityEnvironment.registerActivitiesImplementations(Object...).
newActivityStub(Class<T>) - Method in class io.temporal.testing.TestActivityEnvironmentInternal
Creates client stub to activities that implement given interface.
newActivityStub(Class<T>, ActivityOptions) - Method in class io.temporal.testing.TestActivityEnvironmentInternal
Creates client stub to activities that implement given interface.
newBuilder() - Static method in class io.temporal.testing.TestEnvironmentOptions
 
newBuilder(TestEnvironmentOptions) - Static method in class io.temporal.testing.TestEnvironmentOptions
 
newClientStub() - Method in class io.temporal.internal.testservice.TestWorkflowService
 
newInstance() - Static method in interface io.temporal.testing.TestActivityEnvironment
 
newInstance(TestEnvironmentOptions) - Static method in interface io.temporal.testing.TestActivityEnvironment
 
newInstance() - Static method in interface io.temporal.testing.TestWorkflowEnvironment
 
newInstance(TestEnvironmentOptions) - Static method in interface io.temporal.testing.TestWorkflowEnvironment
 
newLocalActivityStub(Class<T>, LocalActivityOptions, Map<String, LocalActivityOptions>) - Method in interface io.temporal.testing.TestActivityEnvironment
Creates a stub that can be used to invoke activities registered through TestActivityEnvironment.registerActivitiesImplementations(Object...).
newLocalActivityStub(Class<T>, LocalActivityOptions, Map<String, LocalActivityOptions>) - Method in class io.temporal.testing.TestActivityEnvironmentInternal
Creates client stub to activities that implement given interface.
newWorker(String) - Method in interface io.temporal.testing.TestWorkflowEnvironment
Creates a new Worker instance that is connected to the in-memory test Temporal service.
newWorker(String, WorkerOptions) - Method in interface io.temporal.testing.TestWorkflowEnvironment
Creates a new Worker instance that is connected to the in-memory test Temporal service.
newWorker(String) - Method in class io.temporal.testing.TestWorkflowEnvironmentInternal
 
newWorker(String, WorkerOptions) - Method in class io.temporal.testing.TestWorkflowEnvironmentInternal
 

P

pollActivityTaskQueue(PollActivityTaskQueueRequest, StreamObserver<PollActivityTaskQueueResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
pollWorkflowTaskQueue(PollWorkflowTaskQueueRequest, StreamObserver<PollWorkflowTaskQueueResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 

Q

queryWorkflow(QueryWorkflowRequest, StreamObserver<QueryWorkflowResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 

R

recordActivityTaskHeartbeat(RecordActivityTaskHeartbeatRequest, StreamObserver<RecordActivityTaskHeartbeatResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
recordActivityTaskHeartbeatById(RecordActivityTaskHeartbeatByIdRequest, StreamObserver<RecordActivityTaskHeartbeatByIdResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
registerActivitiesImplementations(Object...) - Method in interface io.temporal.testing.TestActivityEnvironment
Registers activity implementations to test.
registerActivitiesImplementations(Object...) - Method in class io.temporal.testing.TestActivityEnvironmentInternal
Register activity implementation objects with a worker.
registerDelayedCallback(Duration, Runnable) - Method in class io.temporal.internal.testservice.TestWorkflowService
Invokes callback after the specified delay according to internal service clock.
registerDelayedCallback(Duration, Runnable) - Method in interface io.temporal.testing.TestWorkflowEnvironment
Registers a callback to run after the specified delay according to the test Temporal service internal clock.
registerDelayedCallback(Duration, Runnable) - Method in class io.temporal.testing.TestWorkflowEnvironmentInternal
 
replayWorkflowExecution(File, Class<?>, Class<?>...) - Static method in class io.temporal.testing.WorkflowReplayer
Replays workflow from a file
replayWorkflowExecution(String, Class<?>, Class<?>...) - Static method in class io.temporal.testing.WorkflowReplayer
Replays workflow from a json serialized history.
replayWorkflowExecution(WorkflowExecutionHistory, Class<?>, Class<?>...) - Static method in class io.temporal.testing.WorkflowReplayer
Replays workflow from a WorkflowExecutionHistory.
replayWorkflowExecutionFromResource(String, Class<?>, Class<?>...) - Static method in class io.temporal.testing.WorkflowReplayer
Replays workflow from a resource that contains a json serialized history.
requestCancelActivity() - Method in interface io.temporal.testing.TestActivityEnvironment
Requests activity cancellation.
requestCancelActivity() - Method in class io.temporal.testing.TestActivityEnvironmentInternal
 
requestCancelWorkflowExecution(RequestCancelWorkflowExecutionRequest, StreamObserver<RequestCancelWorkflowExecutionResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
respondActivityTaskCanceled(RespondActivityTaskCanceledRequest, StreamObserver<RespondActivityTaskCanceledResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
respondActivityTaskCanceledById(RespondActivityTaskCanceledByIdRequest, StreamObserver<RespondActivityTaskCanceledByIdResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
respondActivityTaskCompleted(RespondActivityTaskCompletedRequest, StreamObserver<RespondActivityTaskCompletedResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
respondActivityTaskCompletedById(RespondActivityTaskCompletedByIdRequest, StreamObserver<RespondActivityTaskCompletedByIdResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
respondActivityTaskFailed(RespondActivityTaskFailedRequest, StreamObserver<RespondActivityTaskFailedResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
respondActivityTaskFailedById(RespondActivityTaskFailedByIdRequest, StreamObserver<RespondActivityTaskFailedByIdResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
respondQueryTaskCompleted(RespondQueryTaskCompletedRequest, StreamObserver<RespondQueryTaskCompletedResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
respondWorkflowTaskCompleted(RespondWorkflowTaskCompletedRequest, StreamObserver<RespondWorkflowTaskCompletedResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
respondWorkflowTaskFailed(RespondWorkflowTaskFailedRequest, StreamObserver<RespondWorkflowTaskFailedResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 

S

setActivityHeartbeatListener(Class<T>, Functions.Proc1<T>) - Method in interface io.temporal.testing.TestActivityEnvironment
Sets a listener that is called every time an activity implementation heartbeats through ActivityExecutionContext.heartbeat(Object).
setActivityHeartbeatListener(Class<T>, Type, Functions.Proc1<T>) - Method in interface io.temporal.testing.TestActivityEnvironment
Sets a listener that is called every time an activity implementation heartbeats through ActivityExecutionContext.heartbeat(Object).
setActivityHeartbeatListener(Class<T>, Functions.Proc1<T>) - Method in class io.temporal.testing.TestActivityEnvironmentInternal
 
setActivityHeartbeatListener(Class<T>, Type, Functions.Proc1<T>) - Method in class io.temporal.testing.TestActivityEnvironmentInternal
 
setInitialTime(Instant) - Method in class io.temporal.testing.TestEnvironmentOptions.Builder
Set the initial time for the workflow virtual clock.
setInitialTimeMillis(long) - Method in class io.temporal.testing.TestEnvironmentOptions.Builder
Set the initial time for the workflow virtual clock, milliseconds since epoch.
setMetricsScope(Scope) - Method in class io.temporal.testing.TestEnvironmentOptions.Builder
 
setTarget(String) - Method in class io.temporal.testing.TestEnvironmentOptions.Builder
Optional parameter that defines an endpoint which will be used for the communication with standalone temporal service.
setUseExternalService(boolean) - Method in class io.temporal.testing.TestEnvironmentOptions.Builder
Set to true in order to make test environment use external temporal service or false for in-memory test implementation.
setWorkerFactoryOptions(WorkerFactoryOptions) - Method in class io.temporal.testing.TestEnvironmentOptions.Builder
Set factoryOptions for worker factory used to create workers.
setWorkflowClientOptions(WorkflowClientOptions) - Method in class io.temporal.testing.TestEnvironmentOptions.Builder
 
shutdown() - Method in interface io.temporal.testing.TestWorkflowEnvironment
Initiates an orderly shutdown in which polls are stopped and already received workflow and activity tasks are executed.
shutdown() - Method in class io.temporal.testing.TestWorkflowEnvironmentInternal
 
shutdownNow() - Method in interface io.temporal.testing.TestWorkflowEnvironment
Initiates an orderly shutdown in which polls are stopped and already received workflow and activity tasks are attempted to be stopped.
shutdownNow() - Method in class io.temporal.testing.TestWorkflowEnvironmentInternal
 
signalExternalWorkflowExecution(String, SignalExternalWorkflowExecutionCommandAttributes, TestWorkflowMutableState) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
signalWithStartWorkflowExecution(SignalWithStartWorkflowExecutionRequest, StreamObserver<SignalWithStartWorkflowExecutionResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
signalWorkflowExecution(SignalWorkflowExecutionRequest, StreamObserver<SignalWorkflowExecutionResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
sleep(Duration) - Method in class io.temporal.internal.testservice.TestWorkflowService
Blocks calling thread until internal clock doesn't pass the current + duration time.
sleep(Duration) - Method in interface io.temporal.testing.TestWorkflowEnvironment
Wait until internal test Temporal service time passes the specified duration.
sleep(Duration) - Method in class io.temporal.testing.TestWorkflowEnvironmentInternal
 
start() - Method in interface io.temporal.testing.TestWorkflowEnvironment
Start all workers created by this factory.
start() - Method in class io.temporal.testing.TestWorkflowEnvironmentInternal
 
startWorkflowExecution(StartWorkflowExecutionRequest, StreamObserver<StartWorkflowExecutionResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 

T

terminateWorkflowExecution(TerminateWorkflowExecutionRequest, StreamObserver<TerminateWorkflowExecutionResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
TestActivityEnvironment - Interface in io.temporal.testing
The helper class for unit testing activity implementations.
TestActivityEnvironmentInternal - Class in io.temporal.testing
 
TestActivityEnvironmentInternal(TestEnvironmentOptions) - Constructor for class io.temporal.testing.TestActivityEnvironmentInternal
 
TestEnvironmentOptions - Class in io.temporal.testing
 
TestEnvironmentOptions.Builder - Class in io.temporal.testing
 
TestServiceServer - Class in io.temporal.internal.testservice
 
TestServiceServer() - Constructor for class io.temporal.internal.testservice.TestServiceServer
 
TestWorkflowEnvironment - Interface in io.temporal.testing
TestWorkflowEnvironment provides workflow unit testing capabilities.
TestWorkflowEnvironmentInternal - Class in io.temporal.testing
 
TestWorkflowEnvironmentInternal(TestEnvironmentOptions) - Constructor for class io.temporal.testing.TestWorkflowEnvironmentInternal
 
TestWorkflowService - Class in io.temporal.internal.testservice
In memory implementation of the Temporal service.
TestWorkflowService(boolean) - Constructor for class io.temporal.internal.testservice.TestWorkflowService
 
TestWorkflowService(long) - Constructor for class io.temporal.internal.testservice.TestWorkflowService
 
TestWorkflowService() - Constructor for class io.temporal.internal.testservice.TestWorkflowService
 
toString() - Method in class io.temporal.testing.TestEnvironmentOptions
 

U

unlockTimeSkipping(String) - Method in class io.temporal.internal.testservice.TestWorkflowService
 

V

validateAndBuildWithDefaults() - Method in class io.temporal.testing.TestEnvironmentOptions.Builder
 

W

WorkflowReplayer - Class in io.temporal.testing
Replays a workflow given its history.
WorkflowReplayer() - Constructor for class io.temporal.testing.WorkflowReplayer
 
A B C G I L M N P Q R S T U V W 
Skip navigation links