Skip to content

Commit

Permalink
rename several internal submodules (#7134)
Browse files Browse the repository at this point in the history
  • Loading branch information
smackesey committed Mar 22, 2022
1 parent 35f5f7e commit ff8d594
Show file tree
Hide file tree
Showing 94 changed files with 125 additions and 126 deletions.
2 changes: 1 addition & 1 deletion docs/content/api/modules.json

Large diffs are not rendered by default.

2 changes: 1 addition & 1 deletion docs/content/api/searchindex.json

Large diffs are not rendered by default.

2 changes: 1 addition & 1 deletion docs/content/api/sections.json

Large diffs are not rendered by default.

Binary file modified docs/next/public/objects.inv
Binary file not shown.
4 changes: 2 additions & 2 deletions docs/sphinx/sections/api/apidocs/pipeline.rst
Original file line number Diff line number Diff line change
Expand Up @@ -44,7 +44,7 @@ Reconstructable pipelines
.. autoclass:: reconstructable
:noindex:

.. currentmodule:: dagster.core.definitions.reconstructable
.. currentmodule:: dagster.core.definitions.reconstruct

.. autoclass:: ReconstructablePipeline
:members:
Expand Down Expand Up @@ -128,4 +128,4 @@ Run Config Schema
}
},

}
}
2 changes: 1 addition & 1 deletion examples/airline_demo/airline_demo_tests/test_pipelines.py
Original file line number Diff line number Diff line change
Expand Up @@ -5,7 +5,7 @@
import pytest

from dagster import execute_pipeline, file_relative_path
from dagster.core.definitions.reconstructable import ReconstructablePipeline
from dagster.core.definitions.reconstruct import ReconstructablePipeline
from dagster.core.test_utils import instance_for_test
from dagster.utils import load_yaml_from_globs

Expand Down
2 changes: 1 addition & 1 deletion examples/dbt_example/dbt_example_tests/test_pipeline.py
Original file line number Diff line number Diff line change
@@ -1,7 +1,7 @@
import tempfile

from dagster import execute_pipeline
from dagster.core.definitions.reconstructable import ReconstructablePipeline
from dagster.core.definitions.reconstruct import ReconstructablePipeline
from dagster.core.test_utils import instance_for_test

CEREALS_DATASET_URL = "https://gist.githubusercontent.com/mgasner/bd2c0f66dff4a9f01855cfa6870b1fce/raw/2de62a57fb08da7c58d6480c987077cf91c783a1/cereal.csv"
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -3,7 +3,7 @@
import pytest

from dagster import execute_pipeline, file_relative_path
from dagster.core.definitions.reconstructable import ReconstructablePipeline
from dagster.core.definitions.reconstruct import ReconstructablePipeline
from dagster.core.test_utils import instance_for_test
from dagster.utils import pushd
from dagster.utils.yaml_utils import load_yaml_from_path
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -79,10 +79,10 @@
weekly_schedule,
)
from dagster.core.asset_defs import SourceAsset, asset, build_assets_job
from dagster.core.definitions.decorators.sensor import sensor
from dagster.core.definitions.decorators.sensor_decorator import sensor
from dagster.core.definitions.executor_definition import in_process_executor
from dagster.core.definitions.metadata import MetadataValue
from dagster.core.definitions.reconstructable import ReconstructableRepository
from dagster.core.definitions.reconstruct import ReconstructableRepository
from dagster.core.definitions.sensor_definition import RunRequest, SkipReason
from dagster.core.log_manager import coerce_valid_log_level
from dagster.core.storage.fs_io_manager import fs_io_manager
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -7,7 +7,7 @@
from dagster_graphql.test.utils import execute_dagster_graphql, infer_pipeline_selector

from dagster import execute_pipeline
from dagster.core.definitions.reconstructable import ReconstructableRepository
from dagster.core.definitions.reconstruct import ReconstructableRepository
from dagster.core.storage.pipeline_run import PipelineRunStatus
from dagster.grpc.types import CancelExecutionRequest
from dagster.utils import file_relative_path, safe_tempfile_path
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -10,7 +10,7 @@
main_repo_name,
)

