Skip to content

Commit

Permalink
Remove ray.tasks() from API. (#7807)
Browse files Browse the repository at this point in the history
  • Loading branch information
robertnishihara committed Apr 1, 2020
1 parent 780c1c3 commit b011c60
Show file tree
Hide file tree
Showing 13 changed files with 38 additions and 622 deletions.
2 changes: 0 additions & 2 deletions doc/source/package-ref.rst
Original file line number Diff line number Diff line change
Expand Up @@ -34,8 +34,6 @@ Inspect the Cluster State

.. autofunction:: ray.nodes

.. autofunction:: ray.tasks

.. autofunction:: ray.objects

.. autofunction:: ray.timeline
Expand Down
3 changes: 1 addition & 2 deletions python/ray/__init__.py
Original file line number Diff line number Diff line change
Expand Up @@ -59,7 +59,7 @@
_config = _Config()

from ray.profiling import profile # noqa: E402
from ray.state import (jobs, nodes, actors, tasks, objects, timeline,
from ray.state import (jobs, nodes, actors, objects, timeline,
object_transfer_timeline, cluster_resources,
available_resources, errors) # noqa: E402
from ray.worker import (
Expand Down Expand Up @@ -99,7 +99,6 @@
"jobs",
"nodes",
"actors",
"tasks",
"objects",
"timeline",
"object_transfer_timeline",
Expand Down
2 changes: 0 additions & 2 deletions python/ray/_raylet.pyx
Original file line number Diff line number Diff line change
Expand Up @@ -75,7 +75,6 @@ from ray.includes.libcoreworker cimport (
CFiberEvent,
CActorHandle,
)
from ray.includes.task cimport CTaskSpec
from ray.includes.ray_config cimport RayConfig

import ray
Expand All @@ -98,7 +97,6 @@ cimport cpython
include "includes/unique_ids.pxi"
include "includes/ray_config.pxi"
include "includes/function_descriptor.pxi"
include "includes/task.pxi"
include "includes/buffer.pxi"
include "includes/common.pxi"
include "includes/serialization.pxi"
Expand Down
1 change: 0 additions & 1 deletion python/ray/includes/libcoreworker.pxd
Original file line number Diff line number Diff line change
Expand Up @@ -36,7 +36,6 @@ from ray.includes.common cimport (
from ray.includes.function_descriptor cimport (
CFunctionDescriptor,
)
from ray.includes.task cimport CTaskSpec

ctypedef unordered_map[c_string, c_vector[pair[int64_t, double]]] \
ResourceMappingType
Expand Down
89 changes: 0 additions & 89 deletions python/ray/includes/task.pxd

This file was deleted.

209 changes: 0 additions & 209 deletions python/ray/includes/task.pxi

This file was deleted.

5 changes: 3 additions & 2 deletions python/ray/includes/unique_ids.pxi
Original file line number Diff line number Diff line change
Expand Up @@ -134,8 +134,9 @@ cdef class ObjectID(BaseID):
self.in_core_worker = False

worker = ray.worker.global_worker
# TODO(edoakes): there are dummy object IDs being created in
# includes/task.pxi before the core worker is initialized.
# TODO(edoakes): We should be able to remove the in_core_worker flag.
# But there are still some dummy object IDs being created outside the
# context of a core worker.
if hasattr(worker, "core_worker"):
worker.core_worker.add_object_id_reference(self)
self.in_core_worker = True
Expand Down
Loading

0 comments on commit b011c60

Please sign in to comment.