Skip to content

Commit

Permalink
Update post review
Browse files Browse the repository at this point in the history
  • Loading branch information
maximearmstrong committed Dec 26, 2024
1 parent 24ae2c8 commit efd66b3
Show file tree
Hide file tree
Showing 2 changed files with 5 additions and 4 deletions.
Original file line number Diff line number Diff line change
Expand Up @@ -273,12 +273,12 @@ def all_api_mocks_fixture(
@pytest.fixture(name="airbyte_cloud_sync_and_poll")
def sync_and_poll_fixture():
with patch("dagster_airbyte.resources.AirbyteCloudClient.sync_and_poll") as mocked_function:
# Airbyte output where all sync'd tables match the workspace data that was used to create the assets def
# Airbyte output where all synced tables match the workspace data that was used to create the assets def
expected_airbyte_output = AirbyteOutput(
connection_details=SAMPLE_CONNECTION_DETAILS,
job_details=get_job_details_sample(status=AirbyteJobStatusType.SUCCEEDED),
)
# Airbyte output where a table is missing and an unexpected table is sync'd,
# Airbyte output where a table is missing and an unexpected table is synced,
# compared to the workspace data that was used to create the assets def
unexpected_airbyte_output = AirbyteOutput(
connection_details=UNEXPECTED_SAMPLE_CONNECTION_DETAILS,
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -7,6 +7,7 @@
import pytest
import responses
from dagster import AssetExecutionContext, AssetKey, EnvVar, Failure, materialize
from dagster._core.events import DagsterEventType
from dagster._core.test_utils import environ
from dagster_airbyte import AirbyteCloudWorkspace, airbyte_assets
from dagster_airbyte.resources import (
Expand Down Expand Up @@ -404,7 +405,7 @@ def my_airbyte_assets(context: AssetExecutionContext, airbyte: AirbyteCloudWorks
asset_materializations = [
event
for event in result.events_for_node(cleaned_connection_id)
if event.event_type_value == "ASSET_MATERIALIZATION"
if event.event_type_value == DagsterEventType.ASSET_MATERIALIZATION
]
assert len(asset_materializations) == 2
materialized_asset_keys = {
Expand All @@ -424,7 +425,7 @@ def my_airbyte_assets(context: AssetExecutionContext, airbyte: AirbyteCloudWorks
asset_materializations = [
event
for event in result.events_for_node(cleaned_connection_id)
if event.event_type_value == "ASSET_MATERIALIZATION"
if event.event_type_value == DagsterEventType.ASSET_MATERIALIZATION
]
assert len(asset_materializations) == 2
materialized_asset_keys = {
Expand Down

0 comments on commit efd66b3

Please sign in to comment.