Skip to content

Commit

Permalink
🐛 fix CI build (#39)
Browse files Browse the repository at this point in the history
  • Loading branch information
danielgafni authored Oct 10, 2024
1 parent db03609 commit cded645
Show file tree
Hide file tree
Showing 3 changed files with 7 additions and 16 deletions.
8 changes: 4 additions & 4 deletions dagster_ray/io_manager.py
Original file line number Diff line number Diff line change
Expand Up @@ -64,8 +64,8 @@ class RayIOManager(ConfigurableIOManager, ConfigurableResource):
def handle_output(self, context: OutputContext, obj):
import ray

# if self.address: # TODO: should this really be done here?
# ray.init(self.address, ignore_reinit_error=True)
if self.address: # TODO: should this really be done here?
ray.init(self.address, ignore_reinit_error=True)

object_map = RayObjectMap.get_or_create()

Expand All @@ -83,8 +83,8 @@ def handle_output(self, context: OutputContext, obj):
def load_input(self, context: InputContext):
import ray

# if self.address: # TODO: should this really be done here?
# ray.init(self.address, ignore_reinit_error=True)
if self.address: # TODO: should this really be done here?
ray.init(self.address, ignore_reinit_error=True)

object_map = RayObjectMap.get_or_create()

Expand Down
4 changes: 3 additions & 1 deletion tests/conftest.py
Original file line number Diff line number Diff line change
Expand Up @@ -17,7 +17,9 @@ def dagster_instance(tmp_path_factory: TempPathFactory) -> DagsterInstance:
def local_ray_address() -> Iterator[str]:
import ray

context = ray.init(runtime_env={"env_vars": {"RAY_ENABLE_RECORD_ACTOR_TASK_LOGGING": "1"}})
context = ray.init(
ignore_reinit_error=True, runtime_env={"env_vars": {"RAY_ENABLE_RECORD_ACTOR_TASK_LOGGING": "1"}}
)

yield "auto"

Expand Down
11 changes: 0 additions & 11 deletions tests/test_executor.py
Original file line number Diff line number Diff line change
Expand Up @@ -50,17 +50,6 @@ def my_failing_job():
failed_op()


@pytest.fixture
def local_ray_address() -> Iterator[str]:
import ray

context = ray.init()

yield "auto"

context.disconnect()


@pytest.fixture
def dagster_instance() -> Iterator[DagsterInstance]:
with instance_for_test() as instance:
Expand Down

0 comments on commit cded645

Please sign in to comment.