The simplest way to create an op job is to use the @job decorator.
Within the decorated function body, you can use function calls to indicate the dependency structure between the ops/graphs. This allows you to explicitly define dependencies between ops when you define the job.
In this example, the add_one op depends on the return_five op's output. Because this data dependency exists, the add_one op executes after return_five runs successfully and emits the required output:
from dagster import job, op
@opdefreturn_five():return5@opdefadd_one(arg):return arg +1@jobdefdo_stuff():
add_one(return_five())
When defining an op job, you can provide any of the following:
Creating op jobs from a graph can be useful when you want to define inter-op dependencies before binding them to resources, configuration, executors, and other environment-specific features. This approach to op job creation allows you to customize graphs for each environment by plugging in configuration and services specific to that environment.
You can model this by building multiple op jobs that use the same underlying graph of ops. The graph represents the logical core of data transformation, and the configuration and resources on each op job customize the behavior of that job for its environment.
To do this, define a graph using the @graph decorator:
from dagster import graph, op, ConfigurableResource
classServer(ConfigurableResource):defping_server(self):...@opdefinteract_with_server(server: Server):
server.ping_server()@graphdefdo_stuff():
interact_with_server()
Ops and resources can accept configuration that determines how they behave. By default, configuration is supplied at the time an op job is launched.
When constructing an op job, you can customize how that configuration will be satisfied by passing a value to the config parameter of the GraphDefinition.to_job method or the @job decorator.
You can supply a RunConfig object or raw config dictionary. The supplied config will be used to configure the op job whenever it's launched. It will show up in the Dagster UI Launchpad and can be overridden.
from dagster import Config, OpExecutionContext, RunConfig, job, op
classDoSomethingConfig(Config):
config_param:str@opdefdo_something(context: OpExecutionContext, config: DoSomethingConfig):
context.log.info("config_param: "+ config.config_param)
default_config = RunConfig(
ops={"do_something": DoSomethingConfig(config_param="stuff")})@job(config=default_config)defdo_it_all_with_default_config():
do_something()if __name__ =="__main__":# Will log "config_param: stuff"
do_it_all_with_default_config.execute_in_process()
Supplying a PartitionedConfig will create a partitioned op job. This defines a discrete set of partitions along with a function for generating config for a partition. Op job runs can be configured by selecting a partition.
Supplying a ConfigMapping allows you to expose a narrower config interface to the op job.
Instead of needing to configure every op and resource individually when launching the op job, you can supply a smaller number of values to the outer config. The ConfigMapping will then translate it into config for all the job's ops and resources.
You make jobs available to the UI, GraphQL, and command line by including them in a Definitions object at the top level of Python module or file. The tool loads that module as a code location. If you include schedules or sensors, the code location will automatically include jobs that those schedules or sensors target.
from dagster import Definitions, job
@jobdefdo_it_all():...
defs = Definitions(jobs=[do_it_all])
Dagster has built-in support for testing, including separating business logic from environments and setting explicit expectations on uncontrollable inputs. Refer to the Testing guide for more info and examples.