
dagster_postgres.PostgresEventLogStorage(postgres_url, inst_data=None)[source]¶Postgres-backed event log storage.
Users should not directly instantiate this class; it is instantiated by internal machinery when
dagit and dagster-graphql load, based on the values in the dagster.yaml file in
$DAGSTER_HOME. Configuration of this class should be done by setting values in that file.
To use Postgres for event log storage, you can add a block such as the following to your
dagster.yaml:
event_log_storage:
  module: dagster_postgres.event_log
  class: PostgresEventLogStorage
  config:
    postgres_db:
      username: { username }
      password: { password }
      hostname: { hostname }
      db_name: { db_name }
      port: { port }
Note that the fields in this config are StringSource and
IntSource and can be configured from environment variables.
dagster_postgres.PostgresRunStorage(postgres_url, inst_data=None)[source]¶Postgres-backed run storage.
Users should not directly instantiate this class; it is instantiated by internal machinery when
dagit and dagster-graphql load, based on the values in the dagster.yaml file in
$DAGSTER_HOME. Configuration of this class should be done by setting values in that file.
To use Postgres for run storage, you can add a block such as the following to your
dagster.yaml:
run_storage:
  module: dagster_postgres.run_storage
  class: PostgresRunStorage
  config:
    postgres_db:
      username: { username }
      password: { password }
      hostname: { hostname }
      db_name: { database }
      port: { port }
Note that the fields in this config are StringSource and
IntSource and can be configured from environment variables.
dagster_postgres.PostgresScheduleStorage(postgres_url, inst_data=None)[source]¶Postgres-backed run storage.
Users should not directly instantiate this class; it is instantiated by internal machinery when
dagit and dagster-graphql load, based on the values in the dagster.yaml file in
$DAGSTER_HOME. Configuration of this class should be done by setting values in that file.
To use Postgres for schedule storage, you can add a block such as the following to your
dagster.yaml:
schedule_storage:
  module: dagster_postgres.schedule_storage
  class: PostgresScheduleStorage
  config:
    postgres_db:
      username: { username }
      password: { password }
      hostname: { hostname }
      db_name: { db_name }
      port: { port }
Note that the fields in this config are StringSource and
IntSource and can be configured from environment variables.