abc.ABC
temporalio.client.BuildIdOp
- Base class for Build ID operations as used by Client.update_worker_build_id_compatibility
.temporalio.client.BuildIdOpAddNewCompatible
- Adds a new Build Id into an existing compatible set. The newly added ID becomes the default for that compatible set, and thus new workflow tasks for workflows which have been executing on workers in that set will now start on this new Build Id.temporalio.client.BuildIdOpAddNewDefault
- Adds a new Build Id into a new set, which will be used as the default set for the queue. This means all new workflows will start on this Build Id.temporalio.client.BuildIdOpMergeSets
- Merges two sets into one set, thus declaring all the Build Ids in both as compatible with one another. The default of the primary set is maintained as the merged set's overall default.temporalio.client.BuildIdOpPromoteBuildIdWithinSet
- Promotes a Build Id within an existing set to become the default ID for that set.temporalio.client.BuildIdOpPromoteSetByBuildId
- Promotes a set of compatible Build Ids to become the current default set for the task queue. Any Build Id in the set may be used to target it.temporalio.client.ScheduleAction
- Base class for an action a schedule can take.temporalio.client.ScheduleActionStartWorkflow
- Schedule action to start a workflow.temporalio.client.ScheduleActionExecution
- Base class for an action execution.temporalio.client.ScheduleActionExecutionStartWorkflow
- Execution of a scheduled workflow start.temporalio.client.ScheduleListAction
- Base class for an action a listed schedule can take.temporalio.client.ScheduleListActionStartWorkflow
- Action to start a workflow on a listed schedule.temporalio.common.MetricCounter
- Counter metric created by a metric meter.temporalio.common._NoopMetricCounter
- Undocumentedtemporalio.runtime._MetricCounter
- Undocumentedtemporalio.worker._workflow_instance._ReplaySafeMetricCounter
- Undocumentedtemporalio.common.MetricGauge
- Gauge metric created by a metric meter.temporalio.common._NoopMetricGauge
- Undocumentedtemporalio.runtime._MetricGauge
- Undocumentedtemporalio.worker._workflow_instance._ReplaySafeMetricGauge
- Undocumentedtemporalio.common.MetricHistogram
- Histogram metric created by a metric meter.temporalio.common._NoopMetricHistogram
- Undocumentedtemporalio.runtime._MetricHistogram
- Undocumentedtemporalio.worker._workflow_instance._ReplaySafeMetricHistogram
- Undocumentedtemporalio.common.MetricMeter
- Metric meter for recording metrics.temporalio.common._NoopMetricMeter
- Undocumentedtemporalio.runtime._MetricMeter
- Undocumentedtemporalio.worker._workflow_instance._ReplaySafeMetricMeter
- Undocumentedtemporalio.common.SearchAttributeKey
- Typed search attribute key representation.temporalio.common._SearchAttributeKey
- Undocumentedtemporalio.common.SearchAttributeUpdate
- Representation of a search attribute update.temporalio.common._SearchAttributeUpdate
- Undocumentedtemporalio.converter.EncodingPayloadConverter
- Base converter to/from single payload/value with a known encoding for use in CompositePayloadConverter.temporalio.converter.BinaryNullPayloadConverter
- Converter for 'binary/null' payloads supporting None values.temporalio.converter.BinaryPlainPayloadConverter
- Converter for 'binary/plain' payloads supporting bytes values.temporalio.converter.BinaryProtoPayloadConverter
- Converter for 'binary/protobuf' payloads supporting protobuf Message values.temporalio.converter.JSONPlainPayloadConverter
- Converter for 'json/plain' payloads supporting common Python values.temporalio.converter.JSONProtoPayloadConverter
- Converter for 'json/protobuf' payloads supporting protobuf Message values.temporalio.converter.FailureConverter
- Base failure converter to/from errors.temporalio.converter.DefaultFailureConverter
- Default failure converter.temporalio.converter.DefaultFailureConverterWithEncodedAttributes
- Implementation of DefaultFailureConverter
which moves message and stack trace to encoded attributes subject to a codec.temporalio.converter.JSONTypeConverter
- Converter for converting an object from Python json.loads
result (e.g. scalar, list, or dict) to a known type.temporalio.converter.PayloadCodec
- Codec for encoding/decoding to/from bytes.temporalio.converter.PayloadConverter
- Base payload converter to/from multiple payloads/values.temporalio.converter.CompositePayloadConverter
- Composite payload converter that delegates to a list of encoding payload converters.temporalio.converter.DefaultPayloadConverter
- Default payload converter compatible with other Temporal SDKs.temporalio.service.ServiceClient
- Direct client to Temporal services.temporalio.service._BridgeServiceClient
- No class docstring; 1/1 property, 0/3 instance variable, 1/4 method, 0/1 static method documentedtemporalio.worker.SharedHeartbeatSender
- Base class for a heartbeat sender that is picklable for use in another process.temporalio.worker.SharedStateManager
- Base class for a shared state manager providing cross-process-safe primitives for use by activity executors.temporalio.worker.WorkflowInstance
- Instance of a workflow that can handle activations.temporalio.worker._workflow_instance._WorkflowInstanceImpl
- Undocumentedtemporalio.worker.workflow_sandbox._runner._Instance
- Undocumentedtemporalio.worker.WorkflowRunner
- Abstract runner for workflows that creates workflow instances to run.temporalio.worker.UnsandboxedWorkflowRunner
- Workflow runner that does not do any sandboxing.temporalio.worker.workflow_sandbox.SandboxedWorkflowRunner
- Runner for workflows in a sandbox.temporalio.workflow._Runtime
- Undocumentedtemporalio.worker._workflow_instance._WorkflowInstanceImpl
- Undocumentedasyncio.AbstractEventLoop
temporalio.worker._workflow_instance._WorkflowInstanceImpl
- Undocumentedasyncio.Task
temporalio.workflow._AsyncioTask
- Undocumentedtemporalio.workflow.ActivityHandle
- Handle returned from start_activity
and start_local_activity
.temporalio.worker._workflow_instance._ActivityHandle
- Undocumentedtemporalio.workflow.ChildWorkflowHandle
- Handle for interacting with a child workflow.temporalio.worker._workflow_instance._ChildWorkflowHandle
- Undocumentedasyncio.TimerHandle
temporalio.worker._workflow_instance._TimerHandle
- UndocumentedBaseException
temporalio.activity._CompleteAsyncError
- Undocumentedtemporalio.worker._workflow_instance._ActivityDoBackoffError
- Undocumentedtemporalio.workflow.ContinueAsNewError
- Error thrown by continue_as_new
.temporalio.worker._workflow_instance._ContinueAsNewError
- Undocumentedenum.Enum
temporalio.client.TaskReachabilityType
- Enumerates how a task might reach certain kinds of workflowstemporalio.runtime.OpenTelemetryMetricTemporality
- Temporality for OpenTelemetry metrics.temporalio.workflow.VersioningIntent
- Indicates whether the user intends certain commands to be run on a compatible worker Build Id version or not.enum.IntEnum
temporalio.client.ScheduleOverlapPolicy
- Controls what happens when a workflow would be started by a schedule but one is already running.temporalio.client.WorkflowExecutionStatus
- Status of a workflow execution.temporalio.client.WorkflowHistoryEventFilterType
- Type of history events to get for a workflow.temporalio.common.QueryRejectCondition
- Whether a query should be rejected in certain conditions.temporalio.common.SearchAttributeIndexedValueType
- Server index type of a search attribute.temporalio.common.WorkflowIDReusePolicy
- How already-in-use workflow IDs are handled on start.temporalio.exceptions.RetryState
- Current retry state of the workflow/activity during error.temporalio.exceptions.TimeoutType
- Type of timeout for TimeoutError
.temporalio.service.RPCStatusCode
- Status code for RPCError
.temporalio.workflow.ActivityCancellationType
- How an activity cancellation should be handled.temporalio.workflow.ChildWorkflowCancellationType
- How a child workflow cancellation should be handled.temporalio.workflow.ParentClosePolicy
- How a child workflow should be handled when the parent closes.Exception
temporalio.exceptions.TemporalError
- Base for all Temporal exceptions.temporalio.client.AsyncActivityCancelledError
- Error that occurs when async activity attempted heartbeat but was cancelled.temporalio.client.ScheduleAlreadyRunningError
- Error when a schedule is already running.temporalio.client.WorkflowContinuedAsNewError
- Error that occurs when a workflow was continued as new.temporalio.client.WorkflowFailureError
- Error that occurs when a workflow is unsuccessful.temporalio.client.WorkflowQueryFailedError
- Error that occurs when a query fails.temporalio.client.WorkflowQueryRejectedError
- Error that occurs when a query was rejected.temporalio.client.WorkflowUpdateFailedError
- Error that occurs when an update fails.temporalio.exceptions.FailureError
- Base for runtime failures during workflow/activity execution.temporalio.exceptions.ActivityError
- Error raised on activity failure.temporalio.exceptions.ApplicationError
- Error raised during workflow/activity execution.temporalio.exceptions.CancelledError
- Error raised on workflow/activity cancellation.temporalio.exceptions.ChildWorkflowError
- Error raised on child workflow failure.temporalio.exceptions.ServerError
- Error originating in the Temporal server.temporalio.exceptions.TerminatedError
- Error raised on workflow cancellation.temporalio.exceptions.TimeoutError
- Error raised on workflow/activity timeout.temporalio.exceptions.WorkflowAlreadyStartedError
- Thrown by a client or workflow when a workflow execution has already started.temporalio.service.RPCError
- Error during RPC call.temporalio.workflow._NotInWorkflowEventLoopError
- Undocumentedtemporalio.workflow._UnexpectedEvictionError
- Undocumentedtemporalio.workflow.NondeterminismError
- Error that can be thrown during replay for non-deterministic workflow.temporalio.worker.workflow_sandbox.RestrictedWorkflowAccessError
- Error that occurs when a workflow accesses something non-deterministic.temporalio.workflow.ReadOnlyContextError
- Error thrown when trying to do mutable workflow calls in a read-only context like a query or update validator.json.JSONEncoder
temporalio.converter.AdvancedJSONEncoder
- Advanced JSON encoder.logging.LoggerAdapter
temporalio.activity.LoggerAdapter
- Adapter that adds details to the log about the running activity.temporalio.workflow.LoggerAdapter
- Adapter that adds details to the log about the running workflow.RuntimeError
temporalio.worker._worker._ShutdownRequested
- Undocumentedtemporalio.activity._CompositeEvent
- Undocumentedtemporalio.activity._Context
- Undocumentedtemporalio.activity._Definition
- Undocumentedtemporalio.activity.Info
- Information about the running activity.temporalio.bridge.client.Client
- RPC client using SDK Core.temporalio.bridge.client.ClientConfig
- Python representation of the Rust struct for configuring the client.temporalio.bridge.client.ClientKeepAliveConfig
- Python representation of the Rust struct for configuring keep alive.temporalio.bridge.client.ClientRetryConfig
- Python representation of the Rust struct for configuring retry.temporalio.bridge.client.ClientTlsConfig
- Python representation of the Rust struct for configuring TLS.temporalio.bridge.client.RpcCall
- Python representation of the Rust struct for an RPC call.temporalio.bridge.metric.MetricAttributes
- Metric attributes using SDK Core.temporalio.bridge.metric.MetricCounter
- Metric counter using SDK Core.temporalio.bridge.metric.MetricGauge
- Metric gauge using SDK Core.temporalio.bridge.metric.MetricHistogram
- Metric histogram using SDK Core.temporalio.bridge.metric.MetricMeter
- Metric meter using SDK Core.temporalio.bridge.runtime.LoggingConfig
- Python representation of the Rust struct for logging config.temporalio.bridge.runtime.MetricsConfig
- Python representation of the Rust struct for metrics config.temporalio.bridge.runtime.OpenTelemetryConfig
- Python representation of the Rust struct for OpenTelemetry config.temporalio.bridge.runtime.PrometheusConfig
- Python representation of the Rust struct for Prometheus config.temporalio.bridge.runtime.Runtime
- Runtime for SDK Core.temporalio.bridge.runtime.TelemetryConfig
- Python representation of the Rust struct for telemetry config.temporalio.bridge.testing.DevServerConfig
- Python representation of the Rust struct for configuring dev server.temporalio.bridge.testing.EphemeralServer
- Python representation of a Rust ephemeral server.temporalio.bridge.testing.TestServerConfig
- Python representation of the Rust struct for configuring test server.temporalio.bridge.worker.Worker
- SDK Core worker.temporalio.bridge.worker.WorkerConfig
- Python representation of the Rust struct for configuring a worker.temporalio.client.AsyncActivityHandle
- Handle representing an external activity for completion and heartbeat.temporalio.client.AsyncActivityIDReference
- Reference to an async activity by its qualified ID.temporalio.client.BackfillScheduleInput
- Input for OutboundInterceptor.backfill_schedule
.temporalio.client.BuildIdReachability
- Contains information about the reachability of a specific Build IDtemporalio.client.BuildIdVersionSet
- A set of Build IDs which are compatible with each other.temporalio.client.CancelWorkflowInput
- Input for OutboundInterceptor.cancel_workflow
.temporalio.client.Client
- Client for accessing Temporal.temporalio.client.CompleteAsyncActivityInput
- Input for OutboundInterceptor.complete_async_activity
.temporalio.client.CreateScheduleInput
- Input for OutboundInterceptor.create_schedule
.temporalio.client.DeleteScheduleInput
- Input for OutboundInterceptor.delete_schedule
.temporalio.client.DescribeScheduleInput
- Input for OutboundInterceptor.describe_schedule
.temporalio.client.DescribeWorkflowInput
- Input for OutboundInterceptor.describe_workflow
.temporalio.client.FailAsyncActivityInput
- Input for OutboundInterceptor.fail_async_activity
.temporalio.client.FetchWorkflowHistoryEventsInput
- Input for OutboundInterceptor.fetch_workflow_history_events
.temporalio.client.GetWorkerBuildIdCompatibilityInput
- Input for OutboundInterceptor.get_worker_build_id_compatibility
.temporalio.client.GetWorkerTaskReachabilityInput
- Input for OutboundInterceptor.get_worker_task_reachability
.temporalio.client.HeartbeatAsyncActivityInput
- Input for OutboundInterceptor.heartbeat_async_activity
.temporalio.client.Interceptor
- Interceptor for clients.temporalio.contrib.opentelemetry.TracingInterceptor
- Interceptor that supports client and worker OpenTelemetry span creation and propagation.temporalio.testing._workflow._AssertionErrorInterceptor
- Undocumentedtemporalio.testing._workflow._TimeSkippingClientInterceptor
- Undocumentedtemporalio.client.ListSchedulesInput
- Input for OutboundInterceptor.list_schedules
.temporalio.client.ListWorkflowsInput
- Input for OutboundInterceptor.list_workflows
.temporalio.client.OutboundInterceptor
- OutboundInterceptor for intercepting client calls.temporalio.client._ClientImpl
- Undocumentedtemporalio.contrib.opentelemetry._TracingClientOutboundInterceptor
- Undocumentedtemporalio.testing._workflow._TimeSkippingClientOutboundInterceptor
- Undocumentedtemporalio.client.PauseScheduleInput
- Input for OutboundInterceptor.pause_schedule
.temporalio.client.QueryWorkflowInput
- Input for OutboundInterceptor.query_workflow
.temporalio.client.ReportCancellationAsyncActivityInput
- Input for OutboundInterceptor.report_cancellation_async_activity
.temporalio.client.Schedule
- A schedule for periodically running an action.temporalio.client.ScheduleActionResult
- Information about when an action took place.temporalio.client.ScheduleAsyncIterator
- Asynchronous iterator for ScheduleListDescription
values.temporalio.client.ScheduleBackfill
- Time period and policy for actions taken as if the time passed right now.temporalio.client.ScheduleCalendarSpec
- Specification relative to calendar time when to run an action.temporalio.client.ScheduleDescription
- Description of a schedule.temporalio.client.ScheduleHandle
- Handle for interacting with a schedule.temporalio.client.ScheduleInfo
- Information about a schedule.temporalio.client.ScheduleIntervalSpec
- Specification for scheduling on an interval.temporalio.client.ScheduleListDescription
- Description of a listed schedule.temporalio.client.ScheduleListInfo
- Information about a listed schedule.temporalio.client.ScheduleListSchedule
- Details for a listed schedule.temporalio.client.ScheduleListState
- State of a listed schedule.temporalio.client.SchedulePolicy
- Policies of a schedule.temporalio.client.ScheduleRange
- Inclusive range for a schedule match value.temporalio.client.ScheduleSpec
- Specification of the times scheduled actions may occur.temporalio.client.ScheduleState
- State of a schedule.temporalio.client.ScheduleUpdate
- Result of an update callback for ScheduleHandle.update
.temporalio.client.ScheduleUpdateInput
- Parameter for an update callback for ScheduleHandle.update
.temporalio.client.SignalWorkflowInput
- Input for OutboundInterceptor.signal_workflow
.temporalio.client.StartWorkflowInput
- Input for OutboundInterceptor.start_workflow
.temporalio.client.StartWorkflowUpdateInput
- Input for OutboundInterceptor.start_workflow_update
.temporalio.client.TerminateWorkflowInput
- Input for OutboundInterceptor.terminate_workflow
.temporalio.client.TriggerScheduleInput
- Input for OutboundInterceptor.trigger_schedule
.temporalio.client.UnpauseScheduleInput
- Input for OutboundInterceptor.unpause_schedule
.temporalio.client.UpdateScheduleInput
- Input for OutboundInterceptor.update_schedule
.temporalio.client.UpdateWorkerBuildIdCompatibilityInput
- Input for OutboundInterceptor.update_worker_build_id_compatibility
.temporalio.client.WorkerBuildIdVersionSets
- Represents the sets of compatible Build ID versions associated with some Task Queue, as fetched by Client.get_worker_build_id_compatibility
.temporalio.client.WorkerTaskReachability
- Contains information about the reachability of some Build IDstemporalio.client.WorkflowExecution
- Info for a single workflow execution run.temporalio.client.WorkflowExecutionDescription
- Description for a single workflow execution run.temporalio.client.WorkflowExecutionAsyncIterator
- Asynchronous iterator for WorkflowExecution
values.temporalio.client.WorkflowHistory
- A workflow's ID and immutable history.temporalio.client.WorkflowHistoryEventAsyncIterator
- Asynchronous iterator for history events of a workflow.temporalio.common._NoopMetric
- Undocumentedtemporalio.common._NoopMetricCounter
- Undocumentedtemporalio.common._NoopMetricGauge
- Undocumentedtemporalio.common._NoopMetricHistogram
- Undocumentedtemporalio.common.RawValue
- Representation of an unconverted, raw payload.temporalio.common.RetryPolicy
- Options for retrying workflows and activities.temporalio.contrib.opentelemetry._CompletedWorkflowSpanParams
- Undocumentedtemporalio.contrib.opentelemetry.workflow
- Contains static methods that are safe to call from within a workflow.temporalio.converter.DataConverter
- Data converter for converting and encoding payloads to/from Python values.temporalio.runtime.LogForwardingConfig
- Configuration for log forwarding from Core.temporalio.runtime.LoggingConfig
- Configuration for runtime logging.temporalio.runtime.MetricBuffer
- A buffer that can be set on TelemetryConfig
to record metrics instead of ignoring/exporting them.temporalio.runtime.OpenTelemetryConfig
- Configuration for OpenTelemetry collector.temporalio.runtime.PrometheusConfig
- Configuration for Prometheus metrics endpoint.temporalio.runtime.Runtime
- Runtime for Temporal Python SDK.temporalio.runtime.TelemetryConfig
- Configuration for Core telemetry.temporalio.runtime.TelemetryFilter
- Filter for telemetry use.temporalio.service.ConnectConfig
- Config for connecting to the server.temporalio.service.KeepAliveConfig
- Keep-alive configuration for client connections.temporalio.service.OperatorService
- Client to the Temporal server's operator service.temporalio.service.RetryConfig
- Retry configuration for server calls.temporalio.service.TestService
- Client to the Temporal test server's test service.temporalio.service.TLSConfig
- TLS configuration for connecting to Temporal server.temporalio.service.WorkflowService
- Client to the Temporal server's workflow service.temporalio.testing._activity._Activity
- Undocumentedtemporalio.testing.ActivityEnvironment
- Activity environment for testing activities.temporalio.testing.WorkflowEnvironment
- Workflow environment for testing workflows.temporalio.worker._activity._ActivityWorker
- Undocumentedtemporalio.worker._activity._RunningActivity
- Undocumentedtemporalio.worker._activity._ThreadExceptionRaiser
- Undocumentedtemporalio.worker._interceptor.WorkflowInboundInterceptor
temporalio.worker._workflow_instance._WorkflowInboundImpl
- Undocumentedtemporalio.worker._interceptor.WorkflowOutboundInterceptor
temporalio.worker._workflow_instance._WorkflowOutboundImpl
- Undocumentedtemporalio.worker._workflow._WorkflowWorker
- Undocumentedtemporalio.worker.ActivityInboundInterceptor
- Inbound interceptor to wrap outbound creation and activity execution.temporalio.contrib.opentelemetry._TracingActivityInboundInterceptor
- Undocumentedtemporalio.worker._activity._ActivityInboundImpl
- Undocumentedtemporalio.worker.ActivityOutboundInterceptor
- Outbound interceptor to wrap calls made from within activities.temporalio.worker._activity._ActivityOutboundImpl
- Undocumentedtemporalio.worker.ContinueAsNewInput
- Input for WorkflowOutboundInterceptor.continue_as_new
.temporalio.worker.ExecuteActivityInput
- Input for ActivityInboundInterceptor.execute_activity
.temporalio.worker.ExecuteWorkflowInput
- Input for WorkflowInboundInterceptor.execute_workflow
.temporalio.worker.HandleQueryInput
- Input for WorkflowInboundInterceptor.handle_query
.temporalio.worker.HandleSignalInput
- Input for WorkflowInboundInterceptor.handle_signal
.temporalio.worker.HandleUpdateInput
- Input for WorkflowInboundInterceptor.handle_update_validator
and WorkflowInboundInterceptor.handle_update_handler
.temporalio.worker.Interceptor
- Interceptor for workers.temporalio.contrib.opentelemetry.TracingInterceptor
- Interceptor that supports client and worker OpenTelemetry span creation and propagation.temporalio.testing._workflow._AssertionErrorInterceptor
- Undocumentedtemporalio.worker.Replayer
- Replayer to replay workflows from history.temporalio.worker.SignalChildWorkflowInput
- Input for WorkflowOutboundInterceptor.signal_child_workflow
.temporalio.worker.SignalExternalWorkflowInput
- Input for WorkflowOutboundInterceptor.signal_external_workflow
.temporalio.worker.StartActivityInput
- Input for WorkflowOutboundInterceptor.start_activity
.temporalio.worker.StartChildWorkflowInput
- Input for WorkflowOutboundInterceptor.start_child_workflow
.temporalio.worker.StartLocalActivityInput
- Input for WorkflowOutboundInterceptor.start_local_activity
.temporalio.worker.Worker
- Worker to process workflows and/or activities.temporalio.worker.workflow_sandbox._importer.Importer
- Importer that restricts modules.temporalio.worker.workflow_sandbox._in_sandbox.InSandbox
- Instance that is expected to run inside a sandbox.temporalio.worker.workflow_sandbox._restrictions._RestrictedProxy
- Undocumentedtemporalio.worker.workflow_sandbox._restrictions.RestrictedModule
- Module that is restricted.temporalio.worker.workflow_sandbox._restrictions._RestrictedProxyLookup
- No class docstring; 0/5 instance variable, 1/5 method documentedtemporalio.worker.workflow_sandbox._restrictions._RestrictionState
- Undocumentedtemporalio.worker.workflow_sandbox._restrictions.RestrictionContext
- Context passed around restrictions.temporalio.worker.workflow_sandbox.SandboxMatcher
- Matcher that is used to match modules and members during restriction and pass through checks.temporalio.worker.workflow_sandbox.SandboxRestrictions
- Set of restrictions that can be applied to a sandbox.temporalio.worker.WorkflowInboundInterceptor
- Inbound interceptor to wrap outbound creation, workflow execution, and signal/query handling.temporalio.contrib.opentelemetry.TracingWorkflowInboundInterceptor
- Tracing interceptor for workflow calls.temporalio.testing._workflow._AssertionErrorWorkflowInboundInterceptor
- Undocumentedtemporalio.worker.WorkflowInstanceDetails
- Immutable details for creating a workflow instance.temporalio.worker.WorkflowInterceptorClassInput
- Input for Interceptor.workflow_interceptor_class
.temporalio.worker.WorkflowOutboundInterceptor
- Outbound interceptor to wrap calls made from within workflows.temporalio.worker.WorkflowReplayResult
- Single workflow replay result.temporalio.worker.WorkflowReplayResults
- Results of replaying multiple workflows.temporalio.workflow._Definition
- Undocumentedtemporalio.workflow._QueryDefinition
- Undocumentedtemporalio.workflow._SignalDefinition
- Undocumentedtemporalio.workflow._UpdateDefinition
- Undocumentedtemporalio.workflow.Info
- Information about the running workflow.temporalio.workflow.ParentInfo
- Information about the parent workflow.temporalio.workflow.unsafe
- Contains static methods that should not normally be called during workflow execution except in advanced cases.types.ModuleType
temporalio.worker.workflow_sandbox._restrictions.RestrictedModule
- Module that is restricted.typing.Collection
temporalio.common.TypedSearchAttributes
- Collection of typed search attributes.typing.Generic
temporalio.client.WorkflowHandle
- Handle for interacting with a workflow.temporalio.testing._workflow._TimeSkippingWorkflowHandle
- Undocumentedtemporalio.client.WorkflowUpdateHandle
- Handle for a workflow update execution request.temporalio.common.SearchAttributeKey
- Typed search attribute key representation.temporalio.common._SearchAttributeKey
- Undocumentedtemporalio.common.SearchAttributePair
- A named tuple representing a key/value search attribute pair.temporalio.common.SearchAttributeUpdate
- Representation of a search attribute update.temporalio.common._SearchAttributeUpdate
- Undocumentedtemporalio.service.ServiceCall
- Callable RPC method for services.temporalio.worker.workflow_sandbox._importer._ThreadLocalOverride
- Undocumentedtemporalio.workflow.ChildWorkflowHandle
- Handle for interacting with a child workflow.temporalio.worker._workflow_instance._ChildWorkflowHandle
- Undocumentedtemporalio.workflow.ExternalWorkflowHandle
- Handle for interacting with an external workflow.temporalio.worker._workflow_instance._ExternalWorkflowHandle
- Undocumentedtyping.MutableMapping
typing_extensions.NamedTuple
temporalio.common.SearchAttributePair
- A named tuple representing a key/value search attribute pair.typing_extensions.Protocol
temporalio.bridge.runtime.BufferedLogEntry
- A buffered log entry.temporalio.contrib.opentelemetry._InputWithHeaders
- Undocumentedtemporalio.runtime.BufferedMetric
- A metric for a buffered update.temporalio.runtime.BufferedMetricUpdate
- A single metric value update.temporalio.types.CallableAsyncNoParam
- Generic callable type.temporalio.types.CallableAsyncSingleParam
- Generic callable type.temporalio.types.CallableSyncNoParam
- Generic callable type.temporalio.types.CallableSyncSingleParam
- Generic callable type.temporalio.types.MethodAsyncNoParam
- Generic callable type.temporalio.types.MethodAsyncSingleParam
- Generic callable type.temporalio.types.MethodSyncNoParam
- Generic callable type.temporalio.types.MethodSyncOrAsyncNoParam
- Generic callable type.temporalio.types.MethodSyncOrAsyncSingleParam
- Generic callable type.temporalio.types.MethodSyncSingleParam
- Generic callable type.temporalio.workflow.UpdateMethodMultiParam
- Decorated workflow update functions implement this.typing_extensions.TypedDict
temporalio.client.ClientConfig
- TypedDict of config originally passed to Client
.temporalio.contrib.opentelemetry._WorkflowExternFunctions
- Undocumentedtemporalio.worker._workflow_instance._WorkflowExternFunctions
- Undocumentedtemporalio.worker.ReplayerConfig
- TypedDict of config originally passed to Replayer
.temporalio.worker.WorkerConfig
- TypedDict of config originally passed to Worker
.temporalio.workflow.ActivityConfig
- TypedDict of config that can be used for start_activity
and execute_activity
.temporalio.workflow.ChildWorkflowConfig
- TypedDict of config that can be used for start_child_workflow
and execute_child_workflow
.temporalio.workflow.LocalActivityConfig
- TypedDict of config that can be used for start_local_activity
and execute_local_activity
.