Contents Menu Expand Light mode Dark mode Auto light/dark mode
Logo
Flyte
Getting Started
User Guide
Tutorials
Integrations
Deployment
API Reference
Concepts
Community
flyte.org
Logo
Flyte
  • Getting Started
  • User Guide
  • Tutorials
  • Concepts
  • Deployment
  • API Reference
  • Community

Flytekit SDK

  • Flytekit Python
  • Overview
    • Model Files
    • Authoring Structure
    • Control Plane: FlyteRemote
    • Execution Time Support
    • Command Line Interfaces and Clients
  • Core Flytekit
    • flytekit.task
    • flytekit.workflow
    • flytekit.kwtypes
    • flytekit.current_context
    • flytekit.ExecutionParameters
    • flytekit.FlyteContext
    • flytekit.map_task
    • flytekit.core.workflow.ImperativeWorkflow
    • flytekit.core.node_creation.create_node
    • flytekit.FlyteContextManager
    • flytekit.conditional
    • flytekit.TaskMetadata
    • flytekit.Resources
    • flytekit.WorkflowFailurePolicy
    • flytekit.PodTemplate
    • flytekit.dynamic
    • flytekit.approve
    • flytekit.sleep
    • flytekit.wait_for_input
    • flytekit.CronSchedule
    • flytekit.FixedRate
    • flytekit.Email
    • flytekit.PagerDuty
    • flytekit.Slack
    • flytekit.get_reference_entity
    • flytekit.LaunchPlanReference
    • flytekit.TaskReference
    • flytekit.WorkflowReference
    • flytekit.reference_task
    • flytekit.reference_workflow
    • flytekit.reference_launch_plan
    • flytekit.SQLTask
    • flytekit.ContainerTask
    • flytekit.PythonFunctionTask
    • flytekit.PythonInstanceTask
    • flytekit.LaunchPlan
    • flytekit.Secret
    • flytekit.SecurityContext
    • flytekit.AuthRole
    • flytekit.Labels
    • flytekit.Annotations
    • flytekit.WorkflowExecutionPhase
    • flytekit.Blob
    • flytekit.BlobMetadata
    • flytekit.Literal
    • flytekit.Scalar
    • flytekit.LiteralType
    • flytekit.BlobType
    • flytekit.Deck
    • flytekit.HashMethod
    • flytekit.Description
    • flytekit.Documentation
    • flytekit.SourceCode
  • Configuration
    • flytekit.configuration.Config
    • flytekit.configuration.Image
    • flytekit.configuration.ImageConfig
    • flytekit.configuration.SerializationSettings
    • flytekit.configuration.FastSerializationSettings
    • flytekit.configuration.PlatformConfig
    • flytekit.configuration.StatsConfig
    • flytekit.configuration.SecretsConfig
    • flytekit.configuration.S3Config
    • flytekit.configuration.GCSConfig
    • flytekit.configuration.DataConfig
  • Remote Access
    • flytekit.remote.remote.FlyteRemote
    • flytekit.remote.remote.Options
    • flytekit.remote.entities.FlyteTask
    • flytekit.remote.entities.FlyteWorkflow
    • flytekit.remote.entities.FlyteLaunchPlan
    • flytekit.remote.entities.FlyteNode
    • flytekit.remote.entities.FlyteTaskNode
    • flytekit.remote.entities.FlyteWorkflowNode
    • flytekit.remote.executions.FlyteWorkflowExecution
    • flytekit.remote.executions.FlyteTaskExecution
    • flytekit.remote.executions.FlyteNodeExecution
  • Clients
    • flytekit.clients.friendly.SynchronousFlyteClient
    • flytekit.clients.raw.RawSynchronousFlyteClient
  • Unit Testing
    • flytekit.testing.patch
    • flytekit.testing.task_mock
  • Extending Flytekit
    • flytekit.extend.get_serializable
    • flytekit.extend.context_manager
    • flytekit.extend.SQLTask
    • flytekit.extend.IgnoreOutputs
    • flytekit.extend.PythonTask
    • flytekit.extend.ExecutionState
    • flytekit.extend.Image
    • flytekit.extend.ImageConfig
    • flytekit.extend.SerializationSettings
    • flytekit.extend.Interface
    • flytekit.extend.Promise
    • flytekit.extend.TaskPlugins
    • flytekit.extend.DictTransformer
    • flytekit.extend.T
    • flytekit.extend.TypeEngine
    • flytekit.extend.TypeTransformer
    • flytekit.extend.PythonCustomizedContainerTask
    • flytekit.extend.ExecutableTemplateShimTask
    • flytekit.extend.ShimTaskExecutor
  • Flyte Deck
    • flytekit.deck.Deck
    • flytekit.deck.TopFrameRenderer
  • Plugin API reference
    • AWS Athena
      • flytekitplugins.athena.AthenaConfig
      • flytekitplugins.athena.AthenaTask
    • AWS Batch
      • flytekitplugins.awsbatch.AWSBatchConfig
    • AWS Sagemaker
      • flytekitplugins.awssagemaker.AlgorithmName
      • flytekitplugins.awssagemaker.AlgorithmSpecification
      • flytekitplugins.awssagemaker.CategoricalParameterRange
      • flytekitplugins.awssagemaker.ContinuousParameterRange
      • flytekitplugins.awssagemaker.DISTRIBUTED_TRAINING_CONTEXT_KEY
      • flytekitplugins.awssagemaker.DistributedProtocol
      • flytekitplugins.awssagemaker.DistributedTrainingContext
      • flytekitplugins.awssagemaker.HPOJob
      • flytekitplugins.awssagemaker.HyperparameterScalingType
      • flytekitplugins.awssagemaker.HyperparameterTuningJobConfig
      • flytekitplugins.awssagemaker.HyperparameterTuningObjective
      • flytekitplugins.awssagemaker.HyperparameterTuningObjectiveType
      • flytekitplugins.awssagemaker.HyperparameterTuningStrategy
      • flytekitplugins.awssagemaker.InputContentType
      • flytekitplugins.awssagemaker.InputMode
      • flytekitplugins.awssagemaker.IntegerParameterRange
      • flytekitplugins.awssagemaker.ParameterRangeOneOf
      • flytekitplugins.awssagemaker.SagemakerBuiltinAlgorithmsTask
      • flytekitplugins.awssagemaker.SagemakerCustomTrainingTask
      • flytekitplugins.awssagemaker.SagemakerHPOTask
      • flytekitplugins.awssagemaker.SagemakerTrainingJobConfig
      • flytekitplugins.awssagemaker.TrainingJobEarlyStoppingType
      • flytekitplugins.awssagemaker.TrainingJobResourceConfig
    • Google Bigquery
      • flytekitplugins.bigquery.BigQueryConfig
      • flytekitplugins.bigquery.BigQueryTask
    • FS Spec
    • Dask
      • flytekitplugins.dask.Dask
      • flytekitplugins.dask.Scheduler
      • flytekitplugins.dask.WorkerGroup
    • Deck standard
      • flytekitplugins.deck.BoxRenderer
      • flytekitplugins.deck.FrameProfilingRenderer
      • flytekitplugins.deck.MarkdownRenderer
    • Dolt standard
      • flytekitplugins.dolt.DoltConfig
      • flytekitplugins.dolt.DoltTable
      • flytekitplugins.dolt.DoltTableNameTransformer
    • Great expectations
      • flytekitplugins.great_expectations.BatchRequestConfig
      • flytekitplugins.great_expectations.GreatExpectationsFlyteConfig
      • flytekitplugins.great_expectations.GreatExpectationsTask
      • flytekitplugins.great_expectations.GreatExpectationsType
    • Hive
      • flytekitplugins.hive.HiveConfig
      • flytekitplugins.hive.HiveSelectTask
      • flytekitplugins.hive.HiveTask
    • Pod
      • flytekitplugins.pod.Pod
    • KF MPI
      • flytekitplugins.kfmpi.MPIJob
    • KF Pytorch
      • flytekitplugins.kfpytorch.PyTorch
    • KF Tensorflow
      • flytekitplugins.kftensorflow.TfJob
    • Modin
      • flytekitplugins.modin.ModinPandasDataFrameTransformer
    • Pandera
      • flytekitplugins.pandera.PanderaTransformer
    • Papermill
      • flytekitplugins.papermill.NotebookTask
      • flytekitplugins.papermill.record_outputs
    • Snowflake
      • flytekitplugins.snowflake.SnowflakeConfig
      • flytekitplugins.snowflake.SnowflakeTask
    • Spark
      • flytekitplugins.spark.new_spark_session
      • flytekitplugins.spark.ParquetToSparkDecodingHandler
      • flytekitplugins.spark.Spark
      • flytekitplugins.spark.SparkDataFrameSchemaReader
      • flytekitplugins.spark.SparkDataFrameSchemaWriter
      • flytekitplugins.spark.SparkDataFrameTransformer
    • SQLAlchemy
      • flytekitplugins.sqlalchemy.SQLAlchemyConfig
      • flytekitplugins.sqlalchemy.SQLAlchemyDefaultImages
      • flytekitplugins.sqlalchemy.SQLAlchemyTask
    • ONNX PyTorch
      • flytekitplugins.onnxpytorch.PyTorch2ONNXConfig
      • flytekitplugins.onnxpytorch.PyTorch2ONNX
    • ONNX TensorFlow
      • flytekitplugins.onnxtensorflow.TensorFlow2ONNXConfig
      • flytekitplugins.onnxtensorflow.TensorFlow2ONNX
    • ONNX ScikitLearn
      • flytekitplugins.onnxscikitlearn.ScikitLearn2ONNXConfig
      • flytekitplugins.onnxscikitlearn.ScikitLearn2ONNX
    • Ray
      • flytekitplugins.ray.HeadNodeConfig
      • flytekitplugins.ray.RayJobConfig
      • flytekitplugins.ray.WorkerNodeConfig
    • DBT
      • flytekitplugins.dbt.DBTRun
      • flytekitplugins.dbt.DBTTest
      • flytekitplugins.dbt.BaseDBTInput
      • flytekitplugins.dbt.BaseDBTOutput
      • flytekitplugins.dbt.DBTRunInput
      • flytekitplugins.dbt.DBTRunOutput
      • flytekitplugins.dbt.DBTTestInput
      • flytekitplugins.dbt.DBTTestOutput
    • Vaex
      • flytekitplugins.vaex.VaexDataFrameToParquetEncodingHandler
      • flytekitplugins.vaex.ParquetToVaexDataFrameDecodingHandler
    • MLflow
      • flytekitplugins.mlflow.mlflow_autolog
    • DuckDB
      • flytekitplugins.duckdb.DuckDBQuery
  • Custom Tasks
    • flytekit.core.base_task.kwtypes
    • flytekit.core.base_task.PythonTask
    • flytekit.core.base_task.Task
    • flytekit.core.base_task.TaskMetadata
    • flytekit.core.base_task.TaskResolverMixin
    • flytekit.core.base_task.IgnoreOutputs
    • flytekit.core.python_function_task.PythonFunctionTask
    • flytekit.core.python_function_task.PythonInstanceTask
    • Shell Task
      • flytekit.extras.tasks.shell.ShellTask
      • flytekit.extras.tasks.shell.OutputLocation
    • SQLite3 Task
      • flytekit.extras.sqlite3.task.SQLite3Task
      • flytekit.extras.sqlite3.task.SQLite3Config
  • Custom Types
    • Flytekit StructuredDataset
      • flytekit.types.structured.StructuredDataset
      • flytekit.types.structured.StructuredDatasetEncoder
      • flytekit.types.structured.StructuredDatasetDecoder
    • Flytekit File Type
      • flytekit.types.file.FlyteFile
      • flytekit.types.file.HDF5EncodedFile
      • flytekit.types.file.HTMLPage
      • flytekit.types.file.JoblibSerializedFile
      • flytekit.types.file.JPEGImageFile
      • flytekit.types.file.PDFFile
      • flytekit.types.file.PNGImageFile
      • flytekit.types.file.PythonPickledFile
      • flytekit.types.file.PythonNotebook
      • flytekit.types.file.SVGImageFile
    • Flytekit Directory Type
      • flytekit.types.directory.FlyteDirectory
      • flytekit.types.directory.TensorboardLogs
      • flytekit.types.directory.TFRecordsDirectory
    • PyTorch Type
      • flytekit.extras.pytorch.PyTorchCheckpoint
      • flytekit.extras.pytorch.PyTorchCheckpointTransformer
      • flytekit.extras.pytorch.PyTorchModuleTransformer
      • flytekit.extras.pytorch.PyTorchTensorTransformer
    • TensorFlow Type
      • flytekit.extras.tensorflow.TensorFlowRecordFileTransformer
      • flytekit.extras.tensorflow.TensorFlowRecordsDirTransformer
    • Sklearn Type
      • flytekit.extras.sklearn.SklearnEstimatorTransformer
  • Data Persistence Layer
    • flytekit.core.data_persistence.FileAccessProvider
  • Pyflyte CLI
  • Flytekit Contribution Guide
  v: latest
Versions
latest
Downloads
On Read the Docs
Project Home
Builds
Flytekit
Back to top
Edit this page

Modin API reference#

Tags: Integration, DataFrame

This package contains things that are useful when extending Flytekit.

ModinPandasDataFrameTransformer()

Transforms ModinPandas DataFrame's to and from a Schema (typed/untyped)

Next
flytekitplugins.modin.ModinPandasDataFrameTransformer
Previous
flytekitplugins.kftensorflow.TfJob
Copyright © 2021, Flyte
Made with Sphinx and @pradyunsg's Furo | Show Source