from dagster.core.definitions.reconstructable import ReconstructableRepository
from dagster.core.definitions.reconstruct import ReconstructableRepository
from dagster.core.host_representation import (
ExternalRepositoryOrigin,
InProcessRepositoryLocationOrigin,
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -4,7 +4,7 @@
from contextlib import contextmanager

from dagster import check
from dagster.core.definitions.reconstructable import ReconstructableRepository
from dagster.core.definitions.reconstruct import ReconstructableRepository
from dagster.core.host_representation import InProcessRepositoryLocationOrigin
from dagster.utils import file_relative_path, git_repository_root

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -5,13 +5,17 @@
from dagster_test.graph_job_op_toys.log_asset import log_asset_job
from dagster_test.graph_job_op_toys.log_file import log_file_job
from dagster_test.graph_job_op_toys.log_s3 import log_s3_job
from slack_sdk import WebClient
from slack_sdk.web.client import WebClient

from dagster import AssetKey, RunRequest, SkipReason, check, sensor
from dagster.core.definitions.decorators.sensor import asset_sensor
from dagster.core.definitions.run_status_sensor_definition import (
from dagster import (
AssetKey,
RunFailureSensorContext,
RunRequest,
SkipReason,
asset_sensor,
check,
run_failure_sensor,
sensor,
)


Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -2,9 +2,7 @@
from time import sleep
from typing import List

from dagster import Field, Output, op
from dagster.core.definitions.decorators.graph import graph
from dagster.core.definitions.output import Out
from dagster import Field, Out, Output, graph, op


@op
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -7,10 +7,7 @@

from dagster import check
from dagster.core.code_pointer import FileCodePointer
from dagster.core.definitions.reconstructable import (
ReconstructablePipeline,
ReconstructableRepository,
)
from dagster.core.definitions.reconstruct import ReconstructablePipeline, ReconstructableRepository
from dagster.core.execution.api import create_execution_plan
from dagster.core.execution.build_resources import build_resources
from dagster.core.execution.context.output import build_output_context
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -4,12 +4,12 @@
InputDefinition,
ResourceDefinition,
SolidDefinition,
graph,
repository,
schedule,
sensor,
solid,
)
from dagster.core.definitions.decorators.graph import graph


def make_solid(
Expand Down
12 changes: 8 additions & 4 deletions python_modules/dagster-test/dagster_test/toys/sensors.py
Original file line number Diff line number Diff line change
@@ -1,12 +1,16 @@
import os

from slack_sdk import WebClient
from slack_sdk.web.client import WebClient

from dagster import AssetKey, RunRequest, SkipReason, check, sensor
from dagster.core.definitions.decorators.sensor import asset_sensor
from dagster.core.definitions.run_status_sensor_definition import (
from dagster import (
AssetKey,
PipelineFailureSensorContext,
RunRequest,
SkipReason,
asset_sensor,
check,
pipeline_failure_sensor,
sensor,
)


Expand Down
3 changes: 1 addition & 2 deletions python_modules/dagster-test/dagster_test/toys/sleepy.py
Original file line number Diff line number Diff line change
Expand Up @@ -2,8 +2,7 @@
from time import sleep
from typing import Iterator, List

from dagster import Field, Output, OutputDefinition, solid
from dagster.core.definitions.decorators.graph import graph
from dagster import Field, Output, OutputDefinition, graph, solid


@solid
Expand Down
2 changes: 1 addition & 1 deletion python_modules/dagster/dagster/cli/api.py
Original file line number Diff line number Diff line change
Expand Up @@ -10,7 +10,7 @@
get_working_directory_from_kwargs,
python_origin_target_argument,
)
from dagster.core.definitions.reconstructable import ReconstructablePipeline
from dagster.core.definitions.reconstruct import ReconstructablePipeline
from dagster.core.errors import DagsterExecutionInterruptedError
from dagster.core.events import DagsterEvent, DagsterEventType, EngineEventData
from dagster.core.execution.api import create_execution_plan, execute_plan_iterator
Expand Down
2 changes: 1 addition & 1 deletion python_modules/dagster/dagster/cli/load_handle.py
Original file line number Diff line number Diff line change
Expand Up @@ -5,7 +5,7 @@

from dagster import check
from dagster.cli.workspace.cli_target import get_working_directory_from_kwargs
from dagster.core.definitions.reconstructable import ReconstructableRepository
from dagster.core.definitions.reconstruct import ReconstructableRepository


def _cli_load_invariant(condition, msg=None):
Expand Down
2 changes: 1 addition & 1 deletion python_modules/dagster/dagster/cli/workspace/cli_target.py
Original file line number Diff line number Diff line change
Expand Up @@ -8,7 +8,7 @@

from dagster import check
from dagster.core.code_pointer import CodePointer
from dagster.core.definitions.reconstructable import repository_def_from_target_def
from dagster.core.definitions.reconstruct import repository_def_from_target_def
from dagster.core.host_representation.external import ExternalRepository
from dagster.core.host_representation.repository_location import RepositoryLocation
from dagster.core.instance import DagsterInstance
Expand Down
2 changes: 1 addition & 1 deletion python_modules/dagster/dagster/core/asset_defs/__init__.py
Original file line number Diff line number Diff line change
@@ -1,6 +1,6 @@
from .asset import AssetsDefinition
from .asset_group import AssetGroup
from .asset_in import AssetIn
from .assets import AssetsDefinition
from .assets_job import build_assets_job
from .decorators import asset, multi_asset
from .source_asset import SourceAsset
Original file line number Diff line number Diff line change
Expand Up @@ -31,7 +31,7 @@
from ..definitions.op_definition import OpDefinition
from ..definitions.resource_definition import ResourceDefinition
from ..errors import DagsterInvalidDefinitionError
from .asset import AssetsDefinition
from .assets import AssetsDefinition
from .assets_job import build_assets_job, build_root_manager, build_source_assets_by_key
from .source_asset import SourceAsset

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -3,7 +3,7 @@
from dagster.core.definitions.partition import PartitionsDefinition
from dagster.core.definitions.partition_key_range import PartitionKeyRange

from .asset import AssetsDefinition
from .assets import AssetsDefinition


def get_upstream_partitions_for_partition_range(
Expand Down
4 changes: 2 additions & 2 deletions python_modules/dagster/dagster/core/asset_defs/assets_job.py
Original file line number Diff line number Diff line change
Expand Up @@ -4,7 +4,7 @@

from dagster import check
from dagster.core.definitions.config import ConfigMapping
from dagster.core.definitions.decorators.op import op
from dagster.core.definitions.decorators.op_decorator import op
from dagster.core.definitions.dependency import (
DependencyDefinition,
IDependencyDefinition,
Expand All @@ -27,8 +27,8 @@
from dagster.utils.backcompat import ExperimentalWarning, experimental
from dagster.utils.merger import merge_dicts

from .asset import AssetsDefinition
from .asset_partitions import get_upstream_partitions_for_partition_range
from .assets import AssetsDefinition
from .source_asset import SourceAsset


Expand Down
4 changes: 2 additions & 2 deletions python_modules/dagster/dagster/core/asset_defs/decorators.py
Original file line number Diff line number Diff line change
Expand Up @@ -17,7 +17,7 @@
from dagster.builtins import Nothing
from dagster.config import Field
from dagster.core.decorator_utils import get_function_params, get_valid_name_permutations
from dagster.core.definitions.decorators.op import _Op
from dagster.core.definitions.decorators.op_decorator import _Op
from dagster.core.definitions.events import AssetKey
from dagster.core.definitions.input import In
from dagster.core.definitions.output import Out
Expand All @@ -27,8 +27,8 @@
from dagster.core.types.dagster_type import DagsterType
from dagster.utils.backcompat import ExperimentalWarning, experimental_decorator

from .asset import AssetsDefinition
from .asset_in import AssetIn
from .assets import AssetsDefinition
from .partition_mapping import PartitionMapping

ASSET_DEPENDENCY_METADATA_KEY = ".dagster/asset_deps"
Expand Down
4 changes: 2 additions & 2 deletions python_modules/dagster/dagster/core/definitions/__init__.py
Original file line number Diff line number Diff line change
Expand Up @@ -6,7 +6,7 @@
daily_schedule,
failure_hook,
graph,
hook,
hook_decorator,
hourly_schedule,
job,
lambda_solid,
Expand Down Expand Up @@ -103,7 +103,7 @@
from .pipeline_base import IPipeline
from .pipeline_definition import PipelineDefinition
from .preset import PresetDefinition
from .reconstructable import (
from .reconstruct import (
ReconstructablePipeline,
build_reconstructable_job,
build_reconstructable_pipeline,
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -24,7 +24,7 @@
from dagster.utils import frozentags

from .config import ConfigMapping
from .decorators.solid import (
from .decorators.solid_decorator import (
DecoratedSolidFunction,
NoContextDecoratedSolidFunction,
resolve_checked_solid_fn_inputs,
Expand Down
Original file line number Diff line number Diff line change
@@ -1,11 +1,17 @@
from .composite_solid import composite_solid
from .config_mapping import config_mapping
from .graph import graph
from .hook import failure_hook, success_hook
from .job import job
from .op import op
from .pipeline import pipeline
from .repository import repository
from .schedule import daily_schedule, hourly_schedule, monthly_schedule, schedule, weekly_schedule
from .sensor import asset_sensor, sensor
from .solid import lambda_solid, solid
from .composite_solid_decorator import composite_solid
from .config_mapping_decorator import config_mapping
from .graph_decorator import graph
from .hook_decorator import failure_hook, success_hook
from .job_decorator import job
from .op_decorator import op
from .pipeline_decorator import pipeline
from .repository_decorator import repository
from .schedule_decorator import (
daily_schedule,
hourly_schedule,
monthly_schedule,
schedule,
weekly_schedule,
)
from .sensor_decorator import asset_sensor, sensor
from .solid_decorator import lambda_solid, solid
Original file line number Diff line number Diff line change
Expand Up @@ -55,7 +55,7 @@ def __call__(self, fn: Callable[..., Any]) -> GraphDefinition:
check.dict_param(self.out, "out", key_type=str, value_type=GraphOut)
output_defs = [out.to_definition(name=name) for name, out in self.out.items()]

from dagster.core.definitions.decorators.composite_solid import do_composition
from dagster.core.definitions.decorators.composite_solid_decorator import do_composition

(
input_mappings,
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -51,7 +51,7 @@ def __call__(self, fn: Callable[..., Any]) -> JobDefinition:
if not self.name:
self.name = fn.__name__

from dagster.core.definitions.decorators.composite_solid import do_composition
from dagster.core.definitions.decorators.composite_solid_decorator import do_composition

(
input_mappings,
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -22,7 +22,7 @@
from ..output import Out, OutputDefinition
from ..policy import RetryPolicy
from ..solid_definition import SolidDefinition
from .solid import (
from .solid_decorator import (
DecoratedSolidFunction,
NoContextDecoratedSolidFunction,
resolve_checked_solid_fn_inputs,
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -58,7 +58,7 @@ def __call__(self, fn: Callable[..., Any]) -> PipelineDefinition:
if not self.name:
self.name = fn.__name__

from dagster.core.definitions.decorators.composite_solid import (
from dagster.core.definitions.decorators.composite_solid_decorator import (
do_composition,
get_validated_config_mapping,
)
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -9,7 +9,7 @@
ConfiguredDefinitionConfigSchema,
NamedConfigurableDefinition,
)
from dagster.core.definitions.reconstructable import ReconstructablePipeline
from dagster.core.definitions.reconstruct import ReconstructablePipeline
from dagster.core.errors import DagsterUnmetExecutorRequirementsError
from dagster.core.execution.retries import RetryMode, get_retries_config

Expand Down

1 comment on commit ff8d594

@vercel
Copy link

@vercel vercel bot commented on ff8d594 Mar 22, 2022

Choose a reason for hiding this comment

The reason will be displayed to describe this comment to others. Learn more.

Please sign in to comment.