Executing Dagster on Dask
The dagster-dask module makes a dask_executor available, which can target either a local Dask cluster or a distributed cluster. Computation is distributed across the cluster at the execution step level -- that is, we use Dask to orchestrate execution of the steps in a job, not to parallelize computation within those steps.
This executor takes the compiled execution plan, and converts each execution step into a Dask Future configured with the appropriate task dependencies to ensure tasks are properly sequenced. When the job is executed, these futures are generated and then awaited by the parent Dagster process.
Data is passed between step executions via IO Managers. As a consequence, a persistent shared storage (such as a network filesystem shared by all of the Dask nodes, S3, or GCS) must be used.
Note that, when using this executor, the compute function of a single op is still executed in a single process on a single machine. If your goal is to distribute execution of workloads within the logic of a single op, you may find that invoking Dask or PySpark directly from within the body of an op's compute function is a better fit than the engine layer covered in this documentation.
Requirements
Install dask.distributed.
Local execution
It is relatively straightforward to set up and run a Dagster job on local Dask. This can be useful for testing.
First, run pip install dagster-dask.
Then, create a job with the dask executor:
from dagster_dask import dask_executor
import dagster as dg
@dg.op
def hello_world():
    return "Hello, World!"
@dg.job(executor_def=dask_executor)
def local_dask_job():
    hello_world()
Now you can run this job with a config block such as the following:
execution:
  config:
    cluster:
      local:
Executing this job will spin up local Dask execution, run the job, and exit.
Distributed execution
If you want to use a Dask cluster for distributed execution, you will first need to set up a Dask cluster. Note that the machine running the Dagster parent process must be able to connect to the host/port on which the Dask scheduler is running.
You'll also need an IO manager that uses persistent shared storage, which should be attached to the job along with any resources on which it depends. Here, we use the s3.s3_pickle_io_manager:
from dagster_aws.s3.io_manager import s3_pickle_io_manager
from dagster_aws.s3.resources import s3_resource
from dagster_dask import dask_executor
from dagster import job, op
@op
def hello_world():
    return "Hello, World!"
@job(
    executor_def=dask_executor,
    resource_defs={"io_manager": s3_pickle_io_manager, "s3": s3_resource},
)
def distributed_dask_job():
    hello_world()
For distributing task execution on a Dask cluster, you must provide a config block that includes the address/port of the Dask scheduler:
resources:
  io_manager:
    config:
      s3_bucket: your_bucket_name
execution:
  config:
    cluster:
      existing:
        address: "dask_scheduler.dns_name:8787"
Since Dask will invoke your job code on the cluster workers, you must ensure that the latest version of your Python code is available to all of the Dask workers. Ideally, you'll package this as a Python module, and target your workspace.yaml at this module.
Managing compute resources with Dask
Dask has basic support for compute resource management. In Dask you can specify that a particular worker node has, say, 3 GPUs, and then tasks which are specified with GPU requirements will be scheduled to respect that constraint on available resources.
In Dask, you'd set this up by launching your workers with resource specifications:
dask-worker scheduler:8786 --resources "GPU=2"
and then when submitting tasks to the Dask cluster, specifying resource requirements in the Python API:
client.submit(task, resources={'GPU': 1})
Dagster has simple support for Dask resource specification at the op level for ops that will be executed on Dask clusters. In your op definition, just add tags as follows:
@op(
    ...
    tags={'dagster-dask/resource_requirements': {"GPU": 1}},
)
def my_op(...):
    pass
The dict passed to dagster-dask/resource_requirements will be passed through as the resources argument to the Dask client's ~dask:distributed.Client.submit method for execution on a Dask cluster. Note that in non-Dask execution, this key will be ignored.
Caveats
Dagster logs are not yet retrieved from Dask workers; this will be addressed in follow-up work.
While this library is still nascent, we're working to improve it, and we are happy to accept contributions.