Dagster integration library for Polars
Project description
dagster-polars
Polars integration library for Dagster.
All IOManagers log various metadata about the DataFrame - size, schema, sample, stats.
For all IOManagers the columns
input metadata can be used to select a subset of columns to load.
Features
BasePolarsUPathIOManager
is a base class for IO managers that work with Polars DataFrames. Shouldn't be used directly unless you want to implement your ownIOManager
.- returns the correct type (
polars.DataFrame
orpolars.LazyFrame
) based on the type annotation - handles
Optional
types by skipping loading missing inputs orNone
outputs - inherits all the features of the
UPathIOManager
- works with local and remote filesystems (like S3), supports loading multiple partitions (usedict[str, pl.DataFrame]
type annotation), ... - Implemented serialization formats:
PolarsParquetIOManager
- for reading and writing files in Apache Parquet format. Supports reading partitioned Parquet datasets (for example, often produced by Spark). All read/write options can be set via metadata values.PolarsDeltaIOManager
- for reading and writing Delta Lake. All read/write options can be set via metadata values.mode
,overwrite_schema
andversion
can be set via config parameters.partition_by
metadata value can be set to use native Delta Lake partitioning (it's passed todelta_write_options
ofwrite_delta
). The IOManager won't manage partitioning in this case, and all the asset partitions will be stored in the same Delta Table directory. You are responsible for filtering correct partitions when reading the data in the downstream assets. Extra dependencies can be installed withpip install 'dagster-polars[deltalake]'
.
- returns the correct type (
BigQueryPolarsIOManager
- for reading and writing data from/to BigQuery. Supports writing partitioned tables ("partition_expr"
input metadata key must be specified). Extra dependencies can be installed withpip install 'dagster-polars[gcp]'
.
Quickstart
Installation
pip install dagster-polars
To use the BigQueryPolarsIOManager
you need to install the gcp
extra:
pip install 'dagster-polars[gcp]'
Usage & Examples
import polars as pl
from dagster import AssetIn, Definitions, asset
from dagster_polars import PolarsDeltaIOManager, PolarsParquetIOManager
@asset(io_manager_key="polars_parquet_io_manager")
def upstream() -> pl.DataFrame:
return pl.DataFrame({"a": [1, 2, 3], "b": ["a", "b", "c"]})
@asset(
io_manager_key="polars_parquet_io_manager",
ins={"upstream": AssetIn(metadata={"columns": ["a"]})} # explicitly specify which columns to load
)
def downstream(
upstream: pl.LazyFrame # the type annotation controls whether we load an eager or lazy DataFrame
) -> pl.DataFrame:
df = ... # some lazy operations with `upstream`
return df.collect()
@asset(
io_manager_key="polars_delta_io_manager",
metadata={
"mode": "append" # append to the existing table instead of overwriting it
}
)
def downstream_append(
upstream: pl.DataFrame
) -> pl.DataFrame:
return upstream
base_dir = "/remote/or/local/path" # s3://my-bucket/... or gs://my-bucket/... also works!
definitions = Definitions(
assets=[upstream, downstream, downstream_append],
resources={
"polars_parquet_io_manager": PolarsParquetIOManager(
base_dir=base_dir
),
"polars_delta_io_manager": PolarsDeltaIOManager(
base_dir=base_dir
),
}
)
Development
Installation
poetry install
poetry run pre-commit install
Testing
poetry run pytest
Ideas
- Data validation like in dagster-pandas
- Maybe use
DagsterTypeLoader
?
Project details
Release history Release notifications | RSS feed
Download files
Download the file for your platform. If you're not sure which to choose, learn more about installing packages.
Source Distribution
dagster_polars-0.0.9.tar.gz
(15.0 kB
view hashes)
Built Distribution
Close
Hashes for dagster_polars-0.0.9-py3-none-any.whl
Algorithm | Hash digest | |
---|---|---|
SHA256 | cd4742860a8134c361477b72c549b31bb73953603f22d8c91f991198acae7e9b |
|
MD5 | afefe1afca6c49be5233d5cb8e64e7e2 |
|
BLAKE2b-256 | ebcb36769680b422ef2f7fa9e396c1980f3d4a1639f6ff8513c3a80da9402a7d |