Skip to content

Commit

Permalink
make StepLauncher and friends public (#7945)
Browse files Browse the repository at this point in the history
  • Loading branch information
smackesey committed May 18, 2022
1 parent 1bd83e4 commit 205d811
Show file tree
Hide file tree
Showing 2 changed files with 23 additions and 3 deletions.
19 changes: 19 additions & 0 deletions python_modules/dagster/dagster/__init__.py
Original file line number Diff line number Diff line change
Expand Up @@ -162,6 +162,7 @@
from dagster.core.definitions.run_status_sensor_definition import build_run_status_sensor_context
from dagster.core.definitions.schedule_definition import build_schedule_context
from dagster.core.definitions.sensor_definition import build_sensor_context
from dagster.core.definitions.step_launcher import StepLauncher
from dagster.core.definitions.utils import (
config_from_files,
config_from_pkg_resources,
Expand All @@ -172,6 +173,7 @@
DagsterConfigMappingFunctionError,
DagsterError,
DagsterEventLogInvalidForRun,
DagsterExecutionInterruptedError,
DagsterExecutionStepExecutionError,
DagsterExecutionStepNotFoundError,
DagsterInvalidConfigDefinitionError,
Expand All @@ -188,6 +190,7 @@
DagsterUnknownResourceError,
DagsterUnmetExecutorRequirementsError,
DagsterUserCodeExecutionError,
raise_execution_interrupts,
)
from dagster.core.events import DagsterEvent, DagsterEventType
from dagster.core.execution.api import (
Expand All @@ -206,6 +209,12 @@
from dagster.core.execution.context.output import OutputContext, build_output_context
from dagster.core.execution.context.system import TypeCheckContext
from dagster.core.execution.execute_in_process_result import ExecuteInProcessResult
from dagster.core.execution.plan.external_step import (
external_instance_from_step_run_ref,
run_step_from_ref,
step_context_to_step_run_ref,
step_run_ref_to_step_context,
)
from dagster.core.execution.results import (
CompositeSolidExecutionResult,
PipelineExecutionResult,
Expand Down Expand Up @@ -255,6 +264,7 @@
from dagster.core.types.python_dict import Dict
from dagster.core.types.python_set import Set
from dagster.core.types.python_tuple import Tuple
from dagster.serdes import deserialize_value, serialize_value
from dagster.utils import file_relative_path
from dagster.utils.alert import make_email_on_run_failure_sensor
from dagster.utils.backcompat import ExperimentalWarning, rename_warning
Expand Down Expand Up @@ -465,6 +475,10 @@ def __dir__() -> typing.List[str]:
"InitLoggerContext",
"InitResourceContext",
"ExecuteInProcessResult",
"step_context_to_step_run_ref",
"external_instance_from_step_run_ref",
"step_run_ref_to_step_context",
"run_step_from_ref",
"build_init_resource_context",
"OpExecutionContext",
"PipelineExecutionResult",
Expand Down Expand Up @@ -501,6 +515,7 @@ def __dir__() -> typing.List[str]:
"DagsterConfigMappingFunctionError",
"DagsterError",
"DagsterEventLogInvalidForRun",
"DagsterExecutionInterruptedError",
"DagsterExecutionStepExecutionError",
"DagsterExecutionStepNotFoundError",
"DagsterInvalidConfigDefinitionError",
Expand All @@ -517,6 +532,7 @@ def __dir__() -> typing.List[str]:
"DagsterUnknownResourceError",
"DagsterUnmetExecutorRequirementsError",
"DagsterUserCodeExecutionError",
"raise_execution_interrupts",
# Logging
"DagsterLogManager",
"get_dagster_logger",
Expand Down Expand Up @@ -574,6 +590,8 @@ def __dir__() -> typing.List[str]:
# storage
"EventRecordsFilter",
"RunShardedEventsCursor",
"serialize_value",
"deserialize_value",
# partitions and schedules
"build_schedule_from_partitioned_job",
"schedule_from_partitions",
Expand Down Expand Up @@ -610,6 +628,7 @@ def __dir__() -> typing.List[str]:
"RunStatusSensorContext",
"build_sensor_context",
"build_run_status_sensor_context",
"StepLauncher",
"SkipReason",
"daily_schedule",
"hourly_schedule",
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -5,11 +5,12 @@
import sys
from typing import TYPE_CHECKING, Iterator, Optional, cast

from dagster import Field, StringSource
from dagster import _check as check
from dagster import resource
import dagster._check as check
from dagster.config.field import Field
from dagster.config.source import StringSource
from dagster.core.code_pointer import FileCodePointer, ModuleCodePointer
from dagster.core.definitions.reconstruct import ReconstructablePipeline, ReconstructableRepository
from dagster.core.definitions.resource_definition import resource
from dagster.core.definitions.step_launcher import StepLauncher, StepRunRef
from dagster.core.errors import raise_execution_interrupts
from dagster.core.events import DagsterEvent, DagsterEventType
Expand Down

0 comments on commit 205d811

Please sign in to comment.