Skip to content

Commit

Permalink
fix partition set name for runs feed tests (#25408)
Browse files Browse the repository at this point in the history
## Summary & Motivation
updates the partition_set name in a test so that it conforms to the
expected pattern
https://github.com/dagster-io/dagster/blob/master/python_modules/dagster/dagster/_core/remote_representation/external_data.py#L1800

important for dagster-io/internal#12131 since it
relies on the job name of a backfill being stored correctly. it's not
stored correctly if the test uses the wrong format

## How I Tested These Changes
  • Loading branch information
jamiedemaria authored Oct 22, 2024
1 parent 2860266 commit 05740a4
Showing 1 changed file with 3 additions and 2 deletions.
Original file line number Diff line number Diff line change
Expand Up @@ -3,6 +3,7 @@

import pytest
from dagster._core.execution.backfill import BulkActionStatus, PartitionBackfill
from dagster._core.remote_representation.external_data import partition_set_snap_name_for_job_name
from dagster._core.remote_representation.origin import RemotePartitionSetOrigin
from dagster._core.storage.dagster_run import DagsterRun, DagsterRunStatus
from dagster._core.storage.tags import BACKFILL_ID_TAG
Expand Down Expand Up @@ -930,7 +931,7 @@ def test_get_runs_feed_filter_job_name(self, graphql_context):

partition_set_origin = RemotePartitionSetOrigin(
repository_origin=repository.get_remote_origin(),
partition_set_name="foo_partition",
partition_set_name=partition_set_snap_name_for_job_name("foo"),
)
for _ in range(3):
_create_run(graphql_context, job_name="foo")
Expand All @@ -942,7 +943,7 @@ def test_get_runs_feed_filter_job_name(self, graphql_context):

partition_set_origin = RemotePartitionSetOrigin(
repository_origin=repository.get_remote_origin(),
partition_set_name="bar_partition",
partition_set_name=partition_set_snap_name_for_job_name("bar"),
)
for _ in range(3):
_create_run(graphql_context, job_name="bar")
Expand Down

0 comments on commit 05740a4

Please sign in to comment.