Codebase-Index-Lite / dask__dask-10972 /blocks_by_class_name.json
Jiayi-Pan's picture
Add files using upload-large-folder tool
93bb69d verified
raw
history blame
32 kB
{
"VersioneerConfig": [
[
"dask/_version.py",
[
"VersioneerConfig"
]
]
],
"NotThisMethod": [
[
"dask/_version.py",
[
"NotThisMethod"
]
]
],
"ArrayBackendEntrypoint": [
[
"dask/array/backends.py",
[
"ArrayBackendEntrypoint"
]
]
],
"NumpyBackendEntrypoint": [
[
"dask/array/backends.py",
[
"NumpyBackendEntrypoint"
]
]
],
"PerformanceWarning": [
[
"dask/array/core.py",
[
"PerformanceWarning"
]
]
],
"Array": [
[
"dask/array/core.py",
[
"Array"
]
]
],
"BlockView": [
[
"dask/array/core.py",
[
"BlockView"
]
]
],
"CupyBackendEntrypoint": [
[
"dask/array/cupy_entry_point.py",
[
"CupyBackendEntrypoint"
]
]
],
"gufunc": [
[
"dask/array/gufunc.py",
[
"gufunc"
]
]
],
"_Recurser": [
[
"dask/array/numpy_compat.py",
[
"_Recurser"
]
]
],
"Generator": [
[
"dask/array/random.py",
[
"Generator"
]
]
],
"RandomState": [
[
"dask/array/random.py",
[
"RandomState"
]
]
],
"_PrettyBlocks": [
[
"dask/array/rechunk.py",
[
"_PrettyBlocks"
]
]
],
"ThreadSafetyError": [
[
"dask/array/tests/test_array_core.py",
[
"ThreadSafetyError"
]
]
],
"NonthreadSafeStore": [
[
"dask/array/tests/test_array_core.py",
[
"NonthreadSafeStore"
]
]
],
"ThreadSafeStore": [
[
"dask/array/tests/test_array_core.py",
[
"ThreadSafeStore"
]
]
],
"CounterLock": [
[
"dask/array/tests/test_array_core.py",
[
"CounterLock"
]
]
],
"ARangeSlice": [
[
"dask/array/tests/test_array_core.py",
[
"test_slicing_with_non_ndarrays",
"ARangeSlice"
]
]
],
"ARangeSlicable": [
[
"dask/array/tests/test_array_core.py",
[
"test_slicing_with_non_ndarrays",
"ARangeSlicable"
]
]
],
"FussyLock": [
[
"dask/array/tests/test_array_core.py",
[
"test_from_array_with_lock",
"FussyLock"
]
]
],
"MyArray": [
[
"dask/array/tests/test_array_core.py",
[
"MyArray"
]
],
[
"dask/array/tests/test_array_core.py",
[
"test_from_array_inline",
"MyArray"
]
]
],
"CustomCollection": [
[
"dask/array/tests/test_array_core.py",
[
"test_from_array_dask_collection_warns",
"CustomCollection"
]
]
],
"EncapsulateNDArray": [
[
"dask/array/tests/test_dispatch.py",
[
"EncapsulateNDArray"
]
]
],
"WrappedArray": [
[
"dask/array/tests/test_dispatch.py",
[
"WrappedArray"
]
]
],
"UnknownScalarThatUnderstandsArrayOps": [
[
"dask/array/tests/test_dispatch.py",
[
"UnknownScalarThatUnderstandsArrayOps"
]
]
],
"UnknownScalar": [
[
"dask/array/tests/test_dispatch.py",
[
"UnknownScalar"
]
]
],
"ReturnItem": [
[
"dask/array/tests/test_slicing.py",
[
"ReturnItem"
]
]
],
"da_frompyfunc": [
[
"dask/array/ufunc.py",
[
"da_frompyfunc"
]
]
],
"ufunc": [
[
"dask/array/ufunc.py",
[
"ufunc"
]
]
],
"DaskBackendEntrypoint": [
[
"dask/backends.py",
[
"DaskBackendEntrypoint"
]
]
],
"CreationDispatch": [
[
"dask/backends.py",
[
"CreationDispatch"
]
]
],
"StringAccessor": [
[
"dask/bag/core.py",
[
"StringAccessor"
]
],
[
"dask/dataframe/accessor.py",
[
"StringAccessor"
]
]
],
"Item": [
[
"dask/bag/core.py",
[
"Item"
]
]
],
"Bag": [
[
"dask/bag/core.py",
[
"Bag"
]
]
],
"_MapChunk": [
[
"dask/bag/core.py",
[
"_MapChunk"
]
]
],
"BagOfDicts": [
[
"dask/bag/tests/test_bag.py",
[
"BagOfDicts"
]
]
],
"StrictReal": [
[
"dask/bag/tests/test_bag.py",
[
"StrictReal"
]
]
],
"C": [
[
"dask/bag/tests/test_bag.py",
[
"test_map_releases_element_references_as_soon_as_possible",
"C"
]
],
[
"dask/tests/test_base.py",
[
"test_persist_delayedattr",
"C"
]
],
[
"dask/tests/test_core.py",
[
"test_ishashable",
"C"
]
],
[
"dask/tests/test_core.py",
[
"test_iskey",
"C"
]
],
[
"dask/tests/test_tokenize.py",
[
"test_normalize_object_unserializable",
"C"
]
],
[
"dask/tests/test_tokenize.py",
[
"nested_tokenize_ensure_deterministic",
"C"
]
],
[
"dask/tests/test_tokenize.py",
[
"test_tokenize_local_classes_from_different_contexts",
"f",
"C"
]
],
[
"dask/tests/test_tokenize.py",
[
"test_tokenize_callable_class",
"C"
]
],
[
"dask/tests/test_tokenize.py",
[
"test_tokenize_callable_class_with_tokenize_method",
"C"
]
],
[
"dask/tests/test_tokenize.py",
[
"test_nested_tokenize_seen",
"C"
]
],
[
"dask/tests/test_tokenize.py",
[
"test_tokenize_dict_doesnt_call_str_on_values",
"C"
]
],
[
"dask/tests/test_tokenize.py",
[
"test_tokenize_opaque_object_with_buffers",
"C"
]
]
],
"DaskMethodsMixin": [
[
"dask/base.py",
[
"DaskMethodsMixin"
]
]
],
"TokenizationError": [
[
"dask/base.py",
[
"TokenizationError"
]
]
],
"BlockwiseDep": [
[
"dask/blockwise.py",
[
"BlockwiseDep"
]
]
],
"BlockwiseDepDict": [
[
"dask/blockwise.py",
[
"BlockwiseDepDict"
]
]
],
"BlockIndex": [
[
"dask/blockwise.py",
[
"BlockIndex"
]
]
],
"Blockwise": [
[
"dask/blockwise.py",
[
"Blockwise"
]
]
],
"CustomFSPath": [
[
"dask/bytes/tests/test_bytes_utils.py",
[
"test_stringify_path",
"CustomFSPath"
]
]
],
"Cache": [
[
"dask/cache.py",
[
"Cache"
]
]
],
"Callback": [
[
"dask/callbacks.py",
[
"Callback"
]
]
],
"add_callbacks": [
[
"dask/callbacks.py",
[
"add_callbacks"
]
]
],
"set": [
[
"dask/config.py",
[
"set"
]
]
],
"GlobalMethod": [
[
"dask/context.py",
[
"GlobalMethod"
]
]
],
"literal": [
[
"dask/core.py",
[
"literal"
]
]
],
"Accessor": [
[
"dask/dataframe/accessor.py",
[
"Accessor"
]
]
],
"DatetimeAccessor": [
[
"dask/dataframe/accessor.py",
[
"DatetimeAccessor"
]
]
],
"CachedAccessor": [
[
"dask/dataframe/accessor.py",
[
"CachedAccessor"
]
]
],
"DataFrameBackendEntrypoint": [
[
"dask/dataframe/backends.py",
[
"DataFrameBackendEntrypoint"
]
]
],
"ShuffleGroupResult": [
[
"dask/dataframe/backends.py",
[
"ShuffleGroupResult"
]
]
],
"PandasBackendEntrypoint": [
[
"dask/dataframe/backends.py",
[
"PandasBackendEntrypoint"
]
]
],
"CategoricalAccessor": [
[
"dask/dataframe/categorical.py",
[
"CategoricalAccessor"
]
]
],
"Scalar": [
[
"dask/dataframe/core.py",
[
"Scalar"
]
]
],
"_Frame": [
[
"dask/dataframe/core.py",
[
"_Frame"
]
]
],
"Series": [
[
"dask/dataframe/core.py",
[
"Series"
]
]
],
"Index": [
[
"dask/dataframe/core.py",
[
"Index"
]
]
],
"DataFrame": [
[
"dask/dataframe/core.py",
[
"DataFrame"
]
]
],
"Aggregation": [
[
"dask/dataframe/groupby.py",
[
"Aggregation"
]
]
],
"_GroupBy": [
[
"dask/dataframe/groupby.py",
[
"_GroupBy"
]
]
],
"DataFrameGroupBy": [
[
"dask/dataframe/groupby.py",
[
"DataFrameGroupBy"
]
]
],
"SeriesGroupBy": [
[
"dask/dataframe/groupby.py",
[
"SeriesGroupBy"
]
]
],
"_IndexerBase": [
[
"dask/dataframe/indexing.py",
[
"_IndexerBase"
]
]
],
"_iLocIndexer": [
[
"dask/dataframe/indexing.py",
[
"_iLocIndexer"
]
]
],
"_LocIndexer": [
[
"dask/dataframe/indexing.py",
[
"_LocIndexer"
]
]
],
"CSVFunctionWrapper": [
[
"dask/dataframe/io/csv.py",
[
"CSVFunctionWrapper"
]
]
],
"ColumnSpec": [
[
"dask/dataframe/io/demo.py",
[
"ColumnSpec"
]
]
],
"RangeIndexSpec": [
[
"dask/dataframe/io/demo.py",
[
"RangeIndexSpec"
]
]
],
"DatetimeIndexSpec": [
[
"dask/dataframe/io/demo.py",
[
"DatetimeIndexSpec"
]
]
],
"DatasetSpec": [
[
"dask/dataframe/io/demo.py",
[
"DatasetSpec"
]
]
],
"MakeDataframePart": [
[
"dask/dataframe/io/demo.py",
[
"MakeDataframePart"
]
]
],
"HDFFunctionWrapper": [
[
"dask/dataframe/io/hdf.py",
[
"HDFFunctionWrapper"
]
]
],
"_PackedArgCallable": [
[
"dask/dataframe/io/io.py",
[
"_PackedArgCallable"
]
]
],
"ArrowORCEngine": [
[
"dask/dataframe/io/orc/arrow.py",
[
"ArrowORCEngine"
]
]
],
"ORCFunctionWrapper": [
[
"dask/dataframe/io/orc/core.py",
[
"ORCFunctionWrapper"
]
]
],
"ORCEngine": [
[
"dask/dataframe/io/orc/utils.py",
[
"ORCEngine"
]
]
],
"PartitionObj": [
[
"dask/dataframe/io/parquet/arrow.py",
[
"PartitionObj"
]
]
],
"ArrowDatasetEngine": [
[
"dask/dataframe/io/parquet/arrow.py",
[
"ArrowDatasetEngine"
]
]
],
"ParquetFunctionWrapper": [
[
"dask/dataframe/io/parquet/core.py",
[
"ParquetFunctionWrapper"
]
]
],
"ToParquetFunctionWrapper": [
[
"dask/dataframe/io/parquet/core.py",
[
"ToParquetFunctionWrapper"
]
]
],
"FastParquetEngine": [
[
"dask/dataframe/io/parquet/fastparquet.py",
[
"FastParquetEngine"
]
]
],
"Engine": [
[
"dask/dataframe/io/parquet/utils.py",
[
"Engine"
]
]
],
"MockOutput": [
[
"dask/dataframe/io/tests/test_csv.py",
[
"test__infer_block_size",
"MockOutput"
]
]
],
"Table1": [
[
"dask/dataframe/io/tests/test_hdf.py",
[
"test_hdf_nonpandas_keys",
"Table1"
]
]
],
"Table2": [
[
"dask/dataframe/io/tests/test_hdf.py",
[
"test_hdf_nonpandas_keys",
"Table2"
]
]
],
"Table3": [
[
"dask/dataframe/io/tests/test_hdf.py",
[
"test_hdf_nonpandas_keys",
"Table3"
]
]
],
"MyFunc": [
[
"dask/dataframe/io/tests/test_io.py",
[
"test_from_map_column_projection",
"MyFunc"
]
]
],
"MyEngine": [
[
"dask/dataframe/io/tests/test_parquet.py",
[
"test_get_engine_third_party",
"MyEngine"
]
]
],
"ArrowEngineWithTimestampClamp": [
[
"dask/dataframe/io/tests/test_parquet.py",
[
"test_pandas_timestamp_overflow_pyarrow",
"ArrowEngineWithTimestampClamp"
]
]
],
"DataFrameIOFunction": [
[
"dask/dataframe/io/utils.py",
[
"DataFrameIOFunction"
]
]
],
"SupportsLock": [
[
"dask/dataframe/io/utils.py",
[
"SupportsLock"
]
]
],
"Rolling": [
[
"dask/dataframe/rolling.py",
[
"Rolling"
]
]
],
"RollingGroupby": [
[
"dask/dataframe/rolling.py",
[
"RollingGroupby"
]
]
],
"maybe_buffered_partd": [
[
"dask/dataframe/shuffle.py",
[
"maybe_buffered_partd"
]
]
],
"MyAccessor": [
[
"dask/dataframe/tests/test_accessors.py",
[
"MyAccessor"
]
]
],
"TestCategoricalAccessor": [
[
"dask/dataframe/tests/test_categorical.py",
[
"TestCategoricalAccessor"
]
]
],
"Foo": [
[
"dask/dataframe/tests/test_dataframe.py",
[
"test_dataframe_doc_from_non_pandas",
"Foo"
]
],
[
"dask/tests/test_context.py",
[
"Foo"
]
],
[
"dask/tests/test_delayed.py",
[
"test_callable_obj",
"Foo"
]
],
[
"dask/tests/test_tokenize.py",
[
"test_tokenize_same_repr",
"Foo"
]
],
[
"dask/tests/test_tokenize.py",
[
"test_tokenize_slotted",
"Foo"
]
],
[
"dask/tests/test_tokenize.py",
[
"test_tokenize_slotted_no_value",
"Foo"
]
],
[
"dask/tests/test_tokenize.py",
[
"test_tokenize_slots_and_dict",
"Foo"
]
],
[
"dask/tests/test_tokenize.py",
[
"test_tokenize_method",
"Foo"
]
],
[
"dask/tests/test_utils.py",
[
"test_funcname",
"Foo"
]
],
[
"dask/tests/test_utils.py",
[
"test_derived_from",
"Foo"
]
]
],
"string_subclass": [
[
"dask/dataframe/tests/test_dataframe.py",
[
"test_getitem_string_subclass",
"string_subclass"
]
]
],
"CustomMetadata": [
[
"dask/dataframe/tests/test_utils_dataframe.py",
[
"test_make_meta",
"CustomMetadata"
]
]
],
"DataFrameWrapper": [
[
"dask/dataframe/tests/test_utils_dataframe.py",
[
"test_is_dataframe_like",
"DataFrameWrapper"
]
]
],
"SeriesWrapper": [
[
"dask/dataframe/tests/test_utils_dataframe.py",
[
"test_is_dataframe_like",
"SeriesWrapper"
]
]
],
"IndexWrapper": [
[
"dask/dataframe/tests/test_utils_dataframe.py",
[
"test_is_dataframe_like",
"IndexWrapper"
]
]
],
"Resampler": [
[
"dask/dataframe/tseries/resample.py",
[
"Resampler"
]
]
],
"AttributeNotImplementedError": [
[
"dask/dataframe/utils.py",
[
"AttributeNotImplementedError"
]
]
],
"Delayed": [
[
"dask/delayed.py",
[
"Delayed"
]
]
],
"DelayedLeaf": [
[
"dask/delayed.py",
[
"DelayedLeaf"
]
]
],
"DelayedAttr": [
[
"dask/delayed.py",
[
"DelayedAttr"
]
]
],
"Profiler": [
[
"dask/diagnostics/profile.py",
[
"Profiler"
]
]
],
"ResourceProfiler": [
[
"dask/diagnostics/profile.py",
[
"ResourceProfiler"
]
]
],
"_Tracker": [
[
"dask/diagnostics/profile.py",
[
"_Tracker"
]
]
],
"CacheProfiler": [
[
"dask/diagnostics/profile.py",
[
"CacheProfiler"
]
]
],
"ProgressBar": [
[
"dask/diagnostics/progress.py",
[
"ProgressBar"
]
]
],
"chunks": [
[
"dask/graph_manipulation.py",
[
"chunks"
]
]
],
"Layer": [
[
"dask/highlevelgraph.py",
[
"Layer"
]
]
],
"MaterializedLayer": [
[
"dask/highlevelgraph.py",
[
"MaterializedLayer"
]
]
],
"HighLevelGraph": [
[
"dask/highlevelgraph.py",
[
"HighLevelGraph"
]
]
],
"CallableLazyImport": [
[
"dask/layers.py",
[
"CallableLazyImport"
]
]
],
"ArrayBlockwiseDep": [
[
"dask/layers.py",
[
"ArrayBlockwiseDep"
]
]
],
"ArrayChunkShapeDep": [
[
"dask/layers.py",
[
"ArrayChunkShapeDep"
]
]
],
"ArraySliceDep": [
[
"dask/layers.py",
[
"ArraySliceDep"
]
]
],
"ArrayOverlapLayer": [
[
"dask/layers.py",
[
"ArrayOverlapLayer"
]
]
],
"SimpleShuffleLayer": [
[
"dask/layers.py",
[
"SimpleShuffleLayer"
]
]
],
"ShuffleLayer": [
[
"dask/layers.py",
[
"ShuffleLayer"
]
]
],
"BroadcastJoinLayer": [
[
"dask/layers.py",
[
"BroadcastJoinLayer"
]
]
],
"DataFrameIOLayer": [
[
"dask/layers.py",
[
"DataFrameIOLayer"
]
]
],
"DataFrameTreeReduction": [
[
"dask/layers.py",
[
"DataFrameTreeReduction"
]
]
],
"SynchronousExecutor": [
[
"dask/local.py",
[
"SynchronousExecutor"
]
]
],
"MultiprocessingPoolExecutor": [
[
"dask/local.py",
[
"MultiprocessingPoolExecutor"
]
]
],
"RemoteException": [
[
"dask/multiprocessing.py",
[
"RemoteException"
]
]
],
"Default": [
[
"dask/optimization.py",
[
"Default"
]
]
],
"SubgraphCallable": [
[
"dask/optimization.py",
[
"SubgraphCallable"
]
]
],
"Order": [
[
"dask/order.py",
[
"Order"
]
]
],
"Traverser": [
[
"dask/rewrite.py",
[
"Traverser"
]
]
],
"Token": [
[
"dask/rewrite.py",
[
"Token"
]
]
],
"Node": [
[
"dask/rewrite.py",
[
"Node"
]
]
],
"RewriteRule": [
[
"dask/rewrite.py",
[
"RewriteRule"
]
]
],
"RuleSet": [
[
"dask/rewrite.py",
[
"RuleSet"
]
]
],
"SimpleSizeof": [
[
"dask/sizeof.py",
[
"SimpleSizeof"
]
]
],
"DummyCollection": [
[
"dask/tests/test_base.py",
[
"test_is_dask_collection",
"DummyCollection"
]
],
[
"dask/tests/test_base.py",
[
"test_get_collection_names",
"DummyCollection"
]
]
],
"DoNotMaterialize": [
[
"dask/tests/test_base.py",
[
"test_is_dask_collection_dask_expr_does_not_materialize",
"DoNotMaterialize"
]
]
],
"ADataClass": [
[
"dask/tests/test_base.py",
[
"test_unpack_collections",
"ADataClass"
]
],
[
"dask/tests/test_delayed.py",
[
"test_delayed_with_dataclass_with_custom_init",
"ADataClass"
]
],
[
"dask/tests/test_delayed.py",
[
"test_delayed_with_dataclass_with_eager_custom_init",
"ADataClass"
]
],
[
"dask/tests/test_delayed.py",
[
"test_delayed_with_eager_dataclass_with_set_init_false_field",
"ADataClass"
]
],
[
"dask/tests/test_delayed.py",
[
"test_delayed_with_dataclass_with_set_init_false_field",
"ADataClass"
]
],
[
"dask/tests/test_delayed.py",
[
"test_delayed_with_dataclass_with_unset_init_false_field",
"ADataClass"
]
],
[
"dask/tests/test_tokenize.py",
[
"ADataClass"
]
]
],
"ANamedTuple": [
[
"dask/tests/test_base.py",
[
"test_unpack_collections",
"ANamedTuple"
]
],
[
"dask/tests/test_delayed.py",
[
"test_delayed_with_namedtuple",
"ANamedTuple"
]
]
],
"Tuple": [
[
"dask/tests/test_base.py",
[
"Tuple"
]
],
[
"dask/tests/test_delayed.py",
[
"Tuple"
]
]
],
"MyExecutor": [
[
"dask/tests/test_base.py",
[
"MyExecutor"
]
]
],
"MyDaskArray": [
[
"dask/tests/test_base.py",
[
"test_compute_as_if_collection_low_level_task_graph",
"MyDaskArray"
]
]
],
"MyCallback": [
[
"dask/tests/test_callbacks.py",
[
"test_start_callback",
"MyCallback"
]
],
[
"dask/tests/test_callbacks.py",
[
"test_start_state_callback",
"MyCallback"
]
],
[
"dask/tests/test_callbacks.py",
[
"test_finish_always_called",
"MyCallback"
]
],
[
"dask/tests/test_callbacks.py",
[
"test_nested_schedulers",
"MyCallback"
]
]
],
"ErrorEP": [
[
"dask/tests/test_cli.py",
[
"test_register_command_ep",
"ErrorEP"
]
]
],
"TestGet": [
[
"dask/tests/test_core.py",
[
"TestGet"
]
]
],
"TestCustomGetFail": [
[
"dask/tests/test_core.py",
[
"test_GetFunctionTestMixin_class",
"TestCustomGetFail"
]
]
],
"TestCustomGetPass": [
[
"dask/tests/test_core.py",
[
"test_GetFunctionTestMixin_class",
"TestCustomGetPass"
]
]
],
"MutateOnEq": [
[
"dask/tests/test_core.py",
[
"MutateOnEq"
]
]
],
"MyException": [
[
"dask/tests/test_core.py",
[
"test_subs_with_unfriendly_eq",
"MyException"
]
],
[
"dask/tests/test_local.py",
[
"test_exceptions_propagate",
"MyException"
]
]
],
"F": [
[
"dask/tests/test_core.py",
[
"test_subs_with_unfriendly_eq",
"F"
]
]
],
"MyClass": [
[
"dask/tests/test_delayed.py",
[
"test_to_task_dask",
"MyClass"
]
]
],
"ANonFrozenDataClass": [
[
"dask/tests/test_delayed.py",
[
"ANonFrozenDataClass"
]
]
],
"AFrozenDataClass": [
[
"dask/tests/test_delayed.py",
[
"AFrozenDataClass"
]
]
],
"dummy": [
[
"dask/tests/test_delayed.py",
[
"test_operators",
"dummy"
]
]
],
"A": [
[
"dask/tests/test_delayed.py",
[
"test_delayed_decorator_on_method",
"A"
]
],
[
"dask/tests/test_tokenize.py",
[
"test_check_tokenize",
"A"
]
]
],
"UpdateGraphCounter": [
[
"dask/tests/test_distributed.py",
[
"test_default_scheduler_on_worker",
"UpdateGraphCounter"
]
]
],
"EnsureSplitsRunImmediatelyPlugin": [
[
"dask/tests/test_distributed.py",
[
"test_shuffle_priority",
"EnsureSplitsRunImmediatelyPlugin"
]
]
],
"SomeObject": [
[
"dask/tests/test_distributed.py",
[
"test_non_recursive_df_reduce",
"SomeObject"
]
]
],
"NodeCounter": [
[
"dask/tests/test_graph_manipulation.py",
[
"NodeCounter"
]
]
],
"Unhashable": [
[
"dask/tests/test_highgraph.py",
[
"test_getitem",
"Unhashable"
]
]
],
"SchedulerImportCheck": [
[
"dask/tests/test_layers.py",
[
"SchedulerImportCheck"
]
]
],
"TestGetAsync": [
[
"dask/tests/test_local.py",
[
"TestGetAsync"
]
]
],
"NotUnpickleable": [
[
"dask/tests/test_multiprocessing.py",
[
"NotUnpickleable"
]
]
],
"NoIndex": [
[
"dask/tests/test_multiprocessing.py",
[
"test_works_with_highlevel_graph",
"NoIndex"
]
]
],
"global_": [
[
"dask/tests/test_multiprocessing.py",
[
"global_"
]
]
],
"NonHashableCallable": [
[
"dask/tests/test_optimization.py",
[
"test_inline_functions_non_hashable",
"NonHashableCallable"
]
]
],
"MyProcess": [
[
"dask/tests/test_system.py",
[
"test_cpu_count_cgroups",
"MyProcess"
]
],
[
"dask/tests/test_system.py",
[
"test_cpu_count_cgroups_v2",
"MyProcess"
]
]
],
"B": [
[
"dask/tests/test_tokenize.py",
[
"test_check_tokenize",
"B"
]
]
],
"NeedsCloudPickle": [
[
"dask/tests/test_tokenize.py",
[
"test_tokenize_numpy_array_on_object_dtype",
"NeedsCloudPickle"
]
],
[
"dask/tests/test_tokenize.py",
[
"test_tokenize_pandas_cloudpickle",
"NeedsCloudPickle"
]
]
],
"WithClassMethod": [
[
"dask/tests/test_tokenize.py",
[
"WithClassMethod"
]
]
],
"Bar": [
[
"dask/tests/test_tokenize.py",
[
"test_tokenize_slots_and_dict",
"Bar"
]
],
[
"dask/tests/test_utils.py",
[
"test_dispatch",
"Bar"
]
],
[
"dask/tests/test_utils.py",
[
"test_derived_from",
"Bar"
]
]
],
"D": [
[
"dask/tests/test_tokenize.py",
[
"test_tokenize_callable_class",
"D"
]
]
],
"HasStaticMethods": [
[
"dask/tests/test_tokenize.py",
[
"HasStaticMethods"
]
]
],
"HasStaticMethods2": [
[
"dask/tests/test_tokenize.py",
[
"HasStaticMethods2"
]
]
],
"Color": [
[
"dask/tests/test_tokenize.py",
[
"test_tokenize_enum",
"Color"
]
]
],
"BDataClass": [
[
"dask/tests/test_tokenize.py",
[
"BDataClass"
]
]
],
"NoValueDataClass": [
[
"dask/tests/test_tokenize.py",
[
"NoValueDataClass"
]
]
],
"GlobalClass": [
[
"dask/tests/test_tokenize.py",
[
"GlobalClass"
]
]
],
"LocalType": [
[
"dask/tests/test_tokenize.py",
[
"test_local_objects",
"LocalType"
]
]
],
"LocalReducible": [
[
"dask/tests/test_tokenize.py",
[
"test_local_objects",
"LocalReducible"
]
]
],
"LocalDaskTokenize": [
[
"dask/tests/test_tokenize.py",
[
"test_local_objects",
"LocalDaskTokenize"
]
]
],
"LocalChild": [
[
"dask/tests/test_tokenize.py",
[
"test_local_objects",
"LocalChild"
]
]
],
"SubA": [
[
"dask/tests/test_tokenize.py",
[
"test_tokenize_dataclass",
"SubA"
]
]
],
"NumbaDummy": [
[
"dask/tests/test_tokenize.py",
[
"if_not_numba_",
"NumbaDummy"
]
]
],
"Inheriting": [
[
"dask/tests/test_typing.py",
[
"Inheriting"
]
]
],
"HLGCollection": [
[
"dask/tests/test_typing.py",
[
"HLGCollection"
]
]
],
"NotHLGCollection": [
[
"dask/tests/test_typing.py",
[
"NotHLGCollection"
]
]
],
"MyType": [
[
"dask/tests/test_utils.py",
[
"test_getargspec",
"MyType"
]
],
[
"dask/tests/test_utils.py",
[
"MyType"
]
]
],
"Singular": [
[
"dask/tests/test_utils.py",
[
"test_takes_multiple_arguments",
"Singular"
]
]
],
"Multi": [
[
"dask/tests/test_utils.py",
[
"test_takes_multiple_arguments",
"Multi"
]
]
],
"Lazy": [
[
"dask/tests/test_utils.py",
[
"test_dispatch_lazy_walks_mro",
"Lazy"
]
]
],
"Eager": [
[
"dask/tests/test_utils.py",
[
"test_dispatch_lazy_walks_mro",
"Eager"
]
]
],
"mydict": [
[
"dask/tests/test_utils.py",
[
"test_ensure_dict",
"mydict"
]
]
],
"myset": [
[
"dask/tests/test_utils.py",
[
"test_ensure_set",
"myset"
]
]
],
"Zap": [
[
"dask/tests/test_utils.py",
[
"test_derived_from",
"Zap"
]
]
],
"Base": [
[
"dask/tests/test_utils.py",
[
"test_derived_from_prop_cached_prop",
"Base"
]
]
],
"Derived": [
[
"dask/tests/test_utils.py",
[
"test_derived_from_prop_cached_prop",
"Derived"
]
]
],
"MyWarning": [
[
"dask/tests/test_utils_test.py",
[
"test__check_warning",
"MyWarning"
]
]
],
"_RemovedIn20Warning": [
[
"dask/tests/warning_aliases.py",
[
"try_",
"except_ImportError_",
"_RemovedIn20Warning"
]
]
],
"SchedulerGetCallable": [
[
"dask/typing.py",
[
"SchedulerGetCallable"
]
]
],
"PostPersistCallable": [
[
"dask/typing.py",
[
"PostPersistCallable"
]
]
],
"DaskCollection": [
[
"dask/typing.py",
[
"DaskCollection"
]
]
],
"HLGDaskCollection": [
[
"dask/typing.py",
[
"HLGDaskCollection"
]
]
],
"_NoDefault": [
[
"dask/typing.py",
[
"_NoDefault"
]
]
],
"IndexCallable": [
[
"dask/utils.py",
[
"IndexCallable"
]
]
],
"Dispatch": [
[
"dask/utils.py",
[
"Dispatch"
]
]
],
"methodcaller": [
[
"dask/utils.py",
[
"methodcaller"
]
]
],
"itemgetter": [
[
"dask/utils.py",
[
"itemgetter"
]
]
],
"MethodCache": [
[
"dask/utils.py",
[
"MethodCache"
]
]
],
"SerializableLock": [
[
"dask/utils.py",
[
"SerializableLock"
]
]
],
"OperatorMethodMixin": [
[
"dask/utils.py",
[
"OperatorMethodMixin"
]
]
],
"cached_property": [
[
"dask/utils.py",
[
"cached_property"
]
]
],
"_HashIdWrapper": [
[
"dask/utils.py",
[
"_HashIdWrapper"
]
]
],
"shorten_traceback": [
[
"dask/utils.py",
[
"shorten_traceback"
]
]
],
"GetFunctionTestMixin": [
[
"dask/utils_test.py",
[
"GetFunctionTestMixin"
]
]
]
}