0.1.dev2184+g1e0cbe7.d20250401

Classes

Class Description
flytekit.clients.auth.auth_client.AuthorizationClient Authorization client that stores the credentials in keyring and uses oauth2 standard flow to retrieve the.
flytekit.clients.auth.auth_client.AuthorizationCode
flytekit.clients.auth.auth_client.EndpointMetadata This class can be used to control the rendering of the page on login successful or failure.
flytekit.clients.auth.auth_client.OAuthCallbackHandler A simple wrapper around BaseHTTPServer.
flytekit.clients.auth.auth_client.OAuthHTTPServer A simple wrapper around the BaseHTTPServer.
flytekit.clients.auth.authenticator.Authenticator Base authenticator for all authentication flows.
flytekit.clients.auth.authenticator.ClientConfig Client Configuration that is needed by the authenticator.
flytekit.clients.auth.authenticator.ClientConfigStore Client Config store retrieve client config.
flytekit.clients.auth.authenticator.ClientCredentialsAuthenticator This Authenticator uses ClientId and ClientSecret to authenticate.
flytekit.clients.auth.authenticator.CommandAuthenticator This Authenticator retrieves access_token using the provided command.
flytekit.clients.auth.authenticator.DeviceCodeAuthenticator This Authenticator implements the Device Code authorization flow useful for headless user authentication.
flytekit.clients.auth.authenticator.PKCEAuthenticator This Authenticator encapsulates the entire PKCE flow and automatically opens a browser window for login.
flytekit.clients.auth.authenticator.StaticClientConfigStore Client Config store retrieve client config.
flytekit.clients.auth.exceptions.AccessTokenNotFoundError This error is raised with Access token is not found or if Refreshing the token fails.
flytekit.clients.auth.exceptions.AuthenticationError This is raised for any AuthenticationError.
flytekit.clients.auth.exceptions.AuthenticationPending This is raised if the token endpoint returns authentication pending.
flytekit.clients.auth.keyring.Credentials Stores the credentials together.
flytekit.clients.auth.keyring.KeyringStore Methods to access Keyring Store.
flytekit.clients.auth.token_client.DeviceCodeResponse Response from device auth flow endpoint.
flytekit.clients.auth_helper.AuthenticationHTTPAdapter A custom HTTPAdapter that adds authentication headers to requests of a session.
flytekit.clients.auth_helper.RemoteClientConfigStore This class implements the ClientConfigStore that is served by the Flyte Server, that implements AuthMetadataService.
flytekit.clients.friendly.SynchronousFlyteClient This is a low-level client that users can use to make direct gRPC service calls to the control plane.
flytekit.clients.grpc_utils.auth_interceptor.AuthUnaryInterceptor This Interceptor can be used to automatically add Auth Metadata for every call - lazily in case authentication.
flytekit.clients.grpc_utils.default_metadata_interceptor.DefaultMetadataInterceptor Affords intercepting unary-unary invocations.
flytekit.clients.grpc_utils.wrap_exception_interceptor.RetryExceptionWrapperInterceptor Affords intercepting unary-unary invocations.
flytekit.clients.raw.RawSynchronousFlyteClient This is a thin synchronous wrapper around the auto-generated GRPC stubs for communicating with the admin service.
flytekit.clis.sdk_in_container.utils.ErrorHandlingCommand Helper class that wraps the invoke method of a click command to catch exceptions and print them in a nice way.
flytekit.clis.sdk_in_container.utils.PyFlyteParams
flytekit.configuration.AzureBlobStorageConfig Any Azure Blob Storage specific configuration.
flytekit.configuration.Config This the parent configuration object and holds all the underlying configuration object types.
flytekit.configuration.DataConfig Any data storage specific configuration.
flytekit.configuration.EntrypointSettings This object carries information about the path of the entrypoint command that will be invoked at runtime.
flytekit.configuration.FastSerializationSettings This object hold information about settings necessary to serialize an object so that it can be fast-registered.
flytekit.configuration.GCSConfig Any GCS specific configuration.
flytekit.configuration.GenericPersistenceConfig Data storage configuration that applies across any provider.
flytekit.configuration.Image Image is a structured wrapper for task container images used in object serialization.
flytekit.configuration.ImageConfig We recommend you to use ImageConfig.
flytekit.configuration.LocalConfig Any configuration specific to local runs.
flytekit.configuration.PlatformConfig This object contains the settings to talk to a Flyte backend (the DNS location of your Admin server basically).
flytekit.configuration.S3Config S3 specific configuration.
flytekit.configuration.SecretsConfig Configuration for secrets.
flytekit.configuration.SerializationSettings These settings are provided while serializing a workflow and task, before registration.
flytekit.configuration.StatsConfig Configuration for sending statsd.
flytekit.configuration.default_images.DefaultImages We may want to load the default images from remote - maybe s3 location etc?.
flytekit.configuration.feature_flags.FeatureFlags
flytekit.configuration.file.ConfigEntry A top level Config entry holder, that holds multiple different representations of the config.
flytekit.configuration.file.ConfigFile
flytekit.configuration.file.LegacyConfigEntry Creates a record for the config entry.
flytekit.configuration.file.YamlConfigEntry Creates a record for the config entry.
flytekit.configuration.internal.AWS
flytekit.configuration.internal.AZURE
flytekit.configuration.internal.Credentials
flytekit.configuration.internal.GCP
flytekit.configuration.internal.Images
flytekit.configuration.internal.Local
flytekit.configuration.internal.LocalSDK
flytekit.configuration.internal.Persistence
flytekit.configuration.internal.Platform
flytekit.configuration.internal.Secrets
flytekit.configuration.internal.StatsD
flytekit.configuration.plugin.FlytekitPlugin
flytekit.configuration.plugin.FlytekitPluginProtocol Base class for protocol classes.
flytekit.core.annotation.FlyteAnnotation A core object to add arbitrary annotations to flyte types.
flytekit.core.array_node.ArrayNode
flytekit.core.array_node_map_task.ArrayNodeMapTask Base Class for all Tasks with a Python native Interface.
flytekit.core.array_node_map_task.ArrayNodeMapTaskResolver Special resolver that is used for ArrayNodeMapTasks.
flytekit.core.artifact.Artifact An Artifact is effectively just a metadata layer on top of data that exists in Flyte.
flytekit.core.artifact.ArtifactIDSpecification This is a special object that helps specify how Artifacts are to be created.
flytekit.core.artifact.ArtifactQuery
flytekit.core.artifact.ArtifactSerializationHandler This protocol defines the interface for serializing artifact-related entities down to Flyte IDL.
flytekit.core.artifact.DefaultArtifactSerializationHandler This protocol defines the interface for serializing artifact-related entities down to Flyte IDL.
flytekit.core.artifact.InputsBase A class to provide better partition semantics.
flytekit.core.artifact.Partition
flytekit.core.artifact.Partitions
flytekit.core.artifact.Serializer
flytekit.core.artifact.TimePartition
flytekit.core.base_sql_task.SQLTask Base task types for all SQL tasks.
flytekit.core.base_task.IgnoreOutputs This exception should be used to indicate that the outputs generated by this can be safely ignored.
flytekit.core.base_task.PythonTask Base Class for all Tasks with a Python native Interface.
flytekit.core.base_task.Task The base of all Tasks in flytekit.
flytekit.core.base_task.TaskMetadata Metadata for a Task.
flytekit.core.base_task.TaskResolverMixin Flytekit tasks interact with the Flyte platform very, very broadly in two steps.
flytekit.core.cache.Cache Cache configuration for a task.
flytekit.core.cache.CachePolicy Base class for protocol classes.
flytekit.core.cache.VersionParameters Parameters used for version hash generation.
flytekit.core.checkpointer.Checkpoint Base class for Checkpoint system.
flytekit.core.checkpointer.SyncCheckpoint This class is NOT THREAD-SAFE!.
flytekit.core.class_based_resolver.ClassStorageTaskResolver Stores tasks inside a class variable.
flytekit.core.condition.BranchNode
flytekit.core.condition.Case
flytekit.core.condition.Condition
flytekit.core.condition.ConditionalSection ConditionalSection is used to denote a condition within a Workflow.
flytekit.core.condition.LocalExecutedConditionalSection ConditionalSection is used to denote a condition within a Workflow.
flytekit.core.condition.SkippedConditionalSection This ConditionalSection is used for nested conditionals, when the branch has been evaluated to false.
flytekit.core.container_task.ContainerTask This is an intermediate class that represents Flyte Tasks that run a container at execution time.
flytekit.core.context_manager.CompilationState Compilation state is used during the compilation of a workflow or task.
flytekit.core.context_manager.ExecutionParameters This is a run-time user-centric context object that is accessible to every @task method.
flytekit.core.context_manager.ExecutionState This is the context that is active when executing a task or a local workflow.
flytekit.core.context_manager.FlyteContext This is an internal-facing context object, that most users will not have to deal with.
flytekit.core.context_manager.FlyteContextManager FlyteContextManager manages the execution context within Flytekit.
flytekit.core.context_manager.FlyteEntities This is a global Object that tracks various tasks and workflows that are declared within a VM during the.
flytekit.core.context_manager.OutputMetadata
flytekit.core.context_manager.OutputMetadataTracker This class is for the users to set arbitrary metadata on output literals.
flytekit.core.context_manager.SecretsManager This provides a secrets resolution logic at runtime.
flytekit.core.context_manager.SerializableToString This protocol is used by the Artifact create_from function.
flytekit.core.data_persistence.FileAccessProvider This is the class that is available through the FlyteContext and can be used for persisting data to the remote.
flytekit.core.docstring.Docstring
flytekit.core.environment.Environment
flytekit.core.gate.Gate A node type that waits for user input before proceeding with a workflow.
flytekit.core.hash.HashMethod Flyte-specific object used to wrap the hash function for a specific type.
flytekit.core.hash.HashOnReferenceMixin
flytekit.core.interface.Interface A Python native interface object, like inspect.
flytekit.core.launch_plan.LaunchPlan Launch Plans are one of the core constructs of Flyte.
flytekit.core.launch_plan.ReferenceLaunchPlan A reference launch plan serves as a pointer to a Launch Plan that already exists on your Flyte installation.
flytekit.core.legacy_map_task.MapPythonTask A MapPythonTask defines a :py:class:`flytekit.
flytekit.core.legacy_map_task.MapTaskResolver Special resolver that is used for MapTasks.
flytekit.core.local_cache.LocalTaskCache This class implements a persistent store able to cache the result of local task executions.
flytekit.core.local_fsspec.FlyteLocalFileSystem This class doesn’t do anything except override the separator so that it works on windows.
flytekit.core.mock_stats.MockStats
flytekit.core.node.Node This class will hold all the things necessary to make an SdkNode but we won’t make one until we know things like.
flytekit.core.notification.Email This notification should be used when sending regular emails to people.
flytekit.core.notification.Notification
flytekit.core.notification.PagerDuty This notification should be used when sending emails to the PagerDuty service.
flytekit.core.notification.Slack This notification should be used when sending emails to the Slack.
flytekit.core.options.Options These are options that can be configured for a launchplan during registration or overridden during an execution.
flytekit.core.pod_template.PodTemplate Custom PodTemplate specification for a Task.
flytekit.core.promise.ComparisonExpression ComparisonExpression refers to an expression of the form (lhs operator rhs), where lhs and rhs are operands.
flytekit.core.promise.ConjunctionExpression A Conjunction Expression is an expression of the form either (A and B) or (A or B).
flytekit.core.promise.HasFlyteInterface Base class for protocol classes.
flytekit.core.promise.LocallyExecutable Base class for protocol classes.
flytekit.core.promise.NodeOutput
flytekit.core.promise.Promise This object is a wrapper and exists for three main reasons.
flytekit.core.promise.SupportsNodeCreation Base class for protocol classes.
flytekit.core.promise.VoidPromise This object is returned for tasks that do not return any outputs (declared interface is empty).
flytekit.core.python_auto_container.DefaultNotebookTaskResolver This resolved is used when the task is defined in a notebook.
flytekit.core.python_auto_container.DefaultTaskResolver Please see the notes in the TaskResolverMixin as it describes this default behavior.
flytekit.core.python_auto_container.PickledEntity Represents the structure of the pickled object stored in the .
flytekit.core.python_auto_container.PickledEntityMetadata Metadata for a pickled entity containing version information.
flytekit.core.python_auto_container.PythonAutoContainerTask A Python AutoContainer task should be used as the base for all extensions that want the user’s code to be in the.
flytekit.core.python_customized_container_task.PythonCustomizedContainerTask Please take a look at the comments for :py:class`flytekit.
flytekit.core.python_customized_container_task.TaskTemplateResolver This is a special resolver that resolves the task above at execution time, using only the TaskTemplate,.
flytekit.core.python_function_task.AsyncPythonFunctionTask This is the base task for eager tasks, as well as normal async tasks.
flytekit.core.python_function_task.EagerAsyncPythonFunctionTask This is the base eager task (aka eager workflow) type.
flytekit.core.python_function_task.EagerFailureHandlerTask A Python AutoContainer task should be used as the base for all extensions that want the user’s code to be in the.
flytekit.core.python_function_task.EagerFailureTaskResolver Flytekit tasks interact with the Flyte platform very, very broadly in two steps.
flytekit.core.python_function_task.PythonFunctionTask A Python Function task should be used as the base for all extensions that have a python function.
flytekit.core.python_function_task.PythonInstanceTask This class should be used as the base class for all Tasks that do not have a user defined function body, but have.
flytekit.core.reference_entity.LaunchPlanReference A reference object containing metadata that points to a remote launch plan.
flytekit.core.reference_entity.Reference
flytekit.core.reference_entity.ReferenceEntity
flytekit.core.reference_entity.ReferenceSpec
flytekit.core.reference_entity.ReferenceTemplate
flytekit.core.reference_entity.TaskReference A reference object containing metadata that points to a remote task.
flytekit.core.reference_entity.WorkflowReference A reference object containing metadata that points to a remote workflow.
flytekit.core.resources.ResourceSpec
flytekit.core.resources.Resources This class is used to specify both resource requests and resource limits.
flytekit.core.schedule.CronSchedule Use this when you have a launch plan that you want to run on a cron expression.
flytekit.core.schedule.FixedRate Use this class to schedule a fixed-rate interval for a launch plan.
flytekit.core.schedule.LaunchPlanTriggerBase Base class for protocol classes.
flytekit.core.schedule.OnSchedule Base class for protocol classes.
flytekit.core.shim_task.ExecutableTemplateShimTask The canonical @task decorated Python function task is pretty simple to reason about.
flytekit.core.shim_task.ShimTaskExecutor Please see the notes for the metaclass above first.
flytekit.core.task.Echo Base Class for all Tasks with a Python native Interface.
flytekit.core.task.ReferenceTask This is a reference task, the body of the function passed in through the constructor will never be used, only the.
flytekit.core.task.TaskPlugins This is the TaskPlugins factory for task types that are derivative of PythonFunctionTask.
flytekit.core.tracked_abc.FlyteTrackedABC This class exists because if you try to inherit from abc.
flytekit.core.tracker.InstanceTrackingMeta Please see the original class :py:class`flytekit.
flytekit.core.tracker.TrackedInstance Please see the notes for the metaclass above first.
flytekit.core.type_engine.AsyncTypeTransformer Base transformer type that should be implemented for every python native type that can be handled by flytekit.
flytekit.core.type_engine.BatchSize This is used to annotate a FlyteDirectory when we want to download/upload the contents of the directory in batches.
flytekit.core.type_engine.BinaryIOTransformer Handler for BinaryIO.
flytekit.core.type_engine.DataclassTransformer The Dataclass Transformer provides a type transformer for dataclasses.
flytekit.core.type_engine.DictTransformer Transformer that transforms an univariate dictionary Dict[str, T] to a Literal Map or.
flytekit.core.type_engine.EnumTransformer Enables converting a python type enum.
flytekit.core.type_engine.ListTransformer Transformer that handles a univariate typing.
flytekit.core.type_engine.LiteralsResolver LiteralsResolver is a helper class meant primarily for use with the FlyteRemote experience or any other situation.
flytekit.core.type_engine.ProtobufTransformer Base transformer type that should be implemented for every python native type that can be handled by flytekit.
flytekit.core.type_engine.RestrictedTypeError Common base class for all non-exit exceptions.
flytekit.core.type_engine.RestrictedTypeTransformer Types registered with the RestrictedTypeTransformer are not allowed to be converted to and from literals.
flytekit.core.type_engine.SimpleTransformer A Simple implementation of a type transformer that uses simple lambdas to transform and reduces boilerplate.
flytekit.core.type_engine.TextIOTransformer Handler for TextIO.
flytekit.core.type_engine.TypeEngine Core Extensible TypeEngine of Flytekit.
flytekit.core.type_engine.TypeTransformer Base transformer type that should be implemented for every python native type that can be handled by flytekit.
flytekit.core.type_engine.TypeTransformerFailedError Inappropriate argument type.
flytekit.core.type_engine.UnionTransformer Transformer that handles a typing.
flytekit.core.utils.AutoDeletingTempDir Creates a posix safe tempdir which is auto deleted once out of scope.
flytekit.core.utils.ClassDecorator Abstract class for class decorators.
flytekit.core.utils.Directory
flytekit.core.utils.timeit A context manager and a decorator that measures the execution time of the wrapped code block or functions.
flytekit.core.worker_queue.Controller This controller object is responsible for kicking off and monitoring executions against a Flyte Admin endpoint.
flytekit.core.worker_queue.Update
flytekit.core.worker_queue.WorkItem This is a class to keep track of what the user requested.
flytekit.core.workflow.ImperativeWorkflow An imperative workflow is a programmatic analogue to the typical @workflow function-based workflow and is.
flytekit.core.workflow.PythonFunctionWorkflow Please read :std:ref:flyte:divedeep-workflows first for a high-level understanding of what workflows are in Flyte.
flytekit.core.workflow.ReferenceWorkflow A reference workflow is a pointer to a workflow that already exists on your Flyte installation.
flytekit.core.workflow.WorkflowBase
flytekit.core.workflow.WorkflowMetadata
flytekit.core.workflow.WorkflowMetadataDefaults This class is similarly named to the one above.
flytekit.deck.deck.Deck Deck enable users to get customizable and default visibility into their tasks.
flytekit.deck.deck.TimeLineDeck The TimeLineDeck class is designed to render the execution time of each part of a task.
flytekit.deck.renderer.ArrowRenderer Render an Arrow dataframe as an HTML table.
flytekit.deck.renderer.MarkdownRenderer Convert a markdown string to HTML and return HTML as a unicode string.
flytekit.deck.renderer.PythonDependencyRenderer PythonDependencyDeck is a deck that contains information about packages installed via pip.
flytekit.deck.renderer.Renderable Base class for protocol classes.
flytekit.deck.renderer.SourceCodeRenderer Convert Python source code to HTML, and return HTML as a unicode string.
flytekit.deck.renderer.TopFrameRenderer Render a DataFrame as an HTML table.
flytekit.exceptions.base.FlyteException Common base class for all non-exit exceptions.
flytekit.exceptions.base.FlyteRecoverableException Common base class for all non-exit exceptions.
flytekit.exceptions.eager.EagerException Raised when a node in an eager workflow encounters an error.
flytekit.exceptions.scopes.FlyteScopedException Common base class for all non-exit exceptions.
flytekit.exceptions.scopes.FlyteScopedSystemException Common base class for all non-exit exceptions.
flytekit.exceptions.scopes.FlyteScopedUserException Common base class for all non-exit exceptions.
flytekit.exceptions.system.FlyteAgentNotFound Assertion failed.
flytekit.exceptions.system.FlyteConnectorNotFound Assertion failed.
flytekit.exceptions.system.FlyteDownloadDataException Common base class for all non-exit exceptions.
flytekit.exceptions.system.FlyteEntrypointNotLoadable Common base class for all non-exit exceptions.
flytekit.exceptions.system.FlyteNonRecoverableSystemException Common base class for all non-exit exceptions.
flytekit.exceptions.system.FlyteNotImplementedException Method or function hasn’t been implemented yet.
flytekit.exceptions.system.FlyteSystemAssertion Assertion failed.
flytekit.exceptions.system.FlyteSystemException Common base class for all non-exit exceptions.
flytekit.exceptions.system.FlyteSystemUnavailableException Common base class for all non-exit exceptions.
flytekit.exceptions.system.FlyteUploadDataException Common base class for all non-exit exceptions.
flytekit.exceptions.user.FlyteAssertion Assertion failed.
flytekit.exceptions.user.FlyteAuthenticationException Assertion failed.
flytekit.exceptions.user.FlyteCompilationException Common base class for all non-exit exceptions.
flytekit.exceptions.user.FlyteDataNotFoundException Inappropriate argument value (of correct type).
flytekit.exceptions.user.FlyteDisapprovalException Assertion failed.
flytekit.exceptions.user.FlyteEntityAlreadyExistsException Assertion failed.
flytekit.exceptions.user.FlyteEntityNotExistException Assertion failed.
flytekit.exceptions.user.FlyteEntityNotFoundException Inappropriate argument value (of correct type).
flytekit.exceptions.user.FlyteFailureNodeInputMismatchException Assertion failed.
flytekit.exceptions.user.FlyteInvalidInputException Common base class for all non-exit exceptions.
flytekit.exceptions.user.FlyteMissingReturnValueException Common base class for all non-exit exceptions.
flytekit.exceptions.user.FlyteMissingTypeException Common base class for all non-exit exceptions.
flytekit.exceptions.user.FlytePromiseAttributeResolveException Assertion failed.
flytekit.exceptions.user.FlyteRecoverableException Common base class for all non-exit exceptions.
flytekit.exceptions.user.FlyteTimeout Assertion failed.
flytekit.exceptions.user.FlyteTypeException Inappropriate argument type.
flytekit.exceptions.user.FlyteUserException Common base class for all non-exit exceptions.
flytekit.exceptions.user.FlyteUserRuntimeException Common base class for all non-exit exceptions.
flytekit.exceptions.user.FlyteValidationException Assertion failed.
flytekit.exceptions.user.FlyteValueException Inappropriate argument value (of correct type).
flytekit.extend.backend.base_connector.AsyncConnectorBase This is the base class for all async connectors.
flytekit.extend.backend.base_connector.AsyncConnectorExecutorMixin This mixin class is used to run the async task locally, and it’s only used for local execution.
flytekit.extend.backend.base_connector.ConnectorBase Helper class that provides a standard way to create an ABC using.
flytekit.extend.backend.base_connector.ConnectorRegistry This is the registry for all connectors.
flytekit.extend.backend.base_connector.Resource This is the output resource of the job.
flytekit.extend.backend.base_connector.ResourceMeta This is the metadata for the job.
flytekit.extend.backend.base_connector.SyncConnectorBase This is the base class for all sync connectors.
flytekit.extend.backend.base_connector.SyncConnectorExecutorMixin This mixin class is used to run the sync task locally, and it’s only used for local execution.
flytekit.extend.backend.base_connector.TaskCategory
flytekit.extras.accelerators.BaseAccelerator Base class for all accelerator types.
flytekit.extras.accelerators.GPUAccelerator Class that represents a GPU accelerator.
flytekit.extras.accelerators.MultiInstanceGPUAccelerator Base class for all multi-instance GPU accelerator types.
flytekit.extras.cloud_pickle_resolver.ExperimentalNaiveCloudPickleResolver Please do not use this resolver, basically ever.
flytekit.extras.sqlite3.task.SQLite3Config Use this configuration to configure if sqlite3 files that should be loaded by the task.
flytekit.extras.sqlite3.task.SQLite3Task Run client side SQLite3 queries that optionally return a FlyteSchema object.
flytekit.extras.sqlite3.task.SQLite3TaskExecutor Please see the notes for the metaclass above first.
flytekit.extras.tasks.shell.AttrDict Convert a dictionary to an attribute style lookup.
flytekit.extras.tasks.shell.OutputLocation .
flytekit.extras.tasks.shell.ProcessResult Stores a process return code, standard output and standard error.
flytekit.extras.tasks.shell.RawShellTask
flytekit.extras.tasks.shell.ShellTask
flytekit.image_spec.default_builder.DefaultImageBuilder Image builder using Docker and buildkit.
flytekit.image_spec.image_spec.ImageBuildEngine ImageBuildEngine contains a list of builders that can be used to build an ImageSpec.
flytekit.image_spec.image_spec.ImageSpec This class is used to specify the docker image that will be used to run the task.
flytekit.image_spec.image_spec.ImageSpecBuilder
flytekit.interaction.click_types.DateTimeType The DateTime type converts date strings into datetime objects.
flytekit.interaction.click_types.DirParamType Represents the type of a parameter.
flytekit.interaction.click_types.DurationParamType Represents the type of a parameter.
flytekit.interaction.click_types.EnumParamType The choice type allows a value to be checked against a fixed set.
flytekit.interaction.click_types.FileParamType Represents the type of a parameter.
flytekit.interaction.click_types.FlyteLiteralConverter
flytekit.interaction.click_types.JSONIteratorParamType Represents the type of a parameter.
flytekit.interaction.click_types.JsonParamType Represents the type of a parameter.
flytekit.interaction.click_types.PickleParamType Represents the type of a parameter.
flytekit.interaction.click_types.StructuredDatasetParamType TODO handle column types.
flytekit.interaction.click_types.UnionParamType A composite type that allows for multiple types to be specified.
flytekit.interaction.rich_utils.RichCallback Base class and interface for callback mechanism.
flytekit.interactive.vscode_lib.config.VscodeConfig VscodeConfig is the config contains default URLs of the VSCode server and extension remote paths.
flytekit.interactive.vscode_lib.decorator.vscode Abstract class for class decorators.
flytekit.interfaces.cli_identifiers.Identifier
flytekit.interfaces.cli_identifiers.TaskExecutionIdentifier
flytekit.interfaces.cli_identifiers.WorkflowExecutionIdentifier
flytekit.interfaces.stats.client.DummyStatsClient A dummy client for statsd.
flytekit.interfaces.stats.client.ScopeableStatsProxy A Proxy object for an underlying statsd client.
flytekit.interfaces.stats.client.StatsClientProxy A Proxy object for an underlying statsd client.
flytekit.interfaces.stats.taggable.TaggableStats A Proxy object for an underlying statsd client.
flytekit.models.admin.common.Sort
flytekit.models.admin.task_execution.TaskExecution
flytekit.models.admin.task_execution.TaskExecutionClosure
flytekit.models.admin.workflow.Workflow
flytekit.models.admin.workflow.WorkflowClosure
flytekit.models.admin.workflow.WorkflowSpec
flytekit.models.annotation.TypeAnnotation Python class representation of the flyteidl TypeAnnotation message.
flytekit.models.array_job.ArrayJob
flytekit.models.common.Annotations
flytekit.models.common.AuthRole
flytekit.models.common.EmailNotification
flytekit.models.common.Envs
flytekit.models.common.FlyteABCMeta Metaclass for defining Abstract Base Classes (ABCs).
flytekit.models.common.FlyteCustomIdlEntity
flytekit.models.common.FlyteIdlEntity
flytekit.models.common.FlyteType Metaclass for defining Abstract Base Classes (ABCs).
flytekit.models.common.Labels
flytekit.models.common.NamedEntityIdentifier
flytekit.models.common.Notification
flytekit.models.common.PagerDutyNotification
flytekit.models.common.RawOutputDataConfig
flytekit.models.common.SlackNotification
flytekit.models.common.UrlBlob
flytekit.models.core.catalog.CatalogArtifactTag
flytekit.models.core.catalog.CatalogMetadata
flytekit.models.core.compiler.CompiledTask
flytekit.models.core.compiler.CompiledWorkflow
flytekit.models.core.compiler.CompiledWorkflowClosure
flytekit.models.core.compiler.ConnectionSet
flytekit.models.core.condition.BooleanExpression
flytekit.models.core.condition.ComparisonExpression
flytekit.models.core.condition.ConjunctionExpression
flytekit.models.core.condition.Operand
flytekit.models.core.errors.ContainerError
flytekit.models.core.errors.ErrorDocument
flytekit.models.core.execution.ExecutionError
flytekit.models.core.execution.NodeExecutionPhase
flytekit.models.core.execution.TaskExecutionPhase
flytekit.models.core.execution.TaskLog
flytekit.models.core.execution.WorkflowExecutionPhase This class holds enum values used for setting notifications.
flytekit.models.core.identifier.Identifier
flytekit.models.core.identifier.NodeExecutionIdentifier
flytekit.models.core.identifier.ResourceType
flytekit.models.core.identifier.SignalIdentifier
flytekit.models.core.identifier.TaskExecutionIdentifier
flytekit.models.core.identifier.WorkflowExecutionIdentifier
flytekit.models.core.types.BlobType This type represents offloaded data and is typically used for things like files.
flytekit.models.core.types.EnumType Models _types_pb2.
flytekit.models.core.workflow.Alias
flytekit.models.core.workflow.ApproveCondition
flytekit.models.core.workflow.ArrayNode
flytekit.models.core.workflow.BranchNode
flytekit.models.core.workflow.GateNode
flytekit.models.core.workflow.IfBlock
flytekit.models.core.workflow.IfElseBlock
flytekit.models.core.workflow.Node
flytekit.models.core.workflow.NodeMetadata
flytekit.models.core.workflow.SignalCondition
flytekit.models.core.workflow.SleepCondition
flytekit.models.core.workflow.TaskNode
flytekit.models.core.workflow.TaskNodeOverrides
flytekit.models.core.workflow.WorkflowMetadata
flytekit.models.core.workflow.WorkflowMetadataDefaults
flytekit.models.core.workflow.WorkflowNode
flytekit.models.core.workflow.WorkflowTemplate
flytekit.models.documentation.Description Full user description with formatting preserved.
flytekit.models.documentation.Documentation DescriptionEntity contains detailed description for the task/workflow/launch plan.
flytekit.models.documentation.SourceCode Link to source code used to define this task or workflow.
flytekit.models.domain.Domain Domains are fixed and unique at the global level, and provide an abstraction to isolate resources and feature configuration for different deployment environments.
flytekit.models.dynamic_job.DynamicJobSpec
flytekit.models.event.TaskExecutionMetadata .
flytekit.models.execution.AbortMetadata
flytekit.models.execution.ClusterAssignment
flytekit.models.execution.Execution
flytekit.models.execution.ExecutionClosure
flytekit.models.execution.ExecutionMetadata
flytekit.models.execution.ExecutionSpec
flytekit.models.execution.LiteralMapBlob
flytekit.models.execution.NodeExecutionGetDataResponse Currently, node, task, and workflow execution all have the same get data response.
flytekit.models.execution.NotificationList
flytekit.models.execution.SystemMetadata
flytekit.models.execution.TaskExecutionGetDataResponse Currently, node, task, and workflow execution all have the same get data response.
flytekit.models.execution.WorkflowExecutionGetDataResponse Currently, node, task, and workflow execution all have the same get data response.
flytekit.models.filters.Contains
flytekit.models.filters.Equal
flytekit.models.filters.Filter
flytekit.models.filters.FilterList
flytekit.models.filters.GreaterThan
flytekit.models.filters.GreaterThanOrEqual
flytekit.models.filters.LessThan
flytekit.models.filters.LessThanOrEqual
flytekit.models.filters.NotEqual
flytekit.models.filters.SetFilter
flytekit.models.filters.ValueIn
flytekit.models.filters.ValueNotIn
flytekit.models.interface.Parameter
flytekit.models.interface.ParameterMap
flytekit.models.interface.TypedInterface
flytekit.models.interface.Variable
flytekit.models.interface.VariableMap
flytekit.models.launch_plan.Auth
flytekit.models.launch_plan.LaunchPlan
flytekit.models.launch_plan.LaunchPlanClosure
flytekit.models.launch_plan.LaunchPlanMetadata
flytekit.models.launch_plan.LaunchPlanSpec
flytekit.models.launch_plan.LaunchPlanState
flytekit.models.literals.Binary
flytekit.models.literals.Binding
flytekit.models.literals.BindingData
flytekit.models.literals.BindingDataCollection
flytekit.models.literals.BindingDataMap
flytekit.models.literals.Blob
flytekit.models.literals.BlobMetadata This is metadata for the Blob literal.
flytekit.models.literals.Literal
flytekit.models.literals.LiteralCollection
flytekit.models.literals.LiteralMap
flytekit.models.literals.LiteralOffloadedMetadata
flytekit.models.literals.Primitive
flytekit.models.literals.RetryStrategy
flytekit.models.literals.Scalar
flytekit.models.literals.Schema
flytekit.models.literals.StructuredDataset
flytekit.models.literals.StructuredDatasetMetadata
flytekit.models.literals.Union
flytekit.models.literals.Void
flytekit.models.matchable_resource.ClusterResourceAttributes
flytekit.models.matchable_resource.ExecutionClusterLabel
flytekit.models.matchable_resource.ExecutionQueueAttributes
flytekit.models.matchable_resource.MatchableResource
flytekit.models.matchable_resource.MatchingAttributes
flytekit.models.matchable_resource.PluginOverride
flytekit.models.matchable_resource.PluginOverrides
flytekit.models.named_entity.NamedEntityIdentifier
flytekit.models.named_entity.NamedEntityMetadata
flytekit.models.named_entity.NamedEntityState
flytekit.models.node_execution.DynamicWorkflowNodeMetadata
flytekit.models.node_execution.NodeExecution
flytekit.models.node_execution.NodeExecutionClosure
flytekit.models.node_execution.TaskNodeMetadata
flytekit.models.node_execution.WorkflowNodeMetadata
flytekit.models.presto.PrestoQuery
flytekit.models.project.Project
flytekit.models.qubole.HiveQuery
flytekit.models.qubole.HiveQueryCollection
flytekit.models.qubole.QuboleHiveJob
flytekit.models.schedule.Schedule
flytekit.models.security.Identity
flytekit.models.security.OAuth2Client
flytekit.models.security.OAuth2TokenRequest
flytekit.models.security.Secret See :std:ref:cookbook:secrets for usage examples.
flytekit.models.security.SecurityContext This is a higher level wrapper object that for the most part users shouldn’t have to worry about.
flytekit.models.task.CompiledTask
flytekit.models.task.Container
flytekit.models.task.DataLoadingConfig
flytekit.models.task.IOStrategy Provides methods to manage data in and out of the Raw container using Download Modes.
flytekit.models.task.K8sObjectMetadata
flytekit.models.task.K8sPod
flytekit.models.task.Resources
flytekit.models.task.RuntimeMetadata
flytekit.models.task.Sql
flytekit.models.task.Task
flytekit.models.task.TaskClosure
flytekit.models.task.TaskExecutionMetadata
flytekit.models.task.TaskMetadata
flytekit.models.task.TaskSpec
flytekit.models.task.TaskTemplate
flytekit.models.types.Error
flytekit.models.types.LiteralType
flytekit.models.types.OutputReference
flytekit.models.types.SchemaType
flytekit.models.types.SimpleType
flytekit.models.types.StructuredDatasetType
flytekit.models.types.TypeStructure Models _types_pb2.
flytekit.models.types.UnionType Models _types_pb2.
flytekit.models.workflow_closure.WorkflowClosure
flytekit.remote.entities.FlyteArrayNode
flytekit.remote.entities.FlyteBranchNode
flytekit.remote.entities.FlyteGateNode
flytekit.remote.entities.FlyteLaunchPlan A class encapsulating a remote Flyte launch plan.
flytekit.remote.entities.FlyteNode A class encapsulating a remote Flyte node.
flytekit.remote.entities.FlyteTask A class encapsulating a remote Flyte task.
flytekit.remote.entities.FlyteTaskNode A class encapsulating a task that a Flyte node needs to execute.
flytekit.remote.entities.FlyteWorkflow A class encapsulating a remote Flyte workflow.
flytekit.remote.entities.FlyteWorkflowNode A class encapsulating a workflow that a Flyte node needs to execute.
flytekit.remote.executions.FlyteNodeExecution A class encapsulating a node execution being run on a Flyte remote backend.
flytekit.remote.executions.FlyteTaskExecution A class encapsulating a task execution being run on a Flyte remote backend.
flytekit.remote.executions.FlyteWorkflowExecution A class encapsulating a workflow execution being run on a Flyte remote backend.
flytekit.remote.executions.RemoteExecutionBase
flytekit.remote.interface.TypedInterface
flytekit.remote.lazy_entity.LazyEntity Fetches the entity when the entity is called or when the entity is retrieved.
flytekit.remote.metrics.FlyteExecutionSpan
flytekit.remote.remote.FlyteRemote Main entrypoint for programmatically accessing a Flyte remote backend.
flytekit.remote.remote.RegistrationSkipped RegistrationSkipped error is raised when trying to register an entity that is not registrable.
flytekit.remote.remote.ResolvedIdentifiers
flytekit.remote.remote_callable.RemoteEntity Helper class that provides a standard way to create an ABC using.
flytekit.remote.remote_fs.FlytePathResolver
flytekit.sensor.base_sensor.BaseSensor Base class for all sensors.
flytekit.sensor.base_sensor.SensorConfig Base class for protocol classes.
flytekit.sensor.base_sensor.SensorMetadata
flytekit.sensor.file_sensor.FileSensor Base class for all sensors.
flytekit.sensor.sensor_engine.SensorEngine This is the base class for all async connectors.
flytekit.tools.fast_registration.FastPackageOptions FastPackageOptions is used to set configuration options when packaging files.
flytekit.tools.ignore.DockerIgnore Uses docker-py’s PatternMatcher to check whether a path is ignored.
flytekit.tools.ignore.FlyteIgnore Uses a .
flytekit.tools.ignore.GitIgnore Uses git cli (if available) to list all ignored files and compare with those.
flytekit.tools.ignore.Ignore Base for Ignores, implements core logic.
flytekit.tools.ignore.IgnoreGroup Groups multiple Ignores and checks a path against them.
flytekit.tools.ignore.StandardIgnore Retains the standard ignore functionality that previously existed.
flytekit.tools.repo.NoSerializableEntitiesError Common base class for all non-exit exceptions.
flytekit.types.directory.types.FlyteDirToMultipartBlobTransformer This transformer handles conversion between the Python native FlyteDirectory class defined above, and the Flyte.
flytekit.types.directory.types.FlyteDirectory
flytekit.types.error.error.ErrorTransformer Enables converting a python type FlyteError to LiteralType.
flytekit.types.error.error.FlyteError Special Task type that will be used in the failure node.
flytekit.types.file.FileExt Used for annotating file extension types of FlyteFile.
flytekit.types.file.file.FlyteFile
flytekit.types.file.file.FlyteFilePathTransformer Base transformer type that should be implemented for every python native type that can be handled by flytekit.
flytekit.types.iterator.iterator.FlyteIterator
flytekit.types.iterator.iterator.IteratorTransformer Base transformer type that should be implemented for every python native type that can be handled by flytekit.
flytekit.types.iterator.json_iterator.JSONIterator Abstract base class for generic types.
flytekit.types.iterator.json_iterator.JSONIteratorTransformer A JSON iterator that handles conversion between an iterator/generator and a JSONL file.
flytekit.types.numpy.ndarray.NumpyArrayTransformer TypeTransformer that supports np.
flytekit.types.pickle.pickle.FlytePickle This type is only used by flytekit internally.
flytekit.types.pickle.pickle.FlytePickleTransformer Base transformer type that should be implemented for every python native type that can be handled by flytekit.
flytekit.types.schema.types.FlyteSchema
flytekit.types.schema.types.FlyteSchemaTransformer Base transformer type that should be implemented for every python native type that can be handled by flytekit.
flytekit.types.schema.types.LocalIOSchemaReader Base SchemaReader to handle any readers (that can manage their own IO or otherwise).
flytekit.types.schema.types.LocalIOSchemaWriter Abstract base class for generic types.
flytekit.types.schema.types.SchemaEngine This is the core Engine that handles all schema sub-systems.
flytekit.types.schema.types.SchemaHandler
flytekit.types.schema.types.SchemaReader Base SchemaReader to handle any readers (that can manage their own IO or otherwise).
flytekit.types.schema.types.SchemaWriter Abstract base class for generic types.
flytekit.types.schema.types_pandas.PandasDataFrameTransformer Transforms a pd.
flytekit.types.schema.types_pandas.PandasSchemaReader Base SchemaReader to handle any readers (that can manage their own IO or otherwise).
flytekit.types.schema.types_pandas.PandasSchemaWriter Abstract base class for generic types.
flytekit.types.schema.types_pandas.ParquetIO
flytekit.types.structured.basic_dfs.ArrowToParquetEncodingHandler Helper class that provides a standard way to create an ABC using.
flytekit.types.structured.basic_dfs.CSVToPandasDecodingHandler Helper class that provides a standard way to create an ABC using.
flytekit.types.structured.basic_dfs.PandasToCSVEncodingHandler Helper class that provides a standard way to create an ABC using.
flytekit.types.structured.basic_dfs.PandasToParquetEncodingHandler Helper class that provides a standard way to create an ABC using.
flytekit.types.structured.basic_dfs.ParquetToArrowDecodingHandler Helper class that provides a standard way to create an ABC using.
flytekit.types.structured.basic_dfs.ParquetToPandasDecodingHandler Helper class that provides a standard way to create an ABC using.
flytekit.types.structured.structured_dataset.DuplicateHandlerError Inappropriate argument value (of correct type).
flytekit.types.structured.structured_dataset.StructuredDataset This is the user facing StructuredDataset class.
flytekit.types.structured.structured_dataset.StructuredDatasetDecoder Helper class that provides a standard way to create an ABC using.
flytekit.types.structured.structured_dataset.StructuredDatasetEncoder Helper class that provides a standard way to create an ABC using.
flytekit.types.structured.structured_dataset.StructuredDatasetTransformerEngine Think of this transformer as a higher-level meta transformer that is used for all the dataframe types.
flytekit.utils.rate_limiter.RateLimiter Rate limiter that allows up to a certain number of requests per minute.