Skip to content

Commit

Permalink
[tune] Remove deprecated mlflow+wandb aliases (#36860)
Browse files Browse the repository at this point in the history

Signed-off-by: Kai Fricke <kai@anyscale.com>
Signed-off-by: Justin Yu <justinvyu@anyscale.com>
Co-authored-by: Justin Yu <justinvyu@anyscale.com>
  • Loading branch information
krfricke and justinvyu authored Jun 30, 2023
1 parent 99dc858 commit 2ba7a97
Show file tree
Hide file tree
Showing 5 changed files with 1 addition and 299 deletions.
23 changes: 0 additions & 23 deletions python/ray/air/tests/test_integration_mlflow.py
Original file line number Diff line number Diff line change
Expand Up @@ -9,12 +9,7 @@

from ray._private.dict import flatten_dict
from ray.train._internal.session import init_session
from ray.tune.trainable import wrap_function
from ray.tune.trainable.session import _shutdown as tune_session_shutdown
from ray.tune.integration.mlflow import (
MLflowTrainableMixin,
mlflow_mixin,
)
from ray.air.integrations.mlflow import MLflowLoggerCallback, setup_mlflow, _NoopModule
from ray.air._internal.mlflow import _MLflowLoggerUtil

Expand Down Expand Up @@ -201,24 +196,6 @@ def testMlFlowLoggerLogging(self):
{"dir": "artifact", "run_id": run.info.run_id},
)

def testMlFlowMixinConfig(self):
clear_env_vars()
trial_config = {"par1": 4, "par2": 9.0}

with self.assertRaises(DeprecationWarning):

@mlflow_mixin
def train_fn(config):
return 1

def train_fn_2(config):
return 1

train_fn_2.__mixins__ = (MLflowTrainableMixin,)

with self.assertRaises(DeprecationWarning):
wrap_function(train_fn_2)(trial_config)

def testMlFlowSetupExplicit(self):
clear_env_vars()
trial_config = {"par1": 4, "par2": 9.0}
Expand Down
22 changes: 0 additions & 22 deletions python/ray/air/tests/test_integration_wandb.py
Original file line number Diff line number Diff line change
Expand Up @@ -47,9 +47,6 @@

import ray
from ray.exceptions import RayActorError
from ray.tune import Trainable
from ray.tune.integration.wandb import WandbTrainableMixin
from ray.tune.integration.wandb import wandb_mixin
from ray.air.integrations.wandb import (
WandbLoggerCallback,
_QueueItem,
Expand Down Expand Up @@ -453,25 +450,6 @@ def finish(self):
ray.get(actor.get_state.remote())


class TestWandbClassMixin:
def test_wandb_mixin(self):
class WandbTestTrainable(WandbTrainableMixin, Trainable):
pass

config = {}
with pytest.raises(DeprecationWarning):
WandbTestTrainable(config)


class TestWandbMixinDecorator:
def test_wandb_decorator(self):
with pytest.raises(DeprecationWarning):

@wandb_mixin
def train_fn(config):
return 1


def test_wandb_logging_process_run_info_hook(monkeypatch):
"""
Test WANDB_PROCESS_RUN_INFO_HOOK in _WandbLoggingActor is
Expand Down
139 changes: 0 additions & 139 deletions python/ray/tune/integration/mlflow.py

This file was deleted.

114 changes: 0 additions & 114 deletions python/ray/tune/integration/wandb.py

This file was deleted.

2 changes: 1 addition & 1 deletion python/requirements/ml/tune-requirements.txt
Original file line number Diff line number Diff line change
Expand Up @@ -17,4 +17,4 @@ hyperopt==0.2.7
nevergrad==0.4.3.post7
optuna==3.2.0

tune-sklearn==0.4.4
tune-sklearn==0.4.6

0 comments on commit 2ba7a97

Please sign in to comment.