From 98ae55b059aee87365656b305b8c61e992fa2700 Mon Sep 17 00:00:00 2001 From: doctorpangloss <2229300+doctorpangloss@users.noreply.github.com> Date: Tue, 4 Nov 2025 17:40:19 -0800 Subject: [PATCH] Improvements to compatibility with custom nodes, distributed backends and other changes - remove uv.lock since it will not be used in most cases for installation - add cli args to prevent some custom nodes from installing packages at runtime - temp directories can now be shared between workers without being deleted - propcache yanked is now in the dependencies - fix configuration arguments loading in some tests --- comfy/app/logger.py | 9 +- comfy/cli_args.py | 6 + comfy/cli_args_types.py | 4 + comfy/cmd/execution.py | 28 +- comfy/cmd/main.py | 20 +- comfy/component_model/file_counter.py | 90 + comfy/entrypoints/worker.py | 25 +- comfy/nodes/vanilla_node_importing.py | 24 +- comfy/nodes_context.py | 30 - comfy_compatibility/vanilla.py | 198 +- pyproject.toml | 6 +- tests/conftest.py | 10 +- tests/distributed/test_counter.py | 288 + tests/execution/test_progress_isolation.py | 5 +- tests/inference/test_workflows.py | 10 + uv.lock | 7098 -------------------- 16 files changed, 678 insertions(+), 7173 deletions(-) create mode 100644 comfy/component_model/file_counter.py create mode 100644 tests/distributed/test_counter.py delete mode 100644 uv.lock diff --git a/comfy/app/logger.py b/comfy/app/logger.py index 940ee7f6e..76d921cd1 100644 --- a/comfy/app/logger.py +++ b/comfy/app/logger.py @@ -31,10 +31,12 @@ class LogInterceptor(io.TextIOWrapper): if isinstance(data, str) and data.startswith("\r") and len(logs) > 0 and not logs[-1]["m"].endswith("\n"): logs.pop() logs.append(entry) - super().write(data) + if not self.closed: + super().write(data) def flush(self): - super().flush() + if not self.closed: + super().flush() for cb in self._flush_callbacks: cb(self._logs_since_flush) self._logs_since_flush = [] @@ -56,7 +58,8 @@ def on_flush(callback): class StackTraceLogger(logging.Logger): def _log(self, level, msg, args, exc_info=None, extra=None, stack_info=False, stacklevel=1): - if level >= logging.ERROR: + if not stack_info and level >= logging.ERROR and exc_info is None: + # create a stack even when there is no exception stack_info = True super()._log(level, msg, args, exc_info, extra, stack_info, stacklevel=stacklevel + 1) diff --git a/comfy/cli_args.py b/comfy/cli_args.py index a0b0245ce..fe964ba45 100644 --- a/comfy/cli_args.py +++ b/comfy/cli_args.py @@ -273,6 +273,12 @@ def _create_parser() -> EnhancedConfigArgParser: help="Set the base URL for the ComfyUI API. (default: https://api.comfy.org)", ) + parser.add_argument( + "--block-runtime-package-installation", + action="store_true", + help="When set, custom nodes like ComfyUI Manager, Easy Use, Nunchaku and others will not be able to use pip or uv to install packages at runtime (experimental)." + ) + default_db_url = db_config() parser.add_argument("--database-url", type=str, default=default_db_url, help="Specify the database URL, e.g. for an in-memory database you can use 'sqlite:///:memory:'.") parser.add_argument("--workflows", type=str, action=FlattenAndAppendAction, nargs='+', default=[], help="Execute the API workflow(s) specified in the provided files. For each workflow, its outputs will be printed to a line to standard out. Application logging will be redirected to standard error. Use `-` to signify standard in.") diff --git a/comfy/cli_args_types.py b/comfy/cli_args_types.py index b46baef68..953747f95 100644 --- a/comfy/cli_args_types.py +++ b/comfy/cli_args_types.py @@ -168,6 +168,7 @@ class Configuration(dict): blacklist_custom_nodes (list[str]): Specify custom node folders to never load. Accepts shell-style globs. whitelist_custom_nodes (list[str]): Specify custom node folders to load even when --disable-all-custom-nodes is enabled. default_device (Optional[int]): Set the id of the default device, all other devices will stay visible. + block_runtime_package_installation (Optional[bool]): When set, custom nodes like ComfyUI Manager, Easy Use, Nunchaku and others will not be able to use pip or uv to install packages at runtime (experimental). """ def __init__(self, **kwargs): @@ -286,6 +287,7 @@ class Configuration(dict): self.comfy_api_base: str = "https://api.comfy.org" self.database_url: str = db_config() self.default_device: Optional[int] = None + self.block_runtime_package_installation = None for key, value in kwargs.items(): self[key] = value @@ -315,6 +317,8 @@ class Configuration(dict): super().update(__m, **kwargs) for k, v in changes.items(): self._notify_observers(k, v) + # make this more pythonic + return self def register_observer(self, observer: ConfigObserver): self._observers.append(observer) diff --git a/comfy/cmd/execution.py b/comfy/cmd/execution.py index 3cfe73407..8095d53be 100644 --- a/comfy/cmd/execution.py +++ b/comfy/cmd/execution.py @@ -19,19 +19,23 @@ from typing import List, Optional, Tuple, Literal # order matters from .main_pre import tracer import torch -from frozendict import frozendict -from comfy_execution.graph_types import FrozenTopologicalSort, Input from opentelemetry.trace import get_current_span, StatusCode, Status +from comfy_api.internal import _ComfyNodeInternal, _NodeOutputInternal, first_real_override, is_class, \ + make_locked_method_func +from comfy_api.latest import io +from comfy_compatibility.vanilla import vanilla_environment_node_execution_hooks from comfy_execution.caching import HierarchicalCache, LRUCache, CacheKeySetInputSignature, CacheKeySetID, \ DependencyAwareCache, \ BasicCache from comfy_execution.graph import get_input_info, ExecutionList, DynamicPrompt, ExecutionBlocker +from comfy_execution.graph_types import FrozenTopologicalSort from comfy_execution.graph_utils import is_link, GraphBuilder +from comfy_execution.progress import get_progress_state, reset_progress_state, add_progress_handler, \ + WebUIProgressHandler, \ + ProgressRegistry from comfy_execution.utils import CurrentNodeContext -from comfy_api.internal import _ComfyNodeInternal, _NodeOutputInternal, first_real_override, is_class, make_locked_method_func -from comfy_api.latest import io -from ..execution_context import current_execution_context, context_set_execution_list_and_inputs +from comfy_execution.validation import validate_node_input from .. import interruption from .. import model_management from ..component_model.abstract_prompt_queue import AbstractPromptQueue @@ -44,13 +48,11 @@ from ..component_model.module_property import create_module_properties from ..component_model.queue_types import QueueTuple, HistoryEntry, QueueItem, MAXIMUM_HISTORY_SIZE, ExecutionStatus, \ ExecutionStatusAsDict from ..execution_context import context_execute_node, context_execute_prompt +from ..execution_context import current_execution_context, context_set_execution_list_and_inputs from ..execution_ext import should_panic_on_exception from ..node_requests_caching import use_requests_caching from ..nodes.package_typing import InputTypeSpec, FloatSpecOptions, IntSpecOptions, CustomNode -from ..nodes_context import get_nodes, vanilla_node_execution_environment -from comfy_execution.progress import get_progress_state, reset_progress_state, add_progress_handler, WebUIProgressHandler, \ - ProgressRegistry -from comfy_execution.validation import validate_node_input +from ..nodes_context import get_nodes _module_properties = create_module_properties() logger = logging.getLogger(__name__) @@ -474,9 +476,11 @@ async def execute(server: ExecutorToClientProgress, dynprompt: DynamicPrompt, ca :param pending_subgraph_results: :return: """ - with (context_execute_node(node_id), - vanilla_node_execution_environment(), - use_requests_caching()): + with ( + context_execute_node(node_id), + vanilla_environment_node_execution_hooks(), + use_requests_caching(), + ): return await _execute(server, dynprompt, caches, node_id, extra_data, executed, prompt_id, execution_list, pending_subgraph_results, pending_async_nodes) diff --git a/comfy/cmd/main.py b/comfy/cmd/main.py index 731c87136..182fa2107 100644 --- a/comfy/cmd/main.py +++ b/comfy/cmd/main.py @@ -1,7 +1,7 @@ import asyncio import contextvars import gc -import itertools + import logging import os import shutil @@ -11,8 +11,10 @@ from pathlib import Path from typing import Optional # main_pre must be the earliest import -from .main_pre import args - +from .main_pre import tracer +from ..cli_args_types import Configuration +from ..component_model.file_counter import cleanup_temp as fc_cleanup_temp +from ..execution_context import current_execution_context from . import hook_breaker_ac10a0 from .extra_model_paths import load_extra_path_config from .. import model_management @@ -51,6 +53,7 @@ async def _prompt_worker(q: AbstractPromptQueue, server_instance: server_module. from ..cmd import execution from ..component_model import queue_types from .. import model_management + args = current_execution_context().configuration cache_type = execution.CacheType.CLASSIC if args.cache_lru > 0: cache_type = execution.CacheType.LRU @@ -147,10 +150,14 @@ def setup_database(): init_db() -async def _start_comfyui(from_script_dir: Optional[Path] = None): +async def _start_comfyui(from_script_dir: Optional[Path] = None, configuration: Optional[Configuration] = None): from ..execution_context import context_configuration from ..cli_args import cli_args_configuration - with context_configuration(cli_args_configuration()): + configuration = configuration or cli_args_configuration() + with ( + context_configuration(configuration), + fc_cleanup_temp() + ): await __start_comfyui(from_script_dir=from_script_dir) @@ -159,6 +166,7 @@ async def __start_comfyui(from_script_dir: Optional[Path] = None): Runs ComfyUI's frontend and backend like upstream. :param from_script_dir: when set to a path, assumes that you are running ComfyUI's legacy main.py entrypoint at the root of the git repository located at the path """ + args = current_execution_context().configuration if not from_script_dir: os_getcwd = os.getcwd() else: @@ -168,7 +176,6 @@ async def __start_comfyui(from_script_dir: Optional[Path] = None): temp_dir = os.path.join(os.path.abspath(args.temp_directory), "temp") logger.debug(f"Setting temp directory to: {temp_dir}") folder_paths.set_temp_directory(temp_dir) - cleanup_temp() if args.user_directory: user_dir = os.path.abspath(args.user_directory) @@ -305,7 +312,6 @@ async def __start_comfyui(from_script_dir: Optional[Path] = None): finally: if distributed: await q.close() - cleanup_temp() def entrypoint(): diff --git a/comfy/component_model/file_counter.py b/comfy/component_model/file_counter.py new file mode 100644 index 000000000..9b0f40c14 --- /dev/null +++ b/comfy/component_model/file_counter.py @@ -0,0 +1,90 @@ +import shutil +from contextlib import contextmanager +from pathlib import Path + +import filelock + + +class ContextWrapper: + """A wrapper to hold context manager values for entry and exit.""" + + def __init__(self, value): + self.value = value + self.ctr = None + + def __int__(self): + return self.value + + +class FileCounter: + def __init__(self, path): + self.path = Path(path) + + async def __aenter__(self): + wrapper = ContextWrapper(self.get_and_increment()) + self._context_wrapper = wrapper + return wrapper + + async def __aexit__(self, exc_type, exc_val, exc_tb): + self._context_wrapper.ctr = self.decrement_and_get() + + def __enter__(self): + """Increment on entering the context and return a wrapper.""" + wrapper = ContextWrapper(self.get_and_increment()) + self._context_wrapper = wrapper + return wrapper + + def __exit__(self, exc_type, exc_val, exc_tb): + """Decrement on exiting the context and update the wrapper.""" + self._context_wrapper.ctr = self.decrement_and_get() + + def _read_and_write(self, operation): + lock = filelock.FileLock(f"{self.path}.lock") + with lock: + count = 0 + try: + with open(self.path, 'r') as f: + content = f.read().strip() + if content: + count = int(content) + except FileNotFoundError: + # File doesn't exist, will be created with initial value. + pass + except ValueError: + # File is corrupt or empty, treat as 0 and overwrite. + pass + + original_count = count + new_count = operation(count) + + self.path.parent.mkdir(parents=True, exist_ok=True) + with open(self.path, 'w') as f: + f.write(str(new_count)) + + return original_count, new_count + + def get_and_increment(self): + """Atomically reads the current value, increments it, and returns the original value.""" + original_count, _ = self._read_and_write(lambda x: x + 1) + return original_count + + def decrement_and_get(self): + """Atomically decrements the value and returns the new value.""" + _, new_count = self._read_and_write(lambda x: x - 1) + return new_count + + +@contextmanager +def cleanup_temp(): + from ..cli_args import args + from ..cmd import folder_paths + tmp_dir = Path(args.temp_directory or folder_paths.get_temp_directory()) + counter_path = tmp_dir / "counter.txt" + fc_i = -1 + try: + with FileCounter(counter_path) as fc: + yield + fc_i = fc.ctr + finally: + if fc_i == 0 and tmp_dir.is_dir(): + shutil.rmtree(tmp_dir, ignore_errors=True) diff --git a/comfy/entrypoints/worker.py b/comfy/entrypoints/worker.py index a0bfc0653..267c558a5 100644 --- a/comfy/entrypoints/worker.py +++ b/comfy/entrypoints/worker.py @@ -1,6 +1,7 @@ import asyncio from ..cmd.main_pre import args +from ..component_model.file_counter import cleanup_temp from ..component_model.entrypoints_common import configure_application_paths, executor_from_args @@ -10,19 +11,27 @@ async def main(): args.distributed_queue_worker = True args.distributed_queue_frontend = False + + # in workers, there is a different default + if args.block_runtime_package_installation is None: + args.block_runtime_package_installation = True + assert args.distributed_queue_connection_uri is not None, "Set the --distributed-queue-connection-uri argument to your RabbitMQ server" configure_application_paths(args) executor = await executor_from_args(args) - async with DistributedPromptWorker(connection_uri=args.distributed_queue_connection_uri, - queue_name=args.distributed_queue_name, - executor=executor): - stop = asyncio.Event() - try: - await stop.wait() - except asyncio.CancelledError: - pass + async with ( + DistributedPromptWorker(connection_uri=args.distributed_queue_connection_uri, + queue_name=args.distributed_queue_name, + executor=executor), + ): + with cleanup_temp(): + stop = asyncio.Event() + try: + await stop.wait() + except (asyncio.CancelledError, InterruptedError, KeyboardInterrupt): + pass def entrypoint(): diff --git a/comfy/nodes/vanilla_node_importing.py b/comfy/nodes/vanilla_node_importing.py index 3ccb5ad9a..76d8823d8 100644 --- a/comfy/nodes/vanilla_node_importing.py +++ b/comfy/nodes/vanilla_node_importing.py @@ -8,18 +8,19 @@ import os import sys import time import types -from contextlib import contextmanager +from contextlib import contextmanager, nullcontext from os.path import join, basename, dirname, isdir, isfile, exists, abspath, split, splitext, realpath from typing import Iterable, Any, Generator -from unittest.mock import patch +from unittest.mock import patch, MagicMock -from comfy_compatibility.vanilla import prepare_vanilla_environment +from comfy_compatibility.vanilla import prepare_vanilla_environment, patch_pip_install_subprocess_run, patch_pip_install_popen from . import base_nodes from .comfyui_v3_package_imports import _comfy_entrypoint_upstream_v3_imports from .package_typing import ExportedNodes from ..cmd import folder_paths from ..component_model.plugins import prompt_server_instance_routes from ..distributed.server_stub import ServerStub +from ..execution_context import current_execution_context logger = logging.getLogger(__name__) @@ -44,6 +45,10 @@ class StreamToLogger: # The logger handles its own flushing, so this can be a no-op. pass + @property + def encoding(self): + return "utf-8" + class _PromptServerStub(ServerStub): def __init__(self): @@ -140,6 +145,7 @@ def _exec_mitigations(module: types.ModuleType, module_path: str) -> Generator[E "comfyui-manager", "comfyui_ryanonyheinside", "comfyui-easy-use", + "comfyui_custom_nodes_alekpet", ): from ..cmd import folder_paths old_file = folder_paths.__file__ @@ -147,9 +153,15 @@ def _exec_mitigations(module: types.ModuleType, module_path: str) -> Generator[E try: # mitigate path new_path = join(abspath(join(dirname(old_file), "..", "..")), basename(old_file)) + config = current_execution_context() - with patch.object(folder_paths, "__file__", new_path), \ - patch.object(sys.modules['nodes'], "EXTENSION_WEB_DIRS", {}, create=True): # mitigate JS copy + block_installation = config and config.configuration and config.configuration.block_runtime_package_installation + with ( + patch.object(folder_paths, "__file__", new_path), + # mitigate packages installing things dynamically + patch_pip_install_subprocess_run() if block_installation else nullcontext(), + patch_pip_install_popen() if block_installation else nullcontext(), + ): yield ExportedNodes() finally: # todo: mitigate "/manager/reboot" @@ -263,6 +275,8 @@ def mitigated_import_of_vanilla_custom_nodes() -> ExportedNodes: # this mitigation puts files that custom nodes expects are at the root of the repository back where they should be # found. we're in the middle of executing the import of execution and server, in all likelihood, so like all things, # the way community custom nodes is pretty radioactive + # there's a lot of subtle details here, and unfortunately, once this is called, there are some things that have + # to be activated later, in different places, to make all the hacks necessary for custom nodes to work prepare_vanilla_environment() from ..cmd import folder_paths diff --git a/comfy/nodes_context.py b/comfy/nodes_context.py index 3f01a39ec..800f9fb2d 100644 --- a/comfy/nodes_context.py +++ b/comfy/nodes_context.py @@ -1,9 +1,5 @@ # todo: this should be defined in a common place, the fact that the nodes are imported by execution the way that they are is pretty radioactive -import collections.abc -import sys import threading -from contextlib import contextmanager -from unittest.mock import patch import lazy_object_proxy @@ -28,29 +24,3 @@ def get_nodes() -> ExportedNodes: if len(current_ctx.custom_nodes) == 0: return nodes return exported_nodes_view(nodes, current_ctx.custom_nodes) - - -class _NodeClassMappingsShim(collections.abc.Mapping): - def __iter__(self): - for key in get_nodes().NODE_CLASS_MAPPINGS: - yield key - - def __getitem__(self, item): - return get_nodes().NODE_CLASS_MAPPINGS[item] - - def __len__(self): - return len(get_nodes().NODE_CLASS_MAPPINGS) - - # todo: does this need to be mutable? - - -@contextmanager -def vanilla_node_execution_environment(): - # check if we're running with patched nodes - if 'nodes' in sys.modules: - # this ensures NODE_CLASS_MAPPINGS is loaded lazily and contains all the nodes loaded so far, not just the base nodes - # easy-use and other nodes expect NODE_CLASS_MAPPINGS to contain all the nodes in the environment - with patch('nodes.NODE_CLASS_MAPPINGS', _NodeClassMappingsShim()): - yield - else: - yield diff --git a/comfy_compatibility/vanilla.py b/comfy_compatibility/vanilla.py index 8e21a294d..fa92ca718 100644 --- a/comfy_compatibility/vanilla.py +++ b/comfy_compatibility/vanilla.py @@ -1,16 +1,103 @@ from __future__ import annotations +import collections.abc import contextvars import logging +import subprocess import sys import types +from contextlib import contextmanager, nullcontext from functools import partial +from importlib.util import find_spec +from pathlib import Path +from threading import RLock from typing import Dict +import wrapt + logger = logging.getLogger(__name__) + +# there isn't a way to do this per-thread, it's only per process, so the global is valid +# we don't want some kind of multiprocessing lock, because this is munging the sys.modules +# wrapt.synchronized will be used to synchronize this _in_environment = False +class _NodeClassMappingsShim(collections.abc.Mapping): + def __init__(self): + super().__init__() + self._active = 0 + self._active_lock = RLock() + + def activate(self): + with self._active_lock: + self._active += 1 + + def deactivate(self): + with self._active_lock: + self._active -= 1 + + def __iter__(self): + if self._active > 0: + from comfy.nodes_context import get_nodes + for key in get_nodes().NODE_CLASS_MAPPINGS: + yield key + else: + from comfy.nodes.base_nodes import NODE_CLASS_MAPPINGS + for key in NODE_CLASS_MAPPINGS: + yield key + + def __getitem__(self, item): + if self._active > 0: + from comfy.nodes_context import get_nodes + return get_nodes().NODE_CLASS_MAPPINGS[item] + else: + from comfy.nodes.base_nodes import NODE_CLASS_MAPPINGS + return NODE_CLASS_MAPPINGS[item] + + def __len__(self): + if self._active > 0: + from comfy.nodes_context import get_nodes + return len(get_nodes().NODE_CLASS_MAPPINGS) + else: + from comfy.nodes.base_nodes import NODE_CLASS_MAPPINGS + return len(NODE_CLASS_MAPPINGS) + + # todo: does this need to be mutable? + + +class _NodeShim: + def __init__(self): + self.__name__ = 'nodes' + self.__package__ = '' + + nodes_file = None + try: + # the 'nodes' module is expected to be in the directory above 'comfy' + spec = find_spec('comfy') + if spec and spec.origin: + comfy_package_path = Path(spec.origin).parent + nodes_module_dir = comfy_package_path.parent + nodes_file = str(nodes_module_dir / 'nodes.py') + except (ImportError, AttributeError): + # don't do anything exotic + pass + + self.__file__ = nodes_file + self.__loader__ = None + self.__spec__ = None + + def __node_class_mappings(self) -> _NodeClassMappingsShim: + return getattr(self, "NODE_CLASS_MAPPINGS") + + def activate(self): + self.__node_class_mappings().activate() + + def deactivate(self): + self.__node_class_mappings().deactivate() + + +@wrapt.synchronized def prepare_vanilla_environment(): global _in_environment if _in_environment: @@ -38,7 +125,22 @@ def prepare_vanilla_environment(): for module in (cuda_malloc, folder_paths, latent_preview, node_helpers, protocol): module_short_name = module.__name__.split(".")[-1] sys.modules[module_short_name] = module - sys.modules['nodes'] = base_nodes + + # easy-use needs a shim + # this ensures NODE_CLASS_MAPPINGS is loaded lazily and contains all the nodes loaded so far, not just the base nodes + # easy-use and other nodes expect NODE_CLASS_MAPPINGS to contain all the nodes in the environment + # the shim must be activated after importing, which happens in a tightly coupled way + # todo: it's not clear if we should skip the dunder methods or not + nodes_shim_dir = {k: getattr(base_nodes, k) for k in dir(base_nodes) if not k.startswith("__")} + nodes_shim_dir['NODE_CLASS_MAPPINGS'] = _NodeClassMappingsShim() + nodes_shim_dir['EXTENSION_WEB_DIRS'] = {} + + nodes_shim = _NodeShim() + for k, v in nodes_shim_dir.items(): + setattr(nodes_shim, k, v) + + sys.modules['nodes'] = nodes_shim + comfyui_version = types.ModuleType('comfyui_version', '') setattr(comfyui_version, "__version__", __version__) sys.modules['comfyui_version'] = comfyui_version @@ -76,3 +178,97 @@ def prepare_vanilla_environment(): threading.Thread.start = patched_start setattr(threading.Thread.start, '__is_patched_by_us', True) logger.debug("Patched `threading.Thread.start` to propagate contextvars.") + + +@contextmanager +def patch_pip_install_subprocess_run(): + from unittest.mock import patch, MagicMock + original_subprocess_run = subprocess.run + + def custom_side_effect(*args, **kwargs): + command_list = args[0] if args else [] + + # from easy-use + is_pip_install_call = ( + isinstance(command_list, list) and + len(command_list) == 6 and + command_list[0] == sys.executable and + command_list[1] == '-s' and + command_list[2] == '-m' and + command_list[3] == 'pip' and + command_list[4] == 'install' and + isinstance(command_list[5], str) + ) + + if is_pip_install_call: + package_name = command_list[5] + logger.info(f"Intercepted and mocked `pip install` for: {package_name}") + mock_result = MagicMock() + mock_result.returncode = 0 + return mock_result + else: + return original_subprocess_run(*args, **kwargs) + + with patch('subprocess.run') as mock_run: + mock_run.side_effect = custom_side_effect + yield + + +@contextmanager +def patch_pip_install_popen(): + from unittest.mock import patch, MagicMock + original_subprocess_popen = subprocess.Popen + + def custom_side_effect(*args, **kwargs): + command_list = args[0] if args else [] + + is_pip_install_call = ( + isinstance(command_list, list) and + len(command_list) >= 5 and + command_list[0] == sys.executable and + command_list[1] == "-m" and + command_list[2] == "pip" and + command_list[3] == "install" and + # special case nunchaku + "nunchaku" not in command_list[4:] + ) + + if is_pip_install_call: + package_names = command_list[4:] + logger.info(f"Intercepted and mocked `subprocess.Popen` for: pip install {' '.join(package_names)}") + + mock_popen_instance = MagicMock() + # make stdout and stderr empty iterables so loops over them complete immediately. + mock_popen_instance.stdout = [] + mock_popen_instance.stderr = [] + + return mock_popen_instance + else: + return original_subprocess_popen(*args, **kwargs) + + with patch('subprocess.Popen') as mock_popen: + mock_popen.side_effect = custom_side_effect + yield mock_popen + + +@contextmanager +def vanilla_environment_node_execution_hooks(): + # this handles activating the NODE_CLASS_MAPPINGS shim + from comfy.execution_context import current_execution_context + ctx = current_execution_context() + + if 'nodes' in sys.modules and isinstance(sys.modules['nodes'], _NodeShim): + nodes_shim: _NodeShim = sys.modules['nodes'] + try: + nodes_shim.activate() + + block_installs = ctx and ctx.configuration and ctx.configuration.block_runtime_package_installation is True + with ( + patch_pip_install_subprocess_run() if block_installs else nullcontext(), + patch_pip_install_popen() if block_installs else nullcontext(), + ): + yield + finally: + nodes_shim.deactivate() + else: + yield diff --git a/pyproject.toml b/pyproject.toml index 4a1ca30f9..65f42c34d 100644 --- a/pyproject.toml +++ b/pyproject.toml @@ -27,7 +27,7 @@ dependencies = [ "torchsde>=0.2.6", "einops>=0.6.0", "open-clip-torch>=2.24.0", - "transformers>=4.46.0,!=4.53.0,!=4.53.1,!=4.53.2", + "transformers>=4.46.0,!=4.53.0,!=4.53.1,!=4.53.2,!=4.57.0", "tokenizers>=0.13.3", "sentencepiece", "peft>=0.10.0", @@ -52,7 +52,7 @@ dependencies = [ "tqdm", "protobuf>=3.20.0,<5.0.0", "psutil", - "ConfigArgParse", + "ConfigArgParse>=1.7.1", "aio-pika", "pyjwt[crypto]", "kornia>=0.7.0", @@ -113,6 +113,8 @@ dependencies = [ "stringzilla<4.2.0", "requests_cache", "universal_pathlib", + # yanked propcache is omitted + "propcache!=0.4.0", ] [build-system] diff --git a/tests/conftest.py b/tests/conftest.py index 668ea947c..712cfc0dc 100644 --- a/tests/conftest.py +++ b/tests/conftest.py @@ -13,6 +13,9 @@ from typing import List, Any, Generator import pytest import requests +from comfy.cli_args import default_configuration +from comfy.execution_context import context_configuration + os.environ['OTEL_METRICS_EXPORTER'] = 'none' os.environ["OPENCV_IO_ENABLE_OPENEXR"] = "1" os.environ["HF_XET_HIGH_PERFORMANCE"] = "True" @@ -27,11 +30,8 @@ logging.getLogger("aio_pika").setLevel(logging.CRITICAL + 1) def run_server(server_arguments: Configuration): from comfy.cmd.main import _start_comfyui - from comfy.cli_args import args import asyncio - for arg, value in server_arguments.items(): - args[arg] = value - asyncio.run(_start_comfyui()) + asyncio.run(_start_comfyui(configuration=server_arguments)) @pytest.fixture(scope="function", autouse=False) @@ -140,7 +140,7 @@ def comfy_background_server(tmp_path_factory) -> Generator[tuple[Configuration, tmp_path = tmp_path_factory.mktemp("comfy_background_server") # Start server - configuration = Configuration() + configuration = default_configuration() configuration.listen = "localhost" configuration.output_directory = str(tmp_path) configuration.input_directory = str(tmp_path) diff --git a/tests/distributed/test_counter.py b/tests/distributed/test_counter.py new file mode 100644 index 000000000..6ed5396d8 --- /dev/null +++ b/tests/distributed/test_counter.py @@ -0,0 +1,288 @@ +import os +import shutil +import subprocess +import sys +from threading import Thread, Barrier +from pathlib import Path +import asyncio +import contextvars +from concurrent.futures import ThreadPoolExecutor +import pytest +from testcontainers.core.container import DockerContainer +from testcontainers.core.wait_strategies import LogMessageWaitStrategy + +from comfy.component_model.file_counter import FileCounter +from comfy.component_model.folder_path_types import FolderNames +from comfy.execution_context import context_folder_names_and_paths +from comfy.cmd.folder_paths import init_default_paths + + +def is_tool(name): + """Check whether `name` is on PATH and marked as executable.""" + return shutil.which(name) is not None + + +def run_command(command, check=True): + """Helper to run a shell command.""" + try: + return subprocess.run(command, shell=True, check=check, capture_output=True, text=True) + except subprocess.CalledProcessError as e: + print(f"Command failed: {command}") + print(f"--- STDOUT ---\n{e.stdout}") + print(f"--- STDERR ---\n{e.stderr}") + print("--------------") + raise + + +@pytest.fixture( + params=[ + pytest.param("local", id="local_filesystem"), + pytest.param( + "nfs", + id="nfs_share", + marks=pytest.mark.skipif( + not sys.platform.startswith("linux") + or not is_tool("mount.nfs") + or not is_tool("sudo") + or not os.path.exists("/sys/module/nfsd"), + reason="NFS tests require sudo, nfs-common, and the 'nfsd' kernel module to be loaded.", + ), + ), + pytest.param( + "samba", + id="samba_share", + marks=pytest.mark.skipif( + not sys.platform.startswith("linux") + or not is_tool("mount.cifs") + or not is_tool("sudo"), + reason="Samba tests require sudo on Linux with cifs-utils installed.", + ), + ), + ] +) +def counter_path_factory(request, tmp_path_factory): + """A parameterized fixture to provide paths on local, NFS, and Samba filesystems.""" + if request.param == "local": + yield lambda name: str(tmp_path_factory.mktemp("local_test") / name) + return + + mount_point = tmp_path_factory.mktemp(f"mount_point_{request.param}") + + if request.param == "nfs": + # 1. Create the host directory that will be mounted into the container. + nfs_source = tmp_path_factory.mktemp("nfs_source") + # 2. FIX: Set permissions on the *host* directory. + os.chmod(str(nfs_source), 0o777) + + # 3. FIX: Use the new container's required path: /mnt/data + container_path = "/mnt/data" + + # 4. FIX: Change to the new container image and configuration + nfs_container = DockerContainer("ghcr.io/normal-computing/nfs-server:latest").with_env( + "NFS_SERVER_ALLOWED_CLIENTS", "*" + ).with_kwargs(privileged=True).with_exposed_ports(2049).with_volume_mapping( + str(nfs_source), container_path, mode="rw" # Mount to /mnt/data + ) + + nfs_container.start() + + # 5. FIX: Wait for the new container's export log message + # (and remove the timeout as requested) + nfs_container.waiting_for( + LogMessageWaitStrategy(r"exporting /mnt/data") + ) + + request.addfinalizer(lambda: nfs_container.stop()) + + ip_address = nfs_container.get_container_host_ip() + nfs_port = nfs_container.get_exposed_port(2049) + try: + # 6. FIX: Mount using the new container's command format + # (mounts root ":" and uses "-t nfs4") + run_command(f"sleep 1 && sudo mount -t nfs4 -o proto=tcp,port={nfs_port} {ip_address}:/ {mount_point}") + yield lambda name: str(mount_point / name) + finally: + run_command(f"sudo umount {mount_point}", check=False) + + elif request.param == "samba": + # 1. Create the host directory. + samba_source = tmp_path_factory.mktemp("samba_source") + # 2. Set permissions on the *host* directory. + os.chmod(str(samba_source), 0o777) + + share_name = "storage" + + # 3. FIX: Add the NAME environment variable to tell the container + # to create a share named "storage". + samba_container = DockerContainer("dockurr/samba:latest").with_env( + "RW", "yes" + ).with_env( + "NAME", share_name # <-- This is the crucial fix + ).with_exposed_ports(445).with_volume_mapping( + str(samba_source), "/storage", mode="rw" # This maps the host dir to the internal /storage path + ) + + samba_container.start() + + # 4. Wait for the correct log message + # (and remove the timeout as requested) + samba_container.waiting_for( + LogMessageWaitStrategy(r"smbd version .* started") + ) + + request.addfinalizer(lambda: samba_container.stop()) + + ip_address = samba_container.get_container_host_ip() + samba_port = samba_container.get_exposed_port(445) + try: + # 5. FIX: Mount with the default username/password, not as guest. + run_command(f"sleep 1 && sudo mount -t cifs -o username=samba,password=secret,vers=3.0,port={samba_port},uid=$(id -u),gid=$(id -g) //{ip_address}/{share_name} {mount_point}", check=True) + yield lambda name: str(mount_point / name) + finally: + run_command(f"sudo umount {mount_point}", check=False) + + +def test_initial_state(counter_path_factory): + """Verify initial state and file creation.""" + counter_file = counter_path_factory("counter.txt") + lock_file = counter_path_factory("counter.txt.lock") + + assert not os.path.exists(counter_file) + assert not os.path.exists(lock_file) + + counter = FileCounter(str(counter_file)) + assert counter.get_and_increment() == 0 + assert os.path.exists(counter_file) + with open(counter_file, "r") as f: + assert f.read() == "1" + + +def test_mkdirs(counter_path_factory): + counter_file = counter_path_factory("new_dir/counter.txt") + assert not os.path.exists(os.path.dirname(counter_file)) + + counter = FileCounter(str(counter_file)) + assert counter.get_and_increment() == 0 + assert counter.get_and_increment() == 1 + + +def test_increment_and_decrement(counter_path_factory): + """Test the increment and decrement logic.""" + counter_file = counter_path_factory("counter.txt") + counter = FileCounter(str(counter_file)) + + assert counter.get_and_increment() == 0 # val: 0, new_val: 1 + assert counter.get_and_increment() == 1 # val: 1, new_val: 2 + assert counter.get_and_increment() == 2 # val: 2, new_val: 3 + + assert counter.decrement_and_get() == 2 # val: 3, new_val: 2 + assert counter.decrement_and_get() == 1 # val: 2, new_val: 1 + + assert counter.get_and_increment() == 1 # val: 1, new_val: 2 + + +def test_multiple_instances_same_path(counter_path_factory): + """Verify that multiple FileCounter instances on the same path work correctly.""" + counter_file = counter_path_factory("counter.txt") + counter1 = FileCounter(str(counter_file)) + counter2 = FileCounter(str(counter_file)) + + assert counter1.get_and_increment() == 0 + assert counter2.get_and_increment() == 1 + assert counter1.decrement_and_get() == 1 + assert counter2.get_and_increment() == 1 + + with open(counter_file, "r") as f: + assert f.read() == "2" + + +def test_multithreaded_access(counter_path_factory): + """Ensure atomicity with multiple threads.""" + counter_file = counter_path_factory("counter.txt") + counter = FileCounter(str(counter_file)) + num_threads = 10 + increments_per_thread = 100 + + def worker(): + for _ in range(increments_per_thread): + counter.get_and_increment() + + threads = [Thread(target=worker) for _ in range(num_threads)] + for t in threads: + t.start() + for t in threads: + t.join() + + with open(counter_file, "r") as f: + final_value = int(f.read()) + assert final_value == num_threads * increments_per_thread + + +def test_context_manager(counter_path_factory): + """Test that the counter can be used as a context manager.""" + counter_file = counter_path_factory("counter.txt") + counter = FileCounter(str(counter_file)) + + # Initial state should be 0 + assert counter.get_and_increment() == 0 + with open(counter_file) as f: + assert f.read() == "1" + + with counter as wrapper: + # The wrapper's value is the original count before increment. + assert wrapper.value == 1 + # It can also be used as an integer directly. + assert int(wrapper) == 1 + with open(counter_file) as f: + assert f.read() == "2" # Inside context, value is 2 + + with open(counter_file) as f: + assert f.read() == "1" # Exited context, decremented back to 1 + # After exit, the wrapper's 'ctr' attribute holds the new value. + assert wrapper.ctr == 1 + + +async def test_cleanup_temp_multithreaded(tmp_path): + """ + Test that cleanup_temp correctly deletes the temp directory only + after the last thread has exited the context. + """ + # 1. Use the application's context to define the temp directory for this test. + # This is a cleaner approach than mocking. + base_dir = tmp_path / "base" + temp_dir_override = base_dir / "temp" + fn = FolderNames(base_paths=[base_dir]) + init_default_paths(fn, base_paths_from_configuration=False) + # Override the default temp path + fn.temp_directory = temp_dir_override + + from comfy.component_model.file_counter import cleanup_temp + + num_threads = 5 + # Barrier to make threads wait for each other before exiting. + barrier = Barrier(num_threads) + loop = asyncio.get_running_loop() + + def worker(): + """The task for each thread. It enters the cleanup context and waits.""" + with cleanup_temp(): + # The temp directory and counter file should exist inside the context. + assert temp_dir_override.exists() + assert (temp_dir_override / "counter.txt").exists() + # After exiting, the directory should still exist until the last thread is done. + + # Use the context manager to set the folder paths for the current async context. + with context_folder_names_and_paths(fn): + # Capture the current context, which now includes the folder_paths settings. + + # Run the worker function in a thread pool, applying the captured context to each task. + with ThreadPoolExecutor(max_workers=num_threads) as executor: + + tasks = [loop.run_in_executor(executor, contextvars.copy_context().run, worker) for _ in range(num_threads)] + # Wait for all threads to complete their work. + await asyncio.gather(*tasks) + + # After all threads have joined, the counter should be 0, and the directory deleted. + assert not temp_dir_override.exists() + # the base dir is not going to be deleted + assert base_dir.exists() diff --git a/tests/execution/test_progress_isolation.py b/tests/execution/test_progress_isolation.py index d09a9fe9f..8f7677d48 100644 --- a/tests/execution/test_progress_isolation.py +++ b/tests/execution/test_progress_isolation.py @@ -16,6 +16,7 @@ from typing import List, Dict, Any, Generator from PIL import Image +from comfy.cli_args import default_configuration from comfy.cli_args_types import Configuration from comfy_execution.graph_utils import GraphBuilder from .test_execution import ComfyClient, RunResult @@ -188,7 +189,7 @@ class TestProgressIsolation: tmp_path = tmp_path_factory.mktemp("comfy_background_server") # Start server - configuration = Configuration() + configuration = default_configuration() configuration.listen = args_pytest["listen"] configuration.port = args_pytest["port"] configuration.cpu = True @@ -205,7 +206,7 @@ testing_pack: yaml_path = str(tmp_path_factory.mktemp("comfy_background_server") / "extra_nodes.yaml") with open(yaml_path, mode="wt") as f: f.write(extra_nodes) - configuration.extra_model_paths_config = [str(yaml_path)] + configuration.extra_model_paths_config = [yaml_path] yield from comfy_background_server_from_config(configuration) diff --git a/tests/inference/test_workflows.py b/tests/inference/test_workflows.py index 695bc9f21..5bd1e352c 100644 --- a/tests/inference/test_workflows.py +++ b/tests/inference/test_workflows.py @@ -1,5 +1,6 @@ import importlib.resources import json +import logging from importlib.abc import Traversable import pytest @@ -11,6 +12,8 @@ from comfy.model_downloader_types import CivitFile, HuggingFile from comfy_extras.nodes.nodes_audio import TorchAudioNotFoundError from . import workflows +logger = logging.getLogger(__name__) + @pytest.fixture(scope="function", autouse=False) async def client(tmp_path_factory) -> Comfy: @@ -35,6 +38,7 @@ async def test_workflow(workflow_name: str, workflow_file: Traversable, has_gpu: prompt = Prompt.validate(workflow) # todo: add all the models we want to test a bit m2ore elegantly + outputs = {} try: outputs = await client.queue_prompt(prompt) except TorchAudioNotFoundError: @@ -46,8 +50,14 @@ async def test_workflow(workflow_name: str, workflow_file: Traversable, has_gpu: elif any(v.class_type == "SaveAudio" for v in prompt.values()): save_audio_node_id = next(key for key in prompt if prompt[key].class_type == "SaveAudio") assert outputs[save_audio_node_id]["audio"][0]["filename"] is not None + elif any(v.class_type == "SaveAnimatedWEBP" for v in prompt.values()): + save_video_node_id = next(key for key in prompt if prompt[key].class_type == "SaveAnimatedWEBP") + assert outputs[save_video_node_id]["images"][0]["filename"] is not None elif any(v.class_type == "PreviewString" for v in prompt.values()): save_image_node_id = next(key for key in prompt if prompt[key].class_type == "PreviewString") output_str = outputs[save_image_node_id]["string"][0] assert output_str is not None assert len(output_str) > 0 + else: + assert len(outputs) > 0 + logger.warning(f"test {workflow_name} did not have a node that could be checked for output") diff --git a/uv.lock b/uv.lock deleted file mode 100644 index 8f27387b4..000000000 --- a/uv.lock +++ /dev/null @@ -1,7098 +0,0 @@ -version = 1 -revision = 2 -requires-python = ">=3.10" -resolution-markers = [ - "python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", -] -conflicts = [[ - { package = "comfyui", extra = "cpu" }, - { package = "comfyui", extra = "cu126" }, - { package = "comfyui", extra = "cu128" }, - { package = "comfyui", extra = "rocm" }, -]] - -[[package]] -name = "absl-py" -version = "2.3.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/03/15/18693af986560a5c3cc0b84a8046b536ffb2cdb536e03cce897f2759e284/absl_py-2.3.0.tar.gz", hash = "sha256:d96fda5c884f1b22178852f30ffa85766d50b99e00775ea626c23304f582fc4f", size = 116400, upload-time = "2025-05-27T09:15:50.143Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/87/04/9d75e1d3bb4ab8ec67ff10919476ccdee06c098bcfcf3a352da5f985171d/absl_py-2.3.0-py3-none-any.whl", hash = "sha256:9824a48b654a306168f63e0d97714665f8490b8d89ec7bf2efc24bf67cf579b3", size = 135657, upload-time = "2025-05-27T09:15:48.742Z" }, -] - -[[package]] -name = "accelerate" -version = "1.7.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "huggingface-hub" }, - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "packaging" }, - { name = "psutil" }, - { name = "pyyaml" }, - { name = "safetensors" }, - { name = "torch", version = "2.0.1", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://pypi.org/simple" }, marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" }, marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "extra == 'extra-7-comfyui-cu128' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/97/33/47bbd507e3a851d33d19ce7b2141c5ea3689bfae91ba168044d7db24b0e9/accelerate-1.7.0.tar.gz", hash = "sha256:e8a2a5503d6237b9eee73cc8d36cf543f9c2d8dd2c6713450b322f5e6d53a610", size = 376026, upload-time = "2025-05-15T10:00:52.117Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/f8/bb/be8146c196ad6e4dec78385d91e92591f8a433576c4e04c342a636fcd811/accelerate-1.7.0-py3-none-any.whl", hash = "sha256:cf57165cca28769c6cf2650812371c81b18e05743dfa3c748524b1bb4f2b272f", size = 362095, upload-time = "2025-05-15T10:00:49.914Z" }, -] - -[[package]] -name = "aio-pika" -version = "9.5.5" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "aiormq" }, - { name = "exceptiongroup" }, - { name = "yarl" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/48/00/5391405f15e85bd6cb859186dbe04d99186ca29410a7cdc52848b55a1d72/aio_pika-9.5.5.tar.gz", hash = "sha256:3d2f25838860fa7e209e21fc95555f558401f9b49a832897419489f1c9e1d6a4", size = 48468, upload-time = "2025-02-26T11:15:56.595Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/71/cf/efa5581760bd08263bce8dbf943f32006b6dfd5bc120f43a26257281b546/aio_pika-9.5.5-py3-none-any.whl", hash = "sha256:94e0ac3666398d6a28b0c3b530c1febf4c6d4ececb345620727cfd7bfe1c02e0", size = 54257, upload-time = "2025-02-26T11:15:54.066Z" }, -] - -[[package]] -name = "aiofiles" -version = "24.1.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/0b/03/a88171e277e8caa88a4c77808c20ebb04ba74cc4681bf1e9416c862de237/aiofiles-24.1.0.tar.gz", hash = "sha256:22a075c9e5a3810f0c2e48f3008c94d68c65d763b9b03857924c99e57355166c", size = 30247, upload-time = "2024-06-24T11:02:03.584Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/a5/45/30bb92d442636f570cb5651bc661f52b610e2eec3f891a5dc3a4c3667db0/aiofiles-24.1.0-py3-none-any.whl", hash = "sha256:b4ec55f4195e3eb5d7abd1bf7e061763e864dd4954231fb8539a0ef8bb8260e5", size = 15896, upload-time = "2024-06-24T11:02:01.529Z" }, -] - -[[package]] -name = "aiohappyeyeballs" -version = "2.6.1" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/26/30/f84a107a9c4331c14b2b586036f40965c128aa4fee4dda5d3d51cb14ad54/aiohappyeyeballs-2.6.1.tar.gz", hash = "sha256:c3f9d0113123803ccadfdf3f0faa505bc78e6a72d1cc4806cbd719826e943558", size = 22760, upload-time = "2025-03-12T01:42:48.764Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/0f/15/5bf3b99495fb160b63f95972b81750f18f7f4e02ad051373b669d17d44f2/aiohappyeyeballs-2.6.1-py3-none-any.whl", hash = "sha256:f349ba8f4b75cb25c99c5c2d84e997e485204d2902a9597802b0371f09331fb8", size = 15265, upload-time = "2025-03-12T01:42:47.083Z" }, -] - -[[package]] -name = "aiohttp" -version = "3.12.13" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "aiohappyeyeballs" }, - { name = "aiosignal" }, - { name = "async-timeout", marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "attrs" }, - { name = "frozenlist" }, - { name = "multidict" }, - { name = "propcache" }, - { name = "yarl" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/42/6e/ab88e7cb2a4058bed2f7870276454f85a7c56cd6da79349eb314fc7bbcaa/aiohttp-3.12.13.tar.gz", hash = "sha256:47e2da578528264a12e4e3dd8dd72a7289e5f812758fe086473fab037a10fcce", size = 7819160, upload-time = "2025-06-14T15:15:41.354Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/8b/2d/27e4347660723738b01daa3f5769d56170f232bf4695dd4613340da135bb/aiohttp-3.12.13-cp310-cp310-macosx_10_9_universal2.whl", hash = "sha256:5421af8f22a98f640261ee48aae3a37f0c41371e99412d55eaf2f8a46d5dad29", size = 702090, upload-time = "2025-06-14T15:12:58.938Z" }, - { url = "https://files.pythonhosted.org/packages/10/0b/4a8e0468ee8f2b9aff3c05f2c3a6be1dfc40b03f68a91b31041d798a9510/aiohttp-3.12.13-cp310-cp310-macosx_10_9_x86_64.whl", hash = "sha256:0fcda86f6cb318ba36ed8f1396a6a4a3fd8f856f84d426584392083d10da4de0", size = 478440, upload-time = "2025-06-14T15:13:02.981Z" }, - { url = "https://files.pythonhosted.org/packages/b9/c8/2086df2f9a842b13feb92d071edf756be89250f404f10966b7bc28317f17/aiohttp-3.12.13-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:4cd71c9fb92aceb5a23c4c39d8ecc80389c178eba9feab77f19274843eb9412d", size = 466215, upload-time = "2025-06-14T15:13:04.817Z" }, - { url = "https://files.pythonhosted.org/packages/a7/3d/d23e5bd978bc8012a65853959b13bd3b55c6e5afc172d89c26ad6624c52b/aiohttp-3.12.13-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:34ebf1aca12845066c963016655dac897651e1544f22a34c9b461ac3b4b1d3aa", size = 1648271, upload-time = "2025-06-14T15:13:06.532Z" }, - { url = "https://files.pythonhosted.org/packages/31/31/e00122447bb137591c202786062f26dd383574c9f5157144127077d5733e/aiohttp-3.12.13-cp310-cp310-manylinux_2_17_armv7l.manylinux2014_armv7l.manylinux_2_31_armv7l.whl", hash = "sha256:893a4639694c5b7edd4bdd8141be296042b6806e27cc1d794e585c43010cc294", size = 1622329, upload-time = "2025-06-14T15:13:08.394Z" }, - { url = "https://files.pythonhosted.org/packages/04/01/caef70be3ac38986969045f21f5fb802ce517b3f371f0615206bf8aa6423/aiohttp-3.12.13-cp310-cp310-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:663d8ee3ffb3494502ebcccb49078faddbb84c1d870f9c1dd5a29e85d1f747ce", size = 1694734, upload-time = "2025-06-14T15:13:09.979Z" }, - { url = "https://files.pythonhosted.org/packages/3f/15/328b71fedecf69a9fd2306549b11c8966e420648a3938d75d3ed5bcb47f6/aiohttp-3.12.13-cp310-cp310-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:f0f8f6a85a0006ae2709aa4ce05749ba2cdcb4b43d6c21a16c8517c16593aabe", size = 1737049, upload-time = "2025-06-14T15:13:11.672Z" }, - { url = "https://files.pythonhosted.org/packages/e6/7a/d85866a642158e1147c7da5f93ad66b07e5452a84ec4258e5f06b9071e92/aiohttp-3.12.13-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:1582745eb63df267c92d8b61ca655a0ce62105ef62542c00a74590f306be8cb5", size = 1641715, upload-time = "2025-06-14T15:13:13.548Z" }, - { url = "https://files.pythonhosted.org/packages/14/57/3588800d5d2f5f3e1cb6e7a72747d1abc1e67ba5048e8b845183259c2e9b/aiohttp-3.12.13-cp310-cp310-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:d59227776ee2aa64226f7e086638baa645f4b044f2947dbf85c76ab11dcba073", size = 1581836, upload-time = "2025-06-14T15:13:15.086Z" }, - { url = "https://files.pythonhosted.org/packages/2f/55/c913332899a916d85781aa74572f60fd98127449b156ad9c19e23135b0e4/aiohttp-3.12.13-cp310-cp310-musllinux_1_2_aarch64.whl", hash = "sha256:06b07c418bde1c8e737d8fa67741072bd3f5b0fb66cf8c0655172188c17e5fa6", size = 1625685, upload-time = "2025-06-14T15:13:17.163Z" }, - { url = "https://files.pythonhosted.org/packages/4c/34/26cded195f3bff128d6a6d58d7a0be2ae7d001ea029e0fe9008dcdc6a009/aiohttp-3.12.13-cp310-cp310-musllinux_1_2_armv7l.whl", hash = "sha256:9445c1842680efac0f81d272fd8db7163acfcc2b1436e3f420f4c9a9c5a50795", size = 1636471, upload-time = "2025-06-14T15:13:19.086Z" }, - { url = "https://files.pythonhosted.org/packages/19/21/70629ca006820fccbcec07f3cd5966cbd966e2d853d6da55339af85555b9/aiohttp-3.12.13-cp310-cp310-musllinux_1_2_i686.whl", hash = "sha256:09c4767af0b0b98c724f5d47f2bf33395c8986995b0a9dab0575ca81a554a8c0", size = 1611923, upload-time = "2025-06-14T15:13:20.997Z" }, - { url = "https://files.pythonhosted.org/packages/31/80/7fa3f3bebf533aa6ae6508b51ac0de9965e88f9654fa679cc1a29d335a79/aiohttp-3.12.13-cp310-cp310-musllinux_1_2_ppc64le.whl", hash = "sha256:f3854fbde7a465318ad8d3fc5bef8f059e6d0a87e71a0d3360bb56c0bf87b18a", size = 1691511, upload-time = "2025-06-14T15:13:22.54Z" }, - { url = "https://files.pythonhosted.org/packages/0f/7a/359974653a3cdd3e9cee8ca10072a662c3c0eb46a359c6a1f667b0296e2f/aiohttp-3.12.13-cp310-cp310-musllinux_1_2_s390x.whl", hash = "sha256:2332b4c361c05ecd381edb99e2a33733f3db906739a83a483974b3df70a51b40", size = 1714751, upload-time = "2025-06-14T15:13:24.366Z" }, - { url = "https://files.pythonhosted.org/packages/2d/24/0aa03d522171ce19064347afeefadb008be31ace0bbb7d44ceb055700a14/aiohttp-3.12.13-cp310-cp310-musllinux_1_2_x86_64.whl", hash = "sha256:1561db63fa1b658cd94325d303933553ea7d89ae09ff21cc3bcd41b8521fbbb6", size = 1643090, upload-time = "2025-06-14T15:13:26.231Z" }, - { url = "https://files.pythonhosted.org/packages/86/2e/7d4b0026a41e4b467e143221c51b279083b7044a4b104054f5c6464082ff/aiohttp-3.12.13-cp310-cp310-win32.whl", hash = "sha256:a0be857f0b35177ba09d7c472825d1b711d11c6d0e8a2052804e3b93166de1ad", size = 427526, upload-time = "2025-06-14T15:13:27.988Z" }, - { url = "https://files.pythonhosted.org/packages/17/de/34d998da1e7f0de86382160d039131e9b0af1962eebfe53dda2b61d250e7/aiohttp-3.12.13-cp310-cp310-win_amd64.whl", hash = "sha256:fcc30ad4fb5cb41a33953292d45f54ef4066746d625992aeac33b8c681173178", size = 450734, upload-time = "2025-06-14T15:13:29.394Z" }, - { url = "https://files.pythonhosted.org/packages/6a/65/5566b49553bf20ffed6041c665a5504fb047cefdef1b701407b8ce1a47c4/aiohttp-3.12.13-cp311-cp311-macosx_10_9_universal2.whl", hash = "sha256:7c229b1437aa2576b99384e4be668af1db84b31a45305d02f61f5497cfa6f60c", size = 709401, upload-time = "2025-06-14T15:13:30.774Z" }, - { url = "https://files.pythonhosted.org/packages/14/b5/48e4cc61b54850bdfafa8fe0b641ab35ad53d8e5a65ab22b310e0902fa42/aiohttp-3.12.13-cp311-cp311-macosx_10_9_x86_64.whl", hash = "sha256:04076d8c63471e51e3689c93940775dc3d12d855c0c80d18ac5a1c68f0904358", size = 481669, upload-time = "2025-06-14T15:13:32.316Z" }, - { url = "https://files.pythonhosted.org/packages/04/4f/e3f95c8b2a20a0437d51d41d5ccc4a02970d8ad59352efb43ea2841bd08e/aiohttp-3.12.13-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:55683615813ce3601640cfaa1041174dc956d28ba0511c8cbd75273eb0587014", size = 469933, upload-time = "2025-06-14T15:13:34.104Z" }, - { url = "https://files.pythonhosted.org/packages/41/c9/c5269f3b6453b1cfbd2cfbb6a777d718c5f086a3727f576c51a468b03ae2/aiohttp-3.12.13-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:921bc91e602d7506d37643e77819cb0b840d4ebb5f8d6408423af3d3bf79a7b7", size = 1740128, upload-time = "2025-06-14T15:13:35.604Z" }, - { url = "https://files.pythonhosted.org/packages/6f/49/a3f76caa62773d33d0cfaa842bdf5789a78749dbfe697df38ab1badff369/aiohttp-3.12.13-cp311-cp311-manylinux_2_17_armv7l.manylinux2014_armv7l.manylinux_2_31_armv7l.whl", hash = "sha256:e72d17fe0974ddeae8ed86db297e23dba39c7ac36d84acdbb53df2e18505a013", size = 1688796, upload-time = "2025-06-14T15:13:37.125Z" }, - { url = "https://files.pythonhosted.org/packages/ad/e4/556fccc4576dc22bf18554b64cc873b1a3e5429a5bdb7bbef7f5d0bc7664/aiohttp-3.12.13-cp311-cp311-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:0653d15587909a52e024a261943cf1c5bdc69acb71f411b0dd5966d065a51a47", size = 1787589, upload-time = "2025-06-14T15:13:38.745Z" }, - { url = "https://files.pythonhosted.org/packages/b9/3d/d81b13ed48e1a46734f848e26d55a7391708421a80336e341d2aef3b6db2/aiohttp-3.12.13-cp311-cp311-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:a77b48997c66722c65e157c06c74332cdf9c7ad00494b85ec43f324e5c5a9b9a", size = 1826635, upload-time = "2025-06-14T15:13:40.733Z" }, - { url = "https://files.pythonhosted.org/packages/75/a5/472e25f347da88459188cdaadd1f108f6292f8a25e62d226e63f860486d1/aiohttp-3.12.13-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:d6946bae55fd36cfb8e4092c921075cde029c71c7cb571d72f1079d1e4e013bc", size = 1729095, upload-time = "2025-06-14T15:13:42.312Z" }, - { url = "https://files.pythonhosted.org/packages/b9/fe/322a78b9ac1725bfc59dfc301a5342e73d817592828e4445bd8f4ff83489/aiohttp-3.12.13-cp311-cp311-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:4f95db8c8b219bcf294a53742c7bda49b80ceb9d577c8e7aa075612b7f39ffb7", size = 1666170, upload-time = "2025-06-14T15:13:44.884Z" }, - { url = "https://files.pythonhosted.org/packages/7a/77/ec80912270e231d5e3839dbd6c065472b9920a159ec8a1895cf868c2708e/aiohttp-3.12.13-cp311-cp311-musllinux_1_2_aarch64.whl", hash = "sha256:03d5eb3cfb4949ab4c74822fb3326cd9655c2b9fe22e4257e2100d44215b2e2b", size = 1714444, upload-time = "2025-06-14T15:13:46.401Z" }, - { url = "https://files.pythonhosted.org/packages/21/b2/fb5aedbcb2b58d4180e58500e7c23ff8593258c27c089abfbcc7db65bd40/aiohttp-3.12.13-cp311-cp311-musllinux_1_2_armv7l.whl", hash = "sha256:6383dd0ffa15515283c26cbf41ac8e6705aab54b4cbb77bdb8935a713a89bee9", size = 1709604, upload-time = "2025-06-14T15:13:48.377Z" }, - { url = "https://files.pythonhosted.org/packages/e3/15/a94c05f7c4dc8904f80b6001ad6e07e035c58a8ebfcc15e6b5d58500c858/aiohttp-3.12.13-cp311-cp311-musllinux_1_2_i686.whl", hash = "sha256:6548a411bc8219b45ba2577716493aa63b12803d1e5dc70508c539d0db8dbf5a", size = 1689786, upload-time = "2025-06-14T15:13:50.401Z" }, - { url = "https://files.pythonhosted.org/packages/1d/fd/0d2e618388f7a7a4441eed578b626bda9ec6b5361cd2954cfc5ab39aa170/aiohttp-3.12.13-cp311-cp311-musllinux_1_2_ppc64le.whl", hash = "sha256:81b0fcbfe59a4ca41dc8f635c2a4a71e63f75168cc91026c61be665945739e2d", size = 1783389, upload-time = "2025-06-14T15:13:51.945Z" }, - { url = "https://files.pythonhosted.org/packages/a6/6b/6986d0c75996ef7e64ff7619b9b7449b1d1cbbe05c6755e65d92f1784fe9/aiohttp-3.12.13-cp311-cp311-musllinux_1_2_s390x.whl", hash = "sha256:6a83797a0174e7995e5edce9dcecc517c642eb43bc3cba296d4512edf346eee2", size = 1803853, upload-time = "2025-06-14T15:13:53.533Z" }, - { url = "https://files.pythonhosted.org/packages/21/65/cd37b38f6655d95dd07d496b6d2f3924f579c43fd64b0e32b547b9c24df5/aiohttp-3.12.13-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:a5734d8469a5633a4e9ffdf9983ff7cdb512524645c7a3d4bc8a3de45b935ac3", size = 1716909, upload-time = "2025-06-14T15:13:55.148Z" }, - { url = "https://files.pythonhosted.org/packages/fd/20/2de7012427dc116714c38ca564467f6143aec3d5eca3768848d62aa43e62/aiohttp-3.12.13-cp311-cp311-win32.whl", hash = "sha256:fef8d50dfa482925bb6b4c208b40d8e9fa54cecba923dc65b825a72eed9a5dbd", size = 427036, upload-time = "2025-06-14T15:13:57.076Z" }, - { url = "https://files.pythonhosted.org/packages/f8/b6/98518bcc615ef998a64bef371178b9afc98ee25895b4f476c428fade2220/aiohttp-3.12.13-cp311-cp311-win_amd64.whl", hash = "sha256:9a27da9c3b5ed9d04c36ad2df65b38a96a37e9cfba6f1381b842d05d98e6afe9", size = 451427, upload-time = "2025-06-14T15:13:58.505Z" }, - { url = "https://files.pythonhosted.org/packages/b4/6a/ce40e329788013cd190b1d62bbabb2b6a9673ecb6d836298635b939562ef/aiohttp-3.12.13-cp312-cp312-macosx_10_13_universal2.whl", hash = "sha256:0aa580cf80558557285b49452151b9c69f2fa3ad94c5c9e76e684719a8791b73", size = 700491, upload-time = "2025-06-14T15:14:00.048Z" }, - { url = "https://files.pythonhosted.org/packages/28/d9/7150d5cf9163e05081f1c5c64a0cdf3c32d2f56e2ac95db2a28fe90eca69/aiohttp-3.12.13-cp312-cp312-macosx_10_13_x86_64.whl", hash = "sha256:b103a7e414b57e6939cc4dece8e282cfb22043efd0c7298044f6594cf83ab347", size = 475104, upload-time = "2025-06-14T15:14:01.691Z" }, - { url = "https://files.pythonhosted.org/packages/f8/91/d42ba4aed039ce6e449b3e2db694328756c152a79804e64e3da5bc19dffc/aiohttp-3.12.13-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:78f64e748e9e741d2eccff9597d09fb3cd962210e5b5716047cbb646dc8fe06f", size = 467948, upload-time = "2025-06-14T15:14:03.561Z" }, - { url = "https://files.pythonhosted.org/packages/99/3b/06f0a632775946981d7c4e5a865cddb6e8dfdbaed2f56f9ade7bb4a1039b/aiohttp-3.12.13-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:29c955989bf4c696d2ededc6b0ccb85a73623ae6e112439398935362bacfaaf6", size = 1714742, upload-time = "2025-06-14T15:14:05.558Z" }, - { url = "https://files.pythonhosted.org/packages/92/a6/2552eebad9ec5e3581a89256276009e6a974dc0793632796af144df8b740/aiohttp-3.12.13-cp312-cp312-manylinux_2_17_armv7l.manylinux2014_armv7l.manylinux_2_31_armv7l.whl", hash = "sha256:d640191016763fab76072c87d8854a19e8e65d7a6fcfcbf017926bdbbb30a7e5", size = 1697393, upload-time = "2025-06-14T15:14:07.194Z" }, - { url = "https://files.pythonhosted.org/packages/d8/9f/bd08fdde114b3fec7a021381b537b21920cdd2aa29ad48c5dffd8ee314f1/aiohttp-3.12.13-cp312-cp312-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:4dc507481266b410dede95dd9f26c8d6f5a14315372cc48a6e43eac652237d9b", size = 1752486, upload-time = "2025-06-14T15:14:08.808Z" }, - { url = "https://files.pythonhosted.org/packages/f7/e1/affdea8723aec5bd0959171b5490dccd9a91fcc505c8c26c9f1dca73474d/aiohttp-3.12.13-cp312-cp312-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:8a94daa873465d518db073bd95d75f14302e0208a08e8c942b2f3f1c07288a75", size = 1798643, upload-time = "2025-06-14T15:14:10.767Z" }, - { url = "https://files.pythonhosted.org/packages/f3/9d/666d856cc3af3a62ae86393baa3074cc1d591a47d89dc3bf16f6eb2c8d32/aiohttp-3.12.13-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:177f52420cde4ce0bb9425a375d95577fe082cb5721ecb61da3049b55189e4e6", size = 1718082, upload-time = "2025-06-14T15:14:12.38Z" }, - { url = "https://files.pythonhosted.org/packages/f3/ce/3c185293843d17be063dada45efd2712bb6bf6370b37104b4eda908ffdbd/aiohttp-3.12.13-cp312-cp312-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:0f7df1f620ec40f1a7fbcb99ea17d7326ea6996715e78f71a1c9a021e31b96b8", size = 1633884, upload-time = "2025-06-14T15:14:14.415Z" }, - { url = "https://files.pythonhosted.org/packages/3a/5b/f3413f4b238113be35dfd6794e65029250d4b93caa0974ca572217745bdb/aiohttp-3.12.13-cp312-cp312-musllinux_1_2_aarch64.whl", hash = "sha256:3062d4ad53b36e17796dce1c0d6da0ad27a015c321e663657ba1cc7659cfc710", size = 1694943, upload-time = "2025-06-14T15:14:16.48Z" }, - { url = "https://files.pythonhosted.org/packages/82/c8/0e56e8bf12081faca85d14a6929ad5c1263c146149cd66caa7bc12255b6d/aiohttp-3.12.13-cp312-cp312-musllinux_1_2_armv7l.whl", hash = "sha256:8605e22d2a86b8e51ffb5253d9045ea73683d92d47c0b1438e11a359bdb94462", size = 1716398, upload-time = "2025-06-14T15:14:18.589Z" }, - { url = "https://files.pythonhosted.org/packages/ea/f3/33192b4761f7f9b2f7f4281365d925d663629cfaea093a64b658b94fc8e1/aiohttp-3.12.13-cp312-cp312-musllinux_1_2_i686.whl", hash = "sha256:54fbbe6beafc2820de71ece2198458a711e224e116efefa01b7969f3e2b3ddae", size = 1657051, upload-time = "2025-06-14T15:14:20.223Z" }, - { url = "https://files.pythonhosted.org/packages/5e/0b/26ddd91ca8f84c48452431cb4c5dd9523b13bc0c9766bda468e072ac9e29/aiohttp-3.12.13-cp312-cp312-musllinux_1_2_ppc64le.whl", hash = "sha256:050bd277dfc3768b606fd4eae79dd58ceda67d8b0b3c565656a89ae34525d15e", size = 1736611, upload-time = "2025-06-14T15:14:21.988Z" }, - { url = "https://files.pythonhosted.org/packages/c3/8d/e04569aae853302648e2c138a680a6a2f02e374c5b6711732b29f1e129cc/aiohttp-3.12.13-cp312-cp312-musllinux_1_2_s390x.whl", hash = "sha256:2637a60910b58f50f22379b6797466c3aa6ae28a6ab6404e09175ce4955b4e6a", size = 1764586, upload-time = "2025-06-14T15:14:23.979Z" }, - { url = "https://files.pythonhosted.org/packages/ac/98/c193c1d1198571d988454e4ed75adc21c55af247a9fda08236602921c8c8/aiohttp-3.12.13-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:e986067357550d1aaa21cfe9897fa19e680110551518a5a7cf44e6c5638cb8b5", size = 1724197, upload-time = "2025-06-14T15:14:25.692Z" }, - { url = "https://files.pythonhosted.org/packages/e7/9e/07bb8aa11eec762c6b1ff61575eeeb2657df11ab3d3abfa528d95f3e9337/aiohttp-3.12.13-cp312-cp312-win32.whl", hash = "sha256:ac941a80aeea2aaae2875c9500861a3ba356f9ff17b9cb2dbfb5cbf91baaf5bf", size = 421771, upload-time = "2025-06-14T15:14:27.364Z" }, - { url = "https://files.pythonhosted.org/packages/52/66/3ce877e56ec0813069cdc9607cd979575859c597b6fb9b4182c6d5f31886/aiohttp-3.12.13-cp312-cp312-win_amd64.whl", hash = "sha256:671f41e6146a749b6c81cb7fd07f5a8356d46febdaaaf07b0e774ff04830461e", size = 447869, upload-time = "2025-06-14T15:14:29.05Z" }, - { url = "https://files.pythonhosted.org/packages/11/0f/db19abdf2d86aa1deec3c1e0e5ea46a587b97c07a16516b6438428b3a3f8/aiohttp-3.12.13-cp313-cp313-macosx_10_13_universal2.whl", hash = "sha256:d4a18e61f271127465bdb0e8ff36e8f02ac4a32a80d8927aa52371e93cd87938", size = 694910, upload-time = "2025-06-14T15:14:30.604Z" }, - { url = "https://files.pythonhosted.org/packages/d5/81/0ab551e1b5d7f1339e2d6eb482456ccbe9025605b28eed2b1c0203aaaade/aiohttp-3.12.13-cp313-cp313-macosx_10_13_x86_64.whl", hash = "sha256:532542cb48691179455fab429cdb0d558b5e5290b033b87478f2aa6af5d20ace", size = 472566, upload-time = "2025-06-14T15:14:32.275Z" }, - { url = "https://files.pythonhosted.org/packages/34/3f/6b7d336663337672d29b1f82d1f252ec1a040fe2d548f709d3f90fa2218a/aiohttp-3.12.13-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:d7eea18b52f23c050ae9db5d01f3d264ab08f09e7356d6f68e3f3ac2de9dfabb", size = 464856, upload-time = "2025-06-14T15:14:34.132Z" }, - { url = "https://files.pythonhosted.org/packages/26/7f/32ca0f170496aa2ab9b812630fac0c2372c531b797e1deb3deb4cea904bd/aiohttp-3.12.13-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:ad7c8e5c25f2a26842a7c239de3f7b6bfb92304593ef997c04ac49fb703ff4d7", size = 1703683, upload-time = "2025-06-14T15:14:36.034Z" }, - { url = "https://files.pythonhosted.org/packages/ec/53/d5513624b33a811c0abea8461e30a732294112318276ce3dbf047dbd9d8b/aiohttp-3.12.13-cp313-cp313-manylinux_2_17_armv7l.manylinux2014_armv7l.manylinux_2_31_armv7l.whl", hash = "sha256:6af355b483e3fe9d7336d84539fef460120c2f6e50e06c658fe2907c69262d6b", size = 1684946, upload-time = "2025-06-14T15:14:38Z" }, - { url = "https://files.pythonhosted.org/packages/37/72/4c237dd127827b0247dc138d3ebd49c2ded6114c6991bbe969058575f25f/aiohttp-3.12.13-cp313-cp313-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:a95cf9f097498f35c88e3609f55bb47b28a5ef67f6888f4390b3d73e2bac6177", size = 1737017, upload-time = "2025-06-14T15:14:39.951Z" }, - { url = "https://files.pythonhosted.org/packages/0d/67/8a7eb3afa01e9d0acc26e1ef847c1a9111f8b42b82955fcd9faeb84edeb4/aiohttp-3.12.13-cp313-cp313-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:b8ed8c38a1c584fe99a475a8f60eefc0b682ea413a84c6ce769bb19a7ff1c5ef", size = 1786390, upload-time = "2025-06-14T15:14:42.151Z" }, - { url = "https://files.pythonhosted.org/packages/48/19/0377df97dd0176ad23cd8cad4fd4232cfeadcec6c1b7f036315305c98e3f/aiohttp-3.12.13-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:7a0b9170d5d800126b5bc89d3053a2363406d6e327afb6afaeda2d19ee8bb103", size = 1708719, upload-time = "2025-06-14T15:14:44.039Z" }, - { url = "https://files.pythonhosted.org/packages/61/97/ade1982a5c642b45f3622255173e40c3eed289c169f89d00eeac29a89906/aiohttp-3.12.13-cp313-cp313-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:372feeace612ef8eb41f05ae014a92121a512bd5067db8f25101dd88a8db11da", size = 1622424, upload-time = "2025-06-14T15:14:45.945Z" }, - { url = "https://files.pythonhosted.org/packages/99/ab/00ad3eea004e1d07ccc406e44cfe2b8da5acb72f8c66aeeb11a096798868/aiohttp-3.12.13-cp313-cp313-musllinux_1_2_aarch64.whl", hash = "sha256:a946d3702f7965d81f7af7ea8fb03bb33fe53d311df48a46eeca17e9e0beed2d", size = 1675447, upload-time = "2025-06-14T15:14:47.911Z" }, - { url = "https://files.pythonhosted.org/packages/3f/fe/74e5ce8b2ccaba445fe0087abc201bfd7259431d92ae608f684fcac5d143/aiohttp-3.12.13-cp313-cp313-musllinux_1_2_armv7l.whl", hash = "sha256:a0c4725fae86555bbb1d4082129e21de7264f4ab14baf735278c974785cd2041", size = 1707110, upload-time = "2025-06-14T15:14:50.334Z" }, - { url = "https://files.pythonhosted.org/packages/ef/c4/39af17807f694f7a267bd8ab1fbacf16ad66740862192a6c8abac2bff813/aiohttp-3.12.13-cp313-cp313-musllinux_1_2_i686.whl", hash = "sha256:9b28ea2f708234f0a5c44eb6c7d9eb63a148ce3252ba0140d050b091b6e842d1", size = 1649706, upload-time = "2025-06-14T15:14:52.378Z" }, - { url = "https://files.pythonhosted.org/packages/38/e8/f5a0a5f44f19f171d8477059aa5f28a158d7d57fe1a46c553e231f698435/aiohttp-3.12.13-cp313-cp313-musllinux_1_2_ppc64le.whl", hash = "sha256:d4f5becd2a5791829f79608c6f3dc745388162376f310eb9c142c985f9441cc1", size = 1725839, upload-time = "2025-06-14T15:14:54.617Z" }, - { url = "https://files.pythonhosted.org/packages/fd/ac/81acc594c7f529ef4419d3866913f628cd4fa9cab17f7bf410a5c3c04c53/aiohttp-3.12.13-cp313-cp313-musllinux_1_2_s390x.whl", hash = "sha256:60f2ce6b944e97649051d5f5cc0f439360690b73909230e107fd45a359d3e911", size = 1759311, upload-time = "2025-06-14T15:14:56.597Z" }, - { url = "https://files.pythonhosted.org/packages/38/0d/aabe636bd25c6ab7b18825e5a97d40024da75152bec39aa6ac8b7a677630/aiohttp-3.12.13-cp313-cp313-musllinux_1_2_x86_64.whl", hash = "sha256:69fc1909857401b67bf599c793f2183fbc4804717388b0b888f27f9929aa41f3", size = 1708202, upload-time = "2025-06-14T15:14:58.598Z" }, - { url = "https://files.pythonhosted.org/packages/1f/ab/561ef2d8a223261683fb95a6283ad0d36cb66c87503f3a7dde7afe208bb2/aiohttp-3.12.13-cp313-cp313-win32.whl", hash = "sha256:7d7e68787a2046b0e44ba5587aa723ce05d711e3a3665b6b7545328ac8e3c0dd", size = 420794, upload-time = "2025-06-14T15:15:00.939Z" }, - { url = "https://files.pythonhosted.org/packages/9d/47/b11d0089875a23bff0abd3edb5516bcd454db3fefab8604f5e4b07bd6210/aiohttp-3.12.13-cp313-cp313-win_amd64.whl", hash = "sha256:5a178390ca90419bfd41419a809688c368e63c86bd725e1186dd97f6b89c2706", size = 446735, upload-time = "2025-06-14T15:15:02.858Z" }, -] - -[[package]] -name = "aiormq" -version = "6.8.1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "pamqp" }, - { name = "yarl" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/a4/79/5397756a8782bf3d0dce392b48260c3ec81010f16bef8441ff03505dccb4/aiormq-6.8.1.tar.gz", hash = "sha256:a964ab09634be1da1f9298ce225b310859763d5cf83ef3a7eae1a6dc6bd1da1a", size = 30528, upload-time = "2024-09-04T11:16:38.655Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/2e/be/1a613ae1564426f86650ff58c351902895aa969f7e537e74bfd568f5c8bf/aiormq-6.8.1-py3-none-any.whl", hash = "sha256:5da896c8624193708f9409ffad0b20395010e2747f22aa4150593837f40aa017", size = 31174, upload-time = "2024-09-04T11:16:37.238Z" }, -] - -[[package]] -name = "aiosignal" -version = "1.3.2" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "frozenlist" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/ba/b5/6d55e80f6d8a08ce22b982eafa278d823b541c925f11ee774b0b9c43473d/aiosignal-1.3.2.tar.gz", hash = "sha256:a8c255c66fafb1e499c9351d0bf32ff2d8a0321595ebac3b93713656d2436f54", size = 19424, upload-time = "2024-12-13T17:10:40.86Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/ec/6a/bc7e17a3e87a2985d3e8f4da4cd0f481060eb78fb08596c42be62c90a4d9/aiosignal-1.3.2-py2.py3-none-any.whl", hash = "sha256:45cde58e409a301715980c2b01d0c28bdde3770d8290b5eb2173759d9acb31a5", size = 7597, upload-time = "2024-12-13T17:10:38.469Z" }, -] - -[[package]] -name = "albucore" -version = "0.0.24" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "opencv-python-headless" }, - { name = "simsimd" }, - { name = "stringzilla" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/13/69/d4cbcf2a5768bf91cd14ffef783520458431e5d2b22fbc08418d3ba09a88/albucore-0.0.24.tar.gz", hash = "sha256:f2cab5431fadf94abf87fd0c89d9f59046e49fe5de34afea8f89bc8390253746", size = 16981, upload-time = "2025-03-09T18:46:51.409Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/0a/e2/91f145e1f32428e9e1f21f46a7022ffe63d11f549ee55c3b9265ff5207fc/albucore-0.0.24-py3-none-any.whl", hash = "sha256:adef6e434e50e22c2ee127b7a3e71f2e35fa088bcf54431e18970b62d97d0005", size = 15372, upload-time = "2025-03-09T18:46:50.177Z" }, -] - -[[package]] -name = "albumentations" -version = "2.0.8" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "albucore" }, - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "opencv-python-headless" }, - { name = "pydantic" }, - { name = "pyyaml" }, - { name = "scipy" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/f4/f4/85eb56c3217b53bcfc2d12e840a0b18ca60902086321cafa5a730f9c0470/albumentations-2.0.8.tar.gz", hash = "sha256:4da95e658e490de3c34af8fcdffed09e36aa8a4edd06ca9f9e7e3ea0b0b16856", size = 354460, upload-time = "2025-05-27T21:23:17.415Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/8e/64/013409c451a44b61310fb757af4527f3de57fc98a00f40448de28b864290/albumentations-2.0.8-py3-none-any.whl", hash = "sha256:c4c4259aaf04a7386ad85c7fdcb73c6c7146ca3057446b745cc035805acb1017", size = 369423, upload-time = "2025-05-27T21:23:15.609Z" }, -] - -[[package]] -name = "alembic" -version = "1.16.2" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "mako" }, - { name = "sqlalchemy" }, - { name = "tomli", marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "typing-extensions" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/9c/35/116797ff14635e496bbda0c168987f5326a6555b09312e9b817e360d1f56/alembic-1.16.2.tar.gz", hash = "sha256:e53c38ff88dadb92eb22f8b150708367db731d58ad7e9d417c9168ab516cbed8", size = 1963563, upload-time = "2025-06-16T18:05:08.566Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/dd/e2/88e425adac5ad887a087c38d04fe2030010572a3e0e627f8a6e8c33eeda8/alembic-1.16.2-py3-none-any.whl", hash = "sha256:5f42e9bd0afdbd1d5e3ad856c01754530367debdebf21ed6894e34af52b3bb03", size = 242717, upload-time = "2025-06-16T18:05:10.27Z" }, -] - -[[package]] -name = "altgraph" -version = "0.17.4" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/de/a8/7145824cf0b9e3c28046520480f207df47e927df83aa9555fb47f8505922/altgraph-0.17.4.tar.gz", hash = "sha256:1b5afbb98f6c4dcadb2e2ae6ab9fa994bbb8c1d75f4fa96d340f9437ae454406", size = 48418, upload-time = "2023-09-25T09:04:52.164Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/4d/3f/3bc3f1d83f6e4a7fcb834d3720544ca597590425be5ba9db032b2bf322a2/altgraph-0.17.4-py2.py3-none-any.whl", hash = "sha256:642743b4750de17e655e6711601b077bc6598dbfa3ba5fa2b2a35ce12b508dff", size = 21212, upload-time = "2023-09-25T09:04:50.691Z" }, -] - -[[package]] -name = "annotated-types" -version = "0.7.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/ee/67/531ea369ba64dcff5ec9c3402f9f51bf748cec26dde048a2f973a4eea7f5/annotated_types-0.7.0.tar.gz", hash = "sha256:aff07c09a53a08bc8cfccb9c85b05f1aa9a2a6f23728d790723543408344ce89", size = 16081, upload-time = "2024-05-20T21:33:25.928Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/78/b6/6307fbef88d9b5ee7421e68d78a9f162e0da4900bc5f5793f6d3d0e34fb8/annotated_types-0.7.0-py3-none-any.whl", hash = "sha256:1f02e8b43a8fbbc3f3e0d4f0f4bfc8131bcb4eebe8849b8e5c773f3a1c582a53", size = 13643, upload-time = "2024-05-20T21:33:24.1Z" }, -] - -[[package]] -name = "anthropic" -version = "0.54.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "anyio" }, - { name = "distro" }, - { name = "httpx" }, - { name = "jiter" }, - { name = "pydantic" }, - { name = "sniffio" }, - { name = "typing-extensions" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/89/28/80cb9bb6e7ce77d404145b51da4257455805c17f0a6be528ff3286e3882f/anthropic-0.54.0.tar.gz", hash = "sha256:5e6f997d97ce8e70eac603c3ec2e7f23addeff953fbbb76b19430562bb6ba815", size = 312376, upload-time = "2025-06-11T02:46:27.642Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/de/b9/6ffb48e82c5e97b03cecee872d134a6b6666c2767b2d32ed709f3a60a8fe/anthropic-0.54.0-py3-none-any.whl", hash = "sha256:c1062a0a905daeec17ca9c06c401e4b3f24cb0495841d29d752568a1d4018d56", size = 288774, upload-time = "2025-06-11T02:46:25.578Z" }, -] - -[[package]] -name = "anyio" -version = "4.9.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "exceptiongroup", marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "idna" }, - { name = "sniffio" }, - { name = "typing-extensions", marker = "python_full_version < '3.13' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/95/7d/4c1bd541d4dffa1b52bd83fb8527089e097a106fc90b467a7313b105f840/anyio-4.9.0.tar.gz", hash = "sha256:673c0c244e15788651a4ff38710fea9675823028a6f08a5eda409e0c9840a028", size = 190949, upload-time = "2025-03-17T00:02:54.77Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/a1/ee/48ca1a7c89ffec8b6a0c5d02b89c305671d5ffd8d3c94acf8b8c408575bb/anyio-4.9.0-py3-none-any.whl", hash = "sha256:9f76d541cad6e36af7beb62e978876f3b41e3e04f2c1fbf0884604c0a9c4d93c", size = 100916, upload-time = "2025-03-17T00:02:52.713Z" }, -] - -[[package]] -name = "astroid" -version = "3.3.10" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "typing-extensions", marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/00/c2/9b2de9ed027f9fe5734a6c0c0a601289d796b3caaf1e372e23fa88a73047/astroid-3.3.10.tar.gz", hash = "sha256:c332157953060c6deb9caa57303ae0d20b0fbdb2e59b4a4f2a6ba49d0a7961ce", size = 398941, upload-time = "2025-05-10T13:33:10.405Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/15/58/5260205b9968c20b6457ed82f48f9e3d6edf2f1f95103161798b73aeccf0/astroid-3.3.10-py3-none-any.whl", hash = "sha256:104fb9cb9b27ea95e847a94c003be03a9e039334a8ebca5ee27dafaf5c5711eb", size = 275388, upload-time = "2025-05-10T13:33:08.391Z" }, -] - -[[package]] -name = "async-timeout" -version = "5.0.1" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/a5/ae/136395dfbfe00dfc94da3f3e136d0b13f394cba8f4841120e34226265780/async_timeout-5.0.1.tar.gz", hash = "sha256:d9321a7a3d5a6a5e187e824d2fa0793ce379a202935782d555d6e9d2735677d3", size = 9274, upload-time = "2024-11-06T16:41:39.6Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/fe/ba/e2081de779ca30d473f21f5b30e0e737c438205440784c7dfc81efc2b029/async_timeout-5.0.1-py3-none-any.whl", hash = "sha256:39e3809566ff85354557ec2398b55e096c8364bacac9405a7a1fa429e77fe76c", size = 6233, upload-time = "2024-11-06T16:41:37.9Z" }, -] - -[[package]] -name = "attrs" -version = "25.3.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/5a/b0/1367933a8532ee6ff8d63537de4f1177af4bff9f3e829baf7331f595bb24/attrs-25.3.0.tar.gz", hash = "sha256:75d7cefc7fb576747b2c81b4442d4d4a1ce0900973527c011d1030fd3bf4af1b", size = 812032, upload-time = "2025-03-13T11:10:22.779Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/77/06/bb80f5f86020c4551da315d78b3ab75e8228f89f0162f2c3a819e407941a/attrs-25.3.0-py3-none-any.whl", hash = "sha256:427318ce031701fea540783410126f03899a97ffc6f61596ad581ac2e40e3bc3", size = 63815, upload-time = "2025-03-13T11:10:21.14Z" }, -] - -[[package]] -name = "av" -version = "14.4.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/86/f6/0b473dab52dfdea05f28f3578b1c56b6c796ce85e76951bab7c4e38d5a74/av-14.4.0.tar.gz", hash = "sha256:3ecbf803a7fdf67229c0edada0830d6bfaea4d10bfb24f0c3f4e607cd1064b42", size = 3892203, upload-time = "2025-05-16T19:13:35.737Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/34/0f/cf6b888747cd1e10eafc4a28942e5b666417c03c39853818900bdaa86116/av-14.4.0-cp310-cp310-macosx_12_0_arm64.whl", hash = "sha256:10219620699a65b9829cfa08784da2ed38371f1a223ab8f3523f440a24c8381c", size = 19979523, upload-time = "2025-05-16T19:08:59.751Z" }, - { url = "https://files.pythonhosted.org/packages/45/30/8f09ac71ad23344ff247f16a9229b36b1e2a36214fd56ba55df885e9bf85/av-14.4.0-cp310-cp310-macosx_12_0_x86_64.whl", hash = "sha256:8bac981fde1c05e231df9f73a06ed9febce1f03fb0f1320707ac2861bba2567f", size = 23765838, upload-time = "2025-05-16T19:09:02.362Z" }, - { url = "https://files.pythonhosted.org/packages/a2/57/e0c30ceb1e59e7b2b88c9cd6bf79a0a979128de19a94b300a700d3a7ca52/av-14.4.0-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:cc634ed5bdeb362f0523b73693b079b540418d35d7f3003654f788ae6c317eef", size = 33122039, upload-time = "2025-05-16T19:09:04.729Z" }, - { url = "https://files.pythonhosted.org/packages/c6/a7/9b3064c49f2d2219ee1b895cc77fca18c84d6121b51c8ce6b7f618a2661b/av-14.4.0-cp310-cp310-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:23973ed5c5bec9565094d2b3643f10a6996707ddffa5252e112d578ad34aa9ae", size = 31758563, upload-time = "2025-05-16T19:09:07.679Z" }, - { url = "https://files.pythonhosted.org/packages/23/42/0eafe0de75de6a0db71add8e4ea51ebf090482bad3068f4a874c90fbd110/av-14.4.0-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:0655f7207db6a211d7cedb8ac6a2f7ccc9c4b62290130e393a3fd99425247311", size = 34750358, upload-time = "2025-05-16T19:09:10.932Z" }, - { url = "https://files.pythonhosted.org/packages/75/33/5430ba9ad73036f2d69395d36f3d57b261c51db6f6542bcfc60087640bb7/av-14.4.0-cp310-cp310-musllinux_1_2_aarch64.whl", hash = "sha256:1edaab73319bfefe53ee09c4b1cf7b141ea7e6678a0a1c62f7bac1e2c68ec4e7", size = 35793636, upload-time = "2025-05-16T19:09:13.726Z" }, - { url = "https://files.pythonhosted.org/packages/00/a9/d8c07f0ab69be05a4939719d7a31dc3e9fb112ee8ec6c9411a6c9c085f0a/av-14.4.0-cp310-cp310-musllinux_1_2_i686.whl", hash = "sha256:b54838fa17c031ffd780df07b9962fac1be05220f3c28468f7fe49474f1bf8d2", size = 34123666, upload-time = "2025-05-16T19:09:16.968Z" }, - { url = "https://files.pythonhosted.org/packages/48/e1/2f2f607553f2ac6369e5fc814e77b41f9ceb285ce9d8c02c9ee034b8b6db/av-14.4.0-cp310-cp310-musllinux_1_2_x86_64.whl", hash = "sha256:f4b59ac6c563b9b6197299944145958a8ec34710799fd851f1a889b0cbcd1059", size = 36756157, upload-time = "2025-05-16T19:09:21.447Z" }, - { url = "https://files.pythonhosted.org/packages/d7/f0/d653d4eaa7e68732f8c0013aee40f31ff0cd49e90fdec89cca6c193db207/av-14.4.0-cp310-cp310-win_amd64.whl", hash = "sha256:a0192a584fae9f6cedfac03c06d5bf246517cdf00c8779bc33414404796a526e", size = 27931039, upload-time = "2025-05-16T19:09:24.739Z" }, - { url = "https://files.pythonhosted.org/packages/18/8a/d57418b686ffd05fabd5a0a9cfa97e63b38c35d7101af00e87c51c8cc43c/av-14.4.0-cp311-cp311-macosx_12_0_arm64.whl", hash = "sha256:5b21d5586a88b9fce0ab78e26bd1c38f8642f8e2aad5b35e619f4d202217c701", size = 19965048, upload-time = "2025-05-16T19:09:27.419Z" }, - { url = "https://files.pythonhosted.org/packages/f5/aa/3f878b0301efe587e9b07bb773dd6b47ef44ca09a3cffb4af50c08a170f3/av-14.4.0-cp311-cp311-macosx_12_0_x86_64.whl", hash = "sha256:cf8762d90b0f94a20c9f6e25a94f1757db5a256707964dfd0b1d4403e7a16835", size = 23750064, upload-time = "2025-05-16T19:09:30.012Z" }, - { url = "https://files.pythonhosted.org/packages/9a/b4/6fe94a31f9ed3a927daa72df67c7151968587106f30f9f8fcd792b186633/av-14.4.0-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:c0ac9f08920c7bbe0795319689d901e27cb3d7870b9a0acae3f26fc9daa801a6", size = 33648775, upload-time = "2025-05-16T19:09:33.811Z" }, - { url = "https://files.pythonhosted.org/packages/6c/f3/7f3130753521d779450c935aec3f4beefc8d4645471159f27b54e896470c/av-14.4.0-cp311-cp311-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:a56d9ad2afdb638ec0404e962dc570960aae7e08ae331ad7ff70fbe99a6cf40e", size = 32216915, upload-time = "2025-05-16T19:09:36.99Z" }, - { url = "https://files.pythonhosted.org/packages/f8/9a/8ffabfcafb42154b4b3a67d63f9b69e68fa8c34cb39ddd5cb813dd049ed4/av-14.4.0-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:6bed513cbcb3437d0ae47743edc1f5b4a113c0b66cdd4e1aafc533abf5b2fbf2", size = 35287279, upload-time = "2025-05-16T19:09:39.711Z" }, - { url = "https://files.pythonhosted.org/packages/ad/11/7023ba0a2ca94a57aedf3114ab8cfcecb0819b50c30982a4c5be4d31df41/av-14.4.0-cp311-cp311-musllinux_1_2_aarch64.whl", hash = "sha256:d030c2d3647931e53d51f2f6e0fcf465263e7acf9ec6e4faa8dbfc77975318c3", size = 36294683, upload-time = "2025-05-16T19:09:42.668Z" }, - { url = "https://files.pythonhosted.org/packages/3d/fa/b8ac9636bd5034e2b899354468bef9f4dadb067420a16d8a493a514b7817/av-14.4.0-cp311-cp311-musllinux_1_2_i686.whl", hash = "sha256:1cc21582a4f606271d8c2036ec7a6247df0831050306c55cf8a905701d0f0474", size = 34552391, upload-time = "2025-05-16T19:09:46.852Z" }, - { url = "https://files.pythonhosted.org/packages/fb/29/0db48079c207d1cba7a2783896db5aec3816e17de55942262c244dffbc0f/av-14.4.0-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:ce7c9cd452153d36f1b1478f904ed5f9ab191d76db873bdd3a597193290805d4", size = 37265250, upload-time = "2025-05-16T19:09:50.013Z" }, - { url = "https://files.pythonhosted.org/packages/1c/55/715858c3feb7efa4d667ce83a829c8e6ee3862e297fb2b568da3f968639d/av-14.4.0-cp311-cp311-win_amd64.whl", hash = "sha256:fd261e31cc6b43ca722f80656c39934199d8f2eb391e0147e704b6226acebc29", size = 27925845, upload-time = "2025-05-16T19:09:52.663Z" }, - { url = "https://files.pythonhosted.org/packages/a6/75/b8641653780336c90ba89e5352cac0afa6256a86a150c7703c0b38851c6d/av-14.4.0-cp312-cp312-macosx_12_0_arm64.whl", hash = "sha256:a53e682b239dd23b4e3bc9568cfb1168fc629ab01925fdb2e7556eb426339e94", size = 19954125, upload-time = "2025-05-16T19:09:54.909Z" }, - { url = "https://files.pythonhosted.org/packages/99/e6/37fe6fa5853a48d54d749526365780a63a4bc530be6abf2115e3a21e292a/av-14.4.0-cp312-cp312-macosx_12_0_x86_64.whl", hash = "sha256:5aa0b901751a32703fa938d2155d56ce3faf3630e4a48d238b35d2f7e49e5395", size = 23751479, upload-time = "2025-05-16T19:09:57.113Z" }, - { url = "https://files.pythonhosted.org/packages/f7/75/9a5f0e6bda5f513b62bafd1cff2b495441a8b07ab7fb7b8e62f0c0d1683f/av-14.4.0-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:a3b316fed3597675fe2aacfed34e25fc9d5bb0196dc8c0b014ae5ed4adda48de", size = 33801401, upload-time = "2025-05-16T19:09:59.479Z" }, - { url = "https://files.pythonhosted.org/packages/6a/c9/e4df32a2ad1cb7f3a112d0ed610c5e43c89da80b63c60d60e3dc23793ec0/av-14.4.0-cp312-cp312-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:a587b5c5014c3c0e16143a0f8d99874e46b5d0c50db6111aa0b54206b5687c81", size = 32364330, upload-time = "2025-05-16T19:10:02.111Z" }, - { url = "https://files.pythonhosted.org/packages/ca/f0/64e7444a41817fde49a07d0239c033f7e9280bec4a4bb4784f5c79af95e6/av-14.4.0-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:10d53f75e8ac1ec8877a551c0db32a83c0aaeae719d05285281eaaba211bbc30", size = 35519508, upload-time = "2025-05-16T19:10:05.008Z" }, - { url = "https://files.pythonhosted.org/packages/c2/a8/a370099daa9033a3b6f9b9bd815304b3d8396907a14d09845f27467ba138/av-14.4.0-cp312-cp312-musllinux_1_2_aarch64.whl", hash = "sha256:c8558cfde79dd8fc92d97c70e0f0fa8c94c7a66f68ae73afdf58598f0fe5e10d", size = 36448593, upload-time = "2025-05-16T19:10:07.887Z" }, - { url = "https://files.pythonhosted.org/packages/27/bb/edb6ceff8fa7259cb6330c51dbfbc98dd1912bd6eb5f7bc05a4bb14a9d6e/av-14.4.0-cp312-cp312-musllinux_1_2_i686.whl", hash = "sha256:455b6410dea0ab2d30234ffb28df7d62ca3cdf10708528e247bec3a4cdcced09", size = 34701485, upload-time = "2025-05-16T19:10:10.886Z" }, - { url = "https://files.pythonhosted.org/packages/a7/8a/957da1f581aa1faa9a5dfa8b47ca955edb47f2b76b949950933b457bfa1d/av-14.4.0-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:1661efbe9d975f927b8512d654704223d936f39016fad2ddab00aee7c40f412c", size = 37521981, upload-time = "2025-05-16T19:10:13.678Z" }, - { url = "https://files.pythonhosted.org/packages/28/76/3f1cf0568592f100fd68eb40ed8c491ce95ca3c1378cc2d4c1f6d1bd295d/av-14.4.0-cp312-cp312-win_amd64.whl", hash = "sha256:fbbeef1f421a3461086853d6464ad5526b56ffe8ccb0ab3fd0a1f121dfbf26ad", size = 27925944, upload-time = "2025-05-16T19:10:16.485Z" }, - { url = "https://files.pythonhosted.org/packages/12/4c/b0205f77352312ff457ecdf31723dbf4403b7a03fc1659075d6d32f23ef7/av-14.4.0-cp313-cp313-macosx_12_0_arm64.whl", hash = "sha256:3d2aea7c602b105363903e4017103bc4b60336e7aff80e1c22e8b4ec09fd125f", size = 19917341, upload-time = "2025-05-16T19:10:18.826Z" }, - { url = "https://files.pythonhosted.org/packages/e1/c4/9e783bd7d47828e9c67f9c773c99de45c5ae01b3e942f1abf6cbaf530267/av-14.4.0-cp313-cp313-macosx_12_0_x86_64.whl", hash = "sha256:38c18f036aeb6dc9abf5e867d998c867f9ec93a5f722b60721fdffc123bbb2ae", size = 23715363, upload-time = "2025-05-16T19:10:21.42Z" }, - { url = "https://files.pythonhosted.org/packages/b5/26/b2b406a676864d06b1c591205782d8527e7c99e5bc51a09862c3576e0087/av-14.4.0-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:58c1e18c8be73b6eada2d9ec397852ec74ebe51938451bdf83644a807189d6c8", size = 33496968, upload-time = "2025-05-16T19:10:24.178Z" }, - { url = "https://files.pythonhosted.org/packages/89/09/0a032bbe30c7049fca243ec8cf01f4be49dd6e7f7b9c3c7f0cc13f83c9d3/av-14.4.0-cp313-cp313-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:e4c32ff03a357feb030634f093089a73cb474b04efe7fbfba31f229cb2fab115", size = 32075498, upload-time = "2025-05-16T19:10:27.384Z" }, - { url = "https://files.pythonhosted.org/packages/0b/1f/0fee20f74c1f48086366e59dbd37fa0684cd0f3c782a65cbb719d26c7acd/av-14.4.0-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:af31d16ae25964a6a02e09cc132b9decd5ee493c5dcb21bcdf0d71b2d6adbd59", size = 35224910, upload-time = "2025-05-16T19:10:30.104Z" }, - { url = "https://files.pythonhosted.org/packages/9e/19/1c4a201c75a2a431a85a43fd15d1fad55a28c22d596461d861c8d70f9b92/av-14.4.0-cp313-cp313-musllinux_1_2_aarch64.whl", hash = "sha256:e9fb297009e528f4851d25f3bb2781b2db18b59b10aed10240e947b77c582fb7", size = 36172918, upload-time = "2025-05-16T19:10:32.789Z" }, - { url = "https://files.pythonhosted.org/packages/00/48/26b7e5d911c807f5f017a285362470ba16f44e8ea46f8b09ab5e348dd15b/av-14.4.0-cp313-cp313-musllinux_1_2_i686.whl", hash = "sha256:573314cb9eafec2827dc98c416c965330dc7508193adbccd281700d8673b9f0a", size = 34414492, upload-time = "2025-05-16T19:10:36.023Z" }, - { url = "https://files.pythonhosted.org/packages/6d/26/2f4badfa5b5b7b8f5f83d562b143a83ed940fa458eea4cad495ce95c9741/av-14.4.0-cp313-cp313-musllinux_1_2_x86_64.whl", hash = "sha256:f82ab27ee57c3b80eb50a5293222307dfdc02f810ea41119078cfc85ea3cf9a8", size = 37245826, upload-time = "2025-05-16T19:10:39.562Z" }, - { url = "https://files.pythonhosted.org/packages/f4/02/88dbb6f5a05998b730d2e695b05060297af127ac4250efbe0739daa446d5/av-14.4.0-cp313-cp313-win_amd64.whl", hash = "sha256:9f682003bbcaac620b52f68ff0e85830fff165dea53949e217483a615993ca20", size = 27898395, upload-time = "2025-05-16T19:13:02.653Z" }, -] - -[[package]] -name = "backoff" -version = "2.2.1" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/47/d7/5bbeb12c44d7c4f2fb5b56abce497eb5ed9f34d85701de869acedd602619/backoff-2.2.1.tar.gz", hash = "sha256:03f829f5bb1923180821643f8753b0502c3b682293992485b0eef2807afa5cba", size = 17001, upload-time = "2022-10-05T19:19:32.061Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/df/73/b6e24bd22e6720ca8ee9a85a0c4a2971af8497d8f3193fa05390cbd46e09/backoff-2.2.1-py3-none-any.whl", hash = "sha256:63579f9a0628e06278f7e47b7d7d5b6ce20dc65c5e96a6f3ca99a6adca0396e8", size = 15148, upload-time = "2022-10-05T19:19:30.546Z" }, -] - -[[package]] -name = "can-ada" -version = "2.0.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/6c/62/5bd057d07a3b9b2cd7d5a5fb36e9ba7c32e8d50be99379234ba5a25e8ec7/can_ada-2.0.0.tar.gz", hash = "sha256:ce24e9c6c57a34cacf22087955918a9049bff096477271b0eb695980e416d17b", size = 167011, upload-time = "2025-01-30T04:45:39.375Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/c3/ed/35701f50c43355adf399c05a3cefb75d71670c087648b17efb0d549f4f5b/can_ada-2.0.0-cp310-cp310-macosx_10_15_universal2.whl", hash = "sha256:9e62c43b4fd92f701e1095c7eef8701a8540f48a48fb39749efba41190fa5594", size = 557500, upload-time = "2025-01-30T04:43:42.963Z" }, - { url = "https://files.pythonhosted.org/packages/e4/c2/c57819558cb81f695e100b9fb374b9fff81d150a0a9b9ce29411103ccca5/can_ada-2.0.0-cp310-cp310-macosx_10_15_x86_64.whl", hash = "sha256:5272c0b5c1ee894f397099aa8c8eb47915dc1369e3af3d23da20b56a2fd105a1", size = 285204, upload-time = "2025-01-30T04:43:45.091Z" }, - { url = "https://files.pythonhosted.org/packages/b8/b4/bfdb5dbd646965a7da702ee0738ce2206fad51bc5be5c8a2f8c55d873a1f/can_ada-2.0.0-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:c3ebe81be329c38861c5b6f1f5435c331b099771d41b7cb601ade3d016b4767d", size = 276480, upload-time = "2025-01-30T04:43:46.958Z" }, - { url = "https://files.pythonhosted.org/packages/d7/c1/9fdbbf88be2626d046b94176f837cddea3afa7f2400c9883059cf1667e17/can_ada-2.0.0-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:4eb826e5688707a6fa3764c60660528ad7082a10be516fb161d12ffd1ae848c1", size = 329951, upload-time = "2025-01-30T04:43:48.455Z" }, - { url = "https://files.pythonhosted.org/packages/ca/0b/837213e8e32a8cc3c46ad9f19083e972a49cf88733c7e0f9731999be492b/can_ada-2.0.0-cp310-cp310-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:94e68536fc6ad80744a6819cd9b174f0b5063b57eaddc185934c7ff20121a0a3", size = 363219, upload-time = "2025-01-30T04:43:50.281Z" }, - { url = "https://files.pythonhosted.org/packages/16/b2/ed6c0ae136ac6b30603d5671b37e38863f6ee2c7f711ce6d89a57ccd9077/can_ada-2.0.0-cp310-cp310-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:300247f6dfd9f8b0e8c7137da034f54ed094292ce9aa0da2ab73f731fd8786b6", size = 370413, upload-time = "2025-01-30T04:43:51.591Z" }, - { url = "https://files.pythonhosted.org/packages/3e/f2/5a547aa2afc1705b1db6133e3b32361206fb7c923635169322a3684c705d/can_ada-2.0.0-cp310-cp310-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:113a97c26496fbfdaf0375e3ebf1b24c04ba172e23058e3e4f254b5e831cc56c", size = 346557, upload-time = "2025-01-30T04:43:53.974Z" }, - { url = "https://files.pythonhosted.org/packages/ff/78/f6333db3f6d93c25b0c6d7a2594c1bd0f86d11ee8cbbfb9d0317c84368f4/can_ada-2.0.0-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:830ad534f3d8e81dd561d043b5e570b18c32475f42993f1b58116f9e49bc72cf", size = 339339, upload-time = "2025-01-30T04:43:55.288Z" }, - { url = "https://files.pythonhosted.org/packages/76/fb/d59e4b7eb59a7d20a05854a3ed433fbcdb3603967012cc0d5fe300377d21/can_ada-2.0.0-cp310-cp310-musllinux_1_2_aarch64.whl", hash = "sha256:2e7b98ab57b0078894a0cc1833f78df4ca22fe3902e3b29ca397d748ed5448c8", size = 1264929, upload-time = "2025-01-30T04:43:56.59Z" }, - { url = "https://files.pythonhosted.org/packages/17/c6/6be4fe5c756f978243a9a33d25c721b54fc53e33a3f1d38a9aaca0442e85/can_ada-2.0.0-cp310-cp310-musllinux_1_2_i686.whl", hash = "sha256:fe347799fafdebad6643df82379ca6536296d2f80035027d5aff32f8b67e43b0", size = 1476609, upload-time = "2025-01-30T04:43:57.899Z" }, - { url = "https://files.pythonhosted.org/packages/84/69/9ae7e3c863f790abc1fe71b569a52ef5bf351e23454e0c2aa8604bacff31/can_ada-2.0.0-cp310-cp310-musllinux_1_2_ppc64le.whl", hash = "sha256:e0414664e57b9c8ebc3860d3ee23a7e31b649b94437b098c751e6c0df4d7fb11", size = 1387901, upload-time = "2025-01-30T04:43:59.038Z" }, - { url = "https://files.pythonhosted.org/packages/ff/2c/74ab65b7a8b90e9c7e52e9f1d137933f9f4e4f95ebca828e65d21829c5ed/can_ada-2.0.0-cp310-cp310-musllinux_1_2_s390x.whl", hash = "sha256:51da42b01d5300aeb4a1bda92c08266133eb6df8e4f2f8634223689f1bd66e41", size = 1484665, upload-time = "2025-01-30T04:44:01.091Z" }, - { url = "https://files.pythonhosted.org/packages/2a/36/1a11a126f4a77375d6340208064eb9fe857b0627436f9faa48d6b4170bd9/can_ada-2.0.0-cp310-cp310-musllinux_1_2_x86_64.whl", hash = "sha256:45222855a8c4ed88f54036a5683997136126a55e121c4a9b654d72c0865d9205", size = 1359407, upload-time = "2025-01-30T04:44:04.384Z" }, - { url = "https://files.pythonhosted.org/packages/4f/de/3b20ce870b2ff7367eb20c09cc83c6af44d1c360ffa00ddf02607bbaf1a3/can_ada-2.0.0-cp310-cp310-win32.whl", hash = "sha256:d2ba703c7802222b4a49428dd46f7fed0ea44e32a3faabc3ecc4bd38ca13b345", size = 207418, upload-time = "2025-01-30T04:44:06.296Z" }, - { url = "https://files.pythonhosted.org/packages/96/71/6f4ecfb3822da570eb70af71712dedbbc4e8d7ce920347458119e5c3c158/can_ada-2.0.0-cp310-cp310-win_amd64.whl", hash = "sha256:c8cf0c0abcc688f491819f35d0aa5f7eba2ec235297630280dcdcec0fe3502d0", size = 228179, upload-time = "2025-01-30T04:44:07.373Z" }, - { url = "https://files.pythonhosted.org/packages/1e/f1/da78751db13bdcea95c110a0b4f6ee5ed52e4aa1fd8ec7c7eb8996a9ddb0/can_ada-2.0.0-cp311-cp311-macosx_10_15_universal2.whl", hash = "sha256:6c7e4558356ea08e2bc2edbc9a8272f9d0f92cbdad4271b36e19a5b9b7c310aa", size = 560483, upload-time = "2025-01-30T04:44:08.529Z" }, - { url = "https://files.pythonhosted.org/packages/c8/71/9e6ce99669bca14846972ecef55dfdf94f36f175c3db7a2b21cdcc2f04bf/can_ada-2.0.0-cp311-cp311-macosx_10_15_x86_64.whl", hash = "sha256:e7d67f9a50b0621f835238275452a85dc15831a0b515130db49db134f2887045", size = 286399, upload-time = "2025-01-30T04:44:09.594Z" }, - { url = "https://files.pythonhosted.org/packages/23/91/8852850f0128a2164c906aa4de8d94fbe519faa6f5c6ec8c8db1d5a4ea36/can_ada-2.0.0-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:6521529ece1fbe6ce29fd9d306dc3c756281917aa6d99f327c4ac74d718ea8de", size = 277543, upload-time = "2025-01-30T04:44:11.321Z" }, - { url = "https://files.pythonhosted.org/packages/f6/6a/d8699b5be5bcbc00dcf8e62ac04edba03e44c2cab723ce2a11b3508ed2fb/can_ada-2.0.0-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:d98795e6c36aad2bb41a895296ffe2188ebeb6a9c68a63a0fc6b84087701a4b4", size = 331606, upload-time = "2025-01-30T04:44:13.143Z" }, - { url = "https://files.pythonhosted.org/packages/80/07/c87a8560e516635b17eb30dcd43ce9d01ea2bbf8fdcb92a191363b16160f/can_ada-2.0.0-cp311-cp311-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:1745bbfbd59c20a4175a178f4af042d12d8f1f2d1e2dd732ff19bf119fe01565", size = 364171, upload-time = "2025-01-30T04:44:14.191Z" }, - { url = "https://files.pythonhosted.org/packages/3e/68/9814893a2f3a2bc61537f2ae39f0363dfa883f12831cc39fc965164aa06d/can_ada-2.0.0-cp311-cp311-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:a6b8f8339faf5ccd7855c1d0a5f8bba4c5c79279deab8109a9ccaaddc0ad18c4", size = 371516, upload-time = "2025-01-30T04:44:17.057Z" }, - { url = "https://files.pythonhosted.org/packages/76/8b/f9d582092c8fb1a0e96ad9d006b613533e9f72d605dcaf3855345c3373f7/can_ada-2.0.0-cp311-cp311-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:23a0744a3b8e650a577a678c5fe2f5af4aca520731cba23e22983a6a1a9fcd8a", size = 347664, upload-time = "2025-01-30T04:44:18.275Z" }, - { url = "https://files.pythonhosted.org/packages/b4/ed/a4d5b492ba8624954fad5d83c0905aee386df24ebf05a54760031ac88472/can_ada-2.0.0-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:0dbc6b40044270b8ec8ef6ea5c64d98e1b10fe61691447048cff57ff1fe0edaf", size = 341216, upload-time = "2025-01-30T04:44:19.401Z" }, - { url = "https://files.pythonhosted.org/packages/9b/32/2de99e41d8015c2408b3bf3f6f68a635b9615cd66f34d344a33de72cbb00/can_ada-2.0.0-cp311-cp311-musllinux_1_2_aarch64.whl", hash = "sha256:33a2b4b7a83c21de0bddbffe2c835ff9f66a3fa0e2e7b25693d94851a72b0489", size = 1266598, upload-time = "2025-01-30T04:44:20.458Z" }, - { url = "https://files.pythonhosted.org/packages/c4/12/a981aacd69f58d1be90ad664105646e734929c0dbcf6e0a215bb5cf13a9f/can_ada-2.0.0-cp311-cp311-musllinux_1_2_i686.whl", hash = "sha256:b1cf75fd82da06fc0ac9fa99eea32bf6cbb91781466cc73f5ff206f558cd9939", size = 1477013, upload-time = "2025-01-30T04:44:22.321Z" }, - { url = "https://files.pythonhosted.org/packages/96/c8/2fe6f7c949a33d7f4fa2b530e969bf42054f7d864347934b9d171cef61f3/can_ada-2.0.0-cp311-cp311-musllinux_1_2_ppc64le.whl", hash = "sha256:816c5dc23e73631c79f587c578838e8714a6d245caa060e26a3220759b7f66fa", size = 1389020, upload-time = "2025-01-30T04:44:23.607Z" }, - { url = "https://files.pythonhosted.org/packages/43/83/4565467f71773cf5db739174d19d1c1c5985027e518c1570c0e92ecbe8fd/can_ada-2.0.0-cp311-cp311-musllinux_1_2_s390x.whl", hash = "sha256:508a5de8b04e86443afdbc2277b919a13fb17dd5cd30a0e1a6afa4738c946a91", size = 1486417, upload-time = "2025-01-30T04:44:25.782Z" }, - { url = "https://files.pythonhosted.org/packages/20/5b/7fbc5aca5d2faf209d452b7c1fbf37f0d467a22a3ee017ac0dcc0c9dabec/can_ada-2.0.0-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:11fe3b5b7b99e1c23a8f5477560e4a352fd8db8450c7695b71fef6c842e43e07", size = 1360887, upload-time = "2025-01-30T04:44:27.093Z" }, - { url = "https://files.pythonhosted.org/packages/47/0c/044292a0442b0e0203965c38fd61dd8616db59e02645ce628d9eb7d1c7d5/can_ada-2.0.0-cp311-cp311-win32.whl", hash = "sha256:ebc83b0faa36a9b5618bbf604026983403abbca8ace4f26331913810d69eeb55", size = 208472, upload-time = "2025-01-30T04:44:28.477Z" }, - { url = "https://files.pythonhosted.org/packages/13/45/bdc620310edd8b9864af8407a339cd42a925017b218bec2c47413118b0ab/can_ada-2.0.0-cp311-cp311-win_amd64.whl", hash = "sha256:1c730502997b0c2d994889bfb4977f032f180a14123ec02d9fceb8fc1576cde3", size = 229616, upload-time = "2025-01-30T04:44:29.46Z" }, - { url = "https://files.pythonhosted.org/packages/65/ab/ff55595a6ae942ca6635fcbcc49caee615f51c8eae313b50ad4aa1f64381/can_ada-2.0.0-cp312-cp312-macosx_10_15_universal2.whl", hash = "sha256:9e16efa8eefc23c06fb8175243cddd678151fc183b16eac12ac8d5e3fa128733", size = 559409, upload-time = "2025-01-30T04:44:30.47Z" }, - { url = "https://files.pythonhosted.org/packages/c0/72/239ae8e5e555dcc442a19c043cd12bcacd3cc735bf50aaa41f38ffcaf9dd/can_ada-2.0.0-cp312-cp312-macosx_10_15_x86_64.whl", hash = "sha256:3df467dca36a54505fd8f86404bc181ddfad1a30327774dcd671a5c6cc0e2700", size = 286387, upload-time = "2025-01-30T04:44:31.616Z" }, - { url = "https://files.pythonhosted.org/packages/84/52/328b5d8b3b877a0b99326bd3489cabfce8b8d44ead44062850f69e5179e5/can_ada-2.0.0-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:8347a8a35ccd3a57667546a3ca58a397713f79ae0df076a5cc790ab9683a4a52", size = 277009, upload-time = "2025-01-30T04:44:32.694Z" }, - { url = "https://files.pythonhosted.org/packages/bf/52/7e28b6aa3dcbbaecf71fa1ccf0fd891dd0f5a01b4ca5f0ed25ea1fe336d8/can_ada-2.0.0-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:7221323fbd84f8d0597797f6aea423abbed1b46bac61b30cd731915c458302eb", size = 330919, upload-time = "2025-01-30T04:44:33.733Z" }, - { url = "https://files.pythonhosted.org/packages/f8/f0/0f9e6a85be214409e07f4c3fd00f761ad4c533a23fb0166c0a6fd62b24c6/can_ada-2.0.0-cp312-cp312-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:e2553c403ebb419ae23d589be2ba760da0872b2d7275ab638521802a5189a339", size = 363324, upload-time = "2025-01-30T04:44:35.665Z" }, - { url = "https://files.pythonhosted.org/packages/c8/4a/cfb365cda767bbbf866d52e63476c4bccecbffb4e99e0ce463ed186713a6/can_ada-2.0.0-cp312-cp312-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:efa67828186538bade215af0203419e6dc04244078090c60cdf1d9737ef418f2", size = 368723, upload-time = "2025-01-30T04:44:37.412Z" }, - { url = "https://files.pythonhosted.org/packages/83/02/38582c70c0ce03dd5e9bc194159cef389a26a555dc2355208203b5960d6c/can_ada-2.0.0-cp312-cp312-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:72295f8651cb6c51e345b0315db32af0b5d712bea0be5e4bf1a86d89d1771fc7", size = 346252, upload-time = "2025-01-30T04:44:38.533Z" }, - { url = "https://files.pythonhosted.org/packages/b8/7e/e44e91d9f0e8e63af94b7e3aa9a726541550244077e537270fa1a4c8eeca/can_ada-2.0.0-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:8a1309b8844e809716404a404f115f783dbccace8eb5411a2801f1d6615e3613", size = 340720, upload-time = "2025-01-30T04:44:40.3Z" }, - { url = "https://files.pythonhosted.org/packages/af/70/9098fe7891cdd6a71961df0e3fed5d42c7dfd18501fdf16dddf3437331a2/can_ada-2.0.0-cp312-cp312-musllinux_1_2_aarch64.whl", hash = "sha256:38f46f453b2e432c088f491135f770bc36dff68148d5964f3d368ad0fa71ef03", size = 1266387, upload-time = "2025-01-30T04:44:41.608Z" }, - { url = "https://files.pythonhosted.org/packages/0c/97/df9cf1e8966cfaeb274b0345f00193fa794e8bfd4e3a2987884309a99f87/can_ada-2.0.0-cp312-cp312-musllinux_1_2_i686.whl", hash = "sha256:f363dbb3ae2ea82b2f105b36d4e8b708f062096cf22122b2bedddc2694d7b99b", size = 1476769, upload-time = "2025-01-30T04:44:42.908Z" }, - { url = "https://files.pythonhosted.org/packages/d8/88/14d0dfbdae2ee13d460cdfb0d2329e98007ec09d5f4f6c45597044f5d081/can_ada-2.0.0-cp312-cp312-musllinux_1_2_ppc64le.whl", hash = "sha256:9b0da1a7d08e4c3358ce855abe9ab8ee62124d139d5d2f56627d0455a2174a02", size = 1388504, upload-time = "2025-01-30T04:44:44.108Z" }, - { url = "https://files.pythonhosted.org/packages/d9/64/ace495b1e4f47ad3a1f187bff8fa596b91230e42351f93d0768a6a2ccd99/can_ada-2.0.0-cp312-cp312-musllinux_1_2_s390x.whl", hash = "sha256:243af714826d2ddf16ad8e7ea56550215f1f31b96ef59ffcaaab988c12b3cdf4", size = 1485779, upload-time = "2025-01-30T04:44:45.275Z" }, - { url = "https://files.pythonhosted.org/packages/62/1c/de8f0e336acb328b3dc7bc6e825f15bebdcc19c44a4e17b5dec39325a03e/can_ada-2.0.0-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:2d612a2ab4a4fabf9aadc260bccb99ad376ffc0a9c4fc69f80943e77305dbc2f", size = 1360394, upload-time = "2025-01-30T04:44:46.591Z" }, - { url = "https://files.pythonhosted.org/packages/d4/74/218650bec65fa7fb7fc67f7b7961f7dc31d6bf38539e3419098550830571/can_ada-2.0.0-cp312-cp312-win32.whl", hash = "sha256:544e7663b562b190b87babaa6369e698648aa15de3aa54260ced6d0a7bc3e766", size = 207747, upload-time = "2025-01-30T04:44:47.773Z" }, - { url = "https://files.pythonhosted.org/packages/66/d0/30396a87504fe1a4f685655a236d5629a86db977704734c2f57080ccf23b/can_ada-2.0.0-cp312-cp312-win_amd64.whl", hash = "sha256:ce91efa707dd4ced4a103cfe9cfd5526a048cfb11be0dfd43783341a054590c5", size = 229830, upload-time = "2025-01-30T04:44:48.713Z" }, - { url = "https://files.pythonhosted.org/packages/24/3e/87794b9cddafc8de54bcd6dfd4ba058e2f7d2c222ec48697767dab0dead0/can_ada-2.0.0-cp313-cp313-macosx_10_15_universal2.whl", hash = "sha256:21d05fe8fd899cb6db2299a936003f41c0a436b25cbaa11b82ea4046a2d4a8a2", size = 559699, upload-time = "2025-01-30T04:44:50.659Z" }, - { url = "https://files.pythonhosted.org/packages/b5/e8/2398b855e440f1309120d56d04b1cee1a48896293efa55afc4ae92ac932c/can_ada-2.0.0-cp313-cp313-macosx_10_15_x86_64.whl", hash = "sha256:9bc0266bd8f5f146ef3b3340305fc3da6aa2b3f9333d26f722daf527aae815eb", size = 286451, upload-time = "2025-01-30T04:44:52.511Z" }, - { url = "https://files.pythonhosted.org/packages/64/c7/db8a22da721dcff4ae89aee9d8891f89c9d88e2ced5571e24c289c492bc3/can_ada-2.0.0-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:cf55ab4a398f18350cd645cb9fea8ecadf460403c92d56a98b2b8e2dbcdae82f", size = 277180, upload-time = "2025-01-30T04:44:53.699Z" }, - { url = "https://files.pythonhosted.org/packages/3b/e6/70d7c3377946578fbf8e351b724851043804ca4dc2b7d63175ecac3e2faf/can_ada-2.0.0-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:04d78d8929e984d740ae2e43305a90fdf0cb214d157f2e5a408178238028727a", size = 331790, upload-time = "2025-01-30T04:44:54.85Z" }, - { url = "https://files.pythonhosted.org/packages/c7/29/914d6106a471edef5f20e2f8780f345802baca49d4e60d2e2bb96af716d8/can_ada-2.0.0-cp313-cp313-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:f83a5d8ed196beb1dcbd327b443138de5112cc5fb6c5fe8130720e637e62ddec", size = 363413, upload-time = "2025-01-30T04:44:56.774Z" }, - { url = "https://files.pythonhosted.org/packages/f8/47/7532bc788a5792897adf56e55efcdf67af71694c9804c53ebf26f94b10a7/can_ada-2.0.0-cp313-cp313-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:00cdf5ad7fec8dc5afa6079e5f08bf3e42825b3db733a3c8ccda8dcafe72d55c", size = 368939, upload-time = "2025-01-30T04:44:58.065Z" }, - { url = "https://files.pythonhosted.org/packages/a7/8a/83742728089112dc7cec8deca65d440f317b71223c4e752b4d68032a2cec/can_ada-2.0.0-cp313-cp313-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:9efd25afddd39ea16d84d4e4e803ae0fec8c680e1f1e735f72ceb2b8f204e046", size = 346271, upload-time = "2025-01-30T04:45:00.336Z" }, - { url = "https://files.pythonhosted.org/packages/99/3e/52b59235233f374f7a233339856d4b291cf9b2b8e71693d60f86e9cf8fa9/can_ada-2.0.0-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:01738bf63d97f87eeb64a5bd1b87f1f7fc49afeffb69975038b49fa1e19e3466", size = 340688, upload-time = "2025-01-30T04:45:01.442Z" }, - { url = "https://files.pythonhosted.org/packages/ef/cd/acf542120b278888f99b08616440554bd4c99ee3df3d2561d3f983777f9e/can_ada-2.0.0-cp313-cp313-musllinux_1_2_aarch64.whl", hash = "sha256:00131e1300c57aedb7641f71c3c6f4cf666c49976edc6b72450b9ab3c2d6f39c", size = 1266424, upload-time = "2025-01-30T04:45:02.579Z" }, - { url = "https://files.pythonhosted.org/packages/dc/23/3546ffd915160ceb85368f1da129372813afb64df518ab9854a313beeba2/can_ada-2.0.0-cp313-cp313-musllinux_1_2_i686.whl", hash = "sha256:ef8b3c490c4a87c738a69d35035d3baae6526f9fc1610e69aa2a25fc6ed075c6", size = 1476971, upload-time = "2025-01-30T04:45:03.906Z" }, - { url = "https://files.pythonhosted.org/packages/58/2c/c954e82b59573c4524bdcf6a06f609d0ea5c0c5e7542f94e5382a8c72b5e/can_ada-2.0.0-cp313-cp313-musllinux_1_2_ppc64le.whl", hash = "sha256:847d2c67e58a565487846a211e26d743acc9b70017a0329f98659fc8394cead1", size = 1388443, upload-time = "2025-01-30T04:45:05.107Z" }, - { url = "https://files.pythonhosted.org/packages/97/4f/80ec8a0e62f37817e07ebcf85c381e17731a80a4cd5cc25e325ed6dc71c4/can_ada-2.0.0-cp313-cp313-musllinux_1_2_s390x.whl", hash = "sha256:40d0d78c506fb90dd70a06451c756cd2e781c0c62ad49d70b6a73e1da381e33c", size = 1485730, upload-time = "2025-01-30T04:45:07.074Z" }, - { url = "https://files.pythonhosted.org/packages/b8/42/fce4511d18436e3f9631fa6be62adc7bc66c2978a1e402543342e405c5be/can_ada-2.0.0-cp313-cp313-musllinux_1_2_x86_64.whl", hash = "sha256:a30c1514eebb51995529b69553b1f291cebe4d536e7a2a0bf8d638537132bbd9", size = 1360241, upload-time = "2025-01-30T04:45:08.386Z" }, - { url = "https://files.pythonhosted.org/packages/60/db/ee7c46bbd73dfc4a20b52def9101f5137fc47e5fceca4c52e640a2aa4870/can_ada-2.0.0-cp313-cp313-win32.whl", hash = "sha256:43931273322a4a3243d495d84adf2df469b6dbc2b4ed34c8f2d6d65d1ffc7188", size = 207867, upload-time = "2025-01-30T04:45:09.7Z" }, - { url = "https://files.pythonhosted.org/packages/70/1c/fea09d9707b58afa9192fb27805fc653cecca19e01eb2881d0bccc647346/can_ada-2.0.0-cp313-cp313-win_amd64.whl", hash = "sha256:a15c3ee2a08002ff5843b558b0aba1ed34e9459c7edacec7882f6089613cf853", size = 229959, upload-time = "2025-01-30T04:45:10.838Z" }, -] - -[[package]] -name = "certifi" -version = "2025.6.15" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/73/f7/f14b46d4bcd21092d7d3ccef689615220d8a08fb25e564b65d20738e672e/certifi-2025.6.15.tar.gz", hash = "sha256:d747aa5a8b9bbbb1bb8c22bb13e22bd1f18e9796defa16bab421f7f7a317323b", size = 158753, upload-time = "2025-06-15T02:45:51.329Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/84/ae/320161bd181fc06471eed047ecce67b693fd7515b16d495d8932db763426/certifi-2025.6.15-py3-none-any.whl", hash = "sha256:2e0c7ce7cb5d8f8634ca55d2ba7e6ec2689a2fd6537d8dec1296a477a4910057", size = 157650, upload-time = "2025-06-15T02:45:49.977Z" }, -] - -[[package]] -name = "cffi" -version = "1.17.1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "pycparser" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/fc/97/c783634659c2920c3fc70419e3af40972dbaf758daa229a7d6ea6135c90d/cffi-1.17.1.tar.gz", hash = "sha256:1c39c6016c32bc48dd54561950ebd6836e1670f2ae46128f67cf49e789c52824", size = 516621, upload-time = "2024-09-04T20:45:21.852Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/90/07/f44ca684db4e4f08a3fdc6eeb9a0d15dc6883efc7b8c90357fdbf74e186c/cffi-1.17.1-cp310-cp310-macosx_10_9_x86_64.whl", hash = "sha256:df8b1c11f177bc2313ec4b2d46baec87a5f3e71fc8b45dab2ee7cae86d9aba14", size = 182191, upload-time = "2024-09-04T20:43:30.027Z" }, - { url = "https://files.pythonhosted.org/packages/08/fd/cc2fedbd887223f9f5d170c96e57cbf655df9831a6546c1727ae13fa977a/cffi-1.17.1-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:8f2cdc858323644ab277e9bb925ad72ae0e67f69e804f4898c070998d50b1a67", size = 178592, upload-time = "2024-09-04T20:43:32.108Z" }, - { url = "https://files.pythonhosted.org/packages/de/cc/4635c320081c78d6ffc2cab0a76025b691a91204f4aa317d568ff9280a2d/cffi-1.17.1-cp310-cp310-manylinux_2_12_i686.manylinux2010_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:edae79245293e15384b51f88b00613ba9f7198016a5948b5dddf4917d4d26382", size = 426024, upload-time = "2024-09-04T20:43:34.186Z" }, - { url = "https://files.pythonhosted.org/packages/b6/7b/3b2b250f3aab91abe5f8a51ada1b717935fdaec53f790ad4100fe2ec64d1/cffi-1.17.1-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:45398b671ac6d70e67da8e4224a065cec6a93541bb7aebe1b198a61b58c7b702", size = 448188, upload-time = "2024-09-04T20:43:36.286Z" }, - { url = "https://files.pythonhosted.org/packages/d3/48/1b9283ebbf0ec065148d8de05d647a986c5f22586b18120020452fff8f5d/cffi-1.17.1-cp310-cp310-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:ad9413ccdeda48c5afdae7e4fa2192157e991ff761e7ab8fdd8926f40b160cc3", size = 455571, upload-time = "2024-09-04T20:43:38.586Z" }, - { url = "https://files.pythonhosted.org/packages/40/87/3b8452525437b40f39ca7ff70276679772ee7e8b394934ff60e63b7b090c/cffi-1.17.1-cp310-cp310-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:5da5719280082ac6bd9aa7becb3938dc9f9cbd57fac7d2871717b1feb0902ab6", size = 436687, upload-time = "2024-09-04T20:43:40.084Z" }, - { url = "https://files.pythonhosted.org/packages/8d/fb/4da72871d177d63649ac449aec2e8a29efe0274035880c7af59101ca2232/cffi-1.17.1-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:2bb1a08b8008b281856e5971307cc386a8e9c5b625ac297e853d36da6efe9c17", size = 446211, upload-time = "2024-09-04T20:43:41.526Z" }, - { url = "https://files.pythonhosted.org/packages/ab/a0/62f00bcb411332106c02b663b26f3545a9ef136f80d5df746c05878f8c4b/cffi-1.17.1-cp310-cp310-musllinux_1_1_aarch64.whl", hash = "sha256:045d61c734659cc045141be4bae381a41d89b741f795af1dd018bfb532fd0df8", size = 461325, upload-time = "2024-09-04T20:43:43.117Z" }, - { url = "https://files.pythonhosted.org/packages/36/83/76127035ed2e7e27b0787604d99da630ac3123bfb02d8e80c633f218a11d/cffi-1.17.1-cp310-cp310-musllinux_1_1_i686.whl", hash = "sha256:6883e737d7d9e4899a8a695e00ec36bd4e5e4f18fabe0aca0efe0a4b44cdb13e", size = 438784, upload-time = "2024-09-04T20:43:45.256Z" }, - { url = "https://files.pythonhosted.org/packages/21/81/a6cd025db2f08ac88b901b745c163d884641909641f9b826e8cb87645942/cffi-1.17.1-cp310-cp310-musllinux_1_1_x86_64.whl", hash = "sha256:6b8b4a92e1c65048ff98cfe1f735ef8f1ceb72e3d5f0c25fdb12087a23da22be", size = 461564, upload-time = "2024-09-04T20:43:46.779Z" }, - { url = "https://files.pythonhosted.org/packages/f8/fe/4d41c2f200c4a457933dbd98d3cf4e911870877bd94d9656cc0fcb390681/cffi-1.17.1-cp310-cp310-win32.whl", hash = "sha256:c9c3d058ebabb74db66e431095118094d06abf53284d9c81f27300d0e0d8bc7c", size = 171804, upload-time = "2024-09-04T20:43:48.186Z" }, - { url = "https://files.pythonhosted.org/packages/d1/b6/0b0f5ab93b0df4acc49cae758c81fe4e5ef26c3ae2e10cc69249dfd8b3ab/cffi-1.17.1-cp310-cp310-win_amd64.whl", hash = "sha256:0f048dcf80db46f0098ccac01132761580d28e28bc0f78ae0d58048063317e15", size = 181299, upload-time = "2024-09-04T20:43:49.812Z" }, - { url = "https://files.pythonhosted.org/packages/6b/f4/927e3a8899e52a27fa57a48607ff7dc91a9ebe97399b357b85a0c7892e00/cffi-1.17.1-cp311-cp311-macosx_10_9_x86_64.whl", hash = "sha256:a45e3c6913c5b87b3ff120dcdc03f6131fa0065027d0ed7ee6190736a74cd401", size = 182264, upload-time = "2024-09-04T20:43:51.124Z" }, - { url = "https://files.pythonhosted.org/packages/6c/f5/6c3a8efe5f503175aaddcbea6ad0d2c96dad6f5abb205750d1b3df44ef29/cffi-1.17.1-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:30c5e0cb5ae493c04c8b42916e52ca38079f1b235c2f8ae5f4527b963c401caf", size = 178651, upload-time = "2024-09-04T20:43:52.872Z" }, - { url = "https://files.pythonhosted.org/packages/94/dd/a3f0118e688d1b1a57553da23b16bdade96d2f9bcda4d32e7d2838047ff7/cffi-1.17.1-cp311-cp311-manylinux_2_12_i686.manylinux2010_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:f75c7ab1f9e4aca5414ed4d8e5c0e303a34f4421f8a0d47a4d019ceff0ab6af4", size = 445259, upload-time = "2024-09-04T20:43:56.123Z" }, - { url = "https://files.pythonhosted.org/packages/2e/ea/70ce63780f096e16ce8588efe039d3c4f91deb1dc01e9c73a287939c79a6/cffi-1.17.1-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:a1ed2dd2972641495a3ec98445e09766f077aee98a1c896dcb4ad0d303628e41", size = 469200, upload-time = "2024-09-04T20:43:57.891Z" }, - { url = "https://files.pythonhosted.org/packages/1c/a0/a4fa9f4f781bda074c3ddd57a572b060fa0df7655d2a4247bbe277200146/cffi-1.17.1-cp311-cp311-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:46bf43160c1a35f7ec506d254e5c890f3c03648a4dbac12d624e4490a7046cd1", size = 477235, upload-time = "2024-09-04T20:44:00.18Z" }, - { url = "https://files.pythonhosted.org/packages/62/12/ce8710b5b8affbcdd5c6e367217c242524ad17a02fe5beec3ee339f69f85/cffi-1.17.1-cp311-cp311-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:a24ed04c8ffd54b0729c07cee15a81d964e6fee0e3d4d342a27b020d22959dc6", size = 459721, upload-time = "2024-09-04T20:44:01.585Z" }, - { url = "https://files.pythonhosted.org/packages/ff/6b/d45873c5e0242196f042d555526f92aa9e0c32355a1be1ff8c27f077fd37/cffi-1.17.1-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:610faea79c43e44c71e1ec53a554553fa22321b65fae24889706c0a84d4ad86d", size = 467242, upload-time = "2024-09-04T20:44:03.467Z" }, - { url = "https://files.pythonhosted.org/packages/1a/52/d9a0e523a572fbccf2955f5abe883cfa8bcc570d7faeee06336fbd50c9fc/cffi-1.17.1-cp311-cp311-musllinux_1_1_aarch64.whl", hash = "sha256:a9b15d491f3ad5d692e11f6b71f7857e7835eb677955c00cc0aefcd0669adaf6", size = 477999, upload-time = "2024-09-04T20:44:05.023Z" }, - { url = "https://files.pythonhosted.org/packages/44/74/f2a2460684a1a2d00ca799ad880d54652841a780c4c97b87754f660c7603/cffi-1.17.1-cp311-cp311-musllinux_1_1_i686.whl", hash = "sha256:de2ea4b5833625383e464549fec1bc395c1bdeeb5f25c4a3a82b5a8c756ec22f", size = 454242, upload-time = "2024-09-04T20:44:06.444Z" }, - { url = "https://files.pythonhosted.org/packages/f8/4a/34599cac7dfcd888ff54e801afe06a19c17787dfd94495ab0c8d35fe99fb/cffi-1.17.1-cp311-cp311-musllinux_1_1_x86_64.whl", hash = "sha256:fc48c783f9c87e60831201f2cce7f3b2e4846bf4d8728eabe54d60700b318a0b", size = 478604, upload-time = "2024-09-04T20:44:08.206Z" }, - { url = "https://files.pythonhosted.org/packages/34/33/e1b8a1ba29025adbdcda5fb3a36f94c03d771c1b7b12f726ff7fef2ebe36/cffi-1.17.1-cp311-cp311-win32.whl", hash = "sha256:85a950a4ac9c359340d5963966e3e0a94a676bd6245a4b55bc43949eee26a655", size = 171727, upload-time = "2024-09-04T20:44:09.481Z" }, - { url = "https://files.pythonhosted.org/packages/3d/97/50228be003bb2802627d28ec0627837ac0bf35c90cf769812056f235b2d1/cffi-1.17.1-cp311-cp311-win_amd64.whl", hash = "sha256:caaf0640ef5f5517f49bc275eca1406b0ffa6aa184892812030f04c2abf589a0", size = 181400, upload-time = "2024-09-04T20:44:10.873Z" }, - { url = "https://files.pythonhosted.org/packages/5a/84/e94227139ee5fb4d600a7a4927f322e1d4aea6fdc50bd3fca8493caba23f/cffi-1.17.1-cp312-cp312-macosx_10_9_x86_64.whl", hash = "sha256:805b4371bf7197c329fcb3ead37e710d1bca9da5d583f5073b799d5c5bd1eee4", size = 183178, upload-time = "2024-09-04T20:44:12.232Z" }, - { url = "https://files.pythonhosted.org/packages/da/ee/fb72c2b48656111c4ef27f0f91da355e130a923473bf5ee75c5643d00cca/cffi-1.17.1-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:733e99bc2df47476e3848417c5a4540522f234dfd4ef3ab7fafdf555b082ec0c", size = 178840, upload-time = "2024-09-04T20:44:13.739Z" }, - { url = "https://files.pythonhosted.org/packages/cc/b6/db007700f67d151abadf508cbfd6a1884f57eab90b1bb985c4c8c02b0f28/cffi-1.17.1-cp312-cp312-manylinux_2_12_i686.manylinux2010_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:1257bdabf294dceb59f5e70c64a3e2f462c30c7ad68092d01bbbfb1c16b1ba36", size = 454803, upload-time = "2024-09-04T20:44:15.231Z" }, - { url = "https://files.pythonhosted.org/packages/1a/df/f8d151540d8c200eb1c6fba8cd0dfd40904f1b0682ea705c36e6c2e97ab3/cffi-1.17.1-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:da95af8214998d77a98cc14e3a3bd00aa191526343078b530ceb0bd710fb48a5", size = 478850, upload-time = "2024-09-04T20:44:17.188Z" }, - { url = "https://files.pythonhosted.org/packages/28/c0/b31116332a547fd2677ae5b78a2ef662dfc8023d67f41b2a83f7c2aa78b1/cffi-1.17.1-cp312-cp312-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:d63afe322132c194cf832bfec0dc69a99fb9bb6bbd550f161a49e9e855cc78ff", size = 485729, upload-time = "2024-09-04T20:44:18.688Z" }, - { url = "https://files.pythonhosted.org/packages/91/2b/9a1ddfa5c7f13cab007a2c9cc295b70fbbda7cb10a286aa6810338e60ea1/cffi-1.17.1-cp312-cp312-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:f79fc4fc25f1c8698ff97788206bb3c2598949bfe0fef03d299eb1b5356ada99", size = 471256, upload-time = "2024-09-04T20:44:20.248Z" }, - { url = "https://files.pythonhosted.org/packages/b2/d5/da47df7004cb17e4955df6a43d14b3b4ae77737dff8bf7f8f333196717bf/cffi-1.17.1-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:b62ce867176a75d03a665bad002af8e6d54644fad99a3c70905c543130e39d93", size = 479424, upload-time = "2024-09-04T20:44:21.673Z" }, - { url = "https://files.pythonhosted.org/packages/0b/ac/2a28bcf513e93a219c8a4e8e125534f4f6db03e3179ba1c45e949b76212c/cffi-1.17.1-cp312-cp312-musllinux_1_1_aarch64.whl", hash = "sha256:386c8bf53c502fff58903061338ce4f4950cbdcb23e2902d86c0f722b786bbe3", size = 484568, upload-time = "2024-09-04T20:44:23.245Z" }, - { url = "https://files.pythonhosted.org/packages/d4/38/ca8a4f639065f14ae0f1d9751e70447a261f1a30fa7547a828ae08142465/cffi-1.17.1-cp312-cp312-musllinux_1_1_x86_64.whl", hash = "sha256:4ceb10419a9adf4460ea14cfd6bc43d08701f0835e979bf821052f1805850fe8", size = 488736, upload-time = "2024-09-04T20:44:24.757Z" }, - { url = "https://files.pythonhosted.org/packages/86/c5/28b2d6f799ec0bdecf44dced2ec5ed43e0eb63097b0f58c293583b406582/cffi-1.17.1-cp312-cp312-win32.whl", hash = "sha256:a08d7e755f8ed21095a310a693525137cfe756ce62d066e53f502a83dc550f65", size = 172448, upload-time = "2024-09-04T20:44:26.208Z" }, - { url = "https://files.pythonhosted.org/packages/50/b9/db34c4755a7bd1cb2d1603ac3863f22bcecbd1ba29e5ee841a4bc510b294/cffi-1.17.1-cp312-cp312-win_amd64.whl", hash = "sha256:51392eae71afec0d0c8fb1a53b204dbb3bcabcb3c9b807eedf3e1e6ccf2de903", size = 181976, upload-time = "2024-09-04T20:44:27.578Z" }, - { url = "https://files.pythonhosted.org/packages/8d/f8/dd6c246b148639254dad4d6803eb6a54e8c85c6e11ec9df2cffa87571dbe/cffi-1.17.1-cp313-cp313-macosx_10_13_x86_64.whl", hash = "sha256:f3a2b4222ce6b60e2e8b337bb9596923045681d71e5a082783484d845390938e", size = 182989, upload-time = "2024-09-04T20:44:28.956Z" }, - { url = "https://files.pythonhosted.org/packages/8b/f1/672d303ddf17c24fc83afd712316fda78dc6fce1cd53011b839483e1ecc8/cffi-1.17.1-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:0984a4925a435b1da406122d4d7968dd861c1385afe3b45ba82b750f229811e2", size = 178802, upload-time = "2024-09-04T20:44:30.289Z" }, - { url = "https://files.pythonhosted.org/packages/0e/2d/eab2e858a91fdff70533cab61dcff4a1f55ec60425832ddfdc9cd36bc8af/cffi-1.17.1-cp313-cp313-manylinux_2_12_i686.manylinux2010_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:d01b12eeeb4427d3110de311e1774046ad344f5b1a7403101878976ecd7a10f3", size = 454792, upload-time = "2024-09-04T20:44:32.01Z" }, - { url = "https://files.pythonhosted.org/packages/75/b2/fbaec7c4455c604e29388d55599b99ebcc250a60050610fadde58932b7ee/cffi-1.17.1-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:706510fe141c86a69c8ddc029c7910003a17353970cff3b904ff0686a5927683", size = 478893, upload-time = "2024-09-04T20:44:33.606Z" }, - { url = "https://files.pythonhosted.org/packages/4f/b7/6e4a2162178bf1935c336d4da8a9352cccab4d3a5d7914065490f08c0690/cffi-1.17.1-cp313-cp313-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:de55b766c7aa2e2a3092c51e0483d700341182f08e67c63630d5b6f200bb28e5", size = 485810, upload-time = "2024-09-04T20:44:35.191Z" }, - { url = "https://files.pythonhosted.org/packages/c7/8a/1d0e4a9c26e54746dc08c2c6c037889124d4f59dffd853a659fa545f1b40/cffi-1.17.1-cp313-cp313-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:c59d6e989d07460165cc5ad3c61f9fd8f1b4796eacbd81cee78957842b834af4", size = 471200, upload-time = "2024-09-04T20:44:36.743Z" }, - { url = "https://files.pythonhosted.org/packages/26/9f/1aab65a6c0db35f43c4d1b4f580e8df53914310afc10ae0397d29d697af4/cffi-1.17.1-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:dd398dbc6773384a17fe0d3e7eeb8d1a21c2200473ee6806bb5e6a8e62bb73dd", size = 479447, upload-time = "2024-09-04T20:44:38.492Z" }, - { url = "https://files.pythonhosted.org/packages/5f/e4/fb8b3dd8dc0e98edf1135ff067ae070bb32ef9d509d6cb0f538cd6f7483f/cffi-1.17.1-cp313-cp313-musllinux_1_1_aarch64.whl", hash = "sha256:3edc8d958eb099c634dace3c7e16560ae474aa3803a5df240542b305d14e14ed", size = 484358, upload-time = "2024-09-04T20:44:40.046Z" }, - { url = "https://files.pythonhosted.org/packages/f1/47/d7145bf2dc04684935d57d67dff9d6d795b2ba2796806bb109864be3a151/cffi-1.17.1-cp313-cp313-musllinux_1_1_x86_64.whl", hash = "sha256:72e72408cad3d5419375fc87d289076ee319835bdfa2caad331e377589aebba9", size = 488469, upload-time = "2024-09-04T20:44:41.616Z" }, - { url = "https://files.pythonhosted.org/packages/bf/ee/f94057fa6426481d663b88637a9a10e859e492c73d0384514a17d78ee205/cffi-1.17.1-cp313-cp313-win32.whl", hash = "sha256:e03eab0a8677fa80d646b5ddece1cbeaf556c313dcfac435ba11f107ba117b5d", size = 172475, upload-time = "2024-09-04T20:44:43.733Z" }, - { url = "https://files.pythonhosted.org/packages/7c/fc/6a8cb64e5f0324877d503c854da15d76c1e50eb722e320b15345c4d0c6de/cffi-1.17.1-cp313-cp313-win_amd64.whl", hash = "sha256:f6a16c31041f09ead72d69f583767292f750d24913dadacf5756b966aacb3f1a", size = 182009, upload-time = "2024-09-04T20:44:45.309Z" }, -] - -[[package]] -name = "charset-normalizer" -version = "3.4.2" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/e4/33/89c2ced2b67d1c2a61c19c6751aa8902d46ce3dacb23600a283619f5a12d/charset_normalizer-3.4.2.tar.gz", hash = "sha256:5baececa9ecba31eff645232d59845c07aa030f0c81ee70184a90d35099a0e63", size = 126367, upload-time = "2025-05-02T08:34:42.01Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/95/28/9901804da60055b406e1a1c5ba7aac1276fb77f1dde635aabfc7fd84b8ab/charset_normalizer-3.4.2-cp310-cp310-macosx_10_9_universal2.whl", hash = "sha256:7c48ed483eb946e6c04ccbe02c6b4d1d48e51944b6db70f697e089c193404941", size = 201818, upload-time = "2025-05-02T08:31:46.725Z" }, - { url = "https://files.pythonhosted.org/packages/d9/9b/892a8c8af9110935e5adcbb06d9c6fe741b6bb02608c6513983048ba1a18/charset_normalizer-3.4.2-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:b2d318c11350e10662026ad0eb71bb51c7812fc8590825304ae0bdd4ac283acd", size = 144649, upload-time = "2025-05-02T08:31:48.889Z" }, - { url = "https://files.pythonhosted.org/packages/7b/a5/4179abd063ff6414223575e008593861d62abfc22455b5d1a44995b7c101/charset_normalizer-3.4.2-cp310-cp310-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:9cbfacf36cb0ec2897ce0ebc5d08ca44213af24265bd56eca54bee7923c48fd6", size = 155045, upload-time = "2025-05-02T08:31:50.757Z" }, - { url = "https://files.pythonhosted.org/packages/3b/95/bc08c7dfeddd26b4be8c8287b9bb055716f31077c8b0ea1cd09553794665/charset_normalizer-3.4.2-cp310-cp310-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:18dd2e350387c87dabe711b86f83c9c78af772c748904d372ade190b5c7c9d4d", size = 147356, upload-time = "2025-05-02T08:31:52.634Z" }, - { url = "https://files.pythonhosted.org/packages/a8/2d/7a5b635aa65284bf3eab7653e8b4151ab420ecbae918d3e359d1947b4d61/charset_normalizer-3.4.2-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:8075c35cd58273fee266c58c0c9b670947c19df5fb98e7b66710e04ad4e9ff86", size = 149471, upload-time = "2025-05-02T08:31:56.207Z" }, - { url = "https://files.pythonhosted.org/packages/ae/38/51fc6ac74251fd331a8cfdb7ec57beba8c23fd5493f1050f71c87ef77ed0/charset_normalizer-3.4.2-cp310-cp310-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:5bf4545e3b962767e5c06fe1738f951f77d27967cb2caa64c28be7c4563e162c", size = 151317, upload-time = "2025-05-02T08:31:57.613Z" }, - { url = "https://files.pythonhosted.org/packages/b7/17/edee1e32215ee6e9e46c3e482645b46575a44a2d72c7dfd49e49f60ce6bf/charset_normalizer-3.4.2-cp310-cp310-musllinux_1_2_aarch64.whl", hash = "sha256:7a6ab32f7210554a96cd9e33abe3ddd86732beeafc7a28e9955cdf22ffadbab0", size = 146368, upload-time = "2025-05-02T08:31:59.468Z" }, - { url = "https://files.pythonhosted.org/packages/26/2c/ea3e66f2b5f21fd00b2825c94cafb8c326ea6240cd80a91eb09e4a285830/charset_normalizer-3.4.2-cp310-cp310-musllinux_1_2_i686.whl", hash = "sha256:b33de11b92e9f75a2b545d6e9b6f37e398d86c3e9e9653c4864eb7e89c5773ef", size = 154491, upload-time = "2025-05-02T08:32:01.219Z" }, - { url = "https://files.pythonhosted.org/packages/52/47/7be7fa972422ad062e909fd62460d45c3ef4c141805b7078dbab15904ff7/charset_normalizer-3.4.2-cp310-cp310-musllinux_1_2_ppc64le.whl", hash = "sha256:8755483f3c00d6c9a77f490c17e6ab0c8729e39e6390328e42521ef175380ae6", size = 157695, upload-time = "2025-05-02T08:32:03.045Z" }, - { url = "https://files.pythonhosted.org/packages/2f/42/9f02c194da282b2b340f28e5fb60762de1151387a36842a92b533685c61e/charset_normalizer-3.4.2-cp310-cp310-musllinux_1_2_s390x.whl", hash = "sha256:68a328e5f55ec37c57f19ebb1fdc56a248db2e3e9ad769919a58672958e8f366", size = 154849, upload-time = "2025-05-02T08:32:04.651Z" }, - { url = "https://files.pythonhosted.org/packages/67/44/89cacd6628f31fb0b63201a618049be4be2a7435a31b55b5eb1c3674547a/charset_normalizer-3.4.2-cp310-cp310-musllinux_1_2_x86_64.whl", hash = "sha256:21b2899062867b0e1fde9b724f8aecb1af14f2778d69aacd1a5a1853a597a5db", size = 150091, upload-time = "2025-05-02T08:32:06.719Z" }, - { url = "https://files.pythonhosted.org/packages/1f/79/4b8da9f712bc079c0f16b6d67b099b0b8d808c2292c937f267d816ec5ecc/charset_normalizer-3.4.2-cp310-cp310-win32.whl", hash = "sha256:e8082b26888e2f8b36a042a58307d5b917ef2b1cacab921ad3323ef91901c71a", size = 98445, upload-time = "2025-05-02T08:32:08.66Z" }, - { url = "https://files.pythonhosted.org/packages/7d/d7/96970afb4fb66497a40761cdf7bd4f6fca0fc7bafde3a84f836c1f57a926/charset_normalizer-3.4.2-cp310-cp310-win_amd64.whl", hash = "sha256:f69a27e45c43520f5487f27627059b64aaf160415589230992cec34c5e18a509", size = 105782, upload-time = "2025-05-02T08:32:10.46Z" }, - { url = "https://files.pythonhosted.org/packages/05/85/4c40d00dcc6284a1c1ad5de5e0996b06f39d8232f1031cd23c2f5c07ee86/charset_normalizer-3.4.2-cp311-cp311-macosx_10_9_universal2.whl", hash = "sha256:be1e352acbe3c78727a16a455126d9ff83ea2dfdcbc83148d2982305a04714c2", size = 198794, upload-time = "2025-05-02T08:32:11.945Z" }, - { url = "https://files.pythonhosted.org/packages/41/d9/7a6c0b9db952598e97e93cbdfcb91bacd89b9b88c7c983250a77c008703c/charset_normalizer-3.4.2-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:aa88ca0b1932e93f2d961bf3addbb2db902198dca337d88c89e1559e066e7645", size = 142846, upload-time = "2025-05-02T08:32:13.946Z" }, - { url = "https://files.pythonhosted.org/packages/66/82/a37989cda2ace7e37f36c1a8ed16c58cf48965a79c2142713244bf945c89/charset_normalizer-3.4.2-cp311-cp311-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:d524ba3f1581b35c03cb42beebab4a13e6cdad7b36246bd22541fa585a56cccd", size = 153350, upload-time = "2025-05-02T08:32:15.873Z" }, - { url = "https://files.pythonhosted.org/packages/df/68/a576b31b694d07b53807269d05ec3f6f1093e9545e8607121995ba7a8313/charset_normalizer-3.4.2-cp311-cp311-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:28a1005facc94196e1fb3e82a3d442a9d9110b8434fc1ded7a24a2983c9888d8", size = 145657, upload-time = "2025-05-02T08:32:17.283Z" }, - { url = "https://files.pythonhosted.org/packages/92/9b/ad67f03d74554bed3aefd56fe836e1623a50780f7c998d00ca128924a499/charset_normalizer-3.4.2-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:fdb20a30fe1175ecabed17cbf7812f7b804b8a315a25f24678bcdf120a90077f", size = 147260, upload-time = "2025-05-02T08:32:18.807Z" }, - { url = "https://files.pythonhosted.org/packages/a6/e6/8aebae25e328160b20e31a7e9929b1578bbdc7f42e66f46595a432f8539e/charset_normalizer-3.4.2-cp311-cp311-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:0f5d9ed7f254402c9e7d35d2f5972c9bbea9040e99cd2861bd77dc68263277c7", size = 149164, upload-time = "2025-05-02T08:32:20.333Z" }, - { url = "https://files.pythonhosted.org/packages/8b/f2/b3c2f07dbcc248805f10e67a0262c93308cfa149a4cd3d1fe01f593e5fd2/charset_normalizer-3.4.2-cp311-cp311-musllinux_1_2_aarch64.whl", hash = "sha256:efd387a49825780ff861998cd959767800d54f8308936b21025326de4b5a42b9", size = 144571, upload-time = "2025-05-02T08:32:21.86Z" }, - { url = "https://files.pythonhosted.org/packages/60/5b/c3f3a94bc345bc211622ea59b4bed9ae63c00920e2e8f11824aa5708e8b7/charset_normalizer-3.4.2-cp311-cp311-musllinux_1_2_i686.whl", hash = "sha256:f0aa37f3c979cf2546b73e8222bbfa3dc07a641585340179d768068e3455e544", size = 151952, upload-time = "2025-05-02T08:32:23.434Z" }, - { url = "https://files.pythonhosted.org/packages/e2/4d/ff460c8b474122334c2fa394a3f99a04cf11c646da895f81402ae54f5c42/charset_normalizer-3.4.2-cp311-cp311-musllinux_1_2_ppc64le.whl", hash = "sha256:e70e990b2137b29dc5564715de1e12701815dacc1d056308e2b17e9095372a82", size = 155959, upload-time = "2025-05-02T08:32:24.993Z" }, - { url = "https://files.pythonhosted.org/packages/a2/2b/b964c6a2fda88611a1fe3d4c400d39c66a42d6c169c924818c848f922415/charset_normalizer-3.4.2-cp311-cp311-musllinux_1_2_s390x.whl", hash = "sha256:0c8c57f84ccfc871a48a47321cfa49ae1df56cd1d965a09abe84066f6853b9c0", size = 153030, upload-time = "2025-05-02T08:32:26.435Z" }, - { url = "https://files.pythonhosted.org/packages/59/2e/d3b9811db26a5ebf444bc0fa4f4be5aa6d76fc6e1c0fd537b16c14e849b6/charset_normalizer-3.4.2-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:6b66f92b17849b85cad91259efc341dce9c1af48e2173bf38a85c6329f1033e5", size = 148015, upload-time = "2025-05-02T08:32:28.376Z" }, - { url = "https://files.pythonhosted.org/packages/90/07/c5fd7c11eafd561bb51220d600a788f1c8d77c5eef37ee49454cc5c35575/charset_normalizer-3.4.2-cp311-cp311-win32.whl", hash = "sha256:daac4765328a919a805fa5e2720f3e94767abd632ae410a9062dff5412bae65a", size = 98106, upload-time = "2025-05-02T08:32:30.281Z" }, - { url = "https://files.pythonhosted.org/packages/a8/05/5e33dbef7e2f773d672b6d79f10ec633d4a71cd96db6673625838a4fd532/charset_normalizer-3.4.2-cp311-cp311-win_amd64.whl", hash = "sha256:e53efc7c7cee4c1e70661e2e112ca46a575f90ed9ae3fef200f2a25e954f4b28", size = 105402, upload-time = "2025-05-02T08:32:32.191Z" }, - { url = "https://files.pythonhosted.org/packages/d7/a4/37f4d6035c89cac7930395a35cc0f1b872e652eaafb76a6075943754f095/charset_normalizer-3.4.2-cp312-cp312-macosx_10_13_universal2.whl", hash = "sha256:0c29de6a1a95f24b9a1aa7aefd27d2487263f00dfd55a77719b530788f75cff7", size = 199936, upload-time = "2025-05-02T08:32:33.712Z" }, - { url = "https://files.pythonhosted.org/packages/ee/8a/1a5e33b73e0d9287274f899d967907cd0bf9c343e651755d9307e0dbf2b3/charset_normalizer-3.4.2-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:cddf7bd982eaa998934a91f69d182aec997c6c468898efe6679af88283b498d3", size = 143790, upload-time = "2025-05-02T08:32:35.768Z" }, - { url = "https://files.pythonhosted.org/packages/66/52/59521f1d8e6ab1482164fa21409c5ef44da3e9f653c13ba71becdd98dec3/charset_normalizer-3.4.2-cp312-cp312-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:fcbe676a55d7445b22c10967bceaaf0ee69407fbe0ece4d032b6eb8d4565982a", size = 153924, upload-time = "2025-05-02T08:32:37.284Z" }, - { url = "https://files.pythonhosted.org/packages/86/2d/fb55fdf41964ec782febbf33cb64be480a6b8f16ded2dbe8db27a405c09f/charset_normalizer-3.4.2-cp312-cp312-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:d41c4d287cfc69060fa91cae9683eacffad989f1a10811995fa309df656ec214", size = 146626, upload-time = "2025-05-02T08:32:38.803Z" }, - { url = "https://files.pythonhosted.org/packages/8c/73/6ede2ec59bce19b3edf4209d70004253ec5f4e319f9a2e3f2f15601ed5f7/charset_normalizer-3.4.2-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:4e594135de17ab3866138f496755f302b72157d115086d100c3f19370839dd3a", size = 148567, upload-time = "2025-05-02T08:32:40.251Z" }, - { url = "https://files.pythonhosted.org/packages/09/14/957d03c6dc343c04904530b6bef4e5efae5ec7d7990a7cbb868e4595ee30/charset_normalizer-3.4.2-cp312-cp312-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:cf713fe9a71ef6fd5adf7a79670135081cd4431c2943864757f0fa3a65b1fafd", size = 150957, upload-time = "2025-05-02T08:32:41.705Z" }, - { url = "https://files.pythonhosted.org/packages/0d/c8/8174d0e5c10ccebdcb1b53cc959591c4c722a3ad92461a273e86b9f5a302/charset_normalizer-3.4.2-cp312-cp312-musllinux_1_2_aarch64.whl", hash = "sha256:a370b3e078e418187da8c3674eddb9d983ec09445c99a3a263c2011993522981", size = 145408, upload-time = "2025-05-02T08:32:43.709Z" }, - { url = "https://files.pythonhosted.org/packages/58/aa/8904b84bc8084ac19dc52feb4f5952c6df03ffb460a887b42615ee1382e8/charset_normalizer-3.4.2-cp312-cp312-musllinux_1_2_i686.whl", hash = "sha256:a955b438e62efdf7e0b7b52a64dc5c3396e2634baa62471768a64bc2adb73d5c", size = 153399, upload-time = "2025-05-02T08:32:46.197Z" }, - { url = "https://files.pythonhosted.org/packages/c2/26/89ee1f0e264d201cb65cf054aca6038c03b1a0c6b4ae998070392a3ce605/charset_normalizer-3.4.2-cp312-cp312-musllinux_1_2_ppc64le.whl", hash = "sha256:7222ffd5e4de8e57e03ce2cef95a4c43c98fcb72ad86909abdfc2c17d227fc1b", size = 156815, upload-time = "2025-05-02T08:32:48.105Z" }, - { url = "https://files.pythonhosted.org/packages/fd/07/68e95b4b345bad3dbbd3a8681737b4338ff2c9df29856a6d6d23ac4c73cb/charset_normalizer-3.4.2-cp312-cp312-musllinux_1_2_s390x.whl", hash = "sha256:bee093bf902e1d8fc0ac143c88902c3dfc8941f7ea1d6a8dd2bcb786d33db03d", size = 154537, upload-time = "2025-05-02T08:32:49.719Z" }, - { url = "https://files.pythonhosted.org/packages/77/1a/5eefc0ce04affb98af07bc05f3bac9094513c0e23b0562d64af46a06aae4/charset_normalizer-3.4.2-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:dedb8adb91d11846ee08bec4c8236c8549ac721c245678282dcb06b221aab59f", size = 149565, upload-time = "2025-05-02T08:32:51.404Z" }, - { url = "https://files.pythonhosted.org/packages/37/a0/2410e5e6032a174c95e0806b1a6585eb21e12f445ebe239fac441995226a/charset_normalizer-3.4.2-cp312-cp312-win32.whl", hash = "sha256:db4c7bf0e07fc3b7d89ac2a5880a6a8062056801b83ff56d8464b70f65482b6c", size = 98357, upload-time = "2025-05-02T08:32:53.079Z" }, - { url = "https://files.pythonhosted.org/packages/6c/4f/c02d5c493967af3eda9c771ad4d2bbc8df6f99ddbeb37ceea6e8716a32bc/charset_normalizer-3.4.2-cp312-cp312-win_amd64.whl", hash = "sha256:5a9979887252a82fefd3d3ed2a8e3b937a7a809f65dcb1e068b090e165bbe99e", size = 105776, upload-time = "2025-05-02T08:32:54.573Z" }, - { url = "https://files.pythonhosted.org/packages/ea/12/a93df3366ed32db1d907d7593a94f1fe6293903e3e92967bebd6950ed12c/charset_normalizer-3.4.2-cp313-cp313-macosx_10_13_universal2.whl", hash = "sha256:926ca93accd5d36ccdabd803392ddc3e03e6d4cd1cf17deff3b989ab8e9dbcf0", size = 199622, upload-time = "2025-05-02T08:32:56.363Z" }, - { url = "https://files.pythonhosted.org/packages/04/93/bf204e6f344c39d9937d3c13c8cd5bbfc266472e51fc8c07cb7f64fcd2de/charset_normalizer-3.4.2-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:eba9904b0f38a143592d9fc0e19e2df0fa2e41c3c3745554761c5f6447eedabf", size = 143435, upload-time = "2025-05-02T08:32:58.551Z" }, - { url = "https://files.pythonhosted.org/packages/22/2a/ea8a2095b0bafa6c5b5a55ffdc2f924455233ee7b91c69b7edfcc9e02284/charset_normalizer-3.4.2-cp313-cp313-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:3fddb7e2c84ac87ac3a947cb4e66d143ca5863ef48e4a5ecb83bd48619e4634e", size = 153653, upload-time = "2025-05-02T08:33:00.342Z" }, - { url = "https://files.pythonhosted.org/packages/b6/57/1b090ff183d13cef485dfbe272e2fe57622a76694061353c59da52c9a659/charset_normalizer-3.4.2-cp313-cp313-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:98f862da73774290f251b9df8d11161b6cf25b599a66baf087c1ffe340e9bfd1", size = 146231, upload-time = "2025-05-02T08:33:02.081Z" }, - { url = "https://files.pythonhosted.org/packages/e2/28/ffc026b26f441fc67bd21ab7f03b313ab3fe46714a14b516f931abe1a2d8/charset_normalizer-3.4.2-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:6c9379d65defcab82d07b2a9dfbfc2e95bc8fe0ebb1b176a3190230a3ef0e07c", size = 148243, upload-time = "2025-05-02T08:33:04.063Z" }, - { url = "https://files.pythonhosted.org/packages/c0/0f/9abe9bd191629c33e69e47c6ef45ef99773320e9ad8e9cb08b8ab4a8d4cb/charset_normalizer-3.4.2-cp313-cp313-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:e635b87f01ebc977342e2697d05b56632f5f879a4f15955dfe8cef2448b51691", size = 150442, upload-time = "2025-05-02T08:33:06.418Z" }, - { url = "https://files.pythonhosted.org/packages/67/7c/a123bbcedca91d5916c056407f89a7f5e8fdfce12ba825d7d6b9954a1a3c/charset_normalizer-3.4.2-cp313-cp313-musllinux_1_2_aarch64.whl", hash = "sha256:1c95a1e2902a8b722868587c0e1184ad5c55631de5afc0eb96bc4b0d738092c0", size = 145147, upload-time = "2025-05-02T08:33:08.183Z" }, - { url = "https://files.pythonhosted.org/packages/ec/fe/1ac556fa4899d967b83e9893788e86b6af4d83e4726511eaaad035e36595/charset_normalizer-3.4.2-cp313-cp313-musllinux_1_2_i686.whl", hash = "sha256:ef8de666d6179b009dce7bcb2ad4c4a779f113f12caf8dc77f0162c29d20490b", size = 153057, upload-time = "2025-05-02T08:33:09.986Z" }, - { url = "https://files.pythonhosted.org/packages/2b/ff/acfc0b0a70b19e3e54febdd5301a98b72fa07635e56f24f60502e954c461/charset_normalizer-3.4.2-cp313-cp313-musllinux_1_2_ppc64le.whl", hash = "sha256:32fc0341d72e0f73f80acb0a2c94216bd704f4f0bce10aedea38f30502b271ff", size = 156454, upload-time = "2025-05-02T08:33:11.814Z" }, - { url = "https://files.pythonhosted.org/packages/92/08/95b458ce9c740d0645feb0e96cea1f5ec946ea9c580a94adfe0b617f3573/charset_normalizer-3.4.2-cp313-cp313-musllinux_1_2_s390x.whl", hash = "sha256:289200a18fa698949d2b39c671c2cc7a24d44096784e76614899a7ccf2574b7b", size = 154174, upload-time = "2025-05-02T08:33:13.707Z" }, - { url = "https://files.pythonhosted.org/packages/78/be/8392efc43487ac051eee6c36d5fbd63032d78f7728cb37aebcc98191f1ff/charset_normalizer-3.4.2-cp313-cp313-musllinux_1_2_x86_64.whl", hash = "sha256:4a476b06fbcf359ad25d34a057b7219281286ae2477cc5ff5e3f70a246971148", size = 149166, upload-time = "2025-05-02T08:33:15.458Z" }, - { url = "https://files.pythonhosted.org/packages/44/96/392abd49b094d30b91d9fbda6a69519e95802250b777841cf3bda8fe136c/charset_normalizer-3.4.2-cp313-cp313-win32.whl", hash = "sha256:aaeeb6a479c7667fbe1099af9617c83aaca22182d6cf8c53966491a0f1b7ffb7", size = 98064, upload-time = "2025-05-02T08:33:17.06Z" }, - { url = "https://files.pythonhosted.org/packages/e9/b0/0200da600134e001d91851ddc797809e2fe0ea72de90e09bec5a2fbdaccb/charset_normalizer-3.4.2-cp313-cp313-win_amd64.whl", hash = "sha256:aa6af9e7d59f9c12b33ae4e9450619cf2488e2bbe9b44030905877f0b2324980", size = 105641, upload-time = "2025-05-02T08:33:18.753Z" }, - { url = "https://files.pythonhosted.org/packages/20/94/c5790835a017658cbfabd07f3bfb549140c3ac458cfc196323996b10095a/charset_normalizer-3.4.2-py3-none-any.whl", hash = "sha256:7f56930ab0abd1c45cd15be65cc741c28b1c9a34876ce8c17a2fa107810c0af0", size = 52626, upload-time = "2025-05-02T08:34:40.053Z" }, -] - -[[package]] -name = "chex" -version = "0.1.89" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "absl-py" }, - { name = "jax" }, - { name = "jaxlib" }, - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "setuptools", marker = "python_full_version >= '3.12' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "toolz" }, - { name = "typing-extensions" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/ca/ac/504a8019f7ef372fc6cc3999ec9e3d0fbb38e6992f55d845d5b928010c11/chex-0.1.89.tar.gz", hash = "sha256:78f856e6a0a8459edfcbb402c2c044d2b8102eac4b633838cbdfdcdb09c6c8e0", size = 90676, upload-time = "2025-02-25T15:43:30.23Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/5e/6c/309972937d931069816dc8b28193a650485bc35cca92c04c8c15c4bd181e/chex-0.1.89-py3-none-any.whl", hash = "sha256:145241c27d8944adb634fb7d472a460e1c1b643f561507d4031ad5156ef82dfa", size = 99908, upload-time = "2025-02-25T15:43:27.316Z" }, -] - -[[package]] -name = "clean-fid" -version = "0.1.35" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "pillow" }, - { name = "requests" }, - { name = "scipy" }, - { name = "torch", version = "2.0.1", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://pypi.org/simple" }, marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" }, marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "extra == 'extra-7-comfyui-cu128' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.15.2", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1", source = { registry = "https://pypi.org/simple" }, marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" }, marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "(platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "tqdm" }, -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/70/56/0dfc83e0fe455cfe6272b23a65039b4101c63a4e7446801e26178b675fbf/clean_fid-0.1.35-py3-none-any.whl", hash = "sha256:757cf49d75debe9b07ab14955fe59c845a296deaf0616153b40c5e75b3cf87fb", size = 26008, upload-time = "2022-12-18T20:19:35.819Z" }, -] - -[[package]] -name = "click" -version = "8.2.1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "colorama", marker = "sys_platform == 'win32' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/60/6c/8ca2efa64cf75a977a0d7fac081354553ebe483345c734fb6b6515d96bbc/click-8.2.1.tar.gz", hash = "sha256:27c491cc05d968d271d5a1db13e3b5a184636d9d930f148c50b038f0d0646202", size = 286342, upload-time = "2025-05-20T23:19:49.832Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/85/32/10bb5764d90a8eee674e9dc6f4db6a0ab47c8c4d0d83c27f7c39ac415a4d/click-8.2.1-py3-none-any.whl", hash = "sha256:61a3265b914e850b85317d0b3109c7f8cd35a670f963866005d6ef1d5175a12b", size = 102215, upload-time = "2025-05-20T23:19:47.796Z" }, -] - -[[package]] -name = "cmake" -version = "4.0.3" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/25/3f/30c0f44ec5d727f547c35510ae479053abf56bed24b08f3e128f93d09905/cmake-4.0.3.tar.gz", hash = "sha256:215732f09ea8a7088fe1ab46bbd61669437217278d709fd3851bf8211e8c59e3", size = 34504, upload-time = "2025-06-13T15:34:11.68Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/c3/d2/5579b66d4421ab11dd00f32f4184be383a74e28ad0685a6604e0e7a8fd29/cmake-4.0.3-py3-none-macosx_10_10_universal2.whl", hash = "sha256:f2adfb459747025f40f9d3bdd1f3a485d43e866c0c4eb66373d1fcd666b13e4a", size = 48740112, upload-time = "2025-06-13T15:33:08.513Z" }, - { url = "https://files.pythonhosted.org/packages/67/4d/410c3ebb4a46a236cbc0e3202f5507483ce24c96c1d4a73445675f11b402/cmake-4.0.3-py3-none-manylinux_2_12_i686.manylinux2010_i686.whl", hash = "sha256:04c40c92fdcaa96c66a5731b5b3fbbdf87da99cc68fdd30ff30b90c34d222986", size = 27740648, upload-time = "2025-06-13T15:33:12.877Z" }, - { url = "https://files.pythonhosted.org/packages/77/a7/f845c1e129ad37059612e5d66ffe3dac824fdfd7dec58918a802f38650ff/cmake-4.0.3-py3-none-manylinux_2_12_x86_64.manylinux2010_x86_64.whl", hash = "sha256:d41b83d061bcc375a7a5f2942ba523a7563368d296d91260f9d8a53a10f5e5e5", size = 26983727, upload-time = "2025-06-13T15:33:16.394Z" }, - { url = "https://files.pythonhosted.org/packages/45/ee/750dae28fa12493052c44f744affbfeff0f35a526b4346bd86050e9903e5/cmake-4.0.3-py3-none-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:434f84fdf1e21578974876b8414dc47afeaea62027d9adc37a943a6bb08eb053", size = 27256957, upload-time = "2025-06-13T15:33:19.658Z" }, - { url = "https://files.pythonhosted.org/packages/23/1e/05b08c18145cd8e5ad3f506bfa21fe5277c00faf9052b3fb9bf6d279df42/cmake-4.0.3-py3-none-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:beec48371a4b906fe398758ded5df57fc16e9bb14fd34244d9d66ee35862fb9f", size = 29020848, upload-time = "2025-06-13T15:33:23.161Z" }, - { url = "https://files.pythonhosted.org/packages/db/b5/578e5b50cb848775aee4e04ceecef3c6595c30fb5fe0642a14eaafa02597/cmake-4.0.3-py3-none-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:47dc28bee6cfb4de00c7cf7e87d565b5c86eb4088da81b60a49e214fcdd4ffda", size = 30872393, upload-time = "2025-06-13T15:33:26.316Z" }, - { url = "https://files.pythonhosted.org/packages/42/7d/e4cdb9903b971dbbab1127e96bab86d3d77cedbb637f47a8e44ec02c3672/cmake-4.0.3-py3-none-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:e10fdc972b3211915b65cc89e8cd24e1a26c9bd684ee71c3f369fb488f2c4388", size = 27028264, upload-time = "2025-06-13T15:33:29.619Z" }, - { url = "https://files.pythonhosted.org/packages/60/cb/1e4d8baab7c946f809d6c59914428c10acaf39d9f4b52e1dffff834a9f0a/cmake-4.0.3-py3-none-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:d840e780c48c5df1330879d50615176896e8e6eee554507d21ce8e2f1a5f0ff8", size = 27912444, upload-time = "2025-06-13T15:33:33.296Z" }, - { url = "https://files.pythonhosted.org/packages/cb/3a/ff653130b91d73c172205ac10ad71c62a1474bd85ae110eec085e04aec08/cmake-4.0.3-py3-none-manylinux_2_31_armv7l.whl", hash = "sha256:6ef63bbabcbe3b89c1d80547913b6caceaad57987a27e7afc79ebc88ecd829e4", size = 25156436, upload-time = "2025-06-13T15:33:36.316Z" }, - { url = "https://files.pythonhosted.org/packages/7a/6f/514ba65cf1e2d0a80a97c3c4a2ae3805bf8cb3286de41b864b03b44ca47a/cmake-4.0.3-py3-none-musllinux_1_1_aarch64.whl", hash = "sha256:67103f2bcce8f57b8705ba8e353f18fdc3684a346eee97dc5f94d11575a424c6", size = 28026300, upload-time = "2025-06-13T15:33:39.497Z" }, - { url = "https://files.pythonhosted.org/packages/83/b9/49f847fa09b48110cc0f38b72720f979912ac69742de784998b2e36fda18/cmake-4.0.3-py3-none-musllinux_1_1_i686.whl", hash = "sha256:880a1e1ae26d440d7e4f604fecbf839728ca7b096c870f2e7359855cc4828532", size = 31557948, upload-time = "2025-06-13T15:33:43.099Z" }, - { url = "https://files.pythonhosted.org/packages/c0/d8/bbd8eb74bb6c972572293f043a5cd5a56ec9791f8c46ccfbcf53a84aa556/cmake-4.0.3-py3-none-musllinux_1_1_ppc64le.whl", hash = "sha256:c403b660bbff1fd4d7f1c5d9e015ea27566e49ca9461e260c9758f2fd4e5e813", size = 32281822, upload-time = "2025-06-13T15:33:46.544Z" }, - { url = "https://files.pythonhosted.org/packages/df/a4/aebacccbcab31a1896190d57ac3ad9fdeded18f6ce7634b24958c6de8090/cmake-4.0.3-py3-none-musllinux_1_1_s390x.whl", hash = "sha256:2a66ecdd4c3238484cb0c377d689c086a9b8b533e25329f73d21bd1c38f1ae86", size = 28104040, upload-time = "2025-06-13T15:33:49.687Z" }, - { url = "https://files.pythonhosted.org/packages/a2/b3/42cd72162e7b466863ca4c033fb30ef51109b4eaef9686aa81b86f5afd8b/cmake-4.0.3-py3-none-musllinux_1_1_x86_64.whl", hash = "sha256:004e58b1a1a384c2ca799c9c41ac4ed86ac3b80129462992c43c1121f8729ffd", size = 29638511, upload-time = "2025-06-13T15:33:53.063Z" }, - { url = "https://files.pythonhosted.org/packages/d4/4d/d81d27a0d86bf2e24e4574f672b17230db676be2dd878d747439f1f4abfa/cmake-4.0.3-py3-none-musllinux_1_2_armv7l.whl", hash = "sha256:133dbc33f995cb97a4456d83d67fa0a7a798f53f979454359140588baa928f43", size = 33324625, upload-time = "2025-06-13T15:33:57.463Z" }, - { url = "https://files.pythonhosted.org/packages/5d/eb/c7736686066bbaacd06b69228a8cd3cbdac279a069658e4a646b3dee4a9c/cmake-4.0.3-py3-none-win32.whl", hash = "sha256:3e07bdd14e69ea67d1e67a4f5225ac2fd91ee9e349c440143cdddd7368be1f46", size = 33683662, upload-time = "2025-06-13T15:34:01.075Z" }, - { url = "https://files.pythonhosted.org/packages/a6/03/70e3bfff49ee89b3e4a137b5504ad003b0cae8dbc291cb753228f55b4b9f/cmake-4.0.3-py3-none-win_amd64.whl", hash = "sha256:9a349ff2b4a7c63c896061676bc0f4e6994f373d54314d79ba3608ee7fa75442", size = 36911867, upload-time = "2025-06-13T15:34:04.774Z" }, - { url = "https://files.pythonhosted.org/packages/50/ce/9cfee241950e700a3ac67a0dbbd26da24c7e252bd48c5af129586a4caadd/cmake-4.0.3-py3-none-win_arm64.whl", hash = "sha256:94a52e67b264a51089907c9e74ca5a9e2f3e65c57c457e0f40f02629a0de74d8", size = 35706970, upload-time = "2025-06-13T15:34:08.703Z" }, -] - -[[package]] -name = "colorama" -version = "0.4.6" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/d8/53/6f443c9a4a8358a93a6792e2acffb9d9d5cb0a5cfd8802644b7b1c9a02e4/colorama-0.4.6.tar.gz", hash = "sha256:08695f5cb7ed6e0531a20572697297273c47b8cae5a63ffc6d6ed5c201be6e44", size = 27697, upload-time = "2022-10-25T02:36:22.414Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/d1/d6/3965ed04c63042e047cb6a3e6ed1a63a35087b6a609aa3a15ed8ac56c221/colorama-0.4.6-py2.py3-none-any.whl", hash = "sha256:4f1d9991f5acc0ca119f9d443620b77f9d6b33703e51011c16baf57afb285fc6", size = 25335, upload-time = "2022-10-25T02:36:20.889Z" }, -] - -[[package]] -name = "colour" -version = "0.1.5" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/a0/d4/5911a7618acddc3f594ddf144ecd8a03c29074a540f4494670ad8f153efe/colour-0.1.5.tar.gz", hash = "sha256:af20120fefd2afede8b001fbef2ea9da70ad7d49fafdb6489025dae8745c3aee", size = 24776, upload-time = "2017-11-19T23:20:08.015Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/74/46/e81907704ab203206769dee1385dc77e1407576ff8f50a0681d0a6b541be/colour-0.1.5-py2.py3-none-any.whl", hash = "sha256:33f6db9d564fadc16e59921a56999b79571160ce09916303d35346dddc17978c", size = 23772, upload-time = "2017-11-19T23:20:04.56Z" }, -] - -[[package]] -name = "comfyui" -version = "0.3.41" -source = { editable = "." } -dependencies = [ - { name = "accelerate" }, - { name = "aio-pika" }, - { name = "aiofiles" }, - { name = "aiohttp" }, - { name = "albumentations" }, - { name = "alembic" }, - { name = "anthropic" }, - { name = "av" }, - { name = "can-ada" }, - { name = "certifi" }, - { name = "clean-fid" }, - { name = "colour" }, - { name = "comfyui-embedded-docs" }, - { name = "comfyui-frontend-package" }, - { name = "comfyui-workflow-templates" }, - { name = "configargparse" }, - { name = "diffusers" }, - { name = "einops" }, - { name = "flax" }, - { name = "frozendict" }, - { name = "fsspec" }, - { name = "huggingface-hub", extra = ["hf-transfer"] }, - { name = "humanize" }, - { name = "ijson" }, - { name = "importlib-resources" }, - { name = "jax" }, - { name = "jaxtyping" }, - { name = "joblib" }, - { name = "jsonmerge" }, - { name = "kornia" }, - { name = "lazy-loader" }, - { name = "lazy-object-proxy" }, - { name = "lightning", version = "2.3.3", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "lightning", version = "2.5.1.post0", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra != 'extra-7-comfyui-rocm') or sys_platform == 'Linux' or sys_platform == 'darwin' or sys_platform == 'win32' or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra != 'extra-7-comfyui-rocm')" }, - { name = "ml-dtypes" }, - { name = "mpmath" }, - { name = "natsort" }, - { name = "networkx", version = "3.4.2", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "networkx", version = "3.5", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "open-clip-torch" }, - { name = "openai" }, - { name = "opencv-python-headless" }, - { name = "openexr" }, - { name = "opentelemetry-distro" }, - { name = "opentelemetry-exporter-otlp" }, - { name = "opentelemetry-instrumentation" }, - { name = "opentelemetry-instrumentation-aio-pika" }, - { name = "opentelemetry-instrumentation-requests" }, - { name = "opentelemetry-propagator-jaeger" }, - { name = "opentelemetry-semantic-conventions" }, - { name = "opentelemetry-util-http" }, - { name = "pebble" }, - { name = "peft" }, - { name = "pillow" }, - { name = "protobuf" }, - { name = "psutil" }, - { name = "pydantic" }, - { name = "pydantic-settings" }, - { name = "pyjwt", extra = ["crypto"] }, - { name = "pysoundfile" }, - { name = "python-dateutil" }, - { name = "pyyaml" }, - { name = "resize-right" }, - { name = "safetensors" }, - { name = "scikit-image" }, - { name = "scikit-learn" }, - { name = "scipy" }, - { name = "sentencepiece" }, - { name = "setuptools" }, - { name = "skia-python" }, - { name = "soundfile" }, - { name = "spandrel" }, - { name = "spandrel-extra-arches" }, - { name = "sqlalchemy" }, - { name = "tokenizers" }, - { name = "torch", version = "2.0.1", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://pypi.org/simple" }, marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" }, marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "extra == 'extra-7-comfyui-cu128' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchaudio", version = "2.0.2", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchaudio", version = "2.7.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchaudio", version = "2.7.1", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchaudio", version = "2.7.1", source = { registry = "https://pypi.org/simple" }, marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, - { name = "torchaudio", version = "2.7.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchaudio", version = "2.7.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" }, marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchaudio", version = "2.7.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "(platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchaudio", version = "2.7.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchdiffeq" }, - { name = "torchinfo" }, - { name = "torchsde" }, - { name = "torchvision", version = "0.15.2", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1", source = { registry = "https://pypi.org/simple" }, marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" }, marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "(platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "tqdm" }, - { name = "transformers" }, - { name = "typer" }, - { name = "vtracer" }, - { name = "watchdog" }, - { name = "wrapt" }, - { name = "yarl" }, -] - -[package.optional-dependencies] -attention = [ - { name = "flash-attn", marker = "sys_platform == 'Linux' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "sageattention", version = "1.0.6", source = { registry = "https://pypi.org/simple" }, marker = "(sys_platform != 'Linux' and sys_platform != 'win32') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "sageattention", version = "2.1.1", source = { git = "https://github.com/thu-ml/SageAttention.git#b554fc49b59fbcbbcbceae6ccc8bc4d7ea60950d" }, marker = "sys_platform == 'Linux' or sys_platform == 'win32' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -cpu = [ - { name = "torch", version = "2.7.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchaudio", version = "2.7.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchaudio", version = "2.7.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -cu126 = [ - { name = "torch", version = "2.7.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" } }, - { name = "torchaudio", version = "2.7.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" } }, - { name = "torchvision", version = "0.22.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" } }, - { name = "triton", marker = "sys_platform == 'Linux'" }, - { name = "triton-windows", marker = "sys_platform == 'win32'" }, -] -cu128 = [ - { name = "torch", version = "2.7.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" } }, - { name = "torchaudio", version = "2.7.1", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchaudio", version = "2.7.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "(platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "(platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "triton", marker = "sys_platform == 'Linux'" }, - { name = "triton-windows", marker = "sys_platform == 'win32'" }, -] -rocm = [ - { name = "pytorch-triton-rocm" }, - { name = "torch", version = "2.0.1", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchaudio", version = "2.0.2", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchaudio", version = "2.7.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.15.2", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, -] - -[package.dev-dependencies] -dev = [ - { name = "coverage" }, - { name = "freezegun" }, - { name = "mypy" }, - { name = "pyinstaller" }, - { name = "pylint" }, - { name = "pytest" }, - { name = "pytest-aiohttp" }, - { name = "pytest-asyncio" }, - { name = "pytest-mock" }, - { name = "pytest-xdist" }, - { name = "testcontainers" }, - { name = "testcontainers-rabbitmq" }, - { name = "websocket-client" }, -] - -[package.metadata] -requires-dist = [ - { name = "accelerate", specifier = ">=0.25.0" }, - { name = "aio-pika" }, - { name = "aiofiles", specifier = ">=23.1.0" }, - { name = "aiohttp", specifier = ">=3.11.8" }, - { name = "albumentations", specifier = ">=1.3.0" }, - { name = "alembic" }, - { name = "anthropic" }, - { name = "av", specifier = ">=14.2.0" }, - { name = "can-ada" }, - { name = "certifi" }, - { name = "clean-fid", specifier = ">=0.1.35" }, - { name = "colour" }, - { name = "comfyui-embedded-docs" }, - { name = "comfyui-frontend-package", git = "https://github.com/appmana/appmana-comfyui-frontend?subdirectory=comfyui_frontend_package" }, - { name = "comfyui-workflow-templates" }, - { name = "configargparse" }, - { name = "diffusers", specifier = ">=0.30.1" }, - { name = "einops", specifier = ">=0.6.0" }, - { name = "flash-attn", marker = "sys_platform == 'Linux' and extra == 'attention'" }, - { name = "flax" }, - { name = "frozendict", specifier = ">=2.3.6" }, - { name = "fsspec" }, - { name = "huggingface-hub", extras = ["hf-transfer"] }, - { name = "humanize" }, - { name = "ijson" }, - { name = "importlib-resources" }, - { name = "jax" }, - { name = "jaxtyping" }, - { name = "joblib" }, - { name = "jsonmerge", specifier = ">=1.9.0" }, - { name = "kornia", specifier = ">=0.7.0" }, - { name = "lazy-loader", specifier = ">=0.3" }, - { name = "lazy-object-proxy" }, - { name = "lightning" }, - { name = "ml-dtypes" }, - { name = "mpmath", specifier = ">=1.0,!=1.4.0a0" }, - { name = "natsort" }, - { name = "networkx", specifier = ">=2.6.3" }, - { name = "numpy", specifier = ">=1.24.4" }, - { name = "open-clip-torch", specifier = ">=2.24.0" }, - { name = "openai" }, - { name = "opencv-python-headless", specifier = ">=4.9.0.80" }, - { name = "openexr" }, - { name = "opentelemetry-distro" }, - { name = "opentelemetry-exporter-otlp", specifier = "<=1.27.0" }, - { name = "opentelemetry-instrumentation" }, - { name = "opentelemetry-instrumentation-aio-pika" }, - { name = "opentelemetry-instrumentation-requests" }, - { name = "opentelemetry-propagator-jaeger" }, - { name = "opentelemetry-semantic-conventions" }, - { name = "opentelemetry-util-http" }, - { name = "pebble", specifier = ">=5.0.7" }, - { name = "peft", specifier = ">=0.10.0" }, - { name = "pillow" }, - { name = "protobuf", specifier = ">=3.20.0,<5.0.0" }, - { name = "psutil" }, - { name = "pydantic", specifier = "~=2.0" }, - { name = "pydantic-settings", specifier = "~=2.0" }, - { name = "pyjwt", extras = ["crypto"] }, - { name = "pysoundfile" }, - { name = "python-dateutil", specifier = ">=2.8.2" }, - { name = "pytorch-triton-rocm", marker = "extra == 'rocm'" }, - { name = "pyyaml", specifier = ">=6.0" }, - { name = "resize-right", specifier = ">=0.0.2" }, - { name = "safetensors", specifier = ">=0.4.2" }, - { name = "sageattention", marker = "(sys_platform == 'Linux' and extra == 'attention') or (sys_platform == 'win32' and extra == 'attention')", git = "https://github.com/thu-ml/SageAttention.git" }, - { name = "sageattention", marker = "sys_platform != 'Linux' and sys_platform != 'win32' and extra == 'attention'" }, - { name = "scikit-image", specifier = ">=0.20.0" }, - { name = "scikit-learn", specifier = ">=1.4.1" }, - { name = "scipy" }, - { name = "sentencepiece" }, - { name = "setuptools" }, - { name = "skia-python" }, - { name = "soundfile" }, - { name = "spandrel", specifier = ">=0.3.4" }, - { name = "spandrel-extra-arches" }, - { name = "sqlalchemy" }, - { name = "tokenizers", specifier = ">=0.13.3" }, - { name = "torch" }, - { name = "torch", marker = "(sys_platform == 'Linux' and extra == 'cu126') or (sys_platform == 'win32' and extra == 'cu126')", index = "https://download.pytorch.org/whl/cu126", conflict = { package = "comfyui", extra = "cu126" } }, - { name = "torch", marker = "(sys_platform == 'Linux' and extra == 'cu128') or (sys_platform == 'win32' and extra == 'cu128')", index = "https://download.pytorch.org/whl/cu128", conflict = { package = "comfyui", extra = "cu128" } }, - { name = "torch", marker = "sys_platform == 'Linux' and extra == 'rocm'", index = "https://download.pytorch.org/whl/rocm6.3", conflict = { package = "comfyui", extra = "rocm" } }, - { name = "torch", marker = "sys_platform != 'Linux' and sys_platform != 'win32' and extra == 'cu126'" }, - { name = "torch", marker = "sys_platform != 'Linux' and sys_platform != 'win32' and extra == 'cu128'" }, - { name = "torch", marker = "sys_platform != 'Linux' and extra == 'rocm'" }, - { name = "torch", marker = "extra == 'cpu'", index = "https://download.pytorch.org/whl/cpu", conflict = { package = "comfyui", extra = "cpu" } }, - { name = "torchaudio" }, - { name = "torchaudio", marker = "(sys_platform == 'Linux' and extra == 'cu126') or (sys_platform == 'win32' and extra == 'cu126')", index = "https://download.pytorch.org/whl/cu126", conflict = { package = "comfyui", extra = "cu126" } }, - { name = "torchaudio", marker = "(sys_platform == 'Linux' and extra == 'cu128') or (sys_platform == 'win32' and extra == 'cu128')", index = "https://download.pytorch.org/whl/cu128", conflict = { package = "comfyui", extra = "cu128" } }, - { name = "torchaudio", marker = "sys_platform == 'Linux' and extra == 'rocm'", index = "https://download.pytorch.org/whl/rocm6.3", conflict = { package = "comfyui", extra = "rocm" } }, - { name = "torchaudio", marker = "sys_platform != 'Linux' and sys_platform != 'win32' and extra == 'cu126'" }, - { name = "torchaudio", marker = "sys_platform != 'Linux' and sys_platform != 'win32' and extra == 'cu128'" }, - { name = "torchaudio", marker = "sys_platform != 'Linux' and extra == 'rocm'" }, - { name = "torchaudio", marker = "extra == 'cpu'", index = "https://download.pytorch.org/whl/cpu", conflict = { package = "comfyui", extra = "cpu" } }, - { name = "torchdiffeq", specifier = ">=0.2.3" }, - { name = "torchinfo" }, - { name = "torchsde", specifier = ">=0.2.6" }, - { name = "torchvision" }, - { name = "torchvision", marker = "(sys_platform == 'Linux' and extra == 'cu126') or (sys_platform == 'win32' and extra == 'cu126')", index = "https://download.pytorch.org/whl/cu126", conflict = { package = "comfyui", extra = "cu126" } }, - { name = "torchvision", marker = "(sys_platform == 'Linux' and extra == 'cu128') or (sys_platform == 'win32' and extra == 'cu128')", index = "https://download.pytorch.org/whl/cu128", conflict = { package = "comfyui", extra = "cu128" } }, - { name = "torchvision", marker = "sys_platform == 'Linux' and extra == 'rocm'", index = "https://download.pytorch.org/whl/rocm6.3", conflict = { package = "comfyui", extra = "rocm" } }, - { name = "torchvision", marker = "sys_platform != 'Linux' and sys_platform != 'win32' and extra == 'cu126'" }, - { name = "torchvision", marker = "sys_platform != 'Linux' and sys_platform != 'win32' and extra == 'cu128'" }, - { name = "torchvision", marker = "sys_platform != 'Linux' and extra == 'rocm'" }, - { name = "torchvision", marker = "extra == 'cpu'", index = "https://download.pytorch.org/whl/cpu", conflict = { package = "comfyui", extra = "cpu" } }, - { name = "tqdm" }, - { name = "transformers", specifier = ">=4.29.1" }, - { name = "triton", marker = "sys_platform == 'Linux' and extra == 'cu126'" }, - { name = "triton", marker = "sys_platform == 'Linux' and extra == 'cu128'" }, - { name = "triton-windows", marker = "sys_platform == 'win32' and extra == 'cu126'" }, - { name = "triton-windows", marker = "sys_platform == 'win32' and extra == 'cu128'" }, - { name = "typer" }, - { name = "vtracer" }, - { name = "watchdog" }, - { name = "wrapt", specifier = ">=1.16.0" }, - { name = "yarl", specifier = ">=1.9.4" }, -] -provides-extras = ["cpu", "cu126", "cu128", "rocm", "attention"] - -[package.metadata.requires-dev] -dev = [ - { name = "coverage" }, - { name = "freezegun" }, - { name = "mypy", specifier = ">=1.6.0" }, - { name = "pyinstaller" }, - { name = "pylint" }, - { name = "pytest" }, - { name = "pytest-aiohttp" }, - { name = "pytest-asyncio" }, - { name = "pytest-mock" }, - { name = "pytest-xdist" }, - { name = "testcontainers" }, - { name = "testcontainers-rabbitmq" }, - { name = "websocket-client", specifier = ">=1.6.1" }, -] - -[[package]] -name = "comfyui-embedded-docs" -version = "0.2.2" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/4c/b7/a26af9088f3cc37fe51d9c603e0f2ed6a35f6c7ea941df6d46fd7910a22d/comfyui_embedded_docs-0.2.2.tar.gz", hash = "sha256:1fe54d145970185b89a0a09ccda8a29e295a832c0044baf40dcdfbe741438d59", size = 572274, upload-time = "2025-06-13T03:52:14.241Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/ff/a5/16f7adeaa8fa954528cec084920ae6b567c840795dbf957eb18d41e73f7e/comfyui_embedded_docs-0.2.2-py3-none-any.whl", hash = "sha256:6e0b4c905034e3b193210de5c7a81bf473ef73d6d1623a17a6ae76c8382fdca7", size = 878970, upload-time = "2025-06-13T03:52:12.805Z" }, -] - -[[package]] -name = "comfyui-frontend-package" -version = "0.1.0" -source = { git = "https://github.com/appmana/appmana-comfyui-frontend?subdirectory=comfyui_frontend_package#0b03530a94de58f0d1785e4dbdda06de711c85de" } - -[[package]] -name = "comfyui-workflow-templates" -version = "0.1.29" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/48/61/d360fabb5dc1e9690cea9e50193f258c126d97240026bd79bc01b740fdb5/comfyui_workflow_templates-0.1.29.tar.gz", hash = "sha256:919ae222289cc4a379f619a6fbcebb4eb2bf4566d2df48ea230a96de73478eb5", size = 71363457, upload-time = "2025-06-17T10:42:48.189Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/f1/25/63f7bfe9578ae2a8c3cbe20439e166efaf9c71f4fe4b333350a93fde8676/comfyui_workflow_templates-0.1.29-py3-none-any.whl", hash = "sha256:f1d287f8e95306625e9a27beb063ec04233349e9c7a8692bcb37c35223bf7f19", size = 71375491, upload-time = "2025-06-17T10:42:43.854Z" }, -] - -[[package]] -name = "configargparse" -version = "1.7.1" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/85/4d/6c9ef746dfcc2a32e26f3860bb4a011c008c392b83eabdfb598d1a8bbe5d/configargparse-1.7.1.tar.gz", hash = "sha256:79c2ddae836a1e5914b71d58e4b9adbd9f7779d4e6351a637b7d2d9b6c46d3d9", size = 43958, upload-time = "2025-05-23T14:26:17.369Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/31/28/d28211d29bcc3620b1fece85a65ce5bb22f18670a03cd28ea4b75ede270c/configargparse-1.7.1-py3-none-any.whl", hash = "sha256:8b586a31f9d873abd1ca527ffbe58863c99f36d896e2829779803125e83be4b6", size = 25607, upload-time = "2025-05-23T14:26:15.923Z" }, -] - -[[package]] -name = "coverage" -version = "7.9.1" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/e7/e0/98670a80884f64578f0c22cd70c5e81a6e07b08167721c7487b4d70a7ca0/coverage-7.9.1.tar.gz", hash = "sha256:6cf43c78c4282708a28e466316935ec7489a9c487518a77fa68f716c67909cec", size = 813650, upload-time = "2025-06-13T13:02:28.627Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/c1/78/1c1c5ec58f16817c09cbacb39783c3655d54a221b6552f47ff5ac9297603/coverage-7.9.1-cp310-cp310-macosx_10_9_x86_64.whl", hash = "sha256:cc94d7c5e8423920787c33d811c0be67b7be83c705f001f7180c7b186dcf10ca", size = 212028, upload-time = "2025-06-13T13:00:29.293Z" }, - { url = "https://files.pythonhosted.org/packages/98/db/e91b9076f3a888e3b4ad7972ea3842297a52cc52e73fd1e529856e473510/coverage-7.9.1-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:16aa0830d0c08a2c40c264cef801db8bc4fc0e1892782e45bcacbd5889270509", size = 212420, upload-time = "2025-06-13T13:00:34.027Z" }, - { url = "https://files.pythonhosted.org/packages/0e/d0/2b3733412954576b0aea0a16c3b6b8fbe95eb975d8bfa10b07359ead4252/coverage-7.9.1-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:cf95981b126f23db63e9dbe4cf65bd71f9a6305696fa5e2262693bc4e2183f5b", size = 241529, upload-time = "2025-06-13T13:00:35.786Z" }, - { url = "https://files.pythonhosted.org/packages/b3/00/5e2e5ae2e750a872226a68e984d4d3f3563cb01d1afb449a17aa819bc2c4/coverage-7.9.1-cp310-cp310-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:f05031cf21699785cd47cb7485f67df619e7bcdae38e0fde40d23d3d0210d3c3", size = 239403, upload-time = "2025-06-13T13:00:37.399Z" }, - { url = "https://files.pythonhosted.org/packages/37/3b/a2c27736035156b0a7c20683afe7df498480c0dfdf503b8c878a21b6d7fb/coverage-7.9.1-cp310-cp310-manylinux_2_5_x86_64.manylinux1_x86_64.manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:bb4fbcab8764dc072cb651a4bcda4d11fb5658a1d8d68842a862a6610bd8cfa3", size = 240548, upload-time = "2025-06-13T13:00:39.647Z" }, - { url = "https://files.pythonhosted.org/packages/98/f5/13d5fc074c3c0e0dc80422d9535814abf190f1254d7c3451590dc4f8b18c/coverage-7.9.1-cp310-cp310-musllinux_1_2_aarch64.whl", hash = "sha256:0f16649a7330ec307942ed27d06ee7e7a38417144620bb3d6e9a18ded8a2d3e5", size = 240459, upload-time = "2025-06-13T13:00:40.934Z" }, - { url = "https://files.pythonhosted.org/packages/36/24/24b9676ea06102df824c4a56ffd13dc9da7904478db519efa877d16527d5/coverage-7.9.1-cp310-cp310-musllinux_1_2_i686.whl", hash = "sha256:cea0a27a89e6432705fffc178064503508e3c0184b4f061700e771a09de58187", size = 239128, upload-time = "2025-06-13T13:00:42.343Z" }, - { url = "https://files.pythonhosted.org/packages/be/05/242b7a7d491b369ac5fee7908a6e5ba42b3030450f3ad62c645b40c23e0e/coverage-7.9.1-cp310-cp310-musllinux_1_2_x86_64.whl", hash = "sha256:e980b53a959fa53b6f05343afbd1e6f44a23ed6c23c4b4c56c6662bbb40c82ce", size = 239402, upload-time = "2025-06-13T13:00:43.634Z" }, - { url = "https://files.pythonhosted.org/packages/73/e0/4de7f87192fa65c9c8fbaeb75507e124f82396b71de1797da5602898be32/coverage-7.9.1-cp310-cp310-win32.whl", hash = "sha256:70760b4c5560be6ca70d11f8988ee6542b003f982b32f83d5ac0b72476607b70", size = 214518, upload-time = "2025-06-13T13:00:45.622Z" }, - { url = "https://files.pythonhosted.org/packages/d5/ab/5e4e2fe458907d2a65fab62c773671cfc5ac704f1e7a9ddd91996f66e3c2/coverage-7.9.1-cp310-cp310-win_amd64.whl", hash = "sha256:a66e8f628b71f78c0e0342003d53b53101ba4e00ea8dabb799d9dba0abbbcebe", size = 215436, upload-time = "2025-06-13T13:00:47.245Z" }, - { url = "https://files.pythonhosted.org/packages/60/34/fa69372a07d0903a78ac103422ad34db72281c9fc625eba94ac1185da66f/coverage-7.9.1-cp311-cp311-macosx_10_9_x86_64.whl", hash = "sha256:95c765060e65c692da2d2f51a9499c5e9f5cf5453aeaf1420e3fc847cc060582", size = 212146, upload-time = "2025-06-13T13:00:48.496Z" }, - { url = "https://files.pythonhosted.org/packages/27/f0/da1894915d2767f093f081c42afeba18e760f12fdd7a2f4acbe00564d767/coverage-7.9.1-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:ba383dc6afd5ec5b7a0d0c23d38895db0e15bcba7fb0fa8901f245267ac30d86", size = 212536, upload-time = "2025-06-13T13:00:51.535Z" }, - { url = "https://files.pythonhosted.org/packages/10/d5/3fc33b06e41e390f88eef111226a24e4504d216ab8e5d1a7089aa5a3c87a/coverage-7.9.1-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:37ae0383f13cbdcf1e5e7014489b0d71cc0106458878ccde52e8a12ced4298ed", size = 245092, upload-time = "2025-06-13T13:00:52.883Z" }, - { url = "https://files.pythonhosted.org/packages/0a/39/7aa901c14977aba637b78e95800edf77f29f5a380d29768c5b66f258305b/coverage-7.9.1-cp311-cp311-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:69aa417a030bf11ec46149636314c24c8d60fadb12fc0ee8f10fda0d918c879d", size = 242806, upload-time = "2025-06-13T13:00:54.571Z" }, - { url = "https://files.pythonhosted.org/packages/43/fc/30e5cfeaf560b1fc1989227adedc11019ce4bb7cce59d65db34fe0c2d963/coverage-7.9.1-cp311-cp311-manylinux_2_5_x86_64.manylinux1_x86_64.manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:0a4be2a28656afe279b34d4f91c3e26eccf2f85500d4a4ff0b1f8b54bf807338", size = 244610, upload-time = "2025-06-13T13:00:56.932Z" }, - { url = "https://files.pythonhosted.org/packages/bf/15/cca62b13f39650bc87b2b92bb03bce7f0e79dd0bf2c7529e9fc7393e4d60/coverage-7.9.1-cp311-cp311-musllinux_1_2_aarch64.whl", hash = "sha256:382e7ddd5289f140259b610e5f5c58f713d025cb2f66d0eb17e68d0a94278875", size = 244257, upload-time = "2025-06-13T13:00:58.545Z" }, - { url = "https://files.pythonhosted.org/packages/cd/1a/c0f2abe92c29e1464dbd0ff9d56cb6c88ae2b9e21becdb38bea31fcb2f6c/coverage-7.9.1-cp311-cp311-musllinux_1_2_i686.whl", hash = "sha256:e5532482344186c543c37bfad0ee6069e8ae4fc38d073b8bc836fc8f03c9e250", size = 242309, upload-time = "2025-06-13T13:00:59.836Z" }, - { url = "https://files.pythonhosted.org/packages/57/8d/c6fd70848bd9bf88fa90df2af5636589a8126d2170f3aade21ed53f2b67a/coverage-7.9.1-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:a39d18b3f50cc121d0ce3838d32d58bd1d15dab89c910358ebefc3665712256c", size = 242898, upload-time = "2025-06-13T13:01:02.506Z" }, - { url = "https://files.pythonhosted.org/packages/c2/9e/6ca46c7bff4675f09a66fe2797cd1ad6a24f14c9c7c3b3ebe0470a6e30b8/coverage-7.9.1-cp311-cp311-win32.whl", hash = "sha256:dd24bd8d77c98557880def750782df77ab2b6885a18483dc8588792247174b32", size = 214561, upload-time = "2025-06-13T13:01:04.012Z" }, - { url = "https://files.pythonhosted.org/packages/a1/30/166978c6302010742dabcdc425fa0f938fa5a800908e39aff37a7a876a13/coverage-7.9.1-cp311-cp311-win_amd64.whl", hash = "sha256:6b55ad10a35a21b8015eabddc9ba31eb590f54adc9cd39bcf09ff5349fd52125", size = 215493, upload-time = "2025-06-13T13:01:05.702Z" }, - { url = "https://files.pythonhosted.org/packages/60/07/a6d2342cd80a5be9f0eeab115bc5ebb3917b4a64c2953534273cf9bc7ae6/coverage-7.9.1-cp311-cp311-win_arm64.whl", hash = "sha256:6ad935f0016be24c0e97fc8c40c465f9c4b85cbbe6eac48934c0dc4d2568321e", size = 213869, upload-time = "2025-06-13T13:01:09.345Z" }, - { url = "https://files.pythonhosted.org/packages/68/d9/7f66eb0a8f2fce222de7bdc2046ec41cb31fe33fb55a330037833fb88afc/coverage-7.9.1-cp312-cp312-macosx_10_13_x86_64.whl", hash = "sha256:a8de12b4b87c20de895f10567639c0797b621b22897b0af3ce4b4e204a743626", size = 212336, upload-time = "2025-06-13T13:01:10.909Z" }, - { url = "https://files.pythonhosted.org/packages/20/20/e07cb920ef3addf20f052ee3d54906e57407b6aeee3227a9c91eea38a665/coverage-7.9.1-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:5add197315a054e92cee1b5f686a2bcba60c4c3e66ee3de77ace6c867bdee7cb", size = 212571, upload-time = "2025-06-13T13:01:12.518Z" }, - { url = "https://files.pythonhosted.org/packages/78/f8/96f155de7e9e248ca9c8ff1a40a521d944ba48bec65352da9be2463745bf/coverage-7.9.1-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:600a1d4106fe66f41e5d0136dfbc68fe7200a5cbe85610ddf094f8f22e1b0300", size = 246377, upload-time = "2025-06-13T13:01:14.87Z" }, - { url = "https://files.pythonhosted.org/packages/3e/cf/1d783bd05b7bca5c10ded5f946068909372e94615a4416afadfe3f63492d/coverage-7.9.1-cp312-cp312-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:2a876e4c3e5a2a1715a6608906aa5a2e0475b9c0f68343c2ada98110512ab1d8", size = 243394, upload-time = "2025-06-13T13:01:16.23Z" }, - { url = "https://files.pythonhosted.org/packages/02/dd/e7b20afd35b0a1abea09fb3998e1abc9f9bd953bee548f235aebd2b11401/coverage-7.9.1-cp312-cp312-manylinux_2_5_x86_64.manylinux1_x86_64.manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:81f34346dd63010453922c8e628a52ea2d2ccd73cb2487f7700ac531b247c8a5", size = 245586, upload-time = "2025-06-13T13:01:17.532Z" }, - { url = "https://files.pythonhosted.org/packages/4e/38/b30b0006fea9d617d1cb8e43b1bc9a96af11eff42b87eb8c716cf4d37469/coverage-7.9.1-cp312-cp312-musllinux_1_2_aarch64.whl", hash = "sha256:888f8eee13f2377ce86d44f338968eedec3291876b0b8a7289247ba52cb984cd", size = 245396, upload-time = "2025-06-13T13:01:19.164Z" }, - { url = "https://files.pythonhosted.org/packages/31/e4/4d8ec1dc826e16791f3daf1b50943e8e7e1eb70e8efa7abb03936ff48418/coverage-7.9.1-cp312-cp312-musllinux_1_2_i686.whl", hash = "sha256:9969ef1e69b8c8e1e70d591f91bbc37fc9a3621e447525d1602801a24ceda898", size = 243577, upload-time = "2025-06-13T13:01:22.433Z" }, - { url = "https://files.pythonhosted.org/packages/25/f4/b0e96c5c38e6e40ef465c4bc7f138863e2909c00e54a331da335faf0d81a/coverage-7.9.1-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:60c458224331ee3f1a5b472773e4a085cc27a86a0b48205409d364272d67140d", size = 244809, upload-time = "2025-06-13T13:01:24.143Z" }, - { url = "https://files.pythonhosted.org/packages/8a/65/27e0a1fa5e2e5079bdca4521be2f5dabf516f94e29a0defed35ac2382eb2/coverage-7.9.1-cp312-cp312-win32.whl", hash = "sha256:5f646a99a8c2b3ff4c6a6e081f78fad0dde275cd59f8f49dc4eab2e394332e74", size = 214724, upload-time = "2025-06-13T13:01:25.435Z" }, - { url = "https://files.pythonhosted.org/packages/9b/a8/d5b128633fd1a5e0401a4160d02fa15986209a9e47717174f99dc2f7166d/coverage-7.9.1-cp312-cp312-win_amd64.whl", hash = "sha256:30f445f85c353090b83e552dcbbdad3ec84c7967e108c3ae54556ca69955563e", size = 215535, upload-time = "2025-06-13T13:01:27.861Z" }, - { url = "https://files.pythonhosted.org/packages/a3/37/84bba9d2afabc3611f3e4325ee2c6a47cd449b580d4a606b240ce5a6f9bf/coverage-7.9.1-cp312-cp312-win_arm64.whl", hash = "sha256:af41da5dca398d3474129c58cb2b106a5d93bbb196be0d307ac82311ca234342", size = 213904, upload-time = "2025-06-13T13:01:29.202Z" }, - { url = "https://files.pythonhosted.org/packages/d0/a7/a027970c991ca90f24e968999f7d509332daf6b8c3533d68633930aaebac/coverage-7.9.1-cp313-cp313-macosx_10_13_x86_64.whl", hash = "sha256:31324f18d5969feef7344a932c32428a2d1a3e50b15a6404e97cba1cc9b2c631", size = 212358, upload-time = "2025-06-13T13:01:30.909Z" }, - { url = "https://files.pythonhosted.org/packages/f2/48/6aaed3651ae83b231556750280682528fea8ac7f1232834573472d83e459/coverage-7.9.1-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:0c804506d624e8a20fb3108764c52e0eef664e29d21692afa375e0dd98dc384f", size = 212620, upload-time = "2025-06-13T13:01:32.256Z" }, - { url = "https://files.pythonhosted.org/packages/6c/2a/f4b613f3b44d8b9f144847c89151992b2b6b79cbc506dee89ad0c35f209d/coverage-7.9.1-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:ef64c27bc40189f36fcc50c3fb8f16ccda73b6a0b80d9bd6e6ce4cffcd810bbd", size = 245788, upload-time = "2025-06-13T13:01:33.948Z" }, - { url = "https://files.pythonhosted.org/packages/04/d2/de4fdc03af5e4e035ef420ed26a703c6ad3d7a07aff2e959eb84e3b19ca8/coverage-7.9.1-cp313-cp313-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:d4fe2348cc6ec372e25adec0219ee2334a68d2f5222e0cba9c0d613394e12d86", size = 243001, upload-time = "2025-06-13T13:01:35.285Z" }, - { url = "https://files.pythonhosted.org/packages/f5/e8/eed18aa5583b0423ab7f04e34659e51101135c41cd1dcb33ac1d7013a6d6/coverage-7.9.1-cp313-cp313-manylinux_2_5_x86_64.manylinux1_x86_64.manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:34ed2186fe52fcc24d4561041979a0dec69adae7bce2ae8d1c49eace13e55c43", size = 244985, upload-time = "2025-06-13T13:01:36.712Z" }, - { url = "https://files.pythonhosted.org/packages/17/f8/ae9e5cce8885728c934eaa58ebfa8281d488ef2afa81c3dbc8ee9e6d80db/coverage-7.9.1-cp313-cp313-musllinux_1_2_aarch64.whl", hash = "sha256:25308bd3d00d5eedd5ae7d4357161f4df743e3c0240fa773ee1b0f75e6c7c0f1", size = 245152, upload-time = "2025-06-13T13:01:39.303Z" }, - { url = "https://files.pythonhosted.org/packages/5a/c8/272c01ae792bb3af9b30fac14d71d63371db227980682836ec388e2c57c0/coverage-7.9.1-cp313-cp313-musllinux_1_2_i686.whl", hash = "sha256:73e9439310f65d55a5a1e0564b48e34f5369bee943d72c88378f2d576f5a5751", size = 243123, upload-time = "2025-06-13T13:01:40.727Z" }, - { url = "https://files.pythonhosted.org/packages/8c/d0/2819a1e3086143c094ab446e3bdf07138527a7b88cb235c488e78150ba7a/coverage-7.9.1-cp313-cp313-musllinux_1_2_x86_64.whl", hash = "sha256:37ab6be0859141b53aa89412a82454b482c81cf750de4f29223d52268a86de67", size = 244506, upload-time = "2025-06-13T13:01:42.184Z" }, - { url = "https://files.pythonhosted.org/packages/8b/4e/9f6117b89152df7b6112f65c7a4ed1f2f5ec8e60c4be8f351d91e7acc848/coverage-7.9.1-cp313-cp313-win32.whl", hash = "sha256:64bdd969456e2d02a8b08aa047a92d269c7ac1f47e0c977675d550c9a0863643", size = 214766, upload-time = "2025-06-13T13:01:44.482Z" }, - { url = "https://files.pythonhosted.org/packages/27/0f/4b59f7c93b52c2c4ce7387c5a4e135e49891bb3b7408dcc98fe44033bbe0/coverage-7.9.1-cp313-cp313-win_amd64.whl", hash = "sha256:be9e3f68ca9edb897c2184ad0eee815c635565dbe7a0e7e814dc1f7cbab92c0a", size = 215568, upload-time = "2025-06-13T13:01:45.772Z" }, - { url = "https://files.pythonhosted.org/packages/09/1e/9679826336f8c67b9c39a359352882b24a8a7aee48d4c9cad08d38d7510f/coverage-7.9.1-cp313-cp313-win_arm64.whl", hash = "sha256:1c503289ffef1d5105d91bbb4d62cbe4b14bec4d13ca225f9c73cde9bb46207d", size = 213939, upload-time = "2025-06-13T13:01:47.087Z" }, - { url = "https://files.pythonhosted.org/packages/bb/5b/5c6b4e7a407359a2e3b27bf9c8a7b658127975def62077d441b93a30dbe8/coverage-7.9.1-cp313-cp313t-macosx_10_13_x86_64.whl", hash = "sha256:0b3496922cb5f4215bf5caaef4cf12364a26b0be82e9ed6d050f3352cf2d7ef0", size = 213079, upload-time = "2025-06-13T13:01:48.554Z" }, - { url = "https://files.pythonhosted.org/packages/a2/22/1e2e07279fd2fd97ae26c01cc2186e2258850e9ec125ae87184225662e89/coverage-7.9.1-cp313-cp313t-macosx_11_0_arm64.whl", hash = "sha256:9565c3ab1c93310569ec0d86b017f128f027cab0b622b7af288696d7ed43a16d", size = 213299, upload-time = "2025-06-13T13:01:49.997Z" }, - { url = "https://files.pythonhosted.org/packages/14/c0/4c5125a4b69d66b8c85986d3321520f628756cf524af810baab0790c7647/coverage-7.9.1-cp313-cp313t-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:2241ad5dbf79ae1d9c08fe52b36d03ca122fb9ac6bca0f34439e99f8327ac89f", size = 256535, upload-time = "2025-06-13T13:01:51.314Z" }, - { url = "https://files.pythonhosted.org/packages/81/8b/e36a04889dda9960be4263e95e777e7b46f1bb4fc32202612c130a20c4da/coverage-7.9.1-cp313-cp313t-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:3bb5838701ca68b10ebc0937dbd0eb81974bac54447c55cd58dea5bca8451029", size = 252756, upload-time = "2025-06-13T13:01:54.403Z" }, - { url = "https://files.pythonhosted.org/packages/98/82/be04eff8083a09a4622ecd0e1f31a2c563dbea3ed848069e7b0445043a70/coverage-7.9.1-cp313-cp313t-manylinux_2_5_x86_64.manylinux1_x86_64.manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:b30a25f814591a8c0c5372c11ac8967f669b97444c47fd794926e175c4047ece", size = 254912, upload-time = "2025-06-13T13:01:56.769Z" }, - { url = "https://files.pythonhosted.org/packages/0f/25/c26610a2c7f018508a5ab958e5b3202d900422cf7cdca7670b6b8ca4e8df/coverage-7.9.1-cp313-cp313t-musllinux_1_2_aarch64.whl", hash = "sha256:2d04b16a6062516df97969f1ae7efd0de9c31eb6ebdceaa0d213b21c0ca1a683", size = 256144, upload-time = "2025-06-13T13:01:58.19Z" }, - { url = "https://files.pythonhosted.org/packages/c5/8b/fb9425c4684066c79e863f1e6e7ecebb49e3a64d9f7f7860ef1688c56f4a/coverage-7.9.1-cp313-cp313t-musllinux_1_2_i686.whl", hash = "sha256:7931b9e249edefb07cd6ae10c702788546341d5fe44db5b6108a25da4dca513f", size = 254257, upload-time = "2025-06-13T13:01:59.645Z" }, - { url = "https://files.pythonhosted.org/packages/93/df/27b882f54157fc1131e0e215b0da3b8d608d9b8ef79a045280118a8f98fe/coverage-7.9.1-cp313-cp313t-musllinux_1_2_x86_64.whl", hash = "sha256:52e92b01041151bf607ee858e5a56c62d4b70f4dac85b8c8cb7fb8a351ab2c10", size = 255094, upload-time = "2025-06-13T13:02:01.37Z" }, - { url = "https://files.pythonhosted.org/packages/41/5f/cad1c3dbed8b3ee9e16fa832afe365b4e3eeab1fb6edb65ebbf745eabc92/coverage-7.9.1-cp313-cp313t-win32.whl", hash = "sha256:684e2110ed84fd1ca5f40e89aa44adf1729dc85444004111aa01866507adf363", size = 215437, upload-time = "2025-06-13T13:02:02.905Z" }, - { url = "https://files.pythonhosted.org/packages/99/4d/fad293bf081c0e43331ca745ff63673badc20afea2104b431cdd8c278b4c/coverage-7.9.1-cp313-cp313t-win_amd64.whl", hash = "sha256:437c576979e4db840539674e68c84b3cda82bc824dd138d56bead1435f1cb5d7", size = 216605, upload-time = "2025-06-13T13:02:05.638Z" }, - { url = "https://files.pythonhosted.org/packages/1f/56/4ee027d5965fc7fc126d7ec1187529cc30cc7d740846e1ecb5e92d31b224/coverage-7.9.1-cp313-cp313t-win_arm64.whl", hash = "sha256:18a0912944d70aaf5f399e350445738a1a20b50fbea788f640751c2ed9208b6c", size = 214392, upload-time = "2025-06-13T13:02:07.642Z" }, - { url = "https://files.pythonhosted.org/packages/3e/e5/c723545c3fd3204ebde3b4cc4b927dce709d3b6dc577754bb57f63ca4a4a/coverage-7.9.1-pp39.pp310.pp311-none-any.whl", hash = "sha256:db0f04118d1db74db6c9e1cb1898532c7dcc220f1d2718f058601f7c3f499514", size = 204009, upload-time = "2025-06-13T13:02:25.787Z" }, - { url = "https://files.pythonhosted.org/packages/08/b8/7ddd1e8ba9701dea08ce22029917140e6f66a859427406579fd8d0ca7274/coverage-7.9.1-py3-none-any.whl", hash = "sha256:66b974b145aa189516b6bf2d8423e888b742517d37872f6ee4c5be0073bd9a3c", size = 204000, upload-time = "2025-06-13T13:02:27.173Z" }, -] - -[[package]] -name = "cryptography" -version = "45.0.4" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "cffi", marker = "platform_python_implementation != 'PyPy' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/fe/c8/a2a376a8711c1e11708b9c9972e0c3223f5fc682552c82d8db844393d6ce/cryptography-45.0.4.tar.gz", hash = "sha256:7405ade85c83c37682c8fe65554759800a4a8c54b2d96e0f8ad114d31b808d57", size = 744890, upload-time = "2025-06-10T00:03:51.297Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/cc/1c/92637793de053832523b410dbe016d3f5c11b41d0cf6eef8787aabb51d41/cryptography-45.0.4-cp311-abi3-macosx_10_9_universal2.whl", hash = "sha256:425a9a6ac2823ee6e46a76a21a4e8342d8fa5c01e08b823c1f19a8b74f096069", size = 7055712, upload-time = "2025-06-10T00:02:38.826Z" }, - { url = "https://files.pythonhosted.org/packages/ba/14/93b69f2af9ba832ad6618a03f8a034a5851dc9a3314336a3d71c252467e1/cryptography-45.0.4-cp311-abi3-manylinux2014_aarch64.manylinux_2_17_aarch64.whl", hash = "sha256:680806cf63baa0039b920f4976f5f31b10e772de42f16310a6839d9f21a26b0d", size = 4205335, upload-time = "2025-06-10T00:02:41.64Z" }, - { url = "https://files.pythonhosted.org/packages/67/30/fae1000228634bf0b647fca80403db5ca9e3933b91dd060570689f0bd0f7/cryptography-45.0.4-cp311-abi3-manylinux2014_x86_64.manylinux_2_17_x86_64.whl", hash = "sha256:4ca0f52170e821bc8da6fc0cc565b7bb8ff8d90d36b5e9fdd68e8a86bdf72036", size = 4431487, upload-time = "2025-06-10T00:02:43.696Z" }, - { url = "https://files.pythonhosted.org/packages/6d/5a/7dffcf8cdf0cb3c2430de7404b327e3db64735747d641fc492539978caeb/cryptography-45.0.4-cp311-abi3-manylinux_2_28_aarch64.whl", hash = "sha256:f3fe7a5ae34d5a414957cc7f457e2b92076e72938423ac64d215722f6cf49a9e", size = 4208922, upload-time = "2025-06-10T00:02:45.334Z" }, - { url = "https://files.pythonhosted.org/packages/c6/f3/528729726eb6c3060fa3637253430547fbaaea95ab0535ea41baa4a6fbd8/cryptography-45.0.4-cp311-abi3-manylinux_2_28_armv7l.manylinux_2_31_armv7l.whl", hash = "sha256:25eb4d4d3e54595dc8adebc6bbd5623588991d86591a78c2548ffb64797341e2", size = 3900433, upload-time = "2025-06-10T00:02:47.359Z" }, - { url = "https://files.pythonhosted.org/packages/d9/4a/67ba2e40f619e04d83c32f7e1d484c1538c0800a17c56a22ff07d092ccc1/cryptography-45.0.4-cp311-abi3-manylinux_2_28_x86_64.whl", hash = "sha256:ce1678a2ccbe696cf3af15a75bb72ee008d7ff183c9228592ede9db467e64f1b", size = 4464163, upload-time = "2025-06-10T00:02:49.412Z" }, - { url = "https://files.pythonhosted.org/packages/7e/9a/b4d5aa83661483ac372464809c4b49b5022dbfe36b12fe9e323ca8512420/cryptography-45.0.4-cp311-abi3-manylinux_2_34_aarch64.whl", hash = "sha256:49fe9155ab32721b9122975e168a6760d8ce4cffe423bcd7ca269ba41b5dfac1", size = 4208687, upload-time = "2025-06-10T00:02:50.976Z" }, - { url = "https://files.pythonhosted.org/packages/db/b7/a84bdcd19d9c02ec5807f2ec2d1456fd8451592c5ee353816c09250e3561/cryptography-45.0.4-cp311-abi3-manylinux_2_34_x86_64.whl", hash = "sha256:2882338b2a6e0bd337052e8b9007ced85c637da19ef9ecaf437744495c8c2999", size = 4463623, upload-time = "2025-06-10T00:02:52.542Z" }, - { url = "https://files.pythonhosted.org/packages/d8/84/69707d502d4d905021cac3fb59a316344e9f078b1da7fb43ecde5e10840a/cryptography-45.0.4-cp311-abi3-musllinux_1_2_aarch64.whl", hash = "sha256:23b9c3ea30c3ed4db59e7b9619272e94891f8a3a5591d0b656a7582631ccf750", size = 4332447, upload-time = "2025-06-10T00:02:54.63Z" }, - { url = "https://files.pythonhosted.org/packages/f3/ee/d4f2ab688e057e90ded24384e34838086a9b09963389a5ba6854b5876598/cryptography-45.0.4-cp311-abi3-musllinux_1_2_x86_64.whl", hash = "sha256:b0a97c927497e3bc36b33987abb99bf17a9a175a19af38a892dc4bbb844d7ee2", size = 4572830, upload-time = "2025-06-10T00:02:56.689Z" }, - { url = "https://files.pythonhosted.org/packages/70/d4/994773a261d7ff98034f72c0e8251fe2755eac45e2265db4c866c1c6829c/cryptography-45.0.4-cp311-abi3-win32.whl", hash = "sha256:e00a6c10a5c53979d6242f123c0a97cff9f3abed7f064fc412c36dc521b5f257", size = 2932769, upload-time = "2025-06-10T00:02:58.467Z" }, - { url = "https://files.pythonhosted.org/packages/5a/42/c80bd0b67e9b769b364963b5252b17778a397cefdd36fa9aa4a5f34c599a/cryptography-45.0.4-cp311-abi3-win_amd64.whl", hash = "sha256:817ee05c6c9f7a69a16200f0c90ab26d23a87701e2a284bd15156783e46dbcc8", size = 3410441, upload-time = "2025-06-10T00:03:00.14Z" }, - { url = "https://files.pythonhosted.org/packages/ce/0b/2488c89f3a30bc821c9d96eeacfcab6ff3accc08a9601ba03339c0fd05e5/cryptography-45.0.4-cp37-abi3-macosx_10_9_universal2.whl", hash = "sha256:964bcc28d867e0f5491a564b7debb3ffdd8717928d315d12e0d7defa9e43b723", size = 7031836, upload-time = "2025-06-10T00:03:01.726Z" }, - { url = "https://files.pythonhosted.org/packages/fe/51/8c584ed426093aac257462ae62d26ad61ef1cbf5b58d8b67e6e13c39960e/cryptography-45.0.4-cp37-abi3-manylinux2014_aarch64.manylinux_2_17_aarch64.whl", hash = "sha256:6a5bf57554e80f75a7db3d4b1dacaa2764611ae166ab42ea9a72bcdb5d577637", size = 4195746, upload-time = "2025-06-10T00:03:03.94Z" }, - { url = "https://files.pythonhosted.org/packages/5c/7d/4b0ca4d7af95a704eef2f8f80a8199ed236aaf185d55385ae1d1610c03c2/cryptography-45.0.4-cp37-abi3-manylinux2014_x86_64.manylinux_2_17_x86_64.whl", hash = "sha256:46cf7088bf91bdc9b26f9c55636492c1cce3e7aaf8041bbf0243f5e5325cfb2d", size = 4424456, upload-time = "2025-06-10T00:03:05.589Z" }, - { url = "https://files.pythonhosted.org/packages/1d/45/5fabacbc6e76ff056f84d9f60eeac18819badf0cefc1b6612ee03d4ab678/cryptography-45.0.4-cp37-abi3-manylinux_2_28_aarch64.whl", hash = "sha256:7bedbe4cc930fa4b100fc845ea1ea5788fcd7ae9562e669989c11618ae8d76ee", size = 4198495, upload-time = "2025-06-10T00:03:09.172Z" }, - { url = "https://files.pythonhosted.org/packages/55/b7/ffc9945b290eb0a5d4dab9b7636706e3b5b92f14ee5d9d4449409d010d54/cryptography-45.0.4-cp37-abi3-manylinux_2_28_armv7l.manylinux_2_31_armv7l.whl", hash = "sha256:eaa3e28ea2235b33220b949c5a0d6cf79baa80eab2eb5607ca8ab7525331b9ff", size = 3885540, upload-time = "2025-06-10T00:03:10.835Z" }, - { url = "https://files.pythonhosted.org/packages/7f/e3/57b010282346980475e77d414080acdcb3dab9a0be63071efc2041a2c6bd/cryptography-45.0.4-cp37-abi3-manylinux_2_28_x86_64.whl", hash = "sha256:7ef2dde4fa9408475038fc9aadfc1fb2676b174e68356359632e980c661ec8f6", size = 4452052, upload-time = "2025-06-10T00:03:12.448Z" }, - { url = "https://files.pythonhosted.org/packages/37/e6/ddc4ac2558bf2ef517a358df26f45bc774a99bf4653e7ee34b5e749c03e3/cryptography-45.0.4-cp37-abi3-manylinux_2_34_aarch64.whl", hash = "sha256:6a3511ae33f09094185d111160fd192c67aa0a2a8d19b54d36e4c78f651dc5ad", size = 4198024, upload-time = "2025-06-10T00:03:13.976Z" }, - { url = "https://files.pythonhosted.org/packages/3a/c0/85fa358ddb063ec588aed4a6ea1df57dc3e3bc1712d87c8fa162d02a65fc/cryptography-45.0.4-cp37-abi3-manylinux_2_34_x86_64.whl", hash = "sha256:06509dc70dd71fa56eaa138336244e2fbaf2ac164fc9b5e66828fccfd2b680d6", size = 4451442, upload-time = "2025-06-10T00:03:16.248Z" }, - { url = "https://files.pythonhosted.org/packages/33/67/362d6ec1492596e73da24e669a7fbbaeb1c428d6bf49a29f7a12acffd5dc/cryptography-45.0.4-cp37-abi3-musllinux_1_2_aarch64.whl", hash = "sha256:5f31e6b0a5a253f6aa49be67279be4a7e5a4ef259a9f33c69f7d1b1191939872", size = 4325038, upload-time = "2025-06-10T00:03:18.4Z" }, - { url = "https://files.pythonhosted.org/packages/53/75/82a14bf047a96a1b13ebb47fb9811c4f73096cfa2e2b17c86879687f9027/cryptography-45.0.4-cp37-abi3-musllinux_1_2_x86_64.whl", hash = "sha256:944e9ccf67a9594137f942d5b52c8d238b1b4e46c7a0c2891b7ae6e01e7c80a4", size = 4560964, upload-time = "2025-06-10T00:03:20.06Z" }, - { url = "https://files.pythonhosted.org/packages/cd/37/1a3cba4c5a468ebf9b95523a5ef5651244693dc712001e276682c278fc00/cryptography-45.0.4-cp37-abi3-win32.whl", hash = "sha256:c22fe01e53dc65edd1945a2e6f0015e887f84ced233acecb64b4daadb32f5c97", size = 2924557, upload-time = "2025-06-10T00:03:22.563Z" }, - { url = "https://files.pythonhosted.org/packages/2a/4b/3256759723b7e66380397d958ca07c59cfc3fb5c794fb5516758afd05d41/cryptography-45.0.4-cp37-abi3-win_amd64.whl", hash = "sha256:627ba1bc94f6adf0b0a2e35d87020285ead22d9f648c7e75bb64f367375f3b22", size = 3395508, upload-time = "2025-06-10T00:03:24.586Z" }, - { url = "https://files.pythonhosted.org/packages/16/33/b38e9d372afde56906a23839302c19abdac1c505bfb4776c1e4b07c3e145/cryptography-45.0.4-pp310-pypy310_pp73-macosx_10_9_x86_64.whl", hash = "sha256:a77c6fb8d76e9c9f99f2f3437c1a4ac287b34eaf40997cfab1e9bd2be175ac39", size = 3580103, upload-time = "2025-06-10T00:03:26.207Z" }, - { url = "https://files.pythonhosted.org/packages/c4/b9/357f18064ec09d4807800d05a48f92f3b369056a12f995ff79549fbb31f1/cryptography-45.0.4-pp310-pypy310_pp73-manylinux_2_28_aarch64.whl", hash = "sha256:7aad98a25ed8ac917fdd8a9c1e706e5a0956e06c498be1f713b61734333a4507", size = 4143732, upload-time = "2025-06-10T00:03:27.896Z" }, - { url = "https://files.pythonhosted.org/packages/c4/9c/7f7263b03d5db329093617648b9bd55c953de0b245e64e866e560f9aac07/cryptography-45.0.4-pp310-pypy310_pp73-manylinux_2_28_x86_64.whl", hash = "sha256:3530382a43a0e524bc931f187fc69ef4c42828cf7d7f592f7f249f602b5a4ab0", size = 4385424, upload-time = "2025-06-10T00:03:29.992Z" }, - { url = "https://files.pythonhosted.org/packages/a6/5a/6aa9d8d5073d5acc0e04e95b2860ef2684b2bd2899d8795fc443013e263b/cryptography-45.0.4-pp310-pypy310_pp73-manylinux_2_34_aarch64.whl", hash = "sha256:6b613164cb8425e2f8db5849ffb84892e523bf6d26deb8f9bb76ae86181fa12b", size = 4142438, upload-time = "2025-06-10T00:03:31.782Z" }, - { url = "https://files.pythonhosted.org/packages/42/1c/71c638420f2cdd96d9c2b287fec515faf48679b33a2b583d0f1eda3a3375/cryptography-45.0.4-pp310-pypy310_pp73-manylinux_2_34_x86_64.whl", hash = "sha256:96d4819e25bf3b685199b304a0029ce4a3caf98947ce8a066c9137cc78ad2c58", size = 4384622, upload-time = "2025-06-10T00:03:33.491Z" }, - { url = "https://files.pythonhosted.org/packages/ef/ab/e3a055c34e97deadbf0d846e189237d3385dca99e1a7e27384c3b2292041/cryptography-45.0.4-pp310-pypy310_pp73-win_amd64.whl", hash = "sha256:b97737a3ffbea79eebb062eb0d67d72307195035332501722a9ca86bab9e3ab2", size = 3328911, upload-time = "2025-06-10T00:03:35.035Z" }, - { url = "https://files.pythonhosted.org/packages/ea/ba/cf442ae99ef363855ed84b39e0fb3c106ac66b7a7703f3c9c9cfe05412cb/cryptography-45.0.4-pp311-pypy311_pp73-macosx_10_9_x86_64.whl", hash = "sha256:4828190fb6c4bcb6ebc6331f01fe66ae838bb3bd58e753b59d4b22eb444b996c", size = 3590512, upload-time = "2025-06-10T00:03:36.982Z" }, - { url = "https://files.pythonhosted.org/packages/28/9a/a7d5bb87d149eb99a5abdc69a41e4e47b8001d767e5f403f78bfaafc7aa7/cryptography-45.0.4-pp311-pypy311_pp73-manylinux_2_28_aarch64.whl", hash = "sha256:03dbff8411206713185b8cebe31bc5c0eb544799a50c09035733716b386e61a4", size = 4146899, upload-time = "2025-06-10T00:03:38.659Z" }, - { url = "https://files.pythonhosted.org/packages/17/11/9361c2c71c42cc5c465cf294c8030e72fb0c87752bacbd7a3675245e3db3/cryptography-45.0.4-pp311-pypy311_pp73-manylinux_2_28_x86_64.whl", hash = "sha256:51dfbd4d26172d31150d84c19bbe06c68ea4b7f11bbc7b3a5e146b367c311349", size = 4388900, upload-time = "2025-06-10T00:03:40.233Z" }, - { url = "https://files.pythonhosted.org/packages/c0/76/f95b83359012ee0e670da3e41c164a0c256aeedd81886f878911581d852f/cryptography-45.0.4-pp311-pypy311_pp73-manylinux_2_34_aarch64.whl", hash = "sha256:0339a692de47084969500ee455e42c58e449461e0ec845a34a6a9b9bf7df7fb8", size = 4146422, upload-time = "2025-06-10T00:03:41.827Z" }, - { url = "https://files.pythonhosted.org/packages/09/ad/5429fcc4def93e577a5407988f89cf15305e64920203d4ac14601a9dc876/cryptography-45.0.4-pp311-pypy311_pp73-manylinux_2_34_x86_64.whl", hash = "sha256:0cf13c77d710131d33e63626bd55ae7c0efb701ebdc2b3a7952b9b23a0412862", size = 4388475, upload-time = "2025-06-10T00:03:43.493Z" }, - { url = "https://files.pythonhosted.org/packages/99/49/0ab9774f64555a1b50102757811508f5ace451cf5dc0a2d074a4b9deca6a/cryptography-45.0.4-pp311-pypy311_pp73-win_amd64.whl", hash = "sha256:bbc505d1dc469ac12a0a064214879eac6294038d6b24ae9f71faae1448a9608d", size = 3337594, upload-time = "2025-06-10T00:03:45.523Z" }, -] - -[[package]] -name = "diffusers" -version = "0.33.1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "filelock" }, - { name = "huggingface-hub" }, - { name = "importlib-metadata" }, - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "pillow" }, - { name = "regex" }, - { name = "requests" }, - { name = "safetensors" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/82/cc/1ef6bdc99d3864f6d1ee11bdbe3708b9d33ce35e7671557f641897480956/diffusers-0.33.1.tar.gz", hash = "sha256:fc7f140295d2ec82b1e7474b77bb7057fc0686c14eadc54ca0e52a66527e18a2", size = 2896103, upload-time = "2025-04-10T05:20:29.135Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/e7/7a/f08f610cea8a3395ad3b4f586db23bedb43c68db6c3261145a15e7b63126/diffusers-0.33.1-py3-none-any.whl", hash = "sha256:027469e74f289338eb24127409f8d60d840b1b7ce4b27ffcd3134fd3b8431567", size = 3554612, upload-time = "2025-04-10T05:20:24.774Z" }, -] - -[[package]] -name = "dill" -version = "0.4.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/12/80/630b4b88364e9a8c8c5797f4602d0f76ef820909ee32f0bacb9f90654042/dill-0.4.0.tar.gz", hash = "sha256:0633f1d2df477324f53a895b02c901fb961bdbf65a17122586ea7019292cbcf0", size = 186976, upload-time = "2025-04-16T00:41:48.867Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/50/3d/9373ad9c56321fdab5b41197068e1d8c25883b3fea29dd361f9b55116869/dill-0.4.0-py3-none-any.whl", hash = "sha256:44f54bf6412c2c8464c14e8243eb163690a9800dbe2c367330883b19c7561049", size = 119668, upload-time = "2025-04-16T00:41:47.671Z" }, -] - -[[package]] -name = "distro" -version = "1.9.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/fc/f8/98eea607f65de6527f8a2e8885fc8015d3e6f5775df186e443e0964a11c3/distro-1.9.0.tar.gz", hash = "sha256:2fa77c6fd8940f116ee1d6b94a2f90b13b5ea8d019b98bc8bafdcabcdd9bdbed", size = 60722, upload-time = "2023-12-24T09:54:32.31Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/12/b3/231ffd4ab1fc9d679809f356cebee130ac7daa00d6d6f3206dd4fd137e9e/distro-1.9.0-py3-none-any.whl", hash = "sha256:7bffd925d65168f85027d8da9af6bddab658135b840670a223589bc0c8ef02b2", size = 20277, upload-time = "2023-12-24T09:54:30.421Z" }, -] - -[[package]] -name = "docker" -version = "7.1.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "pywin32", marker = "sys_platform == 'win32' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "requests" }, - { name = "urllib3" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/91/9b/4a2ea29aeba62471211598dac5d96825bb49348fa07e906ea930394a83ce/docker-7.1.0.tar.gz", hash = "sha256:ad8c70e6e3f8926cb8a92619b832b4ea5299e2831c14284663184e200546fa6c", size = 117834, upload-time = "2024-05-23T11:13:57.216Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/e3/26/57c6fb270950d476074c087527a558ccb6f4436657314bfb6cdf484114c4/docker-7.1.0-py3-none-any.whl", hash = "sha256:c96b93b7f0a746f9e77d325bcfb87422a3d8bd4f03136ae8a85b37f1898d5fc0", size = 147774, upload-time = "2024-05-23T11:13:55.01Z" }, -] - -[[package]] -name = "einops" -version = "0.8.1" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/e5/81/df4fbe24dff8ba3934af99044188e20a98ed441ad17a274539b74e82e126/einops-0.8.1.tar.gz", hash = "sha256:de5d960a7a761225532e0f1959e5315ebeafc0cd43394732f103ca44b9837e84", size = 54805, upload-time = "2025-02-09T03:17:00.434Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/87/62/9773de14fe6c45c23649e98b83231fffd7b9892b6cf863251dc2afa73643/einops-0.8.1-py3-none-any.whl", hash = "sha256:919387eb55330f5757c6bea9165c5ff5cfe63a642682ea788a6d472576d81737", size = 64359, upload-time = "2025-02-09T03:17:01.998Z" }, -] - -[[package]] -name = "etils" -version = "1.12.2" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/e4/12/1cc11e88a0201280ff389bc4076df7c3432e39d9f22cba8b71aa263f67b8/etils-1.12.2.tar.gz", hash = "sha256:c6b9e1f0ce66d1bbf54f99201b08a60ba396d3446d9eb18d4bc39b26a2e1a5ee", size = 104711, upload-time = "2025-03-10T15:14:13.671Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/dd/71/40ee142e564b8a34a7ae9546e99e665e0001011a3254d5bbbe113d72ccba/etils-1.12.2-py3-none-any.whl", hash = "sha256:4600bec9de6cf5cb043a171e1856e38b5f273719cf3ecef90199f7091a6b3912", size = 167613, upload-time = "2025-03-10T15:14:12.333Z" }, -] - -[package.optional-dependencies] -epath = [ - { name = "fsspec" }, - { name = "importlib-resources" }, - { name = "typing-extensions" }, - { name = "zipp" }, -] -epy = [ - { name = "typing-extensions" }, -] - -[[package]] -name = "exceptiongroup" -version = "1.3.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "typing-extensions", marker = "python_full_version < '3.13' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/0b/9f/a65090624ecf468cdca03533906e7c69ed7588582240cfe7cc9e770b50eb/exceptiongroup-1.3.0.tar.gz", hash = "sha256:b241f5885f560bc56a59ee63ca4c6a8bfa46ae4ad651af316d4e81817bb9fd88", size = 29749, upload-time = "2025-05-10T17:42:51.123Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/36/f4/c6e662dade71f56cd2f3735141b265c3c79293c109549c1e6933b0651ffc/exceptiongroup-1.3.0-py3-none-any.whl", hash = "sha256:4d111e6e0c13d0644cad6ddaa7ed0261a0b36971f6d23e7ec9b4b9097da78a10", size = 16674, upload-time = "2025-05-10T17:42:49.33Z" }, -] - -[[package]] -name = "execnet" -version = "2.1.1" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/bb/ff/b4c0dc78fbe20c3e59c0c7334de0c27eb4001a2b2017999af398bf730817/execnet-2.1.1.tar.gz", hash = "sha256:5189b52c6121c24feae288166ab41b32549c7e2348652736540b9e6e7d4e72e3", size = 166524, upload-time = "2024-04-08T09:04:19.245Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/43/09/2aea36ff60d16dd8879bdb2f5b3ee0ba8d08cbbdcdfe870e695ce3784385/execnet-2.1.1-py3-none-any.whl", hash = "sha256:26dee51f1b80cebd6d0ca8e74dd8745419761d3bef34163928cbebbdc4749fdc", size = 40612, upload-time = "2024-04-08T09:04:17.414Z" }, -] - -[[package]] -name = "filelock" -version = "3.18.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/0a/10/c23352565a6544bdc5353e0b15fc1c563352101f30e24bf500207a54df9a/filelock-3.18.0.tar.gz", hash = "sha256:adbc88eabb99d2fec8c9c1b229b171f18afa655400173ddc653d5d01501fb9f2", size = 18075, upload-time = "2025-03-14T07:11:40.47Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/4d/36/2a115987e2d8c300a974597416d9de88f2444426de9571f4b59b2cca3acc/filelock-3.18.0-py3-none-any.whl", hash = "sha256:c401f4f8377c4464e6db25fff06205fd89bdd83b65eb0488ed1b160f780e21de", size = 16215, upload-time = "2025-03-14T07:11:39.145Z" }, -] - -[[package]] -name = "flash-attn" -version = "2.8.0.post2" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "einops", marker = "sys_platform == 'Linux' or sys_platform == 'win32' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://pypi.org/simple" }, marker = "(sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" }, marker = "(sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "(sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(sys_platform == 'Linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/32/5c/c7610beeb2fc0e70d0c09a93490bb2d07fb6c8fa1f80ef9617b0cd556d76/flash_attn-2.8.0.post2.tar.gz", hash = "sha256:b51d7015eb78f7ab2c332ec7c36681d7e97834f010b52eb4db1f118351982f58", size = 7857730, upload-time = "2025-06-15T01:39:32.219Z" } - -[[package]] -name = "flax" -version = "0.10.6" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "jax" }, - { name = "msgpack" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "optax" }, - { name = "orbax-checkpoint" }, - { name = "pyyaml" }, - { name = "rich" }, - { name = "tensorstore" }, - { name = "treescope" }, - { name = "typing-extensions" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/6d/e6/2eee448a8b64ddde6fca53b067e6dbfe974bb198f6b21dc13f52aaeab7e3/flax-0.10.6.tar.gz", hash = "sha256:8f3d1eb7de9bbaa18e08d0423dce890aef88a8b9dc6daa23baa631e8dfb09618", size = 5215148, upload-time = "2025-04-23T20:27:07.383Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/fb/f8/aaf70a427f7e17afc1877d69c610b6b0c5093dba5addb63fb6990944e989/flax-0.10.6-py3-none-any.whl", hash = "sha256:86a5f0ba0f1603c687714999b58a4e362e784a6d2dc5a510b18a8e7a6c729e18", size = 447094, upload-time = "2025-04-23T20:27:05.036Z" }, -] - -[[package]] -name = "freezegun" -version = "1.5.2" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "python-dateutil" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/c7/75/0455fa5029507a2150da59db4f165fbc458ff8bb1c4f4d7e8037a14ad421/freezegun-1.5.2.tar.gz", hash = "sha256:a54ae1d2f9c02dbf42e02c18a3ab95ab4295818b549a34dac55592d72a905181", size = 34855, upload-time = "2025-05-24T12:38:47.051Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/b5/b2/68d4c9b6431121b6b6aa5e04a153cac41dcacc79600ed6e2e7c3382156f5/freezegun-1.5.2-py3-none-any.whl", hash = "sha256:5aaf3ba229cda57afab5bd311f0108d86b6fb119ae89d2cd9c43ec8c1733c85b", size = 18715, upload-time = "2025-05-24T12:38:45.274Z" }, -] - -[[package]] -name = "frozendict" -version = "2.4.6" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/bb/59/19eb300ba28e7547538bdf603f1c6c34793240a90e1a7b61b65d8517e35e/frozendict-2.4.6.tar.gz", hash = "sha256:df7cd16470fbd26fc4969a208efadc46319334eb97def1ddf48919b351192b8e", size = 316416, upload-time = "2024-10-13T12:15:32.449Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/a6/7f/e80cdbe0db930b2ba9d46ca35a41b0150156da16dfb79edcc05642690c3b/frozendict-2.4.6-cp310-cp310-macosx_10_9_x86_64.whl", hash = "sha256:c3a05c0a50cab96b4bb0ea25aa752efbfceed5ccb24c007612bc63e51299336f", size = 37927, upload-time = "2024-10-13T12:14:17.927Z" }, - { url = "https://files.pythonhosted.org/packages/29/98/27e145ff7e8e63caa95fb8ee4fc56c68acb208bef01a89c3678a66f9a34d/frozendict-2.4.6-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:f5b94d5b07c00986f9e37a38dd83c13f5fe3bf3f1ccc8e88edea8fe15d6cd88c", size = 37945, upload-time = "2024-10-13T12:14:19.976Z" }, - { url = "https://files.pythonhosted.org/packages/ac/f1/a10be024a9d53441c997b3661ea80ecba6e3130adc53812a4b95b607cdd1/frozendict-2.4.6-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:f4c789fd70879ccb6289a603cdebdc4953e7e5dea047d30c1b180529b28257b5", size = 117656, upload-time = "2024-10-13T12:14:22.038Z" }, - { url = "https://files.pythonhosted.org/packages/46/a6/34c760975e6f1cb4db59a990d58dcf22287e10241c851804670c74c6a27a/frozendict-2.4.6-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:da6a10164c8a50b34b9ab508a9420df38f4edf286b9ca7b7df8a91767baecb34", size = 117444, upload-time = "2024-10-13T12:14:24.251Z" }, - { url = "https://files.pythonhosted.org/packages/62/dd/64bddd1ffa9617f50e7e63656b2a7ad7f0a46c86b5f4a3d2c714d0006277/frozendict-2.4.6-cp310-cp310-musllinux_1_2_aarch64.whl", hash = "sha256:9a8a43036754a941601635ea9c788ebd7a7efbed2becba01b54a887b41b175b9", size = 116801, upload-time = "2024-10-13T12:14:26.518Z" }, - { url = "https://files.pythonhosted.org/packages/45/ae/af06a8bde1947277aad895c2f26c3b8b8b6ee9c0c2ad988fb58a9d1dde3f/frozendict-2.4.6-cp310-cp310-musllinux_1_2_x86_64.whl", hash = "sha256:c9905dcf7aa659e6a11b8051114c9fa76dfde3a6e50e6dc129d5aece75b449a2", size = 117329, upload-time = "2024-10-13T12:14:28.485Z" }, - { url = "https://files.pythonhosted.org/packages/d2/df/be3fa0457ff661301228f4c59c630699568c8ed9b5480f113b3eea7d0cb3/frozendict-2.4.6-cp310-cp310-win_amd64.whl", hash = "sha256:323f1b674a2cc18f86ab81698e22aba8145d7a755e0ac2cccf142ee2db58620d", size = 37522, upload-time = "2024-10-13T12:14:30.418Z" }, - { url = "https://files.pythonhosted.org/packages/4a/6f/c22e0266b4c85f58b4613fec024e040e93753880527bf92b0c1bc228c27c/frozendict-2.4.6-cp310-cp310-win_arm64.whl", hash = "sha256:eabd21d8e5db0c58b60d26b4bb9839cac13132e88277e1376970172a85ee04b3", size = 34056, upload-time = "2024-10-13T12:14:31.757Z" }, - { url = "https://files.pythonhosted.org/packages/04/13/d9839089b900fa7b479cce495d62110cddc4bd5630a04d8469916c0e79c5/frozendict-2.4.6-py311-none-any.whl", hash = "sha256:d065db6a44db2e2375c23eac816f1a022feb2fa98cbb50df44a9e83700accbea", size = 16148, upload-time = "2024-10-13T12:15:26.839Z" }, - { url = "https://files.pythonhosted.org/packages/ba/d0/d482c39cee2ab2978a892558cf130681d4574ea208e162da8958b31e9250/frozendict-2.4.6-py312-none-any.whl", hash = "sha256:49344abe90fb75f0f9fdefe6d4ef6d4894e640fadab71f11009d52ad97f370b9", size = 16146, upload-time = "2024-10-13T12:15:28.16Z" }, - { url = "https://files.pythonhosted.org/packages/a5/8e/b6bf6a0de482d7d7d7a2aaac8fdc4a4d0bb24a809f5ddd422aa7060eb3d2/frozendict-2.4.6-py313-none-any.whl", hash = "sha256:7134a2bb95d4a16556bb5f2b9736dceb6ea848fa5b6f3f6c2d6dba93b44b4757", size = 16146, upload-time = "2024-10-13T12:15:29.495Z" }, -] - -[[package]] -name = "frozenlist" -version = "1.7.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/79/b1/b64018016eeb087db503b038296fd782586432b9c077fc5c7839e9cb6ef6/frozenlist-1.7.0.tar.gz", hash = "sha256:2e310d81923c2437ea8670467121cc3e9b0f76d3043cc1d2331d56c7fb7a3a8f", size = 45078, upload-time = "2025-06-09T23:02:35.538Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/af/36/0da0a49409f6b47cc2d060dc8c9040b897b5902a8a4e37d9bc1deb11f680/frozenlist-1.7.0-cp310-cp310-macosx_10_9_universal2.whl", hash = "sha256:cc4df77d638aa2ed703b878dd093725b72a824c3c546c076e8fdf276f78ee84a", size = 81304, upload-time = "2025-06-09T22:59:46.226Z" }, - { url = "https://files.pythonhosted.org/packages/77/f0/77c11d13d39513b298e267b22eb6cb559c103d56f155aa9a49097221f0b6/frozenlist-1.7.0-cp310-cp310-macosx_10_9_x86_64.whl", hash = "sha256:716a9973a2cc963160394f701964fe25012600f3d311f60c790400b00e568b61", size = 47735, upload-time = "2025-06-09T22:59:48.133Z" }, - { url = "https://files.pythonhosted.org/packages/37/12/9d07fa18971a44150593de56b2f2947c46604819976784bcf6ea0d5db43b/frozenlist-1.7.0-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:a0fd1bad056a3600047fb9462cff4c5322cebc59ebf5d0a3725e0ee78955001d", size = 46775, upload-time = "2025-06-09T22:59:49.564Z" }, - { url = "https://files.pythonhosted.org/packages/70/34/f73539227e06288fcd1f8a76853e755b2b48bca6747e99e283111c18bcd4/frozenlist-1.7.0-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:3789ebc19cb811163e70fe2bd354cea097254ce6e707ae42e56f45e31e96cb8e", size = 224644, upload-time = "2025-06-09T22:59:51.35Z" }, - { url = "https://files.pythonhosted.org/packages/fb/68/c1d9c2f4a6e438e14613bad0f2973567586610cc22dcb1e1241da71de9d3/frozenlist-1.7.0-cp310-cp310-manylinux_2_17_armv7l.manylinux2014_armv7l.manylinux_2_31_armv7l.whl", hash = "sha256:af369aa35ee34f132fcfad5be45fbfcde0e3a5f6a1ec0712857f286b7d20cca9", size = 222125, upload-time = "2025-06-09T22:59:52.884Z" }, - { url = "https://files.pythonhosted.org/packages/b9/d0/98e8f9a515228d708344d7c6986752be3e3192d1795f748c24bcf154ad99/frozenlist-1.7.0-cp310-cp310-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:ac64b6478722eeb7a3313d494f8342ef3478dff539d17002f849101b212ef97c", size = 233455, upload-time = "2025-06-09T22:59:54.74Z" }, - { url = "https://files.pythonhosted.org/packages/79/df/8a11bcec5600557f40338407d3e5bea80376ed1c01a6c0910fcfdc4b8993/frozenlist-1.7.0-cp310-cp310-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:f89f65d85774f1797239693cef07ad4c97fdd0639544bad9ac4b869782eb1981", size = 227339, upload-time = "2025-06-09T22:59:56.187Z" }, - { url = "https://files.pythonhosted.org/packages/50/82/41cb97d9c9a5ff94438c63cc343eb7980dac4187eb625a51bdfdb7707314/frozenlist-1.7.0-cp310-cp310-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:1073557c941395fdfcfac13eb2456cb8aad89f9de27bae29fabca8e563b12615", size = 212969, upload-time = "2025-06-09T22:59:57.604Z" }, - { url = "https://files.pythonhosted.org/packages/13/47/f9179ee5ee4f55629e4f28c660b3fdf2775c8bfde8f9c53f2de2d93f52a9/frozenlist-1.7.0-cp310-cp310-manylinux_2_5_x86_64.manylinux1_x86_64.manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:1ed8d2fa095aae4bdc7fdd80351009a48d286635edffee66bf865e37a9125c50", size = 222862, upload-time = "2025-06-09T22:59:59.498Z" }, - { url = "https://files.pythonhosted.org/packages/1a/52/df81e41ec6b953902c8b7e3a83bee48b195cb0e5ec2eabae5d8330c78038/frozenlist-1.7.0-cp310-cp310-musllinux_1_2_aarch64.whl", hash = "sha256:24c34bea555fe42d9f928ba0a740c553088500377448febecaa82cc3e88aa1fa", size = 222492, upload-time = "2025-06-09T23:00:01.026Z" }, - { url = "https://files.pythonhosted.org/packages/84/17/30d6ea87fa95a9408245a948604b82c1a4b8b3e153cea596421a2aef2754/frozenlist-1.7.0-cp310-cp310-musllinux_1_2_armv7l.whl", hash = "sha256:69cac419ac6a6baad202c85aaf467b65ac860ac2e7f2ac1686dc40dbb52f6577", size = 238250, upload-time = "2025-06-09T23:00:03.401Z" }, - { url = "https://files.pythonhosted.org/packages/8f/00/ecbeb51669e3c3df76cf2ddd66ae3e48345ec213a55e3887d216eb4fbab3/frozenlist-1.7.0-cp310-cp310-musllinux_1_2_i686.whl", hash = "sha256:960d67d0611f4c87da7e2ae2eacf7ea81a5be967861e0c63cf205215afbfac59", size = 218720, upload-time = "2025-06-09T23:00:05.282Z" }, - { url = "https://files.pythonhosted.org/packages/1a/c0/c224ce0e0eb31cc57f67742071bb470ba8246623c1823a7530be0e76164c/frozenlist-1.7.0-cp310-cp310-musllinux_1_2_ppc64le.whl", hash = "sha256:41be2964bd4b15bf575e5daee5a5ce7ed3115320fb3c2b71fca05582ffa4dc9e", size = 232585, upload-time = "2025-06-09T23:00:07.962Z" }, - { url = "https://files.pythonhosted.org/packages/55/3c/34cb694abf532f31f365106deebdeac9e45c19304d83cf7d51ebbb4ca4d1/frozenlist-1.7.0-cp310-cp310-musllinux_1_2_s390x.whl", hash = "sha256:46d84d49e00c9429238a7ce02dc0be8f6d7cd0cd405abd1bebdc991bf27c15bd", size = 234248, upload-time = "2025-06-09T23:00:09.428Z" }, - { url = "https://files.pythonhosted.org/packages/98/c0/2052d8b6cecda2e70bd81299e3512fa332abb6dcd2969b9c80dfcdddbf75/frozenlist-1.7.0-cp310-cp310-musllinux_1_2_x86_64.whl", hash = "sha256:15900082e886edb37480335d9d518cec978afc69ccbc30bd18610b7c1b22a718", size = 221621, upload-time = "2025-06-09T23:00:11.32Z" }, - { url = "https://files.pythonhosted.org/packages/c5/bf/7dcebae315436903b1d98ffb791a09d674c88480c158aa171958a3ac07f0/frozenlist-1.7.0-cp310-cp310-win32.whl", hash = "sha256:400ddd24ab4e55014bba442d917203c73b2846391dd42ca5e38ff52bb18c3c5e", size = 39578, upload-time = "2025-06-09T23:00:13.526Z" }, - { url = "https://files.pythonhosted.org/packages/8f/5f/f69818f017fa9a3d24d1ae39763e29b7f60a59e46d5f91b9c6b21622f4cd/frozenlist-1.7.0-cp310-cp310-win_amd64.whl", hash = "sha256:6eb93efb8101ef39d32d50bce242c84bcbddb4f7e9febfa7b524532a239b4464", size = 43830, upload-time = "2025-06-09T23:00:14.98Z" }, - { url = "https://files.pythonhosted.org/packages/34/7e/803dde33760128acd393a27eb002f2020ddb8d99d30a44bfbaab31c5f08a/frozenlist-1.7.0-cp311-cp311-macosx_10_9_universal2.whl", hash = "sha256:aa51e147a66b2d74de1e6e2cf5921890de6b0f4820b257465101d7f37b49fb5a", size = 82251, upload-time = "2025-06-09T23:00:16.279Z" }, - { url = "https://files.pythonhosted.org/packages/75/a9/9c2c5760b6ba45eae11334db454c189d43d34a4c0b489feb2175e5e64277/frozenlist-1.7.0-cp311-cp311-macosx_10_9_x86_64.whl", hash = "sha256:9b35db7ce1cd71d36ba24f80f0c9e7cff73a28d7a74e91fe83e23d27c7828750", size = 48183, upload-time = "2025-06-09T23:00:17.698Z" }, - { url = "https://files.pythonhosted.org/packages/47/be/4038e2d869f8a2da165f35a6befb9158c259819be22eeaf9c9a8f6a87771/frozenlist-1.7.0-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:34a69a85e34ff37791e94542065c8416c1afbf820b68f720452f636d5fb990cd", size = 47107, upload-time = "2025-06-09T23:00:18.952Z" }, - { url = "https://files.pythonhosted.org/packages/79/26/85314b8a83187c76a37183ceed886381a5f992975786f883472fcb6dc5f2/frozenlist-1.7.0-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:4a646531fa8d82c87fe4bb2e596f23173caec9185bfbca5d583b4ccfb95183e2", size = 237333, upload-time = "2025-06-09T23:00:20.275Z" }, - { url = "https://files.pythonhosted.org/packages/1f/fd/e5b64f7d2c92a41639ffb2ad44a6a82f347787abc0c7df5f49057cf11770/frozenlist-1.7.0-cp311-cp311-manylinux_2_17_armv7l.manylinux2014_armv7l.manylinux_2_31_armv7l.whl", hash = "sha256:79b2ffbba483f4ed36a0f236ccb85fbb16e670c9238313709638167670ba235f", size = 231724, upload-time = "2025-06-09T23:00:21.705Z" }, - { url = "https://files.pythonhosted.org/packages/20/fb/03395c0a43a5976af4bf7534759d214405fbbb4c114683f434dfdd3128ef/frozenlist-1.7.0-cp311-cp311-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:a26f205c9ca5829cbf82bb2a84b5c36f7184c4316617d7ef1b271a56720d6b30", size = 245842, upload-time = "2025-06-09T23:00:23.148Z" }, - { url = "https://files.pythonhosted.org/packages/d0/15/c01c8e1dffdac5d9803507d824f27aed2ba76b6ed0026fab4d9866e82f1f/frozenlist-1.7.0-cp311-cp311-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:bcacfad3185a623fa11ea0e0634aac7b691aa925d50a440f39b458e41c561d98", size = 239767, upload-time = "2025-06-09T23:00:25.103Z" }, - { url = "https://files.pythonhosted.org/packages/14/99/3f4c6fe882c1f5514b6848aa0a69b20cb5e5d8e8f51a339d48c0e9305ed0/frozenlist-1.7.0-cp311-cp311-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:72c1b0fe8fe451b34f12dce46445ddf14bd2a5bcad7e324987194dc8e3a74c86", size = 224130, upload-time = "2025-06-09T23:00:27.061Z" }, - { url = "https://files.pythonhosted.org/packages/4d/83/220a374bd7b2aeba9d0725130665afe11de347d95c3620b9b82cc2fcab97/frozenlist-1.7.0-cp311-cp311-manylinux_2_5_x86_64.manylinux1_x86_64.manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:61d1a5baeaac6c0798ff6edfaeaa00e0e412d49946c53fae8d4b8e8b3566c4ae", size = 235301, upload-time = "2025-06-09T23:00:29.02Z" }, - { url = "https://files.pythonhosted.org/packages/03/3c/3e3390d75334a063181625343e8daab61b77e1b8214802cc4e8a1bb678fc/frozenlist-1.7.0-cp311-cp311-musllinux_1_2_aarch64.whl", hash = "sha256:7edf5c043c062462f09b6820de9854bf28cc6cc5b6714b383149745e287181a8", size = 234606, upload-time = "2025-06-09T23:00:30.514Z" }, - { url = "https://files.pythonhosted.org/packages/23/1e/58232c19608b7a549d72d9903005e2d82488f12554a32de2d5fb59b9b1ba/frozenlist-1.7.0-cp311-cp311-musllinux_1_2_armv7l.whl", hash = "sha256:d50ac7627b3a1bd2dcef6f9da89a772694ec04d9a61b66cf87f7d9446b4a0c31", size = 248372, upload-time = "2025-06-09T23:00:31.966Z" }, - { url = "https://files.pythonhosted.org/packages/c0/a4/e4a567e01702a88a74ce8a324691e62a629bf47d4f8607f24bf1c7216e7f/frozenlist-1.7.0-cp311-cp311-musllinux_1_2_i686.whl", hash = "sha256:ce48b2fece5aeb45265bb7a58259f45027db0abff478e3077e12b05b17fb9da7", size = 229860, upload-time = "2025-06-09T23:00:33.375Z" }, - { url = "https://files.pythonhosted.org/packages/73/a6/63b3374f7d22268b41a9db73d68a8233afa30ed164c46107b33c4d18ecdd/frozenlist-1.7.0-cp311-cp311-musllinux_1_2_ppc64le.whl", hash = "sha256:fe2365ae915a1fafd982c146754e1de6ab3478def8a59c86e1f7242d794f97d5", size = 245893, upload-time = "2025-06-09T23:00:35.002Z" }, - { url = "https://files.pythonhosted.org/packages/6d/eb/d18b3f6e64799a79673c4ba0b45e4cfbe49c240edfd03a68be20002eaeaa/frozenlist-1.7.0-cp311-cp311-musllinux_1_2_s390x.whl", hash = "sha256:45a6f2fdbd10e074e8814eb98b05292f27bad7d1883afbe009d96abdcf3bc898", size = 246323, upload-time = "2025-06-09T23:00:36.468Z" }, - { url = "https://files.pythonhosted.org/packages/5a/f5/720f3812e3d06cd89a1d5db9ff6450088b8f5c449dae8ffb2971a44da506/frozenlist-1.7.0-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:21884e23cffabb157a9dd7e353779077bf5b8f9a58e9b262c6caad2ef5f80a56", size = 233149, upload-time = "2025-06-09T23:00:37.963Z" }, - { url = "https://files.pythonhosted.org/packages/69/68/03efbf545e217d5db8446acfd4c447c15b7c8cf4dbd4a58403111df9322d/frozenlist-1.7.0-cp311-cp311-win32.whl", hash = "sha256:284d233a8953d7b24f9159b8a3496fc1ddc00f4db99c324bd5fb5f22d8698ea7", size = 39565, upload-time = "2025-06-09T23:00:39.753Z" }, - { url = "https://files.pythonhosted.org/packages/58/17/fe61124c5c333ae87f09bb67186d65038834a47d974fc10a5fadb4cc5ae1/frozenlist-1.7.0-cp311-cp311-win_amd64.whl", hash = "sha256:387cbfdcde2f2353f19c2f66bbb52406d06ed77519ac7ee21be0232147c2592d", size = 44019, upload-time = "2025-06-09T23:00:40.988Z" }, - { url = "https://files.pythonhosted.org/packages/ef/a2/c8131383f1e66adad5f6ecfcce383d584ca94055a34d683bbb24ac5f2f1c/frozenlist-1.7.0-cp312-cp312-macosx_10_13_universal2.whl", hash = "sha256:3dbf9952c4bb0e90e98aec1bd992b3318685005702656bc6f67c1a32b76787f2", size = 81424, upload-time = "2025-06-09T23:00:42.24Z" }, - { url = "https://files.pythonhosted.org/packages/4c/9d/02754159955088cb52567337d1113f945b9e444c4960771ea90eb73de8db/frozenlist-1.7.0-cp312-cp312-macosx_10_13_x86_64.whl", hash = "sha256:1f5906d3359300b8a9bb194239491122e6cf1444c2efb88865426f170c262cdb", size = 47952, upload-time = "2025-06-09T23:00:43.481Z" }, - { url = "https://files.pythonhosted.org/packages/01/7a/0046ef1bd6699b40acd2067ed6d6670b4db2f425c56980fa21c982c2a9db/frozenlist-1.7.0-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:3dabd5a8f84573c8d10d8859a50ea2dec01eea372031929871368c09fa103478", size = 46688, upload-time = "2025-06-09T23:00:44.793Z" }, - { url = "https://files.pythonhosted.org/packages/d6/a2/a910bafe29c86997363fb4c02069df4ff0b5bc39d33c5198b4e9dd42d8f8/frozenlist-1.7.0-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:aa57daa5917f1738064f302bf2626281a1cb01920c32f711fbc7bc36111058a8", size = 243084, upload-time = "2025-06-09T23:00:46.125Z" }, - { url = "https://files.pythonhosted.org/packages/64/3e/5036af9d5031374c64c387469bfcc3af537fc0f5b1187d83a1cf6fab1639/frozenlist-1.7.0-cp312-cp312-manylinux_2_17_armv7l.manylinux2014_armv7l.manylinux_2_31_armv7l.whl", hash = "sha256:c193dda2b6d49f4c4398962810fa7d7c78f032bf45572b3e04dd5249dff27e08", size = 233524, upload-time = "2025-06-09T23:00:47.73Z" }, - { url = "https://files.pythonhosted.org/packages/06/39/6a17b7c107a2887e781a48ecf20ad20f1c39d94b2a548c83615b5b879f28/frozenlist-1.7.0-cp312-cp312-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:bfe2b675cf0aaa6d61bf8fbffd3c274b3c9b7b1623beb3809df8a81399a4a9c4", size = 248493, upload-time = "2025-06-09T23:00:49.742Z" }, - { url = "https://files.pythonhosted.org/packages/be/00/711d1337c7327d88c44d91dd0f556a1c47fb99afc060ae0ef66b4d24793d/frozenlist-1.7.0-cp312-cp312-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:8fc5d5cda37f62b262405cf9652cf0856839c4be8ee41be0afe8858f17f4c94b", size = 244116, upload-time = "2025-06-09T23:00:51.352Z" }, - { url = "https://files.pythonhosted.org/packages/24/fe/74e6ec0639c115df13d5850e75722750adabdc7de24e37e05a40527ca539/frozenlist-1.7.0-cp312-cp312-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:b0d5ce521d1dd7d620198829b87ea002956e4319002ef0bc8d3e6d045cb4646e", size = 224557, upload-time = "2025-06-09T23:00:52.855Z" }, - { url = "https://files.pythonhosted.org/packages/8d/db/48421f62a6f77c553575201e89048e97198046b793f4a089c79a6e3268bd/frozenlist-1.7.0-cp312-cp312-manylinux_2_5_x86_64.manylinux1_x86_64.manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:488d0a7d6a0008ca0db273c542098a0fa9e7dfaa7e57f70acef43f32b3f69dca", size = 241820, upload-time = "2025-06-09T23:00:54.43Z" }, - { url = "https://files.pythonhosted.org/packages/1d/fa/cb4a76bea23047c8462976ea7b7a2bf53997a0ca171302deae9d6dd12096/frozenlist-1.7.0-cp312-cp312-musllinux_1_2_aarch64.whl", hash = "sha256:15a7eaba63983d22c54d255b854e8108e7e5f3e89f647fc854bd77a237e767df", size = 236542, upload-time = "2025-06-09T23:00:56.409Z" }, - { url = "https://files.pythonhosted.org/packages/5d/32/476a4b5cfaa0ec94d3f808f193301debff2ea42288a099afe60757ef6282/frozenlist-1.7.0-cp312-cp312-musllinux_1_2_armv7l.whl", hash = "sha256:1eaa7e9c6d15df825bf255649e05bd8a74b04a4d2baa1ae46d9c2d00b2ca2cb5", size = 249350, upload-time = "2025-06-09T23:00:58.468Z" }, - { url = "https://files.pythonhosted.org/packages/8d/ba/9a28042f84a6bf8ea5dbc81cfff8eaef18d78b2a1ad9d51c7bc5b029ad16/frozenlist-1.7.0-cp312-cp312-musllinux_1_2_i686.whl", hash = "sha256:e4389e06714cfa9d47ab87f784a7c5be91d3934cd6e9a7b85beef808297cc025", size = 225093, upload-time = "2025-06-09T23:01:00.015Z" }, - { url = "https://files.pythonhosted.org/packages/bc/29/3a32959e68f9cf000b04e79ba574527c17e8842e38c91d68214a37455786/frozenlist-1.7.0-cp312-cp312-musllinux_1_2_ppc64le.whl", hash = "sha256:73bd45e1488c40b63fe5a7df892baf9e2a4d4bb6409a2b3b78ac1c6236178e01", size = 245482, upload-time = "2025-06-09T23:01:01.474Z" }, - { url = "https://files.pythonhosted.org/packages/80/e8/edf2f9e00da553f07f5fa165325cfc302dead715cab6ac8336a5f3d0adc2/frozenlist-1.7.0-cp312-cp312-musllinux_1_2_s390x.whl", hash = "sha256:99886d98e1643269760e5fe0df31e5ae7050788dd288947f7f007209b8c33f08", size = 249590, upload-time = "2025-06-09T23:01:02.961Z" }, - { url = "https://files.pythonhosted.org/packages/1c/80/9a0eb48b944050f94cc51ee1c413eb14a39543cc4f760ed12657a5a3c45a/frozenlist-1.7.0-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:290a172aae5a4c278c6da8a96222e6337744cd9c77313efe33d5670b9f65fc43", size = 237785, upload-time = "2025-06-09T23:01:05.095Z" }, - { url = "https://files.pythonhosted.org/packages/f3/74/87601e0fb0369b7a2baf404ea921769c53b7ae00dee7dcfe5162c8c6dbf0/frozenlist-1.7.0-cp312-cp312-win32.whl", hash = "sha256:426c7bc70e07cfebc178bc4c2bf2d861d720c4fff172181eeb4a4c41d4ca2ad3", size = 39487, upload-time = "2025-06-09T23:01:06.54Z" }, - { url = "https://files.pythonhosted.org/packages/0b/15/c026e9a9fc17585a9d461f65d8593d281fedf55fbf7eb53f16c6df2392f9/frozenlist-1.7.0-cp312-cp312-win_amd64.whl", hash = "sha256:563b72efe5da92e02eb68c59cb37205457c977aa7a449ed1b37e6939e5c47c6a", size = 43874, upload-time = "2025-06-09T23:01:07.752Z" }, - { url = "https://files.pythonhosted.org/packages/24/90/6b2cebdabdbd50367273c20ff6b57a3dfa89bd0762de02c3a1eb42cb6462/frozenlist-1.7.0-cp313-cp313-macosx_10_13_universal2.whl", hash = "sha256:ee80eeda5e2a4e660651370ebffd1286542b67e268aa1ac8d6dbe973120ef7ee", size = 79791, upload-time = "2025-06-09T23:01:09.368Z" }, - { url = "https://files.pythonhosted.org/packages/83/2e/5b70b6a3325363293fe5fc3ae74cdcbc3e996c2a11dde2fd9f1fb0776d19/frozenlist-1.7.0-cp313-cp313-macosx_10_13_x86_64.whl", hash = "sha256:d1a81c85417b914139e3a9b995d4a1c84559afc839a93cf2cb7f15e6e5f6ed2d", size = 47165, upload-time = "2025-06-09T23:01:10.653Z" }, - { url = "https://files.pythonhosted.org/packages/f4/25/a0895c99270ca6966110f4ad98e87e5662eab416a17e7fd53c364bf8b954/frozenlist-1.7.0-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:cbb65198a9132ebc334f237d7b0df163e4de83fb4f2bdfe46c1e654bdb0c5d43", size = 45881, upload-time = "2025-06-09T23:01:12.296Z" }, - { url = "https://files.pythonhosted.org/packages/19/7c/71bb0bbe0832793c601fff68cd0cf6143753d0c667f9aec93d3c323f4b55/frozenlist-1.7.0-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:dab46c723eeb2c255a64f9dc05b8dd601fde66d6b19cdb82b2e09cc6ff8d8b5d", size = 232409, upload-time = "2025-06-09T23:01:13.641Z" }, - { url = "https://files.pythonhosted.org/packages/c0/45/ed2798718910fe6eb3ba574082aaceff4528e6323f9a8570be0f7028d8e9/frozenlist-1.7.0-cp313-cp313-manylinux_2_17_armv7l.manylinux2014_armv7l.manylinux_2_31_armv7l.whl", hash = "sha256:6aeac207a759d0dedd2e40745575ae32ab30926ff4fa49b1635def65806fddee", size = 225132, upload-time = "2025-06-09T23:01:15.264Z" }, - { url = "https://files.pythonhosted.org/packages/ba/e2/8417ae0f8eacb1d071d4950f32f229aa6bf68ab69aab797b72a07ea68d4f/frozenlist-1.7.0-cp313-cp313-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:bd8c4e58ad14b4fa7802b8be49d47993182fdd4023393899632c88fd8cd994eb", size = 237638, upload-time = "2025-06-09T23:01:16.752Z" }, - { url = "https://files.pythonhosted.org/packages/f8/b7/2ace5450ce85f2af05a871b8c8719b341294775a0a6c5585d5e6170f2ce7/frozenlist-1.7.0-cp313-cp313-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:04fb24d104f425da3540ed83cbfc31388a586a7696142004c577fa61c6298c3f", size = 233539, upload-time = "2025-06-09T23:01:18.202Z" }, - { url = "https://files.pythonhosted.org/packages/46/b9/6989292c5539553dba63f3c83dc4598186ab2888f67c0dc1d917e6887db6/frozenlist-1.7.0-cp313-cp313-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:6a5c505156368e4ea6b53b5ac23c92d7edc864537ff911d2fb24c140bb175e60", size = 215646, upload-time = "2025-06-09T23:01:19.649Z" }, - { url = "https://files.pythonhosted.org/packages/72/31/bc8c5c99c7818293458fe745dab4fd5730ff49697ccc82b554eb69f16a24/frozenlist-1.7.0-cp313-cp313-manylinux_2_5_x86_64.manylinux1_x86_64.manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:8bd7eb96a675f18aa5c553eb7ddc24a43c8c18f22e1f9925528128c052cdbe00", size = 232233, upload-time = "2025-06-09T23:01:21.175Z" }, - { url = "https://files.pythonhosted.org/packages/59/52/460db4d7ba0811b9ccb85af996019f5d70831f2f5f255f7cc61f86199795/frozenlist-1.7.0-cp313-cp313-musllinux_1_2_aarch64.whl", hash = "sha256:05579bf020096fe05a764f1f84cd104a12f78eaab68842d036772dc6d4870b4b", size = 227996, upload-time = "2025-06-09T23:01:23.098Z" }, - { url = "https://files.pythonhosted.org/packages/ba/c9/f4b39e904c03927b7ecf891804fd3b4df3db29b9e487c6418e37988d6e9d/frozenlist-1.7.0-cp313-cp313-musllinux_1_2_armv7l.whl", hash = "sha256:376b6222d114e97eeec13d46c486facd41d4f43bab626b7c3f6a8b4e81a5192c", size = 242280, upload-time = "2025-06-09T23:01:24.808Z" }, - { url = "https://files.pythonhosted.org/packages/b8/33/3f8d6ced42f162d743e3517781566b8481322be321b486d9d262adf70bfb/frozenlist-1.7.0-cp313-cp313-musllinux_1_2_i686.whl", hash = "sha256:0aa7e176ebe115379b5b1c95b4096fb1c17cce0847402e227e712c27bdb5a949", size = 217717, upload-time = "2025-06-09T23:01:26.28Z" }, - { url = "https://files.pythonhosted.org/packages/3e/e8/ad683e75da6ccef50d0ab0c2b2324b32f84fc88ceee778ed79b8e2d2fe2e/frozenlist-1.7.0-cp313-cp313-musllinux_1_2_ppc64le.whl", hash = "sha256:3fbba20e662b9c2130dc771e332a99eff5da078b2b2648153a40669a6d0e36ca", size = 236644, upload-time = "2025-06-09T23:01:27.887Z" }, - { url = "https://files.pythonhosted.org/packages/b2/14/8d19ccdd3799310722195a72ac94ddc677541fb4bef4091d8e7775752360/frozenlist-1.7.0-cp313-cp313-musllinux_1_2_s390x.whl", hash = "sha256:f3f4410a0a601d349dd406b5713fec59b4cee7e71678d5b17edda7f4655a940b", size = 238879, upload-time = "2025-06-09T23:01:29.524Z" }, - { url = "https://files.pythonhosted.org/packages/ce/13/c12bf657494c2fd1079a48b2db49fa4196325909249a52d8f09bc9123fd7/frozenlist-1.7.0-cp313-cp313-musllinux_1_2_x86_64.whl", hash = "sha256:e2cdfaaec6a2f9327bf43c933c0319a7c429058e8537c508964a133dffee412e", size = 232502, upload-time = "2025-06-09T23:01:31.287Z" }, - { url = "https://files.pythonhosted.org/packages/d7/8b/e7f9dfde869825489382bc0d512c15e96d3964180c9499efcec72e85db7e/frozenlist-1.7.0-cp313-cp313-win32.whl", hash = "sha256:5fc4df05a6591c7768459caba1b342d9ec23fa16195e744939ba5914596ae3e1", size = 39169, upload-time = "2025-06-09T23:01:35.503Z" }, - { url = "https://files.pythonhosted.org/packages/35/89/a487a98d94205d85745080a37860ff5744b9820a2c9acbcdd9440bfddf98/frozenlist-1.7.0-cp313-cp313-win_amd64.whl", hash = "sha256:52109052b9791a3e6b5d1b65f4b909703984b770694d3eb64fad124c835d7cba", size = 43219, upload-time = "2025-06-09T23:01:36.784Z" }, - { url = "https://files.pythonhosted.org/packages/56/d5/5c4cf2319a49eddd9dd7145e66c4866bdc6f3dbc67ca3d59685149c11e0d/frozenlist-1.7.0-cp313-cp313t-macosx_10_13_universal2.whl", hash = "sha256:a6f86e4193bb0e235ef6ce3dde5cbabed887e0b11f516ce8a0f4d3b33078ec2d", size = 84345, upload-time = "2025-06-09T23:01:38.295Z" }, - { url = "https://files.pythonhosted.org/packages/a4/7d/ec2c1e1dc16b85bc9d526009961953df9cec8481b6886debb36ec9107799/frozenlist-1.7.0-cp313-cp313t-macosx_10_13_x86_64.whl", hash = "sha256:82d664628865abeb32d90ae497fb93df398a69bb3434463d172b80fc25b0dd7d", size = 48880, upload-time = "2025-06-09T23:01:39.887Z" }, - { url = "https://files.pythonhosted.org/packages/69/86/f9596807b03de126e11e7d42ac91e3d0b19a6599c714a1989a4e85eeefc4/frozenlist-1.7.0-cp313-cp313t-macosx_11_0_arm64.whl", hash = "sha256:912a7e8375a1c9a68325a902f3953191b7b292aa3c3fb0d71a216221deca460b", size = 48498, upload-time = "2025-06-09T23:01:41.318Z" }, - { url = "https://files.pythonhosted.org/packages/5e/cb/df6de220f5036001005f2d726b789b2c0b65f2363b104bbc16f5be8084f8/frozenlist-1.7.0-cp313-cp313t-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:9537c2777167488d539bc5de2ad262efc44388230e5118868e172dd4a552b146", size = 292296, upload-time = "2025-06-09T23:01:42.685Z" }, - { url = "https://files.pythonhosted.org/packages/83/1f/de84c642f17c8f851a2905cee2dae401e5e0daca9b5ef121e120e19aa825/frozenlist-1.7.0-cp313-cp313t-manylinux_2_17_armv7l.manylinux2014_armv7l.manylinux_2_31_armv7l.whl", hash = "sha256:f34560fb1b4c3e30ba35fa9a13894ba39e5acfc5f60f57d8accde65f46cc5e74", size = 273103, upload-time = "2025-06-09T23:01:44.166Z" }, - { url = "https://files.pythonhosted.org/packages/88/3c/c840bfa474ba3fa13c772b93070893c6e9d5c0350885760376cbe3b6c1b3/frozenlist-1.7.0-cp313-cp313t-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:acd03d224b0175f5a850edc104ac19040d35419eddad04e7cf2d5986d98427f1", size = 292869, upload-time = "2025-06-09T23:01:45.681Z" }, - { url = "https://files.pythonhosted.org/packages/a6/1c/3efa6e7d5a39a1d5ef0abeb51c48fb657765794a46cf124e5aca2c7a592c/frozenlist-1.7.0-cp313-cp313t-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:f2038310bc582f3d6a09b3816ab01737d60bf7b1ec70f5356b09e84fb7408ab1", size = 291467, upload-time = "2025-06-09T23:01:47.234Z" }, - { url = "https://files.pythonhosted.org/packages/4f/00/d5c5e09d4922c395e2f2f6b79b9a20dab4b67daaf78ab92e7729341f61f6/frozenlist-1.7.0-cp313-cp313t-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:b8c05e4c8e5f36e5e088caa1bf78a687528f83c043706640a92cb76cd6999384", size = 266028, upload-time = "2025-06-09T23:01:48.819Z" }, - { url = "https://files.pythonhosted.org/packages/4e/27/72765be905619dfde25a7f33813ac0341eb6b076abede17a2e3fbfade0cb/frozenlist-1.7.0-cp313-cp313t-manylinux_2_5_x86_64.manylinux1_x86_64.manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:765bb588c86e47d0b68f23c1bee323d4b703218037765dcf3f25c838c6fecceb", size = 284294, upload-time = "2025-06-09T23:01:50.394Z" }, - { url = "https://files.pythonhosted.org/packages/88/67/c94103a23001b17808eb7dd1200c156bb69fb68e63fcf0693dde4cd6228c/frozenlist-1.7.0-cp313-cp313t-musllinux_1_2_aarch64.whl", hash = "sha256:32dc2e08c67d86d0969714dd484fd60ff08ff81d1a1e40a77dd34a387e6ebc0c", size = 281898, upload-time = "2025-06-09T23:01:52.234Z" }, - { url = "https://files.pythonhosted.org/packages/42/34/a3e2c00c00f9e2a9db5653bca3fec306349e71aff14ae45ecc6d0951dd24/frozenlist-1.7.0-cp313-cp313t-musllinux_1_2_armv7l.whl", hash = "sha256:c0303e597eb5a5321b4de9c68e9845ac8f290d2ab3f3e2c864437d3c5a30cd65", size = 290465, upload-time = "2025-06-09T23:01:53.788Z" }, - { url = "https://files.pythonhosted.org/packages/bb/73/f89b7fbce8b0b0c095d82b008afd0590f71ccb3dee6eee41791cf8cd25fd/frozenlist-1.7.0-cp313-cp313t-musllinux_1_2_i686.whl", hash = "sha256:a47f2abb4e29b3a8d0b530f7c3598badc6b134562b1a5caee867f7c62fee51e3", size = 266385, upload-time = "2025-06-09T23:01:55.769Z" }, - { url = "https://files.pythonhosted.org/packages/cd/45/e365fdb554159462ca12df54bc59bfa7a9a273ecc21e99e72e597564d1ae/frozenlist-1.7.0-cp313-cp313t-musllinux_1_2_ppc64le.whl", hash = "sha256:3d688126c242a6fabbd92e02633414d40f50bb6002fa4cf995a1d18051525657", size = 288771, upload-time = "2025-06-09T23:01:57.4Z" }, - { url = "https://files.pythonhosted.org/packages/00/11/47b6117002a0e904f004d70ec5194fe9144f117c33c851e3d51c765962d0/frozenlist-1.7.0-cp313-cp313t-musllinux_1_2_s390x.whl", hash = "sha256:4e7e9652b3d367c7bd449a727dc79d5043f48b88d0cbfd4f9f1060cf2b414104", size = 288206, upload-time = "2025-06-09T23:01:58.936Z" }, - { url = "https://files.pythonhosted.org/packages/40/37/5f9f3c3fd7f7746082ec67bcdc204db72dad081f4f83a503d33220a92973/frozenlist-1.7.0-cp313-cp313t-musllinux_1_2_x86_64.whl", hash = "sha256:1a85e345b4c43db8b842cab1feb41be5cc0b10a1830e6295b69d7310f99becaf", size = 282620, upload-time = "2025-06-09T23:02:00.493Z" }, - { url = "https://files.pythonhosted.org/packages/0b/31/8fbc5af2d183bff20f21aa743b4088eac4445d2bb1cdece449ae80e4e2d1/frozenlist-1.7.0-cp313-cp313t-win32.whl", hash = "sha256:3a14027124ddb70dfcee5148979998066897e79f89f64b13328595c4bdf77c81", size = 43059, upload-time = "2025-06-09T23:02:02.072Z" }, - { url = "https://files.pythonhosted.org/packages/bb/ed/41956f52105b8dbc26e457c5705340c67c8cc2b79f394b79bffc09d0e938/frozenlist-1.7.0-cp313-cp313t-win_amd64.whl", hash = "sha256:3bf8010d71d4507775f658e9823210b7427be36625b387221642725b515dcf3e", size = 47516, upload-time = "2025-06-09T23:02:03.779Z" }, - { url = "https://files.pythonhosted.org/packages/ee/45/b82e3c16be2182bff01179db177fe144d58b5dc787a7d4492c6ed8b9317f/frozenlist-1.7.0-py3-none-any.whl", hash = "sha256:9a5af342e34f7e97caf8c995864c7a396418ae2859cc6fdf1b1073020d516a7e", size = 13106, upload-time = "2025-06-09T23:02:34.204Z" }, -] - -[[package]] -name = "fsspec" -version = "2025.5.1" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/00/f7/27f15d41f0ed38e8fcc488584b57e902b331da7f7c6dcda53721b15838fc/fsspec-2025.5.1.tar.gz", hash = "sha256:2e55e47a540b91843b755e83ded97c6e897fa0942b11490113f09e9c443c2475", size = 303033, upload-time = "2025-05-24T12:03:23.792Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/bb/61/78c7b3851add1481b048b5fdc29067397a1784e2910592bc81bb3f608635/fsspec-2025.5.1-py3-none-any.whl", hash = "sha256:24d3a2e663d5fc735ab256263c4075f374a174c3410c0b25e5bd1970bceaa462", size = 199052, upload-time = "2025-05-24T12:03:21.66Z" }, -] - -[package.optional-dependencies] -http = [ - { name = "aiohttp" }, -] - -[[package]] -name = "ftfy" -version = "6.3.1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "wcwidth" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/a5/d3/8650919bc3c7c6e90ee3fa7fd618bf373cbbe55dff043bd67353dbb20cd8/ftfy-6.3.1.tar.gz", hash = "sha256:9b3c3d90f84fb267fe64d375a07b7f8912d817cf86009ae134aa03e1819506ec", size = 308927, upload-time = "2024-10-26T00:50:35.149Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/ab/6e/81d47999aebc1b155f81eca4477a616a70f238a2549848c38983f3c22a82/ftfy-6.3.1-py3-none-any.whl", hash = "sha256:7c70eb532015cd2f9adb53f101fb6c7945988d023a085d127d1573dc49dd0083", size = 44821, upload-time = "2024-10-26T00:50:33.425Z" }, -] - -[[package]] -name = "googleapis-common-protos" -version = "1.70.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "protobuf" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/39/24/33db22342cf4a2ea27c9955e6713140fedd51e8b141b5ce5260897020f1a/googleapis_common_protos-1.70.0.tar.gz", hash = "sha256:0e1b44e0ea153e6594f9f394fef15193a68aaaea2d843f83e2742717ca753257", size = 145903, upload-time = "2025-04-14T10:17:02.924Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/86/f1/62a193f0227cf15a920390abe675f386dec35f7ae3ffe6da582d3ade42c7/googleapis_common_protos-1.70.0-py3-none-any.whl", hash = "sha256:b8bfcca8c25a2bb253e0e0b0adaf8c00773e5e6af6fd92397576680b807e0fd8", size = 294530, upload-time = "2025-04-14T10:17:01.271Z" }, -] - -[[package]] -name = "greenlet" -version = "3.2.3" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/c9/92/bb85bd6e80148a4d2e0c59f7c0c2891029f8fd510183afc7d8d2feeed9b6/greenlet-3.2.3.tar.gz", hash = "sha256:8b0dd8ae4c0d6f5e54ee55ba935eeb3d735a9b58a8a1e5b5cbab64e01a39f365", size = 185752, upload-time = "2025-06-05T16:16:09.955Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/92/db/b4c12cff13ebac2786f4f217f06588bccd8b53d260453404ef22b121fc3a/greenlet-3.2.3-cp310-cp310-macosx_11_0_universal2.whl", hash = "sha256:1afd685acd5597349ee6d7a88a8bec83ce13c106ac78c196ee9dde7c04fe87be", size = 268977, upload-time = "2025-06-05T16:10:24.001Z" }, - { url = "https://files.pythonhosted.org/packages/52/61/75b4abd8147f13f70986df2801bf93735c1bd87ea780d70e3b3ecda8c165/greenlet-3.2.3-cp310-cp310-manylinux2014_aarch64.manylinux_2_17_aarch64.whl", hash = "sha256:761917cac215c61e9dc7324b2606107b3b292a8349bdebb31503ab4de3f559ac", size = 627351, upload-time = "2025-06-05T16:38:50.685Z" }, - { url = "https://files.pythonhosted.org/packages/35/aa/6894ae299d059d26254779a5088632874b80ee8cf89a88bca00b0709d22f/greenlet-3.2.3-cp310-cp310-manylinux2014_ppc64le.manylinux_2_17_ppc64le.whl", hash = "sha256:a433dbc54e4a37e4fff90ef34f25a8c00aed99b06856f0119dcf09fbafa16392", size = 638599, upload-time = "2025-06-05T16:41:34.057Z" }, - { url = "https://files.pythonhosted.org/packages/30/64/e01a8261d13c47f3c082519a5e9dbf9e143cc0498ed20c911d04e54d526c/greenlet-3.2.3-cp310-cp310-manylinux2014_s390x.manylinux_2_17_s390x.whl", hash = "sha256:72e77ed69312bab0434d7292316d5afd6896192ac4327d44f3d613ecb85b037c", size = 634482, upload-time = "2025-06-05T16:48:16.26Z" }, - { url = "https://files.pythonhosted.org/packages/47/48/ff9ca8ba9772d083a4f5221f7b4f0ebe8978131a9ae0909cf202f94cd879/greenlet-3.2.3-cp310-cp310-manylinux2014_x86_64.manylinux_2_17_x86_64.whl", hash = "sha256:68671180e3849b963649254a882cd544a3c75bfcd2c527346ad8bb53494444db", size = 633284, upload-time = "2025-06-05T16:13:01.599Z" }, - { url = "https://files.pythonhosted.org/packages/e9/45/626e974948713bc15775b696adb3eb0bd708bec267d6d2d5c47bb47a6119/greenlet-3.2.3-cp310-cp310-manylinux_2_24_x86_64.manylinux_2_28_x86_64.whl", hash = "sha256:49c8cfb18fb419b3d08e011228ef8a25882397f3a859b9fe1436946140b6756b", size = 582206, upload-time = "2025-06-05T16:12:48.51Z" }, - { url = "https://files.pythonhosted.org/packages/b1/8e/8b6f42c67d5df7db35b8c55c9a850ea045219741bb14416255616808c690/greenlet-3.2.3-cp310-cp310-musllinux_1_1_aarch64.whl", hash = "sha256:efc6dc8a792243c31f2f5674b670b3a95d46fa1c6a912b8e310d6f542e7b0712", size = 1111412, upload-time = "2025-06-05T16:36:45.479Z" }, - { url = "https://files.pythonhosted.org/packages/05/46/ab58828217349500a7ebb81159d52ca357da747ff1797c29c6023d79d798/greenlet-3.2.3-cp310-cp310-musllinux_1_1_x86_64.whl", hash = "sha256:731e154aba8e757aedd0781d4b240f1225b075b4409f1bb83b05ff410582cf00", size = 1135054, upload-time = "2025-06-05T16:12:36.478Z" }, - { url = "https://files.pythonhosted.org/packages/68/7f/d1b537be5080721c0f0089a8447d4ef72839039cdb743bdd8ffd23046e9a/greenlet-3.2.3-cp310-cp310-win_amd64.whl", hash = "sha256:96c20252c2f792defe9a115d3287e14811036d51e78b3aaddbee23b69b216302", size = 296573, upload-time = "2025-06-05T16:34:26.521Z" }, - { url = "https://files.pythonhosted.org/packages/fc/2e/d4fcb2978f826358b673f779f78fa8a32ee37df11920dc2bb5589cbeecef/greenlet-3.2.3-cp311-cp311-macosx_11_0_universal2.whl", hash = "sha256:784ae58bba89fa1fa5733d170d42486580cab9decda3484779f4759345b29822", size = 270219, upload-time = "2025-06-05T16:10:10.414Z" }, - { url = "https://files.pythonhosted.org/packages/16/24/929f853e0202130e4fe163bc1d05a671ce8dcd604f790e14896adac43a52/greenlet-3.2.3-cp311-cp311-manylinux2014_aarch64.manylinux_2_17_aarch64.whl", hash = "sha256:0921ac4ea42a5315d3446120ad48f90c3a6b9bb93dd9b3cf4e4d84a66e42de83", size = 630383, upload-time = "2025-06-05T16:38:51.785Z" }, - { url = "https://files.pythonhosted.org/packages/d1/b2/0320715eb61ae70c25ceca2f1d5ae620477d246692d9cc284c13242ec31c/greenlet-3.2.3-cp311-cp311-manylinux2014_ppc64le.manylinux_2_17_ppc64le.whl", hash = "sha256:d2971d93bb99e05f8c2c0c2f4aa9484a18d98c4c3bd3c62b65b7e6ae33dfcfaf", size = 642422, upload-time = "2025-06-05T16:41:35.259Z" }, - { url = "https://files.pythonhosted.org/packages/bd/49/445fd1a210f4747fedf77615d941444349c6a3a4a1135bba9701337cd966/greenlet-3.2.3-cp311-cp311-manylinux2014_s390x.manylinux_2_17_s390x.whl", hash = "sha256:c667c0bf9d406b77a15c924ef3285e1e05250948001220368e039b6aa5b5034b", size = 638375, upload-time = "2025-06-05T16:48:18.235Z" }, - { url = "https://files.pythonhosted.org/packages/7e/c8/ca19760cf6eae75fa8dc32b487e963d863b3ee04a7637da77b616703bc37/greenlet-3.2.3-cp311-cp311-manylinux2014_x86_64.manylinux_2_17_x86_64.whl", hash = "sha256:592c12fb1165be74592f5de0d70f82bc5ba552ac44800d632214b76089945147", size = 637627, upload-time = "2025-06-05T16:13:02.858Z" }, - { url = "https://files.pythonhosted.org/packages/65/89/77acf9e3da38e9bcfca881e43b02ed467c1dedc387021fc4d9bd9928afb8/greenlet-3.2.3-cp311-cp311-manylinux_2_24_x86_64.manylinux_2_28_x86_64.whl", hash = "sha256:29e184536ba333003540790ba29829ac14bb645514fbd7e32af331e8202a62a5", size = 585502, upload-time = "2025-06-05T16:12:49.642Z" }, - { url = "https://files.pythonhosted.org/packages/97/c6/ae244d7c95b23b7130136e07a9cc5aadd60d59b5951180dc7dc7e8edaba7/greenlet-3.2.3-cp311-cp311-musllinux_1_1_aarch64.whl", hash = "sha256:93c0bb79844a367782ec4f429d07589417052e621aa39a5ac1fb99c5aa308edc", size = 1114498, upload-time = "2025-06-05T16:36:46.598Z" }, - { url = "https://files.pythonhosted.org/packages/89/5f/b16dec0cbfd3070658e0d744487919740c6d45eb90946f6787689a7efbce/greenlet-3.2.3-cp311-cp311-musllinux_1_1_x86_64.whl", hash = "sha256:751261fc5ad7b6705f5f76726567375bb2104a059454e0226e1eef6c756748ba", size = 1139977, upload-time = "2025-06-05T16:12:38.262Z" }, - { url = "https://files.pythonhosted.org/packages/66/77/d48fb441b5a71125bcac042fc5b1494c806ccb9a1432ecaa421e72157f77/greenlet-3.2.3-cp311-cp311-win_amd64.whl", hash = "sha256:83a8761c75312361aa2b5b903b79da97f13f556164a7dd2d5448655425bd4c34", size = 297017, upload-time = "2025-06-05T16:25:05.225Z" }, - { url = "https://files.pythonhosted.org/packages/f3/94/ad0d435f7c48debe960c53b8f60fb41c2026b1d0fa4a99a1cb17c3461e09/greenlet-3.2.3-cp312-cp312-macosx_11_0_universal2.whl", hash = "sha256:25ad29caed5783d4bd7a85c9251c651696164622494c00802a139c00d639242d", size = 271992, upload-time = "2025-06-05T16:11:23.467Z" }, - { url = "https://files.pythonhosted.org/packages/93/5d/7c27cf4d003d6e77749d299c7c8f5fd50b4f251647b5c2e97e1f20da0ab5/greenlet-3.2.3-cp312-cp312-manylinux2014_aarch64.manylinux_2_17_aarch64.whl", hash = "sha256:88cd97bf37fe24a6710ec6a3a7799f3f81d9cd33317dcf565ff9950c83f55e0b", size = 638820, upload-time = "2025-06-05T16:38:52.882Z" }, - { url = "https://files.pythonhosted.org/packages/c6/7e/807e1e9be07a125bb4c169144937910bf59b9d2f6d931578e57f0bce0ae2/greenlet-3.2.3-cp312-cp312-manylinux2014_ppc64le.manylinux_2_17_ppc64le.whl", hash = "sha256:baeedccca94880d2f5666b4fa16fc20ef50ba1ee353ee2d7092b383a243b0b0d", size = 653046, upload-time = "2025-06-05T16:41:36.343Z" }, - { url = "https://files.pythonhosted.org/packages/9d/ab/158c1a4ea1068bdbc78dba5a3de57e4c7aeb4e7fa034320ea94c688bfb61/greenlet-3.2.3-cp312-cp312-manylinux2014_s390x.manylinux_2_17_s390x.whl", hash = "sha256:be52af4b6292baecfa0f397f3edb3c6092ce071b499dd6fe292c9ac9f2c8f264", size = 647701, upload-time = "2025-06-05T16:48:19.604Z" }, - { url = "https://files.pythonhosted.org/packages/cc/0d/93729068259b550d6a0288da4ff72b86ed05626eaf1eb7c0d3466a2571de/greenlet-3.2.3-cp312-cp312-manylinux2014_x86_64.manylinux_2_17_x86_64.whl", hash = "sha256:0cc73378150b8b78b0c9fe2ce56e166695e67478550769536a6742dca3651688", size = 649747, upload-time = "2025-06-05T16:13:04.628Z" }, - { url = "https://files.pythonhosted.org/packages/f6/f6/c82ac1851c60851302d8581680573245c8fc300253fc1ff741ae74a6c24d/greenlet-3.2.3-cp312-cp312-manylinux_2_24_x86_64.manylinux_2_28_x86_64.whl", hash = "sha256:706d016a03e78df129f68c4c9b4c4f963f7d73534e48a24f5f5a7101ed13dbbb", size = 605461, upload-time = "2025-06-05T16:12:50.792Z" }, - { url = "https://files.pythonhosted.org/packages/98/82/d022cf25ca39cf1200650fc58c52af32c90f80479c25d1cbf57980ec3065/greenlet-3.2.3-cp312-cp312-musllinux_1_1_aarch64.whl", hash = "sha256:419e60f80709510c343c57b4bb5a339d8767bf9aef9b8ce43f4f143240f88b7c", size = 1121190, upload-time = "2025-06-05T16:36:48.59Z" }, - { url = "https://files.pythonhosted.org/packages/f5/e1/25297f70717abe8104c20ecf7af0a5b82d2f5a980eb1ac79f65654799f9f/greenlet-3.2.3-cp312-cp312-musllinux_1_1_x86_64.whl", hash = "sha256:93d48533fade144203816783373f27a97e4193177ebaaf0fc396db19e5d61163", size = 1149055, upload-time = "2025-06-05T16:12:40.457Z" }, - { url = "https://files.pythonhosted.org/packages/1f/8f/8f9e56c5e82eb2c26e8cde787962e66494312dc8cb261c460e1f3a9c88bc/greenlet-3.2.3-cp312-cp312-win_amd64.whl", hash = "sha256:7454d37c740bb27bdeddfc3f358f26956a07d5220818ceb467a483197d84f849", size = 297817, upload-time = "2025-06-05T16:29:49.244Z" }, - { url = "https://files.pythonhosted.org/packages/b1/cf/f5c0b23309070ae93de75c90d29300751a5aacefc0a3ed1b1d8edb28f08b/greenlet-3.2.3-cp313-cp313-macosx_11_0_universal2.whl", hash = "sha256:500b8689aa9dd1ab26872a34084503aeddefcb438e2e7317b89b11eaea1901ad", size = 270732, upload-time = "2025-06-05T16:10:08.26Z" }, - { url = "https://files.pythonhosted.org/packages/48/ae/91a957ba60482d3fecf9be49bc3948f341d706b52ddb9d83a70d42abd498/greenlet-3.2.3-cp313-cp313-manylinux2014_aarch64.manylinux_2_17_aarch64.whl", hash = "sha256:a07d3472c2a93117af3b0136f246b2833fdc0b542d4a9799ae5f41c28323faef", size = 639033, upload-time = "2025-06-05T16:38:53.983Z" }, - { url = "https://files.pythonhosted.org/packages/6f/df/20ffa66dd5a7a7beffa6451bdb7400d66251374ab40b99981478c69a67a8/greenlet-3.2.3-cp313-cp313-manylinux2014_ppc64le.manylinux_2_17_ppc64le.whl", hash = "sha256:8704b3768d2f51150626962f4b9a9e4a17d2e37c8a8d9867bbd9fa4eb938d3b3", size = 652999, upload-time = "2025-06-05T16:41:37.89Z" }, - { url = "https://files.pythonhosted.org/packages/51/b4/ebb2c8cb41e521f1d72bf0465f2f9a2fd803f674a88db228887e6847077e/greenlet-3.2.3-cp313-cp313-manylinux2014_s390x.manylinux_2_17_s390x.whl", hash = "sha256:5035d77a27b7c62db6cf41cf786cfe2242644a7a337a0e155c80960598baab95", size = 647368, upload-time = "2025-06-05T16:48:21.467Z" }, - { url = "https://files.pythonhosted.org/packages/8e/6a/1e1b5aa10dced4ae876a322155705257748108b7fd2e4fae3f2a091fe81a/greenlet-3.2.3-cp313-cp313-manylinux2014_x86_64.manylinux_2_17_x86_64.whl", hash = "sha256:2d8aa5423cd4a396792f6d4580f88bdc6efcb9205891c9d40d20f6e670992efb", size = 650037, upload-time = "2025-06-05T16:13:06.402Z" }, - { url = "https://files.pythonhosted.org/packages/26/f2/ad51331a157c7015c675702e2d5230c243695c788f8f75feba1af32b3617/greenlet-3.2.3-cp313-cp313-manylinux_2_24_x86_64.manylinux_2_28_x86_64.whl", hash = "sha256:2c724620a101f8170065d7dded3f962a2aea7a7dae133a009cada42847e04a7b", size = 608402, upload-time = "2025-06-05T16:12:51.91Z" }, - { url = "https://files.pythonhosted.org/packages/26/bc/862bd2083e6b3aff23300900a956f4ea9a4059de337f5c8734346b9b34fc/greenlet-3.2.3-cp313-cp313-musllinux_1_1_aarch64.whl", hash = "sha256:873abe55f134c48e1f2a6f53f7d1419192a3d1a4e873bace00499a4e45ea6af0", size = 1119577, upload-time = "2025-06-05T16:36:49.787Z" }, - { url = "https://files.pythonhosted.org/packages/86/94/1fc0cc068cfde885170e01de40a619b00eaa8f2916bf3541744730ffb4c3/greenlet-3.2.3-cp313-cp313-musllinux_1_1_x86_64.whl", hash = "sha256:024571bbce5f2c1cfff08bf3fbaa43bbc7444f580ae13b0099e95d0e6e67ed36", size = 1147121, upload-time = "2025-06-05T16:12:42.527Z" }, - { url = "https://files.pythonhosted.org/packages/27/1a/199f9587e8cb08a0658f9c30f3799244307614148ffe8b1e3aa22f324dea/greenlet-3.2.3-cp313-cp313-win_amd64.whl", hash = "sha256:5195fb1e75e592dd04ce79881c8a22becdfa3e6f500e7feb059b1e6fdd54d3e3", size = 297603, upload-time = "2025-06-05T16:20:12.651Z" }, - { url = "https://files.pythonhosted.org/packages/d8/ca/accd7aa5280eb92b70ed9e8f7fd79dc50a2c21d8c73b9a0856f5b564e222/greenlet-3.2.3-cp314-cp314-macosx_11_0_universal2.whl", hash = "sha256:3d04332dddb10b4a211b68111dabaee2e1a073663d117dc10247b5b1642bac86", size = 271479, upload-time = "2025-06-05T16:10:47.525Z" }, - { url = "https://files.pythonhosted.org/packages/55/71/01ed9895d9eb49223280ecc98a557585edfa56b3d0e965b9fa9f7f06b6d9/greenlet-3.2.3-cp314-cp314-manylinux2014_aarch64.manylinux_2_17_aarch64.whl", hash = "sha256:8186162dffde068a465deab08fc72c767196895c39db26ab1c17c0b77a6d8b97", size = 683952, upload-time = "2025-06-05T16:38:55.125Z" }, - { url = "https://files.pythonhosted.org/packages/ea/61/638c4bdf460c3c678a0a1ef4c200f347dff80719597e53b5edb2fb27ab54/greenlet-3.2.3-cp314-cp314-manylinux2014_ppc64le.manylinux_2_17_ppc64le.whl", hash = "sha256:f4bfbaa6096b1b7a200024784217defedf46a07c2eee1a498e94a1b5f8ec5728", size = 696917, upload-time = "2025-06-05T16:41:38.959Z" }, - { url = "https://files.pythonhosted.org/packages/22/cc/0bd1a7eb759d1f3e3cc2d1bc0f0b487ad3cc9f34d74da4b80f226fde4ec3/greenlet-3.2.3-cp314-cp314-manylinux2014_s390x.manylinux_2_17_s390x.whl", hash = "sha256:ed6cfa9200484d234d8394c70f5492f144b20d4533f69262d530a1a082f6ee9a", size = 692443, upload-time = "2025-06-05T16:48:23.113Z" }, - { url = "https://files.pythonhosted.org/packages/67/10/b2a4b63d3f08362662e89c103f7fe28894a51ae0bc890fabf37d1d780e52/greenlet-3.2.3-cp314-cp314-manylinux2014_x86_64.manylinux_2_17_x86_64.whl", hash = "sha256:02b0df6f63cd15012bed5401b47829cfd2e97052dc89da3cfaf2c779124eb892", size = 692995, upload-time = "2025-06-05T16:13:07.972Z" }, - { url = "https://files.pythonhosted.org/packages/5a/c6/ad82f148a4e3ce9564056453a71529732baf5448ad53fc323e37efe34f66/greenlet-3.2.3-cp314-cp314-manylinux_2_24_x86_64.manylinux_2_28_x86_64.whl", hash = "sha256:86c2d68e87107c1792e2e8d5399acec2487a4e993ab76c792408e59394d52141", size = 655320, upload-time = "2025-06-05T16:12:53.453Z" }, - { url = "https://files.pythonhosted.org/packages/5c/4f/aab73ecaa6b3086a4c89863d94cf26fa84cbff63f52ce9bc4342b3087a06/greenlet-3.2.3-cp314-cp314-win_amd64.whl", hash = "sha256:8c47aae8fbbfcf82cc13327ae802ba13c9c36753b67e760023fd116bc124a62a", size = 301236, upload-time = "2025-06-05T16:15:20.111Z" }, -] - -[[package]] -name = "grpcio" -version = "1.73.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/8e/7b/ca3f561aeecf0c846d15e1b38921a60dffffd5d4113931198fbf455334ee/grpcio-1.73.0.tar.gz", hash = "sha256:3af4c30918a7f0d39de500d11255f8d9da4f30e94a2033e70fe2a720e184bd8e", size = 12786424, upload-time = "2025-06-09T10:08:23.365Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/b0/44/5ca479c880b9f56c9a9502873ea500c09d1087dc868217a90724c24d83d0/grpcio-1.73.0-cp310-cp310-linux_armv7l.whl", hash = "sha256:d050197eeed50f858ef6c51ab09514856f957dba7b1f7812698260fc9cc417f6", size = 5365135, upload-time = "2025-06-09T10:02:44.243Z" }, - { url = "https://files.pythonhosted.org/packages/8d/b7/78ff355cdb602ab01ea437d316846847e0c1f7d109596e5409402cc13156/grpcio-1.73.0-cp310-cp310-macosx_11_0_universal2.whl", hash = "sha256:ebb8d5f4b0200916fb292a964a4d41210de92aba9007e33d8551d85800ea16cb", size = 10609627, upload-time = "2025-06-09T10:02:46.678Z" }, - { url = "https://files.pythonhosted.org/packages/8d/92/5111235062b9da0e3010e5fd2bdceb766113fcf60520f9c23eb651089dd7/grpcio-1.73.0-cp310-cp310-manylinux_2_17_aarch64.whl", hash = "sha256:c0811331b469e3f15dda5f90ab71bcd9681189a83944fd6dc908e2c9249041ef", size = 5803418, upload-time = "2025-06-09T10:02:49.047Z" }, - { url = "https://files.pythonhosted.org/packages/76/fa/dbf3fca0b91fa044f1114b11adc3d4ccc18ab1ac278daa69d450fd9aaef2/grpcio-1.73.0-cp310-cp310-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:12787c791c3993d0ea1cc8bf90393647e9a586066b3b322949365d2772ba965b", size = 6444741, upload-time = "2025-06-09T10:02:51.763Z" }, - { url = "https://files.pythonhosted.org/packages/44/e1/e7c830c1a29abd13f0e7e861c8db57a67db5cb8a1edc6b9d9cd44c26a1e5/grpcio-1.73.0-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:2c17771e884fddf152f2a0df12478e8d02853e5b602a10a9a9f1f52fa02b1d32", size = 6040755, upload-time = "2025-06-09T10:02:54.379Z" }, - { url = "https://files.pythonhosted.org/packages/b4/57/2eaccbfdd8298ab6bb4504600a4283260983a9db7378eb79c922fd559883/grpcio-1.73.0-cp310-cp310-musllinux_1_1_aarch64.whl", hash = "sha256:275e23d4c428c26b51857bbd95fcb8e528783597207ec592571e4372b300a29f", size = 6132216, upload-time = "2025-06-09T10:02:56.932Z" }, - { url = "https://files.pythonhosted.org/packages/81/a4/1bd2c59d7426ab640b121f42acb820ff7cd5c561d03e9c9164cb8431128e/grpcio-1.73.0-cp310-cp310-musllinux_1_1_i686.whl", hash = "sha256:9ffc972b530bf73ef0f948f799482a1bf12d9b6f33406a8e6387c0ca2098a833", size = 6774779, upload-time = "2025-06-09T10:02:59.683Z" }, - { url = "https://files.pythonhosted.org/packages/c6/64/70ee85055b4107acbe1af6a99ef6885e34db89083e53e5c27b8442e3aa38/grpcio-1.73.0-cp310-cp310-musllinux_1_1_x86_64.whl", hash = "sha256:ebd8d269df64aff092b2cec5e015d8ae09c7e90888b5c35c24fdca719a2c9f35", size = 6304223, upload-time = "2025-06-09T10:03:01.794Z" }, - { url = "https://files.pythonhosted.org/packages/06/02/4b3c373edccf29205205a6d329a267b9337ecbbf658bc70f0a18d63d0a50/grpcio-1.73.0-cp310-cp310-win32.whl", hash = "sha256:072d8154b8f74300ed362c01d54af8b93200c1a9077aeaea79828d48598514f1", size = 3679738, upload-time = "2025-06-09T10:03:03.675Z" }, - { url = "https://files.pythonhosted.org/packages/30/7a/d6dab939cda2129e39a872ad48f61c9951567dcda8ab419b8de446315a68/grpcio-1.73.0-cp310-cp310-win_amd64.whl", hash = "sha256:ce953d9d2100e1078a76a9dc2b7338d5415924dc59c69a15bf6e734db8a0f1ca", size = 4340441, upload-time = "2025-06-09T10:03:05.942Z" }, - { url = "https://files.pythonhosted.org/packages/dd/31/9de81fd12f7b27e6af403531b7249d76f743d58e0654e624b3df26a43ce2/grpcio-1.73.0-cp311-cp311-linux_armv7l.whl", hash = "sha256:51036f641f171eebe5fa7aaca5abbd6150f0c338dab3a58f9111354240fe36ec", size = 5363773, upload-time = "2025-06-09T10:03:08.056Z" }, - { url = "https://files.pythonhosted.org/packages/32/9e/2cb78be357a7f1fc4942b81468ef3c7e5fd3df3ac010540459c10895a57b/grpcio-1.73.0-cp311-cp311-macosx_11_0_universal2.whl", hash = "sha256:d12bbb88381ea00bdd92c55aff3da3391fd85bc902c41275c8447b86f036ce0f", size = 10621912, upload-time = "2025-06-09T10:03:10.489Z" }, - { url = "https://files.pythonhosted.org/packages/59/2f/b43954811a2e218a2761c0813800773ac0ca187b94fd2b8494e8ef232dc8/grpcio-1.73.0-cp311-cp311-manylinux_2_17_aarch64.whl", hash = "sha256:483c507c2328ed0e01bc1adb13d1eada05cc737ec301d8e5a8f4a90f387f1790", size = 5807985, upload-time = "2025-06-09T10:03:13.775Z" }, - { url = "https://files.pythonhosted.org/packages/1b/bf/68e9f47e7ee349ffee712dcd907ee66826cf044f0dec7ab517421e56e857/grpcio-1.73.0-cp311-cp311-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:c201a34aa960c962d0ce23fe5f423f97e9d4b518ad605eae6d0a82171809caaa", size = 6448218, upload-time = "2025-06-09T10:03:16.042Z" }, - { url = "https://files.pythonhosted.org/packages/af/dd/38ae43dd58480d609350cf1411fdac5c2ebb243e2c770f6f7aa3773d5e29/grpcio-1.73.0-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:859f70c8e435e8e1fa060e04297c6818ffc81ca9ebd4940e180490958229a45a", size = 6044343, upload-time = "2025-06-09T10:03:18.229Z" }, - { url = "https://files.pythonhosted.org/packages/93/44/b6770b55071adb86481f36dae87d332fcad883b7f560bba9a940394ba018/grpcio-1.73.0-cp311-cp311-musllinux_1_1_aarch64.whl", hash = "sha256:e2459a27c6886e7e687e4e407778425f3c6a971fa17a16420227bda39574d64b", size = 6135858, upload-time = "2025-06-09T10:03:21.059Z" }, - { url = "https://files.pythonhosted.org/packages/d3/9f/63de49fcef436932fcf0ffb978101a95c83c177058dbfb56dbf30ab81659/grpcio-1.73.0-cp311-cp311-musllinux_1_1_i686.whl", hash = "sha256:e0084d4559ee3dbdcce9395e1bc90fdd0262529b32c417a39ecbc18da8074ac7", size = 6775806, upload-time = "2025-06-09T10:03:23.876Z" }, - { url = "https://files.pythonhosted.org/packages/4d/67/c11f1953469162e958f09690ec3a9be3fdb29dea7f5661362a664f9d609a/grpcio-1.73.0-cp311-cp311-musllinux_1_1_x86_64.whl", hash = "sha256:ef5fff73d5f724755693a464d444ee0a448c6cdfd3c1616a9223f736c622617d", size = 6308413, upload-time = "2025-06-09T10:03:26.033Z" }, - { url = "https://files.pythonhosted.org/packages/ba/6a/9dd04426337db07f28bd51a986b7a038ba56912c81b5bb1083c17dd63404/grpcio-1.73.0-cp311-cp311-win32.whl", hash = "sha256:965a16b71a8eeef91fc4df1dc40dc39c344887249174053814f8a8e18449c4c3", size = 3678972, upload-time = "2025-06-09T10:03:28.433Z" }, - { url = "https://files.pythonhosted.org/packages/04/8b/8c0a8a4fdc2e7977d325eafc587c9cf468039693ac23ad707153231d3cb2/grpcio-1.73.0-cp311-cp311-win_amd64.whl", hash = "sha256:b71a7b4483d1f753bbc11089ff0f6fa63b49c97a9cc20552cded3fcad466d23b", size = 4342967, upload-time = "2025-06-09T10:03:31.215Z" }, - { url = "https://files.pythonhosted.org/packages/9d/4d/e938f3a0e51a47f2ce7e55f12f19f316e7074770d56a7c2765e782ec76bc/grpcio-1.73.0-cp312-cp312-linux_armv7l.whl", hash = "sha256:fb9d7c27089d9ba3746f18d2109eb530ef2a37452d2ff50f5a6696cd39167d3b", size = 5334911, upload-time = "2025-06-09T10:03:33.494Z" }, - { url = "https://files.pythonhosted.org/packages/13/56/f09c72c43aa8d6f15a71f2c63ebdfac9cf9314363dea2598dc501d8370db/grpcio-1.73.0-cp312-cp312-macosx_11_0_universal2.whl", hash = "sha256:128ba2ebdac41e41554d492b82c34586a90ebd0766f8ebd72160c0e3a57b9155", size = 10601460, upload-time = "2025-06-09T10:03:36.613Z" }, - { url = "https://files.pythonhosted.org/packages/20/e3/85496edc81e41b3c44ebefffc7bce133bb531120066877df0f910eabfa19/grpcio-1.73.0-cp312-cp312-manylinux_2_17_aarch64.whl", hash = "sha256:068ecc415f79408d57a7f146f54cdf9f0acb4b301a52a9e563973dc981e82f3d", size = 5759191, upload-time = "2025-06-09T10:03:39.838Z" }, - { url = "https://files.pythonhosted.org/packages/88/cc/fef74270a6d29f35ad744bfd8e6c05183f35074ff34c655a2c80f3b422b2/grpcio-1.73.0-cp312-cp312-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:6ddc1cfb2240f84d35d559ade18f69dcd4257dbaa5ba0de1a565d903aaab2968", size = 6409961, upload-time = "2025-06-09T10:03:42.706Z" }, - { url = "https://files.pythonhosted.org/packages/b0/e6/13cfea15e3b8f79c4ae7b676cb21fab70978b0fde1e1d28bb0e073291290/grpcio-1.73.0-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:e53007f70d9783f53b41b4cf38ed39a8e348011437e4c287eee7dd1d39d54b2f", size = 6003948, upload-time = "2025-06-09T10:03:44.96Z" }, - { url = "https://files.pythonhosted.org/packages/c2/ed/b1a36dad4cc0dbf1f83f6d7b58825fefd5cc9ff3a5036e46091335649473/grpcio-1.73.0-cp312-cp312-musllinux_1_1_aarch64.whl", hash = "sha256:4dd8d8d092efede7d6f48d695ba2592046acd04ccf421436dd7ed52677a9ad29", size = 6103788, upload-time = "2025-06-09T10:03:48.053Z" }, - { url = "https://files.pythonhosted.org/packages/e7/c8/d381433d3d46d10f6858126d2d2245ef329e30f3752ce4514c93b95ca6fc/grpcio-1.73.0-cp312-cp312-musllinux_1_1_i686.whl", hash = "sha256:70176093d0a95b44d24baa9c034bb67bfe2b6b5f7ebc2836f4093c97010e17fd", size = 6749508, upload-time = "2025-06-09T10:03:51.185Z" }, - { url = "https://files.pythonhosted.org/packages/87/0a/ff0c31dbd15e63b34320efafac647270aa88c31aa19ff01154a73dc7ce86/grpcio-1.73.0-cp312-cp312-musllinux_1_1_x86_64.whl", hash = "sha256:085ebe876373ca095e24ced95c8f440495ed0b574c491f7f4f714ff794bbcd10", size = 6284342, upload-time = "2025-06-09T10:03:54.467Z" }, - { url = "https://files.pythonhosted.org/packages/fd/73/f762430c0ba867403b9d6e463afe026bf019bd9206eee753785239719273/grpcio-1.73.0-cp312-cp312-win32.whl", hash = "sha256:cfc556c1d6aef02c727ec7d0016827a73bfe67193e47c546f7cadd3ee6bf1a60", size = 3669319, upload-time = "2025-06-09T10:03:56.751Z" }, - { url = "https://files.pythonhosted.org/packages/10/8b/3411609376b2830449cf416f457ad9d2aacb7f562e1b90fdd8bdedf26d63/grpcio-1.73.0-cp312-cp312-win_amd64.whl", hash = "sha256:bbf45d59d090bf69f1e4e1594832aaf40aa84b31659af3c5e2c3f6a35202791a", size = 4335596, upload-time = "2025-06-09T10:03:59.866Z" }, - { url = "https://files.pythonhosted.org/packages/60/da/6f3f7a78e5455c4cbe87c85063cc6da05d65d25264f9d4aed800ece46294/grpcio-1.73.0-cp313-cp313-linux_armv7l.whl", hash = "sha256:da1d677018ef423202aca6d73a8d3b2cb245699eb7f50eb5f74cae15a8e1f724", size = 5335867, upload-time = "2025-06-09T10:04:03.153Z" }, - { url = "https://files.pythonhosted.org/packages/53/14/7d1f2526b98b9658d7be0bb163fd78d681587de6709d8b0c74b4b481b013/grpcio-1.73.0-cp313-cp313-macosx_11_0_universal2.whl", hash = "sha256:36bf93f6a657f37c131d9dd2c391b867abf1426a86727c3575393e9e11dadb0d", size = 10595587, upload-time = "2025-06-09T10:04:05.694Z" }, - { url = "https://files.pythonhosted.org/packages/02/24/a293c398ae44e741da1ed4b29638edbb002258797b07a783f65506165b4c/grpcio-1.73.0-cp313-cp313-manylinux_2_17_aarch64.whl", hash = "sha256:d84000367508ade791d90c2bafbd905574b5ced8056397027a77a215d601ba15", size = 5765793, upload-time = "2025-06-09T10:04:09.235Z" }, - { url = "https://files.pythonhosted.org/packages/e1/24/d84dbd0b5bf36fb44922798d525a85cefa2ffee7b7110e61406e9750ed15/grpcio-1.73.0-cp313-cp313-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:c98ba1d928a178ce33f3425ff823318040a2b7ef875d30a0073565e5ceb058d9", size = 6415494, upload-time = "2025-06-09T10:04:12.377Z" }, - { url = "https://files.pythonhosted.org/packages/5e/85/c80dc65aed8e9dce3d54688864bac45331d9c7600985541f18bd5cb301d4/grpcio-1.73.0-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:a73c72922dfd30b396a5f25bb3a4590195ee45ecde7ee068acb0892d2900cf07", size = 6007279, upload-time = "2025-06-09T10:04:14.878Z" }, - { url = "https://files.pythonhosted.org/packages/37/fc/207c00a4c6fa303d26e2cbd62fbdb0582facdfd08f55500fd83bf6b0f8db/grpcio-1.73.0-cp313-cp313-musllinux_1_1_aarch64.whl", hash = "sha256:10e8edc035724aba0346a432060fd192b42bd03675d083c01553cab071a28da5", size = 6105505, upload-time = "2025-06-09T10:04:17.39Z" }, - { url = "https://files.pythonhosted.org/packages/72/35/8fe69af820667b87ebfcb24214e42a1d53da53cb39edd6b4f84f6b36da86/grpcio-1.73.0-cp313-cp313-musllinux_1_1_i686.whl", hash = "sha256:f5cdc332b503c33b1643b12ea933582c7b081957c8bc2ea4cc4bc58054a09288", size = 6753792, upload-time = "2025-06-09T10:04:19.989Z" }, - { url = "https://files.pythonhosted.org/packages/e2/d8/738c77c1e821e350da4a048849f695ff88a02b291f8c69db23908867aea6/grpcio-1.73.0-cp313-cp313-musllinux_1_1_x86_64.whl", hash = "sha256:07ad7c57233c2109e4ac999cb9c2710c3b8e3f491a73b058b0ce431f31ed8145", size = 6287593, upload-time = "2025-06-09T10:04:22.878Z" }, - { url = "https://files.pythonhosted.org/packages/09/ec/8498eabc018fa39ae8efe5e47e3f4c1bc9ed6281056713871895dc998807/grpcio-1.73.0-cp313-cp313-win32.whl", hash = "sha256:0eb5df4f41ea10bda99a802b2a292d85be28958ede2a50f2beb8c7fc9a738419", size = 3668637, upload-time = "2025-06-09T10:04:25.787Z" }, - { url = "https://files.pythonhosted.org/packages/d7/35/347db7d2e7674b621afd21b12022e7f48c7b0861b5577134b4e939536141/grpcio-1.73.0-cp313-cp313-win_amd64.whl", hash = "sha256:38cf518cc54cd0c47c9539cefa8888549fcc067db0b0c66a46535ca8032020c4", size = 4335872, upload-time = "2025-06-09T10:04:29.032Z" }, -] - -[[package]] -name = "h11" -version = "0.16.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/01/ee/02a2c011bdab74c6fb3c75474d40b3052059d95df7e73351460c8588d963/h11-0.16.0.tar.gz", hash = "sha256:4e35b956cf45792e4caa5885e69fba00bdbc6ffafbfa020300e549b208ee5ff1", size = 101250, upload-time = "2025-04-24T03:35:25.427Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/04/4b/29cac41a4d98d144bf5f6d33995617b185d14b22401f75ca86f384e87ff1/h11-0.16.0-py3-none-any.whl", hash = "sha256:63cf8bbe7522de3bf65932fda1d9c2772064ffb3dae62d55932da54b31cb6c86", size = 37515, upload-time = "2025-04-24T03:35:24.344Z" }, -] - -[[package]] -name = "hf-transfer" -version = "0.1.9" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/1a/eb/8fc64f40388c29ce8ce3b2b180a089d4d6b25b1d0d232d016704cb852104/hf_transfer-0.1.9.tar.gz", hash = "sha256:035572865dab29d17e783fbf1e84cf1cb24f3fcf8f1b17db1cfc7fdf139f02bf", size = 25201, upload-time = "2025-01-07T10:05:12.947Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/a4/78/0dce00208f585fae675f40033ef9a30dedfa83665d5ac79f16beb4a0a6c2/hf_transfer-0.1.9-cp313-cp313t-macosx_10_12_x86_64.whl", hash = "sha256:6e94e8822da79573c9b6ae4d6b2f847c59a7a06c5327d7db20751b68538dc4f6", size = 1386084, upload-time = "2025-01-07T10:04:47.874Z" }, - { url = "https://files.pythonhosted.org/packages/ea/2e/3d60b1a9e9f29a2152aa66c823bf5e399ae7be3fef310ff0de86779c5d2d/hf_transfer-0.1.9-cp313-cp313t-macosx_11_0_arm64.whl", hash = "sha256:3ebc4ab9023414880c8b1d3c38174d1c9989eb5022d37e814fa91a3060123eb0", size = 1343558, upload-time = "2025-01-07T10:04:42.313Z" }, - { url = "https://files.pythonhosted.org/packages/fb/38/130a5ac3747f104033591bcac1c961cb1faadfdc91704f59b09c0b465ff2/hf_transfer-0.1.9-cp313-cp313t-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:8674026f21ed369aa2a0a4b46000aca850fc44cd2b54af33a172ce5325b4fc82", size = 3726676, upload-time = "2025-01-07T10:04:11.539Z" }, - { url = "https://files.pythonhosted.org/packages/15/a1/f4e27c5ad17aac616ae0849e2aede5aae31db8267a948c6b3eeb9fd96446/hf_transfer-0.1.9-cp313-cp313t-manylinux_2_17_armv7l.manylinux2014_armv7l.whl", hash = "sha256:3a736dfbb2c84f5a2c975478ad200c0c8bfcb58a25a35db402678fb87ce17fa4", size = 3062920, upload-time = "2025-01-07T10:04:16.297Z" }, - { url = "https://files.pythonhosted.org/packages/8d/0d/727abdfba39bc3f1132cfa4c970588c2c0bb0d82fe2d645cc10f4e2f8e0b/hf_transfer-0.1.9-cp313-cp313t-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:504b8427fd785dd8546d53b9fafe6e436bd7a3adf76b9dce556507650a7b4567", size = 3578681, upload-time = "2025-01-07T10:04:29.702Z" }, - { url = "https://files.pythonhosted.org/packages/50/d0/2b213eb1ea8b1252ccaf1a6c804d0aba03fea38aae4124df6a3acb70511a/hf_transfer-0.1.9-cp313-cp313t-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:2c7fc1b85f4d0f76e452765d7648c9f4bfd0aedb9ced2ae1ebfece2d8cfaf8e2", size = 3398837, upload-time = "2025-01-07T10:04:22.778Z" }, - { url = "https://files.pythonhosted.org/packages/8c/8a/79dbce9006e0bd6b74516f97451a7b7c64dbbb426df15d901dd438cfeee3/hf_transfer-0.1.9-cp313-cp313t-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:0d991376f0eac70a60f0cbc95602aa708a6f7c8617f28b4945c1431d67b8e3c8", size = 3546986, upload-time = "2025-01-07T10:04:36.415Z" }, - { url = "https://files.pythonhosted.org/packages/a9/f7/9ac239b6ee6fe0bad130325d987a93ea58c4118e50479f0786f1733b37e8/hf_transfer-0.1.9-cp313-cp313t-musllinux_1_2_aarch64.whl", hash = "sha256:e6ac4eddcd99575ed3735ed911ddf9d1697e2bd13aa3f0ad7e3904dd4863842e", size = 4071715, upload-time = "2025-01-07T10:04:53.224Z" }, - { url = "https://files.pythonhosted.org/packages/d8/a3/0ed697279f5eeb7a40f279bd783cf50e6d0b91f24120dcf66ef2cf8822b4/hf_transfer-0.1.9-cp313-cp313t-musllinux_1_2_armv7l.whl", hash = "sha256:57fd9880da1ee0f47250f735f791fab788f0aa1ee36afc49f761349869c8b4d9", size = 3388081, upload-time = "2025-01-07T10:04:57.818Z" }, - { url = "https://files.pythonhosted.org/packages/dc/eb/47e477bdf1d784f31c7540db6cc8c354b777e51a186897a7abda34517f36/hf_transfer-0.1.9-cp313-cp313t-musllinux_1_2_i686.whl", hash = "sha256:5d561f0520f493c66b016d99ceabe69c23289aa90be38dd802d2aef279f15751", size = 3658654, upload-time = "2025-01-07T10:05:03.168Z" }, - { url = "https://files.pythonhosted.org/packages/45/07/6661e43fbee09594a8a5e9bb778107d95fe38dac4c653982afe03d32bd4d/hf_transfer-0.1.9-cp313-cp313t-musllinux_1_2_x86_64.whl", hash = "sha256:a5b366d34cd449fe9b20ef25941e6eef0460a2f74e7389f02e673e1f88ebd538", size = 3690551, upload-time = "2025-01-07T10:05:09.238Z" }, - { url = "https://files.pythonhosted.org/packages/81/f5/461d2e5f307e5048289b1168d5c642ae3bb2504e88dff1a38b92ed990a21/hf_transfer-0.1.9-cp38-abi3-macosx_10_12_x86_64.whl", hash = "sha256:e66acf91df4a8b72f60223059df3003062a5ae111757187ed1a06750a30e911b", size = 1393046, upload-time = "2025-01-07T10:04:51.003Z" }, - { url = "https://files.pythonhosted.org/packages/41/ba/8d9fd9f1083525edfcb389c93738c802f3559cb749324090d7109c8bf4c2/hf_transfer-0.1.9-cp38-abi3-macosx_11_0_arm64.whl", hash = "sha256:8669dbcc7a3e2e8d61d42cd24da9c50d57770bd74b445c65123291ca842a7e7a", size = 1348126, upload-time = "2025-01-07T10:04:45.712Z" }, - { url = "https://files.pythonhosted.org/packages/8e/a2/cd7885bc9959421065a6fae0fe67b6c55becdeda4e69b873e52976f9a9f0/hf_transfer-0.1.9-cp38-abi3-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:8fd0167c4407a3bc4cdd0307e65ada2294ec04f1813d8a69a5243e379b22e9d8", size = 3728604, upload-time = "2025-01-07T10:04:14.173Z" }, - { url = "https://files.pythonhosted.org/packages/f6/2e/a072cf196edfeda3310c9a5ade0a0fdd785e6154b3ce24fc738c818da2a7/hf_transfer-0.1.9-cp38-abi3-manylinux_2_17_armv7l.manylinux2014_armv7l.whl", hash = "sha256:ee8b10afedcb75f71091bcc197c526a6ebf5c58bbbadb34fdeee6160f55f619f", size = 3064995, upload-time = "2025-01-07T10:04:18.663Z" }, - { url = "https://files.pythonhosted.org/packages/c2/84/aec9ef4c0fab93c1ea2b1badff38c78b4b2f86f0555b26d2051dbc920cde/hf_transfer-0.1.9-cp38-abi3-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:5828057e313de59300dd1abb489444bc452efe3f479d3c55b31a8f680936ba42", size = 3580908, upload-time = "2025-01-07T10:04:32.834Z" }, - { url = "https://files.pythonhosted.org/packages/29/63/b560d39651a56603d64f1a0212d0472a44cbd965db2fa62b99d99cb981bf/hf_transfer-0.1.9-cp38-abi3-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:fc6bd19e1cc177c66bdef15ef8636ad3bde79d5a4f608c158021153b4573509d", size = 3400839, upload-time = "2025-01-07T10:04:26.122Z" }, - { url = "https://files.pythonhosted.org/packages/d6/d8/f87ea6f42456254b48915970ed98e993110521e9263472840174d32c880d/hf_transfer-0.1.9-cp38-abi3-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:cdca9bfb89e6f8f281890cc61a8aff2d3cecaff7e1a4d275574d96ca70098557", size = 3552664, upload-time = "2025-01-07T10:04:40.123Z" }, - { url = "https://files.pythonhosted.org/packages/d6/56/1267c39b65fc8f4e2113b36297320f102718bf5799b544a6cbe22013aa1d/hf_transfer-0.1.9-cp38-abi3-musllinux_1_2_aarch64.whl", hash = "sha256:89a23f58b7b7effbc047b8ca286f131b17728c99a9f972723323003ffd1bb916", size = 4073732, upload-time = "2025-01-07T10:04:55.624Z" }, - { url = "https://files.pythonhosted.org/packages/82/1a/9c748befbe3decf7cb415e34f8a0c3789a0a9c55910dea73d581e48c0ce5/hf_transfer-0.1.9-cp38-abi3-musllinux_1_2_armv7l.whl", hash = "sha256:dc7fff1345980d6c0ebb92c811d24afa4b98b3e07ed070c8e38cc91fd80478c5", size = 3390096, upload-time = "2025-01-07T10:04:59.98Z" }, - { url = "https://files.pythonhosted.org/packages/72/85/4c03da147b6b4b7cb12e074d3d44eee28604a387ed0eaf7eaaead5069c57/hf_transfer-0.1.9-cp38-abi3-musllinux_1_2_i686.whl", hash = "sha256:1a6bd16c667ebe89a069ca163060127a794fa3a3525292c900b8c8cc47985b0d", size = 3664743, upload-time = "2025-01-07T10:05:05.416Z" }, - { url = "https://files.pythonhosted.org/packages/e7/6e/e597b04f753f1b09e6893075d53a82a30c13855cbaa791402695b01e369f/hf_transfer-0.1.9-cp38-abi3-musllinux_1_2_x86_64.whl", hash = "sha256:d2fde99d502093ade3ab1b53f80da18480e9902aa960dab7f74fb1b9e5bc5746", size = 3695243, upload-time = "2025-01-07T10:05:11.411Z" }, - { url = "https://files.pythonhosted.org/packages/09/89/d4e234727a26b2546c8fb70a276cd924260d60135f2165bf8b9ed67bb9a4/hf_transfer-0.1.9-cp38-abi3-win32.whl", hash = "sha256:435cc3cdc8524ce57b074032b8fd76eed70a4224d2091232fa6a8cef8fd6803e", size = 1086605, upload-time = "2025-01-07T10:05:18.873Z" }, - { url = "https://files.pythonhosted.org/packages/a1/14/f1e15b851d1c2af5b0b1a82bf8eb10bda2da62d98180220ba6fd8879bb5b/hf_transfer-0.1.9-cp38-abi3-win_amd64.whl", hash = "sha256:16f208fc678911c37e11aa7b586bc66a37d02e636208f18b6bc53d29b5df40ad", size = 1160240, upload-time = "2025-01-07T10:05:14.324Z" }, -] - -[[package]] -name = "hf-xet" -version = "1.1.4" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/8d/11/b480bb7515db97d5b2b703927a59bbdd3f87e68d47dff5591aada467b4a9/hf_xet-1.1.4.tar.gz", hash = "sha256:875158df90cb13547752532ed73cad9dfaad3b29e203143838f67178418d08a4", size = 492082, upload-time = "2025-06-16T21:20:51.375Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/c4/62/3b41a7439930996530c64955874445012fd9044c82c60b34c5891c34fec6/hf_xet-1.1.4-cp37-abi3-macosx_10_12_x86_64.whl", hash = "sha256:6591ab9f61ea82d261107ed90237e2ece972f6a7577d96f5f071208bbf255d1c", size = 2643151, upload-time = "2025-06-16T21:20:45.656Z" }, - { url = "https://files.pythonhosted.org/packages/9b/9f/1744fb1d79e0ac147578b193ce29208ebb9f4636e8cdf505638f6f0a6874/hf_xet-1.1.4-cp37-abi3-macosx_11_0_arm64.whl", hash = "sha256:071b0b4d4698990f746edd666c7cc42555833d22035d88db0df936677fb57d29", size = 2510687, upload-time = "2025-06-16T21:20:43.754Z" }, - { url = "https://files.pythonhosted.org/packages/d1/a8/49a81d4f81b0d21cc758b6fca3880a85ca0d209e8425c8b3a6ef694881ca/hf_xet-1.1.4-cp37-abi3-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:b5b610831e92e41182d4c028653978b844d332d492cdcba1b920d3aca4a0207e", size = 3057631, upload-time = "2025-06-16T21:20:42.006Z" }, - { url = "https://files.pythonhosted.org/packages/bf/8b/65fa08273789dafbc38d0f0bdd20df56b63ebc6566981bbaa255d9d84a33/hf_xet-1.1.4-cp37-abi3-manylinux_2_28_aarch64.whl", hash = "sha256:f6578bcd71393abfd60395279cc160ca808b61f5f9d535b922fcdcd3f77a708d", size = 2949250, upload-time = "2025-06-16T21:20:39.914Z" }, - { url = "https://files.pythonhosted.org/packages/8b/4b/224340bb1d5c63b6e03e04095b4e42230848454bf4293c45cd7bdaa0c208/hf_xet-1.1.4-cp37-abi3-musllinux_1_2_aarch64.whl", hash = "sha256:fb2bbfa2aae0e4f0baca988e7ba8d8c1a39a25adf5317461eb7069ad00505b3e", size = 3124670, upload-time = "2025-06-16T21:20:47.688Z" }, - { url = "https://files.pythonhosted.org/packages/4a/b7/4be010014de6585401c32a04c46b09a4a842d66bd16ed549a401e973b74b/hf_xet-1.1.4-cp37-abi3-musllinux_1_2_x86_64.whl", hash = "sha256:73346ba3e2e15ea8909a26b0862b458f15b003e6277935e3fba5bf273508d698", size = 3234131, upload-time = "2025-06-16T21:20:49.535Z" }, - { url = "https://files.pythonhosted.org/packages/c2/2d/cf148d532f741fbf93f380ff038a33c1309d1e24ea629dc39d11dca08c92/hf_xet-1.1.4-cp37-abi3-win_amd64.whl", hash = "sha256:52e8f8bc2029d8b911493f43cea131ac3fa1f0dc6a13c50b593c4516f02c6fc3", size = 2695589, upload-time = "2025-06-16T21:20:53.151Z" }, -] - -[[package]] -name = "httpcore" -version = "1.0.9" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "certifi" }, - { name = "h11" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/06/94/82699a10bca87a5556c9c59b5963f2d039dbd239f25bc2a63907a05a14cb/httpcore-1.0.9.tar.gz", hash = "sha256:6e34463af53fd2ab5d807f399a9b45ea31c3dfa2276f15a2c3f00afff6e176e8", size = 85484, upload-time = "2025-04-24T22:06:22.219Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/7e/f5/f66802a942d491edb555dd61e3a9961140fd64c90bce1eafd741609d334d/httpcore-1.0.9-py3-none-any.whl", hash = "sha256:2d400746a40668fc9dec9810239072b40b4484b640a8c38fd654a024c7a1bf55", size = 78784, upload-time = "2025-04-24T22:06:20.566Z" }, -] - -[[package]] -name = "httpx" -version = "0.28.1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "anyio" }, - { name = "certifi" }, - { name = "httpcore" }, - { name = "idna" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/b1/df/48c586a5fe32a0f01324ee087459e112ebb7224f646c0b5023f5e79e9956/httpx-0.28.1.tar.gz", hash = "sha256:75e98c5f16b0f35b567856f597f06ff2270a374470a5c2392242528e3e3e42fc", size = 141406, upload-time = "2024-12-06T15:37:23.222Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/2a/39/e50c7c3a983047577ee07d2a9e53faf5a69493943ec3f6a384bdc792deb2/httpx-0.28.1-py3-none-any.whl", hash = "sha256:d909fcccc110f8c7faf814ca82a9a4d816bc5a6dbfea25d6591d6985b8ba59ad", size = 73517, upload-time = "2024-12-06T15:37:21.509Z" }, -] - -[[package]] -name = "huggingface-hub" -version = "0.33.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "filelock" }, - { name = "fsspec" }, - { name = "hf-xet", marker = "platform_machine == 'aarch64' or platform_machine == 'amd64' or platform_machine == 'arm64' or platform_machine == 'x86_64' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "packaging" }, - { name = "pyyaml" }, - { name = "requests" }, - { name = "tqdm" }, - { name = "typing-extensions" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/91/8a/1362d565fefabaa4185cf3ae842a98dbc5b35146f5694f7080f043a6952f/huggingface_hub-0.33.0.tar.gz", hash = "sha256:aa31f70d29439d00ff7a33837c03f1f9dd83971ce4e29ad664d63ffb17d3bb97", size = 426179, upload-time = "2025-06-11T17:08:07.913Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/33/fb/53587a89fbc00799e4179796f51b3ad713c5de6bb680b2becb6d37c94649/huggingface_hub-0.33.0-py3-none-any.whl", hash = "sha256:e8668875b40c68f9929150d99727d39e5ebb8a05a98e4191b908dc7ded9074b3", size = 514799, upload-time = "2025-06-11T17:08:05.757Z" }, -] - -[package.optional-dependencies] -hf-transfer = [ - { name = "hf-transfer" }, -] - -[[package]] -name = "humanize" -version = "4.12.3" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/22/d1/bbc4d251187a43f69844f7fd8941426549bbe4723e8ff0a7441796b0789f/humanize-4.12.3.tar.gz", hash = "sha256:8430be3a615106fdfceb0b2c1b41c4c98c6b0fc5cc59663a5539b111dd325fb0", size = 80514, upload-time = "2025-04-30T11:51:07.98Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/a0/1e/62a2ec3104394a2975a2629eec89276ede9dbe717092f6966fcf963e1bf0/humanize-4.12.3-py3-none-any.whl", hash = "sha256:2cbf6370af06568fa6d2da77c86edb7886f3160ecd19ee1ffef07979efc597f6", size = 128487, upload-time = "2025-04-30T11:51:06.468Z" }, -] - -[[package]] -name = "idna" -version = "3.10" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/f1/70/7703c29685631f5a7590aa73f1f1d3fa9a380e654b86af429e0934a32f7d/idna-3.10.tar.gz", hash = "sha256:12f65c9b470abda6dc35cf8e63cc574b1c52b11df2c86030af0ac09b01b13ea9", size = 190490, upload-time = "2024-09-15T18:07:39.745Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/76/c6/c88e154df9c4e1a2a66ccf0005a88dfb2650c1dffb6f5ce603dfbd452ce3/idna-3.10-py3-none-any.whl", hash = "sha256:946d195a0d259cbba61165e88e65941f16e9b36ea6ddb97f00452bae8b1287d3", size = 70442, upload-time = "2024-09-15T18:07:37.964Z" }, -] - -[[package]] -name = "ijson" -version = "3.4.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/a3/4f/1cfeada63f5fce87536651268ddf5cca79b8b4bbb457aee4e45777964a0a/ijson-3.4.0.tar.gz", hash = "sha256:5f74dcbad9d592c428d3ca3957f7115a42689ee7ee941458860900236ae9bb13", size = 65782, upload-time = "2025-05-08T02:37:20.135Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/eb/6b/a247ba44004154aaa71f9e6bd9f05ba412f490cc4043618efb29314f035e/ijson-3.4.0-cp310-cp310-macosx_10_9_universal2.whl", hash = "sha256:e27e50f6dcdee648f704abc5d31b976cd2f90b4642ed447cf03296d138433d09", size = 87609, upload-time = "2025-05-08T02:35:20.535Z" }, - { url = "https://files.pythonhosted.org/packages/3c/1d/8d2009d74373b7dec2a49b1167e396debb896501396c70a674bb9ccc41ff/ijson-3.4.0-cp310-cp310-macosx_10_9_x86_64.whl", hash = "sha256:2a753be681ac930740a4af9c93cfb4edc49a167faed48061ea650dc5b0f406f1", size = 59243, upload-time = "2025-05-08T02:35:21.958Z" }, - { url = "https://files.pythonhosted.org/packages/a7/b2/a85a21ebaba81f64a326c303a94625fb94b84890c52d9efdd8acb38b6312/ijson-3.4.0-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:a07c47aed534e0ec198e6a2d4360b259d32ac654af59c015afc517ad7973b7fb", size = 59309, upload-time = "2025-05-08T02:35:23.317Z" }, - { url = "https://files.pythonhosted.org/packages/b1/35/273dfa1f27c38eeaba105496ecb54532199f76c0120177b28315daf5aec3/ijson-3.4.0-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:9c55f48181e11c597cd7146fb31edc8058391201ead69f8f40d2ecbb0b3e4fc6", size = 131213, upload-time = "2025-05-08T02:35:24.735Z" }, - { url = "https://files.pythonhosted.org/packages/4d/37/9d3bb0e200a103ca9f8e9315c4d96ecaca43a3c1957c1ac069ea9dc9c6ba/ijson-3.4.0-cp310-cp310-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:abd5669f96f79d8a2dd5ae81cbd06770a4d42c435fd4a75c74ef28d9913b697d", size = 125456, upload-time = "2025-05-08T02:35:25.896Z" }, - { url = "https://files.pythonhosted.org/packages/00/54/8f015c4df30200fd14435dec9c67bf675dff0fee44a16c084a8ec0f82922/ijson-3.4.0-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:3e3ddd46d16b8542c63b1b8af7006c758d4e21cc1b86122c15f8530fae773461", size = 130192, upload-time = "2025-05-08T02:35:27.367Z" }, - { url = "https://files.pythonhosted.org/packages/88/01/46a0540ad3461332edcc689a8874fa13f0a4c00f60f02d155b70e36f5e0b/ijson-3.4.0-cp310-cp310-musllinux_1_2_aarch64.whl", hash = "sha256:1504cec7fe04be2bb0cc33b50c9dd3f83f98c0540ad4991d4017373b7853cfe6", size = 132217, upload-time = "2025-05-08T02:35:28.545Z" }, - { url = "https://files.pythonhosted.org/packages/d7/da/8f8df42f3fd7ef279e20eae294738eed62d41ed5b6a4baca5121abc7cf0f/ijson-3.4.0-cp310-cp310-musllinux_1_2_i686.whl", hash = "sha256:2f2ff456adeb216603e25d7915f10584c1b958b6eafa60038d76d08fc8a5fb06", size = 127118, upload-time = "2025-05-08T02:35:29.726Z" }, - { url = "https://files.pythonhosted.org/packages/82/0a/a410d9d3b082cc2ec9738d54935a589974cbe54c0f358e4d17465594d660/ijson-3.4.0-cp310-cp310-musllinux_1_2_x86_64.whl", hash = "sha256:0ab00d75d61613a125fbbb524551658b1ad6919a52271ca16563ca5bc2737bb1", size = 129808, upload-time = "2025-05-08T02:35:31.247Z" }, - { url = "https://files.pythonhosted.org/packages/2e/c6/a3e2a446b8bd2cf91cb4ca7439f128d2b379b5a79794d0ea25e379b0f4f3/ijson-3.4.0-cp310-cp310-win32.whl", hash = "sha256:ada421fd59fe2bfa4cfa64ba39aeba3f0753696cdcd4d50396a85f38b1d12b01", size = 51160, upload-time = "2025-05-08T02:35:32.964Z" }, - { url = "https://files.pythonhosted.org/packages/18/7c/e6620603df42d2ef8a92076eaa5cd2b905366e86e113adf49e7b79970bd3/ijson-3.4.0-cp310-cp310-win_amd64.whl", hash = "sha256:8c75e82cec05d00ed3a4af5f4edf08f59d536ed1a86ac7e84044870872d82a33", size = 53710, upload-time = "2025-05-08T02:35:34.033Z" }, - { url = "https://files.pythonhosted.org/packages/1a/0d/3e2998f4d7b7d2db2d511e4f0cf9127b6e2140c325c3cb77be46ae46ff1d/ijson-3.4.0-cp311-cp311-macosx_10_9_universal2.whl", hash = "sha256:9e369bf5a173ca51846c243002ad8025d32032532523b06510881ecc8723ee54", size = 87643, upload-time = "2025-05-08T02:35:35.693Z" }, - { url = "https://files.pythonhosted.org/packages/e9/7b/afef2b08af2fee5ead65fcd972fadc3e31f9ae2b517fe2c378d50a9bf79b/ijson-3.4.0-cp311-cp311-macosx_10_9_x86_64.whl", hash = "sha256:26e7da0a3cd2a56a1fde1b34231867693f21c528b683856f6691e95f9f39caec", size = 59260, upload-time = "2025-05-08T02:35:37.166Z" }, - { url = "https://files.pythonhosted.org/packages/da/4a/39f583a2a13096f5063028bb767622f09cafc9ec254c193deee6c80af59f/ijson-3.4.0-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:1c28c7f604729be22aa453e604e9617b665fa0c24cd25f9f47a970e8130c571a", size = 59311, upload-time = "2025-05-08T02:35:38.538Z" }, - { url = "https://files.pythonhosted.org/packages/3c/58/5b80efd54b093e479c98d14b31d7794267281f6a8729f2c94fbfab661029/ijson-3.4.0-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:0bed8bcb84d3468940f97869da323ba09ae3e6b950df11dea9b62e2b231ca1e3", size = 136125, upload-time = "2025-05-08T02:35:39.976Z" }, - { url = "https://files.pythonhosted.org/packages/e5/f5/f37659b1647ecc3992216277cd8a45e2194e84e8818178f77c99e1d18463/ijson-3.4.0-cp311-cp311-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:296bc824f4088f2af814aaf973b0435bc887ce3d9f517b1577cc4e7d1afb1cb7", size = 130699, upload-time = "2025-05-08T02:35:41.483Z" }, - { url = "https://files.pythonhosted.org/packages/ee/2f/4c580ac4bb5eda059b672ad0a05e4bafdae5182a6ec6ab43546763dafa91/ijson-3.4.0-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:8145f8f40617b6a8aa24e28559d0adc8b889e56a203725226a8a60fa3501073f", size = 134963, upload-time = "2025-05-08T02:35:43.017Z" }, - { url = "https://files.pythonhosted.org/packages/6d/9e/64ec39718609faab6ed6e1ceb44f9c35d71210ad9c87fff477c03503e8f8/ijson-3.4.0-cp311-cp311-musllinux_1_2_aarch64.whl", hash = "sha256:b674a97bd503ea21bc85103e06b6493b1b2a12da3372950f53e1c664566a33a4", size = 137405, upload-time = "2025-05-08T02:35:44.618Z" }, - { url = "https://files.pythonhosted.org/packages/71/b2/f0bf0e4a0962845597996de6de59c0078bc03a1f899e03908220039f4cf6/ijson-3.4.0-cp311-cp311-musllinux_1_2_i686.whl", hash = "sha256:8bc731cf1c3282b021d3407a601a5a327613da9ad3c4cecb1123232623ae1826", size = 131861, upload-time = "2025-05-08T02:35:46.22Z" }, - { url = "https://files.pythonhosted.org/packages/17/83/4a2e3611e2b4842b413ec84d2e54adea55ab52e4408ea0f1b1b927e19536/ijson-3.4.0-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:42ace5e940e0cf58c9de72f688d6829ddd815096d07927ee7e77df2648006365", size = 134297, upload-time = "2025-05-08T02:35:47.401Z" }, - { url = "https://files.pythonhosted.org/packages/38/75/2d332911ac765b44cd7da0cb2b06143521ad5e31dfcc8d8587e6e6168bc8/ijson-3.4.0-cp311-cp311-win32.whl", hash = "sha256:5be39a0df4cd3f02b304382ea8885391900ac62e95888af47525a287c50005e9", size = 51161, upload-time = "2025-05-08T02:35:49.164Z" }, - { url = "https://files.pythonhosted.org/packages/7d/ba/4ad571f9f7fcf5906b26e757b130c1713c5f0198a1e59568f05d53a0816c/ijson-3.4.0-cp311-cp311-win_amd64.whl", hash = "sha256:0b1be1781792291e70d2e177acf564ec672a7907ba74f313583bdf39fe81f9b7", size = 53710, upload-time = "2025-05-08T02:35:50.323Z" }, - { url = "https://files.pythonhosted.org/packages/f8/ec/317ee5b2d13e50448833ead3aa906659a32b376191f6abc2a7c6112d2b27/ijson-3.4.0-cp312-cp312-macosx_10_13_universal2.whl", hash = "sha256:956b148f88259a80a9027ffbe2d91705fae0c004fbfba3e5a24028fbe72311a9", size = 87212, upload-time = "2025-05-08T02:35:51.835Z" }, - { url = "https://files.pythonhosted.org/packages/f8/43/b06c96ced30cacecc5d518f89b0fd1c98c294a30ff88848b70ed7b7f72a1/ijson-3.4.0-cp312-cp312-macosx_10_13_x86_64.whl", hash = "sha256:06b89960f5c721106394c7fba5760b3f67c515b8eb7d80f612388f5eca2f4621", size = 59175, upload-time = "2025-05-08T02:35:52.988Z" }, - { url = "https://files.pythonhosted.org/packages/e9/df/b4aeafb7ecde463130840ee9be36130823ec94a00525049bf700883378b8/ijson-3.4.0-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:9a0bb591cf250dd7e9dfab69d634745a7f3272d31cfe879f9156e0a081fd97ee", size = 59011, upload-time = "2025-05-08T02:35:54.394Z" }, - { url = "https://files.pythonhosted.org/packages/e3/7c/a80b8e361641609507f62022089626d4b8067f0826f51e1c09e4ba86eba8/ijson-3.4.0-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:72e92de999977f4c6b660ffcf2b8d59604ccd531edcbfde05b642baf283e0de8", size = 146094, upload-time = "2025-05-08T02:35:55.601Z" }, - { url = "https://files.pythonhosted.org/packages/01/44/fa416347b9a802e3646c6ff377fc3278bd7d6106e17beb339514b6a3184e/ijson-3.4.0-cp312-cp312-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:9e9602157a5b869d44b6896e64f502c712a312fcde044c2e586fccb85d3e316e", size = 137903, upload-time = "2025-05-08T02:35:56.814Z" }, - { url = "https://files.pythonhosted.org/packages/24/c6/41a9ad4d42df50ff6e70fdce79b034f09b914802737ebbdc141153d8d791/ijson-3.4.0-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:b1e83660edb931a425b7ff662eb49db1f10d30ca6d4d350e5630edbed098bc01", size = 148339, upload-time = "2025-05-08T02:35:58.595Z" }, - { url = "https://files.pythonhosted.org/packages/5f/6f/7d01efda415b8502dce67e067ed9e8a124f53e763002c02207e542e1a2f1/ijson-3.4.0-cp312-cp312-musllinux_1_2_aarch64.whl", hash = "sha256:49bf8eac1c7b7913073865a859c215488461f7591b4fa6a33c14b51cb73659d0", size = 149383, upload-time = "2025-05-08T02:36:00.197Z" }, - { url = "https://files.pythonhosted.org/packages/95/6c/0d67024b9ecb57916c5e5ab0350251c9fe2f86dc9c8ca2b605c194bdad6a/ijson-3.4.0-cp312-cp312-musllinux_1_2_i686.whl", hash = "sha256:160b09273cb42019f1811469508b0a057d19f26434d44752bde6f281da6d3f32", size = 141580, upload-time = "2025-05-08T02:36:01.998Z" }, - { url = "https://files.pythonhosted.org/packages/06/43/e10edcc1c6a3b619294de835e7678bfb3a1b8a75955f3689fd66a1e9e7b4/ijson-3.4.0-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:2019ff4e6f354aa00c76c8591bd450899111c61f2354ad55cc127e2ce2492c44", size = 150280, upload-time = "2025-05-08T02:36:03.926Z" }, - { url = "https://files.pythonhosted.org/packages/07/84/1cbeee8e8190a1ebe6926569a92cf1fa80ddb380c129beb6f86559e1bb24/ijson-3.4.0-cp312-cp312-win32.whl", hash = "sha256:931c007bf6bb8330705429989b2deed6838c22b63358a330bf362b6e458ba0bf", size = 51512, upload-time = "2025-05-08T02:36:05.595Z" }, - { url = "https://files.pythonhosted.org/packages/66/13/530802bc391c95be6fe9f96e9aa427d94067e7c0b7da7a9092344dc44c4b/ijson-3.4.0-cp312-cp312-win_amd64.whl", hash = "sha256:71523f2b64cb856a820223e94d23e88369f193017ecc789bb4de198cc9d349eb", size = 54081, upload-time = "2025-05-08T02:36:07.099Z" }, - { url = "https://files.pythonhosted.org/packages/77/b3/b1d2eb2745e5204ec7a25365a6deb7868576214feb5e109bce368fb692c9/ijson-3.4.0-cp313-cp313-macosx_10_13_universal2.whl", hash = "sha256:e8d96f88d75196a61c9d9443de2b72c2d4a7ba9456ff117b57ae3bba23a54256", size = 87216, upload-time = "2025-05-08T02:36:08.414Z" }, - { url = "https://files.pythonhosted.org/packages/b1/cd/cd6d340087617f8cc9bedbb21d974542fe2f160ed0126b8288d3499a469b/ijson-3.4.0-cp313-cp313-macosx_10_13_x86_64.whl", hash = "sha256:c45906ce2c1d3b62f15645476fc3a6ca279549127f01662a39ca5ed334a00cf9", size = 59170, upload-time = "2025-05-08T02:36:09.604Z" }, - { url = "https://files.pythonhosted.org/packages/3e/4d/32d3a9903b488d3306e3c8288f6ee4217d2eea82728261db03a1045eb5d1/ijson-3.4.0-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:4ab4bc2119b35c4363ea49f29563612237cae9413d2fbe54b223be098b97bc9e", size = 59013, upload-time = "2025-05-08T02:36:10.696Z" }, - { url = "https://files.pythonhosted.org/packages/d5/c8/db15465ab4b0b477cee5964c8bfc94bf8c45af8e27a23e1ad78d1926e587/ijson-3.4.0-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:97b0a9b5a15e61dfb1f14921ea4e0dba39f3a650df6d8f444ddbc2b19b479ff1", size = 146564, upload-time = "2025-05-08T02:36:11.916Z" }, - { url = "https://files.pythonhosted.org/packages/c4/d8/0755545bc122473a9a434ab90e0f378780e603d75495b1ca3872de757873/ijson-3.4.0-cp313-cp313-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:e3047bb994dabedf11de11076ed1147a307924b6e5e2df6784fb2599c4ad8c60", size = 137917, upload-time = "2025-05-08T02:36:13.532Z" }, - { url = "https://files.pythonhosted.org/packages/d0/c6/aeb89c8939ebe3f534af26c8c88000c5e870dbb6ae33644c21a4531f87d2/ijson-3.4.0-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:68c83161b052e9f5dc8191acbc862bb1e63f8a35344cb5cd0db1afd3afd487a6", size = 148897, upload-time = "2025-05-08T02:36:14.813Z" }, - { url = "https://files.pythonhosted.org/packages/be/0e/7ef6e9b372106f2682a4a32b3c65bf86bb471a1670e4dac242faee4a7d3f/ijson-3.4.0-cp313-cp313-musllinux_1_2_aarch64.whl", hash = "sha256:1eebd9b6c20eb1dffde0ae1f0fbb4aeacec2eb7b89adb5c7c0449fc9fd742760", size = 149711, upload-time = "2025-05-08T02:36:16.476Z" }, - { url = "https://files.pythonhosted.org/packages/d1/5d/9841c3ed75bcdabf19b3202de5f862a9c9c86ce5c7c9d95fa32347fdbf5f/ijson-3.4.0-cp313-cp313-musllinux_1_2_i686.whl", hash = "sha256:13fb6d5c35192c541421f3ee81239d91fc15a8d8f26c869250f941f4b346a86c", size = 141691, upload-time = "2025-05-08T02:36:18.044Z" }, - { url = "https://files.pythonhosted.org/packages/d5/d2/ce74e17218dba292e9be10a44ed0c75439f7958cdd263adb0b5b92d012d5/ijson-3.4.0-cp313-cp313-musllinux_1_2_x86_64.whl", hash = "sha256:28b7196ff7b37c4897c547a28fa4876919696739fc91c1f347651c9736877c69", size = 150738, upload-time = "2025-05-08T02:36:19.483Z" }, - { url = "https://files.pythonhosted.org/packages/4e/43/dcc480f94453b1075c9911d4755b823f3ace275761bb37b40139f22109ca/ijson-3.4.0-cp313-cp313-win32.whl", hash = "sha256:3c2691d2da42629522140f77b99587d6f5010440d58d36616f33bc7bdc830cc3", size = 51512, upload-time = "2025-05-08T02:36:20.99Z" }, - { url = "https://files.pythonhosted.org/packages/35/dd/d8c5f15efd85ba51e6e11451ebe23d779361a9ec0d192064c2a8c3cdfcb8/ijson-3.4.0-cp313-cp313-win_amd64.whl", hash = "sha256:c4554718c275a044c47eb3874f78f2c939f300215d9031e785a6711cc51b83fc", size = 54074, upload-time = "2025-05-08T02:36:22.075Z" }, - { url = "https://files.pythonhosted.org/packages/79/73/24ad8cd106203419c4d22bed627e02e281d66b83e91bc206a371893d0486/ijson-3.4.0-cp313-cp313t-macosx_10_13_universal2.whl", hash = "sha256:915a65e3f3c0eee2ea937bc62aaedb6c14cc1e8f0bb9f3f4fb5a9e2bbfa4b480", size = 91694, upload-time = "2025-05-08T02:36:23.289Z" }, - { url = "https://files.pythonhosted.org/packages/17/2d/f7f680984bcb7324a46a4c2df3bd73cf70faef0acfeb85a3f811abdfd590/ijson-3.4.0-cp313-cp313t-macosx_10_13_x86_64.whl", hash = "sha256:afbe9748707684b6c5adc295c4fdcf27765b300aec4d484e14a13dca4e5c0afa", size = 61390, upload-time = "2025-05-08T02:36:24.42Z" }, - { url = "https://files.pythonhosted.org/packages/09/a1/f3ca7bab86f95bdb82494739e71d271410dfefce4590785d511669127145/ijson-3.4.0-cp313-cp313t-macosx_11_0_arm64.whl", hash = "sha256:d823f8f321b4d8d5fa020d0a84f089fec5d52b7c0762430476d9f8bf95bbc1a9", size = 61140, upload-time = "2025-05-08T02:36:26.708Z" }, - { url = "https://files.pythonhosted.org/packages/51/79/dd340df3d4fc7771c95df29997956b92ed0570fe7b616d1792fea9ad93f2/ijson-3.4.0-cp313-cp313t-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:b8a0a2c54f3becf76881188beefd98b484b1d3bd005769a740d5b433b089fa23", size = 214739, upload-time = "2025-05-08T02:36:27.973Z" }, - { url = "https://files.pythonhosted.org/packages/59/f0/85380b7f51d1f5fb7065d76a7b623e02feca920cc678d329b2eccc0011e0/ijson-3.4.0-cp313-cp313t-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:ced19a83ab09afa16257a0b15bc1aa888dbc555cb754be09d375c7f8d41051f2", size = 198338, upload-time = "2025-05-08T02:36:29.496Z" }, - { url = "https://files.pythonhosted.org/packages/a5/cd/313264cf2ec42e0f01d198c49deb7b6fadeb793b3685e20e738eb6b3fa13/ijson-3.4.0-cp313-cp313t-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:8100f9885eff1f38d35cef80ef759a1bbf5fc946349afa681bd7d0e681b7f1a0", size = 207515, upload-time = "2025-05-08T02:36:30.981Z" }, - { url = "https://files.pythonhosted.org/packages/12/94/bf14457aa87ea32641f2db577c9188ef4e4ae373478afef422b31fc7f309/ijson-3.4.0-cp313-cp313t-musllinux_1_2_aarch64.whl", hash = "sha256:d7bcc3f7f21b0f703031ecd15209b1284ea51b2a329d66074b5261de3916c1eb", size = 210081, upload-time = "2025-05-08T02:36:32.403Z" }, - { url = "https://files.pythonhosted.org/packages/7d/b4/eaee39e290e40e52d665db9bd1492cfdce86bd1e47948e0440db209c6023/ijson-3.4.0-cp313-cp313t-musllinux_1_2_i686.whl", hash = "sha256:2dcb190227b09dd171bdcbfe4720fddd574933c66314818dfb3960c8a6246a77", size = 199253, upload-time = "2025-05-08T02:36:33.861Z" }, - { url = "https://files.pythonhosted.org/packages/c5/9c/e09c7b9ac720a703ab115b221b819f149ed54c974edfff623c1e925e57da/ijson-3.4.0-cp313-cp313t-musllinux_1_2_x86_64.whl", hash = "sha256:eda4cfb1d49c6073a901735aaa62e39cb7ab47f3ad7bb184862562f776f1fa8a", size = 203816, upload-time = "2025-05-08T02:36:35.348Z" }, - { url = "https://files.pythonhosted.org/packages/7c/14/acd304f412e32d16a2c12182b9d78206bb0ae35354d35664f45db05c1b3b/ijson-3.4.0-cp313-cp313t-win32.whl", hash = "sha256:0772638efa1f3b72b51736833404f1cbd2f5beeb9c1a3d392e7d385b9160cba7", size = 53760, upload-time = "2025-05-08T02:36:36.608Z" }, - { url = "https://files.pythonhosted.org/packages/2f/24/93dd0a467191590a5ed1fc2b35842bca9d09900d001e00b0b497c0208ef6/ijson-3.4.0-cp313-cp313t-win_amd64.whl", hash = "sha256:3d8a0d67f36e4fb97c61a724456ef0791504b16ce6f74917a31c2e92309bbeb9", size = 56948, upload-time = "2025-05-08T02:36:37.849Z" }, - { url = "https://files.pythonhosted.org/packages/a7/22/da919f16ca9254f8a9ea0ba482d2c1d012ce6e4c712dcafd8adb16b16c63/ijson-3.4.0-pp310-pypy310_pp73-macosx_10_15_x86_64.whl", hash = "sha256:54e989c35dba9cf163d532c14bcf0c260897d5f465643f0cd1fba9c908bed7ef", size = 56480, upload-time = "2025-05-08T02:36:54.942Z" }, - { url = "https://files.pythonhosted.org/packages/6d/54/c2afd289e034d11c4909f4ea90c9dae55053bed358064f310c3dd5033657/ijson-3.4.0-pp310-pypy310_pp73-macosx_11_0_arm64.whl", hash = "sha256:494eeb8e87afef22fbb969a4cb81ac2c535f30406f334fb6136e9117b0bb5380", size = 55956, upload-time = "2025-05-08T02:36:56.178Z" }, - { url = "https://files.pythonhosted.org/packages/43/d6/18799b0fca9ecb8a47e22527eedcea3267e95d4567b564ef21d0299e2d12/ijson-3.4.0-pp310-pypy310_pp73-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:81603de95de1688958af65cd2294881a4790edae7de540b70c65c8253c5dc44a", size = 69394, upload-time = "2025-05-08T02:36:57.699Z" }, - { url = "https://files.pythonhosted.org/packages/c2/d6/c58032c69e9e977bf6d954f22cad0cd52092db89c454ea98926744523665/ijson-3.4.0-pp310-pypy310_pp73-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:8524be12c1773e1be466034cc49c1ecbe3d5b47bb86217bd2a57f73f970a6c19", size = 70378, upload-time = "2025-05-08T02:36:58.98Z" }, - { url = "https://files.pythonhosted.org/packages/da/03/07c6840454d5d228bb5b4509c9a7ac5b9c0b8258e2b317a53f97372be1eb/ijson-3.4.0-pp310-pypy310_pp73-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:17994696ec895d05e0cfa21b11c68c920c82634b4a3d8b8a1455d6fe9fdee8f7", size = 67770, upload-time = "2025-05-08T02:37:00.162Z" }, - { url = "https://files.pythonhosted.org/packages/32/c7/da58a9840380308df574dfdb0276c9d802b12f6125f999e92bcef36db552/ijson-3.4.0-pp310-pypy310_pp73-win_amd64.whl", hash = "sha256:0b67727aaee55d43b2e82b6a866c3cbcb2b66a5e9894212190cbd8773d0d9857", size = 53858, upload-time = "2025-05-08T02:37:01.691Z" }, - { url = "https://files.pythonhosted.org/packages/a3/9b/0bc0594d357600c03c3b5a3a34043d764fc3ad3f0757d2f3aae5b28f6c1c/ijson-3.4.0-pp311-pypy311_pp73-macosx_10_15_x86_64.whl", hash = "sha256:cdc8c5ca0eec789ed99db29c68012dda05027af0860bb360afd28d825238d69d", size = 56483, upload-time = "2025-05-08T02:37:03.274Z" }, - { url = "https://files.pythonhosted.org/packages/00/1f/506cf2574673da1adcc8a794ebb85bf857cabe6294523978637e646814de/ijson-3.4.0-pp311-pypy311_pp73-macosx_11_0_arm64.whl", hash = "sha256:8e6b44b6ec45d5b1a0ee9d97e0e65ab7f62258727004cbbe202bf5f198bc21f7", size = 55957, upload-time = "2025-05-08T02:37:04.865Z" }, - { url = "https://files.pythonhosted.org/packages/dc/3d/a7cd8d8a6de0f3084fe4d457a8f76176e11b013867d1cad16c67d25e8bec/ijson-3.4.0-pp311-pypy311_pp73-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:b51e239e4cb537929796e840d349fc731fdc0d58b1a0683ce5465ad725321e0f", size = 69394, upload-time = "2025-05-08T02:37:06.142Z" }, - { url = "https://files.pythonhosted.org/packages/32/51/aa30abc02aabfc41c95887acf5f1f88da569642d7197fbe5aa105545226d/ijson-3.4.0-pp311-pypy311_pp73-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:ed05d43ec02be8ddb1ab59579761f6656b25d241a77fd74f4f0f7ec09074318a", size = 70377, upload-time = "2025-05-08T02:37:07.353Z" }, - { url = "https://files.pythonhosted.org/packages/c7/37/7773659b8d8d98b34234e1237352f6b446a3c12941619686c7d4a8a5c69c/ijson-3.4.0-pp311-pypy311_pp73-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:cfeca1aaa59d93fd0a3718cbe5f7ef0effff85cf837e0bceb71831a47f39cc14", size = 67767, upload-time = "2025-05-08T02:37:08.587Z" }, - { url = "https://files.pythonhosted.org/packages/cd/1f/dd52a84ed140e31a5d226cd47d98d21aa559aead35ef7bae479eab4c494c/ijson-3.4.0-pp311-pypy311_pp73-win_amd64.whl", hash = "sha256:7ca72ca12e9a1dd4252c97d952be34282907f263f7e28fcdff3a01b83981e837", size = 53864, upload-time = "2025-05-08T02:37:10.044Z" }, -] - -[[package]] -name = "imageio" -version = "2.37.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "pillow" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/0c/47/57e897fb7094afb2d26e8b2e4af9a45c7cf1a405acdeeca001fdf2c98501/imageio-2.37.0.tar.gz", hash = "sha256:71b57b3669666272c818497aebba2b4c5f20d5b37c81720e5e1a56d59c492996", size = 389963, upload-time = "2025-01-20T02:42:37.089Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/cb/bd/b394387b598ed84d8d0fa90611a90bee0adc2021820ad5729f7ced74a8e2/imageio-2.37.0-py3-none-any.whl", hash = "sha256:11efa15b87bc7871b61590326b2d635439acc321cf7f8ce996f812543ce10eed", size = 315796, upload-time = "2025-01-20T02:42:34.931Z" }, -] - -[[package]] -name = "importlib-metadata" -version = "8.7.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "zipp" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/76/66/650a33bd90f786193e4de4b3ad86ea60b53c89b669a5c7be931fac31cdb0/importlib_metadata-8.7.0.tar.gz", hash = "sha256:d13b81ad223b890aa16c5471f2ac3056cf76c5f10f82d6f9292f0b415f389000", size = 56641, upload-time = "2025-04-27T15:29:01.736Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/20/b0/36bd937216ec521246249be3bf9855081de4c5e06a0c9b4219dbeda50373/importlib_metadata-8.7.0-py3-none-any.whl", hash = "sha256:e5dd1551894c77868a30651cef00984d50e1002d06942a7101d34870c5f02afd", size = 27656, upload-time = "2025-04-27T15:29:00.214Z" }, -] - -[[package]] -name = "importlib-resources" -version = "6.5.2" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/cf/8c/f834fbf984f691b4f7ff60f50b514cc3de5cc08abfc3295564dd89c5e2e7/importlib_resources-6.5.2.tar.gz", hash = "sha256:185f87adef5bcc288449d98fb4fba07cea78bc036455dd44c5fc4a2fe78fed2c", size = 44693, upload-time = "2025-01-03T18:51:56.698Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/a4/ed/1f1afb2e9e7f38a545d628f864d562a5ae64fe6f7a10e28ffb9b185b4e89/importlib_resources-6.5.2-py3-none-any.whl", hash = "sha256:789cfdc3ed28c78b67a06acb8126751ced69a3d5f79c095a98298cd8a760ccec", size = 37461, upload-time = "2025-01-03T18:51:54.306Z" }, -] - -[[package]] -name = "iniconfig" -version = "2.1.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/f2/97/ebf4da567aa6827c909642694d71c9fcf53e5b504f2d96afea02718862f3/iniconfig-2.1.0.tar.gz", hash = "sha256:3abbd2e30b36733fee78f9c7f7308f2d0050e88f0087fd25c2645f63c773e1c7", size = 4793, upload-time = "2025-03-19T20:09:59.721Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/2c/e1/e6716421ea10d38022b952c159d5161ca1193197fb744506875fbb87ea7b/iniconfig-2.1.0-py3-none-any.whl", hash = "sha256:9deba5723312380e77435581c6bf4935c94cbfab9b1ed33ef8d238ea168eb760", size = 6050, upload-time = "2025-03-19T20:10:01.071Z" }, -] - -[[package]] -name = "isort" -version = "6.0.1" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/b8/21/1e2a441f74a653a144224d7d21afe8f4169e6c7c20bb13aec3a2dc3815e0/isort-6.0.1.tar.gz", hash = "sha256:1cb5df28dfbc742e490c5e41bad6da41b805b0a8be7bc93cd0fb2a8a890ac450", size = 821955, upload-time = "2025-02-26T21:13:16.955Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/c1/11/114d0a5f4dabbdcedc1125dee0888514c3c3b16d3e9facad87ed96fad97c/isort-6.0.1-py3-none-any.whl", hash = "sha256:2dc5d7f65c9678d94c88dfc29161a320eec67328bc97aad576874cb4be1e9615", size = 94186, upload-time = "2025-02-26T21:13:14.911Z" }, -] - -[[package]] -name = "jax" -version = "0.6.1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "jaxlib" }, - { name = "ml-dtypes" }, - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "opt-einsum" }, - { name = "scipy" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/a3/b9/6d3d88fbab17696d00824ecac3d67feea1ff0abe12d3ebe64166a311ac04/jax-0.6.1.tar.gz", hash = "sha256:c4dcb93e1d34f80cf7adfa81f3fdab62a5068b69107b7a6117f8742ab37b6779", size = 2062260, upload-time = "2025-05-21T18:10:45.017Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/dc/89/99805cd801919b4535e023bfe2de651f5a3ec4f5846a867cbc08006db455/jax-0.6.1-py3-none-any.whl", hash = "sha256:69a4e4506caa5466702bdfd0d7a13d1f9b7281d473885721100a3087fcabf8f9", size = 2394773, upload-time = "2025-05-21T18:10:42.835Z" }, -] - -[[package]] -name = "jaxlib" -version = "0.6.1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "ml-dtypes" }, - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "scipy" }, -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/bb/75/f16efee0f23acef960c18af326d608cff2e27aefabffdc652ccec3004ff2/jaxlib-0.6.1-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:277cc7e9d657d0893a559261277b3eae916ad7fa73e300a629261fb537dca0f1", size = 53770292, upload-time = "2025-05-21T18:10:55.238Z" }, - { url = "https://files.pythonhosted.org/packages/03/06/a135aa4747922bf79caf7132293f625e7921e27369bbbd24bd847c35140d/jaxlib-0.6.1-cp310-cp310-manylinux2014_aarch64.whl", hash = "sha256:8106dc316eb440d07b9d4628a0c8e2acf76da5606742c9f5c33104aaa77b0ac2", size = 78686142, upload-time = "2025-05-21T18:11:00.366Z" }, - { url = "https://files.pythonhosted.org/packages/17/c0/edc1c36586202a9ef2b0341d999cff5737e47a239e56440be650860f87f8/jaxlib-0.6.1-cp310-cp310-manylinux2014_x86_64.whl", hash = "sha256:7ae5815ada71b69532ce443a11160a3ed25c67e82a294a0d89af9d4d27429434", size = 89047535, upload-time = "2025-05-21T18:11:05.534Z" }, - { url = "https://files.pythonhosted.org/packages/43/2e/b9303b425efe12c144e9eb0a9aa59978020fecf20c1591f09e3181610680/jaxlib-0.6.1-cp310-cp310-win_amd64.whl", hash = "sha256:3301addee156f55d1f8079f80b314d89b80094740b7d64e5ec6e7ef2e1febbd7", size = 56824544, upload-time = "2025-05-21T18:11:09.857Z" }, - { url = "https://files.pythonhosted.org/packages/80/62/a3ceb8f8dedb43b4f672b9f2f766029a9f94a016ee6d6974894ab0420eb0/jaxlib-0.6.1-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:02bac5153389f01616516a9fd1dcd6038d23ee50681dac14e4ddbc43ccb3133a", size = 53771693, upload-time = "2025-05-21T18:11:16.628Z" }, - { url = "https://files.pythonhosted.org/packages/7d/40/eae51c403e98353e44aa1eaebf9522baf0488bccfc6f91dfe9d4f448c2ef/jaxlib-0.6.1-cp311-cp311-manylinux2014_aarch64.whl", hash = "sha256:5a90ee7c59b2c00773026fbf918269c7a8676a6a81a34a03af919f7d7bdce9a8", size = 78689747, upload-time = "2025-05-21T18:11:20.662Z" }, - { url = "https://files.pythonhosted.org/packages/6e/6a/94aeafd16d610b09dff8d917b8bdf5f985a6aa2b1a414bc1cfdf5421c09d/jaxlib-0.6.1-cp311-cp311-manylinux2014_x86_64.whl", hash = "sha256:11fcc4b1c741a1e0057f2ffa77d5a82bfe7ee97c3864ed88df67493e789b9173", size = 89050151, upload-time = "2025-05-21T18:11:26.038Z" }, - { url = "https://files.pythonhosted.org/packages/e0/5e/f3aaf20ec803227eeb73ac06e2b451e338240f83fa9fb97fc9faaed1a520/jaxlib-0.6.1-cp311-cp311-win_amd64.whl", hash = "sha256:2168217ec37bf951ca33377d3e0953178ba5cade95f194211d9ab2d53dcd2201", size = 56825361, upload-time = "2025-05-21T18:11:30.586Z" }, - { url = "https://files.pythonhosted.org/packages/83/76/fec2772816bad8ee3f7b450bf3e0927d5e158c45a57b6cd92a48b80bfb1a/jaxlib-0.6.1-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:e14195c23eecd559a61c31027b4172e912e5a50f630320918ffdfae83090ca5a", size = 53787339, upload-time = "2025-05-21T18:11:35.55Z" }, - { url = "https://files.pythonhosted.org/packages/f2/ca/957fdfe2f10477004edca87cd392de21f1d5d3030773601ccd3a0ed0cf72/jaxlib-0.6.1-cp312-cp312-manylinux2014_aarch64.whl", hash = "sha256:b58c29fe747622b70946ea87823ad39202cc83da3d93a5293b432173b738a868", size = 78695871, upload-time = "2025-05-21T18:11:41.041Z" }, - { url = "https://files.pythonhosted.org/packages/79/7b/bb5e24fc929513e3c310b3054d6588b1b6bbf241b5ca12f6eb3d51458981/jaxlib-0.6.1-cp312-cp312-manylinux2014_x86_64.whl", hash = "sha256:d039124468565bbf39363b1504c190e6719e6af89a7948dee256f1dee813bb94", size = 89068176, upload-time = "2025-05-21T18:11:46.897Z" }, - { url = "https://files.pythonhosted.org/packages/1b/12/2bc629d530ee1b333edc81a1d68d262bad2f813ce60fdd46e98d48cc8a20/jaxlib-0.6.1-cp312-cp312-win_amd64.whl", hash = "sha256:76d6f65f3153ffb70e20a76b915d4431823cf70a786d86ba1b76a9c5bf66a0a4", size = 56851131, upload-time = "2025-05-21T18:11:55.455Z" }, - { url = "https://files.pythonhosted.org/packages/8a/b8/6d540bd4b05d1fdfdb140772ea337051d16fb22fd6636d1be88a2848a930/jaxlib-0.6.1-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:f4ca75d9d47a2e90099adfede0e9c926b83ef703d349b3289b8c88e861c09e5d", size = 53790062, upload-time = "2025-05-21T18:11:59.522Z" }, - { url = "https://files.pythonhosted.org/packages/61/03/3fde775865a7d972bb9b23f584b0017aa61104ea6ffc32855b3c0297ca63/jaxlib-0.6.1-cp313-cp313-manylinux2014_aarch64.whl", hash = "sha256:d0c343c51b1052593edb603ddf58cf7f98812b2951ae6c45bd6e93e3e1f2f621", size = 78694596, upload-time = "2025-05-21T18:12:04.066Z" }, - { url = "https://files.pythonhosted.org/packages/59/89/b0a229bf0bd333ef1a5690682deee86f3b38f55613f1423bb2eb26b2d15c/jaxlib-0.6.1-cp313-cp313-manylinux2014_x86_64.whl", hash = "sha256:e734be70fe3e1fa2a31415362721189d974d10a66b0f5396c84585587d101b15", size = 89067270, upload-time = "2025-05-21T18:12:09.507Z" }, - { url = "https://files.pythonhosted.org/packages/f2/ea/cf861b8971f4362be8948fd0ef61a55866b8cc6f562ae0c9671a9d289f99/jaxlib-0.6.1-cp313-cp313-win_amd64.whl", hash = "sha256:b12c8842b2dfc0770ca3785e183f7bed3fa1c2596c720591dbfbe29a05045108", size = 56850186, upload-time = "2025-05-21T18:12:14.384Z" }, - { url = "https://files.pythonhosted.org/packages/03/46/2495a0e387646d1d702d66aa5fd1675f392e959a7d8790b68dca33a8dad0/jaxlib-0.6.1-cp313-cp313t-manylinux2014_aarch64.whl", hash = "sha256:acfe91eb44c29dbbd1f1f65f9bd66e1aef4483f57ad5e3d645129f3ec9ecde2a", size = 78837195, upload-time = "2025-05-21T18:12:18.437Z" }, - { url = "https://files.pythonhosted.org/packages/f2/d7/dccc6354589ebe6a78f591dbdf15f2ef41c81084e5d051a3d2d1674ecb8f/jaxlib-0.6.1-cp313-cp313t-manylinux2014_x86_64.whl", hash = "sha256:5e4f49113a527bcbac70c9e7074e95d8abfa35c3d67c2fed01f77a7abfd317aa", size = 89194164, upload-time = "2025-05-21T18:12:23.912Z" }, -] - -[[package]] -name = "jaxtyping" -version = "0.3.2" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "wadler-lindig" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/88/a8/416bd7ea110ec6b68e8868b0f99c985c735adcf7badc491d3c343937260a/jaxtyping-0.3.2.tar.gz", hash = "sha256:f30483fac4b42e915db8ad2414a85c3b63284aa7d3c100b96b59f755cf4a86ad", size = 44989, upload-time = "2025-04-23T09:48:16.907Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/c9/b9/281e10e2d967ea5e481683eaec99f55ac5a61085ee60551c36942ef32bef/jaxtyping-0.3.2-py3-none-any.whl", hash = "sha256:6a020fd276226ddb5ac4f5725323843dd65e3c7e85c64fd62431e5f738c74e04", size = 55409, upload-time = "2025-04-23T09:48:15.924Z" }, -] - -[[package]] -name = "jinja2" -version = "3.1.6" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "markupsafe" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/df/bf/f7da0350254c0ed7c72f3e33cef02e048281fec7ecec5f032d4aac52226b/jinja2-3.1.6.tar.gz", hash = "sha256:0137fb05990d35f1275a587e9aee6d56da821fc83491a0fb838183be43f66d6d", size = 245115, upload-time = "2025-03-05T20:05:02.478Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/62/a1/3d680cbfd5f4b8f15abc1d571870c5fc3e594bb582bc3b64ea099db13e56/jinja2-3.1.6-py3-none-any.whl", hash = "sha256:85ece4451f492d0c13c5dd7c13a64681a86afae63a5f347908daf103ce6d2f67", size = 134899, upload-time = "2025-03-05T20:05:00.369Z" }, -] - -[[package]] -name = "jiter" -version = "0.10.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/ee/9d/ae7ddb4b8ab3fb1b51faf4deb36cb48a4fbbd7cb36bad6a5fca4741306f7/jiter-0.10.0.tar.gz", hash = "sha256:07a7142c38aacc85194391108dc91b5b57093c978a9932bd86a36862759d9500", size = 162759, upload-time = "2025-05-18T19:04:59.73Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/be/7e/4011b5c77bec97cb2b572f566220364e3e21b51c48c5bd9c4a9c26b41b67/jiter-0.10.0-cp310-cp310-macosx_10_12_x86_64.whl", hash = "sha256:cd2fb72b02478f06a900a5782de2ef47e0396b3e1f7d5aba30daeb1fce66f303", size = 317215, upload-time = "2025-05-18T19:03:04.303Z" }, - { url = "https://files.pythonhosted.org/packages/8a/4f/144c1b57c39692efc7ea7d8e247acf28e47d0912800b34d0ad815f6b2824/jiter-0.10.0-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:32bb468e3af278f095d3fa5b90314728a6916d89ba3d0ffb726dd9bf7367285e", size = 322814, upload-time = "2025-05-18T19:03:06.433Z" }, - { url = "https://files.pythonhosted.org/packages/63/1f/db977336d332a9406c0b1f0b82be6f71f72526a806cbb2281baf201d38e3/jiter-0.10.0-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:aa8b3e0068c26ddedc7abc6fac37da2d0af16b921e288a5a613f4b86f050354f", size = 345237, upload-time = "2025-05-18T19:03:07.833Z" }, - { url = "https://files.pythonhosted.org/packages/d7/1c/aa30a4a775e8a672ad7f21532bdbfb269f0706b39c6ff14e1f86bdd9e5ff/jiter-0.10.0-cp310-cp310-manylinux_2_17_armv7l.manylinux2014_armv7l.whl", hash = "sha256:286299b74cc49e25cd42eea19b72aa82c515d2f2ee12d11392c56d8701f52224", size = 370999, upload-time = "2025-05-18T19:03:09.338Z" }, - { url = "https://files.pythonhosted.org/packages/35/df/f8257abc4207830cb18880781b5f5b716bad5b2a22fb4330cfd357407c5b/jiter-0.10.0-cp310-cp310-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:6ed5649ceeaeffc28d87fb012d25a4cd356dcd53eff5acff1f0466b831dda2a7", size = 491109, upload-time = "2025-05-18T19:03:11.13Z" }, - { url = "https://files.pythonhosted.org/packages/06/76/9e1516fd7b4278aa13a2cc7f159e56befbea9aa65c71586305e7afa8b0b3/jiter-0.10.0-cp310-cp310-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:b2ab0051160cb758a70716448908ef14ad476c3774bd03ddce075f3c1f90a3d6", size = 388608, upload-time = "2025-05-18T19:03:12.911Z" }, - { url = "https://files.pythonhosted.org/packages/6d/64/67750672b4354ca20ca18d3d1ccf2c62a072e8a2d452ac3cf8ced73571ef/jiter-0.10.0-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:03997d2f37f6b67d2f5c475da4412be584e1cec273c1cfc03d642c46db43f8cf", size = 352454, upload-time = "2025-05-18T19:03:14.741Z" }, - { url = "https://files.pythonhosted.org/packages/96/4d/5c4e36d48f169a54b53a305114be3efa2bbffd33b648cd1478a688f639c1/jiter-0.10.0-cp310-cp310-manylinux_2_5_i686.manylinux1_i686.whl", hash = "sha256:c404a99352d839fed80d6afd6c1d66071f3bacaaa5c4268983fc10f769112e90", size = 391833, upload-time = "2025-05-18T19:03:16.426Z" }, - { url = "https://files.pythonhosted.org/packages/0b/de/ce4a6166a78810bd83763d2fa13f85f73cbd3743a325469a4a9289af6dae/jiter-0.10.0-cp310-cp310-musllinux_1_1_aarch64.whl", hash = "sha256:66e989410b6666d3ddb27a74c7e50d0829704ede652fd4c858e91f8d64b403d0", size = 523646, upload-time = "2025-05-18T19:03:17.704Z" }, - { url = "https://files.pythonhosted.org/packages/a2/a6/3bc9acce53466972964cf4ad85efecb94f9244539ab6da1107f7aed82934/jiter-0.10.0-cp310-cp310-musllinux_1_1_x86_64.whl", hash = "sha256:b532d3af9ef4f6374609a3bcb5e05a1951d3bf6190dc6b176fdb277c9bbf15ee", size = 514735, upload-time = "2025-05-18T19:03:19.44Z" }, - { url = "https://files.pythonhosted.org/packages/b4/d8/243c2ab8426a2a4dea85ba2a2ba43df379ccece2145320dfd4799b9633c5/jiter-0.10.0-cp310-cp310-win32.whl", hash = "sha256:da9be20b333970e28b72edc4dff63d4fec3398e05770fb3205f7fb460eb48dd4", size = 210747, upload-time = "2025-05-18T19:03:21.184Z" }, - { url = "https://files.pythonhosted.org/packages/37/7a/8021bd615ef7788b98fc76ff533eaac846322c170e93cbffa01979197a45/jiter-0.10.0-cp310-cp310-win_amd64.whl", hash = "sha256:f59e533afed0c5b0ac3eba20d2548c4a550336d8282ee69eb07b37ea526ee4e5", size = 207484, upload-time = "2025-05-18T19:03:23.046Z" }, - { url = "https://files.pythonhosted.org/packages/1b/dd/6cefc6bd68b1c3c979cecfa7029ab582b57690a31cd2f346c4d0ce7951b6/jiter-0.10.0-cp311-cp311-macosx_10_12_x86_64.whl", hash = "sha256:3bebe0c558e19902c96e99217e0b8e8b17d570906e72ed8a87170bc290b1e978", size = 317473, upload-time = "2025-05-18T19:03:25.942Z" }, - { url = "https://files.pythonhosted.org/packages/be/cf/fc33f5159ce132be1d8dd57251a1ec7a631c7df4bd11e1cd198308c6ae32/jiter-0.10.0-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:558cc7e44fd8e507a236bee6a02fa17199ba752874400a0ca6cd6e2196cdb7dc", size = 321971, upload-time = "2025-05-18T19:03:27.255Z" }, - { url = "https://files.pythonhosted.org/packages/68/a4/da3f150cf1d51f6c472616fb7650429c7ce053e0c962b41b68557fdf6379/jiter-0.10.0-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:4d613e4b379a07d7c8453c5712ce7014e86c6ac93d990a0b8e7377e18505e98d", size = 345574, upload-time = "2025-05-18T19:03:28.63Z" }, - { url = "https://files.pythonhosted.org/packages/84/34/6e8d412e60ff06b186040e77da5f83bc158e9735759fcae65b37d681f28b/jiter-0.10.0-cp311-cp311-manylinux_2_17_armv7l.manylinux2014_armv7l.whl", hash = "sha256:f62cf8ba0618eda841b9bf61797f21c5ebd15a7a1e19daab76e4e4b498d515b2", size = 371028, upload-time = "2025-05-18T19:03:30.292Z" }, - { url = "https://files.pythonhosted.org/packages/fb/d9/9ee86173aae4576c35a2f50ae930d2ccb4c4c236f6cb9353267aa1d626b7/jiter-0.10.0-cp311-cp311-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:919d139cdfa8ae8945112398511cb7fca58a77382617d279556b344867a37e61", size = 491083, upload-time = "2025-05-18T19:03:31.654Z" }, - { url = "https://files.pythonhosted.org/packages/d9/2c/f955de55e74771493ac9e188b0f731524c6a995dffdcb8c255b89c6fb74b/jiter-0.10.0-cp311-cp311-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:13ddbc6ae311175a3b03bd8994881bc4635c923754932918e18da841632349db", size = 388821, upload-time = "2025-05-18T19:03:33.184Z" }, - { url = "https://files.pythonhosted.org/packages/81/5a/0e73541b6edd3f4aada586c24e50626c7815c561a7ba337d6a7eb0a915b4/jiter-0.10.0-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:4c440ea003ad10927a30521a9062ce10b5479592e8a70da27f21eeb457b4a9c5", size = 352174, upload-time = "2025-05-18T19:03:34.965Z" }, - { url = "https://files.pythonhosted.org/packages/1c/c0/61eeec33b8c75b31cae42be14d44f9e6fe3ac15a4e58010256ac3abf3638/jiter-0.10.0-cp311-cp311-manylinux_2_5_i686.manylinux1_i686.whl", hash = "sha256:dc347c87944983481e138dea467c0551080c86b9d21de6ea9306efb12ca8f606", size = 391869, upload-time = "2025-05-18T19:03:36.436Z" }, - { url = "https://files.pythonhosted.org/packages/41/22/5beb5ee4ad4ef7d86f5ea5b4509f680a20706c4a7659e74344777efb7739/jiter-0.10.0-cp311-cp311-musllinux_1_1_aarch64.whl", hash = "sha256:13252b58c1f4d8c5b63ab103c03d909e8e1e7842d302473f482915d95fefd605", size = 523741, upload-time = "2025-05-18T19:03:38.168Z" }, - { url = "https://files.pythonhosted.org/packages/ea/10/768e8818538e5817c637b0df52e54366ec4cebc3346108a4457ea7a98f32/jiter-0.10.0-cp311-cp311-musllinux_1_1_x86_64.whl", hash = "sha256:7d1bbf3c465de4a24ab12fb7766a0003f6f9bce48b8b6a886158c4d569452dc5", size = 514527, upload-time = "2025-05-18T19:03:39.577Z" }, - { url = "https://files.pythonhosted.org/packages/73/6d/29b7c2dc76ce93cbedabfd842fc9096d01a0550c52692dfc33d3cc889815/jiter-0.10.0-cp311-cp311-win32.whl", hash = "sha256:db16e4848b7e826edca4ccdd5b145939758dadf0dc06e7007ad0e9cfb5928ae7", size = 210765, upload-time = "2025-05-18T19:03:41.271Z" }, - { url = "https://files.pythonhosted.org/packages/c2/c9/d394706deb4c660137caf13e33d05a031d734eb99c051142e039d8ceb794/jiter-0.10.0-cp311-cp311-win_amd64.whl", hash = "sha256:9c9c1d5f10e18909e993f9641f12fe1c77b3e9b533ee94ffa970acc14ded3812", size = 209234, upload-time = "2025-05-18T19:03:42.918Z" }, - { url = "https://files.pythonhosted.org/packages/6d/b5/348b3313c58f5fbfb2194eb4d07e46a35748ba6e5b3b3046143f3040bafa/jiter-0.10.0-cp312-cp312-macosx_10_12_x86_64.whl", hash = "sha256:1e274728e4a5345a6dde2d343c8da018b9d4bd4350f5a472fa91f66fda44911b", size = 312262, upload-time = "2025-05-18T19:03:44.637Z" }, - { url = "https://files.pythonhosted.org/packages/9c/4a/6a2397096162b21645162825f058d1709a02965606e537e3304b02742e9b/jiter-0.10.0-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:7202ae396446c988cb2a5feb33a543ab2165b786ac97f53b59aafb803fef0744", size = 320124, upload-time = "2025-05-18T19:03:46.341Z" }, - { url = "https://files.pythonhosted.org/packages/2a/85/1ce02cade7516b726dd88f59a4ee46914bf79d1676d1228ef2002ed2f1c9/jiter-0.10.0-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:23ba7722d6748b6920ed02a8f1726fb4b33e0fd2f3f621816a8b486c66410ab2", size = 345330, upload-time = "2025-05-18T19:03:47.596Z" }, - { url = "https://files.pythonhosted.org/packages/75/d0/bb6b4f209a77190ce10ea8d7e50bf3725fc16d3372d0a9f11985a2b23eff/jiter-0.10.0-cp312-cp312-manylinux_2_17_armv7l.manylinux2014_armv7l.whl", hash = "sha256:371eab43c0a288537d30e1f0b193bc4eca90439fc08a022dd83e5e07500ed026", size = 369670, upload-time = "2025-05-18T19:03:49.334Z" }, - { url = "https://files.pythonhosted.org/packages/a0/f5/a61787da9b8847a601e6827fbc42ecb12be2c925ced3252c8ffcb56afcaf/jiter-0.10.0-cp312-cp312-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:6c675736059020365cebc845a820214765162728b51ab1e03a1b7b3abb70f74c", size = 489057, upload-time = "2025-05-18T19:03:50.66Z" }, - { url = "https://files.pythonhosted.org/packages/12/e4/6f906272810a7b21406c760a53aadbe52e99ee070fc5c0cb191e316de30b/jiter-0.10.0-cp312-cp312-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:0c5867d40ab716e4684858e4887489685968a47e3ba222e44cde6e4a2154f959", size = 389372, upload-time = "2025-05-18T19:03:51.98Z" }, - { url = "https://files.pythonhosted.org/packages/e2/ba/77013b0b8ba904bf3762f11e0129b8928bff7f978a81838dfcc958ad5728/jiter-0.10.0-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:395bb9a26111b60141757d874d27fdea01b17e8fac958b91c20128ba8f4acc8a", size = 352038, upload-time = "2025-05-18T19:03:53.703Z" }, - { url = "https://files.pythonhosted.org/packages/67/27/c62568e3ccb03368dbcc44a1ef3a423cb86778a4389e995125d3d1aaa0a4/jiter-0.10.0-cp312-cp312-manylinux_2_5_i686.manylinux1_i686.whl", hash = "sha256:6842184aed5cdb07e0c7e20e5bdcfafe33515ee1741a6835353bb45fe5d1bd95", size = 391538, upload-time = "2025-05-18T19:03:55.046Z" }, - { url = "https://files.pythonhosted.org/packages/c0/72/0d6b7e31fc17a8fdce76164884edef0698ba556b8eb0af9546ae1a06b91d/jiter-0.10.0-cp312-cp312-musllinux_1_1_aarch64.whl", hash = "sha256:62755d1bcea9876770d4df713d82606c8c1a3dca88ff39046b85a048566d56ea", size = 523557, upload-time = "2025-05-18T19:03:56.386Z" }, - { url = "https://files.pythonhosted.org/packages/2f/09/bc1661fbbcbeb6244bd2904ff3a06f340aa77a2b94e5a7373fd165960ea3/jiter-0.10.0-cp312-cp312-musllinux_1_1_x86_64.whl", hash = "sha256:533efbce2cacec78d5ba73a41756beff8431dfa1694b6346ce7af3a12c42202b", size = 514202, upload-time = "2025-05-18T19:03:57.675Z" }, - { url = "https://files.pythonhosted.org/packages/1b/84/5a5d5400e9d4d54b8004c9673bbe4403928a00d28529ff35b19e9d176b19/jiter-0.10.0-cp312-cp312-win32.whl", hash = "sha256:8be921f0cadd245e981b964dfbcd6fd4bc4e254cdc069490416dd7a2632ecc01", size = 211781, upload-time = "2025-05-18T19:03:59.025Z" }, - { url = "https://files.pythonhosted.org/packages/9b/52/7ec47455e26f2d6e5f2ea4951a0652c06e5b995c291f723973ae9e724a65/jiter-0.10.0-cp312-cp312-win_amd64.whl", hash = "sha256:a7c7d785ae9dda68c2678532a5a1581347e9c15362ae9f6e68f3fdbfb64f2e49", size = 206176, upload-time = "2025-05-18T19:04:00.305Z" }, - { url = "https://files.pythonhosted.org/packages/2e/b0/279597e7a270e8d22623fea6c5d4eeac328e7d95c236ed51a2b884c54f70/jiter-0.10.0-cp313-cp313-macosx_10_12_x86_64.whl", hash = "sha256:e0588107ec8e11b6f5ef0e0d656fb2803ac6cf94a96b2b9fc675c0e3ab5e8644", size = 311617, upload-time = "2025-05-18T19:04:02.078Z" }, - { url = "https://files.pythonhosted.org/packages/91/e3/0916334936f356d605f54cc164af4060e3e7094364add445a3bc79335d46/jiter-0.10.0-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:cafc4628b616dc32530c20ee53d71589816cf385dd9449633e910d596b1f5c8a", size = 318947, upload-time = "2025-05-18T19:04:03.347Z" }, - { url = "https://files.pythonhosted.org/packages/6a/8e/fd94e8c02d0e94539b7d669a7ebbd2776e51f329bb2c84d4385e8063a2ad/jiter-0.10.0-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:520ef6d981172693786a49ff5b09eda72a42e539f14788124a07530f785c3ad6", size = 344618, upload-time = "2025-05-18T19:04:04.709Z" }, - { url = "https://files.pythonhosted.org/packages/6f/b0/f9f0a2ec42c6e9c2e61c327824687f1e2415b767e1089c1d9135f43816bd/jiter-0.10.0-cp313-cp313-manylinux_2_17_armv7l.manylinux2014_armv7l.whl", hash = "sha256:554dedfd05937f8fc45d17ebdf298fe7e0c77458232bcb73d9fbbf4c6455f5b3", size = 368829, upload-time = "2025-05-18T19:04:06.912Z" }, - { url = "https://files.pythonhosted.org/packages/e8/57/5bbcd5331910595ad53b9fd0c610392ac68692176f05ae48d6ce5c852967/jiter-0.10.0-cp313-cp313-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:5bc299da7789deacf95f64052d97f75c16d4fc8c4c214a22bf8d859a4288a1c2", size = 491034, upload-time = "2025-05-18T19:04:08.222Z" }, - { url = "https://files.pythonhosted.org/packages/9b/be/c393df00e6e6e9e623a73551774449f2f23b6ec6a502a3297aeeece2c65a/jiter-0.10.0-cp313-cp313-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:5161e201172de298a8a1baad95eb85db4fb90e902353b1f6a41d64ea64644e25", size = 388529, upload-time = "2025-05-18T19:04:09.566Z" }, - { url = "https://files.pythonhosted.org/packages/42/3e/df2235c54d365434c7f150b986a6e35f41ebdc2f95acea3036d99613025d/jiter-0.10.0-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:2e2227db6ba93cb3e2bf67c87e594adde0609f146344e8207e8730364db27041", size = 350671, upload-time = "2025-05-18T19:04:10.98Z" }, - { url = "https://files.pythonhosted.org/packages/c6/77/71b0b24cbcc28f55ab4dbfe029f9a5b73aeadaba677843fc6dc9ed2b1d0a/jiter-0.10.0-cp313-cp313-manylinux_2_5_i686.manylinux1_i686.whl", hash = "sha256:15acb267ea5e2c64515574b06a8bf393fbfee6a50eb1673614aa45f4613c0cca", size = 390864, upload-time = "2025-05-18T19:04:12.722Z" }, - { url = "https://files.pythonhosted.org/packages/6a/d3/ef774b6969b9b6178e1d1e7a89a3bd37d241f3d3ec5f8deb37bbd203714a/jiter-0.10.0-cp313-cp313-musllinux_1_1_aarch64.whl", hash = "sha256:901b92f2e2947dc6dfcb52fd624453862e16665ea909a08398dde19c0731b7f4", size = 522989, upload-time = "2025-05-18T19:04:14.261Z" }, - { url = "https://files.pythonhosted.org/packages/0c/41/9becdb1d8dd5d854142f45a9d71949ed7e87a8e312b0bede2de849388cb9/jiter-0.10.0-cp313-cp313-musllinux_1_1_x86_64.whl", hash = "sha256:d0cb9a125d5a3ec971a094a845eadde2db0de85b33c9f13eb94a0c63d463879e", size = 513495, upload-time = "2025-05-18T19:04:15.603Z" }, - { url = "https://files.pythonhosted.org/packages/9c/36/3468e5a18238bdedae7c4d19461265b5e9b8e288d3f86cd89d00cbb48686/jiter-0.10.0-cp313-cp313-win32.whl", hash = "sha256:48a403277ad1ee208fb930bdf91745e4d2d6e47253eedc96e2559d1e6527006d", size = 211289, upload-time = "2025-05-18T19:04:17.541Z" }, - { url = "https://files.pythonhosted.org/packages/7e/07/1c96b623128bcb913706e294adb5f768fb7baf8db5e1338ce7b4ee8c78ef/jiter-0.10.0-cp313-cp313-win_amd64.whl", hash = "sha256:75f9eb72ecb640619c29bf714e78c9c46c9c4eaafd644bf78577ede459f330d4", size = 205074, upload-time = "2025-05-18T19:04:19.21Z" }, - { url = "https://files.pythonhosted.org/packages/54/46/caa2c1342655f57d8f0f2519774c6d67132205909c65e9aa8255e1d7b4f4/jiter-0.10.0-cp313-cp313t-macosx_11_0_arm64.whl", hash = "sha256:28ed2a4c05a1f32ef0e1d24c2611330219fed727dae01789f4a335617634b1ca", size = 318225, upload-time = "2025-05-18T19:04:20.583Z" }, - { url = "https://files.pythonhosted.org/packages/43/84/c7d44c75767e18946219ba2d703a5a32ab37b0bc21886a97bc6062e4da42/jiter-0.10.0-cp313-cp313t-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:14a4c418b1ec86a195f1ca69da8b23e8926c752b685af665ce30777233dfe070", size = 350235, upload-time = "2025-05-18T19:04:22.363Z" }, - { url = "https://files.pythonhosted.org/packages/01/16/f5a0135ccd968b480daad0e6ab34b0c7c5ba3bc447e5088152696140dcb3/jiter-0.10.0-cp313-cp313t-win_amd64.whl", hash = "sha256:d7bfed2fe1fe0e4dda6ef682cee888ba444b21e7a6553e03252e4feb6cf0adca", size = 207278, upload-time = "2025-05-18T19:04:23.627Z" }, - { url = "https://files.pythonhosted.org/packages/1c/9b/1d646da42c3de6c2188fdaa15bce8ecb22b635904fc68be025e21249ba44/jiter-0.10.0-cp314-cp314-macosx_10_12_x86_64.whl", hash = "sha256:5e9251a5e83fab8d87799d3e1a46cb4b7f2919b895c6f4483629ed2446f66522", size = 310866, upload-time = "2025-05-18T19:04:24.891Z" }, - { url = "https://files.pythonhosted.org/packages/ad/0e/26538b158e8a7c7987e94e7aeb2999e2e82b1f9d2e1f6e9874ddf71ebda0/jiter-0.10.0-cp314-cp314-macosx_11_0_arm64.whl", hash = "sha256:023aa0204126fe5b87ccbcd75c8a0d0261b9abdbbf46d55e7ae9f8e22424eeb8", size = 318772, upload-time = "2025-05-18T19:04:26.161Z" }, - { url = "https://files.pythonhosted.org/packages/7b/fb/d302893151caa1c2636d6574d213e4b34e31fd077af6050a9c5cbb42f6fb/jiter-0.10.0-cp314-cp314-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:3c189c4f1779c05f75fc17c0c1267594ed918996a231593a21a5ca5438445216", size = 344534, upload-time = "2025-05-18T19:04:27.495Z" }, - { url = "https://files.pythonhosted.org/packages/01/d8/5780b64a149d74e347c5128d82176eb1e3241b1391ac07935693466d6219/jiter-0.10.0-cp314-cp314-manylinux_2_17_armv7l.manylinux2014_armv7l.whl", hash = "sha256:15720084d90d1098ca0229352607cd68256c76991f6b374af96f36920eae13c4", size = 369087, upload-time = "2025-05-18T19:04:28.896Z" }, - { url = "https://files.pythonhosted.org/packages/e8/5b/f235a1437445160e777544f3ade57544daf96ba7e96c1a5b24a6f7ac7004/jiter-0.10.0-cp314-cp314-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:e4f2fb68e5f1cfee30e2b2a09549a00683e0fde4c6a2ab88c94072fc33cb7426", size = 490694, upload-time = "2025-05-18T19:04:30.183Z" }, - { url = "https://files.pythonhosted.org/packages/85/a9/9c3d4617caa2ff89cf61b41e83820c27ebb3f7b5fae8a72901e8cd6ff9be/jiter-0.10.0-cp314-cp314-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:ce541693355fc6da424c08b7edf39a2895f58d6ea17d92cc2b168d20907dee12", size = 388992, upload-time = "2025-05-18T19:04:32.028Z" }, - { url = "https://files.pythonhosted.org/packages/68/b1/344fd14049ba5c94526540af7eb661871f9c54d5f5601ff41a959b9a0bbd/jiter-0.10.0-cp314-cp314-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:31c50c40272e189d50006ad5c73883caabb73d4e9748a688b216e85a9a9ca3b9", size = 351723, upload-time = "2025-05-18T19:04:33.467Z" }, - { url = "https://files.pythonhosted.org/packages/41/89/4c0e345041186f82a31aee7b9d4219a910df672b9fef26f129f0cda07a29/jiter-0.10.0-cp314-cp314-manylinux_2_5_i686.manylinux1_i686.whl", hash = "sha256:fa3402a2ff9815960e0372a47b75c76979d74402448509ccd49a275fa983ef8a", size = 392215, upload-time = "2025-05-18T19:04:34.827Z" }, - { url = "https://files.pythonhosted.org/packages/55/58/ee607863e18d3f895feb802154a2177d7e823a7103f000df182e0f718b38/jiter-0.10.0-cp314-cp314-musllinux_1_1_aarch64.whl", hash = "sha256:1956f934dca32d7bb647ea21d06d93ca40868b505c228556d3373cbd255ce853", size = 522762, upload-time = "2025-05-18T19:04:36.19Z" }, - { url = "https://files.pythonhosted.org/packages/15/d0/9123fb41825490d16929e73c212de9a42913d68324a8ce3c8476cae7ac9d/jiter-0.10.0-cp314-cp314-musllinux_1_1_x86_64.whl", hash = "sha256:fcedb049bdfc555e261d6f65a6abe1d5ad68825b7202ccb9692636c70fcced86", size = 513427, upload-time = "2025-05-18T19:04:37.544Z" }, - { url = "https://files.pythonhosted.org/packages/d8/b3/2bd02071c5a2430d0b70403a34411fc519c2f227da7b03da9ba6a956f931/jiter-0.10.0-cp314-cp314-win32.whl", hash = "sha256:ac509f7eccca54b2a29daeb516fb95b6f0bd0d0d8084efaf8ed5dfc7b9f0b357", size = 210127, upload-time = "2025-05-18T19:04:38.837Z" }, - { url = "https://files.pythonhosted.org/packages/03/0c/5fe86614ea050c3ecd728ab4035534387cd41e7c1855ef6c031f1ca93e3f/jiter-0.10.0-cp314-cp314t-macosx_11_0_arm64.whl", hash = "sha256:5ed975b83a2b8639356151cef5c0d597c68376fc4922b45d0eb384ac058cfa00", size = 318527, upload-time = "2025-05-18T19:04:40.612Z" }, - { url = "https://files.pythonhosted.org/packages/b3/4a/4175a563579e884192ba6e81725fc0448b042024419be8d83aa8a80a3f44/jiter-0.10.0-cp314-cp314t-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:3aa96f2abba33dc77f79b4cf791840230375f9534e5fac927ccceb58c5e604a5", size = 354213, upload-time = "2025-05-18T19:04:41.894Z" }, -] - -[[package]] -name = "joblib" -version = "1.5.1" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/dc/fe/0f5a938c54105553436dbff7a61dc4fed4b1b2c98852f8833beaf4d5968f/joblib-1.5.1.tar.gz", hash = "sha256:f4f86e351f39fe3d0d32a9f2c3d8af1ee4cec285aafcb27003dda5205576b444", size = 330475, upload-time = "2025-05-23T12:04:37.097Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/7d/4f/1195bbac8e0c2acc5f740661631d8d750dc38d4a32b23ee5df3cde6f4e0d/joblib-1.5.1-py3-none-any.whl", hash = "sha256:4719a31f054c7d766948dcd83e9613686b27114f190f717cec7eaa2084f8a74a", size = 307746, upload-time = "2025-05-23T12:04:35.124Z" }, -] - -[[package]] -name = "jsonmerge" -version = "1.9.2" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "jsonschema" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/37/9f/959b3191324d831494b81ec06cfaeb11017858fc59cd9de9c6bd757ef29e/jsonmerge-1.9.2.tar.gz", hash = "sha256:c43757e0180b0e19b7ae4c130ad42a07cc580c31912f61f4823e8eaf2fa394a3", size = 34717, upload-time = "2023-07-19T08:10:07.51Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/71/c2/1032d0dbc2152c45f3d1e582a72e68f41898de9665202392d9400dfa329d/jsonmerge-1.9.2-py3-none-any.whl", hash = "sha256:cab93ee7763fb51a4a09bbdab2eacf499ffb208ab94247ae86acea3e0e823b05", size = 19367, upload-time = "2023-07-19T08:10:06.144Z" }, -] - -[[package]] -name = "jsonschema" -version = "4.24.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "attrs" }, - { name = "jsonschema-specifications" }, - { name = "referencing" }, - { name = "rpds-py" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/bf/d3/1cf5326b923a53515d8f3a2cd442e6d7e94fcc444716e879ea70a0ce3177/jsonschema-4.24.0.tar.gz", hash = "sha256:0b4e8069eb12aedfa881333004bccaec24ecef5a8a6a4b6df142b2cc9599d196", size = 353480, upload-time = "2025-05-26T18:48:10.459Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/a2/3d/023389198f69c722d039351050738d6755376c8fd343e91dc493ea485905/jsonschema-4.24.0-py3-none-any.whl", hash = "sha256:a462455f19f5faf404a7902952b6f0e3ce868f3ee09a359b05eca6673bd8412d", size = 88709, upload-time = "2025-05-26T18:48:08.417Z" }, -] - -[[package]] -name = "jsonschema-specifications" -version = "2025.4.1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "referencing" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/bf/ce/46fbd9c8119cfc3581ee5643ea49464d168028cfb5caff5fc0596d0cf914/jsonschema_specifications-2025.4.1.tar.gz", hash = "sha256:630159c9f4dbea161a6a2205c3011cc4f18ff381b189fff48bb39b9bf26ae608", size = 15513, upload-time = "2025-04-23T12:34:07.418Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/01/0e/b27cdbaccf30b890c40ed1da9fd4a3593a5cf94dae54fb34f8a4b74fcd3f/jsonschema_specifications-2025.4.1-py3-none-any.whl", hash = "sha256:4653bffbd6584f7de83a67e0d620ef16900b390ddc7939d56684d6c81e33f1af", size = 18437, upload-time = "2025-04-23T12:34:05.422Z" }, -] - -[[package]] -name = "kornia" -version = "0.8.1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "kornia-rs" }, - { name = "packaging" }, - { name = "torch", version = "2.0.1", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://pypi.org/simple" }, marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" }, marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "extra == 'extra-7-comfyui-cu128' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/d7/49/3c3aa9c68262b87551d50cdeefff027394316abfe11937a729371a39f50a/kornia-0.8.1.tar.gz", hash = "sha256:9ce5a54a11df661794934a293f89f8b8d49e83dd09b0b9419f6082ab07afe433", size = 652542, upload-time = "2025-05-08T11:13:25.485Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/80/95/a2e359cd08ea24498be59dcd5980e290cdf658ce534bcb7ae13b8ef694e6/kornia-0.8.1-py2.py3-none-any.whl", hash = "sha256:5dcb00faa795dfb45a3630d771387290bc4f40473451352ca250e5bcc81af3d1", size = 1078646, upload-time = "2025-05-08T11:13:22.826Z" }, -] - -[[package]] -name = "kornia-rs" -version = "0.1.9" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/de/28/6e0cc55dfe9967228cfacbeee79d2a31d8ed5bd6bcc478ec0a0f790f1e71/kornia_rs-0.1.9.tar.gz", hash = "sha256:c7e45e84eb3c2454055326f86329e48a68743507460fb7e39315397fa6eeb9a0", size = 108371, upload-time = "2025-05-07T11:42:08.505Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/1a/f2/b0c668be833f628e9586c85a63424271e76c0b44cde187efd409846694e5/kornia_rs-0.1.9-cp310-cp310-macosx_10_12_x86_64.whl", hash = "sha256:ba3bbb9da2c14803b6b7e5faeef87d3e95d0728e722d0a9e7e32e59b3a22ed42", size = 2569136, upload-time = "2025-05-07T11:42:49.884Z" }, - { url = "https://files.pythonhosted.org/packages/eb/af/9dcc146e3693aec8ad52505ee3303c495d6e8faaa8c17e20082109e1c3cd/kornia_rs-0.1.9-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:8bb14f89bd999d5cd5bf5c187d2f25f63b3134676da146eb579023303e9ea2a3", size = 2304661, upload-time = "2025-05-07T11:42:39.059Z" }, - { url = "https://files.pythonhosted.org/packages/e6/49/e8c3865c856c3e95d7b97d8070e14c685fc2eaea9d22787da3a94e6f6d35/kornia_rs-0.1.9-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:d545c3f323d37745228681a71b577e88468d54b965e2194c0e346bb0a969c5f3", size = 2487276, upload-time = "2025-05-07T11:42:06.603Z" }, - { url = "https://files.pythonhosted.org/packages/e9/af/459207ad974d4b0540ff949d0fe2f6197eca905dc4db15b58a230ad5c902/kornia_rs-0.1.9-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:ba36918487a6c9f3b8914562fa94011b82fc4fa822b626763babaf3669aaece1", size = 2759368, upload-time = "2025-05-07T11:42:24.373Z" }, - { url = "https://files.pythonhosted.org/packages/77/81/53c882f3b93474a025302aead72b361128a0620dd629a17c86408fadfe31/kornia_rs-0.1.9-cp310-cp310-win_amd64.whl", hash = "sha256:511d0487c853792f816c3a8bc8edbd550fe9160c6de0a22423c2161fac29d814", size = 2276544, upload-time = "2025-05-07T11:43:02.4Z" }, - { url = "https://files.pythonhosted.org/packages/b6/60/7f514359f49514c3f798702425877ac64a278c65775067d6530766b2deda/kornia_rs-0.1.9-cp311-cp311-macosx_10_12_x86_64.whl", hash = "sha256:a0f45987702e816f34bc0fcac253c504932d8ca877c9ab644d8445e7de737aec", size = 2562384, upload-time = "2025-05-07T11:42:51.247Z" }, - { url = "https://files.pythonhosted.org/packages/d6/4d/21d75004dfdef346292b460119a3fab3668c4df38df6a5ffb2058283d16f/kornia_rs-0.1.9-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:9bb863f3ff42919749b7db4a56f2adb076a10d3c57907305898c72e643fa3d5d", size = 2304921, upload-time = "2025-05-07T11:42:40.327Z" }, - { url = "https://files.pythonhosted.org/packages/b0/ea/e0b14d6d1c6dcefaeacde37d1c2ef5098486e0d5de455e5e18e1063bf72d/kornia_rs-0.1.9-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:54604bc8eb7d4d703eac19963378b4d6a72432a3f0da765edb1b0396d10def01", size = 2487791, upload-time = "2025-05-07T11:42:09.799Z" }, - { url = "https://files.pythonhosted.org/packages/1c/5a/5969a793c1b2b0d9027b2f813ecadb568be3d319abe299df4f8e47ec7707/kornia_rs-0.1.9-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:6cdda9133297c4cff2c2c54be44d5c39bce715306d0bccb8ab1fae7c0dc7cf63", size = 2759632, upload-time = "2025-05-07T11:42:26.042Z" }, - { url = "https://files.pythonhosted.org/packages/e2/59/5cad0e8562417ed54799fc72081c3ee6c63adc3e0d56b2c6b1fd2a1acb13/kornia_rs-0.1.9-cp311-cp311-win_amd64.whl", hash = "sha256:689929d8dab80928feedbcdc2375060a3fe02b32fbf0dba12ae3fefb605fd089", size = 2276410, upload-time = "2025-05-07T11:43:03.628Z" }, - { url = "https://files.pythonhosted.org/packages/ed/50/2f467cd49f47d6036f1199edc6145ba3f0a6729916c310451e1257baa13c/kornia_rs-0.1.9-cp312-cp312-macosx_10_12_x86_64.whl", hash = "sha256:889b4121f830d8827260f0246554f8bd722137d98db0bf3c2b0f5b1812cf5c63", size = 2554172, upload-time = "2025-05-07T11:42:53.018Z" }, - { url = "https://files.pythonhosted.org/packages/e7/35/2eafb7923b4d5582f1c79ac0237195e030f9c460651b48d39dea96b5a627/kornia_rs-0.1.9-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:a0834f6aa44a35b486fe9802516dde24ec5d8b3b51563f18b488098062074671", size = 2299529, upload-time = "2025-05-07T11:42:41.587Z" }, - { url = "https://files.pythonhosted.org/packages/7c/d0/549ccabae5fe59256a4c749e78f844d4bdc17fda87d3fbe813fc8f430055/kornia_rs-0.1.9-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:8e52ead233c9d0b924eee4b906f26f32fde1e236a30723525dfb2b1a610bd48b", size = 2486013, upload-time = "2025-05-07T11:42:11.569Z" }, - { url = "https://files.pythonhosted.org/packages/37/43/fd431c4278101dd25c44ae4c04166905671280f3d6b50d28dc062df544dc/kornia_rs-0.1.9-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:e74a8901843e8e5e47f495927462288c7b7b8dc8a253495051c72a5fbda5f664", size = 2760478, upload-time = "2025-05-07T11:42:27.525Z" }, - { url = "https://files.pythonhosted.org/packages/2f/f1/be747ef1b553950cdce6e63a2031e9b55ba3a793d2a8dd506cfcc9a83d10/kornia_rs-0.1.9-cp312-cp312-win_amd64.whl", hash = "sha256:fdfe0baa04800e541425730d03f3b3d217a1a6f0303926889b443b4562c0fda5", size = 2276689, upload-time = "2025-05-07T11:43:04.878Z" }, - { url = "https://files.pythonhosted.org/packages/ad/12/83ebd43c8fb42d5ad1e66ce66af9c80e9b99e95758f7b0b1ceb8be8eebde/kornia_rs-0.1.9-cp313-cp313-macosx_10_12_x86_64.whl", hash = "sha256:e82f5d90ad5b3d02d28535d19bf612e25ca559003d56fad1d12cd173be5d8418", size = 2554277, upload-time = "2025-05-07T11:42:54.354Z" }, - { url = "https://files.pythonhosted.org/packages/6b/b3/d61868697048f92df3b1ca0fbee791b92c305ba7fae3755521d44dd9ffe1/kornia_rs-0.1.9-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:876f0805ed8d05bd94d6b9a6c43161cdc74bc5c4508f5b737d6975d1dcf9016d", size = 2299896, upload-time = "2025-05-07T11:42:42.859Z" }, - { url = "https://files.pythonhosted.org/packages/98/3a/5f37388ed4fae3f34702e1af25398cdd7c071b4bb250f780e7a2a6378e70/kornia_rs-0.1.9-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:00021bb1941766e1e9e8c2cdbebcf33a08f8de3586e6efc791b9580a7e52b5ed", size = 2486072, upload-time = "2025-05-07T11:42:14.6Z" }, - { url = "https://files.pythonhosted.org/packages/c3/d8/a286db51c1269f632b3e4fdb08cb7319476dbe576796be19fdfbdfd4df1c/kornia_rs-0.1.9-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:9feaa6d410bc4d0609f3c1f2c0c010743706c2f5eed6f5ded10f2b8fec32acdf", size = 2760634, upload-time = "2025-05-07T11:42:28.998Z" }, - { url = "https://files.pythonhosted.org/packages/9a/6f/c3d7da7a06b71a1eb1eb017a1944bcdc9504ef5cdbb0e3345aceabd24b7a/kornia_rs-0.1.9-cp313-cp313-win_amd64.whl", hash = "sha256:4d063e9d74d2b198f080940cd1679cfb66004cd59bb7cc20e0bcf5874ce3d200", size = 2276574, upload-time = "2025-05-07T11:43:06.117Z" }, - { url = "https://files.pythonhosted.org/packages/46/0d/09cb9deeac45e1ac89aacfa1a9417eba3a27015282ca841f4df197e727b2/kornia_rs-0.1.9-cp313-cp313t-macosx_10_12_x86_64.whl", hash = "sha256:f8d03da3dba89fd290f4df012f49262cde128e3682632b5c498b34909d875190", size = 2555142, upload-time = "2025-05-07T11:42:56.093Z" }, - { url = "https://files.pythonhosted.org/packages/db/88/679db8feae7e2ad19317aaef84d6ff2129a37c601b47012ff67041daf7e3/kornia_rs-0.1.9-cp313-cp313t-macosx_11_0_arm64.whl", hash = "sha256:cef15e7db4cd05ebedc25cd62616c38346f71f7e8a2fb751feacc8726e7e417e", size = 2301310, upload-time = "2025-05-07T11:42:44.105Z" }, - { url = "https://files.pythonhosted.org/packages/19/58/1ba746ac8a8a25d30bf3205c59b7a008dbcbe95533d21a33ad9097afe56d/kornia_rs-0.1.9-cp313-cp313t-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:0d6ea40aa2027f62e90c590112fc4be4a787092359ed041479d2b015c0483c97", size = 2487761, upload-time = "2025-05-07T11:42:16.59Z" }, - { url = "https://files.pythonhosted.org/packages/0c/53/84462d5aaf0ad52cb30791d38e144ce8a79519c201ff204f903d54f1dd46/kornia_rs-0.1.9-cp313-cp313t-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:e9282a70c9e81710f04fdb23617c73191324ccc070c7f96d62efb5bf66dc242a", size = 2758585, upload-time = "2025-05-07T11:42:30.465Z" }, - { url = "https://files.pythonhosted.org/packages/5e/51/755dda17b63604816a34ee3b9336d1c6ccb54f3e9bcbc8aafd98412fcb8f/kornia_rs-0.1.9-cp313-cp313t-win_amd64.whl", hash = "sha256:cd6b9860ca2fd6103340f4f977f74fa96562d89563e36c00059f2d96c7cea464", size = 2275851, upload-time = "2025-05-07T11:43:07.424Z" }, -] - -[[package]] -name = "lazy-loader" -version = "0.4" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "packaging" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/6f/6b/c875b30a1ba490860c93da4cabf479e03f584eba06fe5963f6f6644653d8/lazy_loader-0.4.tar.gz", hash = "sha256:47c75182589b91a4e1a85a136c074285a5ad4d9f39c63e0d7fb76391c4574cd1", size = 15431, upload-time = "2024-04-05T13:03:12.261Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/83/60/d497a310bde3f01cb805196ac61b7ad6dc5dcf8dce66634dc34364b20b4f/lazy_loader-0.4-py3-none-any.whl", hash = "sha256:342aa8e14d543a154047afb4ba8ef17f5563baad3fc610d7b15b213b0f119efc", size = 12097, upload-time = "2024-04-05T13:03:10.514Z" }, -] - -[[package]] -name = "lazy-object-proxy" -version = "1.11.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/57/f9/1f56571ed82fb324f293661690635cf42c41deb8a70a6c9e6edc3e9bb3c8/lazy_object_proxy-1.11.0.tar.gz", hash = "sha256:18874411864c9fbbbaa47f9fc1dd7aea754c86cfde21278ef427639d1dd78e9c", size = 44736, upload-time = "2025-04-16T16:53:48.482Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/21/c8/457f1555f066f5bacc44337141294153dc993b5e9132272ab54a64ee98a2/lazy_object_proxy-1.11.0-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:132bc8a34f2f2d662a851acfd1b93df769992ed1b81e2b1fda7db3e73b0d5a18", size = 28045, upload-time = "2025-04-16T16:53:32.314Z" }, - { url = "https://files.pythonhosted.org/packages/18/33/3260b4f8de6f0942008479fee6950b2b40af11fc37dba23aa3672b0ce8a6/lazy_object_proxy-1.11.0-cp310-cp310-win_amd64.whl", hash = "sha256:01261a3afd8621a1accb5682df2593dc7ec7d21d38f411011a5712dcd418fbed", size = 28441, upload-time = "2025-04-16T16:53:33.636Z" }, - { url = "https://files.pythonhosted.org/packages/51/f6/eb645ca1ff7408bb69e9b1fe692cce1d74394efdbb40d6207096c0cd8381/lazy_object_proxy-1.11.0-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:090935756cc041e191f22f4f9c7fd4fe9a454717067adf5b1bbd2ce3046b556e", size = 28047, upload-time = "2025-04-16T16:53:34.679Z" }, - { url = "https://files.pythonhosted.org/packages/13/9c/aabbe1e8b99b8b0edb846b49a517edd636355ac97364419d9ba05b8fa19f/lazy_object_proxy-1.11.0-cp311-cp311-win_amd64.whl", hash = "sha256:76ec715017f06410f57df442c1a8d66e6b5f7035077785b129817f5ae58810a4", size = 28440, upload-time = "2025-04-16T16:53:36.113Z" }, - { url = "https://files.pythonhosted.org/packages/4d/24/dae4759469e9cd318fef145f7cfac7318261b47b23a4701aa477b0c3b42c/lazy_object_proxy-1.11.0-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:9a9f39098e93a63618a79eef2889ae3cf0605f676cd4797fdfd49fcd7ddc318b", size = 28142, upload-time = "2025-04-16T16:53:37.663Z" }, - { url = "https://files.pythonhosted.org/packages/de/0c/645a881f5f27952a02f24584d96f9f326748be06ded2cee25f8f8d1cd196/lazy_object_proxy-1.11.0-cp312-cp312-win_amd64.whl", hash = "sha256:ee13f67f4fcd044ef27bfccb1c93d39c100046fec1fad6e9a1fcdfd17492aeb3", size = 28380, upload-time = "2025-04-16T16:53:39.07Z" }, - { url = "https://files.pythonhosted.org/packages/a8/0f/6e004f928f7ff5abae2b8e1f68835a3870252f886e006267702e1efc5c7b/lazy_object_proxy-1.11.0-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:fd4c84eafd8dd15ea16f7d580758bc5c2ce1f752faec877bb2b1f9f827c329cd", size = 28149, upload-time = "2025-04-16T16:53:40.135Z" }, - { url = "https://files.pythonhosted.org/packages/63/cb/b8363110e32cc1fd82dc91296315f775d37a39df1c1cfa976ec1803dac89/lazy_object_proxy-1.11.0-cp313-cp313-win_amd64.whl", hash = "sha256:d2503427bda552d3aefcac92f81d9e7ca631e680a2268cbe62cd6a58de6409b7", size = 28389, upload-time = "2025-04-16T16:53:43.612Z" }, - { url = "https://files.pythonhosted.org/packages/7b/89/68c50fcfd81e11480cd8ee7f654c9bd790a9053b9a0efe9983d46106f6a9/lazy_object_proxy-1.11.0-cp313-cp313t-macosx_11_0_arm64.whl", hash = "sha256:0613116156801ab3fccb9e2b05ed83b08ea08c2517fdc6c6bc0d4697a1a376e3", size = 28777, upload-time = "2025-04-16T16:53:41.371Z" }, - { url = "https://files.pythonhosted.org/packages/39/d0/7e967689e24de8ea6368ec33295f9abc94b9f3f0cd4571bfe148dc432190/lazy_object_proxy-1.11.0-cp313-cp313t-win_amd64.whl", hash = "sha256:bb03c507d96b65f617a6337dedd604399d35face2cdf01526b913fb50c4cb6e8", size = 29598, upload-time = "2025-04-16T16:53:42.513Z" }, - { url = "https://files.pythonhosted.org/packages/e7/1e/fb441c07b6662ec1fc92b249225ba6e6e5221b05623cb0131d082f782edc/lazy_object_proxy-1.11.0-py3-none-any.whl", hash = "sha256:a56a5093d433341ff7da0e89f9b486031ccd222ec8e52ec84d0ec1cdc819674b", size = 16635, upload-time = "2025-04-16T16:53:47.198Z" }, -] - -[[package]] -name = "lightning" -version = "2.3.3" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -dependencies = [ - { name = "fsspec", extra = ["http"], marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "lightning-utilities", marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version >= '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "packaging", marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "pytorch-lightning", version = "2.3.3", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "pyyaml", marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.0.1", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchmetrics", marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "tqdm", marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "typing-extensions", marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/83/a9/dddaad0bc8b93aa9eec78033ab0d241058f137380483b4142d9de2ae7eea/lightning-2.3.3.tar.gz", hash = "sha256:7f454711895c1c6e455766f01fa39522e25e5ab54c15c5e5fbad342fa92bc93c", size = 618513, upload-time = "2024-07-08T20:47:57.63Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/8c/31/bb00abd336f2e635d8a49ea9e80a82981e364d6cd91738aeeef99ab2ed0a/lightning-2.3.3-py3-none-any.whl", hash = "sha256:5b4950f20b5117f30aad7820709cfa56669567cf4ded93df502b3dee443a6a5d", size = 808454, upload-time = "2024-07-08T20:47:54.133Z" }, -] - -[[package]] -name = "lightning" -version = "2.5.1.post0" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", -] -dependencies = [ - { name = "fsspec", extra = ["http"], marker = "(platform_machine == 'aarch64' and sys_platform == 'linux') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra != 'extra-7-comfyui-rocm') or sys_platform == 'Linux' or sys_platform == 'darwin' or sys_platform == 'win32' or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra != 'extra-7-comfyui-rocm')" }, - { name = "lightning-utilities", marker = "(platform_machine == 'aarch64' and sys_platform == 'linux') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra != 'extra-7-comfyui-rocm') or sys_platform == 'Linux' or sys_platform == 'darwin' or sys_platform == 'win32' or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra != 'extra-7-comfyui-rocm')" }, - { name = "packaging", marker = "(platform_machine == 'aarch64' and sys_platform == 'linux') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra != 'extra-7-comfyui-rocm') or sys_platform == 'Linux' or sys_platform == 'darwin' or sys_platform == 'win32' or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra != 'extra-7-comfyui-rocm')" }, - { name = "pytorch-lightning", version = "2.3.3", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "pytorch-lightning", version = "2.5.1.post0", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or sys_platform == 'Linux' or sys_platform == 'darwin' or sys_platform == 'win32' or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "pyyaml", marker = "(platform_machine == 'aarch64' and sys_platform == 'linux') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra != 'extra-7-comfyui-rocm') or sys_platform == 'Linux' or sys_platform == 'darwin' or sys_platform == 'win32' or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra != 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://pypi.org/simple" }, marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" }, marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "extra == 'extra-7-comfyui-cu128' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchmetrics", marker = "(platform_machine == 'aarch64' and sys_platform == 'linux') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra != 'extra-7-comfyui-rocm') or sys_platform == 'Linux' or sys_platform == 'darwin' or sys_platform == 'win32' or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra != 'extra-7-comfyui-rocm')" }, - { name = "tqdm", marker = "(platform_machine == 'aarch64' and sys_platform == 'linux') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra != 'extra-7-comfyui-rocm') or sys_platform == 'Linux' or sys_platform == 'darwin' or sys_platform == 'win32' or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra != 'extra-7-comfyui-rocm')" }, - { name = "typing-extensions", marker = "(platform_machine == 'aarch64' and sys_platform == 'linux') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra != 'extra-7-comfyui-rocm') or sys_platform == 'Linux' or sys_platform == 'darwin' or sys_platform == 'win32' or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra != 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/97/d0/fb3c5077efdd74c28ea3a277fd80bbf03738d866013a8637691138bfebca/lightning-2.5.1.post0.tar.gz", hash = "sha256:fda1ac63c283b3b08a54be8d905dd88469cf09e9845d36dd28b699e78911cbc8", size = 631113, upload-time = "2025-04-25T20:24:25.054Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/9e/1b/67201d693a575e8a086831710f33e697fab66166223f792e459ef2b84934/lightning-2.5.1.post0-py3-none-any.whl", hash = "sha256:a228a52ca52f0c5006ff327c92b8942f09e1aea3f2d9b0d7c8a209edd5b9e71d", size = 819001, upload-time = "2025-04-25T20:24:21.212Z" }, -] - -[[package]] -name = "lightning-utilities" -version = "0.14.3" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "packaging" }, - { name = "setuptools" }, - { name = "typing-extensions" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/0f/bb/63a6a8c9e7a96b6ba92647fa5b1595c2dbee29f8178705adb4704d82ecba/lightning_utilities-0.14.3.tar.gz", hash = "sha256:37e2f83f273890052955a44054382c211a303012ee577619efbaa5df9e65e9f5", size = 30346, upload-time = "2025-04-03T15:59:56.928Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/1a/c1/31b3184cba7b257a4a3b5ca5b88b9204ccb7aa02fe3c992280899293ed54/lightning_utilities-0.14.3-py3-none-any.whl", hash = "sha256:4ab9066aa36cd7b93a05713808901909e96cc3f187ea6fd3052b2fd91313b468", size = 28894, upload-time = "2025-04-03T15:59:55.658Z" }, -] - -[[package]] -name = "lit" -version = "18.1.8" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/47/b4/d7e210971494db7b9a9ac48ff37dfa59a8b14c773f9cf47e6bda58411c0d/lit-18.1.8.tar.gz", hash = "sha256:47c174a186941ae830f04ded76a3444600be67d5e5fb8282c3783fba671c4edb", size = 161127, upload-time = "2024-06-25T14:33:14.489Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/96/06/b36f150fa7c5bcc96a31a4d19a20fddbd1d965b6f02510b57a3bb8d4b930/lit-18.1.8-py3-none-any.whl", hash = "sha256:a873ff7acd76e746368da32eb7355625e2e55a2baaab884c9cc130f2ee0300f7", size = 96365, upload-time = "2024-06-25T14:33:12.101Z" }, -] - -[[package]] -name = "macholib" -version = "1.16.3" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "altgraph", marker = "sys_platform == 'darwin' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/95/ee/af1a3842bdd5902ce133bd246eb7ffd4375c38642aeb5dc0ae3a0329dfa2/macholib-1.16.3.tar.gz", hash = "sha256:07ae9e15e8e4cd9a788013d81f5908b3609aa76f9b1421bae9c4d7606ec86a30", size = 59309, upload-time = "2023-09-25T09:10:16.155Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/d1/5d/c059c180c84f7962db0aeae7c3b9303ed1d73d76f2bfbc32bc231c8be314/macholib-1.16.3-py2.py3-none-any.whl", hash = "sha256:0e315d7583d38b8c77e815b1ecbdbf504a8258d8b3e17b61165c6feb60d18f2c", size = 38094, upload-time = "2023-09-25T09:10:14.188Z" }, -] - -[[package]] -name = "mako" -version = "1.3.10" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "markupsafe" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/9e/38/bd5b78a920a64d708fe6bc8e0a2c075e1389d53bef8413725c63ba041535/mako-1.3.10.tar.gz", hash = "sha256:99579a6f39583fa7e5630a28c3c1f440e4e97a414b80372649c0ce338da2ea28", size = 392474, upload-time = "2025-04-10T12:44:31.16Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/87/fb/99f81ac72ae23375f22b7afdb7642aba97c00a713c217124420147681a2f/mako-1.3.10-py3-none-any.whl", hash = "sha256:baef24a52fc4fc514a0887ac600f9f1cff3d82c61d4d700a1fa84d597b88db59", size = 78509, upload-time = "2025-04-10T12:50:53.297Z" }, -] - -[[package]] -name = "markdown-it-py" -version = "3.0.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "mdurl" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/38/71/3b932df36c1a044d397a1f92d1cf91ee0a503d91e470cbd670aa66b07ed0/markdown-it-py-3.0.0.tar.gz", hash = "sha256:e3f60a94fa066dc52ec76661e37c851cb232d92f9886b15cb560aaada2df8feb", size = 74596, upload-time = "2023-06-03T06:41:14.443Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/42/d7/1ec15b46af6af88f19b8e5ffea08fa375d433c998b8a7639e76935c14f1f/markdown_it_py-3.0.0-py3-none-any.whl", hash = "sha256:355216845c60bd96232cd8d8c40e8f9765cc86f46880e43a8fd22dc1a1a8cab1", size = 87528, upload-time = "2023-06-03T06:41:11.019Z" }, -] - -[[package]] -name = "markupsafe" -version = "3.0.2" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/b2/97/5d42485e71dfc078108a86d6de8fa46db44a1a9295e89c5d6d4a06e23a62/markupsafe-3.0.2.tar.gz", hash = "sha256:ee55d3edf80167e48ea11a923c7386f4669df67d7994554387f84e7d8b0a2bf0", size = 20537, upload-time = "2024-10-18T15:21:54.129Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/04/90/d08277ce111dd22f77149fd1a5d4653eeb3b3eaacbdfcbae5afb2600eebd/MarkupSafe-3.0.2-cp310-cp310-macosx_10_9_universal2.whl", hash = "sha256:7e94c425039cde14257288fd61dcfb01963e658efbc0ff54f5306b06054700f8", size = 14357, upload-time = "2024-10-18T15:20:51.44Z" }, - { url = "https://files.pythonhosted.org/packages/04/e1/6e2194baeae0bca1fae6629dc0cbbb968d4d941469cbab11a3872edff374/MarkupSafe-3.0.2-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:9e2d922824181480953426608b81967de705c3cef4d1af983af849d7bd619158", size = 12393, upload-time = "2024-10-18T15:20:52.426Z" }, - { url = "https://files.pythonhosted.org/packages/1d/69/35fa85a8ece0a437493dc61ce0bb6d459dcba482c34197e3efc829aa357f/MarkupSafe-3.0.2-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:38a9ef736c01fccdd6600705b09dc574584b89bea478200c5fbf112a6b0d5579", size = 21732, upload-time = "2024-10-18T15:20:53.578Z" }, - { url = "https://files.pythonhosted.org/packages/22/35/137da042dfb4720b638d2937c38a9c2df83fe32d20e8c8f3185dbfef05f7/MarkupSafe-3.0.2-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:bbcb445fa71794da8f178f0f6d66789a28d7319071af7a496d4d507ed566270d", size = 20866, upload-time = "2024-10-18T15:20:55.06Z" }, - { url = "https://files.pythonhosted.org/packages/29/28/6d029a903727a1b62edb51863232152fd335d602def598dade38996887f0/MarkupSafe-3.0.2-cp310-cp310-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:57cb5a3cf367aeb1d316576250f65edec5bb3be939e9247ae594b4bcbc317dfb", size = 20964, upload-time = "2024-10-18T15:20:55.906Z" }, - { url = "https://files.pythonhosted.org/packages/cc/cd/07438f95f83e8bc028279909d9c9bd39e24149b0d60053a97b2bc4f8aa51/MarkupSafe-3.0.2-cp310-cp310-musllinux_1_2_aarch64.whl", hash = "sha256:3809ede931876f5b2ec92eef964286840ed3540dadf803dd570c3b7e13141a3b", size = 21977, upload-time = "2024-10-18T15:20:57.189Z" }, - { url = "https://files.pythonhosted.org/packages/29/01/84b57395b4cc062f9c4c55ce0df7d3108ca32397299d9df00fedd9117d3d/MarkupSafe-3.0.2-cp310-cp310-musllinux_1_2_i686.whl", hash = "sha256:e07c3764494e3776c602c1e78e298937c3315ccc9043ead7e685b7f2b8d47b3c", size = 21366, upload-time = "2024-10-18T15:20:58.235Z" }, - { url = "https://files.pythonhosted.org/packages/bd/6e/61ebf08d8940553afff20d1fb1ba7294b6f8d279df9fd0c0db911b4bbcfd/MarkupSafe-3.0.2-cp310-cp310-musllinux_1_2_x86_64.whl", hash = "sha256:b424c77b206d63d500bcb69fa55ed8d0e6a3774056bdc4839fc9298a7edca171", size = 21091, upload-time = "2024-10-18T15:20:59.235Z" }, - { url = "https://files.pythonhosted.org/packages/11/23/ffbf53694e8c94ebd1e7e491de185124277964344733c45481f32ede2499/MarkupSafe-3.0.2-cp310-cp310-win32.whl", hash = "sha256:fcabf5ff6eea076f859677f5f0b6b5c1a51e70a376b0579e0eadef8db48c6b50", size = 15065, upload-time = "2024-10-18T15:21:00.307Z" }, - { url = "https://files.pythonhosted.org/packages/44/06/e7175d06dd6e9172d4a69a72592cb3f7a996a9c396eee29082826449bbc3/MarkupSafe-3.0.2-cp310-cp310-win_amd64.whl", hash = "sha256:6af100e168aa82a50e186c82875a5893c5597a0c1ccdb0d8b40240b1f28b969a", size = 15514, upload-time = "2024-10-18T15:21:01.122Z" }, - { url = "https://files.pythonhosted.org/packages/6b/28/bbf83e3f76936960b850435576dd5e67034e200469571be53f69174a2dfd/MarkupSafe-3.0.2-cp311-cp311-macosx_10_9_universal2.whl", hash = "sha256:9025b4018f3a1314059769c7bf15441064b2207cb3f065e6ea1e7359cb46db9d", size = 14353, upload-time = "2024-10-18T15:21:02.187Z" }, - { url = "https://files.pythonhosted.org/packages/6c/30/316d194b093cde57d448a4c3209f22e3046c5bb2fb0820b118292b334be7/MarkupSafe-3.0.2-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:93335ca3812df2f366e80509ae119189886b0f3c2b81325d39efdb84a1e2ae93", size = 12392, upload-time = "2024-10-18T15:21:02.941Z" }, - { url = "https://files.pythonhosted.org/packages/f2/96/9cdafba8445d3a53cae530aaf83c38ec64c4d5427d975c974084af5bc5d2/MarkupSafe-3.0.2-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:2cb8438c3cbb25e220c2ab33bb226559e7afb3baec11c4f218ffa7308603c832", size = 23984, upload-time = "2024-10-18T15:21:03.953Z" }, - { url = "https://files.pythonhosted.org/packages/f1/a4/aefb044a2cd8d7334c8a47d3fb2c9f328ac48cb349468cc31c20b539305f/MarkupSafe-3.0.2-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:a123e330ef0853c6e822384873bef7507557d8e4a082961e1defa947aa59ba84", size = 23120, upload-time = "2024-10-18T15:21:06.495Z" }, - { url = "https://files.pythonhosted.org/packages/8d/21/5e4851379f88f3fad1de30361db501300d4f07bcad047d3cb0449fc51f8c/MarkupSafe-3.0.2-cp311-cp311-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:1e084f686b92e5b83186b07e8a17fc09e38fff551f3602b249881fec658d3eca", size = 23032, upload-time = "2024-10-18T15:21:07.295Z" }, - { url = "https://files.pythonhosted.org/packages/00/7b/e92c64e079b2d0d7ddf69899c98842f3f9a60a1ae72657c89ce2655c999d/MarkupSafe-3.0.2-cp311-cp311-musllinux_1_2_aarch64.whl", hash = "sha256:d8213e09c917a951de9d09ecee036d5c7d36cb6cb7dbaece4c71a60d79fb9798", size = 24057, upload-time = "2024-10-18T15:21:08.073Z" }, - { url = "https://files.pythonhosted.org/packages/f9/ac/46f960ca323037caa0a10662ef97d0a4728e890334fc156b9f9e52bcc4ca/MarkupSafe-3.0.2-cp311-cp311-musllinux_1_2_i686.whl", hash = "sha256:5b02fb34468b6aaa40dfc198d813a641e3a63b98c2b05a16b9f80b7ec314185e", size = 23359, upload-time = "2024-10-18T15:21:09.318Z" }, - { url = "https://files.pythonhosted.org/packages/69/84/83439e16197337b8b14b6a5b9c2105fff81d42c2a7c5b58ac7b62ee2c3b1/MarkupSafe-3.0.2-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:0bff5e0ae4ef2e1ae4fdf2dfd5b76c75e5c2fa4132d05fc1b0dabcd20c7e28c4", size = 23306, upload-time = "2024-10-18T15:21:10.185Z" }, - { url = "https://files.pythonhosted.org/packages/9a/34/a15aa69f01e2181ed8d2b685c0d2f6655d5cca2c4db0ddea775e631918cd/MarkupSafe-3.0.2-cp311-cp311-win32.whl", hash = "sha256:6c89876f41da747c8d3677a2b540fb32ef5715f97b66eeb0c6b66f5e3ef6f59d", size = 15094, upload-time = "2024-10-18T15:21:11.005Z" }, - { url = "https://files.pythonhosted.org/packages/da/b8/3a3bd761922d416f3dc5d00bfbed11f66b1ab89a0c2b6e887240a30b0f6b/MarkupSafe-3.0.2-cp311-cp311-win_amd64.whl", hash = "sha256:70a87b411535ccad5ef2f1df5136506a10775d267e197e4cf531ced10537bd6b", size = 15521, upload-time = "2024-10-18T15:21:12.911Z" }, - { url = "https://files.pythonhosted.org/packages/22/09/d1f21434c97fc42f09d290cbb6350d44eb12f09cc62c9476effdb33a18aa/MarkupSafe-3.0.2-cp312-cp312-macosx_10_13_universal2.whl", hash = "sha256:9778bd8ab0a994ebf6f84c2b949e65736d5575320a17ae8984a77fab08db94cf", size = 14274, upload-time = "2024-10-18T15:21:13.777Z" }, - { url = "https://files.pythonhosted.org/packages/6b/b0/18f76bba336fa5aecf79d45dcd6c806c280ec44538b3c13671d49099fdd0/MarkupSafe-3.0.2-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:846ade7b71e3536c4e56b386c2a47adf5741d2d8b94ec9dc3e92e5e1ee1e2225", size = 12348, upload-time = "2024-10-18T15:21:14.822Z" }, - { url = "https://files.pythonhosted.org/packages/e0/25/dd5c0f6ac1311e9b40f4af06c78efde0f3b5cbf02502f8ef9501294c425b/MarkupSafe-3.0.2-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:1c99d261bd2d5f6b59325c92c73df481e05e57f19837bdca8413b9eac4bd8028", size = 24149, upload-time = "2024-10-18T15:21:15.642Z" }, - { url = "https://files.pythonhosted.org/packages/f3/f0/89e7aadfb3749d0f52234a0c8c7867877876e0a20b60e2188e9850794c17/MarkupSafe-3.0.2-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:e17c96c14e19278594aa4841ec148115f9c7615a47382ecb6b82bd8fea3ab0c8", size = 23118, upload-time = "2024-10-18T15:21:17.133Z" }, - { url = "https://files.pythonhosted.org/packages/d5/da/f2eeb64c723f5e3777bc081da884b414671982008c47dcc1873d81f625b6/MarkupSafe-3.0.2-cp312-cp312-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:88416bd1e65dcea10bc7569faacb2c20ce071dd1f87539ca2ab364bf6231393c", size = 22993, upload-time = "2024-10-18T15:21:18.064Z" }, - { url = "https://files.pythonhosted.org/packages/da/0e/1f32af846df486dce7c227fe0f2398dc7e2e51d4a370508281f3c1c5cddc/MarkupSafe-3.0.2-cp312-cp312-musllinux_1_2_aarch64.whl", hash = "sha256:2181e67807fc2fa785d0592dc2d6206c019b9502410671cc905d132a92866557", size = 24178, upload-time = "2024-10-18T15:21:18.859Z" }, - { url = "https://files.pythonhosted.org/packages/c4/f6/bb3ca0532de8086cbff5f06d137064c8410d10779c4c127e0e47d17c0b71/MarkupSafe-3.0.2-cp312-cp312-musllinux_1_2_i686.whl", hash = "sha256:52305740fe773d09cffb16f8ed0427942901f00adedac82ec8b67752f58a1b22", size = 23319, upload-time = "2024-10-18T15:21:19.671Z" }, - { url = "https://files.pythonhosted.org/packages/a2/82/8be4c96ffee03c5b4a034e60a31294daf481e12c7c43ab8e34a1453ee48b/MarkupSafe-3.0.2-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:ad10d3ded218f1039f11a75f8091880239651b52e9bb592ca27de44eed242a48", size = 23352, upload-time = "2024-10-18T15:21:20.971Z" }, - { url = "https://files.pythonhosted.org/packages/51/ae/97827349d3fcffee7e184bdf7f41cd6b88d9919c80f0263ba7acd1bbcb18/MarkupSafe-3.0.2-cp312-cp312-win32.whl", hash = "sha256:0f4ca02bea9a23221c0182836703cbf8930c5e9454bacce27e767509fa286a30", size = 15097, upload-time = "2024-10-18T15:21:22.646Z" }, - { url = "https://files.pythonhosted.org/packages/c1/80/a61f99dc3a936413c3ee4e1eecac96c0da5ed07ad56fd975f1a9da5bc630/MarkupSafe-3.0.2-cp312-cp312-win_amd64.whl", hash = "sha256:8e06879fc22a25ca47312fbe7c8264eb0b662f6db27cb2d3bbbc74b1df4b9b87", size = 15601, upload-time = "2024-10-18T15:21:23.499Z" }, - { url = "https://files.pythonhosted.org/packages/83/0e/67eb10a7ecc77a0c2bbe2b0235765b98d164d81600746914bebada795e97/MarkupSafe-3.0.2-cp313-cp313-macosx_10_13_universal2.whl", hash = "sha256:ba9527cdd4c926ed0760bc301f6728ef34d841f405abf9d4f959c478421e4efd", size = 14274, upload-time = "2024-10-18T15:21:24.577Z" }, - { url = "https://files.pythonhosted.org/packages/2b/6d/9409f3684d3335375d04e5f05744dfe7e9f120062c9857df4ab490a1031a/MarkupSafe-3.0.2-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:f8b3d067f2e40fe93e1ccdd6b2e1d16c43140e76f02fb1319a05cf2b79d99430", size = 12352, upload-time = "2024-10-18T15:21:25.382Z" }, - { url = "https://files.pythonhosted.org/packages/d2/f5/6eadfcd3885ea85fe2a7c128315cc1bb7241e1987443d78c8fe712d03091/MarkupSafe-3.0.2-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:569511d3b58c8791ab4c2e1285575265991e6d8f8700c7be0e88f86cb0672094", size = 24122, upload-time = "2024-10-18T15:21:26.199Z" }, - { url = "https://files.pythonhosted.org/packages/0c/91/96cf928db8236f1bfab6ce15ad070dfdd02ed88261c2afafd4b43575e9e9/MarkupSafe-3.0.2-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:15ab75ef81add55874e7ab7055e9c397312385bd9ced94920f2802310c930396", size = 23085, upload-time = "2024-10-18T15:21:27.029Z" }, - { url = "https://files.pythonhosted.org/packages/c2/cf/c9d56af24d56ea04daae7ac0940232d31d5a8354f2b457c6d856b2057d69/MarkupSafe-3.0.2-cp313-cp313-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:f3818cb119498c0678015754eba762e0d61e5b52d34c8b13d770f0719f7b1d79", size = 22978, upload-time = "2024-10-18T15:21:27.846Z" }, - { url = "https://files.pythonhosted.org/packages/2a/9f/8619835cd6a711d6272d62abb78c033bda638fdc54c4e7f4272cf1c0962b/MarkupSafe-3.0.2-cp313-cp313-musllinux_1_2_aarch64.whl", hash = "sha256:cdb82a876c47801bb54a690c5ae105a46b392ac6099881cdfb9f6e95e4014c6a", size = 24208, upload-time = "2024-10-18T15:21:28.744Z" }, - { url = "https://files.pythonhosted.org/packages/f9/bf/176950a1792b2cd2102b8ffeb5133e1ed984547b75db47c25a67d3359f77/MarkupSafe-3.0.2-cp313-cp313-musllinux_1_2_i686.whl", hash = "sha256:cabc348d87e913db6ab4aa100f01b08f481097838bdddf7c7a84b7575b7309ca", size = 23357, upload-time = "2024-10-18T15:21:29.545Z" }, - { url = "https://files.pythonhosted.org/packages/ce/4f/9a02c1d335caabe5c4efb90e1b6e8ee944aa245c1aaaab8e8a618987d816/MarkupSafe-3.0.2-cp313-cp313-musllinux_1_2_x86_64.whl", hash = "sha256:444dcda765c8a838eaae23112db52f1efaf750daddb2d9ca300bcae1039adc5c", size = 23344, upload-time = "2024-10-18T15:21:30.366Z" }, - { url = "https://files.pythonhosted.org/packages/ee/55/c271b57db36f748f0e04a759ace9f8f759ccf22b4960c270c78a394f58be/MarkupSafe-3.0.2-cp313-cp313-win32.whl", hash = "sha256:bcf3e58998965654fdaff38e58584d8937aa3096ab5354d493c77d1fdd66d7a1", size = 15101, upload-time = "2024-10-18T15:21:31.207Z" }, - { url = "https://files.pythonhosted.org/packages/29/88/07df22d2dd4df40aba9f3e402e6dc1b8ee86297dddbad4872bd5e7b0094f/MarkupSafe-3.0.2-cp313-cp313-win_amd64.whl", hash = "sha256:e6a2a455bd412959b57a172ce6328d2dd1f01cb2135efda2e4576e8a23fa3b0f", size = 15603, upload-time = "2024-10-18T15:21:32.032Z" }, - { url = "https://files.pythonhosted.org/packages/62/6a/8b89d24db2d32d433dffcd6a8779159da109842434f1dd2f6e71f32f738c/MarkupSafe-3.0.2-cp313-cp313t-macosx_10_13_universal2.whl", hash = "sha256:b5a6b3ada725cea8a5e634536b1b01c30bcdcd7f9c6fff4151548d5bf6b3a36c", size = 14510, upload-time = "2024-10-18T15:21:33.625Z" }, - { url = "https://files.pythonhosted.org/packages/7a/06/a10f955f70a2e5a9bf78d11a161029d278eeacbd35ef806c3fd17b13060d/MarkupSafe-3.0.2-cp313-cp313t-macosx_11_0_arm64.whl", hash = "sha256:a904af0a6162c73e3edcb969eeeb53a63ceeb5d8cf642fade7d39e7963a22ddb", size = 12486, upload-time = "2024-10-18T15:21:34.611Z" }, - { url = "https://files.pythonhosted.org/packages/34/cf/65d4a571869a1a9078198ca28f39fba5fbb910f952f9dbc5220afff9f5e6/MarkupSafe-3.0.2-cp313-cp313t-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:4aa4e5faecf353ed117801a068ebab7b7e09ffb6e1d5e412dc852e0da018126c", size = 25480, upload-time = "2024-10-18T15:21:35.398Z" }, - { url = "https://files.pythonhosted.org/packages/0c/e3/90e9651924c430b885468b56b3d597cabf6d72be4b24a0acd1fa0e12af67/MarkupSafe-3.0.2-cp313-cp313t-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:c0ef13eaeee5b615fb07c9a7dadb38eac06a0608b41570d8ade51c56539e509d", size = 23914, upload-time = "2024-10-18T15:21:36.231Z" }, - { url = "https://files.pythonhosted.org/packages/66/8c/6c7cf61f95d63bb866db39085150df1f2a5bd3335298f14a66b48e92659c/MarkupSafe-3.0.2-cp313-cp313t-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:d16a81a06776313e817c951135cf7340a3e91e8c1ff2fac444cfd75fffa04afe", size = 23796, upload-time = "2024-10-18T15:21:37.073Z" }, - { url = "https://files.pythonhosted.org/packages/bb/35/cbe9238ec3f47ac9a7c8b3df7a808e7cb50fe149dc7039f5f454b3fba218/MarkupSafe-3.0.2-cp313-cp313t-musllinux_1_2_aarch64.whl", hash = "sha256:6381026f158fdb7c72a168278597a5e3a5222e83ea18f543112b2662a9b699c5", size = 25473, upload-time = "2024-10-18T15:21:37.932Z" }, - { url = "https://files.pythonhosted.org/packages/e6/32/7621a4382488aa283cc05e8984a9c219abad3bca087be9ec77e89939ded9/MarkupSafe-3.0.2-cp313-cp313t-musllinux_1_2_i686.whl", hash = "sha256:3d79d162e7be8f996986c064d1c7c817f6df3a77fe3d6859f6f9e7be4b8c213a", size = 24114, upload-time = "2024-10-18T15:21:39.799Z" }, - { url = "https://files.pythonhosted.org/packages/0d/80/0985960e4b89922cb5a0bac0ed39c5b96cbc1a536a99f30e8c220a996ed9/MarkupSafe-3.0.2-cp313-cp313t-musllinux_1_2_x86_64.whl", hash = "sha256:131a3c7689c85f5ad20f9f6fb1b866f402c445b220c19fe4308c0b147ccd2ad9", size = 24098, upload-time = "2024-10-18T15:21:40.813Z" }, - { url = "https://files.pythonhosted.org/packages/82/78/fedb03c7d5380df2427038ec8d973587e90561b2d90cd472ce9254cf348b/MarkupSafe-3.0.2-cp313-cp313t-win32.whl", hash = "sha256:ba8062ed2cf21c07a9e295d5b8a2a5ce678b913b45fdf68c32d95d6c1291e0b6", size = 15208, upload-time = "2024-10-18T15:21:41.814Z" }, - { url = "https://files.pythonhosted.org/packages/4f/65/6079a46068dfceaeabb5dcad6d674f5f5c61a6fa5673746f42a9f4c233b3/MarkupSafe-3.0.2-cp313-cp313t-win_amd64.whl", hash = "sha256:e444a31f8db13eb18ada366ab3cf45fd4b31e4db1236a4448f68778c1d1a5a2f", size = 15739, upload-time = "2024-10-18T15:21:42.784Z" }, -] - -[[package]] -name = "mccabe" -version = "0.7.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/e7/ff/0ffefdcac38932a54d2b5eed4e0ba8a408f215002cd178ad1df0f2806ff8/mccabe-0.7.0.tar.gz", hash = "sha256:348e0240c33b60bbdf4e523192ef919f28cb2c3d7d5c7794f74009290f236325", size = 9658, upload-time = "2022-01-24T01:14:51.113Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/27/1a/1f68f9ba0c207934b35b86a8ca3aad8395a3d6dd7921c0686e23853ff5a9/mccabe-0.7.0-py2.py3-none-any.whl", hash = "sha256:6c2d30ab6be0e4a46919781807b4f0d834ebdd6c6e3dca0bda5a15f863427b6e", size = 7350, upload-time = "2022-01-24T01:14:49.62Z" }, -] - -[[package]] -name = "mdurl" -version = "0.1.2" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/d6/54/cfe61301667036ec958cb99bd3efefba235e65cdeb9c84d24a8293ba1d90/mdurl-0.1.2.tar.gz", hash = "sha256:bb413d29f5eea38f31dd4754dd7377d4465116fb207585f97bf925588687c1ba", size = 8729, upload-time = "2022-08-14T12:40:10.846Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/b3/38/89ba8ad64ae25be8de66a6d463314cf1eb366222074cfda9ee839c56a4b4/mdurl-0.1.2-py3-none-any.whl", hash = "sha256:84008a41e51615a49fc9966191ff91509e3c40b939176e643fd50a5c2196b8f8", size = 9979, upload-time = "2022-08-14T12:40:09.779Z" }, -] - -[[package]] -name = "ml-dtypes" -version = "0.5.1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/32/49/6e67c334872d2c114df3020e579f3718c333198f8312290e09ec0216703a/ml_dtypes-0.5.1.tar.gz", hash = "sha256:ac5b58559bb84a95848ed6984eb8013249f90b6bab62aa5acbad876e256002c9", size = 698772, upload-time = "2025-01-07T03:34:55.613Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/f4/88/11ebdbc75445eeb5b6869b708a0d787d1ed812ff86c2170bbfb95febdce1/ml_dtypes-0.5.1-cp310-cp310-macosx_10_9_universal2.whl", hash = "sha256:bd73f51957949069573ff783563486339a9285d72e2f36c18e0c1aa9ca7eb190", size = 671450, upload-time = "2025-01-07T03:33:52.724Z" }, - { url = "https://files.pythonhosted.org/packages/a4/a4/9321cae435d6140f9b0e7af8334456a854b60e3a9c6101280a16e3594965/ml_dtypes-0.5.1-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:810512e2eccdfc3b41eefa3a27402371a3411453a1efc7e9c000318196140fed", size = 4621075, upload-time = "2025-01-07T03:33:54.878Z" }, - { url = "https://files.pythonhosted.org/packages/16/d8/4502e12c6a10d42e13a552e8d97f20198e3cf82a0d1411ad50be56a5077c/ml_dtypes-0.5.1-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:141b2ea2f20bb10802ddca55d91fe21231ef49715cfc971998e8f2a9838f3dbe", size = 4738414, upload-time = "2025-01-07T03:33:57.709Z" }, - { url = "https://files.pythonhosted.org/packages/6b/7e/bc54ae885e4d702e60a4bf50aa9066ff35e9c66b5213d11091f6bffb3036/ml_dtypes-0.5.1-cp310-cp310-win_amd64.whl", hash = "sha256:26ebcc69d7b779c8f129393e99732961b5cc33fcff84090451f448c89b0e01b4", size = 209718, upload-time = "2025-01-07T03:34:00.585Z" }, - { url = "https://files.pythonhosted.org/packages/c9/fd/691335926126bb9beeb030b61a28f462773dcf16b8e8a2253b599013a303/ml_dtypes-0.5.1-cp311-cp311-macosx_10_9_universal2.whl", hash = "sha256:023ce2f502efd4d6c1e0472cc58ce3640d051d40e71e27386bed33901e201327", size = 671448, upload-time = "2025-01-07T03:34:03.153Z" }, - { url = "https://files.pythonhosted.org/packages/ff/a6/63832d91f2feb250d865d069ba1a5d0c686b1f308d1c74ce9764472c5e22/ml_dtypes-0.5.1-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:7000b6e4d8ef07542c05044ec5d8bbae1df083b3f56822c3da63993a113e716f", size = 4625792, upload-time = "2025-01-07T03:34:04.981Z" }, - { url = "https://files.pythonhosted.org/packages/cc/2a/5421fd3dbe6eef9b844cc9d05f568b9fb568503a2e51cb1eb4443d9fc56b/ml_dtypes-0.5.1-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:c09526488c3a9e8b7a23a388d4974b670a9a3dd40c5c8a61db5593ce9b725bab", size = 4743893, upload-time = "2025-01-07T03:34:08.333Z" }, - { url = "https://files.pythonhosted.org/packages/60/30/d3f0fc9499a22801219679a7f3f8d59f1429943c6261f445fb4bfce20718/ml_dtypes-0.5.1-cp311-cp311-win_amd64.whl", hash = "sha256:15ad0f3b0323ce96c24637a88a6f44f6713c64032f27277b069f285c3cf66478", size = 209712, upload-time = "2025-01-07T03:34:12.182Z" }, - { url = "https://files.pythonhosted.org/packages/47/56/1bb21218e1e692506c220ffabd456af9733fba7aa1b14f73899979f4cc20/ml_dtypes-0.5.1-cp312-cp312-macosx_10_9_universal2.whl", hash = "sha256:6f462f5eca22fb66d7ff9c4744a3db4463af06c49816c4b6ac89b16bfcdc592e", size = 670372, upload-time = "2025-01-07T03:34:15.258Z" }, - { url = "https://files.pythonhosted.org/packages/20/95/d8bd96a3b60e00bf31bd78ca4bdd2d6bbaf5acb09b42844432d719d34061/ml_dtypes-0.5.1-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:6f76232163b5b9c34291b54621ee60417601e2e4802a188a0ea7157cd9b323f4", size = 4635946, upload-time = "2025-01-07T03:34:20.412Z" }, - { url = "https://files.pythonhosted.org/packages/08/57/5d58fad4124192b1be42f68bd0c0ddaa26e44a730ff8c9337adade2f5632/ml_dtypes-0.5.1-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:ad4953c5eb9c25a56d11a913c2011d7e580a435ef5145f804d98efa14477d390", size = 4694804, upload-time = "2025-01-07T03:34:23.608Z" }, - { url = "https://files.pythonhosted.org/packages/38/bc/c4260e4a6c6bf684d0313308de1c860467275221d5e7daf69b3fcddfdd0b/ml_dtypes-0.5.1-cp312-cp312-win_amd64.whl", hash = "sha256:9626d0bca1fb387d5791ca36bacbba298c5ef554747b7ebeafefb4564fc83566", size = 210853, upload-time = "2025-01-07T03:34:26.027Z" }, - { url = "https://files.pythonhosted.org/packages/0f/92/bb6a3d18e16fddd18ce6d5f480e1919b33338c70e18cba831c6ae59812ee/ml_dtypes-0.5.1-cp313-cp313-macosx_10_13_universal2.whl", hash = "sha256:12651420130ee7cc13059fc56dac6ad300c3af3848b802d475148c9defd27c23", size = 667696, upload-time = "2025-01-07T03:34:27.526Z" }, - { url = "https://files.pythonhosted.org/packages/6d/29/cfc89d842767e9a51146043b0fa18332c2b38f8831447e6cb1160e3c6102/ml_dtypes-0.5.1-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:c9945669d3dadf8acb40ec2e57d38c985d8c285ea73af57fc5b09872c516106d", size = 4638365, upload-time = "2025-01-07T03:34:30.43Z" }, - { url = "https://files.pythonhosted.org/packages/be/26/adc36e3ea09603d9f6d114894e1c1b7b8e8a9ef6d0b031cc270c6624a37c/ml_dtypes-0.5.1-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:bf9975bda82a99dc935f2ae4c83846d86df8fd6ba179614acac8e686910851da", size = 4702722, upload-time = "2025-01-07T03:34:33.813Z" }, - { url = "https://files.pythonhosted.org/packages/da/8a/a2b9375c94077e5a488a624a195621407846f504068ce22ccf805c674156/ml_dtypes-0.5.1-cp313-cp313-win_amd64.whl", hash = "sha256:fd918d4e6a4e0c110e2e05be7a7814d10dc1b95872accbf6512b80a109b71ae1", size = 210850, upload-time = "2025-01-07T03:34:36.897Z" }, - { url = "https://files.pythonhosted.org/packages/52/38/703169100fdde27957f061d4d0ea3e00525775a09acaccf7e655d9609d55/ml_dtypes-0.5.1-cp313-cp313t-macosx_10_13_universal2.whl", hash = "sha256:05f23447a1c20ddf4dc7c2c661aa9ed93fcb2658f1017c204d1e758714dc28a8", size = 693043, upload-time = "2025-01-07T03:34:38.457Z" }, - { url = "https://files.pythonhosted.org/packages/28/ff/4e234c9c23e0d456f5da5a326c103bf890c746d93351524d987e41f438b3/ml_dtypes-0.5.1-cp313-cp313t-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:1b7fbe5571fdf28fd3aaab3ef4aafc847de9ebf263be959958c1ca58ec8eadf5", size = 4903946, upload-time = "2025-01-07T03:34:40.236Z" }, - { url = "https://files.pythonhosted.org/packages/b7/45/c1a1ccfdd02bc4173ca0f4a2d327683a27df85797b885eb1da1ca325b85c/ml_dtypes-0.5.1-cp313-cp313t-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:d13755f8e8445b3870114e5b6240facaa7cb0c3361e54beba3e07fa912a6e12b", size = 5052731, upload-time = "2025-01-07T03:34:45.308Z" }, -] - -[[package]] -name = "mpmath" -version = "1.3.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/e0/47/dd32fa426cc72114383ac549964eecb20ecfd886d1e5ccf5340b55b02f57/mpmath-1.3.0.tar.gz", hash = "sha256:7a28eb2a9774d00c7bc92411c19a89209d5da7c4c9a9e227be8330a23a25b91f", size = 508106, upload-time = "2023-03-07T16:47:11.061Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/43/e3/7d92a15f894aa0c9c4b49b8ee9ac9850d6e63b03c9c32c0367a13ae62209/mpmath-1.3.0-py3-none-any.whl", hash = "sha256:a0b2b9fe80bbcd81a6647ff13108738cfb482d481d826cc0e02f5b35e5c88d2c", size = 536198, upload-time = "2023-03-07T16:47:09.197Z" }, -] - -[[package]] -name = "msgpack" -version = "1.1.1" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/45/b1/ea4f68038a18c77c9467400d166d74c4ffa536f34761f7983a104357e614/msgpack-1.1.1.tar.gz", hash = "sha256:77b79ce34a2bdab2594f490c8e80dd62a02d650b91a75159a63ec413b8d104cd", size = 173555, upload-time = "2025-06-13T06:52:51.324Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/33/52/f30da112c1dc92cf64f57d08a273ac771e7b29dea10b4b30369b2d7e8546/msgpack-1.1.1-cp310-cp310-macosx_10_9_x86_64.whl", hash = "sha256:353b6fc0c36fde68b661a12949d7d49f8f51ff5fa019c1e47c87c4ff34b080ed", size = 81799, upload-time = "2025-06-13T06:51:37.228Z" }, - { url = "https://files.pythonhosted.org/packages/e4/35/7bfc0def2f04ab4145f7f108e3563f9b4abae4ab0ed78a61f350518cc4d2/msgpack-1.1.1-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:79c408fcf76a958491b4e3b103d1c417044544b68e96d06432a189b43d1215c8", size = 78278, upload-time = "2025-06-13T06:51:38.534Z" }, - { url = "https://files.pythonhosted.org/packages/e8/c5/df5d6c1c39856bc55f800bf82778fd4c11370667f9b9e9d51b2f5da88f20/msgpack-1.1.1-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:78426096939c2c7482bf31ef15ca219a9e24460289c00dd0b94411040bb73ad2", size = 402805, upload-time = "2025-06-13T06:51:39.538Z" }, - { url = "https://files.pythonhosted.org/packages/20/8e/0bb8c977efecfe6ea7116e2ed73a78a8d32a947f94d272586cf02a9757db/msgpack-1.1.1-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:8b17ba27727a36cb73aabacaa44b13090feb88a01d012c0f4be70c00f75048b4", size = 408642, upload-time = "2025-06-13T06:51:41.092Z" }, - { url = "https://files.pythonhosted.org/packages/59/a1/731d52c1aeec52006be6d1f8027c49fdc2cfc3ab7cbe7c28335b2910d7b6/msgpack-1.1.1-cp310-cp310-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:7a17ac1ea6ec3c7687d70201cfda3b1e8061466f28f686c24f627cae4ea8efd0", size = 395143, upload-time = "2025-06-13T06:51:42.575Z" }, - { url = "https://files.pythonhosted.org/packages/2b/92/b42911c52cda2ba67a6418ffa7d08969edf2e760b09015593c8a8a27a97d/msgpack-1.1.1-cp310-cp310-musllinux_1_2_aarch64.whl", hash = "sha256:88d1e966c9235c1d4e2afac21ca83933ba59537e2e2727a999bf3f515ca2af26", size = 395986, upload-time = "2025-06-13T06:51:43.807Z" }, - { url = "https://files.pythonhosted.org/packages/61/dc/8ae165337e70118d4dab651b8b562dd5066dd1e6dd57b038f32ebc3e2f07/msgpack-1.1.1-cp310-cp310-musllinux_1_2_i686.whl", hash = "sha256:f6d58656842e1b2ddbe07f43f56b10a60f2ba5826164910968f5933e5178af75", size = 402682, upload-time = "2025-06-13T06:51:45.534Z" }, - { url = "https://files.pythonhosted.org/packages/58/27/555851cb98dcbd6ce041df1eacb25ac30646575e9cd125681aa2f4b1b6f1/msgpack-1.1.1-cp310-cp310-musllinux_1_2_x86_64.whl", hash = "sha256:96decdfc4adcbc087f5ea7ebdcfd3dee9a13358cae6e81d54be962efc38f6338", size = 406368, upload-time = "2025-06-13T06:51:46.97Z" }, - { url = "https://files.pythonhosted.org/packages/d4/64/39a26add4ce16f24e99eabb9005e44c663db00e3fce17d4ae1ae9d61df99/msgpack-1.1.1-cp310-cp310-win32.whl", hash = "sha256:6640fd979ca9a212e4bcdf6eb74051ade2c690b862b679bfcb60ae46e6dc4bfd", size = 65004, upload-time = "2025-06-13T06:51:48.582Z" }, - { url = "https://files.pythonhosted.org/packages/7d/18/73dfa3e9d5d7450d39debde5b0d848139f7de23bd637a4506e36c9800fd6/msgpack-1.1.1-cp310-cp310-win_amd64.whl", hash = "sha256:8b65b53204fe1bd037c40c4148d00ef918eb2108d24c9aaa20bc31f9810ce0a8", size = 71548, upload-time = "2025-06-13T06:51:49.558Z" }, - { url = "https://files.pythonhosted.org/packages/7f/83/97f24bf9848af23fe2ba04380388216defc49a8af6da0c28cc636d722502/msgpack-1.1.1-cp311-cp311-macosx_10_9_x86_64.whl", hash = "sha256:71ef05c1726884e44f8b1d1773604ab5d4d17729d8491403a705e649116c9558", size = 82728, upload-time = "2025-06-13T06:51:50.68Z" }, - { url = "https://files.pythonhosted.org/packages/aa/7f/2eaa388267a78401f6e182662b08a588ef4f3de6f0eab1ec09736a7aaa2b/msgpack-1.1.1-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:36043272c6aede309d29d56851f8841ba907a1a3d04435e43e8a19928e243c1d", size = 79279, upload-time = "2025-06-13T06:51:51.72Z" }, - { url = "https://files.pythonhosted.org/packages/f8/46/31eb60f4452c96161e4dfd26dbca562b4ec68c72e4ad07d9566d7ea35e8a/msgpack-1.1.1-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:a32747b1b39c3ac27d0670122b57e6e57f28eefb725e0b625618d1b59bf9d1e0", size = 423859, upload-time = "2025-06-13T06:51:52.749Z" }, - { url = "https://files.pythonhosted.org/packages/45/16/a20fa8c32825cc7ae8457fab45670c7a8996d7746ce80ce41cc51e3b2bd7/msgpack-1.1.1-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:8a8b10fdb84a43e50d38057b06901ec9da52baac6983d3f709d8507f3889d43f", size = 429975, upload-time = "2025-06-13T06:51:53.97Z" }, - { url = "https://files.pythonhosted.org/packages/86/ea/6c958e07692367feeb1a1594d35e22b62f7f476f3c568b002a5ea09d443d/msgpack-1.1.1-cp311-cp311-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:ba0c325c3f485dc54ec298d8b024e134acf07c10d494ffa24373bea729acf704", size = 413528, upload-time = "2025-06-13T06:51:55.507Z" }, - { url = "https://files.pythonhosted.org/packages/75/05/ac84063c5dae79722bda9f68b878dc31fc3059adb8633c79f1e82c2cd946/msgpack-1.1.1-cp311-cp311-musllinux_1_2_aarch64.whl", hash = "sha256:88daaf7d146e48ec71212ce21109b66e06a98e5e44dca47d853cbfe171d6c8d2", size = 413338, upload-time = "2025-06-13T06:51:57.023Z" }, - { url = "https://files.pythonhosted.org/packages/69/e8/fe86b082c781d3e1c09ca0f4dacd457ede60a13119b6ce939efe2ea77b76/msgpack-1.1.1-cp311-cp311-musllinux_1_2_i686.whl", hash = "sha256:d8b55ea20dc59b181d3f47103f113e6f28a5e1c89fd5b67b9140edb442ab67f2", size = 422658, upload-time = "2025-06-13T06:51:58.419Z" }, - { url = "https://files.pythonhosted.org/packages/3b/2b/bafc9924df52d8f3bb7c00d24e57be477f4d0f967c0a31ef5e2225e035c7/msgpack-1.1.1-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:4a28e8072ae9779f20427af07f53bbb8b4aa81151054e882aee333b158da8752", size = 427124, upload-time = "2025-06-13T06:51:59.969Z" }, - { url = "https://files.pythonhosted.org/packages/a2/3b/1f717e17e53e0ed0b68fa59e9188f3f610c79d7151f0e52ff3cd8eb6b2dc/msgpack-1.1.1-cp311-cp311-win32.whl", hash = "sha256:7da8831f9a0fdb526621ba09a281fadc58ea12701bc709e7b8cbc362feabc295", size = 65016, upload-time = "2025-06-13T06:52:01.294Z" }, - { url = "https://files.pythonhosted.org/packages/48/45/9d1780768d3b249accecc5a38c725eb1e203d44a191f7b7ff1941f7df60c/msgpack-1.1.1-cp311-cp311-win_amd64.whl", hash = "sha256:5fd1b58e1431008a57247d6e7cc4faa41c3607e8e7d4aaf81f7c29ea013cb458", size = 72267, upload-time = "2025-06-13T06:52:02.568Z" }, - { url = "https://files.pythonhosted.org/packages/e3/26/389b9c593eda2b8551b2e7126ad3a06af6f9b44274eb3a4f054d48ff7e47/msgpack-1.1.1-cp312-cp312-macosx_10_13_x86_64.whl", hash = "sha256:ae497b11f4c21558d95de9f64fff7053544f4d1a17731c866143ed6bb4591238", size = 82359, upload-time = "2025-06-13T06:52:03.909Z" }, - { url = "https://files.pythonhosted.org/packages/ab/65/7d1de38c8a22cf8b1551469159d4b6cf49be2126adc2482de50976084d78/msgpack-1.1.1-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:33be9ab121df9b6b461ff91baac6f2731f83d9b27ed948c5b9d1978ae28bf157", size = 79172, upload-time = "2025-06-13T06:52:05.246Z" }, - { url = "https://files.pythonhosted.org/packages/0f/bd/cacf208b64d9577a62c74b677e1ada005caa9b69a05a599889d6fc2ab20a/msgpack-1.1.1-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:6f64ae8fe7ffba251fecb8408540c34ee9df1c26674c50c4544d72dbf792e5ce", size = 425013, upload-time = "2025-06-13T06:52:06.341Z" }, - { url = "https://files.pythonhosted.org/packages/4d/ec/fd869e2567cc9c01278a736cfd1697941ba0d4b81a43e0aa2e8d71dab208/msgpack-1.1.1-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:a494554874691720ba5891c9b0b39474ba43ffb1aaf32a5dac874effb1619e1a", size = 426905, upload-time = "2025-06-13T06:52:07.501Z" }, - { url = "https://files.pythonhosted.org/packages/55/2a/35860f33229075bce803a5593d046d8b489d7ba2fc85701e714fc1aaf898/msgpack-1.1.1-cp312-cp312-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:cb643284ab0ed26f6957d969fe0dd8bb17beb567beb8998140b5e38a90974f6c", size = 407336, upload-time = "2025-06-13T06:52:09.047Z" }, - { url = "https://files.pythonhosted.org/packages/8c/16/69ed8f3ada150bf92745fb4921bd621fd2cdf5a42e25eb50bcc57a5328f0/msgpack-1.1.1-cp312-cp312-musllinux_1_2_aarch64.whl", hash = "sha256:d275a9e3c81b1093c060c3837e580c37f47c51eca031f7b5fb76f7b8470f5f9b", size = 409485, upload-time = "2025-06-13T06:52:10.382Z" }, - { url = "https://files.pythonhosted.org/packages/c6/b6/0c398039e4c6d0b2e37c61d7e0e9d13439f91f780686deb8ee64ecf1ae71/msgpack-1.1.1-cp312-cp312-musllinux_1_2_i686.whl", hash = "sha256:4fd6b577e4541676e0cc9ddc1709d25014d3ad9a66caa19962c4f5de30fc09ef", size = 412182, upload-time = "2025-06-13T06:52:11.644Z" }, - { url = "https://files.pythonhosted.org/packages/b8/d0/0cf4a6ecb9bc960d624c93effaeaae75cbf00b3bc4a54f35c8507273cda1/msgpack-1.1.1-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:bb29aaa613c0a1c40d1af111abf025f1732cab333f96f285d6a93b934738a68a", size = 419883, upload-time = "2025-06-13T06:52:12.806Z" }, - { url = "https://files.pythonhosted.org/packages/62/83/9697c211720fa71a2dfb632cad6196a8af3abea56eece220fde4674dc44b/msgpack-1.1.1-cp312-cp312-win32.whl", hash = "sha256:870b9a626280c86cff9c576ec0d9cbcc54a1e5ebda9cd26dab12baf41fee218c", size = 65406, upload-time = "2025-06-13T06:52:14.271Z" }, - { url = "https://files.pythonhosted.org/packages/c0/23/0abb886e80eab08f5e8c485d6f13924028602829f63b8f5fa25a06636628/msgpack-1.1.1-cp312-cp312-win_amd64.whl", hash = "sha256:5692095123007180dca3e788bb4c399cc26626da51629a31d40207cb262e67f4", size = 72558, upload-time = "2025-06-13T06:52:15.252Z" }, - { url = "https://files.pythonhosted.org/packages/a1/38/561f01cf3577430b59b340b51329803d3a5bf6a45864a55f4ef308ac11e3/msgpack-1.1.1-cp313-cp313-macosx_10_13_x86_64.whl", hash = "sha256:3765afa6bd4832fc11c3749be4ba4b69a0e8d7b728f78e68120a157a4c5d41f0", size = 81677, upload-time = "2025-06-13T06:52:16.64Z" }, - { url = "https://files.pythonhosted.org/packages/09/48/54a89579ea36b6ae0ee001cba8c61f776451fad3c9306cd80f5b5c55be87/msgpack-1.1.1-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:8ddb2bcfd1a8b9e431c8d6f4f7db0773084e107730ecf3472f1dfe9ad583f3d9", size = 78603, upload-time = "2025-06-13T06:52:17.843Z" }, - { url = "https://files.pythonhosted.org/packages/a0/60/daba2699b308e95ae792cdc2ef092a38eb5ee422f9d2fbd4101526d8a210/msgpack-1.1.1-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:196a736f0526a03653d829d7d4c5500a97eea3648aebfd4b6743875f28aa2af8", size = 420504, upload-time = "2025-06-13T06:52:18.982Z" }, - { url = "https://files.pythonhosted.org/packages/20/22/2ebae7ae43cd8f2debc35c631172ddf14e2a87ffcc04cf43ff9df9fff0d3/msgpack-1.1.1-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:9d592d06e3cc2f537ceeeb23d38799c6ad83255289bb84c2e5792e5a8dea268a", size = 423749, upload-time = "2025-06-13T06:52:20.211Z" }, - { url = "https://files.pythonhosted.org/packages/40/1b/54c08dd5452427e1179a40b4b607e37e2664bca1c790c60c442c8e972e47/msgpack-1.1.1-cp313-cp313-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:4df2311b0ce24f06ba253fda361f938dfecd7b961576f9be3f3fbd60e87130ac", size = 404458, upload-time = "2025-06-13T06:52:21.429Z" }, - { url = "https://files.pythonhosted.org/packages/2e/60/6bb17e9ffb080616a51f09928fdd5cac1353c9becc6c4a8abd4e57269a16/msgpack-1.1.1-cp313-cp313-musllinux_1_2_aarch64.whl", hash = "sha256:e4141c5a32b5e37905b5940aacbc59739f036930367d7acce7a64e4dec1f5e0b", size = 405976, upload-time = "2025-06-13T06:52:22.995Z" }, - { url = "https://files.pythonhosted.org/packages/ee/97/88983e266572e8707c1f4b99c8fd04f9eb97b43f2db40e3172d87d8642db/msgpack-1.1.1-cp313-cp313-musllinux_1_2_i686.whl", hash = "sha256:b1ce7f41670c5a69e1389420436f41385b1aa2504c3b0c30620764b15dded2e7", size = 408607, upload-time = "2025-06-13T06:52:24.152Z" }, - { url = "https://files.pythonhosted.org/packages/bc/66/36c78af2efaffcc15a5a61ae0df53a1d025f2680122e2a9eb8442fed3ae4/msgpack-1.1.1-cp313-cp313-musllinux_1_2_x86_64.whl", hash = "sha256:4147151acabb9caed4e474c3344181e91ff7a388b888f1e19ea04f7e73dc7ad5", size = 424172, upload-time = "2025-06-13T06:52:25.704Z" }, - { url = "https://files.pythonhosted.org/packages/8c/87/a75eb622b555708fe0427fab96056d39d4c9892b0c784b3a721088c7ee37/msgpack-1.1.1-cp313-cp313-win32.whl", hash = "sha256:500e85823a27d6d9bba1d057c871b4210c1dd6fb01fbb764e37e4e8847376323", size = 65347, upload-time = "2025-06-13T06:52:26.846Z" }, - { url = "https://files.pythonhosted.org/packages/ca/91/7dc28d5e2a11a5ad804cf2b7f7a5fcb1eb5a4966d66a5d2b41aee6376543/msgpack-1.1.1-cp313-cp313-win_amd64.whl", hash = "sha256:6d489fba546295983abd142812bda76b57e33d0b9f5d5b71c09a583285506f69", size = 72341, upload-time = "2025-06-13T06:52:27.835Z" }, -] - -[[package]] -name = "multidict" -version = "6.5.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "typing-extensions", marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/46/b5/59f27b4ce9951a4bce56b88ba5ff5159486797ab18863f2b4c1c5e8465bd/multidict-6.5.0.tar.gz", hash = "sha256:942bd8002492ba819426a8d7aefde3189c1b87099cdf18aaaefefcf7f3f7b6d2", size = 98512, upload-time = "2025-06-17T14:15:56.556Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/8b/88/f8354ef1cb1121234c3461ff3d11eac5f4fe115f00552d3376306275c9ab/multidict-6.5.0-cp310-cp310-macosx_10_9_universal2.whl", hash = "sha256:2e118a202904623b1d2606d1c8614e14c9444b59d64454b0c355044058066469", size = 73858, upload-time = "2025-06-17T14:13:21.451Z" }, - { url = "https://files.pythonhosted.org/packages/49/04/634b49c7abe71bd1c61affaeaa0c2a46b6be8d599a07b495259615dbdfe0/multidict-6.5.0-cp310-cp310-macosx_10_9_x86_64.whl", hash = "sha256:a42995bdcaff4e22cb1280ae7752c3ed3fbb398090c6991a2797a4a0e5ed16a9", size = 43186, upload-time = "2025-06-17T14:13:23.615Z" }, - { url = "https://files.pythonhosted.org/packages/3b/ff/091ff4830ec8f96378578bfffa7f324a9dd16f60274cec861ae65ba10be3/multidict-6.5.0-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:2261b538145723ca776e55208640fffd7ee78184d223f37c2b40b9edfe0e818a", size = 43031, upload-time = "2025-06-17T14:13:24.725Z" }, - { url = "https://files.pythonhosted.org/packages/10/c1/1b4137845f8b8dbc2332af54e2d7761c6a29c2c33c8d47a0c8c70676bac1/multidict-6.5.0-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:0e5b19f8cd67235fab3e195ca389490415d9fef5a315b1fa6f332925dc924262", size = 233588, upload-time = "2025-06-17T14:13:26.181Z" }, - { url = "https://files.pythonhosted.org/packages/c3/77/cbe9a1f58c6d4f822663788e414637f256a872bc352cedbaf7717b62db58/multidict-6.5.0-cp310-cp310-manylinux_2_17_armv7l.manylinux2014_armv7l.manylinux_2_31_armv7l.whl", hash = "sha256:177b081e4dec67c3320b16b3aa0babc178bbf758553085669382c7ec711e1ec8", size = 222714, upload-time = "2025-06-17T14:13:27.482Z" }, - { url = "https://files.pythonhosted.org/packages/6c/37/39e1142c2916973818515adc13bbdb68d3d8126935e3855200e059a79bab/multidict-6.5.0-cp310-cp310-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:4d30a2cc106a7d116b52ee046207614db42380b62e6b1dd2a50eba47c5ca5eb1", size = 242741, upload-time = "2025-06-17T14:13:28.92Z" }, - { url = "https://files.pythonhosted.org/packages/a3/aa/60c3ef0c87ccad3445bf01926a1b8235ee24c3dde483faef1079cc91706d/multidict-6.5.0-cp310-cp310-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:a72933bc308d7a64de37f0d51795dbeaceebdfb75454f89035cdfc6a74cfd129", size = 235008, upload-time = "2025-06-17T14:13:30.587Z" }, - { url = "https://files.pythonhosted.org/packages/bf/5e/f7e0fd5f5b8a7b9a75b0f5642ca6b6dde90116266920d8cf63b513f3908b/multidict-6.5.0-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:96d109e663d032280ef8ef62b50924b2e887d5ddf19e301844a6cb7e91a172a6", size = 226627, upload-time = "2025-06-17T14:13:31.831Z" }, - { url = "https://files.pythonhosted.org/packages/b7/74/1bc0a3c6a9105051f68a6991fe235d7358836e81058728c24d5bbdd017cb/multidict-6.5.0-cp310-cp310-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:b555329c9894332401f03b9a87016f0b707b6fccd4706793ec43b4a639e75869", size = 228232, upload-time = "2025-06-17T14:13:33.402Z" }, - { url = "https://files.pythonhosted.org/packages/99/e7/37118291cdc31f4cc680d54047cdea9b520e9a724a643919f71f8c2a2aeb/multidict-6.5.0-cp310-cp310-musllinux_1_2_aarch64.whl", hash = "sha256:6994bad9d471ef2156f2b6850b51e20ee409c6b9deebc0e57be096be9faffdce", size = 246616, upload-time = "2025-06-17T14:13:34.964Z" }, - { url = "https://files.pythonhosted.org/packages/ff/89/e2c08d6bdb21a1a55be4285510d058ace5f5acabe6b57900432e863d4c70/multidict-6.5.0-cp310-cp310-musllinux_1_2_armv7l.whl", hash = "sha256:b15f817276c96cde9060569023808eec966bd8da56a97e6aa8116f34ddab6534", size = 235007, upload-time = "2025-06-17T14:13:36.428Z" }, - { url = "https://files.pythonhosted.org/packages/89/1e/e39a98e8e1477ec7a871b3c17265658fbe6d617048059ae7fa5011b224f3/multidict-6.5.0-cp310-cp310-musllinux_1_2_i686.whl", hash = "sha256:b4bf507c991db535a935b2127cf057a58dbc688c9f309c72080795c63e796f58", size = 244824, upload-time = "2025-06-17T14:13:37.982Z" }, - { url = "https://files.pythonhosted.org/packages/a3/ba/63e11edd45c31e708c5a1904aa7ac4de01e13135a04cfe96bc71eb359b85/multidict-6.5.0-cp310-cp310-musllinux_1_2_ppc64le.whl", hash = "sha256:60c3f8f13d443426c55f88cf3172547bbc600a86d57fd565458b9259239a6737", size = 257229, upload-time = "2025-06-17T14:13:39.554Z" }, - { url = "https://files.pythonhosted.org/packages/0f/00/bdcceb6af424936adfc8b92a79d3a95863585f380071393934f10a63f9e3/multidict-6.5.0-cp310-cp310-musllinux_1_2_s390x.whl", hash = "sha256:a10227168a24420c158747fc201d4279aa9af1671f287371597e2b4f2ff21879", size = 247118, upload-time = "2025-06-17T14:13:40.795Z" }, - { url = "https://files.pythonhosted.org/packages/b6/a0/4aa79e991909cca36ca821a9ba5e8e81e4cd5b887c81f89ded994e0f49df/multidict-6.5.0-cp310-cp310-musllinux_1_2_x86_64.whl", hash = "sha256:e3b1425fe54ccfde66b8cfb25d02be34d5dfd2261a71561ffd887ef4088b4b69", size = 243948, upload-time = "2025-06-17T14:13:42.477Z" }, - { url = "https://files.pythonhosted.org/packages/21/8b/e45e19ce43afb31ff6b0fd5d5816b4fcc1fcc2f37e8a82aefae06c40c7a6/multidict-6.5.0-cp310-cp310-win32.whl", hash = "sha256:b4e47ef51237841d1087e1e1548071a6ef22e27ed0400c272174fa585277c4b4", size = 40433, upload-time = "2025-06-17T14:13:43.972Z" }, - { url = "https://files.pythonhosted.org/packages/d2/6e/96e0ba4601343d9344e69503fca072ace19c35f7d4ca3d68401e59acdc8f/multidict-6.5.0-cp310-cp310-win_amd64.whl", hash = "sha256:63b3b24fadc7067282c88fae5b2f366d5b3a7c15c021c2838de8c65a50eeefb4", size = 44423, upload-time = "2025-06-17T14:13:44.991Z" }, - { url = "https://files.pythonhosted.org/packages/eb/4a/9befa919d7a390f13a5511a69282b7437782071160c566de6e0ebf712c9f/multidict-6.5.0-cp310-cp310-win_arm64.whl", hash = "sha256:8b2d61afbafc679b7eaf08e9de4fa5d38bd5dc7a9c0a577c9f9588fb49f02dbb", size = 41481, upload-time = "2025-06-17T14:13:49.389Z" }, - { url = "https://files.pythonhosted.org/packages/75/ba/484f8e96ee58ec4fef42650eb9dbbedb24f9bc155780888398a4725d2270/multidict-6.5.0-cp311-cp311-macosx_10_9_universal2.whl", hash = "sha256:8b4bf6bb15a05796a07a248084e3e46e032860c899c7a9b981030e61368dba95", size = 73283, upload-time = "2025-06-17T14:13:50.406Z" }, - { url = "https://files.pythonhosted.org/packages/71/48/01d62ea6199d76934c87746695b3ed16aeedfdd564e8d89184577037baac/multidict-6.5.0-cp311-cp311-macosx_10_9_x86_64.whl", hash = "sha256:46bb05d50219655c42a4b8fcda9c7ee658a09adbb719c48e65a20284e36328ea", size = 42937, upload-time = "2025-06-17T14:13:51.45Z" }, - { url = "https://files.pythonhosted.org/packages/da/cf/bb462d920f26d9e2e0aff8a78aeb06af1225b826e9a5468870c57591910a/multidict-6.5.0-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:54f524d73f4d54e87e03c98f6af601af4777e4668a52b1bd2ae0a4d6fc7b392b", size = 42748, upload-time = "2025-06-17T14:13:52.505Z" }, - { url = "https://files.pythonhosted.org/packages/cd/b1/d5c11ea0fdad68d3ed45f0e2527de6496d2fac8afe6b8ca6d407c20ad00f/multidict-6.5.0-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:529b03600466480ecc502000d62e54f185a884ed4570dee90d9a273ee80e37b5", size = 236448, upload-time = "2025-06-17T14:13:53.562Z" }, - { url = "https://files.pythonhosted.org/packages/fc/69/c3ceb264994f5b338c812911a8d660084f37779daef298fc30bd817f75c7/multidict-6.5.0-cp311-cp311-manylinux_2_17_armv7l.manylinux2014_armv7l.manylinux_2_31_armv7l.whl", hash = "sha256:69ad681ad7c93a41ee7005cc83a144b5b34a3838bcf7261e2b5356057b0f78de", size = 228695, upload-time = "2025-06-17T14:13:54.775Z" }, - { url = "https://files.pythonhosted.org/packages/81/3d/c23dcc0d34a35ad29974184db2878021d28fe170ecb9192be6bfee73f1f2/multidict-6.5.0-cp311-cp311-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:3fe9fada8bc0839466b09fa3f6894f003137942984843ec0c3848846329a36ae", size = 247434, upload-time = "2025-06-17T14:13:56.039Z" }, - { url = "https://files.pythonhosted.org/packages/06/b3/06cf7a049129ff52525a859277abb5648e61d7afae7fb7ed02e3806be34e/multidict-6.5.0-cp311-cp311-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:f94c6ea6405fcf81baef1e459b209a78cda5442e61b5b7a57ede39d99b5204a0", size = 239431, upload-time = "2025-06-17T14:13:57.33Z" }, - { url = "https://files.pythonhosted.org/packages/8a/72/b2fe2fafa23af0c6123aebe23b4cd23fdad01dfe7009bb85624e4636d0dd/multidict-6.5.0-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:84ca75ad8a39ed75f079a8931435a5b51ee4c45d9b32e1740f99969a5d1cc2ee", size = 231542, upload-time = "2025-06-17T14:13:58.597Z" }, - { url = "https://files.pythonhosted.org/packages/a1/c9/a52ca0a342a02411a31b6af197a6428a5137d805293f10946eeab614ec06/multidict-6.5.0-cp311-cp311-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:be4c08f3a2a6cc42b414496017928d95898964fed84b1b2dace0c9ee763061f9", size = 233069, upload-time = "2025-06-17T14:13:59.834Z" }, - { url = "https://files.pythonhosted.org/packages/9b/55/a3328a3929b8e131e2678d5e65f552b0a6874fab62123e31f5a5625650b0/multidict-6.5.0-cp311-cp311-musllinux_1_2_aarch64.whl", hash = "sha256:046a7540cfbb4d5dc846a1fd9843f3ba980c6523f2e0c5b8622b4a5c94138ae6", size = 250596, upload-time = "2025-06-17T14:14:01.178Z" }, - { url = "https://files.pythonhosted.org/packages/6c/b8/aa3905a38a8287013aeb0a54c73f79ccd8b32d2f1d53e5934643a36502c2/multidict-6.5.0-cp311-cp311-musllinux_1_2_armv7l.whl", hash = "sha256:64306121171d988af77d74be0d8c73ee1a69cf6f96aea7fa6030c88f32a152dd", size = 237858, upload-time = "2025-06-17T14:14:03.232Z" }, - { url = "https://files.pythonhosted.org/packages/d3/eb/f11d5af028014f402e5dd01ece74533964fa4e7bfae4af4824506fa8c398/multidict-6.5.0-cp311-cp311-musllinux_1_2_i686.whl", hash = "sha256:b4ac1dd5eb0ecf6f7351d5a9137f30a83f7182209c5d37f61614dfdce5714853", size = 249175, upload-time = "2025-06-17T14:14:04.561Z" }, - { url = "https://files.pythonhosted.org/packages/ac/57/d451905a62e5ef489cb4f92e8190d34ac5329427512afd7f893121da4e96/multidict-6.5.0-cp311-cp311-musllinux_1_2_ppc64le.whl", hash = "sha256:bab4a8337235365f4111a7011a1f028826ca683834ebd12de4b85e2844359c36", size = 259532, upload-time = "2025-06-17T14:14:05.798Z" }, - { url = "https://files.pythonhosted.org/packages/d3/90/ff82b5ac5cabe3c79c50cf62a62f3837905aa717e67b6b4b7872804f23c8/multidict-6.5.0-cp311-cp311-musllinux_1_2_s390x.whl", hash = "sha256:a05b5604c5a75df14a63eeeca598d11b2c3745b9008539b70826ea044063a572", size = 250554, upload-time = "2025-06-17T14:14:07.382Z" }, - { url = "https://files.pythonhosted.org/packages/d5/5a/0cabc50d4bc16e61d8b0a8a74499a1409fa7b4ef32970b7662a423781fc7/multidict-6.5.0-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:67c4a640952371c9ca65b6a710598be246ef3be5ca83ed38c16a7660d3980877", size = 248159, upload-time = "2025-06-17T14:14:08.65Z" }, - { url = "https://files.pythonhosted.org/packages/c0/1d/adeabae0771544f140d9f42ab2c46eaf54e793325999c36106078b7f6600/multidict-6.5.0-cp311-cp311-win32.whl", hash = "sha256:fdeae096ca36c12d8aca2640b8407a9d94e961372c68435bef14e31cce726138", size = 40357, upload-time = "2025-06-17T14:14:09.91Z" }, - { url = "https://files.pythonhosted.org/packages/e1/fe/bbd85ae65c96de5c9910c332ee1f4b7be0bf0fb21563895167bcb6502a1f/multidict-6.5.0-cp311-cp311-win_amd64.whl", hash = "sha256:e2977ef8b7ce27723ee8c610d1bd1765da4f3fbe5a64f9bf1fd3b4770e31fbc0", size = 44432, upload-time = "2025-06-17T14:14:11.013Z" }, - { url = "https://files.pythonhosted.org/packages/96/af/f9052d9c4e65195b210da9f7afdea06d3b7592b3221cc0ef1b407f762faa/multidict-6.5.0-cp311-cp311-win_arm64.whl", hash = "sha256:82d0cf0ea49bae43d9e8c3851e21954eff716259ff42da401b668744d1760bcb", size = 41408, upload-time = "2025-06-17T14:14:12.112Z" }, - { url = "https://files.pythonhosted.org/packages/0a/fa/18f4950e00924f7e84c8195f4fc303295e14df23f713d64e778b8fa8b903/multidict-6.5.0-cp312-cp312-macosx_10_13_universal2.whl", hash = "sha256:1bb986c8ea9d49947bc325c51eced1ada6d8d9b4c5b15fd3fcdc3c93edef5a74", size = 73474, upload-time = "2025-06-17T14:14:13.528Z" }, - { url = "https://files.pythonhosted.org/packages/6c/66/0392a2a8948bccff57e4793c9dde3e5c088f01e8b7f8867ee58a2f187fc5/multidict-6.5.0-cp312-cp312-macosx_10_13_x86_64.whl", hash = "sha256:03c0923da300120830fc467e23805d63bbb4e98b94032bd863bc7797ea5fa653", size = 43741, upload-time = "2025-06-17T14:14:15.188Z" }, - { url = "https://files.pythonhosted.org/packages/98/3e/f48487c91b2a070566cfbab876d7e1ebe7deb0a8002e4e896a97998ae066/multidict-6.5.0-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:4c78d5ec00fdd35c91680ab5cf58368faad4bd1a8721f87127326270248de9bc", size = 42143, upload-time = "2025-06-17T14:14:16.612Z" }, - { url = "https://files.pythonhosted.org/packages/3f/49/439c6cc1cd00365cf561bdd3579cc3fa1a0d38effb3a59b8d9562839197f/multidict-6.5.0-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:aadc3cb78be90a887f8f6b73945b840da44b4a483d1c9750459ae69687940c97", size = 239303, upload-time = "2025-06-17T14:14:17.707Z" }, - { url = "https://files.pythonhosted.org/packages/c4/24/491786269e90081cb536e4d7429508725bc92ece176d1204a4449de7c41c/multidict-6.5.0-cp312-cp312-manylinux_2_17_armv7l.manylinux2014_armv7l.manylinux_2_31_armv7l.whl", hash = "sha256:5b02e1ca495d71e07e652e4cef91adae3bf7ae4493507a263f56e617de65dafc", size = 236913, upload-time = "2025-06-17T14:14:18.981Z" }, - { url = "https://files.pythonhosted.org/packages/e8/76/bbe2558b820ebeca8a317ab034541790e8160ca4b1e450415383ac69b339/multidict-6.5.0-cp312-cp312-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:7fe92a62326eef351668eec4e2dfc494927764a0840a1895cff16707fceffcd3", size = 250752, upload-time = "2025-06-17T14:14:20.297Z" }, - { url = "https://files.pythonhosted.org/packages/3e/e3/3977f2c1123f553ceff9f53cd4de04be2c1912333c6fabbcd51531655476/multidict-6.5.0-cp312-cp312-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:7673ee4f63879ecd526488deb1989041abcb101b2d30a9165e1e90c489f3f7fb", size = 243937, upload-time = "2025-06-17T14:14:21.935Z" }, - { url = "https://files.pythonhosted.org/packages/b6/b8/7a6e9c13c79709cdd2f22ee849f058e6da76892d141a67acc0e6c30d845c/multidict-6.5.0-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:fa097ae2a29f573de7e2d86620cbdda5676d27772d4ed2669cfa9961a0d73955", size = 237419, upload-time = "2025-06-17T14:14:23.215Z" }, - { url = "https://files.pythonhosted.org/packages/84/9d/8557f5e88da71bc7e7a8ace1ada4c28197f3bfdc2dd6e51d3b88f2e16e8e/multidict-6.5.0-cp312-cp312-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:300da0fa4f8457d9c4bd579695496116563409e676ac79b5e4dca18e49d1c308", size = 237222, upload-time = "2025-06-17T14:14:24.516Z" }, - { url = "https://files.pythonhosted.org/packages/a3/3b/8f023ad60e7969cb6bc0683738d0e1618f5ff5723d6d2d7818dc6df6ad3d/multidict-6.5.0-cp312-cp312-musllinux_1_2_aarch64.whl", hash = "sha256:9a19bd108c35877b57393243d392d024cfbfdefe759fd137abb98f6fc910b64c", size = 247861, upload-time = "2025-06-17T14:14:25.839Z" }, - { url = "https://files.pythonhosted.org/packages/af/1c/9cf5a099ce7e3189906cf5daa72c44ee962dcb4c1983659f3a6f8a7446ab/multidict-6.5.0-cp312-cp312-musllinux_1_2_armv7l.whl", hash = "sha256:0f32a1777465a35c35ddbbd7fc1293077938a69402fcc59e40b2846d04a120dd", size = 243917, upload-time = "2025-06-17T14:14:27.164Z" }, - { url = "https://files.pythonhosted.org/packages/6c/bb/88ee66ebeef56868044bac58feb1cc25658bff27b20e3cfc464edc181287/multidict-6.5.0-cp312-cp312-musllinux_1_2_i686.whl", hash = "sha256:9cc1e10c14ce8112d1e6d8971fe3cdbe13e314f68bea0e727429249d4a6ce164", size = 249214, upload-time = "2025-06-17T14:14:28.795Z" }, - { url = "https://files.pythonhosted.org/packages/3e/ec/a90e88cc4a1309f33088ab1cdd5c0487718f49dfb82c5ffc845bb17c1973/multidict-6.5.0-cp312-cp312-musllinux_1_2_ppc64le.whl", hash = "sha256:e95c5e07a06594bdc288117ca90e89156aee8cb2d7c330b920d9c3dd19c05414", size = 258682, upload-time = "2025-06-17T14:14:30.066Z" }, - { url = "https://files.pythonhosted.org/packages/d2/d8/16dd69a6811920a31f4e06114ebe67b1cd922c8b05c9c82b050706d0b6fe/multidict-6.5.0-cp312-cp312-musllinux_1_2_s390x.whl", hash = "sha256:40ff26f58323795f5cd2855e2718a1720a1123fb90df4553426f0efd76135462", size = 254254, upload-time = "2025-06-17T14:14:31.323Z" }, - { url = "https://files.pythonhosted.org/packages/ac/a8/90193a5f5ca1bdbf92633d69a25a2ef9bcac7b412b8d48c84d01a2732518/multidict-6.5.0-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:76803a29fd71869a8b59c2118c9dcfb3b8f9c8723e2cce6baeb20705459505cf", size = 247741, upload-time = "2025-06-17T14:14:32.717Z" }, - { url = "https://files.pythonhosted.org/packages/cd/43/29c7a747153c05b41d1f67455426af39ed88d6de3f21c232b8f2724bde13/multidict-6.5.0-cp312-cp312-win32.whl", hash = "sha256:df7ecbc65a53a2ce1b3a0c82e6ad1a43dcfe7c6137733f9176a92516b9f5b851", size = 41049, upload-time = "2025-06-17T14:14:33.941Z" }, - { url = "https://files.pythonhosted.org/packages/1e/e8/8f3fc32b7e901f3a2719764d64aeaf6ae77b4ba961f1c3a3cf3867766636/multidict-6.5.0-cp312-cp312-win_amd64.whl", hash = "sha256:0ec1c3fbbb0b655a6540bce408f48b9a7474fd94ed657dcd2e890671fefa7743", size = 44700, upload-time = "2025-06-17T14:14:35.016Z" }, - { url = "https://files.pythonhosted.org/packages/24/e4/e250806adc98d524d41e69c8d4a42bc3513464adb88cb96224df12928617/multidict-6.5.0-cp312-cp312-win_arm64.whl", hash = "sha256:2d24a00d34808b22c1f15902899b9d82d0faeca9f56281641c791d8605eacd35", size = 41703, upload-time = "2025-06-17T14:14:36.168Z" }, - { url = "https://files.pythonhosted.org/packages/1a/c9/092c4e9402b6d16de761cff88cb842a5c8cc50ccecaf9c4481ba53264b9e/multidict-6.5.0-cp313-cp313-macosx_10_13_universal2.whl", hash = "sha256:53d92df1752df67a928fa7f884aa51edae6f1cf00eeb38cbcf318cf841c17456", size = 73486, upload-time = "2025-06-17T14:14:37.238Z" }, - { url = "https://files.pythonhosted.org/packages/08/f9/6f7ddb8213f5fdf4db48d1d640b78e8aef89b63a5de8a2313286db709250/multidict-6.5.0-cp313-cp313-macosx_10_13_x86_64.whl", hash = "sha256:680210de2c38eef17ce46b8df8bf2c1ece489261a14a6e43c997d49843a27c99", size = 43745, upload-time = "2025-06-17T14:14:38.32Z" }, - { url = "https://files.pythonhosted.org/packages/f3/a7/b9be0163bfeee3bb08a77a1705e24eb7e651d594ea554107fac8a1ca6a4d/multidict-6.5.0-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:e279259bcb936732bfa1a8eec82b5d2352b3df69d2fa90d25808cfc403cee90a", size = 42135, upload-time = "2025-06-17T14:14:39.897Z" }, - { url = "https://files.pythonhosted.org/packages/8e/30/93c8203f943a417bda3c573a34d5db0cf733afdfffb0ca78545c7716dbd8/multidict-6.5.0-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:d1c185fc1069781e3fc8b622c4331fb3b433979850392daa5efbb97f7f9959bb", size = 238585, upload-time = "2025-06-17T14:14:41.332Z" }, - { url = "https://files.pythonhosted.org/packages/9d/fe/2582b56a1807604774f566eeef183b0d6b148f4b89d1612cd077567b2e1e/multidict-6.5.0-cp313-cp313-manylinux_2_17_armv7l.manylinux2014_armv7l.manylinux_2_31_armv7l.whl", hash = "sha256:6bb5f65ff91daf19ce97f48f63585e51595539a8a523258b34f7cef2ec7e0617", size = 236174, upload-time = "2025-06-17T14:14:42.602Z" }, - { url = "https://files.pythonhosted.org/packages/9b/c4/d8b66d42d385bd4f974cbd1eaa8b265e6b8d297249009f312081d5ded5c7/multidict-6.5.0-cp313-cp313-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:d8646b4259450c59b9286db280dd57745897897284f6308edbdf437166d93855", size = 250145, upload-time = "2025-06-17T14:14:43.944Z" }, - { url = "https://files.pythonhosted.org/packages/bc/64/62feda5093ee852426aae3df86fab079f8bf1cdbe403e1078c94672ad3ec/multidict-6.5.0-cp313-cp313-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:d245973d4ecc04eea0a8e5ebec7882cf515480036e1b48e65dffcfbdf86d00be", size = 243470, upload-time = "2025-06-17T14:14:45.343Z" }, - { url = "https://files.pythonhosted.org/packages/67/dc/9f6fa6e854625cf289c0e9f4464b40212a01f76b2f3edfe89b6779b4fb93/multidict-6.5.0-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:a133e7ddc9bc7fb053733d0ff697ce78c7bf39b5aec4ac12857b6116324c8d75", size = 236968, upload-time = "2025-06-17T14:14:46.609Z" }, - { url = "https://files.pythonhosted.org/packages/46/ae/4b81c6e3745faee81a156f3f87402315bdccf04236f75c03e37be19c94ff/multidict-6.5.0-cp313-cp313-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:80d696fa38d738fcebfd53eec4d2e3aeb86a67679fd5e53c325756682f152826", size = 236575, upload-time = "2025-06-17T14:14:47.929Z" }, - { url = "https://files.pythonhosted.org/packages/8a/fa/4089d7642ea344226e1bfab60dd588761d4791754f8072e911836a39bedf/multidict-6.5.0-cp313-cp313-musllinux_1_2_aarch64.whl", hash = "sha256:20d30c9410ac3908abbaa52ee5967a754c62142043cf2ba091e39681bd51d21a", size = 247632, upload-time = "2025-06-17T14:14:49.525Z" }, - { url = "https://files.pythonhosted.org/packages/16/ee/a353dac797de0f28fb7f078cc181c5f2eefe8dd16aa11a7100cbdc234037/multidict-6.5.0-cp313-cp313-musllinux_1_2_armv7l.whl", hash = "sha256:6c65068cc026f217e815fa519d8e959a7188e94ec163ffa029c94ca3ef9d4a73", size = 243520, upload-time = "2025-06-17T14:14:50.83Z" }, - { url = "https://files.pythonhosted.org/packages/50/ec/560deb3d2d95822d6eb1bcb1f1cb728f8f0197ec25be7c936d5d6a5d133c/multidict-6.5.0-cp313-cp313-musllinux_1_2_i686.whl", hash = "sha256:e355ac668a8c3e49c2ca8daa4c92f0ad5b705d26da3d5af6f7d971e46c096da7", size = 248551, upload-time = "2025-06-17T14:14:52.229Z" }, - { url = "https://files.pythonhosted.org/packages/10/85/ddf277e67c78205f6695f2a7639be459bca9cc353b962fd8085a492a262f/multidict-6.5.0-cp313-cp313-musllinux_1_2_ppc64le.whl", hash = "sha256:08db204213d0375a91a381cae0677ab95dd8c67a465eb370549daf6dbbf8ba10", size = 258362, upload-time = "2025-06-17T14:14:53.934Z" }, - { url = "https://files.pythonhosted.org/packages/02/fc/d64ee1df9b87c5210f2d4c419cab07f28589c81b4e5711eda05a122d0614/multidict-6.5.0-cp313-cp313-musllinux_1_2_s390x.whl", hash = "sha256:ffa58e3e215af8f6536dc837a990e456129857bb6fd546b3991be470abd9597a", size = 253862, upload-time = "2025-06-17T14:14:55.323Z" }, - { url = "https://files.pythonhosted.org/packages/c9/7c/a2743c00d9e25f4826d3a77cc13d4746398872cf21c843eef96bb9945665/multidict-6.5.0-cp313-cp313-musllinux_1_2_x86_64.whl", hash = "sha256:3e86eb90015c6f21658dbd257bb8e6aa18bdb365b92dd1fba27ec04e58cdc31b", size = 247391, upload-time = "2025-06-17T14:14:57.293Z" }, - { url = "https://files.pythonhosted.org/packages/9b/03/7773518db74c442904dbd349074f1e7f2a854cee4d9529fc59e623d3949e/multidict-6.5.0-cp313-cp313-win32.whl", hash = "sha256:f34a90fbd9959d0f857323bd3c52b3e6011ed48f78d7d7b9e04980b8a41da3af", size = 41115, upload-time = "2025-06-17T14:14:59.33Z" }, - { url = "https://files.pythonhosted.org/packages/eb/9a/6fc51b1dc11a7baa944bc101a92167d8b0f5929d376a8c65168fc0d35917/multidict-6.5.0-cp313-cp313-win_amd64.whl", hash = "sha256:fcb2aa79ac6aef8d5b709bbfc2fdb1d75210ba43038d70fbb595b35af470ce06", size = 44768, upload-time = "2025-06-17T14:15:00.427Z" }, - { url = "https://files.pythonhosted.org/packages/82/2d/0d010be24b663b3c16e3d3307bbba2de5ae8eec496f6027d5c0515b371a8/multidict-6.5.0-cp313-cp313-win_arm64.whl", hash = "sha256:6dcee5e7e92060b4bb9bb6f01efcbb78c13d0e17d9bc6eec71660dd71dc7b0c2", size = 41770, upload-time = "2025-06-17T14:15:01.854Z" }, - { url = "https://files.pythonhosted.org/packages/aa/d1/a71711a5f32f84b7b036e82182e3250b949a0ce70d51a2c6a4079e665449/multidict-6.5.0-cp313-cp313t-macosx_10_13_universal2.whl", hash = "sha256:cbbc88abea2388fde41dd574159dec2cda005cb61aa84950828610cb5010f21a", size = 80450, upload-time = "2025-06-17T14:15:02.968Z" }, - { url = "https://files.pythonhosted.org/packages/0f/a2/953a9eede63a98fcec2c1a2c1a0d88de120056219931013b871884f51b43/multidict-6.5.0-cp313-cp313t-macosx_10_13_x86_64.whl", hash = "sha256:70b599f70ae6536e5976364d3c3cf36f40334708bd6cebdd1e2438395d5e7676", size = 46971, upload-time = "2025-06-17T14:15:04.149Z" }, - { url = "https://files.pythonhosted.org/packages/44/61/60250212953459edda2c729e1d85130912f23c67bd4f585546fe4bdb1578/multidict-6.5.0-cp313-cp313t-macosx_11_0_arm64.whl", hash = "sha256:828bab777aa8d29d59700018178061854e3a47727e0611cb9bec579d3882de3b", size = 45548, upload-time = "2025-06-17T14:15:05.666Z" }, - { url = "https://files.pythonhosted.org/packages/11/b6/e78ee82e96c495bc2582b303f68bed176b481c8d81a441fec07404fce2ca/multidict-6.5.0-cp313-cp313t-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:a9695fc1462f17b131c111cf0856a22ff154b0480f86f539d24b2778571ff94d", size = 238545, upload-time = "2025-06-17T14:15:06.88Z" }, - { url = "https://files.pythonhosted.org/packages/5a/0f/6132ca06670c8d7b374c3a4fd1ba896fc37fbb66b0de903f61db7d1020ec/multidict-6.5.0-cp313-cp313t-manylinux_2_17_armv7l.manylinux2014_armv7l.manylinux_2_31_armv7l.whl", hash = "sha256:0b5ac6ebaf5d9814b15f399337ebc6d3a7f4ce9331edd404e76c49a01620b68d", size = 229931, upload-time = "2025-06-17T14:15:08.24Z" }, - { url = "https://files.pythonhosted.org/packages/c0/63/d9957c506e6df6b3e7a194f0eea62955c12875e454b978f18262a65d017b/multidict-6.5.0-cp313-cp313t-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:84a51e3baa77ded07be4766a9e41d977987b97e49884d4c94f6d30ab6acaee14", size = 248181, upload-time = "2025-06-17T14:15:09.907Z" }, - { url = "https://files.pythonhosted.org/packages/43/3f/7d5490579640db5999a948e2c41d4a0efd91a75989bda3e0a03a79c92be2/multidict-6.5.0-cp313-cp313t-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:8de67f79314d24179e9b1869ed15e88d6ba5452a73fc9891ac142e0ee018b5d6", size = 241846, upload-time = "2025-06-17T14:15:11.596Z" }, - { url = "https://files.pythonhosted.org/packages/e1/f7/252b1ce949ece52bba4c0de7aa2e3a3d5964e800bce71fb778c2e6c66f7c/multidict-6.5.0-cp313-cp313t-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:17f78a52c214481d30550ec18208e287dfc4736f0c0148208334b105fd9e0887", size = 232893, upload-time = "2025-06-17T14:15:12.946Z" }, - { url = "https://files.pythonhosted.org/packages/45/7e/0070bfd48c16afc26e056f2acce49e853c0d604a69c7124bc0bbdb1bcc0a/multidict-6.5.0-cp313-cp313t-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:2966d0099cb2e2039f9b0e73e7fd5eb9c85805681aa2a7f867f9d95b35356921", size = 228567, upload-time = "2025-06-17T14:15:14.267Z" }, - { url = "https://files.pythonhosted.org/packages/2a/31/90551c75322113ebf5fd9c5422e8641d6952f6edaf6b6c07fdc49b1bebdd/multidict-6.5.0-cp313-cp313t-musllinux_1_2_aarch64.whl", hash = "sha256:86fb42ed5ed1971c642cc52acc82491af97567534a8e381a8d50c02169c4e684", size = 246188, upload-time = "2025-06-17T14:15:15.985Z" }, - { url = "https://files.pythonhosted.org/packages/cc/e2/aa4b02a55e7767ff292871023817fe4db83668d514dab7ccbce25eaf7659/multidict-6.5.0-cp313-cp313t-musllinux_1_2_armv7l.whl", hash = "sha256:4e990cbcb6382f9eae4ec720bcac6a1351509e6fc4a5bb70e4984b27973934e6", size = 235178, upload-time = "2025-06-17T14:15:17.395Z" }, - { url = "https://files.pythonhosted.org/packages/7d/5c/f67e726717c4b138b166be1700e2b56e06fbbcb84643d15f9a9d7335ff41/multidict-6.5.0-cp313-cp313t-musllinux_1_2_i686.whl", hash = "sha256:d99a59d64bb1f7f2117bec837d9e534c5aeb5dcedf4c2b16b9753ed28fdc20a3", size = 243422, upload-time = "2025-06-17T14:15:18.939Z" }, - { url = "https://files.pythonhosted.org/packages/e5/1c/15fa318285e26a50aa3fa979bbcffb90f9b4d5ec58882d0590eda067d0da/multidict-6.5.0-cp313-cp313t-musllinux_1_2_ppc64le.whl", hash = "sha256:e8ef15cc97c9890212e1caf90f0d63f6560e1e101cf83aeaf63a57556689fb34", size = 254898, upload-time = "2025-06-17T14:15:20.31Z" }, - { url = "https://files.pythonhosted.org/packages/ad/3d/d6c6d1c2e9b61ca80313912d30bb90d4179335405e421ef0a164eac2c0f9/multidict-6.5.0-cp313-cp313t-musllinux_1_2_s390x.whl", hash = "sha256:b8a09aec921b34bd8b9f842f0bcfd76c6a8c033dc5773511e15f2d517e7e1068", size = 247129, upload-time = "2025-06-17T14:15:21.665Z" }, - { url = "https://files.pythonhosted.org/packages/29/15/1568258cf0090bfa78d44be66247cfdb16e27dfd935c8136a1e8632d3057/multidict-6.5.0-cp313-cp313t-musllinux_1_2_x86_64.whl", hash = "sha256:ff07b504c23b67f2044533244c230808a1258b3493aaf3ea2a0785f70b7be461", size = 243841, upload-time = "2025-06-17T14:15:23.38Z" }, - { url = "https://files.pythonhosted.org/packages/65/57/64af5dbcfd61427056e840c8e520b502879d480f9632fbe210929fd87393/multidict-6.5.0-cp313-cp313t-win32.whl", hash = "sha256:9232a117341e7e979d210e41c04e18f1dc3a1d251268df6c818f5334301274e1", size = 46761, upload-time = "2025-06-17T14:15:24.733Z" }, - { url = "https://files.pythonhosted.org/packages/26/a8/cac7f7d61e188ff44f28e46cb98f9cc21762e671c96e031f06c84a60556e/multidict-6.5.0-cp313-cp313t-win_amd64.whl", hash = "sha256:44cb5c53fb2d4cbcee70a768d796052b75d89b827643788a75ea68189f0980a1", size = 52112, upload-time = "2025-06-17T14:15:25.906Z" }, - { url = "https://files.pythonhosted.org/packages/51/9f/076533feb1b5488d22936da98b9c217205cfbf9f56f7174e8c5c86d86fe6/multidict-6.5.0-cp313-cp313t-win_arm64.whl", hash = "sha256:51d33fafa82640c0217391d4ce895d32b7e84a832b8aee0dcc1b04d8981ec7f4", size = 44358, upload-time = "2025-06-17T14:15:27.117Z" }, - { url = "https://files.pythonhosted.org/packages/44/d8/45e8fc9892a7386d074941429e033adb4640e59ff0780d96a8cf46fe788e/multidict-6.5.0-py3-none-any.whl", hash = "sha256:5634b35f225977605385f56153bd95a7133faffc0ffe12ad26e10517537e8dfc", size = 12181, upload-time = "2025-06-17T14:15:55.156Z" }, -] - -[[package]] -name = "mypy" -version = "1.16.1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "mypy-extensions" }, - { name = "pathspec" }, - { name = "tomli", marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "typing-extensions" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/81/69/92c7fa98112e4d9eb075a239caa4ef4649ad7d441545ccffbd5e34607cbb/mypy-1.16.1.tar.gz", hash = "sha256:6bd00a0a2094841c5e47e7374bb42b83d64c527a502e3334e1173a0c24437bab", size = 3324747, upload-time = "2025-06-16T16:51:35.145Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/8e/12/2bf23a80fcef5edb75de9a1e295d778e0f46ea89eb8b115818b663eff42b/mypy-1.16.1-cp310-cp310-macosx_10_9_x86_64.whl", hash = "sha256:b4f0fed1022a63c6fec38f28b7fc77fca47fd490445c69d0a66266c59dd0b88a", size = 10958644, upload-time = "2025-06-16T16:51:11.649Z" }, - { url = "https://files.pythonhosted.org/packages/08/50/bfe47b3b278eacf348291742fd5e6613bbc4b3434b72ce9361896417cfe5/mypy-1.16.1-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:86042bbf9f5a05ea000d3203cf87aa9d0ccf9a01f73f71c58979eb9249f46d72", size = 10087033, upload-time = "2025-06-16T16:35:30.089Z" }, - { url = "https://files.pythonhosted.org/packages/21/de/40307c12fe25675a0776aaa2cdd2879cf30d99eec91b898de00228dc3ab5/mypy-1.16.1-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.manylinux_2_28_aarch64.whl", hash = "sha256:ea7469ee5902c95542bea7ee545f7006508c65c8c54b06dc2c92676ce526f3ea", size = 11875645, upload-time = "2025-06-16T16:35:48.49Z" }, - { url = "https://files.pythonhosted.org/packages/a6/d8/85bdb59e4a98b7a31495bd8f1a4445d8ffc86cde4ab1f8c11d247c11aedc/mypy-1.16.1-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.manylinux_2_28_x86_64.whl", hash = "sha256:352025753ef6a83cb9e7f2427319bb7875d1fdda8439d1e23de12ab164179574", size = 12616986, upload-time = "2025-06-16T16:48:39.526Z" }, - { url = "https://files.pythonhosted.org/packages/0e/d0/bb25731158fa8f8ee9e068d3e94fcceb4971fedf1424248496292512afe9/mypy-1.16.1-cp310-cp310-musllinux_1_2_x86_64.whl", hash = "sha256:ff9fa5b16e4c1364eb89a4d16bcda9987f05d39604e1e6c35378a2987c1aac2d", size = 12878632, upload-time = "2025-06-16T16:36:08.195Z" }, - { url = "https://files.pythonhosted.org/packages/2d/11/822a9beb7a2b825c0cb06132ca0a5183f8327a5e23ef89717c9474ba0bc6/mypy-1.16.1-cp310-cp310-win_amd64.whl", hash = "sha256:1256688e284632382f8f3b9e2123df7d279f603c561f099758e66dd6ed4e8bd6", size = 9484391, upload-time = "2025-06-16T16:37:56.151Z" }, - { url = "https://files.pythonhosted.org/packages/9a/61/ec1245aa1c325cb7a6c0f8570a2eee3bfc40fa90d19b1267f8e50b5c8645/mypy-1.16.1-cp311-cp311-macosx_10_9_x86_64.whl", hash = "sha256:472e4e4c100062488ec643f6162dd0d5208e33e2f34544e1fc931372e806c0cc", size = 10890557, upload-time = "2025-06-16T16:37:21.421Z" }, - { url = "https://files.pythonhosted.org/packages/6b/bb/6eccc0ba0aa0c7a87df24e73f0ad34170514abd8162eb0c75fd7128171fb/mypy-1.16.1-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:ea16e2a7d2714277e349e24d19a782a663a34ed60864006e8585db08f8ad1782", size = 10012921, upload-time = "2025-06-16T16:51:28.659Z" }, - { url = "https://files.pythonhosted.org/packages/5f/80/b337a12e2006715f99f529e732c5f6a8c143bb58c92bb142d5ab380963a5/mypy-1.16.1-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.manylinux_2_28_aarch64.whl", hash = "sha256:08e850ea22adc4d8a4014651575567b0318ede51e8e9fe7a68f25391af699507", size = 11802887, upload-time = "2025-06-16T16:50:53.627Z" }, - { url = "https://files.pythonhosted.org/packages/d9/59/f7af072d09793d581a745a25737c7c0a945760036b16aeb620f658a017af/mypy-1.16.1-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.manylinux_2_28_x86_64.whl", hash = "sha256:22d76a63a42619bfb90122889b903519149879ddbf2ba4251834727944c8baca", size = 12531658, upload-time = "2025-06-16T16:33:55.002Z" }, - { url = "https://files.pythonhosted.org/packages/82/c4/607672f2d6c0254b94a646cfc45ad589dd71b04aa1f3d642b840f7cce06c/mypy-1.16.1-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:2c7ce0662b6b9dc8f4ed86eb7a5d505ee3298c04b40ec13b30e572c0e5ae17c4", size = 12732486, upload-time = "2025-06-16T16:37:03.301Z" }, - { url = "https://files.pythonhosted.org/packages/b6/5e/136555ec1d80df877a707cebf9081bd3a9f397dedc1ab9750518d87489ec/mypy-1.16.1-cp311-cp311-win_amd64.whl", hash = "sha256:211287e98e05352a2e1d4e8759c5490925a7c784ddc84207f4714822f8cf99b6", size = 9479482, upload-time = "2025-06-16T16:47:37.48Z" }, - { url = "https://files.pythonhosted.org/packages/b4/d6/39482e5fcc724c15bf6280ff5806548c7185e0c090712a3736ed4d07e8b7/mypy-1.16.1-cp312-cp312-macosx_10_13_x86_64.whl", hash = "sha256:af4792433f09575d9eeca5c63d7d90ca4aeceda9d8355e136f80f8967639183d", size = 11066493, upload-time = "2025-06-16T16:47:01.683Z" }, - { url = "https://files.pythonhosted.org/packages/e6/e5/26c347890efc6b757f4d5bb83f4a0cf5958b8cf49c938ac99b8b72b420a6/mypy-1.16.1-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:66df38405fd8466ce3517eda1f6640611a0b8e70895e2a9462d1d4323c5eb4b9", size = 10081687, upload-time = "2025-06-16T16:48:19.367Z" }, - { url = "https://files.pythonhosted.org/packages/44/c7/b5cb264c97b86914487d6a24bd8688c0172e37ec0f43e93b9691cae9468b/mypy-1.16.1-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.manylinux_2_28_aarch64.whl", hash = "sha256:44e7acddb3c48bd2713994d098729494117803616e116032af192871aed80b79", size = 11839723, upload-time = "2025-06-16T16:49:20.912Z" }, - { url = "https://files.pythonhosted.org/packages/15/f8/491997a9b8a554204f834ed4816bda813aefda31cf873bb099deee3c9a99/mypy-1.16.1-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.manylinux_2_28_x86_64.whl", hash = "sha256:0ab5eca37b50188163fa7c1b73c685ac66c4e9bdee4a85c9adac0e91d8895e15", size = 12722980, upload-time = "2025-06-16T16:37:40.929Z" }, - { url = "https://files.pythonhosted.org/packages/df/f0/2bd41e174b5fd93bc9de9a28e4fb673113633b8a7f3a607fa4a73595e468/mypy-1.16.1-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:dedb6229b2c9086247e21a83c309754b9058b438704ad2f6807f0d8227f6ebdd", size = 12903328, upload-time = "2025-06-16T16:34:35.099Z" }, - { url = "https://files.pythonhosted.org/packages/61/81/5572108a7bec2c46b8aff7e9b524f371fe6ab5efb534d38d6b37b5490da8/mypy-1.16.1-cp312-cp312-win_amd64.whl", hash = "sha256:1f0435cf920e287ff68af3d10a118a73f212deb2ce087619eb4e648116d1fe9b", size = 9562321, upload-time = "2025-06-16T16:48:58.823Z" }, - { url = "https://files.pythonhosted.org/packages/28/e3/96964af4a75a949e67df4b95318fe2b7427ac8189bbc3ef28f92a1c5bc56/mypy-1.16.1-cp313-cp313-macosx_10_13_x86_64.whl", hash = "sha256:ddc91eb318c8751c69ddb200a5937f1232ee8efb4e64e9f4bc475a33719de438", size = 11063480, upload-time = "2025-06-16T16:47:56.205Z" }, - { url = "https://files.pythonhosted.org/packages/f5/4d/cd1a42b8e5be278fab7010fb289d9307a63e07153f0ae1510a3d7b703193/mypy-1.16.1-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:87ff2c13d58bdc4bbe7dc0dedfe622c0f04e2cb2a492269f3b418df2de05c536", size = 10090538, upload-time = "2025-06-16T16:46:43.92Z" }, - { url = "https://files.pythonhosted.org/packages/c9/4f/c3c6b4b66374b5f68bab07c8cabd63a049ff69796b844bc759a0ca99bb2a/mypy-1.16.1-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.manylinux_2_28_aarch64.whl", hash = "sha256:0a7cfb0fe29fe5a9841b7c8ee6dffb52382c45acdf68f032145b75620acfbd6f", size = 11836839, upload-time = "2025-06-16T16:36:28.039Z" }, - { url = "https://files.pythonhosted.org/packages/b4/7e/81ca3b074021ad9775e5cb97ebe0089c0f13684b066a750b7dc208438403/mypy-1.16.1-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.manylinux_2_28_x86_64.whl", hash = "sha256:051e1677689c9d9578b9c7f4d206d763f9bbd95723cd1416fad50db49d52f359", size = 12715634, upload-time = "2025-06-16T16:50:34.441Z" }, - { url = "https://files.pythonhosted.org/packages/e9/95/bdd40c8be346fa4c70edb4081d727a54d0a05382d84966869738cfa8a497/mypy-1.16.1-cp313-cp313-musllinux_1_2_x86_64.whl", hash = "sha256:d5d2309511cc56c021b4b4e462907c2b12f669b2dbeb68300110ec27723971be", size = 12895584, upload-time = "2025-06-16T16:34:54.857Z" }, - { url = "https://files.pythonhosted.org/packages/5a/fd/d486a0827a1c597b3b48b1bdef47228a6e9ee8102ab8c28f944cb83b65dc/mypy-1.16.1-cp313-cp313-win_amd64.whl", hash = "sha256:4f58ac32771341e38a853c5d0ec0dfe27e18e27da9cdb8bbc882d2249c71a3ee", size = 9573886, upload-time = "2025-06-16T16:36:43.589Z" }, - { url = "https://files.pythonhosted.org/packages/cf/d3/53e684e78e07c1a2bf7105715e5edd09ce951fc3f47cf9ed095ec1b7a037/mypy-1.16.1-py3-none-any.whl", hash = "sha256:5fc2ac4027d0ef28d6ba69a0343737a23c4d1b83672bf38d1fe237bdc0643b37", size = 2265923, upload-time = "2025-06-16T16:48:02.366Z" }, -] - -[[package]] -name = "mypy-extensions" -version = "1.1.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/a2/6e/371856a3fb9d31ca8dac321cda606860fa4548858c0cc45d9d1d4ca2628b/mypy_extensions-1.1.0.tar.gz", hash = "sha256:52e68efc3284861e772bbcd66823fde5ae21fd2fdb51c62a211403730b916558", size = 6343, upload-time = "2025-04-22T14:54:24.164Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/79/7b/2c79738432f5c924bef5071f933bcc9efd0473bac3b4aa584a6f7c1c8df8/mypy_extensions-1.1.0-py3-none-any.whl", hash = "sha256:1be4cccdb0f2482337c4743e60421de3a356cd97508abadd57d47403e94f5505", size = 4963, upload-time = "2025-04-22T14:54:22.983Z" }, -] - -[[package]] -name = "natsort" -version = "8.4.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/e2/a9/a0c57aee75f77794adaf35322f8b6404cbd0f89ad45c87197a937764b7d0/natsort-8.4.0.tar.gz", hash = "sha256:45312c4a0e5507593da193dedd04abb1469253b601ecaf63445ad80f0a1ea581", size = 76575, upload-time = "2023-06-20T04:17:19.925Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/ef/82/7a9d0550484a62c6da82858ee9419f3dd1ccc9aa1c26a1e43da3ecd20b0d/natsort-8.4.0-py3-none-any.whl", hash = "sha256:4732914fb471f56b5cce04d7bae6f164a592c7712e1c85f9ef585e197299521c", size = 38268, upload-time = "2023-06-20T04:17:17.522Z" }, -] - -[[package]] -name = "nest-asyncio" -version = "1.6.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/83/f8/51569ac65d696c8ecbee95938f89d4abf00f47d58d48f6fbabfe8f0baefe/nest_asyncio-1.6.0.tar.gz", hash = "sha256:6f172d5449aca15afd6c646851f4e31e02c598d553a667e38cafa997cfec55fe", size = 7418, upload-time = "2024-01-21T14:25:19.227Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/a0/c4/c2971a3ba4c6103a3d10c4b0f24f461ddc027f0f09763220cf35ca1401b3/nest_asyncio-1.6.0-py3-none-any.whl", hash = "sha256:87af6efd6b5e897c81050477ef65c62e2b2f35d51703cae01aff2905b1852e1c", size = 5195, upload-time = "2024-01-21T14:25:17.223Z" }, -] - -[[package]] -name = "networkx" -version = "3.4.2" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", -] -sdist = { url = "https://files.pythonhosted.org/packages/fd/1d/06475e1cd5264c0b870ea2cc6fdb3e37177c1e565c43f56ff17a10e3937f/networkx-3.4.2.tar.gz", hash = "sha256:307c3669428c5362aab27c8a1260aa8f47c4e91d3891f48be0141738d8d053e1", size = 2151368, upload-time = "2024-10-21T12:39:38.695Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/b9/54/dd730b32ea14ea797530a4479b2ed46a6fb250f682a9cfb997e968bf0261/networkx-3.4.2-py3-none-any.whl", hash = "sha256:df5d4365b724cf81b8c6a7312509d0c22386097011ad1abe274afd5e9d3bbc5f", size = 1723263, upload-time = "2024-10-21T12:39:36.247Z" }, -] - -[[package]] -name = "networkx" -version = "3.5" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", -] -sdist = { url = "https://files.pythonhosted.org/packages/6c/4f/ccdb8ad3a38e583f214547fd2f7ff1fc160c43a75af88e6aec213404b96a/networkx-3.5.tar.gz", hash = "sha256:d4c6f9cf81f52d69230866796b82afbccdec3db7ae4fbd1b65ea750feed50037", size = 2471065, upload-time = "2025-05-29T11:35:07.804Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/eb/8d/776adee7bbf76365fdd7f2552710282c79a4ead5d2a46408c9043a2b70ba/networkx-3.5-py3-none-any.whl", hash = "sha256:0030d386a9a06dee3565298b4a734b68589749a544acbb6c412dc9e2489ec6ec", size = 2034406, upload-time = "2025-05-29T11:35:04.961Z" }, -] - -[[package]] -name = "numpy" -version = "2.2.6" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", -] -sdist = { url = "https://files.pythonhosted.org/packages/76/21/7d2a95e4bba9dc13d043ee156a356c0a8f0c6309dff6b21b4d71a073b8a8/numpy-2.2.6.tar.gz", hash = "sha256:e29554e2bef54a90aa5cc07da6ce955accb83f21ab5de01a62c8478897b264fd", size = 20276440, upload-time = "2025-05-17T22:38:04.611Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/9a/3e/ed6db5be21ce87955c0cbd3009f2803f59fa08df21b5df06862e2d8e2bdd/numpy-2.2.6-cp310-cp310-macosx_10_9_x86_64.whl", hash = "sha256:b412caa66f72040e6d268491a59f2c43bf03eb6c96dd8f0307829feb7fa2b6fb", size = 21165245, upload-time = "2025-05-17T21:27:58.555Z" }, - { url = "https://files.pythonhosted.org/packages/22/c2/4b9221495b2a132cc9d2eb862e21d42a009f5a60e45fc44b00118c174bff/numpy-2.2.6-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:8e41fd67c52b86603a91c1a505ebaef50b3314de0213461c7a6e99c9a3beff90", size = 14360048, upload-time = "2025-05-17T21:28:21.406Z" }, - { url = "https://files.pythonhosted.org/packages/fd/77/dc2fcfc66943c6410e2bf598062f5959372735ffda175b39906d54f02349/numpy-2.2.6-cp310-cp310-macosx_14_0_arm64.whl", hash = "sha256:37e990a01ae6ec7fe7fa1c26c55ecb672dd98b19c3d0e1d1f326fa13cb38d163", size = 5340542, upload-time = "2025-05-17T21:28:30.931Z" }, - { url = "https://files.pythonhosted.org/packages/7a/4f/1cb5fdc353a5f5cc7feb692db9b8ec2c3d6405453f982435efc52561df58/numpy-2.2.6-cp310-cp310-macosx_14_0_x86_64.whl", hash = "sha256:5a6429d4be8ca66d889b7cf70f536a397dc45ba6faeb5f8c5427935d9592e9cf", size = 6878301, upload-time = "2025-05-17T21:28:41.613Z" }, - { url = "https://files.pythonhosted.org/packages/eb/17/96a3acd228cec142fcb8723bd3cc39c2a474f7dcf0a5d16731980bcafa95/numpy-2.2.6-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:efd28d4e9cd7d7a8d39074a4d44c63eda73401580c5c76acda2ce969e0a38e83", size = 14297320, upload-time = "2025-05-17T21:29:02.78Z" }, - { url = "https://files.pythonhosted.org/packages/b4/63/3de6a34ad7ad6646ac7d2f55ebc6ad439dbbf9c4370017c50cf403fb19b5/numpy-2.2.6-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:fc7b73d02efb0e18c000e9ad8b83480dfcd5dfd11065997ed4c6747470ae8915", size = 16801050, upload-time = "2025-05-17T21:29:27.675Z" }, - { url = "https://files.pythonhosted.org/packages/07/b6/89d837eddef52b3d0cec5c6ba0456c1bf1b9ef6a6672fc2b7873c3ec4e2e/numpy-2.2.6-cp310-cp310-musllinux_1_2_aarch64.whl", hash = "sha256:74d4531beb257d2c3f4b261bfb0fc09e0f9ebb8842d82a7b4209415896adc680", size = 15807034, upload-time = "2025-05-17T21:29:51.102Z" }, - { url = "https://files.pythonhosted.org/packages/01/c8/dc6ae86e3c61cfec1f178e5c9f7858584049b6093f843bca541f94120920/numpy-2.2.6-cp310-cp310-musllinux_1_2_x86_64.whl", hash = "sha256:8fc377d995680230e83241d8a96def29f204b5782f371c532579b4f20607a289", size = 18614185, upload-time = "2025-05-17T21:30:18.703Z" }, - { url = "https://files.pythonhosted.org/packages/5b/c5/0064b1b7e7c89137b471ccec1fd2282fceaae0ab3a9550f2568782d80357/numpy-2.2.6-cp310-cp310-win32.whl", hash = "sha256:b093dd74e50a8cba3e873868d9e93a85b78e0daf2e98c6797566ad8044e8363d", size = 6527149, upload-time = "2025-05-17T21:30:29.788Z" }, - { url = "https://files.pythonhosted.org/packages/a3/dd/4b822569d6b96c39d1215dbae0582fd99954dcbcf0c1a13c61783feaca3f/numpy-2.2.6-cp310-cp310-win_amd64.whl", hash = "sha256:f0fd6321b839904e15c46e0d257fdd101dd7f530fe03fd6359c1ea63738703f3", size = 12904620, upload-time = "2025-05-17T21:30:48.994Z" }, - { url = "https://files.pythonhosted.org/packages/da/a8/4f83e2aa666a9fbf56d6118faaaf5f1974d456b1823fda0a176eff722839/numpy-2.2.6-cp311-cp311-macosx_10_9_x86_64.whl", hash = "sha256:f9f1adb22318e121c5c69a09142811a201ef17ab257a1e66ca3025065b7f53ae", size = 21176963, upload-time = "2025-05-17T21:31:19.36Z" }, - { url = "https://files.pythonhosted.org/packages/b3/2b/64e1affc7972decb74c9e29e5649fac940514910960ba25cd9af4488b66c/numpy-2.2.6-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:c820a93b0255bc360f53eca31a0e676fd1101f673dda8da93454a12e23fc5f7a", size = 14406743, upload-time = "2025-05-17T21:31:41.087Z" }, - { url = "https://files.pythonhosted.org/packages/4a/9f/0121e375000b5e50ffdd8b25bf78d8e1a5aa4cca3f185d41265198c7b834/numpy-2.2.6-cp311-cp311-macosx_14_0_arm64.whl", hash = "sha256:3d70692235e759f260c3d837193090014aebdf026dfd167834bcba43e30c2a42", size = 5352616, upload-time = "2025-05-17T21:31:50.072Z" }, - { url = "https://files.pythonhosted.org/packages/31/0d/b48c405c91693635fbe2dcd7bc84a33a602add5f63286e024d3b6741411c/numpy-2.2.6-cp311-cp311-macosx_14_0_x86_64.whl", hash = "sha256:481b49095335f8eed42e39e8041327c05b0f6f4780488f61286ed3c01368d491", size = 6889579, upload-time = "2025-05-17T21:32:01.712Z" }, - { url = "https://files.pythonhosted.org/packages/52/b8/7f0554d49b565d0171eab6e99001846882000883998e7b7d9f0d98b1f934/numpy-2.2.6-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:b64d8d4d17135e00c8e346e0a738deb17e754230d7e0810ac5012750bbd85a5a", size = 14312005, upload-time = "2025-05-17T21:32:23.332Z" }, - { url = "https://files.pythonhosted.org/packages/b3/dd/2238b898e51bd6d389b7389ffb20d7f4c10066d80351187ec8e303a5a475/numpy-2.2.6-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:ba10f8411898fc418a521833e014a77d3ca01c15b0c6cdcce6a0d2897e6dbbdf", size = 16821570, upload-time = "2025-05-17T21:32:47.991Z" }, - { url = "https://files.pythonhosted.org/packages/83/6c/44d0325722cf644f191042bf47eedad61c1e6df2432ed65cbe28509d404e/numpy-2.2.6-cp311-cp311-musllinux_1_2_aarch64.whl", hash = "sha256:bd48227a919f1bafbdda0583705e547892342c26fb127219d60a5c36882609d1", size = 15818548, upload-time = "2025-05-17T21:33:11.728Z" }, - { url = "https://files.pythonhosted.org/packages/ae/9d/81e8216030ce66be25279098789b665d49ff19eef08bfa8cb96d4957f422/numpy-2.2.6-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:9551a499bf125c1d4f9e250377c1ee2eddd02e01eac6644c080162c0c51778ab", size = 18620521, upload-time = "2025-05-17T21:33:39.139Z" }, - { url = "https://files.pythonhosted.org/packages/6a/fd/e19617b9530b031db51b0926eed5345ce8ddc669bb3bc0044b23e275ebe8/numpy-2.2.6-cp311-cp311-win32.whl", hash = "sha256:0678000bb9ac1475cd454c6b8c799206af8107e310843532b04d49649c717a47", size = 6525866, upload-time = "2025-05-17T21:33:50.273Z" }, - { url = "https://files.pythonhosted.org/packages/31/0a/f354fb7176b81747d870f7991dc763e157a934c717b67b58456bc63da3df/numpy-2.2.6-cp311-cp311-win_amd64.whl", hash = "sha256:e8213002e427c69c45a52bbd94163084025f533a55a59d6f9c5b820774ef3303", size = 12907455, upload-time = "2025-05-17T21:34:09.135Z" }, - { url = "https://files.pythonhosted.org/packages/82/5d/c00588b6cf18e1da539b45d3598d3557084990dcc4331960c15ee776ee41/numpy-2.2.6-cp312-cp312-macosx_10_13_x86_64.whl", hash = "sha256:41c5a21f4a04fa86436124d388f6ed60a9343a6f767fced1a8a71c3fbca038ff", size = 20875348, upload-time = "2025-05-17T21:34:39.648Z" }, - { url = "https://files.pythonhosted.org/packages/66/ee/560deadcdde6c2f90200450d5938f63a34b37e27ebff162810f716f6a230/numpy-2.2.6-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:de749064336d37e340f640b05f24e9e3dd678c57318c7289d222a8a2f543e90c", size = 14119362, upload-time = "2025-05-17T21:35:01.241Z" }, - { url = "https://files.pythonhosted.org/packages/3c/65/4baa99f1c53b30adf0acd9a5519078871ddde8d2339dc5a7fde80d9d87da/numpy-2.2.6-cp312-cp312-macosx_14_0_arm64.whl", hash = "sha256:894b3a42502226a1cac872f840030665f33326fc3dac8e57c607905773cdcde3", size = 5084103, upload-time = "2025-05-17T21:35:10.622Z" }, - { url = "https://files.pythonhosted.org/packages/cc/89/e5a34c071a0570cc40c9a54eb472d113eea6d002e9ae12bb3a8407fb912e/numpy-2.2.6-cp312-cp312-macosx_14_0_x86_64.whl", hash = "sha256:71594f7c51a18e728451bb50cc60a3ce4e6538822731b2933209a1f3614e9282", size = 6625382, upload-time = "2025-05-17T21:35:21.414Z" }, - { url = "https://files.pythonhosted.org/packages/f8/35/8c80729f1ff76b3921d5c9487c7ac3de9b2a103b1cd05e905b3090513510/numpy-2.2.6-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:f2618db89be1b4e05f7a1a847a9c1c0abd63e63a1607d892dd54668dd92faf87", size = 14018462, upload-time = "2025-05-17T21:35:42.174Z" }, - { url = "https://files.pythonhosted.org/packages/8c/3d/1e1db36cfd41f895d266b103df00ca5b3cbe965184df824dec5c08c6b803/numpy-2.2.6-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:fd83c01228a688733f1ded5201c678f0c53ecc1006ffbc404db9f7a899ac6249", size = 16527618, upload-time = "2025-05-17T21:36:06.711Z" }, - { url = "https://files.pythonhosted.org/packages/61/c6/03ed30992602c85aa3cd95b9070a514f8b3c33e31124694438d88809ae36/numpy-2.2.6-cp312-cp312-musllinux_1_2_aarch64.whl", hash = "sha256:37c0ca431f82cd5fa716eca9506aefcabc247fb27ba69c5062a6d3ade8cf8f49", size = 15505511, upload-time = "2025-05-17T21:36:29.965Z" }, - { url = "https://files.pythonhosted.org/packages/b7/25/5761d832a81df431e260719ec45de696414266613c9ee268394dd5ad8236/numpy-2.2.6-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:fe27749d33bb772c80dcd84ae7e8df2adc920ae8297400dabec45f0dedb3f6de", size = 18313783, upload-time = "2025-05-17T21:36:56.883Z" }, - { url = "https://files.pythonhosted.org/packages/57/0a/72d5a3527c5ebffcd47bde9162c39fae1f90138c961e5296491ce778e682/numpy-2.2.6-cp312-cp312-win32.whl", hash = "sha256:4eeaae00d789f66c7a25ac5f34b71a7035bb474e679f410e5e1a94deb24cf2d4", size = 6246506, upload-time = "2025-05-17T21:37:07.368Z" }, - { url = "https://files.pythonhosted.org/packages/36/fa/8c9210162ca1b88529ab76b41ba02d433fd54fecaf6feb70ef9f124683f1/numpy-2.2.6-cp312-cp312-win_amd64.whl", hash = "sha256:c1f9540be57940698ed329904db803cf7a402f3fc200bfe599334c9bd84a40b2", size = 12614190, upload-time = "2025-05-17T21:37:26.213Z" }, - { url = "https://files.pythonhosted.org/packages/f9/5c/6657823f4f594f72b5471f1db1ab12e26e890bb2e41897522d134d2a3e81/numpy-2.2.6-cp313-cp313-macosx_10_13_x86_64.whl", hash = "sha256:0811bb762109d9708cca4d0b13c4f67146e3c3b7cf8d34018c722adb2d957c84", size = 20867828, upload-time = "2025-05-17T21:37:56.699Z" }, - { url = "https://files.pythonhosted.org/packages/dc/9e/14520dc3dadf3c803473bd07e9b2bd1b69bc583cb2497b47000fed2fa92f/numpy-2.2.6-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:287cc3162b6f01463ccd86be154f284d0893d2b3ed7292439ea97eafa8170e0b", size = 14143006, upload-time = "2025-05-17T21:38:18.291Z" }, - { url = "https://files.pythonhosted.org/packages/4f/06/7e96c57d90bebdce9918412087fc22ca9851cceaf5567a45c1f404480e9e/numpy-2.2.6-cp313-cp313-macosx_14_0_arm64.whl", hash = "sha256:f1372f041402e37e5e633e586f62aa53de2eac8d98cbfb822806ce4bbefcb74d", size = 5076765, upload-time = "2025-05-17T21:38:27.319Z" }, - { url = "https://files.pythonhosted.org/packages/73/ed/63d920c23b4289fdac96ddbdd6132e9427790977d5457cd132f18e76eae0/numpy-2.2.6-cp313-cp313-macosx_14_0_x86_64.whl", hash = "sha256:55a4d33fa519660d69614a9fad433be87e5252f4b03850642f88993f7b2ca566", size = 6617736, upload-time = "2025-05-17T21:38:38.141Z" }, - { url = "https://files.pythonhosted.org/packages/85/c5/e19c8f99d83fd377ec8c7e0cf627a8049746da54afc24ef0a0cb73d5dfb5/numpy-2.2.6-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:f92729c95468a2f4f15e9bb94c432a9229d0d50de67304399627a943201baa2f", size = 14010719, upload-time = "2025-05-17T21:38:58.433Z" }, - { url = "https://files.pythonhosted.org/packages/19/49/4df9123aafa7b539317bf6d342cb6d227e49f7a35b99c287a6109b13dd93/numpy-2.2.6-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:1bc23a79bfabc5d056d106f9befb8d50c31ced2fbc70eedb8155aec74a45798f", size = 16526072, upload-time = "2025-05-17T21:39:22.638Z" }, - { url = "https://files.pythonhosted.org/packages/b2/6c/04b5f47f4f32f7c2b0e7260442a8cbcf8168b0e1a41ff1495da42f42a14f/numpy-2.2.6-cp313-cp313-musllinux_1_2_aarch64.whl", hash = "sha256:e3143e4451880bed956e706a3220b4e5cf6172ef05fcc397f6f36a550b1dd868", size = 15503213, upload-time = "2025-05-17T21:39:45.865Z" }, - { url = "https://files.pythonhosted.org/packages/17/0a/5cd92e352c1307640d5b6fec1b2ffb06cd0dabe7d7b8227f97933d378422/numpy-2.2.6-cp313-cp313-musllinux_1_2_x86_64.whl", hash = "sha256:b4f13750ce79751586ae2eb824ba7e1e8dba64784086c98cdbbcc6a42112ce0d", size = 18316632, upload-time = "2025-05-17T21:40:13.331Z" }, - { url = "https://files.pythonhosted.org/packages/f0/3b/5cba2b1d88760ef86596ad0f3d484b1cbff7c115ae2429678465057c5155/numpy-2.2.6-cp313-cp313-win32.whl", hash = "sha256:5beb72339d9d4fa36522fc63802f469b13cdbe4fdab4a288f0c441b74272ebfd", size = 6244532, upload-time = "2025-05-17T21:43:46.099Z" }, - { url = "https://files.pythonhosted.org/packages/cb/3b/d58c12eafcb298d4e6d0d40216866ab15f59e55d148a5658bb3132311fcf/numpy-2.2.6-cp313-cp313-win_amd64.whl", hash = "sha256:b0544343a702fa80c95ad5d3d608ea3599dd54d4632df855e4c8d24eb6ecfa1c", size = 12610885, upload-time = "2025-05-17T21:44:05.145Z" }, - { url = "https://files.pythonhosted.org/packages/6b/9e/4bf918b818e516322db999ac25d00c75788ddfd2d2ade4fa66f1f38097e1/numpy-2.2.6-cp313-cp313t-macosx_10_13_x86_64.whl", hash = "sha256:0bca768cd85ae743b2affdc762d617eddf3bcf8724435498a1e80132d04879e6", size = 20963467, upload-time = "2025-05-17T21:40:44Z" }, - { url = "https://files.pythonhosted.org/packages/61/66/d2de6b291507517ff2e438e13ff7b1e2cdbdb7cb40b3ed475377aece69f9/numpy-2.2.6-cp313-cp313t-macosx_11_0_arm64.whl", hash = "sha256:fc0c5673685c508a142ca65209b4e79ed6740a4ed6b2267dbba90f34b0b3cfda", size = 14225144, upload-time = "2025-05-17T21:41:05.695Z" }, - { url = "https://files.pythonhosted.org/packages/e4/25/480387655407ead912e28ba3a820bc69af9adf13bcbe40b299d454ec011f/numpy-2.2.6-cp313-cp313t-macosx_14_0_arm64.whl", hash = "sha256:5bd4fc3ac8926b3819797a7c0e2631eb889b4118a9898c84f585a54d475b7e40", size = 5200217, upload-time = "2025-05-17T21:41:15.903Z" }, - { url = "https://files.pythonhosted.org/packages/aa/4a/6e313b5108f53dcbf3aca0c0f3e9c92f4c10ce57a0a721851f9785872895/numpy-2.2.6-cp313-cp313t-macosx_14_0_x86_64.whl", hash = "sha256:fee4236c876c4e8369388054d02d0e9bb84821feb1a64dd59e137e6511a551f8", size = 6712014, upload-time = "2025-05-17T21:41:27.321Z" }, - { url = "https://files.pythonhosted.org/packages/b7/30/172c2d5c4be71fdf476e9de553443cf8e25feddbe185e0bd88b096915bcc/numpy-2.2.6-cp313-cp313t-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:e1dda9c7e08dc141e0247a5b8f49cf05984955246a327d4c48bda16821947b2f", size = 14077935, upload-time = "2025-05-17T21:41:49.738Z" }, - { url = "https://files.pythonhosted.org/packages/12/fb/9e743f8d4e4d3c710902cf87af3512082ae3d43b945d5d16563f26ec251d/numpy-2.2.6-cp313-cp313t-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:f447e6acb680fd307f40d3da4852208af94afdfab89cf850986c3ca00562f4fa", size = 16600122, upload-time = "2025-05-17T21:42:14.046Z" }, - { url = "https://files.pythonhosted.org/packages/12/75/ee20da0e58d3a66f204f38916757e01e33a9737d0b22373b3eb5a27358f9/numpy-2.2.6-cp313-cp313t-musllinux_1_2_aarch64.whl", hash = "sha256:389d771b1623ec92636b0786bc4ae56abafad4a4c513d36a55dce14bd9ce8571", size = 15586143, upload-time = "2025-05-17T21:42:37.464Z" }, - { url = "https://files.pythonhosted.org/packages/76/95/bef5b37f29fc5e739947e9ce5179ad402875633308504a52d188302319c8/numpy-2.2.6-cp313-cp313t-musllinux_1_2_x86_64.whl", hash = "sha256:8e9ace4a37db23421249ed236fdcdd457d671e25146786dfc96835cd951aa7c1", size = 18385260, upload-time = "2025-05-17T21:43:05.189Z" }, - { url = "https://files.pythonhosted.org/packages/09/04/f2f83279d287407cf36a7a8053a5abe7be3622a4363337338f2585e4afda/numpy-2.2.6-cp313-cp313t-win32.whl", hash = "sha256:038613e9fb8c72b0a41f025a7e4c3f0b7a1b5d768ece4796b674c8f3fe13efff", size = 6377225, upload-time = "2025-05-17T21:43:16.254Z" }, - { url = "https://files.pythonhosted.org/packages/67/0e/35082d13c09c02c011cf21570543d202ad929d961c02a147493cb0c2bdf5/numpy-2.2.6-cp313-cp313t-win_amd64.whl", hash = "sha256:6031dd6dfecc0cf9f668681a37648373bddd6421fff6c66ec1624eed0180ee06", size = 12771374, upload-time = "2025-05-17T21:43:35.479Z" }, - { url = "https://files.pythonhosted.org/packages/9e/3b/d94a75f4dbf1ef5d321523ecac21ef23a3cd2ac8b78ae2aac40873590229/numpy-2.2.6-pp310-pypy310_pp73-macosx_10_15_x86_64.whl", hash = "sha256:0b605b275d7bd0c640cad4e5d30fa701a8d59302e127e5f79138ad62762c3e3d", size = 21040391, upload-time = "2025-05-17T21:44:35.948Z" }, - { url = "https://files.pythonhosted.org/packages/17/f4/09b2fa1b58f0fb4f7c7963a1649c64c4d315752240377ed74d9cd878f7b5/numpy-2.2.6-pp310-pypy310_pp73-macosx_14_0_x86_64.whl", hash = "sha256:7befc596a7dc9da8a337f79802ee8adb30a552a94f792b9c9d18c840055907db", size = 6786754, upload-time = "2025-05-17T21:44:47.446Z" }, - { url = "https://files.pythonhosted.org/packages/af/30/feba75f143bdc868a1cc3f44ccfa6c4b9ec522b36458e738cd00f67b573f/numpy-2.2.6-pp310-pypy310_pp73-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:ce47521a4754c8f4593837384bd3424880629f718d87c5d44f8ed763edd63543", size = 16643476, upload-time = "2025-05-17T21:45:11.871Z" }, - { url = "https://files.pythonhosted.org/packages/37/48/ac2a9584402fb6c0cd5b5d1a91dcf176b15760130dd386bbafdbfe3640bf/numpy-2.2.6-pp310-pypy310_pp73-win_amd64.whl", hash = "sha256:d042d24c90c41b54fd506da306759e06e568864df8ec17ccc17e9e884634fd00", size = 12812666, upload-time = "2025-05-17T21:45:31.426Z" }, -] - -[[package]] -name = "numpy" -version = "2.3.0" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", -] -sdist = { url = "https://files.pythonhosted.org/packages/f3/db/8e12381333aea300890829a0a36bfa738cac95475d88982d538725143fd9/numpy-2.3.0.tar.gz", hash = "sha256:581f87f9e9e9db2cba2141400e160e9dd644ee248788d6f90636eeb8fd9260a6", size = 20382813, upload-time = "2025-06-07T14:54:32.608Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/fd/5f/df67435257d827eb3b8af66f585223dc2c3f2eb7ad0b50cb1dae2f35f494/numpy-2.3.0-cp311-cp311-macosx_10_9_x86_64.whl", hash = "sha256:c3c9fdde0fa18afa1099d6257eb82890ea4f3102847e692193b54e00312a9ae9", size = 21199688, upload-time = "2025-06-07T14:36:52.067Z" }, - { url = "https://files.pythonhosted.org/packages/e5/ce/aad219575055d6c9ef29c8c540c81e1c38815d3be1fe09cdbe53d48ee838/numpy-2.3.0-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:46d16f72c2192da7b83984aa5455baee640e33a9f1e61e656f29adf55e406c2b", size = 14359277, upload-time = "2025-06-07T14:37:15.325Z" }, - { url = "https://files.pythonhosted.org/packages/29/6b/2d31da8e6d2ec99bed54c185337a87f8fbeccc1cd9804e38217e92f3f5e2/numpy-2.3.0-cp311-cp311-macosx_14_0_arm64.whl", hash = "sha256:a0be278be9307c4ab06b788f2a077f05e180aea817b3e41cebbd5aaf7bd85ed3", size = 5376069, upload-time = "2025-06-07T14:37:25.636Z" }, - { url = "https://files.pythonhosted.org/packages/7d/2a/6c59a062397553ec7045c53d5fcdad44e4536e54972faa2ba44153bca984/numpy-2.3.0-cp311-cp311-macosx_14_0_x86_64.whl", hash = "sha256:99224862d1412d2562248d4710126355d3a8db7672170a39d6909ac47687a8a4", size = 6913057, upload-time = "2025-06-07T14:37:37.215Z" }, - { url = "https://files.pythonhosted.org/packages/d5/5a/8df16f258d28d033e4f359e29d3aeb54663243ac7b71504e89deeb813202/numpy-2.3.0-cp311-cp311-manylinux_2_28_aarch64.whl", hash = "sha256:2393a914db64b0ead0ab80c962e42d09d5f385802006a6c87835acb1f58adb96", size = 14568083, upload-time = "2025-06-07T14:37:59.337Z" }, - { url = "https://files.pythonhosted.org/packages/0a/92/0528a563dfc2cdccdcb208c0e241a4bb500d7cde218651ffb834e8febc50/numpy-2.3.0-cp311-cp311-manylinux_2_28_x86_64.whl", hash = "sha256:7729c8008d55e80784bd113787ce876ca117185c579c0d626f59b87d433ea779", size = 16929402, upload-time = "2025-06-07T14:38:24.343Z" }, - { url = "https://files.pythonhosted.org/packages/e4/2f/e7a8c8d4a2212c527568d84f31587012cf5497a7271ea1f23332142f634e/numpy-2.3.0-cp311-cp311-musllinux_1_2_aarch64.whl", hash = "sha256:06d4fb37a8d383b769281714897420c5cc3545c79dc427df57fc9b852ee0bf58", size = 15879193, upload-time = "2025-06-07T14:38:48.007Z" }, - { url = "https://files.pythonhosted.org/packages/e2/c3/dada3f005953847fe35f42ac0fe746f6e1ea90b4c6775e4be605dcd7b578/numpy-2.3.0-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:c39ec392b5db5088259c68250e342612db82dc80ce044cf16496cf14cf6bc6f8", size = 18665318, upload-time = "2025-06-07T14:39:15.794Z" }, - { url = "https://files.pythonhosted.org/packages/3b/ae/3f448517dedefc8dd64d803f9d51a8904a48df730e00a3c5fb1e75a60620/numpy-2.3.0-cp311-cp311-win32.whl", hash = "sha256:ee9d3ee70d62827bc91f3ea5eee33153212c41f639918550ac0475e3588da59f", size = 6601108, upload-time = "2025-06-07T14:39:27.176Z" }, - { url = "https://files.pythonhosted.org/packages/8c/4a/556406d2bb2b9874c8cbc840c962683ac28f21efbc9b01177d78f0199ca1/numpy-2.3.0-cp311-cp311-win_amd64.whl", hash = "sha256:43c55b6a860b0eb44d42341438b03513cf3879cb3617afb749ad49307e164edd", size = 13021525, upload-time = "2025-06-07T14:39:46.637Z" }, - { url = "https://files.pythonhosted.org/packages/ed/ee/bf54278aef30335ffa9a189f869ea09e1a195b3f4b93062164a3b02678a7/numpy-2.3.0-cp311-cp311-win_arm64.whl", hash = "sha256:2e6a1409eee0cb0316cb64640a49a49ca44deb1a537e6b1121dc7c458a1299a8", size = 10170327, upload-time = "2025-06-07T14:40:02.703Z" }, - { url = "https://files.pythonhosted.org/packages/89/59/9df493df81ac6f76e9f05cdbe013cdb0c9a37b434f6e594f5bd25e278908/numpy-2.3.0-cp312-cp312-macosx_10_13_x86_64.whl", hash = "sha256:389b85335838155a9076e9ad7f8fdba0827496ec2d2dc32ce69ce7898bde03ba", size = 20897025, upload-time = "2025-06-07T14:40:33.558Z" }, - { url = "https://files.pythonhosted.org/packages/2f/86/4ff04335901d6cf3a6bb9c748b0097546ae5af35e455ae9b962ebff4ecd7/numpy-2.3.0-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:9498f60cd6bb8238d8eaf468a3d5bb031d34cd12556af53510f05fcf581c1b7e", size = 14129882, upload-time = "2025-06-07T14:40:55.034Z" }, - { url = "https://files.pythonhosted.org/packages/71/8d/a942cd4f959de7f08a79ab0c7e6cecb7431d5403dce78959a726f0f57aa1/numpy-2.3.0-cp312-cp312-macosx_14_0_arm64.whl", hash = "sha256:622a65d40d8eb427d8e722fd410ac3ad4958002f109230bc714fa551044ebae2", size = 5110181, upload-time = "2025-06-07T14:41:04.4Z" }, - { url = "https://files.pythonhosted.org/packages/86/5d/45850982efc7b2c839c5626fb67fbbc520d5b0d7c1ba1ae3651f2f74c296/numpy-2.3.0-cp312-cp312-macosx_14_0_x86_64.whl", hash = "sha256:b9446d9d8505aadadb686d51d838f2b6688c9e85636a0c3abaeb55ed54756459", size = 6647581, upload-time = "2025-06-07T14:41:14.695Z" }, - { url = "https://files.pythonhosted.org/packages/1a/c0/c871d4a83f93b00373d3eebe4b01525eee8ef10b623a335ec262b58f4dc1/numpy-2.3.0-cp312-cp312-manylinux_2_28_aarch64.whl", hash = "sha256:50080245365d75137a2bf46151e975de63146ae6d79f7e6bd5c0e85c9931d06a", size = 14262317, upload-time = "2025-06-07T14:41:35.862Z" }, - { url = "https://files.pythonhosted.org/packages/b7/f6/bc47f5fa666d5ff4145254f9e618d56e6a4ef9b874654ca74c19113bb538/numpy-2.3.0-cp312-cp312-manylinux_2_28_x86_64.whl", hash = "sha256:c24bb4113c66936eeaa0dc1e47c74770453d34f46ee07ae4efd853a2ed1ad10a", size = 16633919, upload-time = "2025-06-07T14:42:00.622Z" }, - { url = "https://files.pythonhosted.org/packages/f5/b4/65f48009ca0c9b76df5f404fccdea5a985a1bb2e34e97f21a17d9ad1a4ba/numpy-2.3.0-cp312-cp312-musllinux_1_2_aarch64.whl", hash = "sha256:4d8d294287fdf685281e671886c6dcdf0291a7c19db3e5cb4178d07ccf6ecc67", size = 15567651, upload-time = "2025-06-07T14:42:24.429Z" }, - { url = "https://files.pythonhosted.org/packages/f1/62/5367855a2018578e9334ed08252ef67cc302e53edc869666f71641cad40b/numpy-2.3.0-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:6295f81f093b7f5769d1728a6bd8bf7466de2adfa771ede944ce6711382b89dc", size = 18361723, upload-time = "2025-06-07T14:42:51.167Z" }, - { url = "https://files.pythonhosted.org/packages/d4/75/5baed8cd867eabee8aad1e74d7197d73971d6a3d40c821f1848b8fab8b84/numpy-2.3.0-cp312-cp312-win32.whl", hash = "sha256:e6648078bdd974ef5d15cecc31b0c410e2e24178a6e10bf511e0557eed0f2570", size = 6318285, upload-time = "2025-06-07T14:43:02.052Z" }, - { url = "https://files.pythonhosted.org/packages/bc/49/d5781eaa1a15acb3b3a3f49dc9e2ff18d92d0ce5c2976f4ab5c0a7360250/numpy-2.3.0-cp312-cp312-win_amd64.whl", hash = "sha256:0898c67a58cdaaf29994bc0e2c65230fd4de0ac40afaf1584ed0b02cd74c6fdd", size = 12732594, upload-time = "2025-06-07T14:43:21.071Z" }, - { url = "https://files.pythonhosted.org/packages/c2/1c/6d343e030815c7c97a1f9fbad00211b47717c7fe446834c224bd5311e6f1/numpy-2.3.0-cp312-cp312-win_arm64.whl", hash = "sha256:bd8df082b6c4695753ad6193018c05aac465d634834dca47a3ae06d4bb22d9ea", size = 9891498, upload-time = "2025-06-07T14:43:36.332Z" }, - { url = "https://files.pythonhosted.org/packages/73/fc/1d67f751fd4dbafc5780244fe699bc4084268bad44b7c5deb0492473127b/numpy-2.3.0-cp313-cp313-macosx_10_13_x86_64.whl", hash = "sha256:5754ab5595bfa2c2387d241296e0381c21f44a4b90a776c3c1d39eede13a746a", size = 20889633, upload-time = "2025-06-07T14:44:06.839Z" }, - { url = "https://files.pythonhosted.org/packages/e8/95/73ffdb69e5c3f19ec4530f8924c4386e7ba097efc94b9c0aff607178ad94/numpy-2.3.0-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:d11fa02f77752d8099573d64e5fe33de3229b6632036ec08f7080f46b6649959", size = 14151683, upload-time = "2025-06-07T14:44:28.847Z" }, - { url = "https://files.pythonhosted.org/packages/64/d5/06d4bb31bb65a1d9c419eb5676173a2f90fd8da3c59f816cc54c640ce265/numpy-2.3.0-cp313-cp313-macosx_14_0_arm64.whl", hash = "sha256:aba48d17e87688a765ab1cd557882052f238e2f36545dfa8e29e6a91aef77afe", size = 5102683, upload-time = "2025-06-07T14:44:38.417Z" }, - { url = "https://files.pythonhosted.org/packages/12/8b/6c2cef44f8ccdc231f6b56013dff1d71138c48124334aded36b1a1b30c5a/numpy-2.3.0-cp313-cp313-macosx_14_0_x86_64.whl", hash = "sha256:4dc58865623023b63b10d52f18abaac3729346a7a46a778381e0e3af4b7f3beb", size = 6640253, upload-time = "2025-06-07T14:44:49.359Z" }, - { url = "https://files.pythonhosted.org/packages/62/aa/fca4bf8de3396ddb59544df9b75ffe5b73096174de97a9492d426f5cd4aa/numpy-2.3.0-cp313-cp313-manylinux_2_28_aarch64.whl", hash = "sha256:df470d376f54e052c76517393fa443758fefcdd634645bc9c1f84eafc67087f0", size = 14258658, upload-time = "2025-06-07T14:45:10.156Z" }, - { url = "https://files.pythonhosted.org/packages/1c/12/734dce1087eed1875f2297f687e671cfe53a091b6f2f55f0c7241aad041b/numpy-2.3.0-cp313-cp313-manylinux_2_28_x86_64.whl", hash = "sha256:87717eb24d4a8a64683b7a4e91ace04e2f5c7c77872f823f02a94feee186168f", size = 16628765, upload-time = "2025-06-07T14:45:35.076Z" }, - { url = "https://files.pythonhosted.org/packages/48/03/ffa41ade0e825cbcd5606a5669962419528212a16082763fc051a7247d76/numpy-2.3.0-cp313-cp313-musllinux_1_2_aarch64.whl", hash = "sha256:d8fa264d56882b59dcb5ea4d6ab6f31d0c58a57b41aec605848b6eb2ef4a43e8", size = 15564335, upload-time = "2025-06-07T14:45:58.797Z" }, - { url = "https://files.pythonhosted.org/packages/07/58/869398a11863310aee0ff85a3e13b4c12f20d032b90c4b3ee93c3b728393/numpy-2.3.0-cp313-cp313-musllinux_1_2_x86_64.whl", hash = "sha256:e651756066a0eaf900916497e20e02fe1ae544187cb0fe88de981671ee7f6270", size = 18360608, upload-time = "2025-06-07T14:46:25.687Z" }, - { url = "https://files.pythonhosted.org/packages/2f/8a/5756935752ad278c17e8a061eb2127c9a3edf4ba2c31779548b336f23c8d/numpy-2.3.0-cp313-cp313-win32.whl", hash = "sha256:e43c3cce3b6ae5f94696669ff2a6eafd9a6b9332008bafa4117af70f4b88be6f", size = 6310005, upload-time = "2025-06-07T14:50:13.138Z" }, - { url = "https://files.pythonhosted.org/packages/08/60/61d60cf0dfc0bf15381eaef46366ebc0c1a787856d1db0c80b006092af84/numpy-2.3.0-cp313-cp313-win_amd64.whl", hash = "sha256:81ae0bf2564cf475f94be4a27ef7bcf8af0c3e28da46770fc904da9abd5279b5", size = 12729093, upload-time = "2025-06-07T14:50:31.82Z" }, - { url = "https://files.pythonhosted.org/packages/66/31/2f2f2d2b3e3c32d5753d01437240feaa32220b73258c9eef2e42a0832866/numpy-2.3.0-cp313-cp313-win_arm64.whl", hash = "sha256:c8738baa52505fa6e82778580b23f945e3578412554d937093eac9205e845e6e", size = 9885689, upload-time = "2025-06-07T14:50:47.888Z" }, - { url = "https://files.pythonhosted.org/packages/f1/89/c7828f23cc50f607ceb912774bb4cff225ccae7131c431398ad8400e2c98/numpy-2.3.0-cp313-cp313t-macosx_10_13_x86_64.whl", hash = "sha256:39b27d8b38942a647f048b675f134dd5a567f95bfff481f9109ec308515c51d8", size = 20986612, upload-time = "2025-06-07T14:46:56.077Z" }, - { url = "https://files.pythonhosted.org/packages/dd/46/79ecf47da34c4c50eedec7511e53d57ffdfd31c742c00be7dc1d5ffdb917/numpy-2.3.0-cp313-cp313t-macosx_11_0_arm64.whl", hash = "sha256:0eba4a1ea88f9a6f30f56fdafdeb8da3774349eacddab9581a21234b8535d3d3", size = 14298953, upload-time = "2025-06-07T14:47:18.053Z" }, - { url = "https://files.pythonhosted.org/packages/59/44/f6caf50713d6ff4480640bccb2a534ce1d8e6e0960c8f864947439f0ee95/numpy-2.3.0-cp313-cp313t-macosx_14_0_arm64.whl", hash = "sha256:b0f1f11d0a1da54927436505a5a7670b154eac27f5672afc389661013dfe3d4f", size = 5225806, upload-time = "2025-06-07T14:47:27.524Z" }, - { url = "https://files.pythonhosted.org/packages/a6/43/e1fd1aca7c97e234dd05e66de4ab7a5be54548257efcdd1bc33637e72102/numpy-2.3.0-cp313-cp313t-macosx_14_0_x86_64.whl", hash = "sha256:690d0a5b60a47e1f9dcec7b77750a4854c0d690e9058b7bef3106e3ae9117808", size = 6735169, upload-time = "2025-06-07T14:47:38.057Z" }, - { url = "https://files.pythonhosted.org/packages/84/89/f76f93b06a03177c0faa7ca94d0856c4e5c4bcaf3c5f77640c9ed0303e1c/numpy-2.3.0-cp313-cp313t-manylinux_2_28_aarch64.whl", hash = "sha256:8b51ead2b258284458e570942137155978583e407babc22e3d0ed7af33ce06f8", size = 14330701, upload-time = "2025-06-07T14:47:59.113Z" }, - { url = "https://files.pythonhosted.org/packages/aa/f5/4858c3e9ff7a7d64561b20580cf7cc5d085794bd465a19604945d6501f6c/numpy-2.3.0-cp313-cp313t-manylinux_2_28_x86_64.whl", hash = "sha256:aaf81c7b82c73bd9b45e79cfb9476cb9c29e937494bfe9092c26aece812818ad", size = 16692983, upload-time = "2025-06-07T14:48:24.196Z" }, - { url = "https://files.pythonhosted.org/packages/08/17/0e3b4182e691a10e9483bcc62b4bb8693dbf9ea5dc9ba0b77a60435074bb/numpy-2.3.0-cp313-cp313t-musllinux_1_2_aarch64.whl", hash = "sha256:f420033a20b4f6a2a11f585f93c843ac40686a7c3fa514060a97d9de93e5e72b", size = 15641435, upload-time = "2025-06-07T14:48:47.712Z" }, - { url = "https://files.pythonhosted.org/packages/4e/d5/463279fda028d3c1efa74e7e8d507605ae87f33dbd0543cf4c4527c8b882/numpy-2.3.0-cp313-cp313t-musllinux_1_2_x86_64.whl", hash = "sha256:d344ca32ab482bcf8735d8f95091ad081f97120546f3d250240868430ce52555", size = 18433798, upload-time = "2025-06-07T14:49:14.866Z" }, - { url = "https://files.pythonhosted.org/packages/0e/1e/7a9d98c886d4c39a2b4d3a7c026bffcf8fbcaf518782132d12a301cfc47a/numpy-2.3.0-cp313-cp313t-win32.whl", hash = "sha256:48a2e8eaf76364c32a1feaa60d6925eaf32ed7a040183b807e02674305beef61", size = 6438632, upload-time = "2025-06-07T14:49:25.67Z" }, - { url = "https://files.pythonhosted.org/packages/fe/ab/66fc909931d5eb230107d016861824f335ae2c0533f422e654e5ff556784/numpy-2.3.0-cp313-cp313t-win_amd64.whl", hash = "sha256:ba17f93a94e503551f154de210e4d50c5e3ee20f7e7a1b5f6ce3f22d419b93bb", size = 12868491, upload-time = "2025-06-07T14:49:44.898Z" }, - { url = "https://files.pythonhosted.org/packages/ee/e8/2c8a1c9e34d6f6d600c83d5ce5b71646c32a13f34ca5c518cc060639841c/numpy-2.3.0-cp313-cp313t-win_arm64.whl", hash = "sha256:f14e016d9409680959691c109be98c436c6249eaf7f118b424679793607b5944", size = 9935345, upload-time = "2025-06-07T14:50:02.311Z" }, - { url = "https://files.pythonhosted.org/packages/6a/a2/f8c1133f90eaa1c11bbbec1dc28a42054d0ce74bc2c9838c5437ba5d4980/numpy-2.3.0-pp311-pypy311_pp73-macosx_10_15_x86_64.whl", hash = "sha256:80b46117c7359de8167cc00a2c7d823bdd505e8c7727ae0871025a86d668283b", size = 21070759, upload-time = "2025-06-07T14:51:18.241Z" }, - { url = "https://files.pythonhosted.org/packages/6c/e0/4c05fc44ba28463096eee5ae2a12832c8d2759cc5bcec34ae33386d3ff83/numpy-2.3.0-pp311-pypy311_pp73-macosx_14_0_arm64.whl", hash = "sha256:5814a0f43e70c061f47abd5857d120179609ddc32a613138cbb6c4e9e2dbdda5", size = 5301054, upload-time = "2025-06-07T14:51:27.413Z" }, - { url = "https://files.pythonhosted.org/packages/8a/3b/6c06cdebe922bbc2a466fe2105f50f661238ea223972a69c7deb823821e7/numpy-2.3.0-pp311-pypy311_pp73-macosx_14_0_x86_64.whl", hash = "sha256:ef6c1e88fd6b81ac6d215ed71dc8cd027e54d4bf1d2682d362449097156267a2", size = 6817520, upload-time = "2025-06-07T14:51:38.015Z" }, - { url = "https://files.pythonhosted.org/packages/9d/a3/1e536797fd10eb3c5dbd2e376671667c9af19e241843548575267242ea02/numpy-2.3.0-pp311-pypy311_pp73-manylinux_2_28_aarch64.whl", hash = "sha256:33a5a12a45bb82d9997e2c0b12adae97507ad7c347546190a18ff14c28bbca12", size = 14398078, upload-time = "2025-06-07T14:52:00.122Z" }, - { url = "https://files.pythonhosted.org/packages/7c/61/9d574b10d9368ecb1a0c923952aa593510a20df4940aa615b3a71337c8db/numpy-2.3.0-pp311-pypy311_pp73-manylinux_2_28_x86_64.whl", hash = "sha256:54dfc8681c1906d239e95ab1508d0a533c4a9505e52ee2d71a5472b04437ef97", size = 16751324, upload-time = "2025-06-07T14:52:25.077Z" }, - { url = "https://files.pythonhosted.org/packages/39/de/bcad52ce972dc26232629ca3a99721fd4b22c1d2bda84d5db6541913ef9c/numpy-2.3.0-pp311-pypy311_pp73-win_amd64.whl", hash = "sha256:e017a8a251ff4d18d71f139e28bdc7c31edba7a507f72b1414ed902cbe48c74d", size = 12924237, upload-time = "2025-06-07T14:52:44.713Z" }, -] - -[[package]] -name = "nvidia-cublas-cu12" -version = "12.6.4.1" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/af/eb/ff4b8c503fa1f1796679dce648854d58751982426e4e4b37d6fce49d259c/nvidia_cublas_cu12-12.6.4.1-py3-none-manylinux2014_x86_64.manylinux_2_17_x86_64.whl", hash = "sha256:08ed2686e9875d01b58e3cb379c6896df8e76c75e0d4a7f7dace3d7b6d9ef8eb", size = 393138322, upload-time = "2024-11-20T17:40:25.65Z" }, - { url = "https://files.pythonhosted.org/packages/97/0d/f1f0cadbf69d5b9ef2e4f744c9466cb0a850741d08350736dfdb4aa89569/nvidia_cublas_cu12-12.6.4.1-py3-none-manylinux_2_27_aarch64.whl", hash = "sha256:235f728d6e2a409eddf1df58d5b0921cf80cfa9e72b9f2775ccb7b4a87984668", size = 390794615, upload-time = "2024-11-20T17:39:52.715Z" }, - { url = "https://files.pythonhosted.org/packages/84/f7/985e9bdbe3e0ac9298fcc8cfa51a392862a46a0ffaccbbd56939b62a9c83/nvidia_cublas_cu12-12.6.4.1-py3-none-win_amd64.whl", hash = "sha256:9e4fa264f4d8a4eb0cdbd34beadc029f453b3bafae02401e999cf3d5a5af75f8", size = 434535301, upload-time = "2024-11-20T17:50:41.681Z" }, -] - -[[package]] -name = "nvidia-cublas-cu12" -version = "12.8.3.14" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/ed/63/684a6f72f52671ea222c12ecde9bdf748a0ba025e2ad3ec374e466c26eb6/nvidia_cublas_cu12-12.8.3.14-py3-none-manylinux_2_27_aarch64.whl", hash = "sha256:93a4e0e386cc7f6e56c822531396de8170ed17068a1e18f987574895044cd8c3", size = 604900717, upload-time = "2025-01-23T17:52:55.486Z" }, - { url = "https://files.pythonhosted.org/packages/82/df/4b01f10069e23c641f116c62fc31e31e8dc361a153175d81561d15c8143b/nvidia_cublas_cu12-12.8.3.14-py3-none-manylinux_2_27_x86_64.whl", hash = "sha256:3f0e05e7293598cf61933258b73e66a160c27d59c4422670bf0b79348c04be44", size = 609620630, upload-time = "2025-01-23T17:55:00.753Z" }, - { url = "https://files.pythonhosted.org/packages/6c/54/fbfa3315b936d3358517f7da5f9f2557c279bf210e5261f0cf66cc0f9832/nvidia_cublas_cu12-12.8.3.14-py3-none-win_amd64.whl", hash = "sha256:9ae5eae500aead01fc4bdfc458209df638b1a3551557ce11a78eea9ece602ae9", size = 578387959, upload-time = "2025-01-23T18:08:00.662Z" }, -] - -[[package]] -name = "nvidia-cuda-cupti-cu12" -version = "12.6.80" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/e6/8b/2f6230cb715646c3a9425636e513227ce5c93c4d65823a734f4bb86d43c3/nvidia_cuda_cupti_cu12-12.6.80-py3-none-manylinux2014_aarch64.manylinux_2_17_aarch64.whl", hash = "sha256:166ee35a3ff1587f2490364f90eeeb8da06cd867bd5b701bf7f9a02b78bc63fc", size = 8236764, upload-time = "2024-11-20T17:35:41.03Z" }, - { url = "https://files.pythonhosted.org/packages/25/0f/acb326ac8fd26e13c799e0b4f3b2751543e1834f04d62e729485872198d4/nvidia_cuda_cupti_cu12-12.6.80-py3-none-manylinux2014_aarch64.whl", hash = "sha256:358b4a1d35370353d52e12f0a7d1769fc01ff74a191689d3870b2123156184c4", size = 8236756, upload-time = "2024-10-01T16:57:45.507Z" }, - { url = "https://files.pythonhosted.org/packages/49/60/7b6497946d74bcf1de852a21824d63baad12cd417db4195fc1bfe59db953/nvidia_cuda_cupti_cu12-12.6.80-py3-none-manylinux2014_x86_64.manylinux_2_17_x86_64.whl", hash = "sha256:6768bad6cab4f19e8292125e5f1ac8aa7d1718704012a0e3272a6f61c4bce132", size = 8917980, upload-time = "2024-11-20T17:36:04.019Z" }, - { url = "https://files.pythonhosted.org/packages/a5/24/120ee57b218d9952c379d1e026c4479c9ece9997a4fb46303611ee48f038/nvidia_cuda_cupti_cu12-12.6.80-py3-none-manylinux2014_x86_64.whl", hash = "sha256:a3eff6cdfcc6a4c35db968a06fcadb061cbc7d6dde548609a941ff8701b98b73", size = 8917972, upload-time = "2024-10-01T16:58:06.036Z" }, - { url = "https://files.pythonhosted.org/packages/1c/81/7796f096afaf726796b1b648f3bc80cafc61fe7f77f44a483c89e6c5ef34/nvidia_cuda_cupti_cu12-12.6.80-py3-none-win_amd64.whl", hash = "sha256:bbe6ae76e83ce5251b56e8c8e61a964f757175682bbad058b170b136266ab00a", size = 5724175, upload-time = "2024-10-01T17:09:47.955Z" }, -] - -[[package]] -name = "nvidia-cuda-cupti-cu12" -version = "12.8.57" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/fe/53/458956a65283c55c22ba40a65745bbe9ff20c10b68ea241bc575e20c0465/nvidia_cuda_cupti_cu12-12.8.57-py3-none-manylinux2014_aarch64.manylinux_2_17_aarch64.whl", hash = "sha256:ff154211724fd824e758ce176b66007b558eea19c9a5135fc991827ee147e317", size = 9526469, upload-time = "2025-01-23T17:47:33.104Z" }, - { url = "https://files.pythonhosted.org/packages/39/6f/3683ecf4e38931971946777d231c2df00dd5c1c4c2c914c42ad8f9f4dca6/nvidia_cuda_cupti_cu12-12.8.57-py3-none-manylinux2014_x86_64.manylinux_2_17_x86_64.whl", hash = "sha256:8e0b2eb847de260739bee4a3f66fac31378f4ff49538ff527a38a01a9a39f950", size = 10237547, upload-time = "2025-01-23T17:47:56.863Z" }, - { url = "https://files.pythonhosted.org/packages/3f/2a/cabe033045427beb042b70b394ac3fd7cfefe157c965268824011b16af67/nvidia_cuda_cupti_cu12-12.8.57-py3-none-win_amd64.whl", hash = "sha256:bbed719c52a476958a74cfc42f2b95a3fd6b3fd94eb40134acc4601feb4acac3", size = 7002337, upload-time = "2025-01-23T18:04:35.34Z" }, -] - -[[package]] -name = "nvidia-cuda-nvrtc-cu12" -version = "12.6.77" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/f4/2f/72df534873235983cc0a5371c3661bebef7c4682760c275590b972c7b0f9/nvidia_cuda_nvrtc_cu12-12.6.77-py3-none-manylinux2014_aarch64.whl", hash = "sha256:5847f1d6e5b757f1d2b3991a01082a44aad6f10ab3c5c0213fa3e25bddc25a13", size = 23162955, upload-time = "2024-10-01T16:59:50.922Z" }, - { url = "https://files.pythonhosted.org/packages/75/2e/46030320b5a80661e88039f59060d1790298b4718944a65a7f2aeda3d9e9/nvidia_cuda_nvrtc_cu12-12.6.77-py3-none-manylinux2014_x86_64.whl", hash = "sha256:35b0cc6ee3a9636d5409133e79273ce1f3fd087abb0532d2d2e8fff1fe9efc53", size = 23650380, upload-time = "2024-10-01T17:00:14.643Z" }, - { url = "https://files.pythonhosted.org/packages/f5/46/d3a1cdda8bb113c80f43a0a6f3a853356d487b830f3483f92d49ce87fa55/nvidia_cuda_nvrtc_cu12-12.6.77-py3-none-win_amd64.whl", hash = "sha256:f7007dbd914c56bd80ea31bc43e8e149da38f68158f423ba845fc3292684e45a", size = 39026742, upload-time = "2024-10-01T17:10:49.058Z" }, -] - -[[package]] -name = "nvidia-cuda-nvrtc-cu12" -version = "12.8.61" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/d4/22/32029d4583f7b19cfe75c84399cbcfd23f2aaf41c66fc8db4da460104fff/nvidia_cuda_nvrtc_cu12-12.8.61-py3-none-manylinux2010_x86_64.manylinux_2_12_x86_64.whl", hash = "sha256:a0fa9c2a21583105550ebd871bd76e2037205d56f33f128e69f6d2a55e0af9ed", size = 88024585, upload-time = "2025-01-23T17:50:10.722Z" }, - { url = "https://files.pythonhosted.org/packages/f1/98/29f98d57fc40d6646337e942d37509c6d5f8abe29012671f7a6eb9978ebe/nvidia_cuda_nvrtc_cu12-12.8.61-py3-none-manylinux2014_aarch64.manylinux_2_17_aarch64.whl", hash = "sha256:b1f376bf58111ca73dde4fd4df89a462b164602e074a76a2c29c121ca478dcd4", size = 43097015, upload-time = "2025-01-23T17:49:44.331Z" }, - { url = "https://files.pythonhosted.org/packages/f8/5b/052d05aa068e4752415ad03bac58e852ea8bc17c9321e08546b3f261e47e/nvidia_cuda_nvrtc_cu12-12.8.61-py3-none-win_amd64.whl", hash = "sha256:9c8887bf5e5dffc441018ba8c5dc59952372a6f4806819e8c1f03d62637dbeea", size = 73567440, upload-time = "2025-01-23T18:05:51.036Z" }, -] - -[[package]] -name = "nvidia-cuda-runtime-cu12" -version = "12.6.77" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/8f/ea/590b2ac00d772a8abd1c387a92b46486d2679ca6622fd25c18ff76265663/nvidia_cuda_runtime_cu12-12.6.77-py3-none-manylinux2014_aarch64.manylinux_2_17_aarch64.whl", hash = "sha256:6116fad3e049e04791c0256a9778c16237837c08b27ed8c8401e2e45de8d60cd", size = 908052, upload-time = "2024-11-20T17:35:19.905Z" }, - { url = "https://files.pythonhosted.org/packages/b7/3d/159023799677126e20c8fd580cca09eeb28d5c5a624adc7f793b9aa8bbfa/nvidia_cuda_runtime_cu12-12.6.77-py3-none-manylinux2014_aarch64.whl", hash = "sha256:d461264ecb429c84c8879a7153499ddc7b19b5f8d84c204307491989a365588e", size = 908040, upload-time = "2024-10-01T16:57:22.221Z" }, - { url = "https://files.pythonhosted.org/packages/e1/23/e717c5ac26d26cf39a27fbc076240fad2e3b817e5889d671b67f4f9f49c5/nvidia_cuda_runtime_cu12-12.6.77-py3-none-manylinux2014_x86_64.manylinux_2_17_x86_64.whl", hash = "sha256:ba3b56a4f896141e25e19ab287cd71e52a6a0f4b29d0d31609f60e3b4d5219b7", size = 897690, upload-time = "2024-11-20T17:35:30.697Z" }, - { url = "https://files.pythonhosted.org/packages/f0/62/65c05e161eeddbafeca24dc461f47de550d9fa8a7e04eb213e32b55cfd99/nvidia_cuda_runtime_cu12-12.6.77-py3-none-manylinux2014_x86_64.whl", hash = "sha256:a84d15d5e1da416dd4774cb42edf5e954a3e60cc945698dc1d5be02321c44dc8", size = 897678, upload-time = "2024-10-01T16:57:33.821Z" }, - { url = "https://files.pythonhosted.org/packages/fa/76/4c80fa138333cc975743fd0687a745fccb30d167f906f13c1c7f9a85e5ea/nvidia_cuda_runtime_cu12-12.6.77-py3-none-win_amd64.whl", hash = "sha256:86c58044c824bf3c173c49a2dbc7a6c8b53cb4e4dca50068be0bf64e9dab3f7f", size = 891773, upload-time = "2024-10-01T17:09:26.362Z" }, -] - -[[package]] -name = "nvidia-cuda-runtime-cu12" -version = "12.8.57" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/cd/9d/e77ec4227e70c6006195bdf410370f2d0e5abfa2dc0d1d315cacd57c5c88/nvidia_cuda_runtime_cu12-12.8.57-py3-none-manylinux2014_aarch64.manylinux_2_17_aarch64.whl", hash = "sha256:534ccebd967b6a44292678fa5da4f00666029cb2ed07a79515ea41ef31fe3ec7", size = 965264, upload-time = "2025-01-23T17:47:11.759Z" }, - { url = "https://files.pythonhosted.org/packages/16/f6/0e1ef31f4753a44084310ba1a7f0abaf977ccd810a604035abb43421c057/nvidia_cuda_runtime_cu12-12.8.57-py3-none-manylinux2014_x86_64.manylinux_2_17_x86_64.whl", hash = "sha256:75342e28567340b7428ce79a5d6bb6ca5ff9d07b69e7ce00d2c7b4dc23eff0be", size = 954762, upload-time = "2025-01-23T17:47:22.21Z" }, - { url = "https://files.pythonhosted.org/packages/16/ee/52508c74bee2a3de8d59c6fd9af4ca2f216052fa2bc916da3a6a7bb998af/nvidia_cuda_runtime_cu12-12.8.57-py3-none-win_amd64.whl", hash = "sha256:89be637e3ee967323865b85e0f147d75f9a5bd98360befa37481b02dd57af8f5", size = 944309, upload-time = "2025-01-23T18:04:23.143Z" }, -] - -[[package]] -name = "nvidia-cudnn-cu12" -version = "9.5.1.17" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -dependencies = [ - { name = "nvidia-cublas-cu12", version = "12.6.4.1", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/99/93/a201a12d3ec1caa8c6ac34c1c2f9eeb696b886f0c36ff23c638b46603bd0/nvidia_cudnn_cu12-9.5.1.17-py3-none-manylinux_2_28_aarch64.whl", hash = "sha256:9fd4584468533c61873e5fda8ca41bac3a38bcb2d12350830c69b0a96a7e4def", size = 570523509, upload-time = "2024-10-25T19:53:03.148Z" }, - { url = "https://files.pythonhosted.org/packages/2a/78/4535c9c7f859a64781e43c969a3a7e84c54634e319a996d43ef32ce46f83/nvidia_cudnn_cu12-9.5.1.17-py3-none-manylinux_2_28_x86_64.whl", hash = "sha256:30ac3869f6db17d170e0e556dd6cc5eee02647abc31ca856634d5a40f82c15b2", size = 570988386, upload-time = "2024-10-25T19:54:26.39Z" }, - { url = "https://files.pythonhosted.org/packages/b6/b2/3f60d15f037fa5419d9d7f788b100ef33ea913ae5315c87ca6d6fa606c35/nvidia_cudnn_cu12-9.5.1.17-py3-none-win_amd64.whl", hash = "sha256:d7af0f8a4f3b4b9dbb3122f2ef553b45694ed9c384d5a75bab197b8eefb79ab8", size = 565440743, upload-time = "2024-10-25T19:55:49.74Z" }, -] - -[[package]] -name = "nvidia-cudnn-cu12" -version = "9.7.1.26" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -dependencies = [ - { name = "nvidia-cublas-cu12", version = "12.8.3.14", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/c1/2e/ec5dda717eeb1de3afbbbb611ca556f9d6d057470759c6abd36d72f0063b/nvidia_cudnn_cu12-9.7.1.26-py3-none-manylinux_2_27_aarch64.whl", hash = "sha256:848a61d40ef3b32bd4e1fadb599f0cf04a4b942fbe5fb3be572ad75f9b8c53ef", size = 725862213, upload-time = "2025-02-06T22:14:57.169Z" }, - { url = "https://files.pythonhosted.org/packages/25/dc/dc825c4b1c83b538e207e34f48f86063c88deaa35d46c651c7c181364ba2/nvidia_cudnn_cu12-9.7.1.26-py3-none-manylinux_2_27_x86_64.whl", hash = "sha256:6d011159a158f3cfc47bf851aea79e31bcff60d530b70ef70474c84cac484d07", size = 726851421, upload-time = "2025-02-06T22:18:29.812Z" }, - { url = "https://files.pythonhosted.org/packages/d0/ea/636cda41b3865caa0d43c34f558167304acde3d2c5f6c54c00a550e69ecd/nvidia_cudnn_cu12-9.7.1.26-py3-none-win_amd64.whl", hash = "sha256:7b805b9a4cf9f3da7c5f4ea4a9dff7baf62d1a612d6154a7e0d2ea51ed296241", size = 715962100, upload-time = "2025-02-06T22:21:32.431Z" }, -] - -[[package]] -name = "nvidia-cufft-cu12" -version = "11.3.0.4" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -dependencies = [ - { name = "nvidia-nvjitlink-cu12", version = "12.6.85", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/1f/37/c50d2b2f2c07e146776389e3080f4faf70bcc4fa6e19d65bb54ca174ebc3/nvidia_cufft_cu12-11.3.0.4-py3-none-manylinux2014_aarch64.manylinux_2_17_aarch64.whl", hash = "sha256:d16079550df460376455cba121db6564089176d9bac9e4f360493ca4741b22a6", size = 200164144, upload-time = "2024-11-20T17:40:58.288Z" }, - { url = "https://files.pythonhosted.org/packages/ce/f5/188566814b7339e893f8d210d3a5332352b1409815908dad6a363dcceac1/nvidia_cufft_cu12-11.3.0.4-py3-none-manylinux2014_aarch64.whl", hash = "sha256:8510990de9f96c803a051822618d42bf6cb8f069ff3f48d93a8486efdacb48fb", size = 200164135, upload-time = "2024-10-01T17:03:24.212Z" }, - { url = "https://files.pythonhosted.org/packages/8f/16/73727675941ab8e6ffd86ca3a4b7b47065edcca7a997920b831f8147c99d/nvidia_cufft_cu12-11.3.0.4-py3-none-manylinux2014_x86_64.manylinux_2_17_x86_64.whl", hash = "sha256:ccba62eb9cef5559abd5e0d54ceed2d9934030f51163df018532142a8ec533e5", size = 200221632, upload-time = "2024-11-20T17:41:32.357Z" }, - { url = "https://files.pythonhosted.org/packages/60/de/99ec247a07ea40c969d904fc14f3a356b3e2a704121675b75c366b694ee1/nvidia_cufft_cu12-11.3.0.4-py3-none-manylinux2014_x86_64.whl", hash = "sha256:768160ac89f6f7b459bee747e8d175dbf53619cfe74b2a5636264163138013ca", size = 200221622, upload-time = "2024-10-01T17:03:58.79Z" }, - { url = "https://files.pythonhosted.org/packages/b4/38/36fd800cec8f6e89b7c1576edaaf8076e69ec631644cdbc1b5f2e2b5a9df/nvidia_cufft_cu12-11.3.0.4-py3-none-win_amd64.whl", hash = "sha256:6048ebddfb90d09d2707efb1fd78d4e3a77cb3ae4dc60e19aab6be0ece2ae464", size = 199356881, upload-time = "2024-10-01T17:13:01.861Z" }, -] - -[[package]] -name = "nvidia-cufft-cu12" -version = "11.3.3.41" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -dependencies = [ - { name = "nvidia-nvjitlink-cu12", version = "12.8.61", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/72/95/6157cb45a49f5090a470de42353a22a0ed5b13077886dca891b4b0e350fe/nvidia_cufft_cu12-11.3.3.41-py3-none-manylinux2014_aarch64.manylinux_2_17_aarch64.whl", hash = "sha256:68509dcd7e3306e69d0e2d8a6d21c8b25ed62e6df8aac192ce752f17677398b5", size = 193108626, upload-time = "2025-01-23T17:55:49.192Z" }, - { url = "https://files.pythonhosted.org/packages/ac/26/b53c493c38dccb1f1a42e1a21dc12cba2a77fbe36c652f7726d9ec4aba28/nvidia_cufft_cu12-11.3.3.41-py3-none-manylinux2014_x86_64.manylinux_2_17_x86_64.whl", hash = "sha256:da650080ab79fcdf7a4b06aa1b460e99860646b176a43f6208099bdc17836b6a", size = 193118795, upload-time = "2025-01-23T17:56:30.536Z" }, - { url = "https://files.pythonhosted.org/packages/32/f3/f6248aa119c2726b1bdd02d472332cae274133bd32ca5fa8822efb0c308c/nvidia_cufft_cu12-11.3.3.41-py3-none-win_amd64.whl", hash = "sha256:f9760612886786601d27a0993bb29ce1f757e6b8b173499d0ecfa850d31b50f8", size = 192216738, upload-time = "2025-01-23T18:08:51.102Z" }, -] - -[[package]] -name = "nvidia-cufile-cu12" -version = "1.11.1.6" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/b2/66/cc9876340ac68ae71b15c743ddb13f8b30d5244af344ec8322b449e35426/nvidia_cufile_cu12-1.11.1.6-py3-none-manylinux2014_x86_64.manylinux_2_17_x86_64.whl", hash = "sha256:cc23469d1c7e52ce6c1d55253273d32c565dd22068647f3aa59b3c6b005bf159", size = 1142103, upload-time = "2024-11-20T17:42:11.83Z" }, - { url = "https://files.pythonhosted.org/packages/17/bf/cc834147263b929229ce4aadd62869f0b195e98569d4c28b23edc72b85d9/nvidia_cufile_cu12-1.11.1.6-py3-none-manylinux_2_27_aarch64.whl", hash = "sha256:8f57a0051dcf2543f6dc2b98a98cb2719c37d3cee1baba8965d57f3bbc90d4db", size = 1066155, upload-time = "2024-11-20T17:41:49.376Z" }, -] - -[[package]] -name = "nvidia-cufile-cu12" -version = "1.13.0.11" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/e5/9c/1f3264d0a84c8a031487fb7f59780fc78fa6f1c97776233956780e3dc3ac/nvidia_cufile_cu12-1.13.0.11-py3-none-manylinux2014_x86_64.manylinux_2_17_x86_64.whl", hash = "sha256:483f434c541806936b98366f6d33caef5440572de8ddf38d453213729da3e7d4", size = 1197801, upload-time = "2025-01-23T17:57:07.247Z" }, - { url = "https://files.pythonhosted.org/packages/35/80/f6a0fc90ab6fa4ac916f3643e5b620fd19724626c59ae83b74f5efef0349/nvidia_cufile_cu12-1.13.0.11-py3-none-manylinux_2_27_aarch64.whl", hash = "sha256:2acbee65dc2eaf58331f0798c5e6bcdd790c4acb26347530297e63528c9eba5d", size = 1120660, upload-time = "2025-01-23T17:56:56.608Z" }, -] - -[[package]] -name = "nvidia-curand-cu12" -version = "10.3.7.77" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/42/ac/36543605358a355632f1a6faa3e2d5dfb91eab1e4bc7d552040e0383c335/nvidia_curand_cu12-10.3.7.77-py3-none-manylinux2014_aarch64.whl", hash = "sha256:6e82df077060ea28e37f48a3ec442a8f47690c7499bff392a5938614b56c98d8", size = 56289881, upload-time = "2024-10-01T17:04:18.981Z" }, - { url = "https://files.pythonhosted.org/packages/73/1b/44a01c4e70933637c93e6e1a8063d1e998b50213a6b65ac5a9169c47e98e/nvidia_curand_cu12-10.3.7.77-py3-none-manylinux2014_x86_64.manylinux_2_17_x86_64.whl", hash = "sha256:a42cd1344297f70b9e39a1e4f467a4e1c10f1da54ff7a85c12197f6c652c8bdf", size = 56279010, upload-time = "2024-11-20T17:42:50.958Z" }, - { url = "https://files.pythonhosted.org/packages/4a/aa/2c7ff0b5ee02eaef890c0ce7d4f74bc30901871c5e45dee1ae6d0083cd80/nvidia_curand_cu12-10.3.7.77-py3-none-manylinux2014_x86_64.whl", hash = "sha256:99f1a32f1ac2bd134897fc7a203f779303261268a65762a623bf30cc9fe79117", size = 56279000, upload-time = "2024-10-01T17:04:45.274Z" }, - { url = "https://files.pythonhosted.org/packages/a6/02/5362a9396f23f7de1dd8a64369e87c85ffff8216fc8194ace0fa45ba27a5/nvidia_curand_cu12-10.3.7.77-py3-none-manylinux_2_27_aarch64.whl", hash = "sha256:7b2ed8e95595c3591d984ea3603dd66fe6ce6812b886d59049988a712ed06b6e", size = 56289882, upload-time = "2024-11-20T17:42:25.222Z" }, - { url = "https://files.pythonhosted.org/packages/a9/a8/0cd0cec757bd4b4b4ef150fca62ec064db7d08a291dced835a0be7d2c147/nvidia_curand_cu12-10.3.7.77-py3-none-win_amd64.whl", hash = "sha256:6d6d935ffba0f3d439b7cd968192ff068fafd9018dbf1b85b37261b13cfc9905", size = 55783873, upload-time = "2024-10-01T17:13:30.377Z" }, -] - -[[package]] -name = "nvidia-curand-cu12" -version = "10.3.9.55" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/f4/13/bbcf48e2f8a6a9adef58f130bc968810528a4e66bbbe62fad335241e699f/nvidia_curand_cu12-10.3.9.55-py3-none-manylinux_2_27_aarch64.whl", hash = "sha256:b6bb90c044fa9b07cedae2ef29077c4cf851fb6fdd6d862102321f359dca81e9", size = 63623836, upload-time = "2025-01-23T17:57:22.319Z" }, - { url = "https://files.pythonhosted.org/packages/bd/fc/7be5d0082507269bb04ac07cc614c84b78749efb96e8cf4100a8a1178e98/nvidia_curand_cu12-10.3.9.55-py3-none-manylinux_2_27_x86_64.whl", hash = "sha256:8387d974240c91f6a60b761b83d4b2f9b938b7e0b9617bae0f0dafe4f5c36b86", size = 63618038, upload-time = "2025-01-23T17:57:41.838Z" }, - { url = "https://files.pythonhosted.org/packages/d6/f0/91252f3cffe3f3c233a8e17262c21b41534652edfe783c1e58ea1c92c115/nvidia_curand_cu12-10.3.9.55-py3-none-win_amd64.whl", hash = "sha256:570d82475fe7f3d8ed01ffbe3b71796301e0e24c98762ca018ff8ce4f5418e1f", size = 62761446, upload-time = "2025-01-23T18:09:21.663Z" }, -] - -[[package]] -name = "nvidia-cusolver-cu12" -version = "11.7.1.2" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -dependencies = [ - { name = "nvidia-cublas-cu12", version = "12.6.4.1", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-cusparse-cu12", version = "12.5.4.2", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-nvjitlink-cu12", version = "12.6.85", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/93/17/dbe1aa865e4fdc7b6d4d0dd308fdd5aaab60f939abfc0ea1954eac4fb113/nvidia_cusolver_cu12-11.7.1.2-py3-none-manylinux2014_aarch64.whl", hash = "sha256:0ce237ef60acde1efc457335a2ddadfd7610b892d94efee7b776c64bb1cac9e0", size = 157833628, upload-time = "2024-10-01T17:05:05.591Z" }, - { url = "https://files.pythonhosted.org/packages/f0/6e/c2cf12c9ff8b872e92b4a5740701e51ff17689c4d726fca91875b07f655d/nvidia_cusolver_cu12-11.7.1.2-py3-none-manylinux2014_x86_64.manylinux_2_17_x86_64.whl", hash = "sha256:e9e49843a7707e42022babb9bcfa33c29857a93b88020c4e4434656a655b698c", size = 158229790, upload-time = "2024-11-20T17:43:43.211Z" }, - { url = "https://files.pythonhosted.org/packages/9f/81/baba53585da791d043c10084cf9553e074548408e04ae884cfe9193bd484/nvidia_cusolver_cu12-11.7.1.2-py3-none-manylinux2014_x86_64.whl", hash = "sha256:6cf28f17f64107a0c4d7802be5ff5537b2130bfc112f25d5a30df227058ca0e6", size = 158229780, upload-time = "2024-10-01T17:05:39.875Z" }, - { url = "https://files.pythonhosted.org/packages/7c/5f/07d0ba3b7f19be5a5ec32a8679fc9384cfd9fc6c869825e93be9f28d6690/nvidia_cusolver_cu12-11.7.1.2-py3-none-manylinux_2_27_aarch64.whl", hash = "sha256:dbbe4fc38ec1289c7e5230e16248365e375c3673c9c8bac5796e2e20db07f56e", size = 157833630, upload-time = "2024-11-20T17:43:16.77Z" }, - { url = "https://files.pythonhosted.org/packages/d4/53/fff50a0808df7113d77e3bbc7c2b7eaed6f57d5eb80fbe93ead2aea1e09a/nvidia_cusolver_cu12-11.7.1.2-py3-none-win_amd64.whl", hash = "sha256:6813f9d8073f555444a8705f3ab0296d3e1cb37a16d694c5fc8b862a0d8706d7", size = 149287877, upload-time = "2024-10-01T17:13:49.804Z" }, -] - -[[package]] -name = "nvidia-cusolver-cu12" -version = "11.7.2.55" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -dependencies = [ - { name = "nvidia-cublas-cu12", version = "12.8.3.14", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-cusparse-cu12", version = "12.5.7.53", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-nvjitlink-cu12", version = "12.8.61", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/8c/ce/4214a892e804b20bf66d04f04a473006fc2d3dac158160ef85f1bc906639/nvidia_cusolver_cu12-11.7.2.55-py3-none-manylinux_2_27_aarch64.whl", hash = "sha256:0fd9e98246f43c15bee5561147ad235dfdf2d037f5d07c9d41af3f7f72feb7cc", size = 260094827, upload-time = "2025-01-23T17:58:17.586Z" }, - { url = "https://files.pythonhosted.org/packages/c2/08/953675873a136d96bb12f93b49ba045d1107bc94d2551c52b12fa6c7dec3/nvidia_cusolver_cu12-11.7.2.55-py3-none-manylinux_2_27_x86_64.whl", hash = "sha256:4d1354102f1e922cee9db51920dba9e2559877cf6ff5ad03a00d853adafb191b", size = 260373342, upload-time = "2025-01-23T17:58:56.406Z" }, - { url = "https://files.pythonhosted.org/packages/c4/f9/e0e6f8b7aecd13e0f9e937d116fb3211329a0a92b9bea9624b1368de307a/nvidia_cusolver_cu12-11.7.2.55-py3-none-win_amd64.whl", hash = "sha256:a5a516c55da5c5aba98420d9bc9bcab18245f21ec87338cc1f930eb18dd411ac", size = 249600787, upload-time = "2025-01-23T18:10:07.641Z" }, -] - -[[package]] -name = "nvidia-cusparse-cu12" -version = "12.5.4.2" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -dependencies = [ - { name = "nvidia-nvjitlink-cu12", version = "12.6.85", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/eb/eb/6681efd0aa7df96b4f8067b3ce7246833dd36830bb4cec8896182773db7d/nvidia_cusparse_cu12-12.5.4.2-py3-none-manylinux2014_aarch64.manylinux_2_17_aarch64.whl", hash = "sha256:d25b62fb18751758fe3c93a4a08eff08effedfe4edf1c6bb5afd0890fe88f887", size = 216451147, upload-time = "2024-11-20T17:44:18.055Z" }, - { url = "https://files.pythonhosted.org/packages/d3/56/3af21e43014eb40134dea004e8d0f1ef19d9596a39e4d497d5a7de01669f/nvidia_cusparse_cu12-12.5.4.2-py3-none-manylinux2014_aarch64.whl", hash = "sha256:7aa32fa5470cf754f72d1116c7cbc300b4e638d3ae5304cfa4a638a5b87161b1", size = 216451135, upload-time = "2024-10-01T17:06:03.826Z" }, - { url = "https://files.pythonhosted.org/packages/06/1e/b8b7c2f4099a37b96af5c9bb158632ea9e5d9d27d7391d7eb8fc45236674/nvidia_cusparse_cu12-12.5.4.2-py3-none-manylinux2014_x86_64.manylinux_2_17_x86_64.whl", hash = "sha256:7556d9eca156e18184b94947ade0fba5bb47d69cec46bf8660fd2c71a4b48b73", size = 216561367, upload-time = "2024-11-20T17:44:54.824Z" }, - { url = "https://files.pythonhosted.org/packages/43/ac/64c4316ba163e8217a99680c7605f779accffc6a4bcd0c778c12948d3707/nvidia_cusparse_cu12-12.5.4.2-py3-none-manylinux2014_x86_64.whl", hash = "sha256:23749a6571191a215cb74d1cdbff4a86e7b19f1200c071b3fcf844a5bea23a2f", size = 216561357, upload-time = "2024-10-01T17:06:29.861Z" }, - { url = "https://files.pythonhosted.org/packages/45/ef/876ad8e4260e1128e6d4aac803d9d51baf3791ebdb4a9b8d9b8db032b4b0/nvidia_cusparse_cu12-12.5.4.2-py3-none-win_amd64.whl", hash = "sha256:4acb8c08855a26d737398cba8fb6f8f5045d93f82612b4cfd84645a2332ccf20", size = 213712630, upload-time = "2024-10-01T17:14:23.779Z" }, -] - -[[package]] -name = "nvidia-cusparse-cu12" -version = "12.5.7.53" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -dependencies = [ - { name = "nvidia-nvjitlink-cu12", version = "12.8.61", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/2e/a2/313db0453087f5324a5900380ca2e57e050c8de76f407b5e11383dc762ae/nvidia_cusparse_cu12-12.5.7.53-py3-none-manylinux2014_aarch64.manylinux_2_17_aarch64.whl", hash = "sha256:d869c6146ca80f4305b62e02d924b4aaced936f8173e3cef536a67eed2a91af1", size = 291963692, upload-time = "2025-01-23T17:59:40.325Z" }, - { url = "https://files.pythonhosted.org/packages/c2/ab/31e8149c66213b846c082a3b41b1365b831f41191f9f40c6ddbc8a7d550e/nvidia_cusparse_cu12-12.5.7.53-py3-none-manylinux2014_x86_64.manylinux_2_17_x86_64.whl", hash = "sha256:3c1b61eb8c85257ea07e9354606b26397612627fdcd327bfd91ccf6155e7c86d", size = 292064180, upload-time = "2025-01-23T18:00:23.233Z" }, - { url = "https://files.pythonhosted.org/packages/7c/48/64b01653919a3d1d9b5117c156806ab0db8312c7496ff646477a5c1545bf/nvidia_cusparse_cu12-12.5.7.53-py3-none-win_amd64.whl", hash = "sha256:82c201d6781bacf6bb7c654f0446728d0fe596dfdd82ef4a04c204ce3e107441", size = 288767123, upload-time = "2025-01-23T18:11:01.543Z" }, -] - -[[package]] -name = "nvidia-cusparselt-cu12" -version = "0.6.3" -source = { registry = "https://pypi.org/simple" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/62/da/4de092c61c6dea1fc9c936e69308a02531d122e12f1f649825934ad651b5/nvidia_cusparselt_cu12-0.6.3-py3-none-manylinux2014_aarch64.whl", hash = "sha256:8371549623ba601a06322af2133c4a44350575f5a3108fb75f3ef20b822ad5f1", size = 156402859, upload-time = "2024-10-16T02:23:17.184Z" }, - { url = "https://files.pythonhosted.org/packages/3b/9a/72ef35b399b0e183bc2e8f6f558036922d453c4d8237dab26c666a04244b/nvidia_cusparselt_cu12-0.6.3-py3-none-manylinux2014_x86_64.whl", hash = "sha256:e5c8a26c36445dd2e6812f1177978a24e2d37cacce7e090f297a688d1ec44f46", size = 156785796, upload-time = "2024-10-15T21:29:17.709Z" }, - { url = "https://files.pythonhosted.org/packages/46/3e/9e1e394a02a06f694be2c97bbe47288bb7c90ea84c7e9cf88f7b28afe165/nvidia_cusparselt_cu12-0.6.3-py3-none-win_amd64.whl", hash = "sha256:3b325bcbd9b754ba43df5a311488fca11a6b5dc3d11df4d190c000cf1a0765c7", size = 155595972, upload-time = "2024-10-15T22:58:35.426Z" }, -] - -[[package]] -name = "nvidia-nccl-cu12" -version = "2.26.2" -source = { registry = "https://pypi.org/simple" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/69/5b/ca2f213f637305633814ae8c36b153220e40a07ea001966dcd87391f3acb/nvidia_nccl_cu12-2.26.2-py3-none-manylinux2014_aarch64.manylinux_2_17_aarch64.whl", hash = "sha256:5c196e95e832ad30fbbb50381eb3cbd1fadd5675e587a548563993609af19522", size = 291671495, upload-time = "2025-03-13T00:30:07.805Z" }, - { url = "https://files.pythonhosted.org/packages/67/ca/f42388aed0fddd64ade7493dbba36e1f534d4e6fdbdd355c6a90030ae028/nvidia_nccl_cu12-2.26.2-py3-none-manylinux2014_x86_64.manylinux_2_17_x86_64.whl", hash = "sha256:694cf3879a206553cc9d7dbda76b13efaf610fdb70a50cba303de1b0d1530ac6", size = 201319755, upload-time = "2025-03-13T00:29:55.296Z" }, -] - -[[package]] -name = "nvidia-nvjitlink-cu12" -version = "12.6.85" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/9d/d7/c5383e47c7e9bf1c99d5bd2a8c935af2b6d705ad831a7ec5c97db4d82f4f/nvidia_nvjitlink_cu12-12.6.85-py3-none-manylinux2010_x86_64.manylinux_2_12_x86_64.whl", hash = "sha256:eedc36df9e88b682efe4309aa16b5b4e78c2407eac59e8c10a6a47535164369a", size = 19744971, upload-time = "2024-11-20T17:46:53.366Z" }, - { url = "https://files.pythonhosted.org/packages/31/db/dc71113d441f208cdfe7ae10d4983884e13f464a6252450693365e166dcf/nvidia_nvjitlink_cu12-12.6.85-py3-none-manylinux2014_aarch64.manylinux_2_17_aarch64.whl", hash = "sha256:cf4eaa7d4b6b543ffd69d6abfb11efdeb2db48270d94dfd3a452c24150829e41", size = 19270338, upload-time = "2024-11-20T17:46:29.758Z" }, - { url = "https://files.pythonhosted.org/packages/89/76/93c1467b1387387440a4d25102d86b7794535449b689f8e2dc22c1c8ff7f/nvidia_nvjitlink_cu12-12.6.85-py3-none-win_amd64.whl", hash = "sha256:e61120e52ed675747825cdd16febc6a0730537451d867ee58bee3853b1b13d1c", size = 161908572, upload-time = "2024-11-20T17:52:40.124Z" }, -] - -[[package]] -name = "nvidia-nvjitlink-cu12" -version = "12.8.61" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/03/f8/9d85593582bd99b8d7c65634d2304780aefade049b2b94d96e44084be90b/nvidia_nvjitlink_cu12-12.8.61-py3-none-manylinux2010_x86_64.manylinux_2_12_x86_64.whl", hash = "sha256:45fd79f2ae20bd67e8bc411055939049873bfd8fac70ff13bd4865e0b9bdab17", size = 39243473, upload-time = "2025-01-23T18:03:03.509Z" }, - { url = "https://files.pythonhosted.org/packages/af/53/698f3758f48c5fcb1112721e40cc6714da3980d3c7e93bae5b29dafa9857/nvidia_nvjitlink_cu12-12.8.61-py3-none-manylinux2014_aarch64.manylinux_2_17_aarch64.whl", hash = "sha256:9b80ecab31085dda3ce3b41d043be0ec739216c3fc633b8abe212d5a30026df0", size = 38374634, upload-time = "2025-01-23T18:02:35.812Z" }, - { url = "https://files.pythonhosted.org/packages/7f/c6/0d1b2bfeb2ef42c06db0570c4d081e5cde4450b54c09e43165126cfe6ff6/nvidia_nvjitlink_cu12-12.8.61-py3-none-win_amd64.whl", hash = "sha256:1166a964d25fdc0eae497574d38824305195a5283324a21ccb0ce0c802cbf41c", size = 268514099, upload-time = "2025-01-23T18:12:33.874Z" }, -] - -[[package]] -name = "nvidia-nvtx-cu12" -version = "12.6.77" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/b9/93/80f8a520375af9d7ee44571a6544653a176e53c2b8ccce85b97b83c2491b/nvidia_nvtx_cu12-12.6.77-py3-none-manylinux2014_aarch64.manylinux_2_17_aarch64.whl", hash = "sha256:f44f8d86bb7d5629988d61c8d3ae61dddb2015dee142740536bc7481b022fe4b", size = 90549, upload-time = "2024-11-20T17:38:17.387Z" }, - { url = "https://files.pythonhosted.org/packages/2b/53/36e2fd6c7068997169b49ffc8c12d5af5e5ff209df6e1a2c4d373b3a638f/nvidia_nvtx_cu12-12.6.77-py3-none-manylinux2014_aarch64.whl", hash = "sha256:adcaabb9d436c9761fca2b13959a2d237c5f9fd406c8e4b723c695409ff88059", size = 90539, upload-time = "2024-10-01T17:00:27.179Z" }, - { url = "https://files.pythonhosted.org/packages/56/9a/fff8376f8e3d084cd1530e1ef7b879bb7d6d265620c95c1b322725c694f4/nvidia_nvtx_cu12-12.6.77-py3-none-manylinux2014_x86_64.manylinux_2_17_x86_64.whl", hash = "sha256:b90bed3df379fa79afbd21be8e04a0314336b8ae16768b58f2d34cb1d04cd7d2", size = 89276, upload-time = "2024-11-20T17:38:27.621Z" }, - { url = "https://files.pythonhosted.org/packages/9e/4e/0d0c945463719429b7bd21dece907ad0bde437a2ff12b9b12fee94722ab0/nvidia_nvtx_cu12-12.6.77-py3-none-manylinux2014_x86_64.whl", hash = "sha256:6574241a3ec5fdc9334353ab8c479fe75841dbe8f4532a8fc97ce63503330ba1", size = 89265, upload-time = "2024-10-01T17:00:38.172Z" }, - { url = "https://files.pythonhosted.org/packages/f7/cd/98a447919d4ed14d407ac82b14b0a0c9c1dbfe81099934b1fc3bfd1e6316/nvidia_nvtx_cu12-12.6.77-py3-none-win_amd64.whl", hash = "sha256:2fb11a4af04a5e6c84073e6404d26588a34afd35379f0855a99797897efa75c0", size = 56434, upload-time = "2024-10-01T17:11:13.124Z" }, -] - -[[package]] -name = "nvidia-nvtx-cu12" -version = "12.8.55" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/bb/e8/ae6ecbdade8bb9174d75db2b302c57c1c27d9277d6531c62aafde5fb32a3/nvidia_nvtx_cu12-12.8.55-py3-none-manylinux2014_aarch64.manylinux_2_17_aarch64.whl", hash = "sha256:c38405335fbc0f0bf363eaeaeb476e8dfa8bae82fada41d25ace458b9ba9f3db", size = 91103, upload-time = "2025-01-23T17:50:24.664Z" }, - { url = "https://files.pythonhosted.org/packages/8d/cd/0e8c51b2ae3a58f054f2e7fe91b82d201abfb30167f2431e9bd92d532f42/nvidia_nvtx_cu12-12.8.55-py3-none-manylinux2014_x86_64.manylinux_2_17_x86_64.whl", hash = "sha256:2dd0780f1a55c21d8e06a743de5bd95653de630decfff40621dbde78cc307102", size = 89896, upload-time = "2025-01-23T17:50:44.487Z" }, - { url = "https://files.pythonhosted.org/packages/e5/14/84d46e62bfde46dd20cfb041e0bb5c2ec454fd6a384696e7fa3463c5bb59/nvidia_nvtx_cu12-12.8.55-py3-none-win_amd64.whl", hash = "sha256:9022681677aef1313458f88353ad9c0d2fbbe6402d6b07c9f00ba0e3ca8774d3", size = 56435, upload-time = "2025-01-23T18:06:06.268Z" }, -] - -[[package]] -name = "open-clip-torch" -version = "2.32.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "ftfy" }, - { name = "huggingface-hub" }, - { name = "regex" }, - { name = "safetensors" }, - { name = "timm" }, - { name = "torch", version = "2.0.1", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://pypi.org/simple" }, marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" }, marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "extra == 'extra-7-comfyui-cu128' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.15.2", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1", source = { registry = "https://pypi.org/simple" }, marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" }, marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "(platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "tqdm" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/6d/7b/fd38dfd522968135dce71d0b543c2ae776f9c8e27df6ad46b63bab09eef7/open_clip_torch-2.32.0.tar.gz", hash = "sha256:0220bc111162527eb738c1fe20dbfd6ea45dfe44726b54a4de18d3945d8f2f00", size = 1491248, upload-time = "2025-04-05T21:55:24.51Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/32/f9/0458745c1d299411161ee3b6c32228a3de0be1d8497d779fd7f17a8e96aa/open_clip_torch-2.32.0-py3-none-any.whl", hash = "sha256:80b35b43e37afc2b6173aa5ab0ad68744ab3a3211e624f72dfe743a162707637", size = 1528783, upload-time = "2025-04-05T21:55:22.967Z" }, -] - -[[package]] -name = "openai" -version = "1.88.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "anyio" }, - { name = "distro" }, - { name = "httpx" }, - { name = "jiter" }, - { name = "pydantic" }, - { name = "sniffio" }, - { name = "tqdm" }, - { name = "typing-extensions" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/5a/ea/bbeef604d1fe0f7e9111745bb8a81362973a95713b28855beb9a9832ab12/openai-1.88.0.tar.gz", hash = "sha256:122d35e42998255cf1fc84560f6ee49a844e65c054cd05d3e42fda506b832bb1", size = 470963, upload-time = "2025-06-17T05:04:45.856Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/f4/03/ef68d77a38dd383cbed7fc898857d394d5a8b0520a35f054e7fe05dc3ac1/openai-1.88.0-py3-none-any.whl", hash = "sha256:7edd7826b3b83f5846562a6f310f040c79576278bf8e3687b30ba05bb5dff978", size = 734293, upload-time = "2025-06-17T05:04:43.858Z" }, -] - -[[package]] -name = "opencv-python-headless" -version = "4.11.0.86" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/36/2f/5b2b3ba52c864848885ba988f24b7f105052f68da9ab0e693cc7c25b0b30/opencv-python-headless-4.11.0.86.tar.gz", hash = "sha256:996eb282ca4b43ec6a3972414de0e2331f5d9cda2b41091a49739c19fb843798", size = 95177929, upload-time = "2025-01-16T13:53:40.22Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/dc/53/2c50afa0b1e05ecdb4603818e85f7d174e683d874ef63a6abe3ac92220c8/opencv_python_headless-4.11.0.86-cp37-abi3-macosx_13_0_arm64.whl", hash = "sha256:48128188ade4a7e517237c8e1e11a9cdf5c282761473383e77beb875bb1e61ca", size = 37326460, upload-time = "2025-01-16T13:52:57.015Z" }, - { url = "https://files.pythonhosted.org/packages/3b/43/68555327df94bb9b59a1fd645f63fafb0762515344d2046698762fc19d58/opencv_python_headless-4.11.0.86-cp37-abi3-macosx_13_0_x86_64.whl", hash = "sha256:a66c1b286a9de872c343ee7c3553b084244299714ebb50fbdcd76f07ebbe6c81", size = 56723330, upload-time = "2025-01-16T13:55:45.731Z" }, - { url = "https://files.pythonhosted.org/packages/45/be/1438ce43ebe65317344a87e4b150865c5585f4c0db880a34cdae5ac46881/opencv_python_headless-4.11.0.86-cp37-abi3-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:6efabcaa9df731f29e5ea9051776715b1bdd1845d7c9530065c7951d2a2899eb", size = 29487060, upload-time = "2025-01-16T13:51:59.625Z" }, - { url = "https://files.pythonhosted.org/packages/dd/5c/c139a7876099916879609372bfa513b7f1257f7f1a908b0bdc1c2328241b/opencv_python_headless-4.11.0.86-cp37-abi3-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:0e0a27c19dd1f40ddff94976cfe43066fbbe9dfbb2ec1907d66c19caef42a57b", size = 49969856, upload-time = "2025-01-16T13:53:29.654Z" }, - { url = "https://files.pythonhosted.org/packages/95/dd/ed1191c9dc91abcc9f752b499b7928aacabf10567bb2c2535944d848af18/opencv_python_headless-4.11.0.86-cp37-abi3-win32.whl", hash = "sha256:f447d8acbb0b6f2808da71fddd29c1cdd448d2bc98f72d9bb78a7a898fc9621b", size = 29324425, upload-time = "2025-01-16T13:52:49.048Z" }, - { url = "https://files.pythonhosted.org/packages/86/8a/69176a64335aed183529207ba8bc3d329c2999d852b4f3818027203f50e6/opencv_python_headless-4.11.0.86-cp37-abi3-win_amd64.whl", hash = "sha256:6c304df9caa7a6a5710b91709dd4786bf20a74d57672b3c31f7033cc638174ca", size = 39402386, upload-time = "2025-01-16T13:52:56.418Z" }, -] - -[[package]] -name = "openexr" -version = "3.3.4" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/d9/f8/f47e1ba7447209968ef9e63f453dac8c87ae2f1379cfb10108d241356400/openexr-3.3.4.tar.gz", hash = "sha256:49e814fe9f60777a02393a61720cf6c2684ae92ba9055c4056aaf660c1d8592c", size = 21075282, upload-time = "2025-06-09T02:04:59.428Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/d3/1d/ef8d60893e9375192fb2fb8d61413fca51dcd64429fa924889007708ce7e/openexr-3.3.4-cp310-cp310-macosx_10_15_universal2.whl", hash = "sha256:bb1de3e4b4a3081c5f1d698255b2d4caeb1302e6ba5e9e30ce3146dff26707c9", size = 2017730, upload-time = "2025-06-09T02:03:33.002Z" }, - { url = "https://files.pythonhosted.org/packages/98/65/8b6fcdf9b7e93d82f803b720355026b2f3f226e9dab92c6dc3e11c5b13f2/openexr-3.3.4-cp310-cp310-macosx_10_15_x86_64.whl", hash = "sha256:2efa9a331b9e7a818ab6b50dc5f06d378bf1f7102fbd730dc1c59919bd5e3014", size = 1046331, upload-time = "2025-06-09T02:03:35.021Z" }, - { url = "https://files.pythonhosted.org/packages/5e/0d/232a0b6bd03b41ee5462dcbb7a9b01f363d4690e74123b6c5c449ae6e8f0/openexr-3.3.4-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:bee442829cc180f2ac1fda957e3e6885a76e14d58b50943ddd4ce4f594313d0b", size = 980854, upload-time = "2025-06-09T02:03:37.358Z" }, - { url = "https://files.pythonhosted.org/packages/7c/88/e734c1fc787eada7b8395e8ee120fb58f3c4430132bbb277f584ff2175f9/openexr-3.3.4-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:f34062139af1fbdcba80d13527d9ad19b76433135676f86b0657bd8eaa4b3f51", size = 1115700, upload-time = "2025-06-09T02:03:39.468Z" }, - { url = "https://files.pythonhosted.org/packages/2b/0c/7e913f31293194dfa45f7e6093017cacc3c75e2b8742027dfeced547daba/openexr-3.3.4-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:f100604729621209ad18f4d91049a60514f1df7ea8040c4e7487c6883145bec4", size = 1174896, upload-time = "2025-06-09T02:03:41.186Z" }, - { url = "https://files.pythonhosted.org/packages/5d/b9/e2a8def7d425426747f8d0bd02639271b13ad51e2cad619608a00bd6753a/openexr-3.3.4-cp310-cp310-musllinux_1_2_aarch64.whl", hash = "sha256:cc3074bf89a694eeca029d1f3f72896790bfdd20f5f50432cd15d78712b37eb5", size = 2083524, upload-time = "2025-06-09T02:03:43.208Z" }, - { url = "https://files.pythonhosted.org/packages/8e/d1/7aa3ff56b677cfd544b0bdae000a0a8812d6f83083fa098a89e7ae2b8d9e/openexr-3.3.4-cp310-cp310-musllinux_1_2_x86_64.whl", hash = "sha256:4ce9a142ba7ab90a036ae8dfabd6e49b9c0aba2688f5ec5d26892df5a092da86", size = 2192222, upload-time = "2025-06-09T02:03:45.608Z" }, - { url = "https://files.pythonhosted.org/packages/ef/9b/445df488fe6082036d29f11d6c7c81d8cb90de47051ced560ed59e81adc4/openexr-3.3.4-cp310-cp310-win_amd64.whl", hash = "sha256:852691d9fe414dabba12a8abcf14aa3dddccb7aa1b5d87ad9cf4b2a85149b675", size = 677746, upload-time = "2025-06-09T02:03:47.647Z" }, - { url = "https://files.pythonhosted.org/packages/41/36/845e559ea1f7894cd8c347ab702307826bd3238584c1561bf0f4306ef30e/openexr-3.3.4-cp311-cp311-macosx_10_15_universal2.whl", hash = "sha256:2fe9b6d04f2d4378bce077463d4704379a0a1b2854a8ca4295860c9f57147cae", size = 2021130, upload-time = "2025-06-09T02:03:49.562Z" }, - { url = "https://files.pythonhosted.org/packages/b2/96/e52331d0589983061de6f51a87dfefa8666e50f7183d61b35d29a8a0f765/openexr-3.3.4-cp311-cp311-macosx_10_15_x86_64.whl", hash = "sha256:c85dfe045d7aec423b4458e08f855c769ec0fdaac1dc232372b864f7bc51fa23", size = 1048073, upload-time = "2025-06-09T02:03:51.274Z" }, - { url = "https://files.pythonhosted.org/packages/82/f3/2ab9e147db91b4a43efb4c3024d6d2febc1aa620c36f47b5a5847ed42dce/openexr-3.3.4-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:d86e03627ccaa41be9fdff0db9c98d4260f2ab6000e361816d091a31622e450a", size = 982584, upload-time = "2025-06-09T02:03:53.22Z" }, - { url = "https://files.pythonhosted.org/packages/b9/7a/1df7cbcc30adcd5748f0b360524a96f2bbf79f23f8d8f1da35a34cc22c16/openexr-3.3.4-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:f5e3eb8041306dbf595fd4315e0f8acc1a7fa3892d3b8cbff5f4ea4963951005", size = 1116487, upload-time = "2025-06-09T02:03:54.907Z" }, - { url = "https://files.pythonhosted.org/packages/c9/68/2b0decc6a126b9994f85712ae113dd2fcb21509598de02c199c1dbe16506/openexr-3.3.4-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:8dcf89e7bed97c03aa68af42f55f3100ef5b215f1228638b8bc09f66b5a98266", size = 1176322, upload-time = "2025-06-09T02:03:57.055Z" }, - { url = "https://files.pythonhosted.org/packages/ca/15/ded7e2a147c660811f42bb6f146e2cfbda6c4067f88c9896ad0cb11c7eb1/openexr-3.3.4-cp311-cp311-musllinux_1_2_aarch64.whl", hash = "sha256:d9a67e979941b2ddd7bf495dfbc85edd23bb132ed92bcf1c6b6d64e9d92ff62a", size = 2085550, upload-time = "2025-06-09T02:03:59.202Z" }, - { url = "https://files.pythonhosted.org/packages/9a/e6/c69bb562ae98623f8f5c753ab78fc170ec75e20b9c97ac05a635fd3729e8/openexr-3.3.4-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:f0fa54c4da43d6c4c539b143c2552211ec62d204bdb948f6accf60af408822ae", size = 2193008, upload-time = "2025-06-09T02:04:00.934Z" }, - { url = "https://files.pythonhosted.org/packages/6c/3e/16f70bfdc4a6914f868b328289907ba0c50a9fc0cf409f77ba8b7f7ca489/openexr-3.3.4-cp311-cp311-win_amd64.whl", hash = "sha256:2e0fb02339dc5b2aa42038d1766da44e175118838ce76fafba29d69fda8c519b", size = 678463, upload-time = "2025-06-09T02:04:02.541Z" }, - { url = "https://files.pythonhosted.org/packages/8d/06/09a8c3d097d13ad73e70ed88f7329322251198e52869b6d2c0a482eb23da/openexr-3.3.4-cp312-cp312-macosx_10_15_universal2.whl", hash = "sha256:eba95c865db2d0fa8dd3febd6451900803c0b1354fd54c8e056dcbb8c2ea2fc5", size = 2030778, upload-time = "2025-06-09T02:04:04.319Z" }, - { url = "https://files.pythonhosted.org/packages/15/44/3c7e0a95aacc4b931f7ed7477edd6206e15e4fffd9ad9fbf30a6a1724f19/openexr-3.3.4-cp312-cp312-macosx_10_15_x86_64.whl", hash = "sha256:65979cd9f6d402e508afc131e30465898028a781693ea84a28eaaac3f8402cac", size = 1053661, upload-time = "2025-06-09T02:04:06.356Z" }, - { url = "https://files.pythonhosted.org/packages/30/b4/9e17140b575a6b5b1a7ac53524f2aa41be3f21715c1f537db53b1dd687d3/openexr-3.3.4-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:24b1e57314d2c82135033538b25ec857608009103a21299344a69d9b8e044792", size = 984042, upload-time = "2025-06-09T02:04:08.102Z" }, - { url = "https://files.pythonhosted.org/packages/7b/d1/5fddf431be3fcbb17af855163e5c78b6cd3a54e8cd4827a54d3f1552ed41/openexr-3.3.4-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:92da83660ea6bac48ae5b9b9ddd202dd3fb88bffb9135e279aa0cd47c79c7240", size = 1112891, upload-time = "2025-06-09T02:04:09.793Z" }, - { url = "https://files.pythonhosted.org/packages/9e/3b/66ae1b024f60a1001903aa75d2b82f03e3cdd5972e449426c8c6b3b191f9/openexr-3.3.4-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:42bfc5c5dbebc974c6ed029a843a89c6f0235a661c24005a45f96d3ac3f8fad3", size = 1175062, upload-time = "2025-06-09T02:04:11.436Z" }, - { url = "https://files.pythonhosted.org/packages/4f/cd/ed6288f73fae8de93f61cbae02e4908a1c591fb3fbe36897e7635b3b3649/openexr-3.3.4-cp312-cp312-musllinux_1_2_aarch64.whl", hash = "sha256:dad866a8f8e82f18ddb636b4d9aac0b5596ea6256a592bad4b828941d9b253ea", size = 2086790, upload-time = "2025-06-09T02:04:13.206Z" }, - { url = "https://files.pythonhosted.org/packages/0f/4f/fc7e26e4e74be569680d9257e22ddbaf0e6656afe8b8ea97c82e9de5ee35/openexr-3.3.4-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:fb456ceeffe9c97bd99f69ac5ac3ae5b5948466d9195db0d575fafc6989dbd73", size = 2194810, upload-time = "2025-06-09T02:04:15.516Z" }, - { url = "https://files.pythonhosted.org/packages/6c/8b/782f56af1edad038d2f0fc149cbfe9a1d787f4830a4c20b2ce2dc639ed1b/openexr-3.3.4-cp312-cp312-win_amd64.whl", hash = "sha256:31fe38752630211a43e74ee6d768eb5c888f466bacf1617fd1ee9e807c26fe70", size = 679943, upload-time = "2025-06-09T02:04:17.069Z" }, -] - -[[package]] -name = "opentelemetry-api" -version = "1.34.1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "importlib-metadata" }, - { name = "typing-extensions" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/4d/5e/94a8cb759e4e409022229418294e098ca7feca00eb3c467bb20cbd329bda/opentelemetry_api-1.34.1.tar.gz", hash = "sha256:64f0bd06d42824843731d05beea88d4d4b6ae59f9fe347ff7dfa2cc14233bbb3", size = 64987, upload-time = "2025-06-10T08:55:19.818Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/a5/3a/2ba85557e8dc024c0842ad22c570418dc02c36cbd1ab4b832a93edf071b8/opentelemetry_api-1.34.1-py3-none-any.whl", hash = "sha256:b7df4cb0830d5a6c29ad0c0691dbae874d8daefa934b8b1d642de48323d32a8c", size = 65767, upload-time = "2025-06-10T08:54:56.717Z" }, -] - -[[package]] -name = "opentelemetry-distro" -version = "0.55b1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "opentelemetry-api" }, - { name = "opentelemetry-instrumentation" }, - { name = "opentelemetry-sdk" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/1f/bc/2a447ad11ce5247378b7ad736647b4160f43890ef0bb6b45986925bac2b0/opentelemetry_distro-0.55b1.tar.gz", hash = "sha256:da442bf137ab48f531b87d2ec80a19eada53b54c153ad96f0689f946a8d9bcd3", size = 2582, upload-time = "2025-06-10T08:58:13.592Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/6f/7a/6384468f67a9283d3654193e327d0236438f92238e2abdec334a749b3ad6/opentelemetry_distro-0.55b1-py3-none-any.whl", hash = "sha256:6b9dc9bf78b221206096f964e9cdf9bbba4d703725e1115de4b8c83cad1e45cc", size = 3344, upload-time = "2025-06-10T08:57:10.745Z" }, -] - -[[package]] -name = "opentelemetry-exporter-otlp" -version = "1.15.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "opentelemetry-exporter-otlp-proto-grpc" }, - { name = "opentelemetry-exporter-otlp-proto-http" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/d9/bd/abafe13a0d77145270a39de7442d12d71b51a9f9d103d15d636110ae8a21/opentelemetry_exporter_otlp-1.15.0.tar.gz", hash = "sha256:4f7c49751d9720e2e726e13b0bb958ccade4e29122c305d92c033da432c8d2c5", size = 6126, upload-time = "2022-12-09T22:28:43.353Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/64/a2/4956610bd5348977fea8818d488793a46d1359337c0226164f093a17c61c/opentelemetry_exporter_otlp-1.15.0-py3-none-any.whl", hash = "sha256:79f22748b6a54808a0448093dfa189c8490e729f67c134d4c992533d9393b33e", size = 6976, upload-time = "2022-12-09T22:28:12.944Z" }, -] - -[[package]] -name = "opentelemetry-exporter-otlp-proto-grpc" -version = "1.15.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "backoff" }, - { name = "googleapis-common-protos" }, - { name = "grpcio" }, - { name = "opentelemetry-api" }, - { name = "opentelemetry-proto" }, - { name = "opentelemetry-sdk" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/e4/ab/1be294b194af410f350f867a54621b4f33b7551adce2ae795e907148fc1e/opentelemetry_exporter_otlp_proto_grpc-1.15.0.tar.gz", hash = "sha256:844f2a4bb9bcda34e4eb6fe36765e5031aacb36dc60ed88c90fc246942ea26e7", size = 27262, upload-time = "2022-12-09T22:28:44.359Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/dd/8f/73ad108bcfd61b4169be5ad8b76acaf9158f224740da10ab9ea3469d551a/opentelemetry_exporter_otlp_proto_grpc-1.15.0-py3-none-any.whl", hash = "sha256:c2a5492ba7d140109968135d641d06ce3c5bd73c50665f787526065d57d7fd1d", size = 20378, upload-time = "2022-12-09T22:28:14.623Z" }, -] - -[[package]] -name = "opentelemetry-exporter-otlp-proto-http" -version = "1.15.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "backoff" }, - { name = "googleapis-common-protos" }, - { name = "opentelemetry-api" }, - { name = "opentelemetry-proto" }, - { name = "opentelemetry-sdk" }, - { name = "requests" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/ad/ee/14baa8edbf6b0c8e23a93ee0807fb637d4689959a0b166e2821032fade34/opentelemetry_exporter_otlp_proto_http-1.15.0.tar.gz", hash = "sha256:11b2c814249a49b22f6cca7a06b05701f561d577b747f3660dfd67b6eb9daf9c", size = 18930, upload-time = "2022-12-09T22:28:45.366Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/b0/12/77af459682a4f41eb9f13801af6a12420a86f5673dc568585ee49112e969/opentelemetry_exporter_otlp_proto_http-1.15.0-py3-none-any.whl", hash = "sha256:3ec2a02196c8a54bf5cbf7fe623a5238625638e83b6047a983bdf96e2bbb74c0", size = 21588, upload-time = "2022-12-09T22:28:15.776Z" }, -] - -[[package]] -name = "opentelemetry-instrumentation" -version = "0.55b1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "opentelemetry-api" }, - { name = "opentelemetry-semantic-conventions" }, - { name = "packaging" }, - { name = "wrapt" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/cb/69/d8995f229ddf4d98b9c85dd126aeca03dd1742f6dc5d3bc0d2f6dae1535c/opentelemetry_instrumentation-0.55b1.tar.gz", hash = "sha256:2dc50aa207b9bfa16f70a1a0571e011e737a9917408934675b89ef4d5718c87b", size = 28552, upload-time = "2025-06-10T08:58:15.312Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/60/7d/8ddfda1506c2fcca137924d5688ccabffa1aed9ec0955b7d0772de02cec3/opentelemetry_instrumentation-0.55b1-py3-none-any.whl", hash = "sha256:cbb1496b42bc394e01bc63701b10e69094e8564e281de063e4328d122cc7a97e", size = 31108, upload-time = "2025-06-10T08:57:14.355Z" }, -] - -[[package]] -name = "opentelemetry-instrumentation-aio-pika" -version = "0.55b1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "opentelemetry-api" }, - { name = "opentelemetry-instrumentation" }, - { name = "wrapt" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/de/4f/3a3dfacb5cce002e2ac451f2565fc60ed5610fbc7a76fd9f18d94f10ae47/opentelemetry_instrumentation_aio_pika-0.55b1.tar.gz", hash = "sha256:376e85e20c7937255be6705c4effdb488290937928ccfb53c0d45825b5074e7a", size = 10076, upload-time = "2025-06-10T08:58:15.968Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/50/f2/36c5787cb3a98c10b172ce278797fc9c56d2baebf08fb35673b502ac7f28/opentelemetry_instrumentation_aio_pika-0.55b1-py3-none-any.whl", hash = "sha256:1f7277df3275d497276c8f45e62771dda2d9557de9e0ee4c86e537fa888a2dd2", size = 13457, upload-time = "2025-06-10T08:57:15.309Z" }, -] - -[[package]] -name = "opentelemetry-instrumentation-requests" -version = "0.55b1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "opentelemetry-api" }, - { name = "opentelemetry-instrumentation" }, - { name = "opentelemetry-semantic-conventions" }, - { name = "opentelemetry-util-http" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/29/0c/8300ceffd0a41e69590f20ff4854f5c0b2ed5e9453c21c1d710746377cd2/opentelemetry_instrumentation_requests-0.55b1.tar.gz", hash = "sha256:3a04ae7bc90af08acef074b369275cf77c60533b319fa91cad76a380fd035c83", size = 14778, upload-time = "2025-06-10T08:58:42.958Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/fc/31/9643d13bb78e07038c96e264a9e75cde93ecde50ff2b0cac7597613074d7/opentelemetry_instrumentation_requests-0.55b1-py3-none-any.whl", hash = "sha256:c9ba0a67850b49aa965e760e87e4b68e52530e5373a0b3c15d290a8997136619", size = 12973, upload-time = "2025-06-10T08:57:58.132Z" }, -] - -[[package]] -name = "opentelemetry-propagator-jaeger" -version = "1.34.1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "opentelemetry-api" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/5c/33/17dd30e5b065287c0aa326eb1790754e770f9b216b64267d188117228554/opentelemetry_propagator_jaeger-1.34.1.tar.gz", hash = "sha256:130794595cc3e559bd0a1298942d4e17bbaaf738e2dace719e5a17a12fc65620", size = 8661, upload-time = "2025-06-10T08:55:31.625Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/7a/84/4f5e00f6768c9c2d17a608226aff3f11f274f65e76e7ef00f57bb5d74460/opentelemetry_propagator_jaeger-1.34.1-py3-none-any.whl", hash = "sha256:d71948a9f3eaa23224ab773038e9f7c11a8f2aaa38e8cabc78f70a8f72d91ec7", size = 8777, upload-time = "2025-06-10T08:55:13.584Z" }, -] - -[[package]] -name = "opentelemetry-proto" -version = "1.15.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "protobuf" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/1e/80/b3b2a98039574e57b6b15982219ae025d55f8c46d50dde258865ce5601b4/opentelemetry_proto-1.15.0.tar.gz", hash = "sha256:9c4008e40ac8cab359daac283fbe7002c5c29c77ea2674ad5626a249e64e0101", size = 35713, upload-time = "2022-12-09T22:28:55.409Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/3a/56/8343d94af8f32594f6b0bd273f72a40e430fb5970a353237af53af5d3031/opentelemetry_proto-1.15.0-py3-none-any.whl", hash = "sha256:044b6d044b4d10530f250856f933442b8753a17f94ae37c207607f733fb9a844", size = 52616, upload-time = "2022-12-09T22:28:30.03Z" }, -] - -[[package]] -name = "opentelemetry-sdk" -version = "1.34.1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "opentelemetry-api" }, - { name = "opentelemetry-semantic-conventions" }, - { name = "typing-extensions" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/6f/41/fe20f9036433da8e0fcef568984da4c1d1c771fa072ecd1a4d98779dccdd/opentelemetry_sdk-1.34.1.tar.gz", hash = "sha256:8091db0d763fcd6098d4781bbc80ff0971f94e260739aa6afe6fd379cdf3aa4d", size = 159441, upload-time = "2025-06-10T08:55:33.028Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/07/1b/def4fe6aa73f483cabf4c748f4c25070d5f7604dcc8b52e962983491b29e/opentelemetry_sdk-1.34.1-py3-none-any.whl", hash = "sha256:308effad4059562f1d92163c61c8141df649da24ce361827812c40abb2a1e96e", size = 118477, upload-time = "2025-06-10T08:55:16.02Z" }, -] - -[[package]] -name = "opentelemetry-semantic-conventions" -version = "0.55b1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "opentelemetry-api" }, - { name = "typing-extensions" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/5d/f0/f33458486da911f47c4aa6db9bda308bb80f3236c111bf848bd870c16b16/opentelemetry_semantic_conventions-0.55b1.tar.gz", hash = "sha256:ef95b1f009159c28d7a7849f5cbc71c4c34c845bb514d66adfdf1b3fff3598b3", size = 119829, upload-time = "2025-06-10T08:55:33.881Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/1a/89/267b0af1b1d0ba828f0e60642b6a5116ac1fd917cde7fc02821627029bd1/opentelemetry_semantic_conventions-0.55b1-py3-none-any.whl", hash = "sha256:5da81dfdf7d52e3d37f8fe88d5e771e191de924cfff5f550ab0b8f7b2409baed", size = 196223, upload-time = "2025-06-10T08:55:17.638Z" }, -] - -[[package]] -name = "opentelemetry-util-http" -version = "0.55b1" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/12/f7/3cc23b95921177cdda6d61d3475659b86bac335ed02dd19f994a850ceee3/opentelemetry_util_http-0.55b1.tar.gz", hash = "sha256:29e119c1f6796cccf5fc2aedb55274435cde5976d0ac3fec3ca20a80118f821e", size = 8038, upload-time = "2025-06-10T08:58:53.414Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/a3/0a/49c5464efc0e6f6aa94a9ec054879efe2a59d7c1f6aacc500665b3d8afdc/opentelemetry_util_http-0.55b1-py3-none-any.whl", hash = "sha256:e134218df8ff010e111466650e5f019496b29c3b4f1b7de0e8ff8ebeafeebdf4", size = 7299, upload-time = "2025-06-10T08:58:11.785Z" }, -] - -[[package]] -name = "opt-einsum" -version = "3.4.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/8c/b9/2ac072041e899a52f20cf9510850ff58295003aa75525e58343591b0cbfb/opt_einsum-3.4.0.tar.gz", hash = "sha256:96ca72f1b886d148241348783498194c577fa30a8faac108586b14f1ba4473ac", size = 63004, upload-time = "2024-09-26T14:33:24.483Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/23/cd/066e86230ae37ed0be70aae89aabf03ca8d9f39c8aea0dec8029455b5540/opt_einsum-3.4.0-py3-none-any.whl", hash = "sha256:69bb92469f86a1565195ece4ac0323943e83477171b91d24c35afe028a90d7cd", size = 71932, upload-time = "2024-09-26T14:33:23.039Z" }, -] - -[[package]] -name = "optax" -version = "0.2.5" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "absl-py" }, - { name = "chex" }, - { name = "jax" }, - { name = "jaxlib" }, - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/c0/75/1e011953c48be502d4d84fa8458e91be7c6f983002511669bddd7b1a065f/optax-0.2.5.tar.gz", hash = "sha256:b2e38c7aea376186deae758ba7a258e6ef760c6f6131e9e11bc561c65386d594", size = 258548, upload-time = "2025-06-10T17:00:47.544Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/b9/33/f86091c706db1a5459f501830241afff2ecab3532725c188ea57be6e54de/optax-0.2.5-py3-none-any.whl", hash = "sha256:966deae936207f268ac8f564d8ed228d645ac1aaddefbbf194096d2299b24ba8", size = 354324, upload-time = "2025-06-10T17:00:46.062Z" }, -] - -[[package]] -name = "orbax-checkpoint" -version = "0.11.15" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "absl-py" }, - { name = "etils", extra = ["epath", "epy"] }, - { name = "humanize" }, - { name = "jax" }, - { name = "msgpack" }, - { name = "nest-asyncio" }, - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "protobuf" }, - { name = "pyyaml" }, - { name = "simplejson" }, - { name = "tensorstore" }, - { name = "typing-extensions" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/08/e3/c16be24e4f70fab99586a31a918a124a0cbd4e852e7344399dfd9ead2003/orbax_checkpoint-0.11.15.tar.gz", hash = "sha256:b602787715200de22a5b29a493cfa6e09c951697bee5e3df36509b62f01c87d8", size = 338039, upload-time = "2025-06-13T17:34:48.547Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/c2/fd/94b37f1233f7f09d8f03712d6cfad3d3bcb752d22e845d9fe3eb075f1347/orbax_checkpoint-0.11.15-py3-none-any.whl", hash = "sha256:1c6ed79e398588a2fd592ad5e017d9aff8915fe83e8b2d7146daa78576c3bb05", size = 477501, upload-time = "2025-06-13T17:34:47.335Z" }, -] - -[[package]] -name = "packaging" -version = "24.2" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/d0/63/68dbb6eb2de9cb10ee4c9c14a0148804425e13c4fb20d61cce69f53106da/packaging-24.2.tar.gz", hash = "sha256:c228a6dc5e932d346bc5739379109d49e8853dd8223571c7c5b55260edc0b97f", size = 163950, upload-time = "2024-11-08T09:47:47.202Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/88/ef/eb23f262cca3c0c4eb7ab1933c3b1f03d021f2c48f54763065b6f0e321be/packaging-24.2-py3-none-any.whl", hash = "sha256:09abb1bccd265c01f4a3aa3f7a7db064b36514d2cba19a2f694fe6150451a759", size = 65451, upload-time = "2024-11-08T09:47:44.722Z" }, -] - -[[package]] -name = "pamqp" -version = "3.3.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/fb/62/35bbd3d3021e008606cd0a9532db7850c65741bbf69ac8a3a0d8cfeb7934/pamqp-3.3.0.tar.gz", hash = "sha256:40b8795bd4efcf2b0f8821c1de83d12ca16d5760f4507836267fd7a02b06763b", size = 30993, upload-time = "2024-01-12T20:37:25.085Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/ac/8d/c1e93296e109a320e508e38118cf7d1fc2a4d1c2ec64de78565b3c445eb5/pamqp-3.3.0-py2.py3-none-any.whl", hash = "sha256:c901a684794157ae39b52cbf700db8c9aae7a470f13528b9d7b4e5f7202f8eb0", size = 33848, upload-time = "2024-01-12T20:37:21.359Z" }, -] - -[[package]] -name = "pathspec" -version = "0.12.1" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/ca/bc/f35b8446f4531a7cb215605d100cd88b7ac6f44ab3fc94870c120ab3adbf/pathspec-0.12.1.tar.gz", hash = "sha256:a482d51503a1ab33b1c67a6c3813a26953dbdc71c31dacaef9a838c4e29f5712", size = 51043, upload-time = "2023-12-10T22:30:45Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/cc/20/ff623b09d963f88bfde16306a54e12ee5ea43e9b597108672ff3a408aad6/pathspec-0.12.1-py3-none-any.whl", hash = "sha256:a0d503e138a4c123b27490a4f7beda6a01c6f288df0e4a8b79c7eb0dc7b4cc08", size = 31191, upload-time = "2023-12-10T22:30:43.14Z" }, -] - -[[package]] -name = "pebble" -version = "5.1.1" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/5f/5b/90bf2acce03a12750a570cede27b9cddd4b6f5f2cf4de1048231bb21c382/pebble-5.1.1.tar.gz", hash = "sha256:4e91a5b8e48b30b26eaa5391ba2cf65fbb3594fba17b88bc0b3351cf849d0305", size = 38672, upload-time = "2025-03-16T16:23:08.219Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/4d/a7/bece0e6b17b75506c4bf13eb79728931e2f240d7928a02f0e6d2ca9c41e9/pebble-5.1.1-py3-none-any.whl", hash = "sha256:c262c94159cf6419fd4ac27ff72408650a16d6c3cf000171fb2a0386038c416e", size = 34598, upload-time = "2025-03-16T16:22:26.954Z" }, -] - -[[package]] -name = "pefile" -version = "2023.2.7" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/78/c5/3b3c62223f72e2360737fd2a57c30e5b2adecd85e70276879609a7403334/pefile-2023.2.7.tar.gz", hash = "sha256:82e6114004b3d6911c77c3953e3838654b04511b8b66e8583db70c65998017dc", size = 74854, upload-time = "2023-02-07T12:23:55.958Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/55/26/d0ad8b448476d0a1e8d3ea5622dc77b916db84c6aa3cb1e1c0965af948fc/pefile-2023.2.7-py3-none-any.whl", hash = "sha256:da185cd2af68c08a6cd4481f7325ed600a88f6a813bad9dea07ab3ef73d8d8d6", size = 71791, upload-time = "2023-02-07T12:28:36.678Z" }, -] - -[[package]] -name = "peft" -version = "0.15.2" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "accelerate" }, - { name = "huggingface-hub" }, - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "packaging" }, - { name = "psutil" }, - { name = "pyyaml" }, - { name = "safetensors" }, - { name = "torch", version = "2.0.1", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://pypi.org/simple" }, marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" }, marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "extra == 'extra-7-comfyui-cu128' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "tqdm" }, - { name = "transformers" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/33/65/faa18cd8ffbe0f742c3f2559770646cce2574b9cd28a2a05e8d36f64e968/peft-0.15.2.tar.gz", hash = "sha256:7059029f4d42a092ded1aa117dd366a46084aef638bdd593f6ab0195d5427fcd", size = 472952, upload-time = "2025-04-15T15:27:53.09Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/68/85/8e6ea3d1089f2b6de3c1cd34bbbd7560912af9d34b057be3b8b8fefe1da3/peft-0.15.2-py3-none-any.whl", hash = "sha256:0dfc942b03b7af4b7267cd4e30b15e3a4a1d277adc581ce6245fc13f1f93d0a0", size = 411051, upload-time = "2025-04-15T15:27:50.799Z" }, -] - -[[package]] -name = "pika" -version = "1.3.2" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/db/db/d4102f356af18f316c67f2cead8ece307f731dd63140e2c71f170ddacf9b/pika-1.3.2.tar.gz", hash = "sha256:b2a327ddddf8570b4965b3576ac77091b850262d34ce8c1d8cb4e4146aa4145f", size = 145029, upload-time = "2023-05-05T14:25:43.368Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/f9/f3/f412836ec714d36f0f4ab581b84c491e3f42c6b5b97a6c6ed1817f3c16d0/pika-1.3.2-py3-none-any.whl", hash = "sha256:0779a7c1fafd805672796085560d290213a465e4f6f76a6fb19e378d8041a14f", size = 155415, upload-time = "2023-05-05T14:25:41.484Z" }, -] - -[[package]] -name = "pillow" -version = "11.2.1" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/af/cb/bb5c01fcd2a69335b86c22142b2bccfc3464087efb7fd382eee5ffc7fdf7/pillow-11.2.1.tar.gz", hash = "sha256:a64dd61998416367b7ef979b73d3a85853ba9bec4c2925f74e588879a58716b6", size = 47026707, upload-time = "2025-04-12T17:50:03.289Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/0d/8b/b158ad57ed44d3cc54db8d68ad7c0a58b8fc0e4c7a3f995f9d62d5b464a1/pillow-11.2.1-cp310-cp310-macosx_10_10_x86_64.whl", hash = "sha256:d57a75d53922fc20c165016a20d9c44f73305e67c351bbc60d1adaf662e74047", size = 3198442, upload-time = "2025-04-12T17:47:10.666Z" }, - { url = "https://files.pythonhosted.org/packages/b1/f8/bb5d956142f86c2d6cc36704943fa761f2d2e4c48b7436fd0a85c20f1713/pillow-11.2.1-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:127bf6ac4a5b58b3d32fc8289656f77f80567d65660bc46f72c0d77e6600cc95", size = 3030553, upload-time = "2025-04-12T17:47:13.153Z" }, - { url = "https://files.pythonhosted.org/packages/22/7f/0e413bb3e2aa797b9ca2c5c38cb2e2e45d88654e5b12da91ad446964cfae/pillow-11.2.1-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:b4ba4be812c7a40280629e55ae0b14a0aafa150dd6451297562e1764808bbe61", size = 4405503, upload-time = "2025-04-12T17:47:15.36Z" }, - { url = "https://files.pythonhosted.org/packages/f3/b4/cc647f4d13f3eb837d3065824aa58b9bcf10821f029dc79955ee43f793bd/pillow-11.2.1-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:c8bd62331e5032bc396a93609982a9ab6b411c05078a52f5fe3cc59234a3abd1", size = 4490648, upload-time = "2025-04-12T17:47:17.37Z" }, - { url = "https://files.pythonhosted.org/packages/c2/6f/240b772a3b35cdd7384166461567aa6713799b4e78d180c555bd284844ea/pillow-11.2.1-cp310-cp310-manylinux_2_28_aarch64.whl", hash = "sha256:562d11134c97a62fe3af29581f083033179f7ff435f78392565a1ad2d1c2c45c", size = 4508937, upload-time = "2025-04-12T17:47:19.066Z" }, - { url = "https://files.pythonhosted.org/packages/f3/5e/7ca9c815ade5fdca18853db86d812f2f188212792780208bdb37a0a6aef4/pillow-11.2.1-cp310-cp310-manylinux_2_28_x86_64.whl", hash = "sha256:c97209e85b5be259994eb5b69ff50c5d20cca0f458ef9abd835e262d9d88b39d", size = 4599802, upload-time = "2025-04-12T17:47:21.404Z" }, - { url = "https://files.pythonhosted.org/packages/02/81/c3d9d38ce0c4878a77245d4cf2c46d45a4ad0f93000227910a46caff52f3/pillow-11.2.1-cp310-cp310-musllinux_1_2_aarch64.whl", hash = "sha256:0c3e6d0f59171dfa2e25d7116217543310908dfa2770aa64b8f87605f8cacc97", size = 4576717, upload-time = "2025-04-12T17:47:23.571Z" }, - { url = "https://files.pythonhosted.org/packages/42/49/52b719b89ac7da3185b8d29c94d0e6aec8140059e3d8adcaa46da3751180/pillow-11.2.1-cp310-cp310-musllinux_1_2_x86_64.whl", hash = "sha256:cc1c3bc53befb6096b84165956e886b1729634a799e9d6329a0c512ab651e579", size = 4654874, upload-time = "2025-04-12T17:47:25.783Z" }, - { url = "https://files.pythonhosted.org/packages/5b/0b/ede75063ba6023798267023dc0d0401f13695d228194d2242d5a7ba2f964/pillow-11.2.1-cp310-cp310-win32.whl", hash = "sha256:312c77b7f07ab2139924d2639860e084ec2a13e72af54d4f08ac843a5fc9c79d", size = 2331717, upload-time = "2025-04-12T17:47:28.922Z" }, - { url = "https://files.pythonhosted.org/packages/ed/3c/9831da3edea527c2ed9a09f31a2c04e77cd705847f13b69ca60269eec370/pillow-11.2.1-cp310-cp310-win_amd64.whl", hash = "sha256:9bc7ae48b8057a611e5fe9f853baa88093b9a76303937449397899385da06fad", size = 2676204, upload-time = "2025-04-12T17:47:31.283Z" }, - { url = "https://files.pythonhosted.org/packages/01/97/1f66ff8a1503d8cbfc5bae4dc99d54c6ec1e22ad2b946241365320caabc2/pillow-11.2.1-cp310-cp310-win_arm64.whl", hash = "sha256:2728567e249cdd939f6cc3d1f049595c66e4187f3c34078cbc0a7d21c47482d2", size = 2414767, upload-time = "2025-04-12T17:47:34.655Z" }, - { url = "https://files.pythonhosted.org/packages/68/08/3fbf4b98924c73037a8e8b4c2c774784805e0fb4ebca6c5bb60795c40125/pillow-11.2.1-cp311-cp311-macosx_10_10_x86_64.whl", hash = "sha256:35ca289f712ccfc699508c4658a1d14652e8033e9b69839edf83cbdd0ba39e70", size = 3198450, upload-time = "2025-04-12T17:47:37.135Z" }, - { url = "https://files.pythonhosted.org/packages/84/92/6505b1af3d2849d5e714fc75ba9e69b7255c05ee42383a35a4d58f576b16/pillow-11.2.1-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:e0409af9f829f87a2dfb7e259f78f317a5351f2045158be321fd135973fff7bf", size = 3030550, upload-time = "2025-04-12T17:47:39.345Z" }, - { url = "https://files.pythonhosted.org/packages/3c/8c/ac2f99d2a70ff966bc7eb13dacacfaab57c0549b2ffb351b6537c7840b12/pillow-11.2.1-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:d4e5c5edee874dce4f653dbe59db7c73a600119fbea8d31f53423586ee2aafd7", size = 4415018, upload-time = "2025-04-12T17:47:41.128Z" }, - { url = "https://files.pythonhosted.org/packages/1f/e3/0a58b5d838687f40891fff9cbaf8669f90c96b64dc8f91f87894413856c6/pillow-11.2.1-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:b93a07e76d13bff9444f1a029e0af2964e654bfc2e2c2d46bfd080df5ad5f3d8", size = 4498006, upload-time = "2025-04-12T17:47:42.912Z" }, - { url = "https://files.pythonhosted.org/packages/21/f5/6ba14718135f08fbfa33308efe027dd02b781d3f1d5c471444a395933aac/pillow-11.2.1-cp311-cp311-manylinux_2_28_aarch64.whl", hash = "sha256:e6def7eed9e7fa90fde255afaf08060dc4b343bbe524a8f69bdd2a2f0018f600", size = 4517773, upload-time = "2025-04-12T17:47:44.611Z" }, - { url = "https://files.pythonhosted.org/packages/20/f2/805ad600fc59ebe4f1ba6129cd3a75fb0da126975c8579b8f57abeb61e80/pillow-11.2.1-cp311-cp311-manylinux_2_28_x86_64.whl", hash = "sha256:8f4f3724c068be008c08257207210c138d5f3731af6c155a81c2b09a9eb3a788", size = 4607069, upload-time = "2025-04-12T17:47:46.46Z" }, - { url = "https://files.pythonhosted.org/packages/71/6b/4ef8a288b4bb2e0180cba13ca0a519fa27aa982875882392b65131401099/pillow-11.2.1-cp311-cp311-musllinux_1_2_aarch64.whl", hash = "sha256:a0a6709b47019dff32e678bc12c63008311b82b9327613f534e496dacaefb71e", size = 4583460, upload-time = "2025-04-12T17:47:49.255Z" }, - { url = "https://files.pythonhosted.org/packages/62/ae/f29c705a09cbc9e2a456590816e5c234382ae5d32584f451c3eb41a62062/pillow-11.2.1-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:f6b0c664ccb879109ee3ca702a9272d877f4fcd21e5eb63c26422fd6e415365e", size = 4661304, upload-time = "2025-04-12T17:47:51.067Z" }, - { url = "https://files.pythonhosted.org/packages/6e/1a/c8217b6f2f73794a5e219fbad087701f412337ae6dbb956db37d69a9bc43/pillow-11.2.1-cp311-cp311-win32.whl", hash = "sha256:cc5d875d56e49f112b6def6813c4e3d3036d269c008bf8aef72cd08d20ca6df6", size = 2331809, upload-time = "2025-04-12T17:47:54.425Z" }, - { url = "https://files.pythonhosted.org/packages/e2/72/25a8f40170dc262e86e90f37cb72cb3de5e307f75bf4b02535a61afcd519/pillow-11.2.1-cp311-cp311-win_amd64.whl", hash = "sha256:0f5c7eda47bf8e3c8a283762cab94e496ba977a420868cb819159980b6709193", size = 2676338, upload-time = "2025-04-12T17:47:56.535Z" }, - { url = "https://files.pythonhosted.org/packages/06/9e/76825e39efee61efea258b479391ca77d64dbd9e5804e4ad0fa453b4ba55/pillow-11.2.1-cp311-cp311-win_arm64.whl", hash = "sha256:4d375eb838755f2528ac8cbc926c3e31cc49ca4ad0cf79cff48b20e30634a4a7", size = 2414918, upload-time = "2025-04-12T17:47:58.217Z" }, - { url = "https://files.pythonhosted.org/packages/c7/40/052610b15a1b8961f52537cc8326ca6a881408bc2bdad0d852edeb6ed33b/pillow-11.2.1-cp312-cp312-macosx_10_13_x86_64.whl", hash = "sha256:78afba22027b4accef10dbd5eed84425930ba41b3ea0a86fa8d20baaf19d807f", size = 3190185, upload-time = "2025-04-12T17:48:00.417Z" }, - { url = "https://files.pythonhosted.org/packages/e5/7e/b86dbd35a5f938632093dc40d1682874c33dcfe832558fc80ca56bfcb774/pillow-11.2.1-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:78092232a4ab376a35d68c4e6d5e00dfd73454bd12b230420025fbe178ee3b0b", size = 3030306, upload-time = "2025-04-12T17:48:02.391Z" }, - { url = "https://files.pythonhosted.org/packages/a4/5c/467a161f9ed53e5eab51a42923c33051bf8d1a2af4626ac04f5166e58e0c/pillow-11.2.1-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:25a5f306095c6780c52e6bbb6109624b95c5b18e40aab1c3041da3e9e0cd3e2d", size = 4416121, upload-time = "2025-04-12T17:48:04.554Z" }, - { url = "https://files.pythonhosted.org/packages/62/73/972b7742e38ae0e2ac76ab137ca6005dcf877480da0d9d61d93b613065b4/pillow-11.2.1-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:0c7b29dbd4281923a2bfe562acb734cee96bbb129e96e6972d315ed9f232bef4", size = 4501707, upload-time = "2025-04-12T17:48:06.831Z" }, - { url = "https://files.pythonhosted.org/packages/e4/3a/427e4cb0b9e177efbc1a84798ed20498c4f233abde003c06d2650a6d60cb/pillow-11.2.1-cp312-cp312-manylinux_2_28_aarch64.whl", hash = "sha256:3e645b020f3209a0181a418bffe7b4a93171eef6c4ef6cc20980b30bebf17b7d", size = 4522921, upload-time = "2025-04-12T17:48:09.229Z" }, - { url = "https://files.pythonhosted.org/packages/fe/7c/d8b1330458e4d2f3f45d9508796d7caf0c0d3764c00c823d10f6f1a3b76d/pillow-11.2.1-cp312-cp312-manylinux_2_28_x86_64.whl", hash = "sha256:b2dbea1012ccb784a65349f57bbc93730b96e85b42e9bf7b01ef40443db720b4", size = 4612523, upload-time = "2025-04-12T17:48:11.631Z" }, - { url = "https://files.pythonhosted.org/packages/b3/2f/65738384e0b1acf451de5a573d8153fe84103772d139e1e0bdf1596be2ea/pillow-11.2.1-cp312-cp312-musllinux_1_2_aarch64.whl", hash = "sha256:da3104c57bbd72948d75f6a9389e6727d2ab6333c3617f0a89d72d4940aa0443", size = 4587836, upload-time = "2025-04-12T17:48:13.592Z" }, - { url = "https://files.pythonhosted.org/packages/6a/c5/e795c9f2ddf3debb2dedd0df889f2fe4b053308bb59a3cc02a0cd144d641/pillow-11.2.1-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:598174aef4589af795f66f9caab87ba4ff860ce08cd5bb447c6fc553ffee603c", size = 4669390, upload-time = "2025-04-12T17:48:15.938Z" }, - { url = "https://files.pythonhosted.org/packages/96/ae/ca0099a3995976a9fce2f423166f7bff9b12244afdc7520f6ed38911539a/pillow-11.2.1-cp312-cp312-win32.whl", hash = "sha256:1d535df14716e7f8776b9e7fee118576d65572b4aad3ed639be9e4fa88a1cad3", size = 2332309, upload-time = "2025-04-12T17:48:17.885Z" }, - { url = "https://files.pythonhosted.org/packages/7c/18/24bff2ad716257fc03da964c5e8f05d9790a779a8895d6566e493ccf0189/pillow-11.2.1-cp312-cp312-win_amd64.whl", hash = "sha256:14e33b28bf17c7a38eede290f77db7c664e4eb01f7869e37fa98a5aa95978941", size = 2676768, upload-time = "2025-04-12T17:48:19.655Z" }, - { url = "https://files.pythonhosted.org/packages/da/bb/e8d656c9543276517ee40184aaa39dcb41e683bca121022f9323ae11b39d/pillow-11.2.1-cp312-cp312-win_arm64.whl", hash = "sha256:21e1470ac9e5739ff880c211fc3af01e3ae505859392bf65458c224d0bf283eb", size = 2415087, upload-time = "2025-04-12T17:48:21.991Z" }, - { url = "https://files.pythonhosted.org/packages/36/9c/447528ee3776e7ab8897fe33697a7ff3f0475bb490c5ac1456a03dc57956/pillow-11.2.1-cp313-cp313-macosx_10_13_x86_64.whl", hash = "sha256:fdec757fea0b793056419bca3e9932eb2b0ceec90ef4813ea4c1e072c389eb28", size = 3190098, upload-time = "2025-04-12T17:48:23.915Z" }, - { url = "https://files.pythonhosted.org/packages/b5/09/29d5cd052f7566a63e5b506fac9c60526e9ecc553825551333e1e18a4858/pillow-11.2.1-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:b0e130705d568e2f43a17bcbe74d90958e8a16263868a12c3e0d9c8162690830", size = 3030166, upload-time = "2025-04-12T17:48:25.738Z" }, - { url = "https://files.pythonhosted.org/packages/71/5d/446ee132ad35e7600652133f9c2840b4799bbd8e4adba881284860da0a36/pillow-11.2.1-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:7bdb5e09068332578214cadd9c05e3d64d99e0e87591be22a324bdbc18925be0", size = 4408674, upload-time = "2025-04-12T17:48:27.908Z" }, - { url = "https://files.pythonhosted.org/packages/69/5f/cbe509c0ddf91cc3a03bbacf40e5c2339c4912d16458fcb797bb47bcb269/pillow-11.2.1-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:d189ba1bebfbc0c0e529159631ec72bb9e9bc041f01ec6d3233d6d82eb823bc1", size = 4496005, upload-time = "2025-04-12T17:48:29.888Z" }, - { url = "https://files.pythonhosted.org/packages/f9/b3/dd4338d8fb8a5f312021f2977fb8198a1184893f9b00b02b75d565c33b51/pillow-11.2.1-cp313-cp313-manylinux_2_28_aarch64.whl", hash = "sha256:191955c55d8a712fab8934a42bfefbf99dd0b5875078240943f913bb66d46d9f", size = 4518707, upload-time = "2025-04-12T17:48:31.874Z" }, - { url = "https://files.pythonhosted.org/packages/13/eb/2552ecebc0b887f539111c2cd241f538b8ff5891b8903dfe672e997529be/pillow-11.2.1-cp313-cp313-manylinux_2_28_x86_64.whl", hash = "sha256:ad275964d52e2243430472fc5d2c2334b4fc3ff9c16cb0a19254e25efa03a155", size = 4610008, upload-time = "2025-04-12T17:48:34.422Z" }, - { url = "https://files.pythonhosted.org/packages/72/d1/924ce51bea494cb6e7959522d69d7b1c7e74f6821d84c63c3dc430cbbf3b/pillow-11.2.1-cp313-cp313-musllinux_1_2_aarch64.whl", hash = "sha256:750f96efe0597382660d8b53e90dd1dd44568a8edb51cb7f9d5d918b80d4de14", size = 4585420, upload-time = "2025-04-12T17:48:37.641Z" }, - { url = "https://files.pythonhosted.org/packages/43/ab/8f81312d255d713b99ca37479a4cb4b0f48195e530cdc1611990eb8fd04b/pillow-11.2.1-cp313-cp313-musllinux_1_2_x86_64.whl", hash = "sha256:fe15238d3798788d00716637b3d4e7bb6bde18b26e5d08335a96e88564a36b6b", size = 4667655, upload-time = "2025-04-12T17:48:39.652Z" }, - { url = "https://files.pythonhosted.org/packages/94/86/8f2e9d2dc3d308dfd137a07fe1cc478df0a23d42a6c4093b087e738e4827/pillow-11.2.1-cp313-cp313-win32.whl", hash = "sha256:3fe735ced9a607fee4f481423a9c36701a39719252a9bb251679635f99d0f7d2", size = 2332329, upload-time = "2025-04-12T17:48:41.765Z" }, - { url = "https://files.pythonhosted.org/packages/6d/ec/1179083b8d6067a613e4d595359b5fdea65d0a3b7ad623fee906e1b3c4d2/pillow-11.2.1-cp313-cp313-win_amd64.whl", hash = "sha256:74ee3d7ecb3f3c05459ba95eed5efa28d6092d751ce9bf20e3e253a4e497e691", size = 2676388, upload-time = "2025-04-12T17:48:43.625Z" }, - { url = "https://files.pythonhosted.org/packages/23/f1/2fc1e1e294de897df39fa8622d829b8828ddad938b0eaea256d65b84dd72/pillow-11.2.1-cp313-cp313-win_arm64.whl", hash = "sha256:5119225c622403afb4b44bad4c1ca6c1f98eed79db8d3bc6e4e160fc6339d66c", size = 2414950, upload-time = "2025-04-12T17:48:45.475Z" }, - { url = "https://files.pythonhosted.org/packages/c4/3e/c328c48b3f0ead7bab765a84b4977acb29f101d10e4ef57a5e3400447c03/pillow-11.2.1-cp313-cp313t-macosx_10_13_x86_64.whl", hash = "sha256:8ce2e8411c7aaef53e6bb29fe98f28cd4fbd9a1d9be2eeea434331aac0536b22", size = 3192759, upload-time = "2025-04-12T17:48:47.866Z" }, - { url = "https://files.pythonhosted.org/packages/18/0e/1c68532d833fc8b9f404d3a642991441d9058eccd5606eab31617f29b6d4/pillow-11.2.1-cp313-cp313t-macosx_11_0_arm64.whl", hash = "sha256:9ee66787e095127116d91dea2143db65c7bb1e232f617aa5957c0d9d2a3f23a7", size = 3033284, upload-time = "2025-04-12T17:48:50.189Z" }, - { url = "https://files.pythonhosted.org/packages/b7/cb/6faf3fb1e7705fd2db74e070f3bf6f88693601b0ed8e81049a8266de4754/pillow-11.2.1-cp313-cp313t-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:9622e3b6c1d8b551b6e6f21873bdcc55762b4b2126633014cea1803368a9aa16", size = 4445826, upload-time = "2025-04-12T17:48:52.346Z" }, - { url = "https://files.pythonhosted.org/packages/07/94/8be03d50b70ca47fb434a358919d6a8d6580f282bbb7af7e4aa40103461d/pillow-11.2.1-cp313-cp313t-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:63b5dff3a68f371ea06025a1a6966c9a1e1ee452fc8020c2cd0ea41b83e9037b", size = 4527329, upload-time = "2025-04-12T17:48:54.403Z" }, - { url = "https://files.pythonhosted.org/packages/fd/a4/bfe78777076dc405e3bd2080bc32da5ab3945b5a25dc5d8acaa9de64a162/pillow-11.2.1-cp313-cp313t-manylinux_2_28_aarch64.whl", hash = "sha256:31df6e2d3d8fc99f993fd253e97fae451a8db2e7207acf97859732273e108406", size = 4549049, upload-time = "2025-04-12T17:48:56.383Z" }, - { url = "https://files.pythonhosted.org/packages/65/4d/eaf9068dc687c24979e977ce5677e253624bd8b616b286f543f0c1b91662/pillow-11.2.1-cp313-cp313t-manylinux_2_28_x86_64.whl", hash = "sha256:062b7a42d672c45a70fa1f8b43d1d38ff76b63421cbbe7f88146b39e8a558d91", size = 4635408, upload-time = "2025-04-12T17:48:58.782Z" }, - { url = "https://files.pythonhosted.org/packages/1d/26/0fd443365d9c63bc79feb219f97d935cd4b93af28353cba78d8e77b61719/pillow-11.2.1-cp313-cp313t-musllinux_1_2_aarch64.whl", hash = "sha256:4eb92eca2711ef8be42fd3f67533765d9fd043b8c80db204f16c8ea62ee1a751", size = 4614863, upload-time = "2025-04-12T17:49:00.709Z" }, - { url = "https://files.pythonhosted.org/packages/49/65/dca4d2506be482c2c6641cacdba5c602bc76d8ceb618fd37de855653a419/pillow-11.2.1-cp313-cp313t-musllinux_1_2_x86_64.whl", hash = "sha256:f91ebf30830a48c825590aede79376cb40f110b387c17ee9bd59932c961044f9", size = 4692938, upload-time = "2025-04-12T17:49:02.946Z" }, - { url = "https://files.pythonhosted.org/packages/b3/92/1ca0c3f09233bd7decf8f7105a1c4e3162fb9142128c74adad0fb361b7eb/pillow-11.2.1-cp313-cp313t-win32.whl", hash = "sha256:e0b55f27f584ed623221cfe995c912c61606be8513bfa0e07d2c674b4516d9dd", size = 2335774, upload-time = "2025-04-12T17:49:04.889Z" }, - { url = "https://files.pythonhosted.org/packages/a5/ac/77525347cb43b83ae905ffe257bbe2cc6fd23acb9796639a1f56aa59d191/pillow-11.2.1-cp313-cp313t-win_amd64.whl", hash = "sha256:36d6b82164c39ce5482f649b437382c0fb2395eabc1e2b1702a6deb8ad647d6e", size = 2681895, upload-time = "2025-04-12T17:49:06.635Z" }, - { url = "https://files.pythonhosted.org/packages/67/32/32dc030cfa91ca0fc52baebbba2e009bb001122a1daa8b6a79ad830b38d3/pillow-11.2.1-cp313-cp313t-win_arm64.whl", hash = "sha256:225c832a13326e34f212d2072982bb1adb210e0cc0b153e688743018c94a2681", size = 2417234, upload-time = "2025-04-12T17:49:08.399Z" }, - { url = "https://files.pythonhosted.org/packages/33/49/c8c21e4255b4f4a2c0c68ac18125d7f5460b109acc6dfdef1a24f9b960ef/pillow-11.2.1-pp310-pypy310_pp73-macosx_10_15_x86_64.whl", hash = "sha256:9b7b0d4fd2635f54ad82785d56bc0d94f147096493a79985d0ab57aedd563156", size = 3181727, upload-time = "2025-04-12T17:49:31.898Z" }, - { url = "https://files.pythonhosted.org/packages/6d/f1/f7255c0838f8c1ef6d55b625cfb286835c17e8136ce4351c5577d02c443b/pillow-11.2.1-pp310-pypy310_pp73-macosx_11_0_arm64.whl", hash = "sha256:aa442755e31c64037aa7c1cb186e0b369f8416c567381852c63444dd666fb772", size = 2999833, upload-time = "2025-04-12T17:49:34.2Z" }, - { url = "https://files.pythonhosted.org/packages/e2/57/9968114457bd131063da98d87790d080366218f64fa2943b65ac6739abb3/pillow-11.2.1-pp310-pypy310_pp73-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:f0d3348c95b766f54b76116d53d4cb171b52992a1027e7ca50c81b43b9d9e363", size = 3437472, upload-time = "2025-04-12T17:49:36.294Z" }, - { url = "https://files.pythonhosted.org/packages/b2/1b/e35d8a158e21372ecc48aac9c453518cfe23907bb82f950d6e1c72811eb0/pillow-11.2.1-pp310-pypy310_pp73-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:85d27ea4c889342f7e35f6d56e7e1cb345632ad592e8c51b693d7b7556043ce0", size = 3459976, upload-time = "2025-04-12T17:49:38.988Z" }, - { url = "https://files.pythonhosted.org/packages/26/da/2c11d03b765efff0ccc473f1c4186dc2770110464f2177efaed9cf6fae01/pillow-11.2.1-pp310-pypy310_pp73-manylinux_2_28_aarch64.whl", hash = "sha256:bf2c33d6791c598142f00c9c4c7d47f6476731c31081331664eb26d6ab583e01", size = 3527133, upload-time = "2025-04-12T17:49:40.985Z" }, - { url = "https://files.pythonhosted.org/packages/79/1a/4e85bd7cadf78412c2a3069249a09c32ef3323650fd3005c97cca7aa21df/pillow-11.2.1-pp310-pypy310_pp73-manylinux_2_28_x86_64.whl", hash = "sha256:e616e7154c37669fc1dfc14584f11e284e05d1c650e1c0f972f281c4ccc53193", size = 3571555, upload-time = "2025-04-12T17:49:42.964Z" }, - { url = "https://files.pythonhosted.org/packages/69/03/239939915216de1e95e0ce2334bf17a7870ae185eb390fab6d706aadbfc0/pillow-11.2.1-pp310-pypy310_pp73-win_amd64.whl", hash = "sha256:39ad2e0f424394e3aebc40168845fee52df1394a4673a6ee512d840d14ab3013", size = 2674713, upload-time = "2025-04-12T17:49:44.944Z" }, - { url = "https://files.pythonhosted.org/packages/a4/ad/2613c04633c7257d9481ab21d6b5364b59fc5d75faafd7cb8693523945a3/pillow-11.2.1-pp311-pypy311_pp73-macosx_10_15_x86_64.whl", hash = "sha256:80f1df8dbe9572b4b7abdfa17eb5d78dd620b1d55d9e25f834efdbee872d3aed", size = 3181734, upload-time = "2025-04-12T17:49:46.789Z" }, - { url = "https://files.pythonhosted.org/packages/a4/fd/dcdda4471ed667de57bb5405bb42d751e6cfdd4011a12c248b455c778e03/pillow-11.2.1-pp311-pypy311_pp73-macosx_11_0_arm64.whl", hash = "sha256:ea926cfbc3957090becbcbbb65ad177161a2ff2ad578b5a6ec9bb1e1cd78753c", size = 2999841, upload-time = "2025-04-12T17:49:48.812Z" }, - { url = "https://files.pythonhosted.org/packages/ac/89/8a2536e95e77432833f0db6fd72a8d310c8e4272a04461fb833eb021bf94/pillow-11.2.1-pp311-pypy311_pp73-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:738db0e0941ca0376804d4de6a782c005245264edaa253ffce24e5a15cbdc7bd", size = 3437470, upload-time = "2025-04-12T17:49:50.831Z" }, - { url = "https://files.pythonhosted.org/packages/9d/8f/abd47b73c60712f88e9eda32baced7bfc3e9bd6a7619bb64b93acff28c3e/pillow-11.2.1-pp311-pypy311_pp73-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:9db98ab6565c69082ec9b0d4e40dd9f6181dab0dd236d26f7a50b8b9bfbd5076", size = 3460013, upload-time = "2025-04-12T17:49:53.278Z" }, - { url = "https://files.pythonhosted.org/packages/f6/20/5c0a0aa83b213b7a07ec01e71a3d6ea2cf4ad1d2c686cc0168173b6089e7/pillow-11.2.1-pp311-pypy311_pp73-manylinux_2_28_aarch64.whl", hash = "sha256:036e53f4170e270ddb8797d4c590e6dd14d28e15c7da375c18978045f7e6c37b", size = 3527165, upload-time = "2025-04-12T17:49:55.164Z" }, - { url = "https://files.pythonhosted.org/packages/58/0e/2abab98a72202d91146abc839e10c14f7cf36166f12838ea0c4db3ca6ecb/pillow-11.2.1-pp311-pypy311_pp73-manylinux_2_28_x86_64.whl", hash = "sha256:14f73f7c291279bd65fda51ee87affd7c1e097709f7fdd0188957a16c264601f", size = 3571586, upload-time = "2025-04-12T17:49:57.171Z" }, - { url = "https://files.pythonhosted.org/packages/21/2c/5e05f58658cf49b6667762cca03d6e7d85cededde2caf2ab37b81f80e574/pillow-11.2.1-pp311-pypy311_pp73-win_amd64.whl", hash = "sha256:208653868d5c9ecc2b327f9b9ef34e0e42a4cdd172c2988fd81d62d2bc9bc044", size = 2674751, upload-time = "2025-04-12T17:49:59.628Z" }, -] - -[[package]] -name = "platformdirs" -version = "4.3.8" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/fe/8b/3c73abc9c759ecd3f1f7ceff6685840859e8070c4d947c93fae71f6a0bf2/platformdirs-4.3.8.tar.gz", hash = "sha256:3d512d96e16bcb959a814c9f348431070822a6496326a4be0911c40b5a74c2bc", size = 21362, upload-time = "2025-05-07T22:47:42.121Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/fe/39/979e8e21520d4e47a0bbe349e2713c0aac6f3d853d0e5b34d76206c439aa/platformdirs-4.3.8-py3-none-any.whl", hash = "sha256:ff7059bb7eb1179e2685604f4aaf157cfd9535242bd23742eadc3c13542139b4", size = 18567, upload-time = "2025-05-07T22:47:40.376Z" }, -] - -[[package]] -name = "pluggy" -version = "1.6.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/f9/e2/3e91f31a7d2b083fe6ef3fa267035b518369d9511ffab804f839851d2779/pluggy-1.6.0.tar.gz", hash = "sha256:7dcc130b76258d33b90f61b658791dede3486c3e6bfb003ee5c9bfb396dd22f3", size = 69412, upload-time = "2025-05-15T12:30:07.975Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/54/20/4d324d65cc6d9205fabedc306948156824eb9f0ee1633355a8f7ec5c66bf/pluggy-1.6.0-py3-none-any.whl", hash = "sha256:e920276dd6813095e9377c0bc5566d94c932c33b27a3e3945d8389c374dd4746", size = 20538, upload-time = "2025-05-15T12:30:06.134Z" }, -] - -[[package]] -name = "propcache" -version = "0.3.2" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/a6/16/43264e4a779dd8588c21a70f0709665ee8f611211bdd2c87d952cfa7c776/propcache-0.3.2.tar.gz", hash = "sha256:20d7d62e4e7ef05f221e0db2856b979540686342e7dd9973b815599c7057e168", size = 44139, upload-time = "2025-06-09T22:56:06.081Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/ab/14/510deed325e262afeb8b360043c5d7c960da7d3ecd6d6f9496c9c56dc7f4/propcache-0.3.2-cp310-cp310-macosx_10_9_universal2.whl", hash = "sha256:22d9962a358aedbb7a2e36187ff273adeaab9743373a272976d2e348d08c7770", size = 73178, upload-time = "2025-06-09T22:53:40.126Z" }, - { url = "https://files.pythonhosted.org/packages/cd/4e/ad52a7925ff01c1325653a730c7ec3175a23f948f08626a534133427dcff/propcache-0.3.2-cp310-cp310-macosx_10_9_x86_64.whl", hash = "sha256:0d0fda578d1dc3f77b6b5a5dce3b9ad69a8250a891760a548df850a5e8da87f3", size = 43133, upload-time = "2025-06-09T22:53:41.965Z" }, - { url = "https://files.pythonhosted.org/packages/63/7c/e9399ba5da7780871db4eac178e9c2e204c23dd3e7d32df202092a1ed400/propcache-0.3.2-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:3def3da3ac3ce41562d85db655d18ebac740cb3fa4367f11a52b3da9d03a5cc3", size = 43039, upload-time = "2025-06-09T22:53:43.268Z" }, - { url = "https://files.pythonhosted.org/packages/22/e1/58da211eb8fdc6fc854002387d38f415a6ca5f5c67c1315b204a5d3e9d7a/propcache-0.3.2-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:9bec58347a5a6cebf239daba9bda37dffec5b8d2ce004d9fe4edef3d2815137e", size = 201903, upload-time = "2025-06-09T22:53:44.872Z" }, - { url = "https://files.pythonhosted.org/packages/c4/0a/550ea0f52aac455cb90111c8bab995208443e46d925e51e2f6ebdf869525/propcache-0.3.2-cp310-cp310-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:55ffda449a507e9fbd4aca1a7d9aa6753b07d6166140e5a18d2ac9bc49eac220", size = 213362, upload-time = "2025-06-09T22:53:46.707Z" }, - { url = "https://files.pythonhosted.org/packages/5a/af/9893b7d878deda9bb69fcf54600b247fba7317761b7db11fede6e0f28bd0/propcache-0.3.2-cp310-cp310-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:64a67fb39229a8a8491dd42f864e5e263155e729c2e7ff723d6e25f596b1e8cb", size = 210525, upload-time = "2025-06-09T22:53:48.547Z" }, - { url = "https://files.pythonhosted.org/packages/7c/bb/38fd08b278ca85cde36d848091ad2b45954bc5f15cce494bb300b9285831/propcache-0.3.2-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:9da1cf97b92b51253d5b68cf5a2b9e0dafca095e36b7f2da335e27dc6172a614", size = 198283, upload-time = "2025-06-09T22:53:50.067Z" }, - { url = "https://files.pythonhosted.org/packages/78/8c/9fe55bd01d362bafb413dfe508c48753111a1e269737fa143ba85693592c/propcache-0.3.2-cp310-cp310-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:5f559e127134b07425134b4065be45b166183fdcb433cb6c24c8e4149056ad50", size = 191872, upload-time = "2025-06-09T22:53:51.438Z" }, - { url = "https://files.pythonhosted.org/packages/54/14/4701c33852937a22584e08abb531d654c8bcf7948a8f87ad0a4822394147/propcache-0.3.2-cp310-cp310-musllinux_1_2_aarch64.whl", hash = "sha256:aff2e4e06435d61f11a428360a932138d0ec288b0a31dd9bd78d200bd4a2b339", size = 199452, upload-time = "2025-06-09T22:53:53.229Z" }, - { url = "https://files.pythonhosted.org/packages/16/44/447f2253d859602095356007657ee535e0093215ea0b3d1d6a41d16e5201/propcache-0.3.2-cp310-cp310-musllinux_1_2_armv7l.whl", hash = "sha256:4927842833830942a5d0a56e6f4839bc484785b8e1ce8d287359794818633ba0", size = 191567, upload-time = "2025-06-09T22:53:54.541Z" }, - { url = "https://files.pythonhosted.org/packages/f2/b3/e4756258749bb2d3b46defcff606a2f47410bab82be5824a67e84015b267/propcache-0.3.2-cp310-cp310-musllinux_1_2_i686.whl", hash = "sha256:6107ddd08b02654a30fb8ad7a132021759d750a82578b94cd55ee2772b6ebea2", size = 193015, upload-time = "2025-06-09T22:53:56.44Z" }, - { url = "https://files.pythonhosted.org/packages/1e/df/e6d3c7574233164b6330b9fd697beeac402afd367280e6dc377bb99b43d9/propcache-0.3.2-cp310-cp310-musllinux_1_2_ppc64le.whl", hash = "sha256:70bd8b9cd6b519e12859c99f3fc9a93f375ebd22a50296c3a295028bea73b9e7", size = 204660, upload-time = "2025-06-09T22:53:57.839Z" }, - { url = "https://files.pythonhosted.org/packages/b2/53/e4d31dd5170b4a0e2e6b730f2385a96410633b4833dc25fe5dffd1f73294/propcache-0.3.2-cp310-cp310-musllinux_1_2_s390x.whl", hash = "sha256:2183111651d710d3097338dd1893fcf09c9f54e27ff1a8795495a16a469cc90b", size = 206105, upload-time = "2025-06-09T22:53:59.638Z" }, - { url = "https://files.pythonhosted.org/packages/7f/fe/74d54cf9fbe2a20ff786e5f7afcfde446588f0cf15fb2daacfbc267b866c/propcache-0.3.2-cp310-cp310-musllinux_1_2_x86_64.whl", hash = "sha256:fb075ad271405dcad8e2a7ffc9a750a3bf70e533bd86e89f0603e607b93aa64c", size = 196980, upload-time = "2025-06-09T22:54:01.071Z" }, - { url = "https://files.pythonhosted.org/packages/22/ec/c469c9d59dada8a7679625e0440b544fe72e99311a4679c279562051f6fc/propcache-0.3.2-cp310-cp310-win32.whl", hash = "sha256:404d70768080d3d3bdb41d0771037da19d8340d50b08e104ca0e7f9ce55fce70", size = 37679, upload-time = "2025-06-09T22:54:03.003Z" }, - { url = "https://files.pythonhosted.org/packages/38/35/07a471371ac89d418f8d0b699c75ea6dca2041fbda360823de21f6a9ce0a/propcache-0.3.2-cp310-cp310-win_amd64.whl", hash = "sha256:7435d766f978b4ede777002e6b3b6641dd229cd1da8d3d3106a45770365f9ad9", size = 41459, upload-time = "2025-06-09T22:54:04.134Z" }, - { url = "https://files.pythonhosted.org/packages/80/8d/e8b436717ab9c2cfc23b116d2c297305aa4cd8339172a456d61ebf5669b8/propcache-0.3.2-cp311-cp311-macosx_10_9_universal2.whl", hash = "sha256:0b8d2f607bd8f80ddc04088bc2a037fdd17884a6fcadc47a96e334d72f3717be", size = 74207, upload-time = "2025-06-09T22:54:05.399Z" }, - { url = "https://files.pythonhosted.org/packages/d6/29/1e34000e9766d112171764b9fa3226fa0153ab565d0c242c70e9945318a7/propcache-0.3.2-cp311-cp311-macosx_10_9_x86_64.whl", hash = "sha256:06766d8f34733416e2e34f46fea488ad5d60726bb9481d3cddf89a6fa2d9603f", size = 43648, upload-time = "2025-06-09T22:54:08.023Z" }, - { url = "https://files.pythonhosted.org/packages/46/92/1ad5af0df781e76988897da39b5f086c2bf0f028b7f9bd1f409bb05b6874/propcache-0.3.2-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:a2dc1f4a1df4fecf4e6f68013575ff4af84ef6f478fe5344317a65d38a8e6dc9", size = 43496, upload-time = "2025-06-09T22:54:09.228Z" }, - { url = "https://files.pythonhosted.org/packages/b3/ce/e96392460f9fb68461fabab3e095cb00c8ddf901205be4eae5ce246e5b7e/propcache-0.3.2-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:be29c4f4810c5789cf10ddf6af80b041c724e629fa51e308a7a0fb19ed1ef7bf", size = 217288, upload-time = "2025-06-09T22:54:10.466Z" }, - { url = "https://files.pythonhosted.org/packages/c5/2a/866726ea345299f7ceefc861a5e782b045545ae6940851930a6adaf1fca6/propcache-0.3.2-cp311-cp311-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:59d61f6970ecbd8ff2e9360304d5c8876a6abd4530cb752c06586849ac8a9dc9", size = 227456, upload-time = "2025-06-09T22:54:11.828Z" }, - { url = "https://files.pythonhosted.org/packages/de/03/07d992ccb6d930398689187e1b3c718339a1c06b8b145a8d9650e4726166/propcache-0.3.2-cp311-cp311-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:62180e0b8dbb6b004baec00a7983e4cc52f5ada9cd11f48c3528d8cfa7b96a66", size = 225429, upload-time = "2025-06-09T22:54:13.823Z" }, - { url = "https://files.pythonhosted.org/packages/5d/e6/116ba39448753b1330f48ab8ba927dcd6cf0baea8a0ccbc512dfb49ba670/propcache-0.3.2-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:c144ca294a204c470f18cf4c9d78887810d04a3e2fbb30eea903575a779159df", size = 213472, upload-time = "2025-06-09T22:54:15.232Z" }, - { url = "https://files.pythonhosted.org/packages/a6/85/f01f5d97e54e428885a5497ccf7f54404cbb4f906688a1690cd51bf597dc/propcache-0.3.2-cp311-cp311-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:c5c2a784234c28854878d68978265617aa6dc0780e53d44b4d67f3651a17a9a2", size = 204480, upload-time = "2025-06-09T22:54:17.104Z" }, - { url = "https://files.pythonhosted.org/packages/e3/79/7bf5ab9033b8b8194cc3f7cf1aaa0e9c3256320726f64a3e1f113a812dce/propcache-0.3.2-cp311-cp311-musllinux_1_2_aarch64.whl", hash = "sha256:5745bc7acdafa978ca1642891b82c19238eadc78ba2aaa293c6863b304e552d7", size = 214530, upload-time = "2025-06-09T22:54:18.512Z" }, - { url = "https://files.pythonhosted.org/packages/31/0b/bd3e0c00509b609317df4a18e6b05a450ef2d9a963e1d8bc9c9415d86f30/propcache-0.3.2-cp311-cp311-musllinux_1_2_armv7l.whl", hash = "sha256:c0075bf773d66fa8c9d41f66cc132ecc75e5bb9dd7cce3cfd14adc5ca184cb95", size = 205230, upload-time = "2025-06-09T22:54:19.947Z" }, - { url = "https://files.pythonhosted.org/packages/7a/23/fae0ff9b54b0de4e819bbe559508da132d5683c32d84d0dc2ccce3563ed4/propcache-0.3.2-cp311-cp311-musllinux_1_2_i686.whl", hash = "sha256:5f57aa0847730daceff0497f417c9de353c575d8da3579162cc74ac294c5369e", size = 206754, upload-time = "2025-06-09T22:54:21.716Z" }, - { url = "https://files.pythonhosted.org/packages/b7/7f/ad6a3c22630aaa5f618b4dc3c3598974a72abb4c18e45a50b3cdd091eb2f/propcache-0.3.2-cp311-cp311-musllinux_1_2_ppc64le.whl", hash = "sha256:eef914c014bf72d18efb55619447e0aecd5fb7c2e3fa7441e2e5d6099bddff7e", size = 218430, upload-time = "2025-06-09T22:54:23.17Z" }, - { url = "https://files.pythonhosted.org/packages/5b/2c/ba4f1c0e8a4b4c75910742f0d333759d441f65a1c7f34683b4a74c0ee015/propcache-0.3.2-cp311-cp311-musllinux_1_2_s390x.whl", hash = "sha256:2a4092e8549031e82facf3decdbc0883755d5bbcc62d3aea9d9e185549936dcf", size = 223884, upload-time = "2025-06-09T22:54:25.539Z" }, - { url = "https://files.pythonhosted.org/packages/88/e4/ebe30fc399e98572019eee82ad0caf512401661985cbd3da5e3140ffa1b0/propcache-0.3.2-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:85871b050f174bc0bfb437efbdb68aaf860611953ed12418e4361bc9c392749e", size = 211480, upload-time = "2025-06-09T22:54:26.892Z" }, - { url = "https://files.pythonhosted.org/packages/96/0a/7d5260b914e01d1d0906f7f38af101f8d8ed0dc47426219eeaf05e8ea7c2/propcache-0.3.2-cp311-cp311-win32.whl", hash = "sha256:36c8d9b673ec57900c3554264e630d45980fd302458e4ac801802a7fd2ef7897", size = 37757, upload-time = "2025-06-09T22:54:28.241Z" }, - { url = "https://files.pythonhosted.org/packages/e1/2d/89fe4489a884bc0da0c3278c552bd4ffe06a1ace559db5ef02ef24ab446b/propcache-0.3.2-cp311-cp311-win_amd64.whl", hash = "sha256:e53af8cb6a781b02d2ea079b5b853ba9430fcbe18a8e3ce647d5982a3ff69f39", size = 41500, upload-time = "2025-06-09T22:54:29.4Z" }, - { url = "https://files.pythonhosted.org/packages/a8/42/9ca01b0a6f48e81615dca4765a8f1dd2c057e0540f6116a27dc5ee01dfb6/propcache-0.3.2-cp312-cp312-macosx_10_13_universal2.whl", hash = "sha256:8de106b6c84506b31c27168582cd3cb3000a6412c16df14a8628e5871ff83c10", size = 73674, upload-time = "2025-06-09T22:54:30.551Z" }, - { url = "https://files.pythonhosted.org/packages/af/6e/21293133beb550f9c901bbece755d582bfaf2176bee4774000bd4dd41884/propcache-0.3.2-cp312-cp312-macosx_10_13_x86_64.whl", hash = "sha256:28710b0d3975117239c76600ea351934ac7b5ff56e60953474342608dbbb6154", size = 43570, upload-time = "2025-06-09T22:54:32.296Z" }, - { url = "https://files.pythonhosted.org/packages/0c/c8/0393a0a3a2b8760eb3bde3c147f62b20044f0ddac81e9d6ed7318ec0d852/propcache-0.3.2-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:ce26862344bdf836650ed2487c3d724b00fbfec4233a1013f597b78c1cb73615", size = 43094, upload-time = "2025-06-09T22:54:33.929Z" }, - { url = "https://files.pythonhosted.org/packages/37/2c/489afe311a690399d04a3e03b069225670c1d489eb7b044a566511c1c498/propcache-0.3.2-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:bca54bd347a253af2cf4544bbec232ab982f4868de0dd684246b67a51bc6b1db", size = 226958, upload-time = "2025-06-09T22:54:35.186Z" }, - { url = "https://files.pythonhosted.org/packages/9d/ca/63b520d2f3d418c968bf596839ae26cf7f87bead026b6192d4da6a08c467/propcache-0.3.2-cp312-cp312-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:55780d5e9a2ddc59711d727226bb1ba83a22dd32f64ee15594b9392b1f544eb1", size = 234894, upload-time = "2025-06-09T22:54:36.708Z" }, - { url = "https://files.pythonhosted.org/packages/11/60/1d0ed6fff455a028d678df30cc28dcee7af77fa2b0e6962ce1df95c9a2a9/propcache-0.3.2-cp312-cp312-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:035e631be25d6975ed87ab23153db6a73426a48db688070d925aa27e996fe93c", size = 233672, upload-time = "2025-06-09T22:54:38.062Z" }, - { url = "https://files.pythonhosted.org/packages/37/7c/54fd5301ef38505ab235d98827207176a5c9b2aa61939b10a460ca53e123/propcache-0.3.2-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:ee6f22b6eaa39297c751d0e80c0d3a454f112f5c6481214fcf4c092074cecd67", size = 224395, upload-time = "2025-06-09T22:54:39.634Z" }, - { url = "https://files.pythonhosted.org/packages/ee/1a/89a40e0846f5de05fdc6779883bf46ba980e6df4d2ff8fb02643de126592/propcache-0.3.2-cp312-cp312-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:7ca3aee1aa955438c4dba34fc20a9f390e4c79967257d830f137bd5a8a32ed3b", size = 212510, upload-time = "2025-06-09T22:54:41.565Z" }, - { url = "https://files.pythonhosted.org/packages/5e/33/ca98368586c9566a6b8d5ef66e30484f8da84c0aac3f2d9aec6d31a11bd5/propcache-0.3.2-cp312-cp312-musllinux_1_2_aarch64.whl", hash = "sha256:7a4f30862869fa2b68380d677cc1c5fcf1e0f2b9ea0cf665812895c75d0ca3b8", size = 222949, upload-time = "2025-06-09T22:54:43.038Z" }, - { url = "https://files.pythonhosted.org/packages/ba/11/ace870d0aafe443b33b2f0b7efdb872b7c3abd505bfb4890716ad7865e9d/propcache-0.3.2-cp312-cp312-musllinux_1_2_armv7l.whl", hash = "sha256:b77ec3c257d7816d9f3700013639db7491a434644c906a2578a11daf13176251", size = 217258, upload-time = "2025-06-09T22:54:44.376Z" }, - { url = "https://files.pythonhosted.org/packages/5b/d2/86fd6f7adffcfc74b42c10a6b7db721d1d9ca1055c45d39a1a8f2a740a21/propcache-0.3.2-cp312-cp312-musllinux_1_2_i686.whl", hash = "sha256:cab90ac9d3f14b2d5050928483d3d3b8fb6b4018893fc75710e6aa361ecb2474", size = 213036, upload-time = "2025-06-09T22:54:46.243Z" }, - { url = "https://files.pythonhosted.org/packages/07/94/2d7d1e328f45ff34a0a284cf5a2847013701e24c2a53117e7c280a4316b3/propcache-0.3.2-cp312-cp312-musllinux_1_2_ppc64le.whl", hash = "sha256:0b504d29f3c47cf6b9e936c1852246c83d450e8e063d50562115a6be6d3a2535", size = 227684, upload-time = "2025-06-09T22:54:47.63Z" }, - { url = "https://files.pythonhosted.org/packages/b7/05/37ae63a0087677e90b1d14710e532ff104d44bc1efa3b3970fff99b891dc/propcache-0.3.2-cp312-cp312-musllinux_1_2_s390x.whl", hash = "sha256:ce2ac2675a6aa41ddb2a0c9cbff53780a617ac3d43e620f8fd77ba1c84dcfc06", size = 234562, upload-time = "2025-06-09T22:54:48.982Z" }, - { url = "https://files.pythonhosted.org/packages/a4/7c/3f539fcae630408d0bd8bf3208b9a647ccad10976eda62402a80adf8fc34/propcache-0.3.2-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:62b4239611205294cc433845b914131b2a1f03500ff3c1ed093ed216b82621e1", size = 222142, upload-time = "2025-06-09T22:54:50.424Z" }, - { url = "https://files.pythonhosted.org/packages/7c/d2/34b9eac8c35f79f8a962546b3e97e9d4b990c420ee66ac8255d5d9611648/propcache-0.3.2-cp312-cp312-win32.whl", hash = "sha256:df4a81b9b53449ebc90cc4deefb052c1dd934ba85012aa912c7ea7b7e38b60c1", size = 37711, upload-time = "2025-06-09T22:54:52.072Z" }, - { url = "https://files.pythonhosted.org/packages/19/61/d582be5d226cf79071681d1b46b848d6cb03d7b70af7063e33a2787eaa03/propcache-0.3.2-cp312-cp312-win_amd64.whl", hash = "sha256:7046e79b989d7fe457bb755844019e10f693752d169076138abf17f31380800c", size = 41479, upload-time = "2025-06-09T22:54:53.234Z" }, - { url = "https://files.pythonhosted.org/packages/dc/d1/8c747fafa558c603c4ca19d8e20b288aa0c7cda74e9402f50f31eb65267e/propcache-0.3.2-cp313-cp313-macosx_10_13_universal2.whl", hash = "sha256:ca592ed634a73ca002967458187109265e980422116c0a107cf93d81f95af945", size = 71286, upload-time = "2025-06-09T22:54:54.369Z" }, - { url = "https://files.pythonhosted.org/packages/61/99/d606cb7986b60d89c36de8a85d58764323b3a5ff07770a99d8e993b3fa73/propcache-0.3.2-cp313-cp313-macosx_10_13_x86_64.whl", hash = "sha256:9ecb0aad4020e275652ba3975740f241bd12a61f1a784df044cf7477a02bc252", size = 42425, upload-time = "2025-06-09T22:54:55.642Z" }, - { url = "https://files.pythonhosted.org/packages/8c/96/ef98f91bbb42b79e9bb82bdd348b255eb9d65f14dbbe3b1594644c4073f7/propcache-0.3.2-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:7f08f1cc28bd2eade7a8a3d2954ccc673bb02062e3e7da09bc75d843386b342f", size = 41846, upload-time = "2025-06-09T22:54:57.246Z" }, - { url = "https://files.pythonhosted.org/packages/5b/ad/3f0f9a705fb630d175146cd7b1d2bf5555c9beaed54e94132b21aac098a6/propcache-0.3.2-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:d1a342c834734edb4be5ecb1e9fb48cb64b1e2320fccbd8c54bf8da8f2a84c33", size = 208871, upload-time = "2025-06-09T22:54:58.975Z" }, - { url = "https://files.pythonhosted.org/packages/3a/38/2085cda93d2c8b6ec3e92af2c89489a36a5886b712a34ab25de9fbca7992/propcache-0.3.2-cp313-cp313-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:8a544caaae1ac73f1fecfae70ded3e93728831affebd017d53449e3ac052ac1e", size = 215720, upload-time = "2025-06-09T22:55:00.471Z" }, - { url = "https://files.pythonhosted.org/packages/61/c1/d72ea2dc83ac7f2c8e182786ab0fc2c7bd123a1ff9b7975bee671866fe5f/propcache-0.3.2-cp313-cp313-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:310d11aa44635298397db47a3ebce7db99a4cc4b9bbdfcf6c98a60c8d5261cf1", size = 215203, upload-time = "2025-06-09T22:55:01.834Z" }, - { url = "https://files.pythonhosted.org/packages/af/81/b324c44ae60c56ef12007105f1460d5c304b0626ab0cc6b07c8f2a9aa0b8/propcache-0.3.2-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:4c1396592321ac83157ac03a2023aa6cc4a3cc3cfdecb71090054c09e5a7cce3", size = 206365, upload-time = "2025-06-09T22:55:03.199Z" }, - { url = "https://files.pythonhosted.org/packages/09/73/88549128bb89e66d2aff242488f62869014ae092db63ccea53c1cc75a81d/propcache-0.3.2-cp313-cp313-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:8cabf5b5902272565e78197edb682017d21cf3b550ba0460ee473753f28d23c1", size = 196016, upload-time = "2025-06-09T22:55:04.518Z" }, - { url = "https://files.pythonhosted.org/packages/b9/3f/3bdd14e737d145114a5eb83cb172903afba7242f67c5877f9909a20d948d/propcache-0.3.2-cp313-cp313-musllinux_1_2_aarch64.whl", hash = "sha256:0a2f2235ac46a7aa25bdeb03a9e7060f6ecbd213b1f9101c43b3090ffb971ef6", size = 205596, upload-time = "2025-06-09T22:55:05.942Z" }, - { url = "https://files.pythonhosted.org/packages/0f/ca/2f4aa819c357d3107c3763d7ef42c03980f9ed5c48c82e01e25945d437c1/propcache-0.3.2-cp313-cp313-musllinux_1_2_armv7l.whl", hash = "sha256:92b69e12e34869a6970fd2f3da91669899994b47c98f5d430b781c26f1d9f387", size = 200977, upload-time = "2025-06-09T22:55:07.792Z" }, - { url = "https://files.pythonhosted.org/packages/cd/4a/e65276c7477533c59085251ae88505caf6831c0e85ff8b2e31ebcbb949b1/propcache-0.3.2-cp313-cp313-musllinux_1_2_i686.whl", hash = "sha256:54e02207c79968ebbdffc169591009f4474dde3b4679e16634d34c9363ff56b4", size = 197220, upload-time = "2025-06-09T22:55:09.173Z" }, - { url = "https://files.pythonhosted.org/packages/7c/54/fc7152e517cf5578278b242396ce4d4b36795423988ef39bb8cd5bf274c8/propcache-0.3.2-cp313-cp313-musllinux_1_2_ppc64le.whl", hash = "sha256:4adfb44cb588001f68c5466579d3f1157ca07f7504fc91ec87862e2b8e556b88", size = 210642, upload-time = "2025-06-09T22:55:10.62Z" }, - { url = "https://files.pythonhosted.org/packages/b9/80/abeb4a896d2767bf5f1ea7b92eb7be6a5330645bd7fb844049c0e4045d9d/propcache-0.3.2-cp313-cp313-musllinux_1_2_s390x.whl", hash = "sha256:fd3e6019dc1261cd0291ee8919dd91fbab7b169bb76aeef6c716833a3f65d206", size = 212789, upload-time = "2025-06-09T22:55:12.029Z" }, - { url = "https://files.pythonhosted.org/packages/b3/db/ea12a49aa7b2b6d68a5da8293dcf50068d48d088100ac016ad92a6a780e6/propcache-0.3.2-cp313-cp313-musllinux_1_2_x86_64.whl", hash = "sha256:4c181cad81158d71c41a2bce88edce078458e2dd5ffee7eddd6b05da85079f43", size = 205880, upload-time = "2025-06-09T22:55:13.45Z" }, - { url = "https://files.pythonhosted.org/packages/d1/e5/9076a0bbbfb65d1198007059c65639dfd56266cf8e477a9707e4b1999ff4/propcache-0.3.2-cp313-cp313-win32.whl", hash = "sha256:8a08154613f2249519e549de2330cf8e2071c2887309a7b07fb56098f5170a02", size = 37220, upload-time = "2025-06-09T22:55:15.284Z" }, - { url = "https://files.pythonhosted.org/packages/d3/f5/b369e026b09a26cd77aa88d8fffd69141d2ae00a2abaaf5380d2603f4b7f/propcache-0.3.2-cp313-cp313-win_amd64.whl", hash = "sha256:e41671f1594fc4ab0a6dec1351864713cb3a279910ae8b58f884a88a0a632c05", size = 40678, upload-time = "2025-06-09T22:55:16.445Z" }, - { url = "https://files.pythonhosted.org/packages/a4/3a/6ece377b55544941a08d03581c7bc400a3c8cd3c2865900a68d5de79e21f/propcache-0.3.2-cp313-cp313t-macosx_10_13_universal2.whl", hash = "sha256:9a3cf035bbaf035f109987d9d55dc90e4b0e36e04bbbb95af3055ef17194057b", size = 76560, upload-time = "2025-06-09T22:55:17.598Z" }, - { url = "https://files.pythonhosted.org/packages/0c/da/64a2bb16418740fa634b0e9c3d29edff1db07f56d3546ca2d86ddf0305e1/propcache-0.3.2-cp313-cp313t-macosx_10_13_x86_64.whl", hash = "sha256:156c03d07dc1323d8dacaa221fbe028c5c70d16709cdd63502778e6c3ccca1b0", size = 44676, upload-time = "2025-06-09T22:55:18.922Z" }, - { url = "https://files.pythonhosted.org/packages/36/7b/f025e06ea51cb72c52fb87e9b395cced02786610b60a3ed51da8af017170/propcache-0.3.2-cp313-cp313t-macosx_11_0_arm64.whl", hash = "sha256:74413c0ba02ba86f55cf60d18daab219f7e531620c15f1e23d95563f505efe7e", size = 44701, upload-time = "2025-06-09T22:55:20.106Z" }, - { url = "https://files.pythonhosted.org/packages/a4/00/faa1b1b7c3b74fc277f8642f32a4c72ba1d7b2de36d7cdfb676db7f4303e/propcache-0.3.2-cp313-cp313t-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:f066b437bb3fa39c58ff97ab2ca351db465157d68ed0440abecb21715eb24b28", size = 276934, upload-time = "2025-06-09T22:55:21.5Z" }, - { url = "https://files.pythonhosted.org/packages/74/ab/935beb6f1756e0476a4d5938ff44bf0d13a055fed880caf93859b4f1baf4/propcache-0.3.2-cp313-cp313t-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:f1304b085c83067914721e7e9d9917d41ad87696bf70f0bc7dee450e9c71ad0a", size = 278316, upload-time = "2025-06-09T22:55:22.918Z" }, - { url = "https://files.pythonhosted.org/packages/f8/9d/994a5c1ce4389610838d1caec74bdf0e98b306c70314d46dbe4fcf21a3e2/propcache-0.3.2-cp313-cp313t-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:ab50cef01b372763a13333b4e54021bdcb291fc9a8e2ccb9c2df98be51bcde6c", size = 282619, upload-time = "2025-06-09T22:55:24.651Z" }, - { url = "https://files.pythonhosted.org/packages/2b/00/a10afce3d1ed0287cef2e09506d3be9822513f2c1e96457ee369adb9a6cd/propcache-0.3.2-cp313-cp313t-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:fad3b2a085ec259ad2c2842666b2a0a49dea8463579c606426128925af1ed725", size = 265896, upload-time = "2025-06-09T22:55:26.049Z" }, - { url = "https://files.pythonhosted.org/packages/2e/a8/2aa6716ffa566ca57c749edb909ad27884680887d68517e4be41b02299f3/propcache-0.3.2-cp313-cp313t-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:261fa020c1c14deafd54c76b014956e2f86991af198c51139faf41c4d5e83892", size = 252111, upload-time = "2025-06-09T22:55:27.381Z" }, - { url = "https://files.pythonhosted.org/packages/36/4f/345ca9183b85ac29c8694b0941f7484bf419c7f0fea2d1e386b4f7893eed/propcache-0.3.2-cp313-cp313t-musllinux_1_2_aarch64.whl", hash = "sha256:46d7f8aa79c927e5f987ee3a80205c987717d3659f035c85cf0c3680526bdb44", size = 268334, upload-time = "2025-06-09T22:55:28.747Z" }, - { url = "https://files.pythonhosted.org/packages/3e/ca/fcd54f78b59e3f97b3b9715501e3147f5340167733d27db423aa321e7148/propcache-0.3.2-cp313-cp313t-musllinux_1_2_armv7l.whl", hash = "sha256:6d8f3f0eebf73e3c0ff0e7853f68be638b4043c65a70517bb575eff54edd8dbe", size = 255026, upload-time = "2025-06-09T22:55:30.184Z" }, - { url = "https://files.pythonhosted.org/packages/8b/95/8e6a6bbbd78ac89c30c225210a5c687790e532ba4088afb8c0445b77ef37/propcache-0.3.2-cp313-cp313t-musllinux_1_2_i686.whl", hash = "sha256:03c89c1b14a5452cf15403e291c0ccd7751d5b9736ecb2c5bab977ad6c5bcd81", size = 250724, upload-time = "2025-06-09T22:55:31.646Z" }, - { url = "https://files.pythonhosted.org/packages/ee/b0/0dd03616142baba28e8b2d14ce5df6631b4673850a3d4f9c0f9dd714a404/propcache-0.3.2-cp313-cp313t-musllinux_1_2_ppc64le.whl", hash = "sha256:0cc17efde71e12bbaad086d679ce575268d70bc123a5a71ea7ad76f70ba30bba", size = 268868, upload-time = "2025-06-09T22:55:33.209Z" }, - { url = "https://files.pythonhosted.org/packages/c5/98/2c12407a7e4fbacd94ddd32f3b1e3d5231e77c30ef7162b12a60e2dd5ce3/propcache-0.3.2-cp313-cp313t-musllinux_1_2_s390x.whl", hash = "sha256:acdf05d00696bc0447e278bb53cb04ca72354e562cf88ea6f9107df8e7fd9770", size = 271322, upload-time = "2025-06-09T22:55:35.065Z" }, - { url = "https://files.pythonhosted.org/packages/35/91/9cb56efbb428b006bb85db28591e40b7736847b8331d43fe335acf95f6c8/propcache-0.3.2-cp313-cp313t-musllinux_1_2_x86_64.whl", hash = "sha256:4445542398bd0b5d32df908031cb1b30d43ac848e20470a878b770ec2dcc6330", size = 265778, upload-time = "2025-06-09T22:55:36.45Z" }, - { url = "https://files.pythonhosted.org/packages/9a/4c/b0fe775a2bdd01e176b14b574be679d84fc83958335790f7c9a686c1f468/propcache-0.3.2-cp313-cp313t-win32.whl", hash = "sha256:f86e5d7cd03afb3a1db8e9f9f6eff15794e79e791350ac48a8c924e6f439f394", size = 41175, upload-time = "2025-06-09T22:55:38.436Z" }, - { url = "https://files.pythonhosted.org/packages/a4/ff/47f08595e3d9b5e149c150f88d9714574f1a7cbd89fe2817158a952674bf/propcache-0.3.2-cp313-cp313t-win_amd64.whl", hash = "sha256:9704bedf6e7cbe3c65eca4379a9b53ee6a83749f047808cbb5044d40d7d72198", size = 44857, upload-time = "2025-06-09T22:55:39.687Z" }, - { url = "https://files.pythonhosted.org/packages/cc/35/cc0aaecf278bb4575b8555f2b137de5ab821595ddae9da9d3cd1da4072c7/propcache-0.3.2-py3-none-any.whl", hash = "sha256:98f1ec44fb675f5052cccc8e609c46ed23a35a1cfd18545ad4e29002d858a43f", size = 12663, upload-time = "2025-06-09T22:56:04.484Z" }, -] - -[[package]] -name = "protobuf" -version = "4.25.8" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/df/01/34c8d2b6354906d728703cb9d546a0e534de479e25f1b581e4094c4a85cc/protobuf-4.25.8.tar.gz", hash = "sha256:6135cf8affe1fc6f76cced2641e4ea8d3e59518d1f24ae41ba97bcad82d397cd", size = 380920, upload-time = "2025-05-28T14:22:25.153Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/45/ff/05f34305fe6b85bbfbecbc559d423a5985605cad5eda4f47eae9e9c9c5c5/protobuf-4.25.8-cp310-abi3-win32.whl", hash = "sha256:504435d831565f7cfac9f0714440028907f1975e4bed228e58e72ecfff58a1e0", size = 392745, upload-time = "2025-05-28T14:22:10.524Z" }, - { url = "https://files.pythonhosted.org/packages/08/35/8b8a8405c564caf4ba835b1fdf554da869954712b26d8f2a98c0e434469b/protobuf-4.25.8-cp310-abi3-win_amd64.whl", hash = "sha256:bd551eb1fe1d7e92c1af1d75bdfa572eff1ab0e5bf1736716814cdccdb2360f9", size = 413736, upload-time = "2025-05-28T14:22:13.156Z" }, - { url = "https://files.pythonhosted.org/packages/28/d7/ab27049a035b258dab43445eb6ec84a26277b16105b277cbe0a7698bdc6c/protobuf-4.25.8-cp37-abi3-macosx_10_9_universal2.whl", hash = "sha256:ca809b42f4444f144f2115c4c1a747b9a404d590f18f37e9402422033e464e0f", size = 394537, upload-time = "2025-05-28T14:22:14.768Z" }, - { url = "https://files.pythonhosted.org/packages/bd/6d/a4a198b61808dd3d1ee187082ccc21499bc949d639feb948961b48be9a7e/protobuf-4.25.8-cp37-abi3-manylinux2014_aarch64.whl", hash = "sha256:9ad7ef62d92baf5a8654fbb88dac7fa5594cfa70fd3440488a5ca3bfc6d795a7", size = 294005, upload-time = "2025-05-28T14:22:16.052Z" }, - { url = "https://files.pythonhosted.org/packages/d6/c6/c9deaa6e789b6fc41b88ccbdfe7a42d2b82663248b715f55aa77fbc00724/protobuf-4.25.8-cp37-abi3-manylinux2014_x86_64.whl", hash = "sha256:83e6e54e93d2b696a92cad6e6efc924f3850f82b52e1563778dfab8b355101b0", size = 294924, upload-time = "2025-05-28T14:22:17.105Z" }, - { url = "https://files.pythonhosted.org/packages/0c/c1/6aece0ab5209981a70cd186f164c133fdba2f51e124ff92b73de7fd24d78/protobuf-4.25.8-py3-none-any.whl", hash = "sha256:15a0af558aa3b13efef102ae6e4f3efac06f1eea11afb3a57db2901447d9fb59", size = 156757, upload-time = "2025-05-28T14:22:24.135Z" }, -] - -[[package]] -name = "psutil" -version = "7.0.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/2a/80/336820c1ad9286a4ded7e845b2eccfcb27851ab8ac6abece774a6ff4d3de/psutil-7.0.0.tar.gz", hash = "sha256:7be9c3eba38beccb6495ea33afd982a44074b78f28c434a1f51cc07fd315c456", size = 497003, upload-time = "2025-02-13T21:54:07.946Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/ed/e6/2d26234410f8b8abdbf891c9da62bee396583f713fb9f3325a4760875d22/psutil-7.0.0-cp36-abi3-macosx_10_9_x86_64.whl", hash = "sha256:101d71dc322e3cffd7cea0650b09b3d08b8e7c4109dd6809fe452dfd00e58b25", size = 238051, upload-time = "2025-02-13T21:54:12.36Z" }, - { url = "https://files.pythonhosted.org/packages/04/8b/30f930733afe425e3cbfc0e1468a30a18942350c1a8816acfade80c005c4/psutil-7.0.0-cp36-abi3-macosx_11_0_arm64.whl", hash = "sha256:39db632f6bb862eeccf56660871433e111b6ea58f2caea825571951d4b6aa3da", size = 239535, upload-time = "2025-02-13T21:54:16.07Z" }, - { url = "https://files.pythonhosted.org/packages/2a/ed/d362e84620dd22876b55389248e522338ed1bf134a5edd3b8231d7207f6d/psutil-7.0.0-cp36-abi3-manylinux_2_12_i686.manylinux2010_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:1fcee592b4c6f146991ca55919ea3d1f8926497a713ed7faaf8225e174581e91", size = 275004, upload-time = "2025-02-13T21:54:18.662Z" }, - { url = "https://files.pythonhosted.org/packages/bf/b9/b0eb3f3cbcb734d930fdf839431606844a825b23eaf9a6ab371edac8162c/psutil-7.0.0-cp36-abi3-manylinux_2_12_x86_64.manylinux2010_x86_64.manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:4b1388a4f6875d7e2aff5c4ca1cc16c545ed41dd8bb596cefea80111db353a34", size = 277986, upload-time = "2025-02-13T21:54:21.811Z" }, - { url = "https://files.pythonhosted.org/packages/eb/a2/709e0fe2f093556c17fbafda93ac032257242cabcc7ff3369e2cb76a97aa/psutil-7.0.0-cp36-abi3-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:a5f098451abc2828f7dc6b58d44b532b22f2088f4999a937557b603ce72b1993", size = 279544, upload-time = "2025-02-13T21:54:24.68Z" }, - { url = "https://files.pythonhosted.org/packages/50/e6/eecf58810b9d12e6427369784efe814a1eec0f492084ce8eb8f4d89d6d61/psutil-7.0.0-cp37-abi3-win32.whl", hash = "sha256:ba3fcef7523064a6c9da440fc4d6bd07da93ac726b5733c29027d7dc95b39d99", size = 241053, upload-time = "2025-02-13T21:54:34.31Z" }, - { url = "https://files.pythonhosted.org/packages/50/1b/6921afe68c74868b4c9fa424dad3be35b095e16687989ebbb50ce4fceb7c/psutil-7.0.0-cp37-abi3-win_amd64.whl", hash = "sha256:4cf3d4eb1aa9b348dec30105c55cd9b7d4629285735a102beb4441e38db90553", size = 244885, upload-time = "2025-02-13T21:54:37.486Z" }, -] - -[[package]] -name = "pybind11" -version = "2.13.6" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/d2/c1/72b9622fcb32ff98b054f724e213c7f70d6898baa714f4516288456ceaba/pybind11-2.13.6.tar.gz", hash = "sha256:ba6af10348c12b24e92fa086b39cfba0eff619b61ac77c406167d813b096d39a", size = 218403, upload-time = "2024-09-14T00:35:22.606Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/13/2f/0f24b288e2ce56f51c920137620b4434a38fd80583dbbe24fc2a1656c388/pybind11-2.13.6-py3-none-any.whl", hash = "sha256:237c41e29157b962835d356b370ededd57594a26d5894a795960f0047cb5caf5", size = 243282, upload-time = "2024-09-14T00:35:20.361Z" }, -] - -[[package]] -name = "pycparser" -version = "2.22" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/1d/b2/31537cf4b1ca988837256c910a668b553fceb8f069bedc4b1c826024b52c/pycparser-2.22.tar.gz", hash = "sha256:491c8be9c040f5390f5bf44a5b07752bd07f56edf992381b05c701439eec10f6", size = 172736, upload-time = "2024-03-30T13:22:22.564Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/13/a3/a812df4e2dd5696d1f351d58b8fe16a405b234ad2886a0dab9183fb78109/pycparser-2.22-py3-none-any.whl", hash = "sha256:c3702b6d3dd8c7abc1afa565d7e63d53a1d0bd86cdc24edd75470f4de499cfcc", size = 117552, upload-time = "2024-03-30T13:22:20.476Z" }, -] - -[[package]] -name = "pydantic" -version = "2.11.7" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "annotated-types" }, - { name = "pydantic-core" }, - { name = "typing-extensions" }, - { name = "typing-inspection" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/00/dd/4325abf92c39ba8623b5af936ddb36ffcfe0beae70405d456ab1fb2f5b8c/pydantic-2.11.7.tar.gz", hash = "sha256:d989c3c6cb79469287b1569f7447a17848c998458d49ebe294e975b9baf0f0db", size = 788350, upload-time = "2025-06-14T08:33:17.137Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/6a/c0/ec2b1c8712ca690e5d61979dee872603e92b8a32f94cc1b72d53beab008a/pydantic-2.11.7-py3-none-any.whl", hash = "sha256:dde5df002701f6de26248661f6835bbe296a47bf73990135c7d07ce741b9623b", size = 444782, upload-time = "2025-06-14T08:33:14.905Z" }, -] - -[[package]] -name = "pydantic-core" -version = "2.33.2" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "typing-extensions" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/ad/88/5f2260bdfae97aabf98f1778d43f69574390ad787afb646292a638c923d4/pydantic_core-2.33.2.tar.gz", hash = "sha256:7cb8bc3605c29176e1b105350d2e6474142d7c1bd1d9327c4a9bdb46bf827acc", size = 435195, upload-time = "2025-04-23T18:33:52.104Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/e5/92/b31726561b5dae176c2d2c2dc43a9c5bfba5d32f96f8b4c0a600dd492447/pydantic_core-2.33.2-cp310-cp310-macosx_10_12_x86_64.whl", hash = "sha256:2b3d326aaef0c0399d9afffeb6367d5e26ddc24d351dbc9c636840ac355dc5d8", size = 2028817, upload-time = "2025-04-23T18:30:43.919Z" }, - { url = "https://files.pythonhosted.org/packages/a3/44/3f0b95fafdaca04a483c4e685fe437c6891001bf3ce8b2fded82b9ea3aa1/pydantic_core-2.33.2-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:0e5b2671f05ba48b94cb90ce55d8bdcaaedb8ba00cc5359f6810fc918713983d", size = 1861357, upload-time = "2025-04-23T18:30:46.372Z" }, - { url = "https://files.pythonhosted.org/packages/30/97/e8f13b55766234caae05372826e8e4b3b96e7b248be3157f53237682e43c/pydantic_core-2.33.2-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:0069c9acc3f3981b9ff4cdfaf088e98d83440a4c7ea1bc07460af3d4dc22e72d", size = 1898011, upload-time = "2025-04-23T18:30:47.591Z" }, - { url = "https://files.pythonhosted.org/packages/9b/a3/99c48cf7bafc991cc3ee66fd544c0aae8dc907b752f1dad2d79b1b5a471f/pydantic_core-2.33.2-cp310-cp310-manylinux_2_17_armv7l.manylinux2014_armv7l.whl", hash = "sha256:d53b22f2032c42eaaf025f7c40c2e3b94568ae077a606f006d206a463bc69572", size = 1982730, upload-time = "2025-04-23T18:30:49.328Z" }, - { url = "https://files.pythonhosted.org/packages/de/8e/a5b882ec4307010a840fb8b58bd9bf65d1840c92eae7534c7441709bf54b/pydantic_core-2.33.2-cp310-cp310-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:0405262705a123b7ce9f0b92f123334d67b70fd1f20a9372b907ce1080c7ba02", size = 2136178, upload-time = "2025-04-23T18:30:50.907Z" }, - { url = "https://files.pythonhosted.org/packages/e4/bb/71e35fc3ed05af6834e890edb75968e2802fe98778971ab5cba20a162315/pydantic_core-2.33.2-cp310-cp310-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:4b25d91e288e2c4e0662b8038a28c6a07eaac3e196cfc4ff69de4ea3db992a1b", size = 2736462, upload-time = "2025-04-23T18:30:52.083Z" }, - { url = "https://files.pythonhosted.org/packages/31/0d/c8f7593e6bc7066289bbc366f2235701dcbebcd1ff0ef8e64f6f239fb47d/pydantic_core-2.33.2-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:6bdfe4b3789761f3bcb4b1ddf33355a71079858958e3a552f16d5af19768fef2", size = 2005652, upload-time = "2025-04-23T18:30:53.389Z" }, - { url = "https://files.pythonhosted.org/packages/d2/7a/996d8bd75f3eda405e3dd219ff5ff0a283cd8e34add39d8ef9157e722867/pydantic_core-2.33.2-cp310-cp310-manylinux_2_5_i686.manylinux1_i686.whl", hash = "sha256:efec8db3266b76ef9607c2c4c419bdb06bf335ae433b80816089ea7585816f6a", size = 2113306, upload-time = "2025-04-23T18:30:54.661Z" }, - { url = "https://files.pythonhosted.org/packages/ff/84/daf2a6fb2db40ffda6578a7e8c5a6e9c8affb251a05c233ae37098118788/pydantic_core-2.33.2-cp310-cp310-musllinux_1_1_aarch64.whl", hash = "sha256:031c57d67ca86902726e0fae2214ce6770bbe2f710dc33063187a68744a5ecac", size = 2073720, upload-time = "2025-04-23T18:30:56.11Z" }, - { url = "https://files.pythonhosted.org/packages/77/fb/2258da019f4825128445ae79456a5499c032b55849dbd5bed78c95ccf163/pydantic_core-2.33.2-cp310-cp310-musllinux_1_1_armv7l.whl", hash = "sha256:f8de619080e944347f5f20de29a975c2d815d9ddd8be9b9b7268e2e3ef68605a", size = 2244915, upload-time = "2025-04-23T18:30:57.501Z" }, - { url = "https://files.pythonhosted.org/packages/d8/7a/925ff73756031289468326e355b6fa8316960d0d65f8b5d6b3a3e7866de7/pydantic_core-2.33.2-cp310-cp310-musllinux_1_1_x86_64.whl", hash = "sha256:73662edf539e72a9440129f231ed3757faab89630d291b784ca99237fb94db2b", size = 2241884, upload-time = "2025-04-23T18:30:58.867Z" }, - { url = "https://files.pythonhosted.org/packages/0b/b0/249ee6d2646f1cdadcb813805fe76265745c4010cf20a8eba7b0e639d9b2/pydantic_core-2.33.2-cp310-cp310-win32.whl", hash = "sha256:0a39979dcbb70998b0e505fb1556a1d550a0781463ce84ebf915ba293ccb7e22", size = 1910496, upload-time = "2025-04-23T18:31:00.078Z" }, - { url = "https://files.pythonhosted.org/packages/66/ff/172ba8f12a42d4b552917aa65d1f2328990d3ccfc01d5b7c943ec084299f/pydantic_core-2.33.2-cp310-cp310-win_amd64.whl", hash = "sha256:b0379a2b24882fef529ec3b4987cb5d003b9cda32256024e6fe1586ac45fc640", size = 1955019, upload-time = "2025-04-23T18:31:01.335Z" }, - { url = "https://files.pythonhosted.org/packages/3f/8d/71db63483d518cbbf290261a1fc2839d17ff89fce7089e08cad07ccfce67/pydantic_core-2.33.2-cp311-cp311-macosx_10_12_x86_64.whl", hash = "sha256:4c5b0a576fb381edd6d27f0a85915c6daf2f8138dc5c267a57c08a62900758c7", size = 2028584, upload-time = "2025-04-23T18:31:03.106Z" }, - { url = "https://files.pythonhosted.org/packages/24/2f/3cfa7244ae292dd850989f328722d2aef313f74ffc471184dc509e1e4e5a/pydantic_core-2.33.2-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:e799c050df38a639db758c617ec771fd8fb7a5f8eaaa4b27b101f266b216a246", size = 1855071, upload-time = "2025-04-23T18:31:04.621Z" }, - { url = "https://files.pythonhosted.org/packages/b3/d3/4ae42d33f5e3f50dd467761304be2fa0a9417fbf09735bc2cce003480f2a/pydantic_core-2.33.2-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:dc46a01bf8d62f227d5ecee74178ffc448ff4e5197c756331f71efcc66dc980f", size = 1897823, upload-time = "2025-04-23T18:31:06.377Z" }, - { url = "https://files.pythonhosted.org/packages/f4/f3/aa5976e8352b7695ff808599794b1fba2a9ae2ee954a3426855935799488/pydantic_core-2.33.2-cp311-cp311-manylinux_2_17_armv7l.manylinux2014_armv7l.whl", hash = "sha256:a144d4f717285c6d9234a66778059f33a89096dfb9b39117663fd8413d582dcc", size = 1983792, upload-time = "2025-04-23T18:31:07.93Z" }, - { url = "https://files.pythonhosted.org/packages/d5/7a/cda9b5a23c552037717f2b2a5257e9b2bfe45e687386df9591eff7b46d28/pydantic_core-2.33.2-cp311-cp311-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:73cf6373c21bc80b2e0dc88444f41ae60b2f070ed02095754eb5a01df12256de", size = 2136338, upload-time = "2025-04-23T18:31:09.283Z" }, - { url = "https://files.pythonhosted.org/packages/2b/9f/b8f9ec8dd1417eb9da784e91e1667d58a2a4a7b7b34cf4af765ef663a7e5/pydantic_core-2.33.2-cp311-cp311-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:3dc625f4aa79713512d1976fe9f0bc99f706a9dee21dfd1810b4bbbf228d0e8a", size = 2730998, upload-time = "2025-04-23T18:31:11.7Z" }, - { url = "https://files.pythonhosted.org/packages/47/bc/cd720e078576bdb8255d5032c5d63ee5c0bf4b7173dd955185a1d658c456/pydantic_core-2.33.2-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:881b21b5549499972441da4758d662aeea93f1923f953e9cbaff14b8b9565aef", size = 2003200, upload-time = "2025-04-23T18:31:13.536Z" }, - { url = "https://files.pythonhosted.org/packages/ca/22/3602b895ee2cd29d11a2b349372446ae9727c32e78a94b3d588a40fdf187/pydantic_core-2.33.2-cp311-cp311-manylinux_2_5_i686.manylinux1_i686.whl", hash = "sha256:bdc25f3681f7b78572699569514036afe3c243bc3059d3942624e936ec93450e", size = 2113890, upload-time = "2025-04-23T18:31:15.011Z" }, - { url = "https://files.pythonhosted.org/packages/ff/e6/e3c5908c03cf00d629eb38393a98fccc38ee0ce8ecce32f69fc7d7b558a7/pydantic_core-2.33.2-cp311-cp311-musllinux_1_1_aarch64.whl", hash = "sha256:fe5b32187cbc0c862ee201ad66c30cf218e5ed468ec8dc1cf49dec66e160cc4d", size = 2073359, upload-time = "2025-04-23T18:31:16.393Z" }, - { url = "https://files.pythonhosted.org/packages/12/e7/6a36a07c59ebefc8777d1ffdaf5ae71b06b21952582e4b07eba88a421c79/pydantic_core-2.33.2-cp311-cp311-musllinux_1_1_armv7l.whl", hash = "sha256:bc7aee6f634a6f4a95676fcb5d6559a2c2a390330098dba5e5a5f28a2e4ada30", size = 2245883, upload-time = "2025-04-23T18:31:17.892Z" }, - { url = "https://files.pythonhosted.org/packages/16/3f/59b3187aaa6cc0c1e6616e8045b284de2b6a87b027cce2ffcea073adf1d2/pydantic_core-2.33.2-cp311-cp311-musllinux_1_1_x86_64.whl", hash = "sha256:235f45e5dbcccf6bd99f9f472858849f73d11120d76ea8707115415f8e5ebebf", size = 2241074, upload-time = "2025-04-23T18:31:19.205Z" }, - { url = "https://files.pythonhosted.org/packages/e0/ed/55532bb88f674d5d8f67ab121a2a13c385df382de2a1677f30ad385f7438/pydantic_core-2.33.2-cp311-cp311-win32.whl", hash = "sha256:6368900c2d3ef09b69cb0b913f9f8263b03786e5b2a387706c5afb66800efd51", size = 1910538, upload-time = "2025-04-23T18:31:20.541Z" }, - { url = "https://files.pythonhosted.org/packages/fe/1b/25b7cccd4519c0b23c2dd636ad39d381abf113085ce4f7bec2b0dc755eb1/pydantic_core-2.33.2-cp311-cp311-win_amd64.whl", hash = "sha256:1e063337ef9e9820c77acc768546325ebe04ee38b08703244c1309cccc4f1bab", size = 1952909, upload-time = "2025-04-23T18:31:22.371Z" }, - { url = "https://files.pythonhosted.org/packages/49/a9/d809358e49126438055884c4366a1f6227f0f84f635a9014e2deb9b9de54/pydantic_core-2.33.2-cp311-cp311-win_arm64.whl", hash = "sha256:6b99022f1d19bc32a4c2a0d544fc9a76e3be90f0b3f4af413f87d38749300e65", size = 1897786, upload-time = "2025-04-23T18:31:24.161Z" }, - { url = "https://files.pythonhosted.org/packages/18/8a/2b41c97f554ec8c71f2a8a5f85cb56a8b0956addfe8b0efb5b3d77e8bdc3/pydantic_core-2.33.2-cp312-cp312-macosx_10_12_x86_64.whl", hash = "sha256:a7ec89dc587667f22b6a0b6579c249fca9026ce7c333fc142ba42411fa243cdc", size = 2009000, upload-time = "2025-04-23T18:31:25.863Z" }, - { url = "https://files.pythonhosted.org/packages/a1/02/6224312aacb3c8ecbaa959897af57181fb6cf3a3d7917fd44d0f2917e6f2/pydantic_core-2.33.2-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:3c6db6e52c6d70aa0d00d45cdb9b40f0433b96380071ea80b09277dba021ddf7", size = 1847996, upload-time = "2025-04-23T18:31:27.341Z" }, - { url = "https://files.pythonhosted.org/packages/d6/46/6dcdf084a523dbe0a0be59d054734b86a981726f221f4562aed313dbcb49/pydantic_core-2.33.2-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:4e61206137cbc65e6d5256e1166f88331d3b6238e082d9f74613b9b765fb9025", size = 1880957, upload-time = "2025-04-23T18:31:28.956Z" }, - { url = "https://files.pythonhosted.org/packages/ec/6b/1ec2c03837ac00886ba8160ce041ce4e325b41d06a034adbef11339ae422/pydantic_core-2.33.2-cp312-cp312-manylinux_2_17_armv7l.manylinux2014_armv7l.whl", hash = "sha256:eb8c529b2819c37140eb51b914153063d27ed88e3bdc31b71198a198e921e011", size = 1964199, upload-time = "2025-04-23T18:31:31.025Z" }, - { url = "https://files.pythonhosted.org/packages/2d/1d/6bf34d6adb9debd9136bd197ca72642203ce9aaaa85cfcbfcf20f9696e83/pydantic_core-2.33.2-cp312-cp312-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:c52b02ad8b4e2cf14ca7b3d918f3eb0ee91e63b3167c32591e57c4317e134f8f", size = 2120296, upload-time = "2025-04-23T18:31:32.514Z" }, - { url = "https://files.pythonhosted.org/packages/e0/94/2bd0aaf5a591e974b32a9f7123f16637776c304471a0ab33cf263cf5591a/pydantic_core-2.33.2-cp312-cp312-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:96081f1605125ba0855dfda83f6f3df5ec90c61195421ba72223de35ccfb2f88", size = 2676109, upload-time = "2025-04-23T18:31:33.958Z" }, - { url = "https://files.pythonhosted.org/packages/f9/41/4b043778cf9c4285d59742281a769eac371b9e47e35f98ad321349cc5d61/pydantic_core-2.33.2-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:8f57a69461af2a5fa6e6bbd7a5f60d3b7e6cebb687f55106933188e79ad155c1", size = 2002028, upload-time = "2025-04-23T18:31:39.095Z" }, - { url = "https://files.pythonhosted.org/packages/cb/d5/7bb781bf2748ce3d03af04d5c969fa1308880e1dca35a9bd94e1a96a922e/pydantic_core-2.33.2-cp312-cp312-manylinux_2_5_i686.manylinux1_i686.whl", hash = "sha256:572c7e6c8bb4774d2ac88929e3d1f12bc45714ae5ee6d9a788a9fb35e60bb04b", size = 2100044, upload-time = "2025-04-23T18:31:41.034Z" }, - { url = "https://files.pythonhosted.org/packages/fe/36/def5e53e1eb0ad896785702a5bbfd25eed546cdcf4087ad285021a90ed53/pydantic_core-2.33.2-cp312-cp312-musllinux_1_1_aarch64.whl", hash = "sha256:db4b41f9bd95fbe5acd76d89920336ba96f03e149097365afe1cb092fceb89a1", size = 2058881, upload-time = "2025-04-23T18:31:42.757Z" }, - { url = "https://files.pythonhosted.org/packages/01/6c/57f8d70b2ee57fc3dc8b9610315949837fa8c11d86927b9bb044f8705419/pydantic_core-2.33.2-cp312-cp312-musllinux_1_1_armv7l.whl", hash = "sha256:fa854f5cf7e33842a892e5c73f45327760bc7bc516339fda888c75ae60edaeb6", size = 2227034, upload-time = "2025-04-23T18:31:44.304Z" }, - { url = "https://files.pythonhosted.org/packages/27/b9/9c17f0396a82b3d5cbea4c24d742083422639e7bb1d5bf600e12cb176a13/pydantic_core-2.33.2-cp312-cp312-musllinux_1_1_x86_64.whl", hash = "sha256:5f483cfb75ff703095c59e365360cb73e00185e01aaea067cd19acffd2ab20ea", size = 2234187, upload-time = "2025-04-23T18:31:45.891Z" }, - { url = "https://files.pythonhosted.org/packages/b0/6a/adf5734ffd52bf86d865093ad70b2ce543415e0e356f6cacabbc0d9ad910/pydantic_core-2.33.2-cp312-cp312-win32.whl", hash = "sha256:9cb1da0f5a471435a7bc7e439b8a728e8b61e59784b2af70d7c169f8dd8ae290", size = 1892628, upload-time = "2025-04-23T18:31:47.819Z" }, - { url = "https://files.pythonhosted.org/packages/43/e4/5479fecb3606c1368d496a825d8411e126133c41224c1e7238be58b87d7e/pydantic_core-2.33.2-cp312-cp312-win_amd64.whl", hash = "sha256:f941635f2a3d96b2973e867144fde513665c87f13fe0e193c158ac51bfaaa7b2", size = 1955866, upload-time = "2025-04-23T18:31:49.635Z" }, - { url = "https://files.pythonhosted.org/packages/0d/24/8b11e8b3e2be9dd82df4b11408a67c61bb4dc4f8e11b5b0fc888b38118b5/pydantic_core-2.33.2-cp312-cp312-win_arm64.whl", hash = "sha256:cca3868ddfaccfbc4bfb1d608e2ccaaebe0ae628e1416aeb9c4d88c001bb45ab", size = 1888894, upload-time = "2025-04-23T18:31:51.609Z" }, - { url = "https://files.pythonhosted.org/packages/46/8c/99040727b41f56616573a28771b1bfa08a3d3fe74d3d513f01251f79f172/pydantic_core-2.33.2-cp313-cp313-macosx_10_12_x86_64.whl", hash = "sha256:1082dd3e2d7109ad8b7da48e1d4710c8d06c253cbc4a27c1cff4fbcaa97a9e3f", size = 2015688, upload-time = "2025-04-23T18:31:53.175Z" }, - { url = "https://files.pythonhosted.org/packages/3a/cc/5999d1eb705a6cefc31f0b4a90e9f7fc400539b1a1030529700cc1b51838/pydantic_core-2.33.2-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:f517ca031dfc037a9c07e748cefd8d96235088b83b4f4ba8939105d20fa1dcd6", size = 1844808, upload-time = "2025-04-23T18:31:54.79Z" }, - { url = "https://files.pythonhosted.org/packages/6f/5e/a0a7b8885c98889a18b6e376f344da1ef323d270b44edf8174d6bce4d622/pydantic_core-2.33.2-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:0a9f2c9dd19656823cb8250b0724ee9c60a82f3cdf68a080979d13092a3b0fef", size = 1885580, upload-time = "2025-04-23T18:31:57.393Z" }, - { url = "https://files.pythonhosted.org/packages/3b/2a/953581f343c7d11a304581156618c3f592435523dd9d79865903272c256a/pydantic_core-2.33.2-cp313-cp313-manylinux_2_17_armv7l.manylinux2014_armv7l.whl", hash = "sha256:2b0a451c263b01acebe51895bfb0e1cc842a5c666efe06cdf13846c7418caa9a", size = 1973859, upload-time = "2025-04-23T18:31:59.065Z" }, - { url = "https://files.pythonhosted.org/packages/e6/55/f1a813904771c03a3f97f676c62cca0c0a4138654107c1b61f19c644868b/pydantic_core-2.33.2-cp313-cp313-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:1ea40a64d23faa25e62a70ad163571c0b342b8bf66d5fa612ac0dec4f069d916", size = 2120810, upload-time = "2025-04-23T18:32:00.78Z" }, - { url = "https://files.pythonhosted.org/packages/aa/c3/053389835a996e18853ba107a63caae0b9deb4a276c6b472931ea9ae6e48/pydantic_core-2.33.2-cp313-cp313-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:0fb2d542b4d66f9470e8065c5469ec676978d625a8b7a363f07d9a501a9cb36a", size = 2676498, upload-time = "2025-04-23T18:32:02.418Z" }, - { url = "https://files.pythonhosted.org/packages/eb/3c/f4abd740877a35abade05e437245b192f9d0ffb48bbbbd708df33d3cda37/pydantic_core-2.33.2-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:9fdac5d6ffa1b5a83bca06ffe7583f5576555e6c8b3a91fbd25ea7780f825f7d", size = 2000611, upload-time = "2025-04-23T18:32:04.152Z" }, - { url = "https://files.pythonhosted.org/packages/59/a7/63ef2fed1837d1121a894d0ce88439fe3e3b3e48c7543b2a4479eb99c2bd/pydantic_core-2.33.2-cp313-cp313-manylinux_2_5_i686.manylinux1_i686.whl", hash = "sha256:04a1a413977ab517154eebb2d326da71638271477d6ad87a769102f7c2488c56", size = 2107924, upload-time = "2025-04-23T18:32:06.129Z" }, - { url = "https://files.pythonhosted.org/packages/04/8f/2551964ef045669801675f1cfc3b0d74147f4901c3ffa42be2ddb1f0efc4/pydantic_core-2.33.2-cp313-cp313-musllinux_1_1_aarch64.whl", hash = "sha256:c8e7af2f4e0194c22b5b37205bfb293d166a7344a5b0d0eaccebc376546d77d5", size = 2063196, upload-time = "2025-04-23T18:32:08.178Z" }, - { url = "https://files.pythonhosted.org/packages/26/bd/d9602777e77fc6dbb0c7db9ad356e9a985825547dce5ad1d30ee04903918/pydantic_core-2.33.2-cp313-cp313-musllinux_1_1_armv7l.whl", hash = "sha256:5c92edd15cd58b3c2d34873597a1e20f13094f59cf88068adb18947df5455b4e", size = 2236389, upload-time = "2025-04-23T18:32:10.242Z" }, - { url = "https://files.pythonhosted.org/packages/42/db/0e950daa7e2230423ab342ae918a794964b053bec24ba8af013fc7c94846/pydantic_core-2.33.2-cp313-cp313-musllinux_1_1_x86_64.whl", hash = "sha256:65132b7b4a1c0beded5e057324b7e16e10910c106d43675d9bd87d4f38dde162", size = 2239223, upload-time = "2025-04-23T18:32:12.382Z" }, - { url = "https://files.pythonhosted.org/packages/58/4d/4f937099c545a8a17eb52cb67fe0447fd9a373b348ccfa9a87f141eeb00f/pydantic_core-2.33.2-cp313-cp313-win32.whl", hash = "sha256:52fb90784e0a242bb96ec53f42196a17278855b0f31ac7c3cc6f5c1ec4811849", size = 1900473, upload-time = "2025-04-23T18:32:14.034Z" }, - { url = "https://files.pythonhosted.org/packages/a0/75/4a0a9bac998d78d889def5e4ef2b065acba8cae8c93696906c3a91f310ca/pydantic_core-2.33.2-cp313-cp313-win_amd64.whl", hash = "sha256:c083a3bdd5a93dfe480f1125926afcdbf2917ae714bdb80b36d34318b2bec5d9", size = 1955269, upload-time = "2025-04-23T18:32:15.783Z" }, - { url = "https://files.pythonhosted.org/packages/f9/86/1beda0576969592f1497b4ce8e7bc8cbdf614c352426271b1b10d5f0aa64/pydantic_core-2.33.2-cp313-cp313-win_arm64.whl", hash = "sha256:e80b087132752f6b3d714f041ccf74403799d3b23a72722ea2e6ba2e892555b9", size = 1893921, upload-time = "2025-04-23T18:32:18.473Z" }, - { url = "https://files.pythonhosted.org/packages/a4/7d/e09391c2eebeab681df2b74bfe6c43422fffede8dc74187b2b0bf6fd7571/pydantic_core-2.33.2-cp313-cp313t-macosx_11_0_arm64.whl", hash = "sha256:61c18fba8e5e9db3ab908620af374db0ac1baa69f0f32df4f61ae23f15e586ac", size = 1806162, upload-time = "2025-04-23T18:32:20.188Z" }, - { url = "https://files.pythonhosted.org/packages/f1/3d/847b6b1fed9f8ed3bb95a9ad04fbd0b212e832d4f0f50ff4d9ee5a9f15cf/pydantic_core-2.33.2-cp313-cp313t-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:95237e53bb015f67b63c91af7518a62a8660376a6a0db19b89acc77a4d6199f5", size = 1981560, upload-time = "2025-04-23T18:32:22.354Z" }, - { url = "https://files.pythonhosted.org/packages/6f/9a/e73262f6c6656262b5fdd723ad90f518f579b7bc8622e43a942eec53c938/pydantic_core-2.33.2-cp313-cp313t-win_amd64.whl", hash = "sha256:c2fc0a768ef76c15ab9238afa6da7f69895bb5d1ee83aeea2e3509af4472d0b9", size = 1935777, upload-time = "2025-04-23T18:32:25.088Z" }, - { url = "https://files.pythonhosted.org/packages/30/68/373d55e58b7e83ce371691f6eaa7175e3a24b956c44628eb25d7da007917/pydantic_core-2.33.2-pp310-pypy310_pp73-macosx_10_12_x86_64.whl", hash = "sha256:5c4aa4e82353f65e548c476b37e64189783aa5384903bfea4f41580f255fddfa", size = 2023982, upload-time = "2025-04-23T18:32:53.14Z" }, - { url = "https://files.pythonhosted.org/packages/a4/16/145f54ac08c96a63d8ed6442f9dec17b2773d19920b627b18d4f10a061ea/pydantic_core-2.33.2-pp310-pypy310_pp73-macosx_11_0_arm64.whl", hash = "sha256:d946c8bf0d5c24bf4fe333af284c59a19358aa3ec18cb3dc4370080da1e8ad29", size = 1858412, upload-time = "2025-04-23T18:32:55.52Z" }, - { url = "https://files.pythonhosted.org/packages/41/b1/c6dc6c3e2de4516c0bb2c46f6a373b91b5660312342a0cf5826e38ad82fa/pydantic_core-2.33.2-pp310-pypy310_pp73-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:87b31b6846e361ef83fedb187bb5b4372d0da3f7e28d85415efa92d6125d6e6d", size = 1892749, upload-time = "2025-04-23T18:32:57.546Z" }, - { url = "https://files.pythonhosted.org/packages/12/73/8cd57e20afba760b21b742106f9dbdfa6697f1570b189c7457a1af4cd8a0/pydantic_core-2.33.2-pp310-pypy310_pp73-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:aa9d91b338f2df0508606f7009fde642391425189bba6d8c653afd80fd6bb64e", size = 2067527, upload-time = "2025-04-23T18:32:59.771Z" }, - { url = "https://files.pythonhosted.org/packages/e3/d5/0bb5d988cc019b3cba4a78f2d4b3854427fc47ee8ec8e9eaabf787da239c/pydantic_core-2.33.2-pp310-pypy310_pp73-manylinux_2_5_i686.manylinux1_i686.whl", hash = "sha256:2058a32994f1fde4ca0480ab9d1e75a0e8c87c22b53a3ae66554f9af78f2fe8c", size = 2108225, upload-time = "2025-04-23T18:33:04.51Z" }, - { url = "https://files.pythonhosted.org/packages/f1/c5/00c02d1571913d496aabf146106ad8239dc132485ee22efe08085084ff7c/pydantic_core-2.33.2-pp310-pypy310_pp73-musllinux_1_1_aarch64.whl", hash = "sha256:0e03262ab796d986f978f79c943fc5f620381be7287148b8010b4097f79a39ec", size = 2069490, upload-time = "2025-04-23T18:33:06.391Z" }, - { url = "https://files.pythonhosted.org/packages/22/a8/dccc38768274d3ed3a59b5d06f59ccb845778687652daa71df0cab4040d7/pydantic_core-2.33.2-pp310-pypy310_pp73-musllinux_1_1_armv7l.whl", hash = "sha256:1a8695a8d00c73e50bff9dfda4d540b7dee29ff9b8053e38380426a85ef10052", size = 2237525, upload-time = "2025-04-23T18:33:08.44Z" }, - { url = "https://files.pythonhosted.org/packages/d4/e7/4f98c0b125dda7cf7ccd14ba936218397b44f50a56dd8c16a3091df116c3/pydantic_core-2.33.2-pp310-pypy310_pp73-musllinux_1_1_x86_64.whl", hash = "sha256:fa754d1850735a0b0e03bcffd9d4b4343eb417e47196e4485d9cca326073a42c", size = 2238446, upload-time = "2025-04-23T18:33:10.313Z" }, - { url = "https://files.pythonhosted.org/packages/ce/91/2ec36480fdb0b783cd9ef6795753c1dea13882f2e68e73bce76ae8c21e6a/pydantic_core-2.33.2-pp310-pypy310_pp73-win_amd64.whl", hash = "sha256:a11c8d26a50bfab49002947d3d237abe4d9e4b5bdc8846a63537b6488e197808", size = 2066678, upload-time = "2025-04-23T18:33:12.224Z" }, - { url = "https://files.pythonhosted.org/packages/7b/27/d4ae6487d73948d6f20dddcd94be4ea43e74349b56eba82e9bdee2d7494c/pydantic_core-2.33.2-pp311-pypy311_pp73-macosx_10_12_x86_64.whl", hash = "sha256:dd14041875d09cc0f9308e37a6f8b65f5585cf2598a53aa0123df8b129d481f8", size = 2025200, upload-time = "2025-04-23T18:33:14.199Z" }, - { url = "https://files.pythonhosted.org/packages/f1/b8/b3cb95375f05d33801024079b9392a5ab45267a63400bf1866e7ce0f0de4/pydantic_core-2.33.2-pp311-pypy311_pp73-macosx_11_0_arm64.whl", hash = "sha256:d87c561733f66531dced0da6e864f44ebf89a8fba55f31407b00c2f7f9449593", size = 1859123, upload-time = "2025-04-23T18:33:16.555Z" }, - { url = "https://files.pythonhosted.org/packages/05/bc/0d0b5adeda59a261cd30a1235a445bf55c7e46ae44aea28f7bd6ed46e091/pydantic_core-2.33.2-pp311-pypy311_pp73-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:2f82865531efd18d6e07a04a17331af02cb7a651583c418df8266f17a63c6612", size = 1892852, upload-time = "2025-04-23T18:33:18.513Z" }, - { url = "https://files.pythonhosted.org/packages/3e/11/d37bdebbda2e449cb3f519f6ce950927b56d62f0b84fd9cb9e372a26a3d5/pydantic_core-2.33.2-pp311-pypy311_pp73-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:2bfb5112df54209d820d7bf9317c7a6c9025ea52e49f46b6a2060104bba37de7", size = 2067484, upload-time = "2025-04-23T18:33:20.475Z" }, - { url = "https://files.pythonhosted.org/packages/8c/55/1f95f0a05ce72ecb02a8a8a1c3be0579bbc29b1d5ab68f1378b7bebc5057/pydantic_core-2.33.2-pp311-pypy311_pp73-manylinux_2_5_i686.manylinux1_i686.whl", hash = "sha256:64632ff9d614e5eecfb495796ad51b0ed98c453e447a76bcbeeb69615079fc7e", size = 2108896, upload-time = "2025-04-23T18:33:22.501Z" }, - { url = "https://files.pythonhosted.org/packages/53/89/2b2de6c81fa131f423246a9109d7b2a375e83968ad0800d6e57d0574629b/pydantic_core-2.33.2-pp311-pypy311_pp73-musllinux_1_1_aarch64.whl", hash = "sha256:f889f7a40498cc077332c7ab6b4608d296d852182211787d4f3ee377aaae66e8", size = 2069475, upload-time = "2025-04-23T18:33:24.528Z" }, - { url = "https://files.pythonhosted.org/packages/b8/e9/1f7efbe20d0b2b10f6718944b5d8ece9152390904f29a78e68d4e7961159/pydantic_core-2.33.2-pp311-pypy311_pp73-musllinux_1_1_armv7l.whl", hash = "sha256:de4b83bb311557e439b9e186f733f6c645b9417c84e2eb8203f3f820a4b988bf", size = 2239013, upload-time = "2025-04-23T18:33:26.621Z" }, - { url = "https://files.pythonhosted.org/packages/3c/b2/5309c905a93811524a49b4e031e9851a6b00ff0fb668794472ea7746b448/pydantic_core-2.33.2-pp311-pypy311_pp73-musllinux_1_1_x86_64.whl", hash = "sha256:82f68293f055f51b51ea42fafc74b6aad03e70e191799430b90c13d643059ebb", size = 2238715, upload-time = "2025-04-23T18:33:28.656Z" }, - { url = "https://files.pythonhosted.org/packages/32/56/8a7ca5d2cd2cda1d245d34b1c9a942920a718082ae8e54e5f3e5a58b7add/pydantic_core-2.33.2-pp311-pypy311_pp73-win_amd64.whl", hash = "sha256:329467cecfb529c925cf2bbd4d60d2c509bc2fb52a20c1045bf09bb70971a9c1", size = 2066757, upload-time = "2025-04-23T18:33:30.645Z" }, -] - -[[package]] -name = "pydantic-settings" -version = "2.9.1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "pydantic" }, - { name = "python-dotenv" }, - { name = "typing-inspection" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/67/1d/42628a2c33e93f8e9acbde0d5d735fa0850f3e6a2f8cb1eb6c40b9a732ac/pydantic_settings-2.9.1.tar.gz", hash = "sha256:c509bf79d27563add44e8446233359004ed85066cd096d8b510f715e6ef5d268", size = 163234, upload-time = "2025-04-18T16:44:48.265Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/b6/5f/d6d641b490fd3ec2c4c13b4244d68deea3a1b970a97be64f34fb5504ff72/pydantic_settings-2.9.1-py3-none-any.whl", hash = "sha256:59b4f431b1defb26fe620c71a7d3968a710d719f5f4cdbbdb7926edeb770f6ef", size = 44356, upload-time = "2025-04-18T16:44:46.617Z" }, -] - -[[package]] -name = "pygments" -version = "2.19.1" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/7c/2d/c3338d48ea6cc0feb8446d8e6937e1408088a72a39937982cc6111d17f84/pygments-2.19.1.tar.gz", hash = "sha256:61c16d2a8576dc0649d9f39e089b5f02bcd27fba10d8fb4dcc28173f7a45151f", size = 4968581, upload-time = "2025-01-06T17:26:30.443Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/8a/0b/9fcc47d19c48b59121088dd6da2488a49d5f72dacf8262e2790a1d2c7d15/pygments-2.19.1-py3-none-any.whl", hash = "sha256:9ea1544ad55cecf4b8242fab6dd35a93bbce657034b0611ee383099054ab6d8c", size = 1225293, upload-time = "2025-01-06T17:26:25.553Z" }, -] - -[[package]] -name = "pyinstaller" -version = "6.14.1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "altgraph" }, - { name = "macholib", marker = "sys_platform == 'darwin' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "packaging" }, - { name = "pefile", marker = "sys_platform == 'win32' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "pyinstaller-hooks-contrib" }, - { name = "pywin32-ctypes", marker = "sys_platform == 'win32' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "setuptools" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/9f/4a/d66d3a9c34349d73eb099401060e2591da8ccc5ed427e54fff3961302513/pyinstaller-6.14.1.tar.gz", hash = "sha256:35d5c06a668e21f0122178dbf20e40fd21012dc8f6170042af6050c4e7b3edca", size = 4284317, upload-time = "2025-06-08T18:45:46.367Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/43/f6/fa56e547fe849db4b8da0acaad6101a6382c18370c7e0f378a1cf0ea89f0/pyinstaller-6.14.1-py3-none-macosx_10_13_universal2.whl", hash = "sha256:da559cfe4f7a20a7ebdafdf12ea2a03ea94d3caa49736ef53ee2c155d78422c9", size = 999937, upload-time = "2025-06-08T18:44:26.429Z" }, - { url = "https://files.pythonhosted.org/packages/af/a6/a2814978f47ae038b1ce112717adbdcfd8dfb9504e5c52437902331cde1a/pyinstaller-6.14.1-py3-none-manylinux2014_aarch64.whl", hash = "sha256:f040d1e3d42af3730104078d10d4a8ca3350bd1c78de48f12e1b26f761e0cbc3", size = 719569, upload-time = "2025-06-08T18:44:30.948Z" }, - { url = "https://files.pythonhosted.org/packages/35/f0/86391a4c0f558aef43a7dac8f678d46f4e5b84bd133308e3ea81f7384ab9/pyinstaller-6.14.1-py3-none-manylinux2014_i686.whl", hash = "sha256:7b8813fb2d5a82ef4ceffc342ed9a11a6fc1ef21e68e833dbd8fedb8a188d3f5", size = 729824, upload-time = "2025-06-08T18:44:34.983Z" }, - { url = "https://files.pythonhosted.org/packages/e5/88/446814e335d937406e6e1ae4a77ed922b8eea8b90f3aaf69427a16b58ed2/pyinstaller-6.14.1-py3-none-manylinux2014_ppc64le.whl", hash = "sha256:e2cfdbc6dd41d19872054fc233da18856ec422a7fdea899b6985ae04f980376a", size = 727937, upload-time = "2025-06-08T18:44:38.954Z" }, - { url = "https://files.pythonhosted.org/packages/c6/0f/5aa891c61d303ad4a794b7e2f864aacf64fe0f6f5559e2aec0f742595fad/pyinstaller-6.14.1-py3-none-manylinux2014_s390x.whl", hash = "sha256:a4d53b3ecb5786b097b79bda88c4089186fc1498ef7eaa6cee57599ae459241e", size = 724762, upload-time = "2025-06-08T18:44:42.768Z" }, - { url = "https://files.pythonhosted.org/packages/c5/92/e32ec0a1754852a8ed5a60f6746c6483e3da68aee97d314f3a3a99e0ed9e/pyinstaller-6.14.1-py3-none-manylinux2014_x86_64.whl", hash = "sha256:c48dd257f77f61ebea2d1fdbaf11243730f2271873c88d3b5ecb7869525d3bcb", size = 724957, upload-time = "2025-06-08T18:44:46.829Z" }, - { url = "https://files.pythonhosted.org/packages/c3/66/1260f384e47bf939f6238f791d4cda7edb94771d2fa0a451e0edb21ac9c7/pyinstaller-6.14.1-py3-none-musllinux_1_1_aarch64.whl", hash = "sha256:5b05cbb2ffc033b4681268159b82bac94b875475c339603c7e605f00a73c8746", size = 724132, upload-time = "2025-06-08T18:44:51.081Z" }, - { url = "https://files.pythonhosted.org/packages/d2/8b/8570ab94ec07e0b2b1203f45840353ee76aa067a2540c97da43d43477b26/pyinstaller-6.14.1-py3-none-musllinux_1_1_x86_64.whl", hash = "sha256:d5fd73757c8ea9adb2f9c1f81656335ba9890029ede3031835d768fde36e89f0", size = 723847, upload-time = "2025-06-08T18:44:54.896Z" }, - { url = "https://files.pythonhosted.org/packages/d5/43/6c68dc9e53b09ff948d6e46477932b387832bbb920c48061d734ef089368/pyinstaller-6.14.1-py3-none-win32.whl", hash = "sha256:547f7a93592e408cbfd093ce9fd9631215387dab0dbf3130351d3b0b1186a534", size = 1299744, upload-time = "2025-06-08T18:45:00.781Z" }, - { url = "https://files.pythonhosted.org/packages/7c/dd/bb8d5bcb0592f7f5d454ad308051d00ed34f8b08d5003400b825cfe35513/pyinstaller-6.14.1-py3-none-win_amd64.whl", hash = "sha256:0794290b4b56ef9d35858334deb29f36ec1e1f193b0f825212a0aa5a1bec5a2f", size = 1357625, upload-time = "2025-06-08T18:45:06.826Z" }, - { url = "https://files.pythonhosted.org/packages/89/57/8a8979737980e50aa5031b77318ce783759bf25be2956317f2e1d7a65a09/pyinstaller-6.14.1-py3-none-win_arm64.whl", hash = "sha256:d9d99695827f892cb19644106da30681363e8ff27b8326ac8416d62890ab9c74", size = 1298607, upload-time = "2025-06-08T18:45:12.766Z" }, -] - -[[package]] -name = "pyinstaller-hooks-contrib" -version = "2025.5" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "packaging" }, - { name = "setuptools" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/5f/ff/e3376595935d5f8135964d2177cd3e3e0c1b5a6237497d9775237c247a5d/pyinstaller_hooks_contrib-2025.5.tar.gz", hash = "sha256:707386770b8fe066c04aad18a71bc483c7b25e18b4750a756999f7da2ab31982", size = 163124, upload-time = "2025-06-08T18:47:53.26Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/0c/2c/b4d317534e17dd1df95c394d4b37febb15ead006a1c07c2bb006481fb5e7/pyinstaller_hooks_contrib-2025.5-py3-none-any.whl", hash = "sha256:ebfae1ba341cb0002fb2770fad0edf2b3e913c2728d92df7ad562260988ca373", size = 437246, upload-time = "2025-06-08T18:47:51.516Z" }, -] - -[[package]] -name = "pyjwt" -version = "2.10.1" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/e7/46/bd74733ff231675599650d3e47f361794b22ef3e3770998dda30d3b63726/pyjwt-2.10.1.tar.gz", hash = "sha256:3cc5772eb20009233caf06e9d8a0577824723b44e6648ee0a2aedb6cf9381953", size = 87785, upload-time = "2024-11-28T03:43:29.933Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/61/ad/689f02752eeec26aed679477e80e632ef1b682313be70793d798c1d5fc8f/PyJWT-2.10.1-py3-none-any.whl", hash = "sha256:dcdd193e30abefd5debf142f9adfcdd2b58004e644f25406ffaebd50bd98dacb", size = 22997, upload-time = "2024-11-28T03:43:27.893Z" }, -] - -[package.optional-dependencies] -crypto = [ - { name = "cryptography" }, -] - -[[package]] -name = "pylint" -version = "3.3.7" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "astroid" }, - { name = "colorama", marker = "sys_platform == 'win32' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "dill" }, - { name = "isort" }, - { name = "mccabe" }, - { name = "platformdirs" }, - { name = "tomli", marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "tomlkit" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/1c/e4/83e487d3ddd64ab27749b66137b26dc0c5b5c161be680e6beffdc99070b3/pylint-3.3.7.tar.gz", hash = "sha256:2b11de8bde49f9c5059452e0c310c079c746a0a8eeaa789e5aa966ecc23e4559", size = 1520709, upload-time = "2025-05-04T17:07:51.089Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/e8/83/bff755d09e31b5d25cc7fdc4bf3915d1a404e181f1abf0359af376845c24/pylint-3.3.7-py3-none-any.whl", hash = "sha256:43860aafefce92fca4cf6b61fe199cdc5ae54ea28f9bf4cd49de267b5195803d", size = 522565, upload-time = "2025-05-04T17:07:48.714Z" }, -] - -[[package]] -name = "pysoundfile" -version = "0.9.0.post1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "cffi" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/07/fa/bbe4d1c4328eaa83c0656c729eabbf811377fc1e8416d42bf7f7af63ef8c/PySoundFile-0.9.0.post1.tar.gz", hash = "sha256:43dd46a2afc0484c26930a7e59eef9365cee81bce7a4aadc5699f788f60d32c3", size = 1817942, upload-time = "2017-02-03T08:34:48.676Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/2a/b3/0b871e5fd31b9a8e54b4ee359384e705a1ca1e2870706d2f081dc7cc1693/PySoundFile-0.9.0.post1-py2.py3-none-any.whl", hash = "sha256:db14f84f4af1910f54766cf0c0f19d52414fa80aa0e11cb338b5614946f39947", size = 24161, upload-time = "2017-02-03T08:34:43.372Z" }, - { url = "https://files.pythonhosted.org/packages/f7/62/bddd31ba4f575eca81c6642d809fe01ed5ee5f55ebb4e9b14d0a033cc6bf/PySoundFile-0.9.0.post1-py2.py3.cp26.cp27.cp32.cp33.cp34.cp35.cp36.pp27.pp32.pp33-none-macosx_10_5_x86_64.macosx_10_6_intel.macosx_10_9_intel.macosx_10_9_x86_64.whl", hash = "sha256:5889138553f4e675158054f8f41c212ca76ac0e2d949e38d1dd8ded4ca3f0ce0", size = 573152, upload-time = "2017-02-03T08:34:30.961Z" }, - { url = "https://files.pythonhosted.org/packages/b8/d4/4c02ba1cee60e5c5c546de4761bcb7e42cba577216561067ffe40cf8fb0a/PySoundFile-0.9.0.post1-py2.py3.cp26.cp27.cp32.cp33.cp34.cp35.cp36.pp27.pp32.pp33-none-win32.whl", hash = "sha256:c5c5cc8e5f3793a4b9f405c0c77e116e859ac16e065bb6b7f78f2a59484fd7a8", size = 639232, upload-time = "2017-02-03T08:34:35.427Z" }, - { url = "https://files.pythonhosted.org/packages/9d/8e/30d9f80802e8ea2c5b96db2f320fdb147e25a84fd74caa251b57bedeeb33/PySoundFile-0.9.0.post1-py2.py3.cp26.cp27.cp32.cp33.cp34.cp35.cp36.pp27.pp32.pp33-none-win_amd64.whl", hash = "sha256:d92afd505d395523200d5b7f217e409bae4639c90cc61e90832a57a5a0fb484a", size = 671839, upload-time = "2017-02-03T08:34:39.533Z" }, -] - -[[package]] -name = "pytest" -version = "8.4.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "colorama", marker = "sys_platform == 'win32' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "exceptiongroup", marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "iniconfig" }, - { name = "packaging" }, - { name = "pluggy" }, - { name = "pygments" }, - { name = "tomli", marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/fb/aa/405082ce2749be5398045152251ac69c0f3578c7077efc53431303af97ce/pytest-8.4.0.tar.gz", hash = "sha256:14d920b48472ea0dbf68e45b96cd1ffda4705f33307dcc86c676c1b5104838a6", size = 1515232, upload-time = "2025-06-02T17:36:30.03Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/2f/de/afa024cbe022b1b318a3d224125aa24939e99b4ff6f22e0ba639a2eaee47/pytest-8.4.0-py3-none-any.whl", hash = "sha256:f40f825768ad76c0977cbacdf1fd37c6f7a468e460ea6a0636078f8972d4517e", size = 363797, upload-time = "2025-06-02T17:36:27.859Z" }, -] - -[[package]] -name = "pytest-aiohttp" -version = "1.1.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "aiohttp" }, - { name = "pytest" }, - { name = "pytest-asyncio" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/72/4b/d326890c153f2c4ce1bf45d07683c08c10a1766058a22934620bc6ac6592/pytest_aiohttp-1.1.0.tar.gz", hash = "sha256:147de8cb164f3fc9d7196967f109ab3c0b93ea3463ab50631e56438eab7b5adc", size = 12842, upload-time = "2025-01-23T12:44:04.465Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/ba/0f/e6af71c02e0f1098eaf7d2dbf3ffdf0a69fc1e0ef174f96af05cef161f1b/pytest_aiohttp-1.1.0-py3-none-any.whl", hash = "sha256:f39a11693a0dce08dd6c542d241e199dd8047a6e6596b2bcfa60d373f143456d", size = 8932, upload-time = "2025-01-23T12:44:03.27Z" }, -] - -[[package]] -name = "pytest-asyncio" -version = "1.0.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "pytest" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/d0/d4/14f53324cb1a6381bef29d698987625d80052bb33932d8e7cbf9b337b17c/pytest_asyncio-1.0.0.tar.gz", hash = "sha256:d15463d13f4456e1ead2594520216b225a16f781e144f8fdf6c5bb4667c48b3f", size = 46960, upload-time = "2025-05-26T04:54:40.484Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/30/05/ce271016e351fddc8399e546f6e23761967ee09c8c568bbfbecb0c150171/pytest_asyncio-1.0.0-py3-none-any.whl", hash = "sha256:4f024da9f1ef945e680dc68610b52550e36590a67fd31bb3b4943979a1f90ef3", size = 15976, upload-time = "2025-05-26T04:54:39.035Z" }, -] - -[[package]] -name = "pytest-mock" -version = "3.14.1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "pytest" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/71/28/67172c96ba684058a4d24ffe144d64783d2a270d0af0d9e792737bddc75c/pytest_mock-3.14.1.tar.gz", hash = "sha256:159e9edac4c451ce77a5cdb9fc5d1100708d2dd4ba3c3df572f14097351af80e", size = 33241, upload-time = "2025-05-26T13:58:45.167Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/b2/05/77b60e520511c53d1c1ca75f1930c7dd8e971d0c4379b7f4b3f9644685ba/pytest_mock-3.14.1-py3-none-any.whl", hash = "sha256:178aefcd11307d874b4cd3100344e7e2d888d9791a6a1d9bfe90fbc1b74fd1d0", size = 9923, upload-time = "2025-05-26T13:58:43.487Z" }, -] - -[[package]] -name = "pytest-xdist" -version = "3.7.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "execnet" }, - { name = "pytest" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/49/dc/865845cfe987b21658e871d16e0a24e871e00884c545f246dd8f6f69edda/pytest_xdist-3.7.0.tar.gz", hash = "sha256:f9248c99a7c15b7d2f90715df93610353a485827bc06eefb6566d23f6400f126", size = 87550, upload-time = "2025-05-26T21:18:20.251Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/0d/b2/0e802fde6f1c5b2f7ae7e9ad42b83fd4ecebac18a8a8c2f2f14e39dce6e1/pytest_xdist-3.7.0-py3-none-any.whl", hash = "sha256:7d3fbd255998265052435eb9daa4e99b62e6fb9cfb6efd1f858d4d8c0c7f0ca0", size = 46142, upload-time = "2025-05-26T21:18:18.759Z" }, -] - -[[package]] -name = "python-dateutil" -version = "2.9.0.post0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "six" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/66/c0/0c8b6ad9f17a802ee498c46e004a0eb49bc148f2fd230864601a86dcf6db/python-dateutil-2.9.0.post0.tar.gz", hash = "sha256:37dd54208da7e1cd875388217d5e00ebd4179249f90fb72437e91a35459a0ad3", size = 342432, upload-time = "2024-03-01T18:36:20.211Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/ec/57/56b9bcc3c9c6a792fcbaf139543cee77261f3651ca9da0c93f5c1221264b/python_dateutil-2.9.0.post0-py2.py3-none-any.whl", hash = "sha256:a8b2bc7bffae282281c8140a97d3aa9c14da0b136dfe83f850eea9a5f7470427", size = 229892, upload-time = "2024-03-01T18:36:18.57Z" }, -] - -[[package]] -name = "python-dotenv" -version = "1.1.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/88/2c/7bb1416c5620485aa793f2de31d3df393d3686aa8a8506d11e10e13c5baf/python_dotenv-1.1.0.tar.gz", hash = "sha256:41f90bc6f5f177fb41f53e87666db362025010eb28f60a01c9143bfa33a2b2d5", size = 39920, upload-time = "2025-03-25T10:14:56.835Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/1e/18/98a99ad95133c6a6e2005fe89faedf294a748bd5dc803008059409ac9b1e/python_dotenv-1.1.0-py3-none-any.whl", hash = "sha256:d7c01d9e2293916c18baf562d95698754b0dbbb5e74d457c45d4f6561fb9d55d", size = 20256, upload-time = "2025-03-25T10:14:55.034Z" }, -] - -[[package]] -name = "pytorch-lightning" -version = "2.3.3" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -dependencies = [ - { name = "fsspec", extra = ["http"], marker = "(platform_machine != 'aarch64' and sys_platform == 'linux') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "lightning-utilities", marker = "(platform_machine != 'aarch64' and sys_platform == 'linux') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (python_full_version >= '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (python_full_version >= '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (python_full_version >= '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32') or (python_full_version >= '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (python_full_version >= '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (python_full_version >= '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (python_full_version >= '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version >= '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (python_full_version < '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (python_full_version < '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (python_full_version < '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32') or (python_full_version < '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (python_full_version < '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (python_full_version < '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (python_full_version < '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "packaging", marker = "(platform_machine != 'aarch64' and sys_platform == 'linux') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "pyyaml", marker = "(platform_machine != 'aarch64' and sys_platform == 'linux') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.0.1", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchmetrics", marker = "(platform_machine != 'aarch64' and sys_platform == 'linux') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "tqdm", marker = "(platform_machine != 'aarch64' and sys_platform == 'linux') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "typing-extensions", marker = "(platform_machine != 'aarch64' and sys_platform == 'linux') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/e6/af/d20939d82145b36406e59a1f07ce2f7fe7bd191926636dc80f19b9a11c2c/pytorch-lightning-2.3.3.tar.gz", hash = "sha256:5f974015425af6873b5689246c5495ca12686b446751479273c154b73aeea843", size = 622981, upload-time = "2024-07-08T20:48:01.383Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/cf/1c/6122684e93864c09cf8010e27ad82b3b2f4864bd6864a40cb9e040752277/pytorch_lightning-2.3.3-py3-none-any.whl", hash = "sha256:4365e3f2874e223e63cb42628d24c88c2bdc8d1794453cac38c0619b31115fba", size = 812270, upload-time = "2024-07-08T20:47:55.216Z" }, -] - -[[package]] -name = "pytorch-lightning" -version = "2.5.1.post0" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", -] -dependencies = [ - { name = "fsspec", extra = ["http"], marker = "(platform_machine == 'aarch64' and sys_platform == 'linux') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or sys_platform == 'Linux' or sys_platform == 'darwin' or sys_platform == 'win32' or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "lightning-utilities", marker = "(platform_machine == 'aarch64' and sys_platform == 'linux') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or sys_platform == 'Linux' or sys_platform == 'darwin' or sys_platform == 'win32' or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "packaging", marker = "(platform_machine == 'aarch64' and sys_platform == 'linux') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or sys_platform == 'Linux' or sys_platform == 'darwin' or sys_platform == 'win32' or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "pyyaml", marker = "(platform_machine == 'aarch64' and sys_platform == 'linux') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or sys_platform == 'Linux' or sys_platform == 'darwin' or sys_platform == 'win32' or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchmetrics", marker = "(platform_machine == 'aarch64' and sys_platform == 'linux') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or sys_platform == 'Linux' or sys_platform == 'darwin' or sys_platform == 'win32' or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "tqdm", marker = "(platform_machine == 'aarch64' and sys_platform == 'linux') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or sys_platform == 'Linux' or sys_platform == 'darwin' or sys_platform == 'win32' or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "typing-extensions", marker = "(platform_machine == 'aarch64' and sys_platform == 'linux') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or sys_platform == 'Linux' or sys_platform == 'darwin' or sys_platform == 'win32' or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/fe/0c/cfa6223c525f67ea3a7a2907e36e9e9a9653300f82cfd9af88f8136514ab/pytorch_lightning-2.5.1.post0.tar.gz", hash = "sha256:abc3d5a804d41f941b14e3fd7db5572a1270cd1e9889b50e962984c87d498d94", size = 634368, upload-time = "2025-04-25T20:24:29.272Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/de/a9/e14821cfaf08e8d78185cca0477c9d3a62bafe1b4b530100f7b66bb1f7bb/pytorch_lightning-2.5.1.post0-py3-none-any.whl", hash = "sha256:873fb21392c8b79908218f5ca8f65bd835439216e52550c36ff55d849e99c93e", size = 823084, upload-time = "2025-04-25T20:24:27.421Z" }, -] - -[[package]] -name = "pytorch-triton-rocm" -version = "2.1.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "cmake" }, - { name = "filelock" }, - { name = "lit" }, - { name = "torch", version = "2.0.1", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/d6/7e/fd050a6a36146b19e29e311d34631447eff15d15d6101e3425bc7caa276e/pytorch_triton_rocm-2.1.0-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:774af3d74561490dad4b7d4668bb1054b1e9237b192cc1c1407c7eb5cef17d42", size = 169392593, upload-time = "2023-04-19T04:07:23.483Z" }, - { url = "https://files.pythonhosted.org/packages/e3/d5/1f5e65837de23ec950c1fed25821fcac097d769876ed031234260e9c70eb/pytorch_triton_rocm-2.1.0-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:ec63623c16eebe356d40460a09374a2546591dd2b0cb2122622111fc4d0f7f25", size = 169397352, upload-time = "2023-04-19T04:07:36.005Z" }, -] - -[[package]] -name = "pywin32" -version = "310" -source = { registry = "https://pypi.org/simple" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/95/da/a5f38fffbba2fb99aa4aa905480ac4b8e83ca486659ac8c95bce47fb5276/pywin32-310-cp310-cp310-win32.whl", hash = "sha256:6dd97011efc8bf51d6793a82292419eba2c71cf8e7250cfac03bba284454abc1", size = 8848240, upload-time = "2025-03-17T00:55:46.783Z" }, - { url = "https://files.pythonhosted.org/packages/aa/fe/d873a773324fa565619ba555a82c9dabd677301720f3660a731a5d07e49a/pywin32-310-cp310-cp310-win_amd64.whl", hash = "sha256:c3e78706e4229b915a0821941a84e7ef420bf2b77e08c9dae3c76fd03fd2ae3d", size = 9601854, upload-time = "2025-03-17T00:55:48.783Z" }, - { url = "https://files.pythonhosted.org/packages/3c/84/1a8e3d7a15490d28a5d816efa229ecb4999cdc51a7c30dd8914f669093b8/pywin32-310-cp310-cp310-win_arm64.whl", hash = "sha256:33babed0cf0c92a6f94cc6cc13546ab24ee13e3e800e61ed87609ab91e4c8213", size = 8522963, upload-time = "2025-03-17T00:55:50.969Z" }, - { url = "https://files.pythonhosted.org/packages/f7/b1/68aa2986129fb1011dabbe95f0136f44509afaf072b12b8f815905a39f33/pywin32-310-cp311-cp311-win32.whl", hash = "sha256:1e765f9564e83011a63321bb9d27ec456a0ed90d3732c4b2e312b855365ed8bd", size = 8784284, upload-time = "2025-03-17T00:55:53.124Z" }, - { url = "https://files.pythonhosted.org/packages/b3/bd/d1592635992dd8db5bb8ace0551bc3a769de1ac8850200cfa517e72739fb/pywin32-310-cp311-cp311-win_amd64.whl", hash = "sha256:126298077a9d7c95c53823934f000599f66ec9296b09167810eb24875f32689c", size = 9520748, upload-time = "2025-03-17T00:55:55.203Z" }, - { url = "https://files.pythonhosted.org/packages/90/b1/ac8b1ffce6603849eb45a91cf126c0fa5431f186c2e768bf56889c46f51c/pywin32-310-cp311-cp311-win_arm64.whl", hash = "sha256:19ec5fc9b1d51c4350be7bb00760ffce46e6c95eaf2f0b2f1150657b1a43c582", size = 8455941, upload-time = "2025-03-17T00:55:57.048Z" }, - { url = "https://files.pythonhosted.org/packages/6b/ec/4fdbe47932f671d6e348474ea35ed94227fb5df56a7c30cbbb42cd396ed0/pywin32-310-cp312-cp312-win32.whl", hash = "sha256:8a75a5cc3893e83a108c05d82198880704c44bbaee4d06e442e471d3c9ea4f3d", size = 8796239, upload-time = "2025-03-17T00:55:58.807Z" }, - { url = "https://files.pythonhosted.org/packages/e3/e5/b0627f8bb84e06991bea89ad8153a9e50ace40b2e1195d68e9dff6b03d0f/pywin32-310-cp312-cp312-win_amd64.whl", hash = "sha256:bf5c397c9a9a19a6f62f3fb821fbf36cac08f03770056711f765ec1503972060", size = 9503839, upload-time = "2025-03-17T00:56:00.8Z" }, - { url = "https://files.pythonhosted.org/packages/1f/32/9ccf53748df72301a89713936645a664ec001abd35ecc8578beda593d37d/pywin32-310-cp312-cp312-win_arm64.whl", hash = "sha256:2349cc906eae872d0663d4d6290d13b90621eaf78964bb1578632ff20e152966", size = 8459470, upload-time = "2025-03-17T00:56:02.601Z" }, - { url = "https://files.pythonhosted.org/packages/1c/09/9c1b978ffc4ae53999e89c19c77ba882d9fce476729f23ef55211ea1c034/pywin32-310-cp313-cp313-win32.whl", hash = "sha256:5d241a659c496ada3253cd01cfaa779b048e90ce4b2b38cd44168ad555ce74ab", size = 8794384, upload-time = "2025-03-17T00:56:04.383Z" }, - { url = "https://files.pythonhosted.org/packages/45/3c/b4640f740ffebadd5d34df35fecba0e1cfef8fde9f3e594df91c28ad9b50/pywin32-310-cp313-cp313-win_amd64.whl", hash = "sha256:667827eb3a90208ddbdcc9e860c81bde63a135710e21e4cb3348968e4bd5249e", size = 9503039, upload-time = "2025-03-17T00:56:06.207Z" }, - { url = "https://files.pythonhosted.org/packages/b4/f4/f785020090fb050e7fb6d34b780f2231f302609dc964672f72bfaeb59a28/pywin32-310-cp313-cp313-win_arm64.whl", hash = "sha256:e308f831de771482b7cf692a1f308f8fca701b2d8f9dde6cc440c7da17e47b33", size = 8458152, upload-time = "2025-03-17T00:56:07.819Z" }, -] - -[[package]] -name = "pywin32-ctypes" -version = "0.2.3" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/85/9f/01a1a99704853cb63f253eea009390c88e7131c67e66a0a02099a8c917cb/pywin32-ctypes-0.2.3.tar.gz", hash = "sha256:d162dc04946d704503b2edc4d55f3dba5c1d539ead017afa00142c38b9885755", size = 29471, upload-time = "2024-08-14T10:15:34.626Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/de/3d/8161f7711c017e01ac9f008dfddd9410dff3674334c233bde66e7ba65bbf/pywin32_ctypes-0.2.3-py3-none-any.whl", hash = "sha256:8a1513379d709975552d202d942d9837758905c8d01eb82b8bcc30918929e7b8", size = 30756, upload-time = "2024-08-14T10:15:33.187Z" }, -] - -[[package]] -name = "pyyaml" -version = "6.0.2" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/54/ed/79a089b6be93607fa5cdaedf301d7dfb23af5f25c398d5ead2525b063e17/pyyaml-6.0.2.tar.gz", hash = "sha256:d584d9ec91ad65861cc08d42e834324ef890a082e591037abe114850ff7bbc3e", size = 130631, upload-time = "2024-08-06T20:33:50.674Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/9b/95/a3fac87cb7158e231b5a6012e438c647e1a87f09f8e0d123acec8ab8bf71/PyYAML-6.0.2-cp310-cp310-macosx_10_9_x86_64.whl", hash = "sha256:0a9a2848a5b7feac301353437eb7d5957887edbf81d56e903999a75a3d743086", size = 184199, upload-time = "2024-08-06T20:31:40.178Z" }, - { url = "https://files.pythonhosted.org/packages/c7/7a/68bd47624dab8fd4afbfd3c48e3b79efe09098ae941de5b58abcbadff5cb/PyYAML-6.0.2-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:29717114e51c84ddfba879543fb232a6ed60086602313ca38cce623c1d62cfbf", size = 171758, upload-time = "2024-08-06T20:31:42.173Z" }, - { url = "https://files.pythonhosted.org/packages/49/ee/14c54df452143b9ee9f0f29074d7ca5516a36edb0b4cc40c3f280131656f/PyYAML-6.0.2-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:8824b5a04a04a047e72eea5cec3bc266db09e35de6bdfe34c9436ac5ee27d237", size = 718463, upload-time = "2024-08-06T20:31:44.263Z" }, - { url = "https://files.pythonhosted.org/packages/4d/61/de363a97476e766574650d742205be468921a7b532aa2499fcd886b62530/PyYAML-6.0.2-cp310-cp310-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:7c36280e6fb8385e520936c3cb3b8042851904eba0e58d277dca80a5cfed590b", size = 719280, upload-time = "2024-08-06T20:31:50.199Z" }, - { url = "https://files.pythonhosted.org/packages/6b/4e/1523cb902fd98355e2e9ea5e5eb237cbc5f3ad5f3075fa65087aa0ecb669/PyYAML-6.0.2-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:ec031d5d2feb36d1d1a24380e4db6d43695f3748343d99434e6f5f9156aaa2ed", size = 751239, upload-time = "2024-08-06T20:31:52.292Z" }, - { url = "https://files.pythonhosted.org/packages/b7/33/5504b3a9a4464893c32f118a9cc045190a91637b119a9c881da1cf6b7a72/PyYAML-6.0.2-cp310-cp310-musllinux_1_1_aarch64.whl", hash = "sha256:936d68689298c36b53b29f23c6dbb74de12b4ac12ca6cfe0e047bedceea56180", size = 695802, upload-time = "2024-08-06T20:31:53.836Z" }, - { url = "https://files.pythonhosted.org/packages/5c/20/8347dcabd41ef3a3cdc4f7b7a2aff3d06598c8779faa189cdbf878b626a4/PyYAML-6.0.2-cp310-cp310-musllinux_1_1_x86_64.whl", hash = "sha256:23502f431948090f597378482b4812b0caae32c22213aecf3b55325e049a6c68", size = 720527, upload-time = "2024-08-06T20:31:55.565Z" }, - { url = "https://files.pythonhosted.org/packages/be/aa/5afe99233fb360d0ff37377145a949ae258aaab831bde4792b32650a4378/PyYAML-6.0.2-cp310-cp310-win32.whl", hash = "sha256:2e99c6826ffa974fe6e27cdb5ed0021786b03fc98e5ee3c5bfe1fd5015f42b99", size = 144052, upload-time = "2024-08-06T20:31:56.914Z" }, - { url = "https://files.pythonhosted.org/packages/b5/84/0fa4b06f6d6c958d207620fc60005e241ecedceee58931bb20138e1e5776/PyYAML-6.0.2-cp310-cp310-win_amd64.whl", hash = "sha256:a4d3091415f010369ae4ed1fc6b79def9416358877534caf6a0fdd2146c87a3e", size = 161774, upload-time = "2024-08-06T20:31:58.304Z" }, - { url = "https://files.pythonhosted.org/packages/f8/aa/7af4e81f7acba21a4c6be026da38fd2b872ca46226673c89a758ebdc4fd2/PyYAML-6.0.2-cp311-cp311-macosx_10_9_x86_64.whl", hash = "sha256:cc1c1159b3d456576af7a3e4d1ba7e6924cb39de8f67111c735f6fc832082774", size = 184612, upload-time = "2024-08-06T20:32:03.408Z" }, - { url = "https://files.pythonhosted.org/packages/8b/62/b9faa998fd185f65c1371643678e4d58254add437edb764a08c5a98fb986/PyYAML-6.0.2-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:1e2120ef853f59c7419231f3bf4e7021f1b936f6ebd222406c3b60212205d2ee", size = 172040, upload-time = "2024-08-06T20:32:04.926Z" }, - { url = "https://files.pythonhosted.org/packages/ad/0c/c804f5f922a9a6563bab712d8dcc70251e8af811fce4524d57c2c0fd49a4/PyYAML-6.0.2-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:5d225db5a45f21e78dd9358e58a98702a0302f2659a3c6cd320564b75b86f47c", size = 736829, upload-time = "2024-08-06T20:32:06.459Z" }, - { url = "https://files.pythonhosted.org/packages/51/16/6af8d6a6b210c8e54f1406a6b9481febf9c64a3109c541567e35a49aa2e7/PyYAML-6.0.2-cp311-cp311-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:5ac9328ec4831237bec75defaf839f7d4564be1e6b25ac710bd1a96321cc8317", size = 764167, upload-time = "2024-08-06T20:32:08.338Z" }, - { url = "https://files.pythonhosted.org/packages/75/e4/2c27590dfc9992f73aabbeb9241ae20220bd9452df27483b6e56d3975cc5/PyYAML-6.0.2-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:3ad2a3decf9aaba3d29c8f537ac4b243e36bef957511b4766cb0057d32b0be85", size = 762952, upload-time = "2024-08-06T20:32:14.124Z" }, - { url = "https://files.pythonhosted.org/packages/9b/97/ecc1abf4a823f5ac61941a9c00fe501b02ac3ab0e373c3857f7d4b83e2b6/PyYAML-6.0.2-cp311-cp311-musllinux_1_1_aarch64.whl", hash = "sha256:ff3824dc5261f50c9b0dfb3be22b4567a6f938ccce4587b38952d85fd9e9afe4", size = 735301, upload-time = "2024-08-06T20:32:16.17Z" }, - { url = "https://files.pythonhosted.org/packages/45/73/0f49dacd6e82c9430e46f4a027baa4ca205e8b0a9dce1397f44edc23559d/PyYAML-6.0.2-cp311-cp311-musllinux_1_1_x86_64.whl", hash = "sha256:797b4f722ffa07cc8d62053e4cff1486fa6dc094105d13fea7b1de7d8bf71c9e", size = 756638, upload-time = "2024-08-06T20:32:18.555Z" }, - { url = "https://files.pythonhosted.org/packages/22/5f/956f0f9fc65223a58fbc14459bf34b4cc48dec52e00535c79b8db361aabd/PyYAML-6.0.2-cp311-cp311-win32.whl", hash = "sha256:11d8f3dd2b9c1207dcaf2ee0bbbfd5991f571186ec9cc78427ba5bd32afae4b5", size = 143850, upload-time = "2024-08-06T20:32:19.889Z" }, - { url = "https://files.pythonhosted.org/packages/ed/23/8da0bbe2ab9dcdd11f4f4557ccaf95c10b9811b13ecced089d43ce59c3c8/PyYAML-6.0.2-cp311-cp311-win_amd64.whl", hash = "sha256:e10ce637b18caea04431ce14fabcf5c64a1c61ec9c56b071a4b7ca131ca52d44", size = 161980, upload-time = "2024-08-06T20:32:21.273Z" }, - { url = "https://files.pythonhosted.org/packages/86/0c/c581167fc46d6d6d7ddcfb8c843a4de25bdd27e4466938109ca68492292c/PyYAML-6.0.2-cp312-cp312-macosx_10_9_x86_64.whl", hash = "sha256:c70c95198c015b85feafc136515252a261a84561b7b1d51e3384e0655ddf25ab", size = 183873, upload-time = "2024-08-06T20:32:25.131Z" }, - { url = "https://files.pythonhosted.org/packages/a8/0c/38374f5bb272c051e2a69281d71cba6fdb983413e6758b84482905e29a5d/PyYAML-6.0.2-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:ce826d6ef20b1bc864f0a68340c8b3287705cae2f8b4b1d932177dcc76721725", size = 173302, upload-time = "2024-08-06T20:32:26.511Z" }, - { url = "https://files.pythonhosted.org/packages/c3/93/9916574aa8c00aa06bbac729972eb1071d002b8e158bd0e83a3b9a20a1f7/PyYAML-6.0.2-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:1f71ea527786de97d1a0cc0eacd1defc0985dcf6b3f17bb77dcfc8c34bec4dc5", size = 739154, upload-time = "2024-08-06T20:32:28.363Z" }, - { url = "https://files.pythonhosted.org/packages/95/0f/b8938f1cbd09739c6da569d172531567dbcc9789e0029aa070856f123984/PyYAML-6.0.2-cp312-cp312-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:9b22676e8097e9e22e36d6b7bda33190d0d400f345f23d4065d48f4ca7ae0425", size = 766223, upload-time = "2024-08-06T20:32:30.058Z" }, - { url = "https://files.pythonhosted.org/packages/b9/2b/614b4752f2e127db5cc206abc23a8c19678e92b23c3db30fc86ab731d3bd/PyYAML-6.0.2-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:80bab7bfc629882493af4aa31a4cfa43a4c57c83813253626916b8c7ada83476", size = 767542, upload-time = "2024-08-06T20:32:31.881Z" }, - { url = "https://files.pythonhosted.org/packages/d4/00/dd137d5bcc7efea1836d6264f049359861cf548469d18da90cd8216cf05f/PyYAML-6.0.2-cp312-cp312-musllinux_1_1_aarch64.whl", hash = "sha256:0833f8694549e586547b576dcfaba4a6b55b9e96098b36cdc7ebefe667dfed48", size = 731164, upload-time = "2024-08-06T20:32:37.083Z" }, - { url = "https://files.pythonhosted.org/packages/c9/1f/4f998c900485e5c0ef43838363ba4a9723ac0ad73a9dc42068b12aaba4e4/PyYAML-6.0.2-cp312-cp312-musllinux_1_1_x86_64.whl", hash = "sha256:8b9c7197f7cb2738065c481a0461e50ad02f18c78cd75775628afb4d7137fb3b", size = 756611, upload-time = "2024-08-06T20:32:38.898Z" }, - { url = "https://files.pythonhosted.org/packages/df/d1/f5a275fdb252768b7a11ec63585bc38d0e87c9e05668a139fea92b80634c/PyYAML-6.0.2-cp312-cp312-win32.whl", hash = "sha256:ef6107725bd54b262d6dedcc2af448a266975032bc85ef0172c5f059da6325b4", size = 140591, upload-time = "2024-08-06T20:32:40.241Z" }, - { url = "https://files.pythonhosted.org/packages/0c/e8/4f648c598b17c3d06e8753d7d13d57542b30d56e6c2dedf9c331ae56312e/PyYAML-6.0.2-cp312-cp312-win_amd64.whl", hash = "sha256:7e7401d0de89a9a855c839bc697c079a4af81cf878373abd7dc625847d25cbd8", size = 156338, upload-time = "2024-08-06T20:32:41.93Z" }, - { url = "https://files.pythonhosted.org/packages/ef/e3/3af305b830494fa85d95f6d95ef7fa73f2ee1cc8ef5b495c7c3269fb835f/PyYAML-6.0.2-cp313-cp313-macosx_10_13_x86_64.whl", hash = "sha256:efdca5630322a10774e8e98e1af481aad470dd62c3170801852d752aa7a783ba", size = 181309, upload-time = "2024-08-06T20:32:43.4Z" }, - { url = "https://files.pythonhosted.org/packages/45/9f/3b1c20a0b7a3200524eb0076cc027a970d320bd3a6592873c85c92a08731/PyYAML-6.0.2-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:50187695423ffe49e2deacb8cd10510bc361faac997de9efef88badc3bb9e2d1", size = 171679, upload-time = "2024-08-06T20:32:44.801Z" }, - { url = "https://files.pythonhosted.org/packages/7c/9a/337322f27005c33bcb656c655fa78325b730324c78620e8328ae28b64d0c/PyYAML-6.0.2-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:0ffe8360bab4910ef1b9e87fb812d8bc0a308b0d0eef8c8f44e0254ab3b07133", size = 733428, upload-time = "2024-08-06T20:32:46.432Z" }, - { url = "https://files.pythonhosted.org/packages/a3/69/864fbe19e6c18ea3cc196cbe5d392175b4cf3d5d0ac1403ec3f2d237ebb5/PyYAML-6.0.2-cp313-cp313-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:17e311b6c678207928d649faa7cb0d7b4c26a0ba73d41e99c4fff6b6c3276484", size = 763361, upload-time = "2024-08-06T20:32:51.188Z" }, - { url = "https://files.pythonhosted.org/packages/04/24/b7721e4845c2f162d26f50521b825fb061bc0a5afcf9a386840f23ea19fa/PyYAML-6.0.2-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:70b189594dbe54f75ab3a1acec5f1e3faa7e8cf2f1e08d9b561cb41b845f69d5", size = 759523, upload-time = "2024-08-06T20:32:53.019Z" }, - { url = "https://files.pythonhosted.org/packages/2b/b2/e3234f59ba06559c6ff63c4e10baea10e5e7df868092bf9ab40e5b9c56b6/PyYAML-6.0.2-cp313-cp313-musllinux_1_1_aarch64.whl", hash = "sha256:41e4e3953a79407c794916fa277a82531dd93aad34e29c2a514c2c0c5fe971cc", size = 726660, upload-time = "2024-08-06T20:32:54.708Z" }, - { url = "https://files.pythonhosted.org/packages/fe/0f/25911a9f080464c59fab9027482f822b86bf0608957a5fcc6eaac85aa515/PyYAML-6.0.2-cp313-cp313-musllinux_1_1_x86_64.whl", hash = "sha256:68ccc6023a3400877818152ad9a1033e3db8625d899c72eacb5a668902e4d652", size = 751597, upload-time = "2024-08-06T20:32:56.985Z" }, - { url = "https://files.pythonhosted.org/packages/14/0d/e2c3b43bbce3cf6bd97c840b46088a3031085179e596d4929729d8d68270/PyYAML-6.0.2-cp313-cp313-win32.whl", hash = "sha256:bc2fa7c6b47d6bc618dd7fb02ef6fdedb1090ec036abab80d4681424b84c1183", size = 140527, upload-time = "2024-08-06T20:33:03.001Z" }, - { url = "https://files.pythonhosted.org/packages/fa/de/02b54f42487e3d3c6efb3f89428677074ca7bf43aae402517bc7cca949f3/PyYAML-6.0.2-cp313-cp313-win_amd64.whl", hash = "sha256:8388ee1976c416731879ac16da0aff3f63b286ffdd57cdeb95f3f2e085687563", size = 156446, upload-time = "2024-08-06T20:33:04.33Z" }, -] - -[[package]] -name = "referencing" -version = "0.36.2" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "attrs" }, - { name = "rpds-py" }, - { name = "typing-extensions", marker = "python_full_version < '3.13' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/2f/db/98b5c277be99dd18bfd91dd04e1b759cad18d1a338188c936e92f921c7e2/referencing-0.36.2.tar.gz", hash = "sha256:df2e89862cd09deabbdba16944cc3f10feb6b3e6f18e902f7cc25609a34775aa", size = 74744, upload-time = "2025-01-25T08:48:16.138Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/c1/b1/3baf80dc6d2b7bc27a95a67752d0208e410351e3feb4eb78de5f77454d8d/referencing-0.36.2-py3-none-any.whl", hash = "sha256:e8699adbbf8b5c7de96d8ffa0eb5c158b3beafce084968e2ea8bb08c6794dcd0", size = 26775, upload-time = "2025-01-25T08:48:14.241Z" }, -] - -[[package]] -name = "regex" -version = "2024.11.6" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/8e/5f/bd69653fbfb76cf8604468d3b4ec4c403197144c7bfe0e6a5fc9e02a07cb/regex-2024.11.6.tar.gz", hash = "sha256:7ab159b063c52a0333c884e4679f8d7a85112ee3078fe3d9004b2dd875585519", size = 399494, upload-time = "2024-11-06T20:12:31.635Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/95/3c/4651f6b130c6842a8f3df82461a8950f923925db8b6961063e82744bddcc/regex-2024.11.6-cp310-cp310-macosx_10_9_universal2.whl", hash = "sha256:ff590880083d60acc0433f9c3f713c51f7ac6ebb9adf889c79a261ecf541aa91", size = 482674, upload-time = "2024-11-06T20:08:57.575Z" }, - { url = "https://files.pythonhosted.org/packages/15/51/9f35d12da8434b489c7b7bffc205c474a0a9432a889457026e9bc06a297a/regex-2024.11.6-cp310-cp310-macosx_10_9_x86_64.whl", hash = "sha256:658f90550f38270639e83ce492f27d2c8d2cd63805c65a13a14d36ca126753f0", size = 287684, upload-time = "2024-11-06T20:08:59.787Z" }, - { url = "https://files.pythonhosted.org/packages/bd/18/b731f5510d1b8fb63c6b6d3484bfa9a59b84cc578ac8b5172970e05ae07c/regex-2024.11.6-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:164d8b7b3b4bcb2068b97428060b2a53be050085ef94eca7f240e7947f1b080e", size = 284589, upload-time = "2024-11-06T20:09:01.896Z" }, - { url = "https://files.pythonhosted.org/packages/78/a2/6dd36e16341ab95e4c6073426561b9bfdeb1a9c9b63ab1b579c2e96cb105/regex-2024.11.6-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:d3660c82f209655a06b587d55e723f0b813d3a7db2e32e5e7dc64ac2a9e86fde", size = 782511, upload-time = "2024-11-06T20:09:04.062Z" }, - { url = "https://files.pythonhosted.org/packages/1b/2b/323e72d5d2fd8de0d9baa443e1ed70363ed7e7b2fb526f5950c5cb99c364/regex-2024.11.6-cp310-cp310-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:d22326fcdef5e08c154280b71163ced384b428343ae16a5ab2b3354aed12436e", size = 821149, upload-time = "2024-11-06T20:09:06.237Z" }, - { url = "https://files.pythonhosted.org/packages/90/30/63373b9ea468fbef8a907fd273e5c329b8c9535fee36fc8dba5fecac475d/regex-2024.11.6-cp310-cp310-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:f1ac758ef6aebfc8943560194e9fd0fa18bcb34d89fd8bd2af18183afd8da3a2", size = 809707, upload-time = "2024-11-06T20:09:07.715Z" }, - { url = "https://files.pythonhosted.org/packages/f2/98/26d3830875b53071f1f0ae6d547f1d98e964dd29ad35cbf94439120bb67a/regex-2024.11.6-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:997d6a487ff00807ba810e0f8332c18b4eb8d29463cfb7c820dc4b6e7562d0cf", size = 781702, upload-time = "2024-11-06T20:09:10.101Z" }, - { url = "https://files.pythonhosted.org/packages/87/55/eb2a068334274db86208ab9d5599ffa63631b9f0f67ed70ea7c82a69bbc8/regex-2024.11.6-cp310-cp310-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:02a02d2bb04fec86ad61f3ea7f49c015a0681bf76abb9857f945d26159d2968c", size = 771976, upload-time = "2024-11-06T20:09:11.566Z" }, - { url = "https://files.pythonhosted.org/packages/74/c0/be707bcfe98254d8f9d2cff55d216e946f4ea48ad2fd8cf1428f8c5332ba/regex-2024.11.6-cp310-cp310-manylinux_2_5_x86_64.manylinux1_x86_64.manylinux_2_12_x86_64.manylinux2010_x86_64.whl", hash = "sha256:f02f93b92358ee3f78660e43b4b0091229260c5d5c408d17d60bf26b6c900e86", size = 697397, upload-time = "2024-11-06T20:09:13.119Z" }, - { url = "https://files.pythonhosted.org/packages/49/dc/bb45572ceb49e0f6509f7596e4ba7031f6819ecb26bc7610979af5a77f45/regex-2024.11.6-cp310-cp310-musllinux_1_2_aarch64.whl", hash = "sha256:06eb1be98df10e81ebaded73fcd51989dcf534e3c753466e4b60c4697a003b67", size = 768726, upload-time = "2024-11-06T20:09:14.85Z" }, - { url = "https://files.pythonhosted.org/packages/5a/db/f43fd75dc4c0c2d96d0881967897926942e935d700863666f3c844a72ce6/regex-2024.11.6-cp310-cp310-musllinux_1_2_i686.whl", hash = "sha256:040df6fe1a5504eb0f04f048e6d09cd7c7110fef851d7c567a6b6e09942feb7d", size = 775098, upload-time = "2024-11-06T20:09:16.504Z" }, - { url = "https://files.pythonhosted.org/packages/99/d7/f94154db29ab5a89d69ff893159b19ada89e76b915c1293e98603d39838c/regex-2024.11.6-cp310-cp310-musllinux_1_2_ppc64le.whl", hash = "sha256:fdabbfc59f2c6edba2a6622c647b716e34e8e3867e0ab975412c5c2f79b82da2", size = 839325, upload-time = "2024-11-06T20:09:18.698Z" }, - { url = "https://files.pythonhosted.org/packages/f7/17/3cbfab1f23356fbbf07708220ab438a7efa1e0f34195bf857433f79f1788/regex-2024.11.6-cp310-cp310-musllinux_1_2_s390x.whl", hash = "sha256:8447d2d39b5abe381419319f942de20b7ecd60ce86f16a23b0698f22e1b70008", size = 843277, upload-time = "2024-11-06T20:09:21.725Z" }, - { url = "https://files.pythonhosted.org/packages/7e/f2/48b393b51900456155de3ad001900f94298965e1cad1c772b87f9cfea011/regex-2024.11.6-cp310-cp310-musllinux_1_2_x86_64.whl", hash = "sha256:da8f5fc57d1933de22a9e23eec290a0d8a5927a5370d24bda9a6abe50683fe62", size = 773197, upload-time = "2024-11-06T20:09:24.092Z" }, - { url = "https://files.pythonhosted.org/packages/45/3f/ef9589aba93e084cd3f8471fded352826dcae8489b650d0b9b27bc5bba8a/regex-2024.11.6-cp310-cp310-win32.whl", hash = "sha256:b489578720afb782f6ccf2840920f3a32e31ba28a4b162e13900c3e6bd3f930e", size = 261714, upload-time = "2024-11-06T20:09:26.36Z" }, - { url = "https://files.pythonhosted.org/packages/42/7e/5f1b92c8468290c465fd50c5318da64319133231415a8aa6ea5ab995a815/regex-2024.11.6-cp310-cp310-win_amd64.whl", hash = "sha256:5071b2093e793357c9d8b2929dfc13ac5f0a6c650559503bb81189d0a3814519", size = 274042, upload-time = "2024-11-06T20:09:28.762Z" }, - { url = "https://files.pythonhosted.org/packages/58/58/7e4d9493a66c88a7da6d205768119f51af0f684fe7be7bac8328e217a52c/regex-2024.11.6-cp311-cp311-macosx_10_9_universal2.whl", hash = "sha256:5478c6962ad548b54a591778e93cd7c456a7a29f8eca9c49e4f9a806dcc5d638", size = 482669, upload-time = "2024-11-06T20:09:31.064Z" }, - { url = "https://files.pythonhosted.org/packages/34/4c/8f8e631fcdc2ff978609eaeef1d6994bf2f028b59d9ac67640ed051f1218/regex-2024.11.6-cp311-cp311-macosx_10_9_x86_64.whl", hash = "sha256:2c89a8cc122b25ce6945f0423dc1352cb9593c68abd19223eebbd4e56612c5b7", size = 287684, upload-time = "2024-11-06T20:09:32.915Z" }, - { url = "https://files.pythonhosted.org/packages/c5/1b/f0e4d13e6adf866ce9b069e191f303a30ab1277e037037a365c3aad5cc9c/regex-2024.11.6-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:94d87b689cdd831934fa3ce16cc15cd65748e6d689f5d2b8f4f4df2065c9fa20", size = 284589, upload-time = "2024-11-06T20:09:35.504Z" }, - { url = "https://files.pythonhosted.org/packages/25/4d/ab21047f446693887f25510887e6820b93f791992994f6498b0318904d4a/regex-2024.11.6-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:1062b39a0a2b75a9c694f7a08e7183a80c63c0d62b301418ffd9c35f55aaa114", size = 792121, upload-time = "2024-11-06T20:09:37.701Z" }, - { url = "https://files.pythonhosted.org/packages/45/ee/c867e15cd894985cb32b731d89576c41a4642a57850c162490ea34b78c3b/regex-2024.11.6-cp311-cp311-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:167ed4852351d8a750da48712c3930b031f6efdaa0f22fa1933716bfcd6bf4a3", size = 831275, upload-time = "2024-11-06T20:09:40.371Z" }, - { url = "https://files.pythonhosted.org/packages/b3/12/b0f480726cf1c60f6536fa5e1c95275a77624f3ac8fdccf79e6727499e28/regex-2024.11.6-cp311-cp311-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:2d548dafee61f06ebdb584080621f3e0c23fff312f0de1afc776e2a2ba99a74f", size = 818257, upload-time = "2024-11-06T20:09:43.059Z" }, - { url = "https://files.pythonhosted.org/packages/bf/ce/0d0e61429f603bac433910d99ef1a02ce45a8967ffbe3cbee48599e62d88/regex-2024.11.6-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:f2a19f302cd1ce5dd01a9099aaa19cae6173306d1302a43b627f62e21cf18ac0", size = 792727, upload-time = "2024-11-06T20:09:48.19Z" }, - { url = "https://files.pythonhosted.org/packages/e4/c1/243c83c53d4a419c1556f43777ccb552bccdf79d08fda3980e4e77dd9137/regex-2024.11.6-cp311-cp311-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:bec9931dfb61ddd8ef2ebc05646293812cb6b16b60cf7c9511a832b6f1854b55", size = 780667, upload-time = "2024-11-06T20:09:49.828Z" }, - { url = "https://files.pythonhosted.org/packages/c5/f4/75eb0dd4ce4b37f04928987f1d22547ddaf6c4bae697623c1b05da67a8aa/regex-2024.11.6-cp311-cp311-musllinux_1_2_aarch64.whl", hash = "sha256:9714398225f299aa85267fd222f7142fcb5c769e73d7733344efc46f2ef5cf89", size = 776963, upload-time = "2024-11-06T20:09:51.819Z" }, - { url = "https://files.pythonhosted.org/packages/16/5d/95c568574e630e141a69ff8a254c2f188b4398e813c40d49228c9bbd9875/regex-2024.11.6-cp311-cp311-musllinux_1_2_i686.whl", hash = "sha256:202eb32e89f60fc147a41e55cb086db2a3f8cb82f9a9a88440dcfc5d37faae8d", size = 784700, upload-time = "2024-11-06T20:09:53.982Z" }, - { url = "https://files.pythonhosted.org/packages/8e/b5/f8495c7917f15cc6fee1e7f395e324ec3e00ab3c665a7dc9d27562fd5290/regex-2024.11.6-cp311-cp311-musllinux_1_2_ppc64le.whl", hash = "sha256:4181b814e56078e9b00427ca358ec44333765f5ca1b45597ec7446d3a1ef6e34", size = 848592, upload-time = "2024-11-06T20:09:56.222Z" }, - { url = "https://files.pythonhosted.org/packages/1c/80/6dd7118e8cb212c3c60b191b932dc57db93fb2e36fb9e0e92f72a5909af9/regex-2024.11.6-cp311-cp311-musllinux_1_2_s390x.whl", hash = "sha256:068376da5a7e4da51968ce4c122a7cd31afaaec4fccc7856c92f63876e57b51d", size = 852929, upload-time = "2024-11-06T20:09:58.642Z" }, - { url = "https://files.pythonhosted.org/packages/11/9b/5a05d2040297d2d254baf95eeeb6df83554e5e1df03bc1a6687fc4ba1f66/regex-2024.11.6-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:ac10f2c4184420d881a3475fb2c6f4d95d53a8d50209a2500723d831036f7c45", size = 781213, upload-time = "2024-11-06T20:10:00.867Z" }, - { url = "https://files.pythonhosted.org/packages/26/b7/b14e2440156ab39e0177506c08c18accaf2b8932e39fb092074de733d868/regex-2024.11.6-cp311-cp311-win32.whl", hash = "sha256:c36f9b6f5f8649bb251a5f3f66564438977b7ef8386a52460ae77e6070d309d9", size = 261734, upload-time = "2024-11-06T20:10:03.361Z" }, - { url = "https://files.pythonhosted.org/packages/80/32/763a6cc01d21fb3819227a1cc3f60fd251c13c37c27a73b8ff4315433a8e/regex-2024.11.6-cp311-cp311-win_amd64.whl", hash = "sha256:02e28184be537f0e75c1f9b2f8847dc51e08e6e171c6bde130b2687e0c33cf60", size = 274052, upload-time = "2024-11-06T20:10:05.179Z" }, - { url = "https://files.pythonhosted.org/packages/ba/30/9a87ce8336b172cc232a0db89a3af97929d06c11ceaa19d97d84fa90a8f8/regex-2024.11.6-cp312-cp312-macosx_10_13_universal2.whl", hash = "sha256:52fb28f528778f184f870b7cf8f225f5eef0a8f6e3778529bdd40c7b3920796a", size = 483781, upload-time = "2024-11-06T20:10:07.07Z" }, - { url = "https://files.pythonhosted.org/packages/01/e8/00008ad4ff4be8b1844786ba6636035f7ef926db5686e4c0f98093612add/regex-2024.11.6-cp312-cp312-macosx_10_13_x86_64.whl", hash = "sha256:fdd6028445d2460f33136c55eeb1f601ab06d74cb3347132e1c24250187500d9", size = 288455, upload-time = "2024-11-06T20:10:09.117Z" }, - { url = "https://files.pythonhosted.org/packages/60/85/cebcc0aff603ea0a201667b203f13ba75d9fc8668fab917ac5b2de3967bc/regex-2024.11.6-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:805e6b60c54bf766b251e94526ebad60b7de0c70f70a4e6210ee2891acb70bf2", size = 284759, upload-time = "2024-11-06T20:10:11.155Z" }, - { url = "https://files.pythonhosted.org/packages/94/2b/701a4b0585cb05472a4da28ee28fdfe155f3638f5e1ec92306d924e5faf0/regex-2024.11.6-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:b85c2530be953a890eaffde05485238f07029600e8f098cdf1848d414a8b45e4", size = 794976, upload-time = "2024-11-06T20:10:13.24Z" }, - { url = "https://files.pythonhosted.org/packages/4b/bf/fa87e563bf5fee75db8915f7352e1887b1249126a1be4813837f5dbec965/regex-2024.11.6-cp312-cp312-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:bb26437975da7dc36b7efad18aa9dd4ea569d2357ae6b783bf1118dabd9ea577", size = 833077, upload-time = "2024-11-06T20:10:15.37Z" }, - { url = "https://files.pythonhosted.org/packages/a1/56/7295e6bad94b047f4d0834e4779491b81216583c00c288252ef625c01d23/regex-2024.11.6-cp312-cp312-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:abfa5080c374a76a251ba60683242bc17eeb2c9818d0d30117b4486be10c59d3", size = 823160, upload-time = "2024-11-06T20:10:19.027Z" }, - { url = "https://files.pythonhosted.org/packages/fb/13/e3b075031a738c9598c51cfbc4c7879e26729c53aa9cca59211c44235314/regex-2024.11.6-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:70b7fa6606c2881c1db9479b0eaa11ed5dfa11c8d60a474ff0e095099f39d98e", size = 796896, upload-time = "2024-11-06T20:10:21.85Z" }, - { url = "https://files.pythonhosted.org/packages/24/56/0b3f1b66d592be6efec23a795b37732682520b47c53da5a32c33ed7d84e3/regex-2024.11.6-cp312-cp312-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:0c32f75920cf99fe6b6c539c399a4a128452eaf1af27f39bce8909c9a3fd8cbe", size = 783997, upload-time = "2024-11-06T20:10:24.329Z" }, - { url = "https://files.pythonhosted.org/packages/f9/a1/eb378dada8b91c0e4c5f08ffb56f25fcae47bf52ad18f9b2f33b83e6d498/regex-2024.11.6-cp312-cp312-musllinux_1_2_aarch64.whl", hash = "sha256:982e6d21414e78e1f51cf595d7f321dcd14de1f2881c5dc6a6e23bbbbd68435e", size = 781725, upload-time = "2024-11-06T20:10:28.067Z" }, - { url = "https://files.pythonhosted.org/packages/83/f2/033e7dec0cfd6dda93390089864732a3409246ffe8b042e9554afa9bff4e/regex-2024.11.6-cp312-cp312-musllinux_1_2_i686.whl", hash = "sha256:a7c2155f790e2fb448faed6dd241386719802296ec588a8b9051c1f5c481bc29", size = 789481, upload-time = "2024-11-06T20:10:31.612Z" }, - { url = "https://files.pythonhosted.org/packages/83/23/15d4552ea28990a74e7696780c438aadd73a20318c47e527b47a4a5a596d/regex-2024.11.6-cp312-cp312-musllinux_1_2_ppc64le.whl", hash = "sha256:149f5008d286636e48cd0b1dd65018548944e495b0265b45e1bffecce1ef7f39", size = 852896, upload-time = "2024-11-06T20:10:34.054Z" }, - { url = "https://files.pythonhosted.org/packages/e3/39/ed4416bc90deedbfdada2568b2cb0bc1fdb98efe11f5378d9892b2a88f8f/regex-2024.11.6-cp312-cp312-musllinux_1_2_s390x.whl", hash = "sha256:e5364a4502efca094731680e80009632ad6624084aff9a23ce8c8c6820de3e51", size = 860138, upload-time = "2024-11-06T20:10:36.142Z" }, - { url = "https://files.pythonhosted.org/packages/93/2d/dd56bb76bd8e95bbce684326302f287455b56242a4f9c61f1bc76e28360e/regex-2024.11.6-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:0a86e7eeca091c09e021db8eb72d54751e527fa47b8d5787caf96d9831bd02ad", size = 787692, upload-time = "2024-11-06T20:10:38.394Z" }, - { url = "https://files.pythonhosted.org/packages/0b/55/31877a249ab7a5156758246b9c59539abbeba22461b7d8adc9e8475ff73e/regex-2024.11.6-cp312-cp312-win32.whl", hash = "sha256:32f9a4c643baad4efa81d549c2aadefaeba12249b2adc5af541759237eee1c54", size = 262135, upload-time = "2024-11-06T20:10:40.367Z" }, - { url = "https://files.pythonhosted.org/packages/38/ec/ad2d7de49a600cdb8dd78434a1aeffe28b9d6fc42eb36afab4a27ad23384/regex-2024.11.6-cp312-cp312-win_amd64.whl", hash = "sha256:a93c194e2df18f7d264092dc8539b8ffb86b45b899ab976aa15d48214138e81b", size = 273567, upload-time = "2024-11-06T20:10:43.467Z" }, - { url = "https://files.pythonhosted.org/packages/90/73/bcb0e36614601016552fa9344544a3a2ae1809dc1401b100eab02e772e1f/regex-2024.11.6-cp313-cp313-macosx_10_13_universal2.whl", hash = "sha256:a6ba92c0bcdf96cbf43a12c717eae4bc98325ca3730f6b130ffa2e3c3c723d84", size = 483525, upload-time = "2024-11-06T20:10:45.19Z" }, - { url = "https://files.pythonhosted.org/packages/0f/3f/f1a082a46b31e25291d830b369b6b0c5576a6f7fb89d3053a354c24b8a83/regex-2024.11.6-cp313-cp313-macosx_10_13_x86_64.whl", hash = "sha256:525eab0b789891ac3be914d36893bdf972d483fe66551f79d3e27146191a37d4", size = 288324, upload-time = "2024-11-06T20:10:47.177Z" }, - { url = "https://files.pythonhosted.org/packages/09/c9/4e68181a4a652fb3ef5099e077faf4fd2a694ea6e0f806a7737aff9e758a/regex-2024.11.6-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:086a27a0b4ca227941700e0b31425e7a28ef1ae8e5e05a33826e17e47fbfdba0", size = 284617, upload-time = "2024-11-06T20:10:49.312Z" }, - { url = "https://files.pythonhosted.org/packages/fc/fd/37868b75eaf63843165f1d2122ca6cb94bfc0271e4428cf58c0616786dce/regex-2024.11.6-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:bde01f35767c4a7899b7eb6e823b125a64de314a8ee9791367c9a34d56af18d0", size = 795023, upload-time = "2024-11-06T20:10:51.102Z" }, - { url = "https://files.pythonhosted.org/packages/c4/7c/d4cd9c528502a3dedb5c13c146e7a7a539a3853dc20209c8e75d9ba9d1b2/regex-2024.11.6-cp313-cp313-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:b583904576650166b3d920d2bcce13971f6f9e9a396c673187f49811b2769dc7", size = 833072, upload-time = "2024-11-06T20:10:52.926Z" }, - { url = "https://files.pythonhosted.org/packages/4f/db/46f563a08f969159c5a0f0e722260568425363bea43bb7ae370becb66a67/regex-2024.11.6-cp313-cp313-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:1c4de13f06a0d54fa0d5ab1b7138bfa0d883220965a29616e3ea61b35d5f5fc7", size = 823130, upload-time = "2024-11-06T20:10:54.828Z" }, - { url = "https://files.pythonhosted.org/packages/db/60/1eeca2074f5b87df394fccaa432ae3fc06c9c9bfa97c5051aed70e6e00c2/regex-2024.11.6-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:3cde6e9f2580eb1665965ce9bf17ff4952f34f5b126beb509fee8f4e994f143c", size = 796857, upload-time = "2024-11-06T20:10:56.634Z" }, - { url = "https://files.pythonhosted.org/packages/10/db/ac718a08fcee981554d2f7bb8402f1faa7e868c1345c16ab1ebec54b0d7b/regex-2024.11.6-cp313-cp313-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:0d7f453dca13f40a02b79636a339c5b62b670141e63efd511d3f8f73fba162b3", size = 784006, upload-time = "2024-11-06T20:10:59.369Z" }, - { url = "https://files.pythonhosted.org/packages/c2/41/7da3fe70216cea93144bf12da2b87367590bcf07db97604edeea55dac9ad/regex-2024.11.6-cp313-cp313-musllinux_1_2_aarch64.whl", hash = "sha256:59dfe1ed21aea057a65c6b586afd2a945de04fc7db3de0a6e3ed5397ad491b07", size = 781650, upload-time = "2024-11-06T20:11:02.042Z" }, - { url = "https://files.pythonhosted.org/packages/a7/d5/880921ee4eec393a4752e6ab9f0fe28009435417c3102fc413f3fe81c4e5/regex-2024.11.6-cp313-cp313-musllinux_1_2_i686.whl", hash = "sha256:b97c1e0bd37c5cd7902e65f410779d39eeda155800b65fc4d04cc432efa9bc6e", size = 789545, upload-time = "2024-11-06T20:11:03.933Z" }, - { url = "https://files.pythonhosted.org/packages/dc/96/53770115e507081122beca8899ab7f5ae28ae790bfcc82b5e38976df6a77/regex-2024.11.6-cp313-cp313-musllinux_1_2_ppc64le.whl", hash = "sha256:f9d1e379028e0fc2ae3654bac3cbbef81bf3fd571272a42d56c24007979bafb6", size = 853045, upload-time = "2024-11-06T20:11:06.497Z" }, - { url = "https://files.pythonhosted.org/packages/31/d3/1372add5251cc2d44b451bd94f43b2ec78e15a6e82bff6a290ef9fd8f00a/regex-2024.11.6-cp313-cp313-musllinux_1_2_s390x.whl", hash = "sha256:13291b39131e2d002a7940fb176e120bec5145f3aeb7621be6534e46251912c4", size = 860182, upload-time = "2024-11-06T20:11:09.06Z" }, - { url = "https://files.pythonhosted.org/packages/ed/e3/c446a64984ea9f69982ba1a69d4658d5014bc7a0ea468a07e1a1265db6e2/regex-2024.11.6-cp313-cp313-musllinux_1_2_x86_64.whl", hash = "sha256:4f51f88c126370dcec4908576c5a627220da6c09d0bff31cfa89f2523843316d", size = 787733, upload-time = "2024-11-06T20:11:11.256Z" }, - { url = "https://files.pythonhosted.org/packages/2b/f1/e40c8373e3480e4f29f2692bd21b3e05f296d3afebc7e5dcf21b9756ca1c/regex-2024.11.6-cp313-cp313-win32.whl", hash = "sha256:63b13cfd72e9601125027202cad74995ab26921d8cd935c25f09c630436348ff", size = 262122, upload-time = "2024-11-06T20:11:13.161Z" }, - { url = "https://files.pythonhosted.org/packages/45/94/bc295babb3062a731f52621cdc992d123111282e291abaf23faa413443ea/regex-2024.11.6-cp313-cp313-win_amd64.whl", hash = "sha256:2b3361af3198667e99927da8b84c1b010752fa4b1115ee30beaa332cabc3ef1a", size = 273545, upload-time = "2024-11-06T20:11:15Z" }, -] - -[[package]] -name = "requests" -version = "2.32.4" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "certifi" }, - { name = "charset-normalizer" }, - { name = "idna" }, - { name = "urllib3" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/e1/0a/929373653770d8a0d7ea76c37de6e41f11eb07559b103b1c02cafb3f7cf8/requests-2.32.4.tar.gz", hash = "sha256:27d0316682c8a29834d3264820024b62a36942083d52caf2f14c0591336d3422", size = 135258, upload-time = "2025-06-09T16:43:07.34Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/7c/e4/56027c4a6b4ae70ca9de302488c5ca95ad4a39e190093d6c1a8ace08341b/requests-2.32.4-py3-none-any.whl", hash = "sha256:27babd3cda2a6d50b30443204ee89830707d396671944c998b5975b031ac2b2c", size = 64847, upload-time = "2025-06-09T16:43:05.728Z" }, -] - -[[package]] -name = "resize-right" -version = "0.0.2" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/f3/43/8d1bb734c6cd1c6424c8612d405f9bbfa87392751522d28b7daa3509c42b/resize-right-0.0.2.tar.gz", hash = "sha256:7dc35b72ce4012b77f7cc9049835163793ab98a58ab8893610fb119fe59af520", size = 11669, upload-time = "2022-05-05T02:17:03.113Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/1d/08/c5c0640a08d7b373f1175c536462862054ee32145dae457c89916cd568d2/resize_right-0.0.2-py3-none-any.whl", hash = "sha256:78351ca3eda0872208fcbc90861b45de559f90fb4027ce41825fdeb9b995005c", size = 8911, upload-time = "2022-05-05T02:17:01.788Z" }, -] - -[[package]] -name = "rich" -version = "14.0.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "markdown-it-py" }, - { name = "pygments" }, - { name = "typing-extensions", marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/a1/53/830aa4c3066a8ab0ae9a9955976fb770fe9c6102117c8ec4ab3ea62d89e8/rich-14.0.0.tar.gz", hash = "sha256:82f1bc23a6a21ebca4ae0c45af9bdbc492ed20231dcb63f297d6d1021a9d5725", size = 224078, upload-time = "2025-03-30T14:15:14.23Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/0d/9b/63f4c7ebc259242c89b3acafdb37b41d1185c07ff0011164674e9076b491/rich-14.0.0-py3-none-any.whl", hash = "sha256:1c9491e1951aac09caffd42f448ee3d04e58923ffe14993f6e83068dc395d7e0", size = 243229, upload-time = "2025-03-30T14:15:12.283Z" }, -] - -[[package]] -name = "rpds-py" -version = "0.25.1" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/8c/a6/60184b7fc00dd3ca80ac635dd5b8577d444c57e8e8742cecabfacb829921/rpds_py-0.25.1.tar.gz", hash = "sha256:8960b6dac09b62dac26e75d7e2c4a22efb835d827a7278c34f72b2b84fa160e3", size = 27304, upload-time = "2025-05-21T12:46:12.502Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/cb/09/e1158988e50905b7f8306487a576b52d32aa9a87f79f7ab24ee8db8b6c05/rpds_py-0.25.1-cp310-cp310-macosx_10_12_x86_64.whl", hash = "sha256:f4ad628b5174d5315761b67f212774a32f5bad5e61396d38108bd801c0a8f5d9", size = 373140, upload-time = "2025-05-21T12:42:38.834Z" }, - { url = "https://files.pythonhosted.org/packages/e0/4b/a284321fb3c45c02fc74187171504702b2934bfe16abab89713eedfe672e/rpds_py-0.25.1-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:8c742af695f7525e559c16f1562cf2323db0e3f0fbdcabdf6865b095256b2d40", size = 358860, upload-time = "2025-05-21T12:42:41.394Z" }, - { url = "https://files.pythonhosted.org/packages/4e/46/8ac9811150c75edeae9fc6fa0e70376c19bc80f8e1f7716981433905912b/rpds_py-0.25.1-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:605ffe7769e24b1800b4d024d24034405d9404f0bc2f55b6db3362cd34145a6f", size = 386179, upload-time = "2025-05-21T12:42:43.213Z" }, - { url = "https://files.pythonhosted.org/packages/f3/ec/87eb42d83e859bce91dcf763eb9f2ab117142a49c9c3d17285440edb5b69/rpds_py-0.25.1-cp310-cp310-manylinux_2_17_armv7l.manylinux2014_armv7l.whl", hash = "sha256:ccc6f3ddef93243538be76f8e47045b4aad7a66a212cd3a0f23e34469473d36b", size = 400282, upload-time = "2025-05-21T12:42:44.92Z" }, - { url = "https://files.pythonhosted.org/packages/68/c8/2a38e0707d7919c8c78e1d582ab15cf1255b380bcb086ca265b73ed6db23/rpds_py-0.25.1-cp310-cp310-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:f70316f760174ca04492b5ab01be631a8ae30cadab1d1081035136ba12738cfa", size = 521824, upload-time = "2025-05-21T12:42:46.856Z" }, - { url = "https://files.pythonhosted.org/packages/5e/2c/6a92790243569784dde84d144bfd12bd45102f4a1c897d76375076d730ab/rpds_py-0.25.1-cp310-cp310-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:e1dafef8df605fdb46edcc0bf1573dea0d6d7b01ba87f85cd04dc855b2b4479e", size = 411644, upload-time = "2025-05-21T12:42:48.838Z" }, - { url = "https://files.pythonhosted.org/packages/eb/76/66b523ffc84cf47db56efe13ae7cf368dee2bacdec9d89b9baca5e2e6301/rpds_py-0.25.1-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:0701942049095741a8aeb298a31b203e735d1c61f4423511d2b1a41dcd8a16da", size = 386955, upload-time = "2025-05-21T12:42:50.835Z" }, - { url = "https://files.pythonhosted.org/packages/b6/b9/a362d7522feaa24dc2b79847c6175daa1c642817f4a19dcd5c91d3e2c316/rpds_py-0.25.1-cp310-cp310-manylinux_2_5_i686.manylinux1_i686.whl", hash = "sha256:e87798852ae0b37c88babb7f7bbbb3e3fecc562a1c340195b44c7e24d403e380", size = 421039, upload-time = "2025-05-21T12:42:52.348Z" }, - { url = "https://files.pythonhosted.org/packages/0f/c4/b5b6f70b4d719b6584716889fd3413102acf9729540ee76708d56a76fa97/rpds_py-0.25.1-cp310-cp310-musllinux_1_2_aarch64.whl", hash = "sha256:3bcce0edc1488906c2d4c75c94c70a0417e83920dd4c88fec1078c94843a6ce9", size = 563290, upload-time = "2025-05-21T12:42:54.404Z" }, - { url = "https://files.pythonhosted.org/packages/87/a3/2e6e816615c12a8f8662c9d8583a12eb54c52557521ef218cbe3095a8afa/rpds_py-0.25.1-cp310-cp310-musllinux_1_2_i686.whl", hash = "sha256:e2f6a2347d3440ae789505693a02836383426249d5293541cd712e07e7aecf54", size = 592089, upload-time = "2025-05-21T12:42:55.976Z" }, - { url = "https://files.pythonhosted.org/packages/c0/08/9b8e1050e36ce266135994e2c7ec06e1841f1c64da739daeb8afe9cb77a4/rpds_py-0.25.1-cp310-cp310-musllinux_1_2_x86_64.whl", hash = "sha256:4fd52d3455a0aa997734f3835cbc4c9f32571345143960e7d7ebfe7b5fbfa3b2", size = 558400, upload-time = "2025-05-21T12:42:58.032Z" }, - { url = "https://files.pythonhosted.org/packages/f2/df/b40b8215560b8584baccd839ff5c1056f3c57120d79ac41bd26df196da7e/rpds_py-0.25.1-cp310-cp310-win32.whl", hash = "sha256:3f0b1798cae2bbbc9b9db44ee068c556d4737911ad53a4e5093d09d04b3bbc24", size = 219741, upload-time = "2025-05-21T12:42:59.479Z" }, - { url = "https://files.pythonhosted.org/packages/10/99/e4c58be18cf5d8b40b8acb4122bc895486230b08f978831b16a3916bd24d/rpds_py-0.25.1-cp310-cp310-win_amd64.whl", hash = "sha256:3ebd879ab996537fc510a2be58c59915b5dd63bccb06d1ef514fee787e05984a", size = 231553, upload-time = "2025-05-21T12:43:01.425Z" }, - { url = "https://files.pythonhosted.org/packages/95/e1/df13fe3ddbbea43567e07437f097863b20c99318ae1f58a0fe389f763738/rpds_py-0.25.1-cp311-cp311-macosx_10_12_x86_64.whl", hash = "sha256:5f048bbf18b1f9120685c6d6bb70cc1a52c8cc11bdd04e643d28d3be0baf666d", size = 373341, upload-time = "2025-05-21T12:43:02.978Z" }, - { url = "https://files.pythonhosted.org/packages/7a/58/deef4d30fcbcbfef3b6d82d17c64490d5c94585a2310544ce8e2d3024f83/rpds_py-0.25.1-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:4fbb0dbba559959fcb5d0735a0f87cdbca9e95dac87982e9b95c0f8f7ad10255", size = 359111, upload-time = "2025-05-21T12:43:05.128Z" }, - { url = "https://files.pythonhosted.org/packages/bb/7e/39f1f4431b03e96ebaf159e29a0f82a77259d8f38b2dd474721eb3a8ac9b/rpds_py-0.25.1-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:d4ca54b9cf9d80b4016a67a0193ebe0bcf29f6b0a96f09db942087e294d3d4c2", size = 386112, upload-time = "2025-05-21T12:43:07.13Z" }, - { url = "https://files.pythonhosted.org/packages/db/e7/847068a48d63aec2ae695a1646089620b3b03f8ccf9f02c122ebaf778f3c/rpds_py-0.25.1-cp311-cp311-manylinux_2_17_armv7l.manylinux2014_armv7l.whl", hash = "sha256:1ee3e26eb83d39b886d2cb6e06ea701bba82ef30a0de044d34626ede51ec98b0", size = 400362, upload-time = "2025-05-21T12:43:08.693Z" }, - { url = "https://files.pythonhosted.org/packages/3b/3d/9441d5db4343d0cee759a7ab4d67420a476cebb032081763de934719727b/rpds_py-0.25.1-cp311-cp311-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:89706d0683c73a26f76a5315d893c051324d771196ae8b13e6ffa1ffaf5e574f", size = 522214, upload-time = "2025-05-21T12:43:10.694Z" }, - { url = "https://files.pythonhosted.org/packages/a2/ec/2cc5b30d95f9f1a432c79c7a2f65d85e52812a8f6cbf8768724571710786/rpds_py-0.25.1-cp311-cp311-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:c2013ee878c76269c7b557a9a9c042335d732e89d482606990b70a839635feb7", size = 411491, upload-time = "2025-05-21T12:43:12.739Z" }, - { url = "https://files.pythonhosted.org/packages/dc/6c/44695c1f035077a017dd472b6a3253553780837af2fac9b6ac25f6a5cb4d/rpds_py-0.25.1-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:45e484db65e5380804afbec784522de84fa95e6bb92ef1bd3325d33d13efaebd", size = 386978, upload-time = "2025-05-21T12:43:14.25Z" }, - { url = "https://files.pythonhosted.org/packages/b1/74/b4357090bb1096db5392157b4e7ed8bb2417dc7799200fcbaee633a032c9/rpds_py-0.25.1-cp311-cp311-manylinux_2_5_i686.manylinux1_i686.whl", hash = "sha256:48d64155d02127c249695abb87d39f0faf410733428d499867606be138161d65", size = 420662, upload-time = "2025-05-21T12:43:15.8Z" }, - { url = "https://files.pythonhosted.org/packages/26/dd/8cadbebf47b96e59dfe8b35868e5c38a42272699324e95ed522da09d3a40/rpds_py-0.25.1-cp311-cp311-musllinux_1_2_aarch64.whl", hash = "sha256:048893e902132fd6548a2e661fb38bf4896a89eea95ac5816cf443524a85556f", size = 563385, upload-time = "2025-05-21T12:43:17.78Z" }, - { url = "https://files.pythonhosted.org/packages/c3/ea/92960bb7f0e7a57a5ab233662f12152085c7dc0d5468534c65991a3d48c9/rpds_py-0.25.1-cp311-cp311-musllinux_1_2_i686.whl", hash = "sha256:0317177b1e8691ab5879f4f33f4b6dc55ad3b344399e23df2e499de7b10a548d", size = 592047, upload-time = "2025-05-21T12:43:19.457Z" }, - { url = "https://files.pythonhosted.org/packages/61/ad/71aabc93df0d05dabcb4b0c749277881f8e74548582d96aa1bf24379493a/rpds_py-0.25.1-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:bffcf57826d77a4151962bf1701374e0fc87f536e56ec46f1abdd6a903354042", size = 557863, upload-time = "2025-05-21T12:43:21.69Z" }, - { url = "https://files.pythonhosted.org/packages/93/0f/89df0067c41f122b90b76f3660028a466eb287cbe38efec3ea70e637ca78/rpds_py-0.25.1-cp311-cp311-win32.whl", hash = "sha256:cda776f1967cb304816173b30994faaf2fd5bcb37e73118a47964a02c348e1bc", size = 219627, upload-time = "2025-05-21T12:43:23.311Z" }, - { url = "https://files.pythonhosted.org/packages/7c/8d/93b1a4c1baa903d0229374d9e7aa3466d751f1d65e268c52e6039c6e338e/rpds_py-0.25.1-cp311-cp311-win_amd64.whl", hash = "sha256:dc3c1ff0abc91444cd20ec643d0f805df9a3661fcacf9c95000329f3ddf268a4", size = 231603, upload-time = "2025-05-21T12:43:25.145Z" }, - { url = "https://files.pythonhosted.org/packages/cb/11/392605e5247bead2f23e6888e77229fbd714ac241ebbebb39a1e822c8815/rpds_py-0.25.1-cp311-cp311-win_arm64.whl", hash = "sha256:5a3ddb74b0985c4387719fc536faced33cadf2172769540c62e2a94b7b9be1c4", size = 223967, upload-time = "2025-05-21T12:43:26.566Z" }, - { url = "https://files.pythonhosted.org/packages/7f/81/28ab0408391b1dc57393653b6a0cf2014cc282cc2909e4615e63e58262be/rpds_py-0.25.1-cp312-cp312-macosx_10_12_x86_64.whl", hash = "sha256:b5ffe453cde61f73fea9430223c81d29e2fbf412a6073951102146c84e19e34c", size = 364647, upload-time = "2025-05-21T12:43:28.559Z" }, - { url = "https://files.pythonhosted.org/packages/2c/9a/7797f04cad0d5e56310e1238434f71fc6939d0bc517192a18bb99a72a95f/rpds_py-0.25.1-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:115874ae5e2fdcfc16b2aedc95b5eef4aebe91b28e7e21951eda8a5dc0d3461b", size = 350454, upload-time = "2025-05-21T12:43:30.615Z" }, - { url = "https://files.pythonhosted.org/packages/69/3c/93d2ef941b04898011e5d6eaa56a1acf46a3b4c9f4b3ad1bbcbafa0bee1f/rpds_py-0.25.1-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:a714bf6e5e81b0e570d01f56e0c89c6375101b8463999ead3a93a5d2a4af91fa", size = 389665, upload-time = "2025-05-21T12:43:32.629Z" }, - { url = "https://files.pythonhosted.org/packages/c1/57/ad0e31e928751dde8903a11102559628d24173428a0f85e25e187defb2c1/rpds_py-0.25.1-cp312-cp312-manylinux_2_17_armv7l.manylinux2014_armv7l.whl", hash = "sha256:35634369325906bcd01577da4c19e3b9541a15e99f31e91a02d010816b49bfda", size = 403873, upload-time = "2025-05-21T12:43:34.576Z" }, - { url = "https://files.pythonhosted.org/packages/16/ad/c0c652fa9bba778b4f54980a02962748479dc09632e1fd34e5282cf2556c/rpds_py-0.25.1-cp312-cp312-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:d4cb2b3ddc16710548801c6fcc0cfcdeeff9dafbc983f77265877793f2660309", size = 525866, upload-time = "2025-05-21T12:43:36.123Z" }, - { url = "https://files.pythonhosted.org/packages/2a/39/3e1839bc527e6fcf48d5fec4770070f872cdee6c6fbc9b259932f4e88a38/rpds_py-0.25.1-cp312-cp312-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:9ceca1cf097ed77e1a51f1dbc8d174d10cb5931c188a4505ff9f3e119dfe519b", size = 416886, upload-time = "2025-05-21T12:43:38.034Z" }, - { url = "https://files.pythonhosted.org/packages/7a/95/dd6b91cd4560da41df9d7030a038298a67d24f8ca38e150562644c829c48/rpds_py-0.25.1-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:2c2cd1a4b0c2b8c5e31ffff50d09f39906fe351389ba143c195566056c13a7ea", size = 390666, upload-time = "2025-05-21T12:43:40.065Z" }, - { url = "https://files.pythonhosted.org/packages/64/48/1be88a820e7494ce0a15c2d390ccb7c52212370badabf128e6a7bb4cb802/rpds_py-0.25.1-cp312-cp312-manylinux_2_5_i686.manylinux1_i686.whl", hash = "sha256:1de336a4b164c9188cb23f3703adb74a7623ab32d20090d0e9bf499a2203ad65", size = 425109, upload-time = "2025-05-21T12:43:42.263Z" }, - { url = "https://files.pythonhosted.org/packages/cf/07/3e2a17927ef6d7720b9949ec1b37d1e963b829ad0387f7af18d923d5cfa5/rpds_py-0.25.1-cp312-cp312-musllinux_1_2_aarch64.whl", hash = "sha256:9fca84a15333e925dd59ce01da0ffe2ffe0d6e5d29a9eeba2148916d1824948c", size = 567244, upload-time = "2025-05-21T12:43:43.846Z" }, - { url = "https://files.pythonhosted.org/packages/d2/e5/76cf010998deccc4f95305d827847e2eae9c568099c06b405cf96384762b/rpds_py-0.25.1-cp312-cp312-musllinux_1_2_i686.whl", hash = "sha256:88ec04afe0c59fa64e2f6ea0dd9657e04fc83e38de90f6de201954b4d4eb59bd", size = 596023, upload-time = "2025-05-21T12:43:45.932Z" }, - { url = "https://files.pythonhosted.org/packages/52/9a/df55efd84403736ba37a5a6377b70aad0fd1cb469a9109ee8a1e21299a1c/rpds_py-0.25.1-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:a8bd2f19e312ce3e1d2c635618e8a8d8132892bb746a7cf74780a489f0f6cdcb", size = 561634, upload-time = "2025-05-21T12:43:48.263Z" }, - { url = "https://files.pythonhosted.org/packages/ab/aa/dc3620dd8db84454aaf9374bd318f1aa02578bba5e567f5bf6b79492aca4/rpds_py-0.25.1-cp312-cp312-win32.whl", hash = "sha256:e5e2f7280d8d0d3ef06f3ec1b4fd598d386cc6f0721e54f09109a8132182fbfe", size = 222713, upload-time = "2025-05-21T12:43:49.897Z" }, - { url = "https://files.pythonhosted.org/packages/a3/7f/7cef485269a50ed5b4e9bae145f512d2a111ca638ae70cc101f661b4defd/rpds_py-0.25.1-cp312-cp312-win_amd64.whl", hash = "sha256:db58483f71c5db67d643857404da360dce3573031586034b7d59f245144cc192", size = 235280, upload-time = "2025-05-21T12:43:51.893Z" }, - { url = "https://files.pythonhosted.org/packages/99/f2/c2d64f6564f32af913bf5f3f7ae41c7c263c5ae4c4e8f1a17af8af66cd46/rpds_py-0.25.1-cp312-cp312-win_arm64.whl", hash = "sha256:6d50841c425d16faf3206ddbba44c21aa3310a0cebc3c1cdfc3e3f4f9f6f5728", size = 225399, upload-time = "2025-05-21T12:43:53.351Z" }, - { url = "https://files.pythonhosted.org/packages/2b/da/323848a2b62abe6a0fec16ebe199dc6889c5d0a332458da8985b2980dffe/rpds_py-0.25.1-cp313-cp313-macosx_10_12_x86_64.whl", hash = "sha256:659d87430a8c8c704d52d094f5ba6fa72ef13b4d385b7e542a08fc240cb4a559", size = 364498, upload-time = "2025-05-21T12:43:54.841Z" }, - { url = "https://files.pythonhosted.org/packages/1f/b4/4d3820f731c80fd0cd823b3e95b9963fec681ae45ba35b5281a42382c67d/rpds_py-0.25.1-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:68f6f060f0bbdfb0245267da014d3a6da9be127fe3e8cc4a68c6f833f8a23bb1", size = 350083, upload-time = "2025-05-21T12:43:56.428Z" }, - { url = "https://files.pythonhosted.org/packages/d5/b1/3a8ee1c9d480e8493619a437dec685d005f706b69253286f50f498cbdbcf/rpds_py-0.25.1-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:083a9513a33e0b92cf6e7a6366036c6bb43ea595332c1ab5c8ae329e4bcc0a9c", size = 389023, upload-time = "2025-05-21T12:43:57.995Z" }, - { url = "https://files.pythonhosted.org/packages/3b/31/17293edcfc934dc62c3bf74a0cb449ecd549531f956b72287203e6880b87/rpds_py-0.25.1-cp313-cp313-manylinux_2_17_armv7l.manylinux2014_armv7l.whl", hash = "sha256:816568614ecb22b18a010c7a12559c19f6fe993526af88e95a76d5a60b8b75fb", size = 403283, upload-time = "2025-05-21T12:43:59.546Z" }, - { url = "https://files.pythonhosted.org/packages/d1/ca/e0f0bc1a75a8925024f343258c8ecbd8828f8997ea2ac71e02f67b6f5299/rpds_py-0.25.1-cp313-cp313-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:3c6564c0947a7f52e4792983f8e6cf9bac140438ebf81f527a21d944f2fd0a40", size = 524634, upload-time = "2025-05-21T12:44:01.087Z" }, - { url = "https://files.pythonhosted.org/packages/3e/03/5d0be919037178fff33a6672ffc0afa04ea1cfcb61afd4119d1b5280ff0f/rpds_py-0.25.1-cp313-cp313-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:5c4a128527fe415d73cf1f70a9a688d06130d5810be69f3b553bf7b45e8acf79", size = 416233, upload-time = "2025-05-21T12:44:02.604Z" }, - { url = "https://files.pythonhosted.org/packages/05/7c/8abb70f9017a231c6c961a8941403ed6557664c0913e1bf413cbdc039e75/rpds_py-0.25.1-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:a49e1d7a4978ed554f095430b89ecc23f42014a50ac385eb0c4d163ce213c325", size = 390375, upload-time = "2025-05-21T12:44:04.162Z" }, - { url = "https://files.pythonhosted.org/packages/7a/ac/a87f339f0e066b9535074a9f403b9313fd3892d4a164d5d5f5875ac9f29f/rpds_py-0.25.1-cp313-cp313-manylinux_2_5_i686.manylinux1_i686.whl", hash = "sha256:d74ec9bc0e2feb81d3f16946b005748119c0f52a153f6db6a29e8cd68636f295", size = 424537, upload-time = "2025-05-21T12:44:06.175Z" }, - { url = "https://files.pythonhosted.org/packages/1f/8f/8d5c1567eaf8c8afe98a838dd24de5013ce6e8f53a01bd47fe8bb06b5533/rpds_py-0.25.1-cp313-cp313-musllinux_1_2_aarch64.whl", hash = "sha256:3af5b4cc10fa41e5bc64e5c198a1b2d2864337f8fcbb9a67e747e34002ce812b", size = 566425, upload-time = "2025-05-21T12:44:08.242Z" }, - { url = "https://files.pythonhosted.org/packages/95/33/03016a6be5663b389c8ab0bbbcca68d9e96af14faeff0a04affcb587e776/rpds_py-0.25.1-cp313-cp313-musllinux_1_2_i686.whl", hash = "sha256:79dc317a5f1c51fd9c6a0c4f48209c6b8526d0524a6904fc1076476e79b00f98", size = 595197, upload-time = "2025-05-21T12:44:10.449Z" }, - { url = "https://files.pythonhosted.org/packages/33/8d/da9f4d3e208c82fda311bff0cf0a19579afceb77cf456e46c559a1c075ba/rpds_py-0.25.1-cp313-cp313-musllinux_1_2_x86_64.whl", hash = "sha256:1521031351865e0181bc585147624d66b3b00a84109b57fcb7a779c3ec3772cd", size = 561244, upload-time = "2025-05-21T12:44:12.387Z" }, - { url = "https://files.pythonhosted.org/packages/e2/b3/39d5dcf7c5f742ecd6dbc88f6f84ae54184b92f5f387a4053be2107b17f1/rpds_py-0.25.1-cp313-cp313-win32.whl", hash = "sha256:5d473be2b13600b93a5675d78f59e63b51b1ba2d0476893415dfbb5477e65b31", size = 222254, upload-time = "2025-05-21T12:44:14.261Z" }, - { url = "https://files.pythonhosted.org/packages/5f/19/2d6772c8eeb8302c5f834e6d0dfd83935a884e7c5ce16340c7eaf89ce925/rpds_py-0.25.1-cp313-cp313-win_amd64.whl", hash = "sha256:a7b74e92a3b212390bdce1d93da9f6488c3878c1d434c5e751cbc202c5e09500", size = 234741, upload-time = "2025-05-21T12:44:16.236Z" }, - { url = "https://files.pythonhosted.org/packages/5b/5a/145ada26cfaf86018d0eb304fe55eafdd4f0b6b84530246bb4a7c4fb5c4b/rpds_py-0.25.1-cp313-cp313-win_arm64.whl", hash = "sha256:dd326a81afe332ede08eb39ab75b301d5676802cdffd3a8f287a5f0b694dc3f5", size = 224830, upload-time = "2025-05-21T12:44:17.749Z" }, - { url = "https://files.pythonhosted.org/packages/4b/ca/d435844829c384fd2c22754ff65889c5c556a675d2ed9eb0e148435c6690/rpds_py-0.25.1-cp313-cp313t-macosx_10_12_x86_64.whl", hash = "sha256:a58d1ed49a94d4183483a3ce0af22f20318d4a1434acee255d683ad90bf78129", size = 359668, upload-time = "2025-05-21T12:44:19.322Z" }, - { url = "https://files.pythonhosted.org/packages/1f/01/b056f21db3a09f89410d493d2f6614d87bb162499f98b649d1dbd2a81988/rpds_py-0.25.1-cp313-cp313t-macosx_11_0_arm64.whl", hash = "sha256:f251bf23deb8332823aef1da169d5d89fa84c89f67bdfb566c49dea1fccfd50d", size = 345649, upload-time = "2025-05-21T12:44:20.962Z" }, - { url = "https://files.pythonhosted.org/packages/e0/0f/e0d00dc991e3d40e03ca36383b44995126c36b3eafa0ccbbd19664709c88/rpds_py-0.25.1-cp313-cp313t-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:8dbd586bfa270c1103ece2109314dd423df1fa3d9719928b5d09e4840cec0d72", size = 384776, upload-time = "2025-05-21T12:44:22.516Z" }, - { url = "https://files.pythonhosted.org/packages/9f/a2/59374837f105f2ca79bde3c3cd1065b2f8c01678900924949f6392eab66d/rpds_py-0.25.1-cp313-cp313t-manylinux_2_17_armv7l.manylinux2014_armv7l.whl", hash = "sha256:6d273f136e912aa101a9274c3145dcbddbe4bac560e77e6d5b3c9f6e0ed06d34", size = 395131, upload-time = "2025-05-21T12:44:24.147Z" }, - { url = "https://files.pythonhosted.org/packages/9c/dc/48e8d84887627a0fe0bac53f0b4631e90976fd5d35fff8be66b8e4f3916b/rpds_py-0.25.1-cp313-cp313t-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:666fa7b1bd0a3810a7f18f6d3a25ccd8866291fbbc3c9b912b917a6715874bb9", size = 520942, upload-time = "2025-05-21T12:44:25.915Z" }, - { url = "https://files.pythonhosted.org/packages/7c/f5/ee056966aeae401913d37befeeab57a4a43a4f00099e0a20297f17b8f00c/rpds_py-0.25.1-cp313-cp313t-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:921954d7fbf3fccc7de8f717799304b14b6d9a45bbeec5a8d7408ccbf531faf5", size = 411330, upload-time = "2025-05-21T12:44:27.638Z" }, - { url = "https://files.pythonhosted.org/packages/ab/74/b2cffb46a097cefe5d17f94ede7a174184b9d158a0aeb195f39f2c0361e8/rpds_py-0.25.1-cp313-cp313t-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:f3d86373ff19ca0441ebeb696ef64cb58b8b5cbacffcda5a0ec2f3911732a194", size = 387339, upload-time = "2025-05-21T12:44:29.292Z" }, - { url = "https://files.pythonhosted.org/packages/7f/9a/0ff0b375dcb5161c2b7054e7d0b7575f1680127505945f5cabaac890bc07/rpds_py-0.25.1-cp313-cp313t-manylinux_2_5_i686.manylinux1_i686.whl", hash = "sha256:c8980cde3bb8575e7c956a530f2c217c1d6aac453474bf3ea0f9c89868b531b6", size = 418077, upload-time = "2025-05-21T12:44:30.877Z" }, - { url = "https://files.pythonhosted.org/packages/0d/a1/fda629bf20d6b698ae84c7c840cfb0e9e4200f664fc96e1f456f00e4ad6e/rpds_py-0.25.1-cp313-cp313t-musllinux_1_2_aarch64.whl", hash = "sha256:8eb8c84ecea987a2523e057c0d950bcb3f789696c0499290b8d7b3107a719d78", size = 562441, upload-time = "2025-05-21T12:44:32.541Z" }, - { url = "https://files.pythonhosted.org/packages/20/15/ce4b5257f654132f326f4acd87268e1006cc071e2c59794c5bdf4bebbb51/rpds_py-0.25.1-cp313-cp313t-musllinux_1_2_i686.whl", hash = "sha256:e43a005671a9ed5a650f3bc39e4dbccd6d4326b24fb5ea8be5f3a43a6f576c72", size = 590750, upload-time = "2025-05-21T12:44:34.557Z" }, - { url = "https://files.pythonhosted.org/packages/fb/ab/e04bf58a8d375aeedb5268edcc835c6a660ebf79d4384d8e0889439448b0/rpds_py-0.25.1-cp313-cp313t-musllinux_1_2_x86_64.whl", hash = "sha256:58f77c60956501a4a627749a6dcb78dac522f249dd96b5c9f1c6af29bfacfb66", size = 558891, upload-time = "2025-05-21T12:44:37.358Z" }, - { url = "https://files.pythonhosted.org/packages/90/82/cb8c6028a6ef6cd2b7991e2e4ced01c854b6236ecf51e81b64b569c43d73/rpds_py-0.25.1-cp313-cp313t-win32.whl", hash = "sha256:2cb9e5b5e26fc02c8a4345048cd9998c2aca7c2712bd1b36da0c72ee969a3523", size = 218718, upload-time = "2025-05-21T12:44:38.969Z" }, - { url = "https://files.pythonhosted.org/packages/b6/97/5a4b59697111c89477d20ba8a44df9ca16b41e737fa569d5ae8bff99e650/rpds_py-0.25.1-cp313-cp313t-win_amd64.whl", hash = "sha256:401ca1c4a20cc0510d3435d89c069fe0a9ae2ee6495135ac46bdd49ec0495763", size = 232218, upload-time = "2025-05-21T12:44:40.512Z" }, - { url = "https://files.pythonhosted.org/packages/78/ff/566ce53529b12b4f10c0a348d316bd766970b7060b4fd50f888be3b3b281/rpds_py-0.25.1-pp310-pypy310_pp73-macosx_10_12_x86_64.whl", hash = "sha256:b24bf3cd93d5b6ecfbedec73b15f143596c88ee249fa98cefa9a9dc9d92c6f28", size = 373931, upload-time = "2025-05-21T12:45:05.01Z" }, - { url = "https://files.pythonhosted.org/packages/83/5d/deba18503f7c7878e26aa696e97f051175788e19d5336b3b0e76d3ef9256/rpds_py-0.25.1-pp310-pypy310_pp73-macosx_11_0_arm64.whl", hash = "sha256:0eb90e94f43e5085623932b68840b6f379f26db7b5c2e6bcef3179bd83c9330f", size = 359074, upload-time = "2025-05-21T12:45:06.714Z" }, - { url = "https://files.pythonhosted.org/packages/0d/74/313415c5627644eb114df49c56a27edba4d40cfd7c92bd90212b3604ca84/rpds_py-0.25.1-pp310-pypy310_pp73-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:d50e4864498a9ab639d6d8854b25e80642bd362ff104312d9770b05d66e5fb13", size = 387255, upload-time = "2025-05-21T12:45:08.669Z" }, - { url = "https://files.pythonhosted.org/packages/8c/c8/c723298ed6338963d94e05c0f12793acc9b91d04ed7c4ba7508e534b7385/rpds_py-0.25.1-pp310-pypy310_pp73-manylinux_2_17_armv7l.manylinux2014_armv7l.whl", hash = "sha256:7c9409b47ba0650544b0bb3c188243b83654dfe55dcc173a86832314e1a6a35d", size = 400714, upload-time = "2025-05-21T12:45:10.39Z" }, - { url = "https://files.pythonhosted.org/packages/33/8a/51f1f6aa653c2e110ed482ef2ae94140d56c910378752a1b483af11019ee/rpds_py-0.25.1-pp310-pypy310_pp73-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:796ad874c89127c91970652a4ee8b00d56368b7e00d3477f4415fe78164c8000", size = 523105, upload-time = "2025-05-21T12:45:12.273Z" }, - { url = "https://files.pythonhosted.org/packages/c7/a4/7873d15c088ad3bff36910b29ceb0f178e4b3232c2adbe9198de68a41e63/rpds_py-0.25.1-pp310-pypy310_pp73-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:85608eb70a659bf4c1142b2781083d4b7c0c4e2c90eff11856a9754e965b2540", size = 411499, upload-time = "2025-05-21T12:45:13.95Z" }, - { url = "https://files.pythonhosted.org/packages/90/f3/0ce1437befe1410766d11d08239333ac1b2d940f8a64234ce48a7714669c/rpds_py-0.25.1-pp310-pypy310_pp73-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:c4feb9211d15d9160bc85fa72fed46432cdc143eb9cf6d5ca377335a921ac37b", size = 387918, upload-time = "2025-05-21T12:45:15.649Z" }, - { url = "https://files.pythonhosted.org/packages/94/d4/5551247988b2a3566afb8a9dba3f1d4a3eea47793fd83000276c1a6c726e/rpds_py-0.25.1-pp310-pypy310_pp73-manylinux_2_5_i686.manylinux1_i686.whl", hash = "sha256:ccfa689b9246c48947d31dd9d8b16d89a0ecc8e0e26ea5253068efb6c542b76e", size = 421705, upload-time = "2025-05-21T12:45:17.788Z" }, - { url = "https://files.pythonhosted.org/packages/b0/25/5960f28f847bf736cc7ee3c545a7e1d2f3b5edaf82c96fb616c2f5ed52d0/rpds_py-0.25.1-pp310-pypy310_pp73-musllinux_1_2_aarch64.whl", hash = "sha256:3c5b317ecbd8226887994852e85de562f7177add602514d4ac40f87de3ae45a8", size = 564489, upload-time = "2025-05-21T12:45:19.466Z" }, - { url = "https://files.pythonhosted.org/packages/02/66/1c99884a0d44e8c2904d3c4ec302f995292d5dde892c3bf7685ac1930146/rpds_py-0.25.1-pp310-pypy310_pp73-musllinux_1_2_i686.whl", hash = "sha256:454601988aab2c6e8fd49e7634c65476b2b919647626208e376afcd22019eeb8", size = 592557, upload-time = "2025-05-21T12:45:21.362Z" }, - { url = "https://files.pythonhosted.org/packages/55/ae/4aeac84ebeffeac14abb05b3bb1d2f728d00adb55d3fb7b51c9fa772e760/rpds_py-0.25.1-pp310-pypy310_pp73-musllinux_1_2_x86_64.whl", hash = "sha256:1c0c434a53714358532d13539272db75a5ed9df75a4a090a753ac7173ec14e11", size = 558691, upload-time = "2025-05-21T12:45:23.084Z" }, - { url = "https://files.pythonhosted.org/packages/41/b3/728a08ff6f5e06fe3bb9af2e770e9d5fd20141af45cff8dfc62da4b2d0b3/rpds_py-0.25.1-pp310-pypy310_pp73-win_amd64.whl", hash = "sha256:f73ce1512e04fbe2bc97836e89830d6b4314c171587a99688082d090f934d20a", size = 231651, upload-time = "2025-05-21T12:45:24.72Z" }, - { url = "https://files.pythonhosted.org/packages/49/74/48f3df0715a585cbf5d34919c9c757a4c92c1a9eba059f2d334e72471f70/rpds_py-0.25.1-pp311-pypy311_pp73-macosx_10_12_x86_64.whl", hash = "sha256:ee86d81551ec68a5c25373c5643d343150cc54672b5e9a0cafc93c1870a53954", size = 374208, upload-time = "2025-05-21T12:45:26.306Z" }, - { url = "https://files.pythonhosted.org/packages/55/b0/9b01bb11ce01ec03d05e627249cc2c06039d6aa24ea5a22a39c312167c10/rpds_py-0.25.1-pp311-pypy311_pp73-macosx_11_0_arm64.whl", hash = "sha256:89c24300cd4a8e4a51e55c31a8ff3918e6651b241ee8876a42cc2b2a078533ba", size = 359262, upload-time = "2025-05-21T12:45:28.322Z" }, - { url = "https://files.pythonhosted.org/packages/a9/eb/5395621618f723ebd5116c53282052943a726dba111b49cd2071f785b665/rpds_py-0.25.1-pp311-pypy311_pp73-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:771c16060ff4e79584dc48902a91ba79fd93eade3aa3a12d6d2a4aadaf7d542b", size = 387366, upload-time = "2025-05-21T12:45:30.42Z" }, - { url = "https://files.pythonhosted.org/packages/68/73/3d51442bdb246db619d75039a50ea1cf8b5b4ee250c3e5cd5c3af5981cd4/rpds_py-0.25.1-pp311-pypy311_pp73-manylinux_2_17_armv7l.manylinux2014_armv7l.whl", hash = "sha256:785ffacd0ee61c3e60bdfde93baa6d7c10d86f15655bd706c89da08068dc5038", size = 400759, upload-time = "2025-05-21T12:45:32.516Z" }, - { url = "https://files.pythonhosted.org/packages/b7/4c/3a32d5955d7e6cb117314597bc0f2224efc798428318b13073efe306512a/rpds_py-0.25.1-pp311-pypy311_pp73-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:2a40046a529cc15cef88ac5ab589f83f739e2d332cb4d7399072242400ed68c9", size = 523128, upload-time = "2025-05-21T12:45:34.396Z" }, - { url = "https://files.pythonhosted.org/packages/be/95/1ffccd3b0bb901ae60b1dd4b1be2ab98bb4eb834cd9b15199888f5702f7b/rpds_py-0.25.1-pp311-pypy311_pp73-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:85fc223d9c76cabe5d0bff82214459189720dc135db45f9f66aa7cffbf9ff6c1", size = 411597, upload-time = "2025-05-21T12:45:36.164Z" }, - { url = "https://files.pythonhosted.org/packages/ef/6d/6e6cd310180689db8b0d2de7f7d1eabf3fb013f239e156ae0d5a1a85c27f/rpds_py-0.25.1-pp311-pypy311_pp73-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:b0be9965f93c222fb9b4cc254235b3b2b215796c03ef5ee64f995b1b69af0762", size = 388053, upload-time = "2025-05-21T12:45:38.45Z" }, - { url = "https://files.pythonhosted.org/packages/4a/87/ec4186b1fe6365ced6fa470960e68fc7804bafbe7c0cf5a36237aa240efa/rpds_py-0.25.1-pp311-pypy311_pp73-manylinux_2_5_i686.manylinux1_i686.whl", hash = "sha256:8378fa4a940f3fb509c081e06cb7f7f2adae8cf46ef258b0e0ed7519facd573e", size = 421821, upload-time = "2025-05-21T12:45:40.732Z" }, - { url = "https://files.pythonhosted.org/packages/7a/60/84f821f6bf4e0e710acc5039d91f8f594fae0d93fc368704920d8971680d/rpds_py-0.25.1-pp311-pypy311_pp73-musllinux_1_2_aarch64.whl", hash = "sha256:33358883a4490287e67a2c391dfaea4d9359860281db3292b6886bf0be3d8692", size = 564534, upload-time = "2025-05-21T12:45:42.672Z" }, - { url = "https://files.pythonhosted.org/packages/41/3a/bc654eb15d3b38f9330fe0f545016ba154d89cdabc6177b0295910cd0ebe/rpds_py-0.25.1-pp311-pypy311_pp73-musllinux_1_2_i686.whl", hash = "sha256:1d1fadd539298e70cac2f2cb36f5b8a65f742b9b9f1014dd4ea1f7785e2470bf", size = 592674, upload-time = "2025-05-21T12:45:44.533Z" }, - { url = "https://files.pythonhosted.org/packages/2e/ba/31239736f29e4dfc7a58a45955c5db852864c306131fd6320aea214d5437/rpds_py-0.25.1-pp311-pypy311_pp73-musllinux_1_2_x86_64.whl", hash = "sha256:9a46c2fb2545e21181445515960006e85d22025bd2fe6db23e76daec6eb689fe", size = 558781, upload-time = "2025-05-21T12:45:46.281Z" }, -] - -[[package]] -name = "safetensors" -version = "0.5.3" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/71/7e/2d5d6ee7b40c0682315367ec7475693d110f512922d582fef1bd4a63adc3/safetensors-0.5.3.tar.gz", hash = "sha256:b6b0d6ecacec39a4fdd99cc19f4576f5219ce858e6fd8dbe7609df0b8dc56965", size = 67210, upload-time = "2025-02-26T09:15:13.155Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/18/ae/88f6c49dbd0cc4da0e08610019a3c78a7d390879a919411a410a1876d03a/safetensors-0.5.3-cp38-abi3-macosx_10_12_x86_64.whl", hash = "sha256:bd20eb133db8ed15b40110b7c00c6df51655a2998132193de2f75f72d99c7073", size = 436917, upload-time = "2025-02-26T09:15:03.702Z" }, - { url = "https://files.pythonhosted.org/packages/b8/3b/11f1b4a2f5d2ab7da34ecc062b0bc301f2be024d110a6466726bec8c055c/safetensors-0.5.3-cp38-abi3-macosx_11_0_arm64.whl", hash = "sha256:21d01c14ff6c415c485616b8b0bf961c46b3b343ca59110d38d744e577f9cce7", size = 418419, upload-time = "2025-02-26T09:15:01.765Z" }, - { url = "https://files.pythonhosted.org/packages/5d/9a/add3e6fef267658075c5a41573c26d42d80c935cdc992384dfae435feaef/safetensors-0.5.3-cp38-abi3-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:11bce6164887cd491ca75c2326a113ba934be596e22b28b1742ce27b1d076467", size = 459493, upload-time = "2025-02-26T09:14:51.812Z" }, - { url = "https://files.pythonhosted.org/packages/df/5c/bf2cae92222513cc23b3ff85c4a1bb2811a2c3583ac0f8e8d502751de934/safetensors-0.5.3-cp38-abi3-manylinux_2_17_armv7l.manylinux2014_armv7l.whl", hash = "sha256:4a243be3590bc3301c821da7a18d87224ef35cbd3e5f5727e4e0728b8172411e", size = 472400, upload-time = "2025-02-26T09:14:53.549Z" }, - { url = "https://files.pythonhosted.org/packages/58/11/7456afb740bd45782d0f4c8e8e1bb9e572f1bf82899fb6ace58af47b4282/safetensors-0.5.3-cp38-abi3-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:8bd84b12b1670a6f8e50f01e28156422a2bc07fb16fc4e98bded13039d688a0d", size = 522891, upload-time = "2025-02-26T09:14:55.717Z" }, - { url = "https://files.pythonhosted.org/packages/57/3d/fe73a9d2ace487e7285f6e157afee2383bd1ddb911b7cb44a55cf812eae3/safetensors-0.5.3-cp38-abi3-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:391ac8cab7c829452175f871fcaf414aa1e292b5448bd02620f675a7f3e7abb9", size = 537694, upload-time = "2025-02-26T09:14:57.036Z" }, - { url = "https://files.pythonhosted.org/packages/a6/f8/dae3421624fcc87a89d42e1898a798bc7ff72c61f38973a65d60df8f124c/safetensors-0.5.3-cp38-abi3-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:cead1fa41fc54b1e61089fa57452e8834f798cb1dc7a09ba3524f1eb08e0317a", size = 471642, upload-time = "2025-02-26T09:15:00.544Z" }, - { url = "https://files.pythonhosted.org/packages/ce/20/1fbe16f9b815f6c5a672f5b760951e20e17e43f67f231428f871909a37f6/safetensors-0.5.3-cp38-abi3-manylinux_2_5_i686.manylinux1_i686.whl", hash = "sha256:1077f3e94182d72618357b04b5ced540ceb71c8a813d3319f1aba448e68a770d", size = 502241, upload-time = "2025-02-26T09:14:58.303Z" }, - { url = "https://files.pythonhosted.org/packages/5f/18/8e108846b506487aa4629fe4116b27db65c3dde922de2c8e0cc1133f3f29/safetensors-0.5.3-cp38-abi3-musllinux_1_2_aarch64.whl", hash = "sha256:799021e78287bac619c7b3f3606730a22da4cda27759ddf55d37c8db7511c74b", size = 638001, upload-time = "2025-02-26T09:15:05.79Z" }, - { url = "https://files.pythonhosted.org/packages/82/5a/c116111d8291af6c8c8a8b40628fe833b9db97d8141c2a82359d14d9e078/safetensors-0.5.3-cp38-abi3-musllinux_1_2_armv7l.whl", hash = "sha256:df26da01aaac504334644e1b7642fa000bfec820e7cef83aeac4e355e03195ff", size = 734013, upload-time = "2025-02-26T09:15:07.892Z" }, - { url = "https://files.pythonhosted.org/packages/7d/ff/41fcc4d3b7de837963622e8610d998710705bbde9a8a17221d85e5d0baad/safetensors-0.5.3-cp38-abi3-musllinux_1_2_i686.whl", hash = "sha256:32c3ef2d7af8b9f52ff685ed0bc43913cdcde135089ae322ee576de93eae5135", size = 670687, upload-time = "2025-02-26T09:15:09.979Z" }, - { url = "https://files.pythonhosted.org/packages/40/ad/2b113098e69c985a3d8fbda4b902778eae4a35b7d5188859b4a63d30c161/safetensors-0.5.3-cp38-abi3-musllinux_1_2_x86_64.whl", hash = "sha256:37f1521be045e56fc2b54c606d4455573e717b2d887c579ee1dbba5f868ece04", size = 643147, upload-time = "2025-02-26T09:15:11.185Z" }, - { url = "https://files.pythonhosted.org/packages/0a/0c/95aeb51d4246bd9a3242d3d8349c1112b4ee7611a4b40f0c5c93b05f001d/safetensors-0.5.3-cp38-abi3-win32.whl", hash = "sha256:cfc0ec0846dcf6763b0ed3d1846ff36008c6e7290683b61616c4b040f6a54ace", size = 296677, upload-time = "2025-02-26T09:15:16.554Z" }, - { url = "https://files.pythonhosted.org/packages/69/e2/b011c38e5394c4c18fb5500778a55ec43ad6106126e74723ffaee246f56e/safetensors-0.5.3-cp38-abi3-win_amd64.whl", hash = "sha256:836cbbc320b47e80acd40e44c8682db0e8ad7123209f69b093def21ec7cafd11", size = 308878, upload-time = "2025-02-26T09:15:14.99Z" }, -] - -[[package]] -name = "sageattention" -version = "1.0.6" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "python_full_version >= '3.13' and sys_platform == 'darwin'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version == '3.12.*' and sys_platform == 'darwin'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version == '3.11.*' and sys_platform == 'darwin'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version < '3.11' and sys_platform == 'darwin'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -sdist = { url = "https://files.pythonhosted.org/packages/a5/c9/0445157fd09c8e5722503588db2a25afe9ab362d927b344dbbe7ee3ce84b/sageattention-1.0.6.tar.gz", hash = "sha256:b0398a5877222ee1abaeccd27d1029309c8b57994794a11c1278e0bfd176512c", size = 12611, upload-time = "2024-11-20T13:30:41.346Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/53/06/f7b47adb766bcb38b3f88763374a3e8dffea05ee9b556bc24dbcbd60fd29/sageattention-1.0.6-py3-none-any.whl", hash = "sha256:fafc66569bed62a16839e820c2612141b5a20accf55b876d941bab9c0ac5d888", size = 20105, upload-time = "2024-11-20T13:30:39.544Z" }, -] - -[[package]] -name = "sageattention" -version = "2.1.1" -source = { git = "https://github.com/thu-ml/SageAttention.git#b554fc49b59fbcbbcbceae6ccc8bc4d7ea60950d" } -resolution-markers = [ - "python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", -] - -[[package]] -name = "scikit-image" -version = "0.25.2" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "imageio" }, - { name = "lazy-loader" }, - { name = "networkx", version = "3.4.2", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "networkx", version = "3.5", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "packaging" }, - { name = "pillow" }, - { name = "scipy" }, - { name = "tifffile", version = "2025.5.10", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "tifffile", version = "2025.6.11", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/c7/a8/3c0f256012b93dd2cb6fda9245e9f4bff7dc0486880b248005f15ea2255e/scikit_image-0.25.2.tar.gz", hash = "sha256:e5a37e6cd4d0c018a7a55b9d601357e3382826d3888c10d0213fc63bff977dde", size = 22693594, upload-time = "2025-02-18T18:05:24.538Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/11/cb/016c63f16065c2d333c8ed0337e18a5cdf9bc32d402e4f26b0db362eb0e2/scikit_image-0.25.2-cp310-cp310-macosx_10_9_x86_64.whl", hash = "sha256:d3278f586793176599df6a4cf48cb6beadae35c31e58dc01a98023af3dc31c78", size = 13988922, upload-time = "2025-02-18T18:04:11.069Z" }, - { url = "https://files.pythonhosted.org/packages/30/ca/ff4731289cbed63c94a0c9a5b672976603118de78ed21910d9060c82e859/scikit_image-0.25.2-cp310-cp310-macosx_12_0_arm64.whl", hash = "sha256:5c311069899ce757d7dbf1d03e32acb38bb06153236ae77fcd820fd62044c063", size = 13192698, upload-time = "2025-02-18T18:04:15.362Z" }, - { url = "https://files.pythonhosted.org/packages/39/6d/a2aadb1be6d8e149199bb9b540ccde9e9622826e1ab42fe01de4c35ab918/scikit_image-0.25.2-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:be455aa7039a6afa54e84f9e38293733a2622b8c2fb3362b822d459cc5605e99", size = 14153634, upload-time = "2025-02-18T18:04:18.496Z" }, - { url = "https://files.pythonhosted.org/packages/96/08/916e7d9ee4721031b2f625db54b11d8379bd51707afaa3e5a29aecf10bc4/scikit_image-0.25.2-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:a4c464b90e978d137330be433df4e76d92ad3c5f46a22f159520ce0fdbea8a09", size = 14767545, upload-time = "2025-02-18T18:04:22.556Z" }, - { url = "https://files.pythonhosted.org/packages/5f/ee/c53a009e3997dda9d285402f19226fbd17b5b3cb215da391c4ed084a1424/scikit_image-0.25.2-cp310-cp310-win_amd64.whl", hash = "sha256:60516257c5a2d2f74387c502aa2f15a0ef3498fbeaa749f730ab18f0a40fd054", size = 12812908, upload-time = "2025-02-18T18:04:26.364Z" }, - { url = "https://files.pythonhosted.org/packages/c4/97/3051c68b782ee3f1fb7f8f5bb7d535cf8cb92e8aae18fa9c1cdf7e15150d/scikit_image-0.25.2-cp311-cp311-macosx_10_9_x86_64.whl", hash = "sha256:f4bac9196fb80d37567316581c6060763b0f4893d3aca34a9ede3825bc035b17", size = 14003057, upload-time = "2025-02-18T18:04:30.395Z" }, - { url = "https://files.pythonhosted.org/packages/19/23/257fc696c562639826065514d551b7b9b969520bd902c3a8e2fcff5b9e17/scikit_image-0.25.2-cp311-cp311-macosx_12_0_arm64.whl", hash = "sha256:d989d64ff92e0c6c0f2018c7495a5b20e2451839299a018e0e5108b2680f71e0", size = 13180335, upload-time = "2025-02-18T18:04:33.449Z" }, - { url = "https://files.pythonhosted.org/packages/ef/14/0c4a02cb27ca8b1e836886b9ec7c9149de03053650e9e2ed0625f248dd92/scikit_image-0.25.2-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:b2cfc96b27afe9a05bc92f8c6235321d3a66499995675b27415e0d0c76625173", size = 14144783, upload-time = "2025-02-18T18:04:36.594Z" }, - { url = "https://files.pythonhosted.org/packages/dd/9b/9fb556463a34d9842491d72a421942c8baff4281025859c84fcdb5e7e602/scikit_image-0.25.2-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:24cc986e1f4187a12aa319f777b36008764e856e5013666a4a83f8df083c2641", size = 14785376, upload-time = "2025-02-18T18:04:39.856Z" }, - { url = "https://files.pythonhosted.org/packages/de/ec/b57c500ee85885df5f2188f8bb70398481393a69de44a00d6f1d055f103c/scikit_image-0.25.2-cp311-cp311-win_amd64.whl", hash = "sha256:b4f6b61fc2db6340696afe3db6b26e0356911529f5f6aee8c322aa5157490c9b", size = 12791698, upload-time = "2025-02-18T18:04:42.868Z" }, - { url = "https://files.pythonhosted.org/packages/35/8c/5df82881284459f6eec796a5ac2a0a304bb3384eec2e73f35cfdfcfbf20c/scikit_image-0.25.2-cp312-cp312-macosx_10_13_x86_64.whl", hash = "sha256:8db8dd03663112783221bf01ccfc9512d1cc50ac9b5b0fe8f4023967564719fb", size = 13986000, upload-time = "2025-02-18T18:04:47.156Z" }, - { url = "https://files.pythonhosted.org/packages/ce/e6/93bebe1abcdce9513ffec01d8af02528b4c41fb3c1e46336d70b9ed4ef0d/scikit_image-0.25.2-cp312-cp312-macosx_12_0_arm64.whl", hash = "sha256:483bd8cc10c3d8a7a37fae36dfa5b21e239bd4ee121d91cad1f81bba10cfb0ed", size = 13235893, upload-time = "2025-02-18T18:04:51.049Z" }, - { url = "https://files.pythonhosted.org/packages/53/4b/eda616e33f67129e5979a9eb33c710013caa3aa8a921991e6cc0b22cea33/scikit_image-0.25.2-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:9d1e80107bcf2bf1291acfc0bf0425dceb8890abe9f38d8e94e23497cbf7ee0d", size = 14178389, upload-time = "2025-02-18T18:04:54.245Z" }, - { url = "https://files.pythonhosted.org/packages/6b/b5/b75527c0f9532dd8a93e8e7cd8e62e547b9f207d4c11e24f0006e8646b36/scikit_image-0.25.2-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:a17e17eb8562660cc0d31bb55643a4da996a81944b82c54805c91b3fe66f4824", size = 15003435, upload-time = "2025-02-18T18:04:57.586Z" }, - { url = "https://files.pythonhosted.org/packages/34/e3/49beb08ebccda3c21e871b607c1cb2f258c3fa0d2f609fed0a5ba741b92d/scikit_image-0.25.2-cp312-cp312-win_amd64.whl", hash = "sha256:bdd2b8c1de0849964dbc54037f36b4e9420157e67e45a8709a80d727f52c7da2", size = 12899474, upload-time = "2025-02-18T18:05:01.166Z" }, - { url = "https://files.pythonhosted.org/packages/e6/7c/9814dd1c637f7a0e44342985a76f95a55dd04be60154247679fd96c7169f/scikit_image-0.25.2-cp313-cp313-macosx_10_13_x86_64.whl", hash = "sha256:7efa888130f6c548ec0439b1a7ed7295bc10105458a421e9bf739b457730b6da", size = 13921841, upload-time = "2025-02-18T18:05:03.963Z" }, - { url = "https://files.pythonhosted.org/packages/84/06/66a2e7661d6f526740c309e9717d3bd07b473661d5cdddef4dd978edab25/scikit_image-0.25.2-cp313-cp313-macosx_12_0_arm64.whl", hash = "sha256:dd8011efe69c3641920614d550f5505f83658fe33581e49bed86feab43a180fc", size = 13196862, upload-time = "2025-02-18T18:05:06.986Z" }, - { url = "https://files.pythonhosted.org/packages/4e/63/3368902ed79305f74c2ca8c297dfeb4307269cbe6402412668e322837143/scikit_image-0.25.2-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:28182a9d3e2ce3c2e251383bdda68f8d88d9fff1a3ebe1eb61206595c9773341", size = 14117785, upload-time = "2025-02-18T18:05:10.69Z" }, - { url = "https://files.pythonhosted.org/packages/cd/9b/c3da56a145f52cd61a68b8465d6a29d9503bc45bc993bb45e84371c97d94/scikit_image-0.25.2-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:b8abd3c805ce6944b941cfed0406d88faeb19bab3ed3d4b50187af55cf24d147", size = 14977119, upload-time = "2025-02-18T18:05:13.871Z" }, - { url = "https://files.pythonhosted.org/packages/8a/97/5fcf332e1753831abb99a2525180d3fb0d70918d461ebda9873f66dcc12f/scikit_image-0.25.2-cp313-cp313-win_amd64.whl", hash = "sha256:64785a8acefee460ec49a354706db0b09d1f325674107d7fa3eadb663fb56d6f", size = 12885116, upload-time = "2025-02-18T18:05:17.844Z" }, - { url = "https://files.pythonhosted.org/packages/10/cc/75e9f17e3670b5ed93c32456fda823333c6279b144cd93e2c03aa06aa472/scikit_image-0.25.2-cp313-cp313t-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:330d061bd107d12f8d68f1d611ae27b3b813b8cdb0300a71d07b1379178dd4cd", size = 13862801, upload-time = "2025-02-18T18:05:20.783Z" }, -] - -[[package]] -name = "scikit-learn" -version = "1.7.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "joblib" }, - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "scipy" }, - { name = "threadpoolctl" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/df/3b/29fa87e76b1d7b3b77cc1fcbe82e6e6b8cd704410705b008822de530277c/scikit_learn-1.7.0.tar.gz", hash = "sha256:c01e869b15aec88e2cdb73d27f15bdbe03bce8e2fb43afbe77c45d399e73a5a3", size = 7178217, upload-time = "2025-06-05T22:02:46.703Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/a4/70/e725b1da11e7e833f558eb4d3ea8b7ed7100edda26101df074f1ae778235/scikit_learn-1.7.0-cp310-cp310-macosx_10_9_x86_64.whl", hash = "sha256:9fe7f51435f49d97bd41d724bb3e11eeb939882af9c29c931a8002c357e8cdd5", size = 11728006, upload-time = "2025-06-05T22:01:43.007Z" }, - { url = "https://files.pythonhosted.org/packages/32/aa/43874d372e9dc51eb361f5c2f0a4462915c9454563b3abb0d9457c66b7e9/scikit_learn-1.7.0-cp310-cp310-macosx_12_0_arm64.whl", hash = "sha256:d0c93294e1e1acbee2d029b1f2a064f26bd928b284938d51d412c22e0c977eb3", size = 10726255, upload-time = "2025-06-05T22:01:46.082Z" }, - { url = "https://files.pythonhosted.org/packages/f5/1a/da73cc18e00f0b9ae89f7e4463a02fb6e0569778120aeab138d9554ecef0/scikit_learn-1.7.0-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:bf3755f25f145186ad8c403312f74fb90df82a4dfa1af19dc96ef35f57237a94", size = 12205657, upload-time = "2025-06-05T22:01:48.729Z" }, - { url = "https://files.pythonhosted.org/packages/fb/f6/800cb3243dd0137ca6d98df8c9d539eb567ba0a0a39ecd245c33fab93510/scikit_learn-1.7.0-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:2726c8787933add436fb66fb63ad18e8ef342dfb39bbbd19dc1e83e8f828a85a", size = 12877290, upload-time = "2025-06-05T22:01:51.073Z" }, - { url = "https://files.pythonhosted.org/packages/4c/bd/99c3ccb49946bd06318fe194a1c54fb7d57ac4fe1c2f4660d86b3a2adf64/scikit_learn-1.7.0-cp310-cp310-win_amd64.whl", hash = "sha256:e2539bb58886a531b6e86a510c0348afaadd25005604ad35966a85c2ec378800", size = 10713211, upload-time = "2025-06-05T22:01:54.107Z" }, - { url = "https://files.pythonhosted.org/packages/5a/42/c6b41711c2bee01c4800ad8da2862c0b6d2956a399d23ce4d77f2ca7f0c7/scikit_learn-1.7.0-cp311-cp311-macosx_10_9_x86_64.whl", hash = "sha256:8ef09b1615e1ad04dc0d0054ad50634514818a8eb3ee3dee99af3bffc0ef5007", size = 11719657, upload-time = "2025-06-05T22:01:56.345Z" }, - { url = "https://files.pythonhosted.org/packages/a3/24/44acca76449e391b6b2522e67a63c0454b7c1f060531bdc6d0118fb40851/scikit_learn-1.7.0-cp311-cp311-macosx_12_0_arm64.whl", hash = "sha256:7d7240c7b19edf6ed93403f43b0fcb0fe95b53bc0b17821f8fb88edab97085ef", size = 10712636, upload-time = "2025-06-05T22:01:59.093Z" }, - { url = "https://files.pythonhosted.org/packages/9f/1b/fcad1ccb29bdc9b96bcaa2ed8345d56afb77b16c0c47bafe392cc5d1d213/scikit_learn-1.7.0-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:80bd3bd4e95381efc47073a720d4cbab485fc483966f1709f1fd559afac57ab8", size = 12242817, upload-time = "2025-06-05T22:02:01.43Z" }, - { url = "https://files.pythonhosted.org/packages/c6/38/48b75c3d8d268a3f19837cb8a89155ead6e97c6892bb64837183ea41db2b/scikit_learn-1.7.0-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:9dbe48d69aa38ecfc5a6cda6c5df5abef0c0ebdb2468e92437e2053f84abb8bc", size = 12873961, upload-time = "2025-06-05T22:02:03.951Z" }, - { url = "https://files.pythonhosted.org/packages/f4/5a/ba91b8c57aa37dbd80d5ff958576a9a8c14317b04b671ae7f0d09b00993a/scikit_learn-1.7.0-cp311-cp311-win_amd64.whl", hash = "sha256:8fa979313b2ffdfa049ed07252dc94038def3ecd49ea2a814db5401c07f1ecfa", size = 10717277, upload-time = "2025-06-05T22:02:06.77Z" }, - { url = "https://files.pythonhosted.org/packages/70/3a/bffab14e974a665a3ee2d79766e7389572ffcaad941a246931c824afcdb2/scikit_learn-1.7.0-cp312-cp312-macosx_10_13_x86_64.whl", hash = "sha256:c2c7243d34aaede0efca7a5a96d67fddaebb4ad7e14a70991b9abee9dc5c0379", size = 11646758, upload-time = "2025-06-05T22:02:09.51Z" }, - { url = "https://files.pythonhosted.org/packages/58/d8/f3249232fa79a70cb40595282813e61453c1e76da3e1a44b77a63dd8d0cb/scikit_learn-1.7.0-cp312-cp312-macosx_12_0_arm64.whl", hash = "sha256:9f39f6a811bf3f15177b66c82cbe0d7b1ebad9f190737dcdef77cfca1ea3c19c", size = 10673971, upload-time = "2025-06-05T22:02:12.217Z" }, - { url = "https://files.pythonhosted.org/packages/67/93/eb14c50533bea2f77758abe7d60a10057e5f2e2cdcf0a75a14c6bc19c734/scikit_learn-1.7.0-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:63017a5f9a74963d24aac7590287149a8d0f1a0799bbe7173c0d8ba1523293c0", size = 11818428, upload-time = "2025-06-05T22:02:14.947Z" }, - { url = "https://files.pythonhosted.org/packages/08/17/804cc13b22a8663564bb0b55fb89e661a577e4e88a61a39740d58b909efe/scikit_learn-1.7.0-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:0b2f8a0b1e73e9a08b7cc498bb2aeab36cdc1f571f8ab2b35c6e5d1c7115d97d", size = 12505887, upload-time = "2025-06-05T22:02:17.824Z" }, - { url = "https://files.pythonhosted.org/packages/68/c7/4e956281a077f4835458c3f9656c666300282d5199039f26d9de1dabd9be/scikit_learn-1.7.0-cp312-cp312-win_amd64.whl", hash = "sha256:34cc8d9d010d29fb2b7cbcd5ccc24ffdd80515f65fe9f1e4894ace36b267ce19", size = 10668129, upload-time = "2025-06-05T22:02:20.536Z" }, - { url = "https://files.pythonhosted.org/packages/9a/c3/a85dcccdaf1e807e6f067fa95788a6485b0491d9ea44fd4c812050d04f45/scikit_learn-1.7.0-cp313-cp313-macosx_10_13_x86_64.whl", hash = "sha256:5b7974f1f32bc586c90145df51130e02267e4b7e77cab76165c76cf43faca0d9", size = 11559841, upload-time = "2025-06-05T22:02:23.308Z" }, - { url = "https://files.pythonhosted.org/packages/d8/57/eea0de1562cc52d3196eae51a68c5736a31949a465f0b6bb3579b2d80282/scikit_learn-1.7.0-cp313-cp313-macosx_12_0_arm64.whl", hash = "sha256:014e07a23fe02e65f9392898143c542a50b6001dbe89cb867e19688e468d049b", size = 10616463, upload-time = "2025-06-05T22:02:26.068Z" }, - { url = "https://files.pythonhosted.org/packages/10/a4/39717ca669296dfc3a62928393168da88ac9d8cbec88b6321ffa62c6776f/scikit_learn-1.7.0-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:e7e7ced20582d3a5516fb6f405fd1d254e1f5ce712bfef2589f51326af6346e8", size = 11766512, upload-time = "2025-06-05T22:02:28.689Z" }, - { url = "https://files.pythonhosted.org/packages/d5/cd/a19722241d5f7b51e08351e1e82453e0057aeb7621b17805f31fcb57bb6c/scikit_learn-1.7.0-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:1babf2511e6ffd695da7a983b4e4d6de45dce39577b26b721610711081850906", size = 12461075, upload-time = "2025-06-05T22:02:31.233Z" }, - { url = "https://files.pythonhosted.org/packages/f3/bc/282514272815c827a9acacbe5b99f4f1a4bc5961053719d319480aee0812/scikit_learn-1.7.0-cp313-cp313-win_amd64.whl", hash = "sha256:5abd2acff939d5bd4701283f009b01496832d50ddafa83c90125a4e41c33e314", size = 10652517, upload-time = "2025-06-05T22:02:34.139Z" }, - { url = "https://files.pythonhosted.org/packages/ea/78/7357d12b2e4c6674175f9a09a3ba10498cde8340e622715bcc71e532981d/scikit_learn-1.7.0-cp313-cp313t-macosx_10_13_x86_64.whl", hash = "sha256:e39d95a929b112047c25b775035c8c234c5ca67e681ce60d12413afb501129f7", size = 12111822, upload-time = "2025-06-05T22:02:36.904Z" }, - { url = "https://files.pythonhosted.org/packages/d0/0c/9c3715393343f04232f9d81fe540eb3831d0b4ec351135a145855295110f/scikit_learn-1.7.0-cp313-cp313t-macosx_12_0_arm64.whl", hash = "sha256:0521cb460426c56fee7e07f9365b0f45ec8ca7b2d696534ac98bfb85e7ae4775", size = 11325286, upload-time = "2025-06-05T22:02:39.739Z" }, - { url = "https://files.pythonhosted.org/packages/64/e0/42282ad3dd70b7c1a5f65c412ac3841f6543502a8d6263cae7b466612dc9/scikit_learn-1.7.0-cp313-cp313t-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:317ca9f83acbde2883bd6bb27116a741bfcb371369706b4f9973cf30e9a03b0d", size = 12380865, upload-time = "2025-06-05T22:02:42.137Z" }, - { url = "https://files.pythonhosted.org/packages/4e/d0/3ef4ab2c6be4aa910445cd09c5ef0b44512e3de2cfb2112a88bb647d2cf7/scikit_learn-1.7.0-cp313-cp313t-win_amd64.whl", hash = "sha256:126c09740a6f016e815ab985b21e3a0656835414521c81fc1a8da78b679bdb75", size = 11549609, upload-time = "2025-06-05T22:02:44.483Z" }, -] - -[[package]] -name = "scipy" -version = "1.15.3" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/0f/37/6964b830433e654ec7485e45a00fc9a27cf868d622838f6b6d9c5ec0d532/scipy-1.15.3.tar.gz", hash = "sha256:eae3cf522bc7df64b42cad3925c876e1b0b6c35c1337c93e12c0f366f55b0eaf", size = 59419214, upload-time = "2025-05-08T16:13:05.955Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/78/2f/4966032c5f8cc7e6a60f1b2e0ad686293b9474b65246b0c642e3ef3badd0/scipy-1.15.3-cp310-cp310-macosx_10_13_x86_64.whl", hash = "sha256:a345928c86d535060c9c2b25e71e87c39ab2f22fc96e9636bd74d1dbf9de448c", size = 38702770, upload-time = "2025-05-08T16:04:20.849Z" }, - { url = "https://files.pythonhosted.org/packages/a0/6e/0c3bf90fae0e910c274db43304ebe25a6b391327f3f10b5dcc638c090795/scipy-1.15.3-cp310-cp310-macosx_12_0_arm64.whl", hash = "sha256:ad3432cb0f9ed87477a8d97f03b763fd1d57709f1bbde3c9369b1dff5503b253", size = 30094511, upload-time = "2025-05-08T16:04:27.103Z" }, - { url = "https://files.pythonhosted.org/packages/ea/b1/4deb37252311c1acff7f101f6453f0440794f51b6eacb1aad4459a134081/scipy-1.15.3-cp310-cp310-macosx_14_0_arm64.whl", hash = "sha256:aef683a9ae6eb00728a542b796f52a5477b78252edede72b8327a886ab63293f", size = 22368151, upload-time = "2025-05-08T16:04:31.731Z" }, - { url = "https://files.pythonhosted.org/packages/38/7d/f457626e3cd3c29b3a49ca115a304cebb8cc6f31b04678f03b216899d3c6/scipy-1.15.3-cp310-cp310-macosx_14_0_x86_64.whl", hash = "sha256:1c832e1bd78dea67d5c16f786681b28dd695a8cb1fb90af2e27580d3d0967e92", size = 25121732, upload-time = "2025-05-08T16:04:36.596Z" }, - { url = "https://files.pythonhosted.org/packages/db/0a/92b1de4a7adc7a15dcf5bddc6e191f6f29ee663b30511ce20467ef9b82e4/scipy-1.15.3-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:263961f658ce2165bbd7b99fa5135195c3a12d9bef045345016b8b50c315cb82", size = 35547617, upload-time = "2025-05-08T16:04:43.546Z" }, - { url = "https://files.pythonhosted.org/packages/8e/6d/41991e503e51fc1134502694c5fa7a1671501a17ffa12716a4a9151af3df/scipy-1.15.3-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:9e2abc762b0811e09a0d3258abee2d98e0c703eee49464ce0069590846f31d40", size = 37662964, upload-time = "2025-05-08T16:04:49.431Z" }, - { url = "https://files.pythonhosted.org/packages/25/e1/3df8f83cb15f3500478c889be8fb18700813b95e9e087328230b98d547ff/scipy-1.15.3-cp310-cp310-musllinux_1_2_aarch64.whl", hash = "sha256:ed7284b21a7a0c8f1b6e5977ac05396c0d008b89e05498c8b7e8f4a1423bba0e", size = 37238749, upload-time = "2025-05-08T16:04:55.215Z" }, - { url = "https://files.pythonhosted.org/packages/93/3e/b3257cf446f2a3533ed7809757039016b74cd6f38271de91682aa844cfc5/scipy-1.15.3-cp310-cp310-musllinux_1_2_x86_64.whl", hash = "sha256:5380741e53df2c566f4d234b100a484b420af85deb39ea35a1cc1be84ff53a5c", size = 40022383, upload-time = "2025-05-08T16:05:01.914Z" }, - { url = "https://files.pythonhosted.org/packages/d1/84/55bc4881973d3f79b479a5a2e2df61c8c9a04fcb986a213ac9c02cfb659b/scipy-1.15.3-cp310-cp310-win_amd64.whl", hash = "sha256:9d61e97b186a57350f6d6fd72640f9e99d5a4a2b8fbf4b9ee9a841eab327dc13", size = 41259201, upload-time = "2025-05-08T16:05:08.166Z" }, - { url = "https://files.pythonhosted.org/packages/96/ab/5cc9f80f28f6a7dff646c5756e559823614a42b1939d86dd0ed550470210/scipy-1.15.3-cp311-cp311-macosx_10_13_x86_64.whl", hash = "sha256:993439ce220d25e3696d1b23b233dd010169b62f6456488567e830654ee37a6b", size = 38714255, upload-time = "2025-05-08T16:05:14.596Z" }, - { url = "https://files.pythonhosted.org/packages/4a/4a/66ba30abe5ad1a3ad15bfb0b59d22174012e8056ff448cb1644deccbfed2/scipy-1.15.3-cp311-cp311-macosx_12_0_arm64.whl", hash = "sha256:34716e281f181a02341ddeaad584205bd2fd3c242063bd3423d61ac259ca7eba", size = 30111035, upload-time = "2025-05-08T16:05:20.152Z" }, - { url = "https://files.pythonhosted.org/packages/4b/fa/a7e5b95afd80d24313307f03624acc65801846fa75599034f8ceb9e2cbf6/scipy-1.15.3-cp311-cp311-macosx_14_0_arm64.whl", hash = "sha256:3b0334816afb8b91dab859281b1b9786934392aa3d527cd847e41bb6f45bee65", size = 22384499, upload-time = "2025-05-08T16:05:24.494Z" }, - { url = "https://files.pythonhosted.org/packages/17/99/f3aaddccf3588bb4aea70ba35328c204cadd89517a1612ecfda5b2dd9d7a/scipy-1.15.3-cp311-cp311-macosx_14_0_x86_64.whl", hash = "sha256:6db907c7368e3092e24919b5e31c76998b0ce1684d51a90943cb0ed1b4ffd6c1", size = 25152602, upload-time = "2025-05-08T16:05:29.313Z" }, - { url = "https://files.pythonhosted.org/packages/56/c5/1032cdb565f146109212153339f9cb8b993701e9fe56b1c97699eee12586/scipy-1.15.3-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:721d6b4ef5dc82ca8968c25b111e307083d7ca9091bc38163fb89243e85e3889", size = 35503415, upload-time = "2025-05-08T16:05:34.699Z" }, - { url = "https://files.pythonhosted.org/packages/bd/37/89f19c8c05505d0601ed5650156e50eb881ae3918786c8fd7262b4ee66d3/scipy-1.15.3-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:39cb9c62e471b1bb3750066ecc3a3f3052b37751c7c3dfd0fd7e48900ed52982", size = 37652622, upload-time = "2025-05-08T16:05:40.762Z" }, - { url = "https://files.pythonhosted.org/packages/7e/31/be59513aa9695519b18e1851bb9e487de66f2d31f835201f1b42f5d4d475/scipy-1.15.3-cp311-cp311-musllinux_1_2_aarch64.whl", hash = "sha256:795c46999bae845966368a3c013e0e00947932d68e235702b5c3f6ea799aa8c9", size = 37244796, upload-time = "2025-05-08T16:05:48.119Z" }, - { url = "https://files.pythonhosted.org/packages/10/c0/4f5f3eeccc235632aab79b27a74a9130c6c35df358129f7ac8b29f562ac7/scipy-1.15.3-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:18aaacb735ab38b38db42cb01f6b92a2d0d4b6aabefeb07f02849e47f8fb3594", size = 40047684, upload-time = "2025-05-08T16:05:54.22Z" }, - { url = "https://files.pythonhosted.org/packages/ab/a7/0ddaf514ce8a8714f6ed243a2b391b41dbb65251affe21ee3077ec45ea9a/scipy-1.15.3-cp311-cp311-win_amd64.whl", hash = "sha256:ae48a786a28412d744c62fd7816a4118ef97e5be0bee968ce8f0a2fba7acf3bb", size = 41246504, upload-time = "2025-05-08T16:06:00.437Z" }, - { url = "https://files.pythonhosted.org/packages/37/4b/683aa044c4162e10ed7a7ea30527f2cbd92e6999c10a8ed8edb253836e9c/scipy-1.15.3-cp312-cp312-macosx_10_13_x86_64.whl", hash = "sha256:6ac6310fdbfb7aa6612408bd2f07295bcbd3fda00d2d702178434751fe48e019", size = 38766735, upload-time = "2025-05-08T16:06:06.471Z" }, - { url = "https://files.pythonhosted.org/packages/7b/7e/f30be3d03de07f25dc0ec926d1681fed5c732d759ac8f51079708c79e680/scipy-1.15.3-cp312-cp312-macosx_12_0_arm64.whl", hash = "sha256:185cd3d6d05ca4b44a8f1595af87f9c372bb6acf9c808e99aa3e9aa03bd98cf6", size = 30173284, upload-time = "2025-05-08T16:06:11.686Z" }, - { url = "https://files.pythonhosted.org/packages/07/9c/0ddb0d0abdabe0d181c1793db51f02cd59e4901da6f9f7848e1f96759f0d/scipy-1.15.3-cp312-cp312-macosx_14_0_arm64.whl", hash = "sha256:05dc6abcd105e1a29f95eada46d4a3f251743cfd7d3ae8ddb4088047f24ea477", size = 22446958, upload-time = "2025-05-08T16:06:15.97Z" }, - { url = "https://files.pythonhosted.org/packages/af/43/0bce905a965f36c58ff80d8bea33f1f9351b05fad4beaad4eae34699b7a1/scipy-1.15.3-cp312-cp312-macosx_14_0_x86_64.whl", hash = "sha256:06efcba926324df1696931a57a176c80848ccd67ce6ad020c810736bfd58eb1c", size = 25242454, upload-time = "2025-05-08T16:06:20.394Z" }, - { url = "https://files.pythonhosted.org/packages/56/30/a6f08f84ee5b7b28b4c597aca4cbe545535c39fe911845a96414700b64ba/scipy-1.15.3-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:c05045d8b9bfd807ee1b9f38761993297b10b245f012b11b13b91ba8945f7e45", size = 35210199, upload-time = "2025-05-08T16:06:26.159Z" }, - { url = "https://files.pythonhosted.org/packages/0b/1f/03f52c282437a168ee2c7c14a1a0d0781a9a4a8962d84ac05c06b4c5b555/scipy-1.15.3-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:271e3713e645149ea5ea3e97b57fdab61ce61333f97cfae392c28ba786f9bb49", size = 37309455, upload-time = "2025-05-08T16:06:32.778Z" }, - { url = "https://files.pythonhosted.org/packages/89/b1/fbb53137f42c4bf630b1ffdfc2151a62d1d1b903b249f030d2b1c0280af8/scipy-1.15.3-cp312-cp312-musllinux_1_2_aarch64.whl", hash = "sha256:6cfd56fc1a8e53f6e89ba3a7a7251f7396412d655bca2aa5611c8ec9a6784a1e", size = 36885140, upload-time = "2025-05-08T16:06:39.249Z" }, - { url = "https://files.pythonhosted.org/packages/2e/2e/025e39e339f5090df1ff266d021892694dbb7e63568edcfe43f892fa381d/scipy-1.15.3-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:0ff17c0bb1cb32952c09217d8d1eed9b53d1463e5f1dd6052c7857f83127d539", size = 39710549, upload-time = "2025-05-08T16:06:45.729Z" }, - { url = "https://files.pythonhosted.org/packages/e6/eb/3bf6ea8ab7f1503dca3a10df2e4b9c3f6b3316df07f6c0ded94b281c7101/scipy-1.15.3-cp312-cp312-win_amd64.whl", hash = "sha256:52092bc0472cfd17df49ff17e70624345efece4e1a12b23783a1ac59a1b728ed", size = 40966184, upload-time = "2025-05-08T16:06:52.623Z" }, - { url = "https://files.pythonhosted.org/packages/73/18/ec27848c9baae6e0d6573eda6e01a602e5649ee72c27c3a8aad673ebecfd/scipy-1.15.3-cp313-cp313-macosx_10_13_x86_64.whl", hash = "sha256:2c620736bcc334782e24d173c0fdbb7590a0a436d2fdf39310a8902505008759", size = 38728256, upload-time = "2025-05-08T16:06:58.696Z" }, - { url = "https://files.pythonhosted.org/packages/74/cd/1aef2184948728b4b6e21267d53b3339762c285a46a274ebb7863c9e4742/scipy-1.15.3-cp313-cp313-macosx_12_0_arm64.whl", hash = "sha256:7e11270a000969409d37ed399585ee530b9ef6aa99d50c019de4cb01e8e54e62", size = 30109540, upload-time = "2025-05-08T16:07:04.209Z" }, - { url = "https://files.pythonhosted.org/packages/5b/d8/59e452c0a255ec352bd0a833537a3bc1bfb679944c4938ab375b0a6b3a3e/scipy-1.15.3-cp313-cp313-macosx_14_0_arm64.whl", hash = "sha256:8c9ed3ba2c8a2ce098163a9bdb26f891746d02136995df25227a20e71c396ebb", size = 22383115, upload-time = "2025-05-08T16:07:08.998Z" }, - { url = "https://files.pythonhosted.org/packages/08/f5/456f56bbbfccf696263b47095291040655e3cbaf05d063bdc7c7517f32ac/scipy-1.15.3-cp313-cp313-macosx_14_0_x86_64.whl", hash = "sha256:0bdd905264c0c9cfa74a4772cdb2070171790381a5c4d312c973382fc6eaf730", size = 25163884, upload-time = "2025-05-08T16:07:14.091Z" }, - { url = "https://files.pythonhosted.org/packages/a2/66/a9618b6a435a0f0c0b8a6d0a2efb32d4ec5a85f023c2b79d39512040355b/scipy-1.15.3-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:79167bba085c31f38603e11a267d862957cbb3ce018d8b38f79ac043bc92d825", size = 35174018, upload-time = "2025-05-08T16:07:19.427Z" }, - { url = "https://files.pythonhosted.org/packages/b5/09/c5b6734a50ad4882432b6bb7c02baf757f5b2f256041da5df242e2d7e6b6/scipy-1.15.3-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:c9deabd6d547aee2c9a81dee6cc96c6d7e9a9b1953f74850c179f91fdc729cb7", size = 37269716, upload-time = "2025-05-08T16:07:25.712Z" }, - { url = "https://files.pythonhosted.org/packages/77/0a/eac00ff741f23bcabd352731ed9b8995a0a60ef57f5fd788d611d43d69a1/scipy-1.15.3-cp313-cp313-musllinux_1_2_aarch64.whl", hash = "sha256:dde4fc32993071ac0c7dd2d82569e544f0bdaff66269cb475e0f369adad13f11", size = 36872342, upload-time = "2025-05-08T16:07:31.468Z" }, - { url = "https://files.pythonhosted.org/packages/fe/54/4379be86dd74b6ad81551689107360d9a3e18f24d20767a2d5b9253a3f0a/scipy-1.15.3-cp313-cp313-musllinux_1_2_x86_64.whl", hash = "sha256:f77f853d584e72e874d87357ad70f44b437331507d1c311457bed8ed2b956126", size = 39670869, upload-time = "2025-05-08T16:07:38.002Z" }, - { url = "https://files.pythonhosted.org/packages/87/2e/892ad2862ba54f084ffe8cc4a22667eaf9c2bcec6d2bff1d15713c6c0703/scipy-1.15.3-cp313-cp313-win_amd64.whl", hash = "sha256:b90ab29d0c37ec9bf55424c064312930ca5f4bde15ee8619ee44e69319aab163", size = 40988851, upload-time = "2025-05-08T16:08:33.671Z" }, - { url = "https://files.pythonhosted.org/packages/1b/e9/7a879c137f7e55b30d75d90ce3eb468197646bc7b443ac036ae3fe109055/scipy-1.15.3-cp313-cp313t-macosx_10_13_x86_64.whl", hash = "sha256:3ac07623267feb3ae308487c260ac684b32ea35fd81e12845039952f558047b8", size = 38863011, upload-time = "2025-05-08T16:07:44.039Z" }, - { url = "https://files.pythonhosted.org/packages/51/d1/226a806bbd69f62ce5ef5f3ffadc35286e9fbc802f606a07eb83bf2359de/scipy-1.15.3-cp313-cp313t-macosx_12_0_arm64.whl", hash = "sha256:6487aa99c2a3d509a5227d9a5e889ff05830a06b2ce08ec30df6d79db5fcd5c5", size = 30266407, upload-time = "2025-05-08T16:07:49.891Z" }, - { url = "https://files.pythonhosted.org/packages/e5/9b/f32d1d6093ab9eeabbd839b0f7619c62e46cc4b7b6dbf05b6e615bbd4400/scipy-1.15.3-cp313-cp313t-macosx_14_0_arm64.whl", hash = "sha256:50f9e62461c95d933d5c5ef4a1f2ebf9a2b4e83b0db374cb3f1de104d935922e", size = 22540030, upload-time = "2025-05-08T16:07:54.121Z" }, - { url = "https://files.pythonhosted.org/packages/e7/29/c278f699b095c1a884f29fda126340fcc201461ee8bfea5c8bdb1c7c958b/scipy-1.15.3-cp313-cp313t-macosx_14_0_x86_64.whl", hash = "sha256:14ed70039d182f411ffc74789a16df3835e05dc469b898233a245cdfd7f162cb", size = 25218709, upload-time = "2025-05-08T16:07:58.506Z" }, - { url = "https://files.pythonhosted.org/packages/24/18/9e5374b617aba742a990581373cd6b68a2945d65cc588482749ef2e64467/scipy-1.15.3-cp313-cp313t-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:0a769105537aa07a69468a0eefcd121be52006db61cdd8cac8a0e68980bbb723", size = 34809045, upload-time = "2025-05-08T16:08:03.929Z" }, - { url = "https://files.pythonhosted.org/packages/e1/fe/9c4361e7ba2927074360856db6135ef4904d505e9b3afbbcb073c4008328/scipy-1.15.3-cp313-cp313t-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:9db984639887e3dffb3928d118145ffe40eff2fa40cb241a306ec57c219ebbbb", size = 36703062, upload-time = "2025-05-08T16:08:09.558Z" }, - { url = "https://files.pythonhosted.org/packages/b7/8e/038ccfe29d272b30086b25a4960f757f97122cb2ec42e62b460d02fe98e9/scipy-1.15.3-cp313-cp313t-musllinux_1_2_aarch64.whl", hash = "sha256:40e54d5c7e7ebf1aa596c374c49fa3135f04648a0caabcb66c52884b943f02b4", size = 36393132, upload-time = "2025-05-08T16:08:15.34Z" }, - { url = "https://files.pythonhosted.org/packages/10/7e/5c12285452970be5bdbe8352c619250b97ebf7917d7a9a9e96b8a8140f17/scipy-1.15.3-cp313-cp313t-musllinux_1_2_x86_64.whl", hash = "sha256:5e721fed53187e71d0ccf382b6bf977644c533e506c4d33c3fb24de89f5c3ed5", size = 38979503, upload-time = "2025-05-08T16:08:21.513Z" }, - { url = "https://files.pythonhosted.org/packages/81/06/0a5e5349474e1cbc5757975b21bd4fad0e72ebf138c5592f191646154e06/scipy-1.15.3-cp313-cp313t-win_amd64.whl", hash = "sha256:76ad1fb5f8752eabf0fa02e4cc0336b4e8f021e2d5f061ed37d6d264db35e3ca", size = 40308097, upload-time = "2025-05-08T16:08:27.627Z" }, -] - -[[package]] -name = "sentencepiece" -version = "0.2.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/c9/d2/b9c7ca067c26d8ff085d252c89b5f69609ca93fb85a00ede95f4857865d4/sentencepiece-0.2.0.tar.gz", hash = "sha256:a52c19171daaf2e697dc6cbe67684e0fa341b1248966f6aebb541de654d15843", size = 2632106, upload-time = "2024-02-19T17:06:47.428Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/f6/71/98648c3b64b23edb5403f74bcc906ad21766872a6e1ada26ea3f1eb941ab/sentencepiece-0.2.0-cp310-cp310-macosx_10_9_universal2.whl", hash = "sha256:188779e1298a1c8b8253c7d3ad729cb0a9891e5cef5e5d07ce4592c54869e227", size = 2408979, upload-time = "2024-02-19T17:05:34.651Z" }, - { url = "https://files.pythonhosted.org/packages/77/9f/7efbaa6d4c0c718a9affbecc536b03ca62f99f421bdffb531c16030e2d2b/sentencepiece-0.2.0-cp310-cp310-macosx_10_9_x86_64.whl", hash = "sha256:bed9cf85b296fa2b76fc2547b9cbb691a523864cebaee86304c43a7b4cb1b452", size = 1238845, upload-time = "2024-02-19T17:05:37.371Z" }, - { url = "https://files.pythonhosted.org/packages/1c/e4/c2541027a43ec6962ba9b601805d17ba3f86b38bdeae0e8ac65a2981e248/sentencepiece-0.2.0-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:d7b67e724bead13f18db6e1d10b6bbdc454af574d70efbb36f27d90387be1ca3", size = 1181472, upload-time = "2024-02-19T17:05:39.775Z" }, - { url = "https://files.pythonhosted.org/packages/fd/46/316c1ba6c52b97de76aff7b9da678f7afbb52136afb2987c474d95630e65/sentencepiece-0.2.0-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:2fde4b08cfe237be4484c6c7c2e2c75fb862cfeab6bd5449ce4caeafd97b767a", size = 1259151, upload-time = "2024-02-19T17:05:42.594Z" }, - { url = "https://files.pythonhosted.org/packages/aa/5a/3c48738a0835d76dd06c62b6ac48d39c923cde78dd0f587353bdcbb99851/sentencepiece-0.2.0-cp310-cp310-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:4c378492056202d1c48a4979650981635fd97875a00eabb1f00c6a236b013b5e", size = 1355931, upload-time = "2024-02-19T17:05:44.695Z" }, - { url = "https://files.pythonhosted.org/packages/a6/27/33019685023221ca8ed98e8ceb7ae5e166032686fa3662c68f1f1edf334e/sentencepiece-0.2.0-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:1380ce6540a368de2ef6d7e6ba14ba8f3258df650d39ba7d833b79ee68a52040", size = 1301537, upload-time = "2024-02-19T17:05:46.713Z" }, - { url = "https://files.pythonhosted.org/packages/ca/e4/55f97cef14293171fef5f96e96999919ab5b4d1ce95b53547ad653d7e3bf/sentencepiece-0.2.0-cp310-cp310-win32.whl", hash = "sha256:a1151d6a6dd4b43e552394aed0edfe9292820272f0194bd56c7c1660a0c06c3d", size = 936747, upload-time = "2024-02-19T17:05:48.705Z" }, - { url = "https://files.pythonhosted.org/packages/85/f4/4ef1a6e0e9dbd8a60780a91df8b7452ada14cfaa0e17b3b8dfa42cecae18/sentencepiece-0.2.0-cp310-cp310-win_amd64.whl", hash = "sha256:d490142b0521ef22bc1085f061d922a2a6666175bb6b42e588ff95c0db6819b2", size = 991525, upload-time = "2024-02-19T17:05:55.145Z" }, - { url = "https://files.pythonhosted.org/packages/32/43/8f8885168a47a02eba1455bd3f4f169f50ad5b8cebd2402d0f5e20854d04/sentencepiece-0.2.0-cp311-cp311-macosx_10_9_universal2.whl", hash = "sha256:17982700c4f6dbb55fa3594f3d7e5dd1c8659a274af3738e33c987d2a27c9d5c", size = 2409036, upload-time = "2024-02-19T17:05:58.021Z" }, - { url = "https://files.pythonhosted.org/packages/0f/35/e63ba28062af0a3d688a9f128e407a1a2608544b2f480cb49bf7f4b1cbb9/sentencepiece-0.2.0-cp311-cp311-macosx_10_9_x86_64.whl", hash = "sha256:7c867012c0e8bcd5bdad0f791609101cb5c66acb303ab3270218d6debc68a65e", size = 1238921, upload-time = "2024-02-19T17:06:06.434Z" }, - { url = "https://files.pythonhosted.org/packages/de/42/ae30952c4a0bd773e90c9bf2579f5533037c886dfc8ec68133d5694f4dd2/sentencepiece-0.2.0-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:7fd6071249c74f779c5b27183295b9202f8dedb68034e716784364443879eaa6", size = 1181477, upload-time = "2024-02-19T17:06:09.292Z" }, - { url = "https://files.pythonhosted.org/packages/e3/ac/2f2ab1d60bb2d795d054eebe5e3f24b164bc21b5a9b75fba7968b3b91b5a/sentencepiece-0.2.0-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:27f90c55a65013cbb8f4d7aab0599bf925cde4adc67ae43a0d323677b5a1c6cb", size = 1259182, upload-time = "2024-02-19T17:06:16.459Z" }, - { url = "https://files.pythonhosted.org/packages/45/fb/14633c6ecf262c468759ffcdb55c3a7ee38fe4eda6a70d75ee7c7d63c58b/sentencepiece-0.2.0-cp311-cp311-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:b293734059ef656dcd65be62ff771507bea8fed0a711b6733976e1ed3add4553", size = 1355537, upload-time = "2024-02-19T17:06:19.274Z" }, - { url = "https://files.pythonhosted.org/packages/fb/12/2f5c8d4764b00033cf1c935b702d3bb878d10be9f0b87f0253495832d85f/sentencepiece-0.2.0-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:e58b47f933aca74c6a60a79dcb21d5b9e47416256c795c2d58d55cec27f9551d", size = 1301464, upload-time = "2024-02-19T17:06:21.796Z" }, - { url = "https://files.pythonhosted.org/packages/4e/b1/67afc0bde24f6dcb3acdea0dd8dcdf4b8b0db240f6bacd39378bd32d09f8/sentencepiece-0.2.0-cp311-cp311-win32.whl", hash = "sha256:c581258cf346b327c62c4f1cebd32691826306f6a41d8c4bec43b010dee08e75", size = 936749, upload-time = "2024-02-19T17:06:24.167Z" }, - { url = "https://files.pythonhosted.org/packages/a2/f6/587c62fd21fc988555b85351f50bbde43a51524caafd63bc69240ded14fd/sentencepiece-0.2.0-cp311-cp311-win_amd64.whl", hash = "sha256:0993dbc665f4113017892f1b87c3904a44d0640eda510abcacdfb07f74286d36", size = 991520, upload-time = "2024-02-19T17:06:26.936Z" }, - { url = "https://files.pythonhosted.org/packages/27/5a/141b227ed54293360a9ffbb7bf8252b4e5efc0400cdeac5809340e5d2b21/sentencepiece-0.2.0-cp312-cp312-macosx_10_9_universal2.whl", hash = "sha256:ea5f536e32ea8ec96086ee00d7a4a131ce583a1b18d130711707c10e69601cb2", size = 2409370, upload-time = "2024-02-19T17:06:29.315Z" }, - { url = "https://files.pythonhosted.org/packages/2e/08/a4c135ad6fc2ce26798d14ab72790d66e813efc9589fd30a5316a88ca8d5/sentencepiece-0.2.0-cp312-cp312-macosx_10_9_x86_64.whl", hash = "sha256:d0cb51f53b6aae3c36bafe41e86167c71af8370a039f542c43b0cce5ef24a68c", size = 1239288, upload-time = "2024-02-19T17:06:31.674Z" }, - { url = "https://files.pythonhosted.org/packages/49/0a/2fe387f825ac5aad5a0bfe221904882106cac58e1b693ba7818785a882b6/sentencepiece-0.2.0-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:3212121805afc58d8b00ab4e7dd1f8f76c203ddb9dc94aa4079618a31cf5da0f", size = 1181597, upload-time = "2024-02-19T17:06:33.763Z" }, - { url = "https://files.pythonhosted.org/packages/cc/38/e4698ee2293fe4835dc033c49796a39b3eebd8752098f6bd0aa53a14af1f/sentencepiece-0.2.0-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:2a3149e3066c2a75e0d68a43eb632d7ae728c7925b517f4c05c40f6f7280ce08", size = 1259220, upload-time = "2024-02-19T17:06:35.85Z" }, - { url = "https://files.pythonhosted.org/packages/12/24/fd7ef967c9dad2f6e6e5386d0cadaf65cda8b7be6e3861a9ab3121035139/sentencepiece-0.2.0-cp312-cp312-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:632f3594d3e7ac8b367bca204cb3fd05a01d5b21455acd097ea4c0e30e2f63d7", size = 1355962, upload-time = "2024-02-19T17:06:38.616Z" }, - { url = "https://files.pythonhosted.org/packages/4f/d2/18246f43ca730bb81918f87b7e886531eda32d835811ad9f4657c54eee35/sentencepiece-0.2.0-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:f295105c6bdbb05bd5e1b0cafbd78ff95036f5d3641e7949455a3f4e5e7c3109", size = 1301706, upload-time = "2024-02-19T17:06:40.712Z" }, - { url = "https://files.pythonhosted.org/packages/8a/47/ca237b562f420044ab56ddb4c278672f7e8c866e183730a20e413b38a989/sentencepiece-0.2.0-cp312-cp312-win32.whl", hash = "sha256:fb89f811e5efd18bab141afc3fea3de141c3f69f3fe9e898f710ae7fe3aab251", size = 936941, upload-time = "2024-02-19T17:06:42.802Z" }, - { url = "https://files.pythonhosted.org/packages/c6/97/d159c32642306ee2b70732077632895438867b3b6df282354bd550cf2a67/sentencepiece-0.2.0-cp312-cp312-win_amd64.whl", hash = "sha256:7a673a72aab81fef5ebe755c6e0cc60087d1f3a4700835d40537183c1703a45f", size = 991994, upload-time = "2024-02-19T17:06:45.01Z" }, -] - -[[package]] -name = "setuptools" -version = "80.9.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/18/5d/3bf57dcd21979b887f014ea83c24ae194cfcd12b9e0fda66b957c69d1fca/setuptools-80.9.0.tar.gz", hash = "sha256:f36b47402ecde768dbfafc46e8e4207b4360c654f1f3bb84475f0a28628fb19c", size = 1319958, upload-time = "2025-05-27T00:56:51.443Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/a3/dc/17031897dae0efacfea57dfd3a82fdd2a2aeb58e0ff71b77b87e44edc772/setuptools-80.9.0-py3-none-any.whl", hash = "sha256:062d34222ad13e0cc312a4c02d73f059e86a4acbfbdea8f8f76b28c99f306922", size = 1201486, upload-time = "2025-05-27T00:56:49.664Z" }, -] - -[[package]] -name = "shellingham" -version = "1.5.4" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/58/15/8b3609fd3830ef7b27b655beb4b4e9c62313a4e8da8c676e142cc210d58e/shellingham-1.5.4.tar.gz", hash = "sha256:8dbca0739d487e5bd35ab3ca4b36e11c4078f3a234bfce294b0a0291363404de", size = 10310, upload-time = "2023-10-24T04:13:40.426Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/e0/f9/0595336914c5619e5f28a1fb793285925a8cd4b432c9da0a987836c7f822/shellingham-1.5.4-py2.py3-none-any.whl", hash = "sha256:7ecfff8f2fd72616f7481040475a65b2bf8af90a56c89140852d1120324e8686", size = 9755, upload-time = "2023-10-24T04:13:38.866Z" }, -] - -[[package]] -name = "simplejson" -version = "3.20.1" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/af/92/51b417685abd96b31308b61b9acce7ec50d8e1de8fbc39a7fd4962c60689/simplejson-3.20.1.tar.gz", hash = "sha256:e64139b4ec4f1f24c142ff7dcafe55a22b811a74d86d66560c8815687143037d", size = 85591, upload-time = "2025-02-15T05:18:53.15Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/25/c4/627214fb418cd4a17fb0230ff0b6c3bb4a85cbb48dd69c85dcc3b85df828/simplejson-3.20.1-cp310-cp310-macosx_10_9_universal2.whl", hash = "sha256:e580aa65d5f6c3bf41b9b4afe74be5d5ddba9576701c107c772d936ea2b5043a", size = 93790, upload-time = "2025-02-15T05:15:32.954Z" }, - { url = "https://files.pythonhosted.org/packages/15/ca/56a6a2a33cbcf330c4d71af3f827c47e4e0ba791e78f2642f3d1ab02ff31/simplejson-3.20.1-cp310-cp310-macosx_10_9_x86_64.whl", hash = "sha256:4a586ce4f78cec11f22fe55c5bee0f067e803aab9bad3441afe2181693b5ebb5", size = 75707, upload-time = "2025-02-15T05:15:34.954Z" }, - { url = "https://files.pythonhosted.org/packages/a9/c8/3d92b67e03a3b6207d97202669f9454ed700b35ade9bd4428265a078fb6c/simplejson-3.20.1-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:74a1608f9e6e8c27a4008d70a54270868306d80ed48c9df7872f9f4b8ac87808", size = 75700, upload-time = "2025-02-15T05:15:37.144Z" }, - { url = "https://files.pythonhosted.org/packages/74/30/20001219d6fdca4aaa3974c96dfb6955a766b4e2cc950505a5b51fd050b0/simplejson-3.20.1-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:03db8cb64154189a92a7786209f24e391644f3a3fa335658be2df2af1960b8d8", size = 138672, upload-time = "2025-02-15T05:15:38.547Z" }, - { url = "https://files.pythonhosted.org/packages/21/47/50157810876c2a7ebbd6e6346ec25eda841fe061fecaa02538a7742a3d2a/simplejson-3.20.1-cp310-cp310-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:eea7e2b7d858f6fdfbf0fe3cb846d6bd8a45446865bc09960e51f3d473c2271b", size = 146616, upload-time = "2025-02-15T05:15:39.871Z" }, - { url = "https://files.pythonhosted.org/packages/95/60/8c97cdc93096437b0aca2745aca63c880fe2315fd7f6a6ce6edbb344a2ae/simplejson-3.20.1-cp310-cp310-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:e66712b17d8425bb7ff8968d4c7c7fd5a2dd7bd63728b28356223c000dd2f91f", size = 134344, upload-time = "2025-02-15T05:15:42.091Z" }, - { url = "https://files.pythonhosted.org/packages/bb/9e/da184f0e9bb3a5d7ffcde713bd41b4fe46cca56b6f24d9bd155fac56805a/simplejson-3.20.1-cp310-cp310-manylinux_2_5_x86_64.manylinux1_x86_64.manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:a2cc4f6486f9f515b62f5831ff1888886619b84fc837de68f26d919ba7bbdcbc", size = 138017, upload-time = "2025-02-15T05:15:43.542Z" }, - { url = "https://files.pythonhosted.org/packages/31/db/00d1a8d9b036db98f678c8a3c69ed17d2894d1768d7a00576e787ad3e546/simplejson-3.20.1-cp310-cp310-musllinux_1_2_aarch64.whl", hash = "sha256:a3c2df555ee4016148fa192e2b9cd9e60bc1d40769366134882685e90aee2a1e", size = 140118, upload-time = "2025-02-15T05:15:45.7Z" }, - { url = "https://files.pythonhosted.org/packages/52/21/57fc47eab8c1c73390b933a5ba9271f08e3e1ec83162c580357f28f5b97c/simplejson-3.20.1-cp310-cp310-musllinux_1_2_i686.whl", hash = "sha256:78520f04b7548a5e476b5396c0847e066f1e0a4c0c5e920da1ad65e95f410b11", size = 140314, upload-time = "2025-02-15T05:16:07.949Z" }, - { url = "https://files.pythonhosted.org/packages/ad/cc/7cfd78d1e0fa5e57350b98cfe77353b6dfa13dce21afa4060e1019223852/simplejson-3.20.1-cp310-cp310-musllinux_1_2_ppc64le.whl", hash = "sha256:f4bd49ecde87b0fe9f55cc971449a32832bca9910821f7072bbfae1155eaa007", size = 148544, upload-time = "2025-02-15T05:16:09.455Z" }, - { url = "https://files.pythonhosted.org/packages/63/26/1c894a1c2bd95dc8be0cf5a2fa73b0d173105b6ca18c90cb981ff10443d0/simplejson-3.20.1-cp310-cp310-musllinux_1_2_x86_64.whl", hash = "sha256:7eaae2b88eb5da53caaffdfa50e2e12022553949b88c0df4f9a9663609373f72", size = 141172, upload-time = "2025-02-15T05:16:10.966Z" }, - { url = "https://files.pythonhosted.org/packages/93/27/0717dccc10cd9988dbf1314def52ab32678a95a95328bb37cafacf499400/simplejson-3.20.1-cp310-cp310-win32.whl", hash = "sha256:e836fb88902799eac8debc2b642300748f4860a197fa3d9ea502112b6bb8e142", size = 74181, upload-time = "2025-02-15T05:16:12.361Z" }, - { url = "https://files.pythonhosted.org/packages/5f/af/593f896573f306519332d4287b1ab8b7b888c239bbd5159f7054d7055c2d/simplejson-3.20.1-cp310-cp310-win_amd64.whl", hash = "sha256:b122a19b552b212fc3b5b96fc5ce92333d4a9ac0a800803e1f17ebb16dac4be5", size = 75738, upload-time = "2025-02-15T05:16:14.438Z" }, - { url = "https://files.pythonhosted.org/packages/76/59/74bc90d1c051bc2432c96b34bd4e8036875ab58b4fcbe4d6a5a76985f853/simplejson-3.20.1-cp311-cp311-macosx_10_9_universal2.whl", hash = "sha256:325b8c107253d3217e89d7b50c71015b5b31e2433e6c5bf38967b2f80630a8ca", size = 92132, upload-time = "2025-02-15T05:16:15.743Z" }, - { url = "https://files.pythonhosted.org/packages/71/c7/1970916e0c51794fff89f76da2f632aaf0b259b87753c88a8c409623d3e1/simplejson-3.20.1-cp311-cp311-macosx_10_9_x86_64.whl", hash = "sha256:88a7baa8211089b9e58d78fbc1b0b322103f3f3d459ff16f03a36cece0d0fcf0", size = 74956, upload-time = "2025-02-15T05:16:17.062Z" }, - { url = "https://files.pythonhosted.org/packages/c8/0d/98cc5909180463f1d75fac7180de62d4cdb4e82c4fef276b9e591979372c/simplejson-3.20.1-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:299b1007b8101d50d95bc0db1bf5c38dc372e85b504cf77f596462083ee77e3f", size = 74772, upload-time = "2025-02-15T05:16:19.204Z" }, - { url = "https://files.pythonhosted.org/packages/e1/94/a30a5211a90d67725a3e8fcc1c788189f2ae2ed2b96b63ed15d0b7f5d6bb/simplejson-3.20.1-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:03ec618ed65caab48e81e3ed29586236a8e57daef792f1f3bb59504a7e98cd10", size = 143575, upload-time = "2025-02-15T05:16:21.337Z" }, - { url = "https://files.pythonhosted.org/packages/ee/08/cdb6821f1058eb5db46d252de69ff7e6c53f05f1bae6368fe20d5b51d37e/simplejson-3.20.1-cp311-cp311-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:cd2cdead1d3197f0ff43373cf4730213420523ba48697743e135e26f3d179f38", size = 153241, upload-time = "2025-02-15T05:16:22.859Z" }, - { url = "https://files.pythonhosted.org/packages/4c/2d/ca3caeea0bdc5efc5503d5f57a2dfb56804898fb196dfada121323ee0ccb/simplejson-3.20.1-cp311-cp311-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:3466d2839fdc83e1af42e07b90bc8ff361c4e8796cd66722a40ba14e458faddd", size = 141500, upload-time = "2025-02-15T05:16:25.068Z" }, - { url = "https://files.pythonhosted.org/packages/e1/33/d3e0779d5c58245e7370c98eb969275af6b7a4a5aec3b97cbf85f09ad328/simplejson-3.20.1-cp311-cp311-manylinux_2_5_x86_64.manylinux1_x86_64.manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:d492ed8e92f3a9f9be829205f44b1d0a89af6582f0cf43e0d129fa477b93fe0c", size = 144757, upload-time = "2025-02-15T05:16:28.301Z" }, - { url = "https://files.pythonhosted.org/packages/54/53/2d93128bb55861b2fa36c5944f38da51a0bc6d83e513afc6f7838440dd15/simplejson-3.20.1-cp311-cp311-musllinux_1_2_aarch64.whl", hash = "sha256:f924b485537b640dc69434565463fd6fc0c68c65a8c6e01a823dd26c9983cf79", size = 144409, upload-time = "2025-02-15T05:16:29.687Z" }, - { url = "https://files.pythonhosted.org/packages/99/4c/dac310a98f897ad3435b4bdc836d92e78f09e38c5dbf28211ed21dc59fa2/simplejson-3.20.1-cp311-cp311-musllinux_1_2_i686.whl", hash = "sha256:9e8eacf6a3491bf76ea91a8d46726368a6be0eb94993f60b8583550baae9439e", size = 146082, upload-time = "2025-02-15T05:16:31.064Z" }, - { url = "https://files.pythonhosted.org/packages/ee/22/d7ba958cfed39827335b82656b1c46f89678faecda9a7677b47e87b48ee6/simplejson-3.20.1-cp311-cp311-musllinux_1_2_ppc64le.whl", hash = "sha256:d34d04bf90b4cea7c22d8b19091633908f14a096caa301b24c2f3d85b5068fb8", size = 154339, upload-time = "2025-02-15T05:16:32.719Z" }, - { url = "https://files.pythonhosted.org/packages/b8/c8/b072b741129406a7086a0799c6f5d13096231bf35fdd87a0cffa789687fc/simplejson-3.20.1-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:69dd28d4ce38390ea4aaf212902712c0fd1093dc4c1ff67e09687c3c3e15a749", size = 147915, upload-time = "2025-02-15T05:16:34.291Z" }, - { url = "https://files.pythonhosted.org/packages/6c/46/8347e61e9cf3db5342a42f7fd30a81b4f5cf85977f916852d7674a540907/simplejson-3.20.1-cp311-cp311-win32.whl", hash = "sha256:dfe7a9da5fd2a3499436cd350f31539e0a6ded5da6b5b3d422df016444d65e43", size = 73972, upload-time = "2025-02-15T05:16:35.712Z" }, - { url = "https://files.pythonhosted.org/packages/01/85/b52f24859237b4e9d523d5655796d911ba3d46e242eb1959c45b6af5aedd/simplejson-3.20.1-cp311-cp311-win_amd64.whl", hash = "sha256:896a6c04d7861d507d800da7642479c3547060bf97419d9ef73d98ced8258766", size = 75595, upload-time = "2025-02-15T05:16:36.957Z" }, - { url = "https://files.pythonhosted.org/packages/8d/eb/34c16a1ac9ba265d024dc977ad84e1659d931c0a700967c3e59a98ed7514/simplejson-3.20.1-cp312-cp312-macosx_10_9_universal2.whl", hash = "sha256:f31c4a3a7ab18467ee73a27f3e59158255d1520f3aad74315edde7a940f1be23", size = 93100, upload-time = "2025-02-15T05:16:38.801Z" }, - { url = "https://files.pythonhosted.org/packages/41/fc/2c2c007d135894971e6814e7c0806936e5bade28f8db4dd7e2a58b50debd/simplejson-3.20.1-cp312-cp312-macosx_10_9_x86_64.whl", hash = "sha256:884e6183d16b725e113b83a6fc0230152ab6627d4d36cb05c89c2c5bccfa7bc6", size = 75464, upload-time = "2025-02-15T05:16:40.905Z" }, - { url = "https://files.pythonhosted.org/packages/0f/05/2b5ecb33b776c34bb5cace5de5d7669f9b60e3ca13c113037b2ca86edfbd/simplejson-3.20.1-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:03d7a426e416fe0d3337115f04164cd9427eb4256e843a6b8751cacf70abc832", size = 75112, upload-time = "2025-02-15T05:16:42.246Z" }, - { url = "https://files.pythonhosted.org/packages/fe/36/1f3609a2792f06cd4b71030485f78e91eb09cfd57bebf3116bf2980a8bac/simplejson-3.20.1-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:000602141d0bddfcff60ea6a6e97d5e10c9db6b17fd2d6c66199fa481b6214bb", size = 150182, upload-time = "2025-02-15T05:16:43.557Z" }, - { url = "https://files.pythonhosted.org/packages/2f/b0/053fbda38b8b602a77a4f7829def1b4f316cd8deb5440a6d3ee90790d2a4/simplejson-3.20.1-cp312-cp312-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:af8377a8af78226e82e3a4349efdde59ffa421ae88be67e18cef915e4023a595", size = 158363, upload-time = "2025-02-15T05:16:45.748Z" }, - { url = "https://files.pythonhosted.org/packages/d1/4b/2eb84ae867539a80822e92f9be4a7200dffba609275faf99b24141839110/simplejson-3.20.1-cp312-cp312-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:15c7de4c88ab2fbcb8781a3b982ef883696736134e20b1210bca43fb42ff1acf", size = 148415, upload-time = "2025-02-15T05:16:47.861Z" }, - { url = "https://files.pythonhosted.org/packages/e0/bd/400b0bd372a5666addf2540c7358bfc3841b9ce5cdbc5cc4ad2f61627ad8/simplejson-3.20.1-cp312-cp312-manylinux_2_5_x86_64.manylinux1_x86_64.manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:455a882ff3f97d810709f7b620007d4e0aca8da71d06fc5c18ba11daf1c4df49", size = 152213, upload-time = "2025-02-15T05:16:49.25Z" }, - { url = "https://files.pythonhosted.org/packages/50/12/143f447bf6a827ee9472693768dc1a5eb96154f8feb140a88ce6973a3cfa/simplejson-3.20.1-cp312-cp312-musllinux_1_2_aarch64.whl", hash = "sha256:fc0f523ce923e7f38eb67804bc80e0a028c76d7868500aa3f59225574b5d0453", size = 150048, upload-time = "2025-02-15T05:16:51.5Z" }, - { url = "https://files.pythonhosted.org/packages/5e/ea/dd9b3e8e8ed710a66f24a22c16a907c9b539b6f5f45fd8586bd5c231444e/simplejson-3.20.1-cp312-cp312-musllinux_1_2_i686.whl", hash = "sha256:76461ec929282dde4a08061071a47281ad939d0202dc4e63cdd135844e162fbc", size = 151668, upload-time = "2025-02-15T05:16:53Z" }, - { url = "https://files.pythonhosted.org/packages/99/af/ee52a8045426a0c5b89d755a5a70cc821815ef3c333b56fbcad33c4435c0/simplejson-3.20.1-cp312-cp312-musllinux_1_2_ppc64le.whl", hash = "sha256:ab19c2da8c043607bde4d4ef3a6b633e668a7d2e3d56f40a476a74c5ea71949f", size = 158840, upload-time = "2025-02-15T05:16:54.851Z" }, - { url = "https://files.pythonhosted.org/packages/68/db/ab32869acea6b5de7d75fa0dac07a112ded795d41eaa7e66c7813b17be95/simplejson-3.20.1-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:b2578bedaedf6294415197b267d4ef678fea336dd78ee2a6d2f4b028e9d07be3", size = 154212, upload-time = "2025-02-15T05:16:56.318Z" }, - { url = "https://files.pythonhosted.org/packages/fa/7a/e3132d454977d75a3bf9a6d541d730f76462ebf42a96fea2621498166f41/simplejson-3.20.1-cp312-cp312-win32.whl", hash = "sha256:339f407373325a36b7fd744b688ba5bae0666b5d340ec6d98aebc3014bf3d8ea", size = 74101, upload-time = "2025-02-15T05:16:57.746Z" }, - { url = "https://files.pythonhosted.org/packages/bc/5d/4e243e937fa3560107c69f6f7c2eed8589163f5ed14324e864871daa2dd9/simplejson-3.20.1-cp312-cp312-win_amd64.whl", hash = "sha256:627d4486a1ea7edf1f66bb044ace1ce6b4c1698acd1b05353c97ba4864ea2e17", size = 75736, upload-time = "2025-02-15T05:16:59.017Z" }, - { url = "https://files.pythonhosted.org/packages/c4/03/0f453a27877cb5a5fff16a975925f4119102cc8552f52536b9a98ef0431e/simplejson-3.20.1-cp313-cp313-macosx_10_13_universal2.whl", hash = "sha256:71e849e7ceb2178344998cbe5ade101f1b329460243c79c27fbfc51c0447a7c3", size = 93109, upload-time = "2025-02-15T05:17:00.377Z" }, - { url = "https://files.pythonhosted.org/packages/74/1f/a729f4026850cabeaff23e134646c3f455e86925d2533463420635ae54de/simplejson-3.20.1-cp313-cp313-macosx_10_13_x86_64.whl", hash = "sha256:b63fdbab29dc3868d6f009a59797cefaba315fd43cd32ddd998ee1da28e50e29", size = 75475, upload-time = "2025-02-15T05:17:02.544Z" }, - { url = "https://files.pythonhosted.org/packages/e2/14/50a2713fee8ff1f8d655b1a14f4a0f1c0c7246768a1b3b3d12964a4ed5aa/simplejson-3.20.1-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:1190f9a3ce644fd50ec277ac4a98c0517f532cfebdcc4bd975c0979a9f05e1fb", size = 75112, upload-time = "2025-02-15T05:17:03.875Z" }, - { url = "https://files.pythonhosted.org/packages/45/86/ea9835abb646755140e2d482edc9bc1e91997ed19a59fd77ae4c6a0facea/simplejson-3.20.1-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:c1336ba7bcb722ad487cd265701ff0583c0bb6de638364ca947bb84ecc0015d1", size = 150245, upload-time = "2025-02-15T05:17:06.899Z" }, - { url = "https://files.pythonhosted.org/packages/12/b4/53084809faede45da829fe571c65fbda8479d2a5b9c633f46b74124d56f5/simplejson-3.20.1-cp313-cp313-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:e975aac6a5acd8b510eba58d5591e10a03e3d16c1cf8a8624ca177491f7230f0", size = 158465, upload-time = "2025-02-15T05:17:08.707Z" }, - { url = "https://files.pythonhosted.org/packages/a9/7d/d56579468d1660b3841e1f21c14490d103e33cf911886b22652d6e9683ec/simplejson-3.20.1-cp313-cp313-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:6a6dd11ee282937ad749da6f3b8d87952ad585b26e5edfa10da3ae2536c73078", size = 148514, upload-time = "2025-02-15T05:17:11.323Z" }, - { url = "https://files.pythonhosted.org/packages/19/e3/874b1cca3d3897b486d3afdccc475eb3a09815bf1015b01cf7fcb52a55f0/simplejson-3.20.1-cp313-cp313-manylinux_2_5_x86_64.manylinux1_x86_64.manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:ab980fcc446ab87ea0879edad41a5c28f2d86020014eb035cf5161e8de4474c6", size = 152262, upload-time = "2025-02-15T05:17:13.543Z" }, - { url = "https://files.pythonhosted.org/packages/32/84/f0fdb3625292d945c2bd13a814584603aebdb38cfbe5fe9be6b46fe598c4/simplejson-3.20.1-cp313-cp313-musllinux_1_2_aarch64.whl", hash = "sha256:f5aee2a4cb6b146bd17333ac623610f069f34e8f31d2f4f0c1a2186e50c594f0", size = 150164, upload-time = "2025-02-15T05:17:15.021Z" }, - { url = "https://files.pythonhosted.org/packages/95/51/6d625247224f01eaaeabace9aec75ac5603a42f8ebcce02c486fbda8b428/simplejson-3.20.1-cp313-cp313-musllinux_1_2_i686.whl", hash = "sha256:652d8eecbb9a3b6461b21ec7cf11fd0acbab144e45e600c817ecf18e4580b99e", size = 151795, upload-time = "2025-02-15T05:17:16.542Z" }, - { url = "https://files.pythonhosted.org/packages/7f/d9/bb921df6b35be8412f519e58e86d1060fddf3ad401b783e4862e0a74c4c1/simplejson-3.20.1-cp313-cp313-musllinux_1_2_ppc64le.whl", hash = "sha256:8c09948f1a486a89251ee3a67c9f8c969b379f6ffff1a6064b41fea3bce0a112", size = 159027, upload-time = "2025-02-15T05:17:18.083Z" }, - { url = "https://files.pythonhosted.org/packages/03/c5/5950605e4ad023a6621cf4c931b29fd3d2a9c1f36be937230bfc83d7271d/simplejson-3.20.1-cp313-cp313-musllinux_1_2_x86_64.whl", hash = "sha256:cbbd7b215ad4fc6f058b5dd4c26ee5c59f72e031dfda3ac183d7968a99e4ca3a", size = 154380, upload-time = "2025-02-15T05:17:20.334Z" }, - { url = "https://files.pythonhosted.org/packages/66/ad/b74149557c5ec1e4e4d55758bda426f5d2ec0123cd01a53ae63b8de51fa3/simplejson-3.20.1-cp313-cp313-win32.whl", hash = "sha256:ae81e482476eaa088ef9d0120ae5345de924f23962c0c1e20abbdff597631f87", size = 74102, upload-time = "2025-02-15T05:17:22.475Z" }, - { url = "https://files.pythonhosted.org/packages/db/a9/25282fdd24493e1022f30b7f5cdf804255c007218b2bfaa655bd7ad34b2d/simplejson-3.20.1-cp313-cp313-win_amd64.whl", hash = "sha256:1b9fd15853b90aec3b1739f4471efbf1ac05066a2c7041bf8db821bb73cd2ddc", size = 75736, upload-time = "2025-02-15T05:17:24.122Z" }, - { url = "https://files.pythonhosted.org/packages/4b/30/00f02a0a921556dd5a6db1ef2926a1bc7a8bbbfb1c49cfed68a275b8ab2b/simplejson-3.20.1-py3-none-any.whl", hash = "sha256:8a6c1bbac39fa4a79f83cbf1df6ccd8ff7069582a9fd8db1e52cea073bc2c697", size = 57121, upload-time = "2025-02-15T05:18:51.243Z" }, -] - -[[package]] -name = "simsimd" -version = "6.4.9" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/0e/28/85d7aa0524d0f0c277404435d8d190dafb2af96e90ac262eeddab94485e4/simsimd-6.4.9.tar.gz", hash = "sha256:80c194f4bc5ad2cd22d793471a5775189d503e7bea3ce5bc5d6362381abe1cd2", size = 169091, upload-time = "2025-06-08T03:56:02.198Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/1a/e1/ceaaba953c93250b10d0a2c259166f22a5accbd338a9317adcb66ec3a5e5/simsimd-6.4.9-cp310-cp310-macosx_10_9_x86_64.whl", hash = "sha256:d45df3dc53da6614d8776252048c9adf8a5cad4d60eb0b40057a15e62c161376", size = 177714, upload-time = "2025-06-08T03:52:57.867Z" }, - { url = "https://files.pythonhosted.org/packages/a6/2c/b4380495f168dad919a1b7579ed4b56e841b4afef59eeef96d3cfc85c665/simsimd-6.4.9-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:bc21497555d95640c12e32cec30fa9d8d66f8712710852f97303e397ab3ceba5", size = 132626, upload-time = "2025-06-08T03:53:01.455Z" }, - { url = "https://files.pythonhosted.org/packages/74/78/7d0ef530fd8e8cb72356d8e8c68ff14833f1f5102713bc29db949d1ffac9/simsimd-6.4.9-cp310-cp310-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:49ce9e58bcb678a69bcb1e6f3059e2e926dcab274a3b554f46865a5fdba2b9b4", size = 333541, upload-time = "2025-06-08T03:53:03.338Z" }, - { url = "https://files.pythonhosted.org/packages/45/a5/7639a2e0f965a23f1fa843d57ac88062212ec7a93fa8bd2ac2828fcf89ed/simsimd-6.4.9-cp310-cp310-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:e64425fc9f0099f853fa921fd94491c6877971c435eeb7cfc45028efc9db2995", size = 413076, upload-time = "2025-06-08T03:53:05.137Z" }, - { url = "https://files.pythonhosted.org/packages/d1/3f/2eced8c5a6976014e036cef980b5616b0b724c0c338b7d791c7bf0709d0f/simsimd-6.4.9-cp310-cp310-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:66a99ab29f8849484e525588b75b1238b3e5b83eb91decc57c295a806836f4bb", size = 272531, upload-time = "2025-06-08T03:53:07.201Z" }, - { url = "https://files.pythonhosted.org/packages/d7/48/8cbc44e34e3efd18cdbff901ca252a54f0e62d68f668d586583ef83c7402/simsimd-6.4.9-cp310-cp310-manylinux_2_28_aarch64.whl", hash = "sha256:09516dbebc9e1d909e50ff6ac57c09dce1b02402a8155a21f87ca732daa07600", size = 607220, upload-time = "2025-06-08T03:53:09.19Z" }, - { url = "https://files.pythonhosted.org/packages/b2/ae/f28b4ec854833c6f1335a74a7b4166182ab479da0269246713ae98ab920e/simsimd-6.4.9-cp310-cp310-manylinux_2_28_x86_64.whl", hash = "sha256:616583257c09977024b30e1c588294b49a7cd2e18647e97738eed91d3252e006", size = 1095252, upload-time = "2025-06-08T03:53:11.454Z" }, - { url = "https://files.pythonhosted.org/packages/e4/85/e9ab3861ff3946064f9f7d1e5edb8989780b16aaf9b872edc2060df06cb6/simsimd-6.4.9-cp310-cp310-musllinux_1_2_aarch64.whl", hash = "sha256:2914e271e228ddf29dcf633824e7030b9d533d7a73d47b4a2764d1d965dbbc6f", size = 650015, upload-time = "2025-06-08T03:53:13.76Z" }, - { url = "https://files.pythonhosted.org/packages/96/0e/309eb479fe8ef2f1d5a1c731e4d8b8321d2c16c682be81ceebb60cdb6f5c/simsimd-6.4.9-cp310-cp310-musllinux_1_2_i686.whl", hash = "sha256:105888809d0de489066831b48d5a38baa4849e48b265b4e23f5beb65c0860ce1", size = 421842, upload-time = "2025-06-08T03:53:15.863Z" }, - { url = "https://files.pythonhosted.org/packages/ed/a7/db454e80a40eaf642b0532583d649d5e6db08c413fc1d18b975d465b93b4/simsimd-6.4.9-cp310-cp310-musllinux_1_2_ppc64le.whl", hash = "sha256:14d9a422c15912ab56868329150d685e6589cf60e1f0fe5c2253dda6fa73b03a", size = 531092, upload-time = "2025-06-08T03:53:17.431Z" }, - { url = "https://files.pythonhosted.org/packages/d2/3c/7abaa9e825b58aa3cdffa2011c2667f4bb5ccb1697d361a90ebba6d43feb/simsimd-6.4.9-cp310-cp310-musllinux_1_2_s390x.whl", hash = "sha256:28b62945195124b07b0d4b2ce1318551c7df253b5e783fa7a88a84a36c419fb1", size = 380016, upload-time = "2025-06-08T03:53:19.136Z" }, - { url = "https://files.pythonhosted.org/packages/26/0d/d2dc2282fd5152b9de4b474f78e4deb268989b9c872593e0a3e086d53c24/simsimd-6.4.9-cp310-cp310-musllinux_1_2_x86_64.whl", hash = "sha256:6b2bfd5a586e2d2de7012f02402aac172064c8dec5193cc551b0e26df0a1f100", size = 1030427, upload-time = "2025-06-08T03:53:20.664Z" }, - { url = "https://files.pythonhosted.org/packages/ab/ce/9d2c303890aa6060dce7a404d69f9a03c01500955c701c262fcdda62dc61/simsimd-6.4.9-cp310-cp310-win_amd64.whl", hash = "sha256:f88dd11a9661a36815a419f563354b09cfab82fa5de973279c87a43a84423d93", size = 94973, upload-time = "2025-06-08T03:53:22.357Z" }, - { url = "https://files.pythonhosted.org/packages/db/eb/8338ce28017f99ca7a75466341a6b8f0b5f6917cf1d77ea3055cd34bf1a8/simsimd-6.4.9-cp310-cp310-win_arm64.whl", hash = "sha256:8ff701acd0841f9ad1bfd00811d66d04559698e07a3080ae7d6c3c85ec4a62d9", size = 58102, upload-time = "2025-06-08T03:53:23.838Z" }, - { url = "https://files.pythonhosted.org/packages/73/59/d8dc90461100eab2dbeae5c99f988c5c112b9a0fee3eee3873f6cd71727f/simsimd-6.4.9-cp311-cp311-macosx_10_9_x86_64.whl", hash = "sha256:276eba8b3d5451d3e2f88f94d886b13c1530cffe870221970f23aa7b64118fa8", size = 177713, upload-time = "2025-06-08T03:53:25.448Z" }, - { url = "https://files.pythonhosted.org/packages/d4/7a/90ce868080d4bc0e53505900c7ac391ee812ef83f00566357d9db93a7eac/simsimd-6.4.9-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:7771ef90a2c144b77ff71fcf7e88aebca429f9af1a2517c66766898764bf81b2", size = 132625, upload-time = "2025-06-08T03:53:26.91Z" }, - { url = "https://files.pythonhosted.org/packages/13/10/4a30334e54d659bd13269363067abb5ca860f4f409911129a7470ba45103/simsimd-6.4.9-cp311-cp311-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:71925a967b02f6945523d4b42d5f9f528d81a53dbb04da3f322218bf06443021", size = 333530, upload-time = "2025-06-08T03:53:28.373Z" }, - { url = "https://files.pythonhosted.org/packages/95/56/d0d7b203709e033beb51e7f79ff7089d8dc2ee7752f83a2694661f23fed6/simsimd-6.4.9-cp311-cp311-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:0a9c98420944edc41350129c53c13b5b127ed3240d551c4c6a691684ca575f7a", size = 413045, upload-time = "2025-06-08T03:53:30.437Z" }, - { url = "https://files.pythonhosted.org/packages/3c/48/fa95c11f3b042df6ad479439f0325d3a8e8567346909b4e5f5d6201f4b0a/simsimd-6.4.9-cp311-cp311-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:fa7837de739d9654d708536db60afd1e5cc1dad727e32e2ee7de74564ddc642f", size = 272495, upload-time = "2025-06-08T03:53:31.999Z" }, - { url = "https://files.pythonhosted.org/packages/9d/9b/908b146d89e7cfc9879e74b36eb59fbd43562ddc1ba4bec33def6e369052/simsimd-6.4.9-cp311-cp311-manylinux_2_28_aarch64.whl", hash = "sha256:a08a7b2f58763d1477f3e67007c2e4deda9793efdb80b6905f35a324c01f9fc3", size = 607206, upload-time = "2025-06-08T03:53:33.551Z" }, - { url = "https://files.pythonhosted.org/packages/b2/cf/b37cf76a0c32fce85f100c0f35025f57f4bcae84b8436960774418b7d266/simsimd-6.4.9-cp311-cp311-manylinux_2_28_x86_64.whl", hash = "sha256:20ff187fcd78246907769ae920ce69586c628672a8b4a100f05ce6e61940424d", size = 1095207, upload-time = "2025-06-08T03:53:35.728Z" }, - { url = "https://files.pythonhosted.org/packages/5e/85/39b0790112e840efedbd06cfbc46f8c622f86ff33dbc1753fc97ddbd1624/simsimd-6.4.9-cp311-cp311-musllinux_1_2_aarch64.whl", hash = "sha256:fbddc1a553793b0afd9f350cffe9d06dfc493695d4bf1308fa1ebe84639e3ca0", size = 649992, upload-time = "2025-06-08T03:53:37.979Z" }, - { url = "https://files.pythonhosted.org/packages/32/29/9085c535ee152b50b0a68f2da384dc8c97c5d90411f2c037a9b42c8a4b09/simsimd-6.4.9-cp311-cp311-musllinux_1_2_i686.whl", hash = "sha256:d2eeef1bfc2df1767fdd64141718b78d01eb1d8f5278d5fcfd226c1c577e76ca", size = 421829, upload-time = "2025-06-08T03:53:39.896Z" }, - { url = "https://files.pythonhosted.org/packages/eb/56/6add93efc6a778e3e0b1145d3b7b6aa40d63008d77a74d4bbfea219fdf46/simsimd-6.4.9-cp311-cp311-musllinux_1_2_ppc64le.whl", hash = "sha256:2a8992120e19054f4569d5214bea569802390baa6bba23e0622f9d1bc47bb6ae", size = 531098, upload-time = "2025-06-08T03:53:41.869Z" }, - { url = "https://files.pythonhosted.org/packages/dc/49/a2c3ef816b4bf949635f500deb9713c030760926baeb61aae9aa5096b063/simsimd-6.4.9-cp311-cp311-musllinux_1_2_s390x.whl", hash = "sha256:f254b842b761f1786466e71f89a346f364c9af2f12207cc6277b9c6616544025", size = 379969, upload-time = "2025-06-08T03:53:43.428Z" }, - { url = "https://files.pythonhosted.org/packages/48/84/51b560254273eadec57d210d5c3ed5ec8f04b1c26e935731d37a02d3bdb4/simsimd-6.4.9-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:26645fd5c8d4b922abd6da39704f8e91e45f08c36f802e1d1012442a6a85405f", size = 1030392, upload-time = "2025-06-08T03:53:44.992Z" }, - { url = "https://files.pythonhosted.org/packages/27/a8/75b3a36f2af8f5b5c3c5c783122571c618375837441e8eaa964134c0807f/simsimd-6.4.9-cp311-cp311-win_amd64.whl", hash = "sha256:d4ca57003aae965b0ca31ed7695709475208e5cc31a5ba43fa0e49571df317a5", size = 94978, upload-time = "2025-06-08T03:53:47.18Z" }, - { url = "https://files.pythonhosted.org/packages/ef/3d/160482c578fc18d13bb4755a615139cd47617caf0e11fc028f0a04c2f11e/simsimd-6.4.9-cp311-cp311-win_arm64.whl", hash = "sha256:eab0730ef99193f7b2b0aeebe8eb57d0634705904b2a169d37937c09502316fd", size = 58096, upload-time = "2025-06-08T03:53:49.174Z" }, - { url = "https://files.pythonhosted.org/packages/aa/9e/ab8374840916dd4888842b68372c4337edc61374e3df21b37f4eb985747f/simsimd-6.4.9-cp312-cp312-macosx_10_13_x86_64.whl", hash = "sha256:cfdc1f37e37bd8bf18e0759d19652f6fc2aea7ff943e3b7346bc7d696caacca0", size = 176315, upload-time = "2025-06-08T03:53:50.67Z" }, - { url = "https://files.pythonhosted.org/packages/28/f2/512fb83f9fbfb3b0370621c0dba577086a970096cf42ed33525ccdf7169f/simsimd-6.4.9-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:4721c34e1947627b690828dc70a4a9a3305aeb35702b9cdbf81a7e3069b04271", size = 132645, upload-time = "2025-06-08T03:53:52.255Z" }, - { url = "https://files.pythonhosted.org/packages/93/78/8b22ee99709e77c88c44755475ada7300f20ce84e53176fc4384c60b0f56/simsimd-6.4.9-cp312-cp312-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:9c181a71cbdce4884e074d31c3b4c272df5617f34f37328ead7a0e24c80eb7ba", size = 334025, upload-time = "2025-06-08T03:53:53.698Z" }, - { url = "https://files.pythonhosted.org/packages/db/ed/1c3ee63381c1fb309e52393783baa95e5511978bb97bf8d53fb6d3b3b49a/simsimd-6.4.9-cp312-cp312-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:a43c01a1a975813c2e8afe64a93799336a64f27913c7fe9eb85f69f48399a9b9", size = 413672, upload-time = "2025-06-08T03:53:55.315Z" }, - { url = "https://files.pythonhosted.org/packages/2c/f6/b1ceabd4fe3fbf6894088ffa03e757d40d85ca29a5a80e8e738948f2836a/simsimd-6.4.9-cp312-cp312-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:db26511c3bf22e287053746c1ec1186047986479d6694244b55fca8524dda337", size = 273356, upload-time = "2025-06-08T03:53:57.432Z" }, - { url = "https://files.pythonhosted.org/packages/8b/dc/82c5346e2e6b8912670345d92551740b5123c56b63820d82906d59bd1dcb/simsimd-6.4.9-cp312-cp312-manylinux_2_28_aarch64.whl", hash = "sha256:960e9e111f71b3e7eb28abe37c42680533b4aded1b7faccdfe91ebe9bebe106b", size = 607312, upload-time = "2025-06-08T03:53:59.205Z" }, - { url = "https://files.pythonhosted.org/packages/40/c5/86ba69dcd5d53a1f846230d7ba2a1c414ec7000759e2fd80ae8d9d257bb6/simsimd-6.4.9-cp312-cp312-manylinux_2_28_x86_64.whl", hash = "sha256:7da3e71c4b635c94da85f1933a19a1f9890eeb38387f0584f83a266064303bb1", size = 1095404, upload-time = "2025-06-08T03:54:00.926Z" }, - { url = "https://files.pythonhosted.org/packages/9b/a6/ad9357c2371f231c6cdbaf350de4b8b84a238e846c7f0790b8f874707790/simsimd-6.4.9-cp312-cp312-musllinux_1_2_aarch64.whl", hash = "sha256:a26b626dc27040bd307c7b62ee714159d7fbb396ee000e1edc7874705b1444e1", size = 650024, upload-time = "2025-06-08T03:54:02.784Z" }, - { url = "https://files.pythonhosted.org/packages/14/4d/879b93feccf96b8ab2fd54260c9fa40a62a5d0e0cf9391016476fce06eff/simsimd-6.4.9-cp312-cp312-musllinux_1_2_i686.whl", hash = "sha256:bc7780dacbe535240e6b4a6ad8f2517a5512a0d04490b045d42bd98cfd7917f4", size = 421988, upload-time = "2025-06-08T03:54:04.61Z" }, - { url = "https://files.pythonhosted.org/packages/35/fd/f96fa5172c9633ab45d46e4f4560a459626b31026c0a8147c3064851f7dd/simsimd-6.4.9-cp312-cp312-musllinux_1_2_ppc64le.whl", hash = "sha256:2d8448082f5fb33efb20a41236aa6bdb1b6dc061b2ac78016857582ea06d6abb", size = 531178, upload-time = "2025-06-08T03:54:06.368Z" }, - { url = "https://files.pythonhosted.org/packages/fc/28/2ac37c80483dcb54b1b5f51feb1f59996ce3831d7959bf35a41b5bb7393f/simsimd-6.4.9-cp312-cp312-musllinux_1_2_s390x.whl", hash = "sha256:7452c4fd76ecde1b35aa972e5d5db77e9c673e0df9d15553ce5c166f48def392", size = 380318, upload-time = "2025-06-08T03:54:08.05Z" }, - { url = "https://files.pythonhosted.org/packages/41/00/a10a8d891dc42a54e7a8ee6dc7aefb793d2bdaacc87c096b76cccb69f9a9/simsimd-6.4.9-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:20ba1b58612ddfde05e8372d203d98920f954c75926c3c4cc962bcee4724a3d3", size = 1030783, upload-time = "2025-06-08T03:54:10.311Z" }, - { url = "https://files.pythonhosted.org/packages/47/c0/3799e43c59726332ca9e5215f7794627d96aff75f37eabc9f2fb48b733c6/simsimd-6.4.9-cp312-cp312-win_amd64.whl", hash = "sha256:35c80be64a30c3c07826957ba66357227b808ea4ccc06a447ef3ca6f347715bb", size = 95250, upload-time = "2025-06-08T03:54:12.093Z" }, - { url = "https://files.pythonhosted.org/packages/99/29/ef71257d7f8519a332dd3645fda0bc23c5dc8f53c2c5b4f6d38e71f64396/simsimd-6.4.9-cp312-cp312-win_arm64.whl", hash = "sha256:f17797f73dae9132612d5a42bc90f585dabc15cafdf7e6a96a25a815c9f63a57", size = 58286, upload-time = "2025-06-08T03:54:13.568Z" }, - { url = "https://files.pythonhosted.org/packages/4c/6e/fd8648b7fe7759575e9aa619010fca9ee7d6de02c1271c5bb1569d2fdecb/simsimd-6.4.9-cp313-cp313-macosx_10_13_x86_64.whl", hash = "sha256:ef95d7976e844105752f2b8882215d1a08af829d7467000072674396d9f703f3", size = 176321, upload-time = "2025-06-08T03:54:15.125Z" }, - { url = "https://files.pythonhosted.org/packages/a9/68/957341fafe359649d6f0decb56872d7aed79c7b8496efde977469eb0e5a2/simsimd-6.4.9-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:718cf185822b6b89f2caca01253fc55a50a40fc99fcd8cb32d4bcd0da18e4ed2", size = 132646, upload-time = "2025-06-08T03:54:16.831Z" }, - { url = "https://files.pythonhosted.org/packages/83/8f/9f82547557f5d8ec51a48c92b4df3632b32bffc6788ceed9c3b698acf875/simsimd-6.4.9-cp313-cp313-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:681beed1c44098b17e83adb3e3f356be1353eaa1b5a21de6bcafbfd3e847c069", size = 334067, upload-time = "2025-06-08T03:54:18.332Z" }, - { url = "https://files.pythonhosted.org/packages/89/0f/44b39e12eef2291cd305b48d39889b84d396128063ab20e8cc84b4061b75/simsimd-6.4.9-cp313-cp313-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:8baf2f1a1f3886ef5c3fdaa7586a923b71e1e730db81cb5f63fcb185e1541e62", size = 413728, upload-time = "2025-06-08T03:54:20.533Z" }, - { url = "https://files.pythonhosted.org/packages/d5/35/63a1eacb40a03cb91552e15f024624b590b4b1f35176a778ee878a7a3c5c/simsimd-6.4.9-cp313-cp313-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:7cfb387ac2c9bb27aa7d2d319a976071af3f34e5ad7bc9f9d1ba2a91fda0caa6", size = 273394, upload-time = "2025-06-08T03:54:22.211Z" }, - { url = "https://files.pythonhosted.org/packages/66/d0/e24c93332a90ca1b844ab291f18a9529c788b379a4defef94e466165eae3/simsimd-6.4.9-cp313-cp313-manylinux_2_28_aarch64.whl", hash = "sha256:61453bbce274e3e0b25d8d65c5f83f1a760c154da4a6aa82a47085c25015ff85", size = 607344, upload-time = "2025-06-08T03:54:24.31Z" }, - { url = "https://files.pythonhosted.org/packages/15/58/0979a6ccd70fabaf594f3067c0aee0ee9bf03d496875cbc25cdf61ff1ff6/simsimd-6.4.9-cp313-cp313-manylinux_2_28_x86_64.whl", hash = "sha256:d1f14a5ca3bae1db22b1eff2c2179de8658d2a56cfecd6eeeb19d3b80c155f33", size = 1095438, upload-time = "2025-06-08T03:54:26.566Z" }, - { url = "https://files.pythonhosted.org/packages/fb/cf/df8aad6282c59bd419b23eee933a4f5ee1ed4f6db88b1a74972bc830ae23/simsimd-6.4.9-cp313-cp313-musllinux_1_2_aarch64.whl", hash = "sha256:c2ff0c205e61740af7bf7e572e8f650dc6a80ee1a277cc672db82923a42cd4a2", size = 650032, upload-time = "2025-06-08T03:54:28.832Z" }, - { url = "https://files.pythonhosted.org/packages/14/c4/9a34b3ef213d25c4b91bd0a6f17aa8c7114ddfff2b2a5b60924fcdc66f62/simsimd-6.4.9-cp313-cp313-musllinux_1_2_i686.whl", hash = "sha256:59e3dd3587d6f7ad40cc7aadbd6ea2f953f7bc3fb1c3c606da8c1b832b0d64df", size = 422049, upload-time = "2025-06-08T03:54:30.672Z" }, - { url = "https://files.pythonhosted.org/packages/75/c0/ecf841dd626350f6e71788771b29d188b95aef039480d1493141a59372de/simsimd-6.4.9-cp313-cp313-musllinux_1_2_ppc64le.whl", hash = "sha256:47357b759a1357d7112ae3c4d84e58bddd12dd3442c92a21303c4fc48e3582d4", size = 531212, upload-time = "2025-06-08T03:54:32.991Z" }, - { url = "https://files.pythonhosted.org/packages/a1/10/d99c3ee3c5ccb578e5802821862c79924b3b410e8348fdc9c03c45262f82/simsimd-6.4.9-cp313-cp313-musllinux_1_2_s390x.whl", hash = "sha256:54f7f845ed218ccdb2ede1df50d46ec4df0ed40721b729ddf906da17af388ed4", size = 380314, upload-time = "2025-06-08T03:54:34.818Z" }, - { url = "https://files.pythonhosted.org/packages/bf/e4/1f3088497eabc1d528970eae8ffa0d0a573f413ee35c183a2cba2dbbfaef/simsimd-6.4.9-cp313-cp313-musllinux_1_2_x86_64.whl", hash = "sha256:e368b5f697412d6879df26260e5baee866c534a8aa5cdc83ec664d41b846fa9e", size = 1030868, upload-time = "2025-06-08T03:54:37.078Z" }, - { url = "https://files.pythonhosted.org/packages/ed/2b/5bd42b570dd78d342f53936855f3d721a109df8fdd3207a4b536cd4b8756/simsimd-6.4.9-cp313-cp313-win_amd64.whl", hash = "sha256:f09223931707c6fd0828e76daee43e286134d7a9c50d2fc8e9a0ff595519e756", size = 95255, upload-time = "2025-06-08T03:54:38.85Z" }, - { url = "https://files.pythonhosted.org/packages/81/fc/e17ef18b29816f338e557778959e8bc377d87e076568a43c43ea183ba92c/simsimd-6.4.9-cp313-cp313-win_arm64.whl", hash = "sha256:c42dc27ad738712d667b4c2401bc701993ef4333887dcdbb5afa3ad33091526b", size = 58294, upload-time = "2025-06-08T03:54:40.906Z" }, -] - -[[package]] -name = "six" -version = "1.17.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/94/e7/b2c673351809dca68a0e064b6af791aa332cf192da575fd474ed7d6f16a2/six-1.17.0.tar.gz", hash = "sha256:ff70335d468e7eb6ec65b95b99d3a2836546063f63acc5171de367e834932a81", size = 34031, upload-time = "2024-12-04T17:35:28.174Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/b7/ce/149a00dd41f10bc29e5921b496af8b574d8413afcd5e30dfa0ed46c2cc5e/six-1.17.0-py2.py3-none-any.whl", hash = "sha256:4721f391ed90541fddacab5acf947aa0d3dc7d27b2e1e8eda2be8970586c3274", size = 11050, upload-time = "2024-12-04T17:35:26.475Z" }, -] - -[[package]] -name = "skia-python" -version = "138.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "pybind11" }, -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/b3/e7/1f80fb8e96f835023cda9a1303e19998fc44dd788de1b4e378f76fbff1fb/skia_python-138.0-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:a8bcf4f8d6ea08bdf718ed257f9a9c722f643223f9b93230fd4c15ac5c82029f", size = 11730779, upload-time = "2025-06-09T14:00:32.012Z" }, - { url = "https://files.pythonhosted.org/packages/9a/3e/5e58e64ba620be4b5c5a216503d79cd42d03b9de21642120bb6fe8f602c4/skia_python-138.0-cp310-cp310-macosx_11_0_x86_64.whl", hash = "sha256:1b7f24a5b306f57d75b8733658189dd61ce9114a84b5d119b3b1fb09cbc991cb", size = 12110997, upload-time = "2025-06-09T14:00:34.683Z" }, - { url = "https://files.pythonhosted.org/packages/4e/a8/7d36ed3e3ce5d8a31b268c3ad7037441f587ca21d7260c6210a4849038d6/skia_python-138.0-cp310-cp310-manylinux_2_28_aarch64.whl", hash = "sha256:2c4164013355bcf255651ac8a0ca519fd6095b6e58fa5e7a057919bec158411d", size = 13244564, upload-time = "2025-06-09T14:00:36.895Z" }, - { url = "https://files.pythonhosted.org/packages/da/09/880f8aec9b84fdeddf156bf1e19e22688a1615c7323a2c12990c66185cb3/skia_python-138.0-cp310-cp310-manylinux_2_28_x86_64.whl", hash = "sha256:63a7f9dc8d5fdda969f35d7f8f3a774029093468a9c06771ccce9ab967b275ca", size = 13732684, upload-time = "2025-06-09T14:00:39.903Z" }, - { url = "https://files.pythonhosted.org/packages/60/19/453965549c3d60f820d4370d47bd0775071702051d5bdba6c20f6014fcf2/skia_python-138.0-cp310-cp310-win_amd64.whl", hash = "sha256:740104424e9c94a70a767adcdbfa2bce131c93a82fa00a50432406dc04bac7e8", size = 10719458, upload-time = "2025-06-09T14:00:42.939Z" }, - { url = "https://files.pythonhosted.org/packages/ff/e9/ef5017013792bde58385b970e10cad1266643651a8438ad034b630d9fb5d/skia_python-138.0-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:6e369105b2811b6c32d7f15624202609deeb428164ee395c715df01221c847f5", size = 11733172, upload-time = "2025-06-09T14:00:45.592Z" }, - { url = "https://files.pythonhosted.org/packages/d9/a5/a97952c796da12bce860d2664f796a60951ee893264723019c5a33ebfe92/skia_python-138.0-cp311-cp311-macosx_11_0_x86_64.whl", hash = "sha256:55a2ae437d1c6dc46d9bbc2e3e0b4b5642022dcebc0634591ae1c8acea52a413", size = 12111725, upload-time = "2025-06-09T14:00:49.457Z" }, - { url = "https://files.pythonhosted.org/packages/c1/a5/41eb0ca82a100ee96505899d7c85ab19de8a22def6d0e696111d519f103f/skia_python-138.0-cp311-cp311-manylinux_2_28_aarch64.whl", hash = "sha256:e67c9bcac953fbeb31b38474a4e566371e5719d4e27032686359cbe602819af8", size = 13246160, upload-time = "2025-06-09T14:00:52.21Z" }, - { url = "https://files.pythonhosted.org/packages/9a/d0/2079f4e9774117cdbb67fdbbb31fc29095d69d52d47fd7cf01d51e6429a2/skia_python-138.0-cp311-cp311-manylinux_2_28_x86_64.whl", hash = "sha256:4e9fb097849604e290be28a6b4cc29cb0079b0233e599c2f6b2ec635e47169d2", size = 13733938, upload-time = "2025-06-09T14:00:54.764Z" }, - { url = "https://files.pythonhosted.org/packages/f5/e7/5588e80336e6999dda9367a1522a71a7163d3e42f143b4aa29ac7beff270/skia_python-138.0-cp311-cp311-win_amd64.whl", hash = "sha256:df5a0dd52e1038423f2e1c03677cba5ea974d215adec10763dd855f4a6ca0cfc", size = 10718923, upload-time = "2025-06-09T14:00:57.429Z" }, - { url = "https://files.pythonhosted.org/packages/85/60/a74af40c88b72772560be8c8016540ae21e923160e3f1e8f8303aefc42d9/skia_python-138.0-cp311-cp311-win_arm64.whl", hash = "sha256:054ca430003d52468974cf69d98719e61f188630709a3706a868efc16e817970", size = 10236223, upload-time = "2025-06-09T14:00:59.615Z" }, - { url = "https://files.pythonhosted.org/packages/03/c9/6918a25edd8cf2982a39d70e7fe833d553a8d05dbd27bf6584f035d4eb06/skia_python-138.0-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:6b83d7b8101038ab0fcb920b1a91c872615e45b0ac19fe0c66b55d3ad0d61970", size = 11810205, upload-time = "2025-06-09T14:01:01.781Z" }, - { url = "https://files.pythonhosted.org/packages/ed/1c/8eb0b30088cf61c50443a9bbe59bab29696d3a316b7c7571cec4a048fd7b/skia_python-138.0-cp312-cp312-macosx_11_0_x86_64.whl", hash = "sha256:f22060f513b2fc258b4269e631128ca68889107bc4aa65255119f3d9c1c32993", size = 12198501, upload-time = "2025-06-09T14:01:04.036Z" }, - { url = "https://files.pythonhosted.org/packages/4b/d2/b3741e023011f37d6e337254ba13b120de080561f658d784ca1ca9460db8/skia_python-138.0-cp312-cp312-manylinux_2_28_aarch64.whl", hash = "sha256:02b0c2146d25f45224c2c156dd8b859e89265ee5894c3fa8f456c6c41b27122d", size = 13228949, upload-time = "2025-06-09T14:01:06.431Z" }, - { url = "https://files.pythonhosted.org/packages/94/f0/ea63dbd27f1d7d3a089e32750b082e6bcb4ca7716670be33207bdc4b5e8a/skia_python-138.0-cp312-cp312-manylinux_2_28_x86_64.whl", hash = "sha256:fb9e980a61defcb6ca19d73c97ea23d1aea633a82e9d1dead6ed259c3856baaf", size = 13716695, upload-time = "2025-06-09T14:01:08.735Z" }, - { url = "https://files.pythonhosted.org/packages/23/e9/9acf2197c77d2a90c3b070d1b578245a4332f19b708e8099cea74edc4d0b/skia_python-138.0-cp312-cp312-win_amd64.whl", hash = "sha256:625bb95dc225ea2257f1d1f7b0aee203290b91d909c8f5feaa7cd428f13bce22", size = 10730248, upload-time = "2025-06-09T14:01:10.931Z" }, - { url = "https://files.pythonhosted.org/packages/e1/87/dc95a0086dfb210dad20adf3446b1bd85958e190a7e3409db468fb1e8d7f/skia_python-138.0-cp312-cp312-win_arm64.whl", hash = "sha256:e495143edba2a7cdf59e83723f00c9a247e5baeda4981fc6587803ed46c5ed2a", size = 10240328, upload-time = "2025-06-09T14:01:13.491Z" }, - { url = "https://files.pythonhosted.org/packages/45/93/d27a1b494ee40ee9a34cb1a497a16e158088e39f0acb76b36018a5974e7c/skia_python-138.0-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:1433b5a0bd4ca1c1d050541f54c25d27d55a129894dbd827d4e440697090ff83", size = 11810860, upload-time = "2025-06-09T14:01:15.754Z" }, - { url = "https://files.pythonhosted.org/packages/2a/51/e07fd27e07c206c96b85d5b1bf7f143cc23152578392085e4e7a541e39c6/skia_python-138.0-cp313-cp313-macosx_11_0_x86_64.whl", hash = "sha256:3f053128aa6344fa991c2485f29f40bda77b5f46467a43e778a34ec8f5b3615a", size = 12198469, upload-time = "2025-06-09T14:01:17.891Z" }, - { url = "https://files.pythonhosted.org/packages/12/26/65f991bf4dee40fecb4027e1ee7cc1dacaff2dfa258d47e86af6ae83d8dd/skia_python-138.0-cp313-cp313-manylinux_2_28_aarch64.whl", hash = "sha256:878212d9576d065a45fd143c57d412bc0496c6594ecfcd9cc2cd93b4fd943cb4", size = 13229490, upload-time = "2025-06-09T14:01:21.869Z" }, - { url = "https://files.pythonhosted.org/packages/8d/2e/5c593bdadaf4c84580af8a46853079a8f0055506a826b1e45ea84baaa816/skia_python-138.0-cp313-cp313-manylinux_2_28_x86_64.whl", hash = "sha256:a6b3e58756a9fa8af3714edc05aeafc7922090f5a276c4be11337f252921dbe8", size = 13717865, upload-time = "2025-06-09T14:01:24.049Z" }, - { url = "https://files.pythonhosted.org/packages/be/d9/b112d8f20e28dde3bbf47574d330b42d1dc4daf73650676b966f356f2f8c/skia_python-138.0-cp313-cp313-win_amd64.whl", hash = "sha256:f2d596d5807fafef6bc43440f4df28f71db189f9e2cfb8613224713916837e3c", size = 10730715, upload-time = "2025-06-09T14:01:26.222Z" }, - { url = "https://files.pythonhosted.org/packages/a0/1b/32301010348c72de22f03b4322324937de461f8c906e5c2ec10d0b98ac3b/skia_python-138.0-cp313-cp313-win_arm64.whl", hash = "sha256:20285bf4ee41da754b842c80076fc4a240cb3801f4a1cbbb50b26a5dca1ebc39", size = 10239877, upload-time = "2025-06-09T14:01:28.412Z" }, -] - -[[package]] -name = "sniffio" -version = "1.3.1" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/a2/87/a6771e1546d97e7e041b6ae58d80074f81b7d5121207425c964ddf5cfdbd/sniffio-1.3.1.tar.gz", hash = "sha256:f4324edc670a0f49750a81b895f35c3adb843cca46f0530f79fc1babb23789dc", size = 20372, upload-time = "2024-02-25T23:20:04.057Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/e9/44/75a9c9421471a6c4805dbf2356f7c181a29c1879239abab1ea2cc8f38b40/sniffio-1.3.1-py3-none-any.whl", hash = "sha256:2f6da418d1f1e0fddd844478f41680e794e6051915791a034ff65e5f100525a2", size = 10235, upload-time = "2024-02-25T23:20:01.196Z" }, -] - -[[package]] -name = "soundfile" -version = "0.13.1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "cffi" }, - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/e1/41/9b873a8c055582859b239be17902a85339bec6a30ad162f98c9b0288a2cc/soundfile-0.13.1.tar.gz", hash = "sha256:b2c68dab1e30297317080a5b43df57e302584c49e2942defdde0acccc53f0e5b", size = 46156, upload-time = "2025-01-25T09:17:04.831Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/64/28/e2a36573ccbcf3d57c00626a21fe51989380636e821b341d36ccca0c1c3a/soundfile-0.13.1-py2.py3-none-any.whl", hash = "sha256:a23c717560da2cf4c7b5ae1142514e0fd82d6bbd9dfc93a50423447142f2c445", size = 25751, upload-time = "2025-01-25T09:16:44.235Z" }, - { url = "https://files.pythonhosted.org/packages/ea/ab/73e97a5b3cc46bba7ff8650a1504348fa1863a6f9d57d7001c6b67c5f20e/soundfile-0.13.1-py2.py3-none-macosx_10_9_x86_64.whl", hash = "sha256:82dc664d19831933fe59adad199bf3945ad06d84bc111a5b4c0d3089a5b9ec33", size = 1142250, upload-time = "2025-01-25T09:16:47.583Z" }, - { url = "https://files.pythonhosted.org/packages/a0/e5/58fd1a8d7b26fc113af244f966ee3aecf03cb9293cb935daaddc1e455e18/soundfile-0.13.1-py2.py3-none-macosx_11_0_arm64.whl", hash = "sha256:743f12c12c4054921e15736c6be09ac26b3b3d603aef6fd69f9dde68748f2593", size = 1101406, upload-time = "2025-01-25T09:16:49.662Z" }, - { url = "https://files.pythonhosted.org/packages/58/ae/c0e4a53d77cf6e9a04179535766b3321b0b9ced5f70522e4caf9329f0046/soundfile-0.13.1-py2.py3-none-manylinux_2_28_aarch64.whl", hash = "sha256:9c9e855f5a4d06ce4213f31918653ab7de0c5a8d8107cd2427e44b42df547deb", size = 1235729, upload-time = "2025-01-25T09:16:53.018Z" }, - { url = "https://files.pythonhosted.org/packages/57/5e/70bdd9579b35003a489fc850b5047beeda26328053ebadc1fb60f320f7db/soundfile-0.13.1-py2.py3-none-manylinux_2_28_x86_64.whl", hash = "sha256:03267c4e493315294834a0870f31dbb3b28a95561b80b134f0bd3cf2d5f0e618", size = 1313646, upload-time = "2025-01-25T09:16:54.872Z" }, - { url = "https://files.pythonhosted.org/packages/fe/df/8c11dc4dfceda14e3003bb81a0d0edcaaf0796dd7b4f826ea3e532146bba/soundfile-0.13.1-py2.py3-none-win32.whl", hash = "sha256:c734564fab7c5ddf8e9be5bf70bab68042cd17e9c214c06e365e20d64f9a69d5", size = 899881, upload-time = "2025-01-25T09:16:56.663Z" }, - { url = "https://files.pythonhosted.org/packages/14/e9/6b761de83277f2f02ded7e7ea6f07828ec78e4b229b80e4ca55dd205b9dc/soundfile-0.13.1-py2.py3-none-win_amd64.whl", hash = "sha256:1e70a05a0626524a69e9f0f4dd2ec174b4e9567f4d8b6c11d38b5c289be36ee9", size = 1019162, upload-time = "2025-01-25T09:16:59.573Z" }, -] - -[[package]] -name = "spandrel" -version = "0.4.1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "einops" }, - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "safetensors" }, - { name = "torch", version = "2.0.1", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://pypi.org/simple" }, marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" }, marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "extra == 'extra-7-comfyui-cu128' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.15.2", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1", source = { registry = "https://pypi.org/simple" }, marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" }, marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "(platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "typing-extensions" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/45/e0/048cd03119a9f2b685a79601a52311d5910ff6fd710c01f4ed6769a2892f/spandrel-0.4.1.tar.gz", hash = "sha256:646d9816a942e59d56aab2dc904353952e57dee4b2cb3f59f7ea4dc0fb11a1f2", size = 233544, upload-time = "2025-01-19T15:31:24.02Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/d3/1e/5dce7f0d3eb2aa418bd9cf3e84b2f5d2cf45b1c62488dd139fc93c729cfe/spandrel-0.4.1-py3-none-any.whl", hash = "sha256:49a39aa979769749a42203428355bc4840452854d6334ce0d465af46098dd448", size = 305217, upload-time = "2025-01-19T15:31:22.202Z" }, -] - -[[package]] -name = "spandrel-extra-arches" -version = "0.2.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "einops" }, - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "spandrel" }, - { name = "torch", version = "2.0.1", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://pypi.org/simple" }, marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" }, marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "extra == 'extra-7-comfyui-cu128' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.15.2", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1", source = { registry = "https://pypi.org/simple" }, marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" }, marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "(platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "typing-extensions" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/65/ae/5e62e7a099203ce51eb505858671e89c30a7e50e7f4589dabb8d29df0957/spandrel_extra_arches-0.2.0.tar.gz", hash = "sha256:9216877ecabc9c97e001ad5d49c4f8d2b1f6c6f82d1e77c8e2b350c586b6e64a", size = 69689, upload-time = "2024-09-16T01:36:45.516Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/c4/16/f0935e3a2a3ed362e2d5f357bdd7260b3bec279dd3d95940532a730883ea/spandrel_extra_arches-0.2.0-py3-none-any.whl", hash = "sha256:152e4abbd108470a77b716030029c3e7fc6f61600ec769269c94a46d4a130b4f", size = 86285, upload-time = "2024-09-16T01:36:43.883Z" }, -] - -[[package]] -name = "sqlalchemy" -version = "2.0.41" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "greenlet", marker = "(python_full_version < '3.14' and platform_machine == 'AMD64') or (python_full_version < '3.14' and platform_machine == 'WIN32') or (python_full_version < '3.14' and platform_machine == 'aarch64') or (python_full_version < '3.14' and platform_machine == 'amd64') or (python_full_version < '3.14' and platform_machine == 'ppc64le') or (python_full_version < '3.14' and platform_machine == 'win32') or (python_full_version < '3.14' and platform_machine == 'x86_64') or (platform_machine != 'AMD64' and platform_machine != 'WIN32' and platform_machine != 'aarch64' and platform_machine != 'amd64' and platform_machine != 'ppc64le' and platform_machine != 'win32' and platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'AMD64' and platform_machine != 'WIN32' and platform_machine != 'aarch64' and platform_machine != 'amd64' and platform_machine != 'ppc64le' and platform_machine != 'win32' and platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'AMD64' and platform_machine != 'WIN32' and platform_machine != 'aarch64' and platform_machine != 'amd64' and platform_machine != 'ppc64le' and platform_machine != 'win32' and platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'AMD64' and platform_machine != 'WIN32' and platform_machine != 'aarch64' and platform_machine != 'amd64' and platform_machine != 'ppc64le' and platform_machine != 'win32' and platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'AMD64' and platform_machine != 'WIN32' and platform_machine != 'aarch64' and platform_machine != 'amd64' and platform_machine != 'ppc64le' and platform_machine != 'win32' and platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'AMD64' and platform_machine != 'WIN32' and platform_machine != 'aarch64' and platform_machine != 'amd64' and platform_machine != 'ppc64le' and platform_machine != 'win32' and platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'AMD64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine == 'AMD64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine == 'AMD64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'AMD64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine == 'AMD64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'AMD64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'WIN32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine == 'WIN32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine == 'WIN32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'WIN32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine == 'WIN32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'WIN32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine == 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine == 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine == 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'amd64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine == 'amd64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine == 'amd64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'amd64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine == 'amd64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'amd64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'ppc64le' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine == 'ppc64le' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine == 'ppc64le' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'ppc64le' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine == 'ppc64le' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'ppc64le' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'x86_64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine == 'x86_64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine == 'x86_64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine == 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "typing-extensions" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/63/66/45b165c595ec89aa7dcc2c1cd222ab269bc753f1fc7a1e68f8481bd957bf/sqlalchemy-2.0.41.tar.gz", hash = "sha256:edba70118c4be3c2b1f90754d308d0b79c6fe2c0fdc52d8ddf603916f83f4db9", size = 9689424, upload-time = "2025-05-14T17:10:32.339Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/e9/12/d7c445b1940276a828efce7331cb0cb09d6e5f049651db22f4ebb0922b77/sqlalchemy-2.0.41-cp310-cp310-macosx_10_9_x86_64.whl", hash = "sha256:b1f09b6821406ea1f94053f346f28f8215e293344209129a9c0fcc3578598d7b", size = 2117967, upload-time = "2025-05-14T17:48:15.841Z" }, - { url = "https://files.pythonhosted.org/packages/6f/b8/cb90f23157e28946b27eb01ef401af80a1fab7553762e87df51507eaed61/sqlalchemy-2.0.41-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:1936af879e3db023601196a1684d28e12f19ccf93af01bf3280a3262c4b6b4e5", size = 2107583, upload-time = "2025-05-14T17:48:18.688Z" }, - { url = "https://files.pythonhosted.org/packages/9e/c2/eef84283a1c8164a207d898e063edf193d36a24fb6a5bb3ce0634b92a1e8/sqlalchemy-2.0.41-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:b2ac41acfc8d965fb0c464eb8f44995770239668956dc4cdf502d1b1ffe0d747", size = 3186025, upload-time = "2025-05-14T17:51:51.226Z" }, - { url = "https://files.pythonhosted.org/packages/bd/72/49d52bd3c5e63a1d458fd6d289a1523a8015adedbddf2c07408ff556e772/sqlalchemy-2.0.41-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:81c24e0c0fde47a9723c81d5806569cddef103aebbf79dbc9fcbb617153dea30", size = 3186259, upload-time = "2025-05-14T17:55:22.526Z" }, - { url = "https://files.pythonhosted.org/packages/4f/9e/e3ffc37d29a3679a50b6bbbba94b115f90e565a2b4545abb17924b94c52d/sqlalchemy-2.0.41-cp310-cp310-musllinux_1_2_aarch64.whl", hash = "sha256:23a8825495d8b195c4aa9ff1c430c28f2c821e8c5e2d98089228af887e5d7e29", size = 3126803, upload-time = "2025-05-14T17:51:53.277Z" }, - { url = "https://files.pythonhosted.org/packages/8a/76/56b21e363f6039978ae0b72690237b38383e4657281285a09456f313dd77/sqlalchemy-2.0.41-cp310-cp310-musllinux_1_2_x86_64.whl", hash = "sha256:60c578c45c949f909a4026b7807044e7e564adf793537fc762b2489d522f3d11", size = 3148566, upload-time = "2025-05-14T17:55:24.398Z" }, - { url = "https://files.pythonhosted.org/packages/3b/92/11b8e1b69bf191bc69e300a99badbbb5f2f1102f2b08b39d9eee2e21f565/sqlalchemy-2.0.41-cp310-cp310-win32.whl", hash = "sha256:118c16cd3f1b00c76d69343e38602006c9cfb9998fa4f798606d28d63f23beda", size = 2086696, upload-time = "2025-05-14T17:55:59.136Z" }, - { url = "https://files.pythonhosted.org/packages/5c/88/2d706c9cc4502654860f4576cd54f7db70487b66c3b619ba98e0be1a4642/sqlalchemy-2.0.41-cp310-cp310-win_amd64.whl", hash = "sha256:7492967c3386df69f80cf67efd665c0f667cee67032090fe01d7d74b0e19bb08", size = 2110200, upload-time = "2025-05-14T17:56:00.757Z" }, - { url = "https://files.pythonhosted.org/packages/37/4e/b00e3ffae32b74b5180e15d2ab4040531ee1bef4c19755fe7926622dc958/sqlalchemy-2.0.41-cp311-cp311-macosx_10_9_x86_64.whl", hash = "sha256:6375cd674fe82d7aa9816d1cb96ec592bac1726c11e0cafbf40eeee9a4516b5f", size = 2121232, upload-time = "2025-05-14T17:48:20.444Z" }, - { url = "https://files.pythonhosted.org/packages/ef/30/6547ebb10875302074a37e1970a5dce7985240665778cfdee2323709f749/sqlalchemy-2.0.41-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:9f8c9fdd15a55d9465e590a402f42082705d66b05afc3ffd2d2eb3c6ba919560", size = 2110897, upload-time = "2025-05-14T17:48:21.634Z" }, - { url = "https://files.pythonhosted.org/packages/9e/21/59df2b41b0f6c62da55cd64798232d7349a9378befa7f1bb18cf1dfd510a/sqlalchemy-2.0.41-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:32f9dc8c44acdee06c8fc6440db9eae8b4af8b01e4b1aee7bdd7241c22edff4f", size = 3273313, upload-time = "2025-05-14T17:51:56.205Z" }, - { url = "https://files.pythonhosted.org/packages/62/e4/b9a7a0e5c6f79d49bcd6efb6e90d7536dc604dab64582a9dec220dab54b6/sqlalchemy-2.0.41-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:90c11ceb9a1f482c752a71f203a81858625d8df5746d787a4786bca4ffdf71c6", size = 3273807, upload-time = "2025-05-14T17:55:26.928Z" }, - { url = "https://files.pythonhosted.org/packages/39/d8/79f2427251b44ddee18676c04eab038d043cff0e764d2d8bb08261d6135d/sqlalchemy-2.0.41-cp311-cp311-musllinux_1_2_aarch64.whl", hash = "sha256:911cc493ebd60de5f285bcae0491a60b4f2a9f0f5c270edd1c4dbaef7a38fc04", size = 3209632, upload-time = "2025-05-14T17:51:59.384Z" }, - { url = "https://files.pythonhosted.org/packages/d4/16/730a82dda30765f63e0454918c982fb7193f6b398b31d63c7c3bd3652ae5/sqlalchemy-2.0.41-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:03968a349db483936c249f4d9cd14ff2c296adfa1290b660ba6516f973139582", size = 3233642, upload-time = "2025-05-14T17:55:29.901Z" }, - { url = "https://files.pythonhosted.org/packages/04/61/c0d4607f7799efa8b8ea3c49b4621e861c8f5c41fd4b5b636c534fcb7d73/sqlalchemy-2.0.41-cp311-cp311-win32.whl", hash = "sha256:293cd444d82b18da48c9f71cd7005844dbbd06ca19be1ccf6779154439eec0b8", size = 2086475, upload-time = "2025-05-14T17:56:02.095Z" }, - { url = "https://files.pythonhosted.org/packages/9d/8e/8344f8ae1cb6a479d0741c02cd4f666925b2bf02e2468ddaf5ce44111f30/sqlalchemy-2.0.41-cp311-cp311-win_amd64.whl", hash = "sha256:3d3549fc3e40667ec7199033a4e40a2f669898a00a7b18a931d3efb4c7900504", size = 2110903, upload-time = "2025-05-14T17:56:03.499Z" }, - { url = "https://files.pythonhosted.org/packages/3e/2a/f1f4e068b371154740dd10fb81afb5240d5af4aa0087b88d8b308b5429c2/sqlalchemy-2.0.41-cp312-cp312-macosx_10_13_x86_64.whl", hash = "sha256:81f413674d85cfd0dfcd6512e10e0f33c19c21860342a4890c3a2b59479929f9", size = 2119645, upload-time = "2025-05-14T17:55:24.854Z" }, - { url = "https://files.pythonhosted.org/packages/9b/e8/c664a7e73d36fbfc4730f8cf2bf930444ea87270f2825efbe17bf808b998/sqlalchemy-2.0.41-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:598d9ebc1e796431bbd068e41e4de4dc34312b7aa3292571bb3674a0cb415dd1", size = 2107399, upload-time = "2025-05-14T17:55:28.097Z" }, - { url = "https://files.pythonhosted.org/packages/5c/78/8a9cf6c5e7135540cb682128d091d6afa1b9e48bd049b0d691bf54114f70/sqlalchemy-2.0.41-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:a104c5694dfd2d864a6f91b0956eb5d5883234119cb40010115fd45a16da5e70", size = 3293269, upload-time = "2025-05-14T17:50:38.227Z" }, - { url = "https://files.pythonhosted.org/packages/3c/35/f74add3978c20de6323fb11cb5162702670cc7a9420033befb43d8d5b7a4/sqlalchemy-2.0.41-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:6145afea51ff0af7f2564a05fa95eb46f542919e6523729663a5d285ecb3cf5e", size = 3303364, upload-time = "2025-05-14T17:51:49.829Z" }, - { url = "https://files.pythonhosted.org/packages/6a/d4/c990f37f52c3f7748ebe98883e2a0f7d038108c2c5a82468d1ff3eec50b7/sqlalchemy-2.0.41-cp312-cp312-musllinux_1_2_aarch64.whl", hash = "sha256:b46fa6eae1cd1c20e6e6f44e19984d438b6b2d8616d21d783d150df714f44078", size = 3229072, upload-time = "2025-05-14T17:50:39.774Z" }, - { url = "https://files.pythonhosted.org/packages/15/69/cab11fecc7eb64bc561011be2bd03d065b762d87add52a4ca0aca2e12904/sqlalchemy-2.0.41-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:41836fe661cc98abfae476e14ba1906220f92c4e528771a8a3ae6a151242d2ae", size = 3268074, upload-time = "2025-05-14T17:51:51.736Z" }, - { url = "https://files.pythonhosted.org/packages/5c/ca/0c19ec16858585d37767b167fc9602593f98998a68a798450558239fb04a/sqlalchemy-2.0.41-cp312-cp312-win32.whl", hash = "sha256:a8808d5cf866c781150d36a3c8eb3adccfa41a8105d031bf27e92c251e3969d6", size = 2084514, upload-time = "2025-05-14T17:55:49.915Z" }, - { url = "https://files.pythonhosted.org/packages/7f/23/4c2833d78ff3010a4e17f984c734f52b531a8c9060a50429c9d4b0211be6/sqlalchemy-2.0.41-cp312-cp312-win_amd64.whl", hash = "sha256:5b14e97886199c1f52c14629c11d90c11fbb09e9334fa7bb5f6d068d9ced0ce0", size = 2111557, upload-time = "2025-05-14T17:55:51.349Z" }, - { url = "https://files.pythonhosted.org/packages/d3/ad/2e1c6d4f235a97eeef52d0200d8ddda16f6c4dd70ae5ad88c46963440480/sqlalchemy-2.0.41-cp313-cp313-macosx_10_13_x86_64.whl", hash = "sha256:4eeb195cdedaf17aab6b247894ff2734dcead6c08f748e617bfe05bd5a218443", size = 2115491, upload-time = "2025-05-14T17:55:31.177Z" }, - { url = "https://files.pythonhosted.org/packages/cf/8d/be490e5db8400dacc89056f78a52d44b04fbf75e8439569d5b879623a53b/sqlalchemy-2.0.41-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:d4ae769b9c1c7757e4ccce94b0641bc203bbdf43ba7a2413ab2523d8d047d8dc", size = 2102827, upload-time = "2025-05-14T17:55:34.921Z" }, - { url = "https://files.pythonhosted.org/packages/a0/72/c97ad430f0b0e78efaf2791342e13ffeafcbb3c06242f01a3bb8fe44f65d/sqlalchemy-2.0.41-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:a62448526dd9ed3e3beedc93df9bb6b55a436ed1474db31a2af13b313a70a7e1", size = 3225224, upload-time = "2025-05-14T17:50:41.418Z" }, - { url = "https://files.pythonhosted.org/packages/5e/51/5ba9ea3246ea068630acf35a6ba0d181e99f1af1afd17e159eac7e8bc2b8/sqlalchemy-2.0.41-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:dc56c9788617b8964ad02e8fcfeed4001c1f8ba91a9e1f31483c0dffb207002a", size = 3230045, upload-time = "2025-05-14T17:51:54.722Z" }, - { url = "https://files.pythonhosted.org/packages/78/2f/8c14443b2acea700c62f9b4a8bad9e49fc1b65cfb260edead71fd38e9f19/sqlalchemy-2.0.41-cp313-cp313-musllinux_1_2_aarch64.whl", hash = "sha256:c153265408d18de4cc5ded1941dcd8315894572cddd3c58df5d5b5705b3fa28d", size = 3159357, upload-time = "2025-05-14T17:50:43.483Z" }, - { url = "https://files.pythonhosted.org/packages/fc/b2/43eacbf6ccc5276d76cea18cb7c3d73e294d6fb21f9ff8b4eef9b42bbfd5/sqlalchemy-2.0.41-cp313-cp313-musllinux_1_2_x86_64.whl", hash = "sha256:4f67766965996e63bb46cfbf2ce5355fc32d9dd3b8ad7e536a920ff9ee422e23", size = 3197511, upload-time = "2025-05-14T17:51:57.308Z" }, - { url = "https://files.pythonhosted.org/packages/fa/2e/677c17c5d6a004c3c45334ab1dbe7b7deb834430b282b8a0f75ae220c8eb/sqlalchemy-2.0.41-cp313-cp313-win32.whl", hash = "sha256:bfc9064f6658a3d1cadeaa0ba07570b83ce6801a1314985bf98ec9b95d74e15f", size = 2082420, upload-time = "2025-05-14T17:55:52.69Z" }, - { url = "https://files.pythonhosted.org/packages/e9/61/e8c1b9b6307c57157d328dd8b8348ddc4c47ffdf1279365a13b2b98b8049/sqlalchemy-2.0.41-cp313-cp313-win_amd64.whl", hash = "sha256:82ca366a844eb551daff9d2e6e7a9e5e76d2612c8564f58db6c19a726869c1df", size = 2108329, upload-time = "2025-05-14T17:55:54.495Z" }, - { url = "https://files.pythonhosted.org/packages/1c/fc/9ba22f01b5cdacc8f5ed0d22304718d2c758fce3fd49a5372b886a86f37c/sqlalchemy-2.0.41-py3-none-any.whl", hash = "sha256:57df5dc6fdb5ed1a88a1ed2195fd31927e705cad62dedd86b46972752a80f576", size = 1911224, upload-time = "2025-05-14T17:39:42.154Z" }, -] - -[[package]] -name = "stringzilla" -version = "3.12.5" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/91/77/6e458f53f3ae04df00fd499a124561ad626253bf1c4ee6e2f027e2ddb547/stringzilla-3.12.5.tar.gz", hash = "sha256:57958a420c8e5bfd958740a76a35d357f64c18713a48dbf5983ae0a4e50c010d", size = 186796, upload-time = "2025-04-18T21:35:49.633Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/68/e0/1b5f7cd6c37714b434fa1bad8d0f107c5ce5adf67b1c7b612d62ee5220a8/stringzilla-3.12.5-cp310-cp310-macosx_10_11_universal2.whl", hash = "sha256:309a5596deefadc8b06d372c26ec7e220dacb0c59cf7ad7e7879da403b55ab72", size = 121720, upload-time = "2025-04-18T21:31:23.805Z" }, - { url = "https://files.pythonhosted.org/packages/3b/b5/8ec92434f325d599dbd58bc86a992f7e7aa149246d1d7aef32bade7d7e32/stringzilla-3.12.5-cp310-cp310-macosx_10_11_x86_64.whl", hash = "sha256:58a120a94b8345799a2984a51f2ca5d8259fc98e470ca9d44c07b2f9a6718125", size = 79402, upload-time = "2025-04-18T21:31:26.334Z" }, - { url = "https://files.pythonhosted.org/packages/d3/9c/58bb22f19b1a4591b74c5ae3023f66bb87287ff78cfd2a0ee6572bace031/stringzilla-3.12.5-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:e5dd2069ee42291c9ab06c4cd7ae0b622181af0ce64ce209b000bf43776dd416", size = 79408, upload-time = "2025-04-18T21:31:28.234Z" }, - { url = "https://files.pythonhosted.org/packages/54/e0/5c8e7bbe9914b4d18e1c7ec40bdf12589556d995949cbad4909d9943d2ff/stringzilla-3.12.5-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.manylinux_2_28_aarch64.whl", hash = "sha256:bd6d1d9b15e97b5feb59942a3af5b96f544f00e136fdfdbac7c43b3a73e74772", size = 229174, upload-time = "2025-04-18T21:31:30.076Z" }, - { url = "https://files.pythonhosted.org/packages/f1/95/41a5e17fbd82b243ba88fa44786eb0e29ef06e5bd50dc7e754cb563286c3/stringzilla-3.12.5-cp310-cp310-manylinux_2_17_ppc64le.manylinux2014_ppc64le.manylinux_2_28_ppc64le.whl", hash = "sha256:258e95b9ba322d1fb8bfd2f3c42f4dac3b1c2b4665b0aaaf3f57ebff236f54f8", size = 231939, upload-time = "2025-04-18T21:31:32.283Z" }, - { url = "https://files.pythonhosted.org/packages/0c/71/4370f837eb6b8da53d9e6447ac872eeeacacf21c01be97e98e3c1f0b1327/stringzilla-3.12.5-cp310-cp310-manylinux_2_17_s390x.manylinux2014_s390x.manylinux_2_28_s390x.whl", hash = "sha256:dd65a1f996d5d3a011dd4a9ba39f4981ed48878c77dc51de55f77d520917baf5", size = 203558, upload-time = "2025-04-18T21:31:33.591Z" }, - { url = "https://files.pythonhosted.org/packages/c2/a1/c880e1c9e9e8926473a009fc61c90b9a141f33df3816576c0810ab9b03de/stringzilla-3.12.5-cp310-cp310-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:248a4145334475a4a055a36c4418f70c9084d74e0c11f9acb6b20c15902f5fb8", size = 209097, upload-time = "2025-04-18T21:31:35.528Z" }, - { url = "https://files.pythonhosted.org/packages/5d/f7/989ef27a9122ef1bc11ac913344be6051d22d19952fc2ef292058e60e586/stringzilla-3.12.5-cp310-cp310-manylinux_2_5_x86_64.manylinux1_x86_64.manylinux_2_28_x86_64.whl", hash = "sha256:b38b87381a7908a7f24ab452eab1ded12fd1d0f280e608073e3197ecdfacc43d", size = 304685, upload-time = "2025-04-18T21:31:37.433Z" }, - { url = "https://files.pythonhosted.org/packages/b3/af/be5f092b9de330c43b388660c3baf4601e980f654f1a6b740ea29a274de4/stringzilla-3.12.5-cp310-cp310-musllinux_1_2_aarch64.whl", hash = "sha256:1f36978c2d91f06f647bed422ad91c9b411310012dc0947d4a93e89ca900b75c", size = 224536, upload-time = "2025-04-18T21:31:39.34Z" }, - { url = "https://files.pythonhosted.org/packages/17/ef/f3b5b029c929aa1e15b1e69fcebbbec10f40807494e6ffc059b45fb94948/stringzilla-3.12.5-cp310-cp310-musllinux_1_2_armv7l.whl", hash = "sha256:d22995a79625d756d9bce98fd37e1d6e1b22d2c89501dc55d845c5a433fc3250", size = 198091, upload-time = "2025-04-18T21:31:40.858Z" }, - { url = "https://files.pythonhosted.org/packages/0e/6c/51c9a84b23e7acad44b791c906d5271d7cb32dcfe522d027b2ad35eb8cfe/stringzilla-3.12.5-cp310-cp310-musllinux_1_2_i686.whl", hash = "sha256:b48fa436a40fb4f74c6fb8a56f75ca98384ba0d611df25d20fc3afee6687ded3", size = 210448, upload-time = "2025-04-18T21:31:42.258Z" }, - { url = "https://files.pythonhosted.org/packages/9d/3e/50cb83a77fb20cb093c251466a96e3205477d944a69900d17c49121feffe/stringzilla-3.12.5-cp310-cp310-musllinux_1_2_ppc64le.whl", hash = "sha256:4312f52846f5257bffdee790f8e29a22f5cc9517caa43659635061f175c50896", size = 229361, upload-time = "2025-04-18T21:31:44.797Z" }, - { url = "https://files.pythonhosted.org/packages/34/33/193c716d45559373fc55de25405404dc16c3feab052d33367caeb0d211ae/stringzilla-3.12.5-cp310-cp310-musllinux_1_2_s390x.whl", hash = "sha256:c7f2e90bf2a42106b052013e0bd0ba0c8e7246de50f8ab373ad7595b1974a402", size = 203213, upload-time = "2025-04-18T21:31:46.936Z" }, - { url = "https://files.pythonhosted.org/packages/b2/8a/45937ce7cbe99ecaacce67e5c724fb58e4f2cb1c9d41bd187f65c202b9c8/stringzilla-3.12.5-cp310-cp310-musllinux_1_2_x86_64.whl", hash = "sha256:196b4c6212469bdacb506b53c94eef13837e4a10c45898fb2bbaca209da3b049", size = 298616, upload-time = "2025-04-18T21:32:20.23Z" }, - { url = "https://files.pythonhosted.org/packages/49/a4/120795800b1d38fa8286a6111f5f404322adb3397b18856db3acb4fab54b/stringzilla-3.12.5-cp310-cp310-win32.whl", hash = "sha256:0f71d8224cf6f658ae9cdf0e34cc5839d1f3f3c322de9dc1d849f31e1e72a84b", size = 68533, upload-time = "2025-04-18T21:32:22.137Z" }, - { url = "https://files.pythonhosted.org/packages/40/39/b5ce9ae43e648316846014cb1624431c2f5b820dee39988a18d4a0797ad0/stringzilla-3.12.5-cp310-cp310-win_amd64.whl", hash = "sha256:7c72b496bd63783587559630d87b841eba78838580f7e82bea0c678bcce01118", size = 80126, upload-time = "2025-04-18T21:32:23.52Z" }, - { url = "https://files.pythonhosted.org/packages/f7/c2/e0bc9bef10ba986cf6060b1a5aa87da50676bd2fe2d5ed3071908974e064/stringzilla-3.12.5-cp310-cp310-win_arm64.whl", hash = "sha256:c4e182799abb75e09f2d372f67ec8c6916130507b0895c7ff7030944fda98f83", size = 69783, upload-time = "2025-04-18T21:32:24.877Z" }, - { url = "https://files.pythonhosted.org/packages/d5/37/c6d2d22b79897861684c1e0c50a79c81305e72565fcc82d0c0e27bcc6ca7/stringzilla-3.12.5-cp311-cp311-macosx_10_11_universal2.whl", hash = "sha256:a83218a2b38e645368f7f5e06a4dd4c9606b1b148703e5afe9f3fa9566940c96", size = 121712, upload-time = "2025-04-18T21:32:26.314Z" }, - { url = "https://files.pythonhosted.org/packages/e5/12/09f3d53906923b3cb2b341326f389792ae0dd5c254b7c79a9b266d7a1f97/stringzilla-3.12.5-cp311-cp311-macosx_10_11_x86_64.whl", hash = "sha256:5f698e0571b9feb6a3f0565908ccd472dc55c0f781c2520276f354abe63a0db7", size = 79399, upload-time = "2025-04-18T21:32:28.212Z" }, - { url = "https://files.pythonhosted.org/packages/94/48/32a07b193bf526216a99195ddf4e660ae2f6614d3bbb8f411f8ef215788e/stringzilla-3.12.5-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:a192c5743d103061a5e7b62792395f54257f7f7418afa22a44e2b02bb749608b", size = 79405, upload-time = "2025-04-18T21:32:29.484Z" }, - { url = "https://files.pythonhosted.org/packages/12/7c/90cd904288f788ceb246ae159d4bf5438a708fc102a7e034bd97baf447d2/stringzilla-3.12.5-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.manylinux_2_28_aarch64.whl", hash = "sha256:fed688e2406d5f02e69d389e4378c92d63737ce44ce4afbc5f4587b178a39c17", size = 232077, upload-time = "2025-04-18T21:32:31.036Z" }, - { url = "https://files.pythonhosted.org/packages/c4/e5/f698068dd34af79c270dbf9675b5f8075a005779c6c25a78dc7730c340bd/stringzilla-3.12.5-cp311-cp311-manylinux_2_17_ppc64le.manylinux2014_ppc64le.manylinux_2_28_ppc64le.whl", hash = "sha256:ff2df3ced63d4d1c99130aa6fc686a363a5d7c07a7f4d17646f0197f673da118", size = 235392, upload-time = "2025-04-18T21:32:32.541Z" }, - { url = "https://files.pythonhosted.org/packages/c2/3f/6e5f99b2ca17150d382f21512845558eb0937522ad3d43de780e265061ab/stringzilla-3.12.5-cp311-cp311-manylinux_2_17_s390x.manylinux2014_s390x.manylinux_2_28_s390x.whl", hash = "sha256:40dbc6db2061eb0c2759fa136434e8def3e68143c67a46842a633672b80d78f5", size = 206516, upload-time = "2025-04-18T21:32:34.248Z" }, - { url = "https://files.pythonhosted.org/packages/97/11/9dbb7be39115d0ef30f6787bb0842233faac1a6db76b661c668c2013cd5b/stringzilla-3.12.5-cp311-cp311-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:7e55bc1c3e3de1a8816ce0442e627dd6a46afb319291c981cf2becf149eb4fc6", size = 212053, upload-time = "2025-04-18T21:32:35.756Z" }, - { url = "https://files.pythonhosted.org/packages/bd/a8/dbb08d6576d0f4302897a23ef6f5626ec0015a0515b85336f845101118f9/stringzilla-3.12.5-cp311-cp311-manylinux_2_5_x86_64.manylinux1_x86_64.manylinux_2_28_x86_64.whl", hash = "sha256:7a4281220e0fb395265d035c2f488a4b4fed111ca36fcb67ac32b94fea004c48", size = 307796, upload-time = "2025-04-18T21:32:37.286Z" }, - { url = "https://files.pythonhosted.org/packages/d9/00/997b48e2b4ee087aa85994a5603b9dae35bf299d29265702521916b7c0d9/stringzilla-3.12.5-cp311-cp311-musllinux_1_2_aarch64.whl", hash = "sha256:6ef2d489b9148fa810c7cd73543f27525750a448cb931c2baa4ab413291597cf", size = 227235, upload-time = "2025-04-18T21:32:38.839Z" }, - { url = "https://files.pythonhosted.org/packages/aa/f9/012212a7098c27b19ef9f456c38d9dbd1288cc8e58a3a09b6dd96b028c03/stringzilla-3.12.5-cp311-cp311-musllinux_1_2_armv7l.whl", hash = "sha256:83f19578361dfa7821c1809b0da5d8df13f5470f86405ffc3f529a9336c6a323", size = 201300, upload-time = "2025-04-18T21:32:40.813Z" }, - { url = "https://files.pythonhosted.org/packages/ee/03/0c133cc8639576bbfcdfb443ead52fe4997ba5851be283050ea82e186dc9/stringzilla-3.12.5-cp311-cp311-musllinux_1_2_i686.whl", hash = "sha256:0cff7a8000ea05009b9d452266dfc3cd12fc81a3a1fd44d68e34374eef38e0f1", size = 213683, upload-time = "2025-04-18T21:32:42.248Z" }, - { url = "https://files.pythonhosted.org/packages/6c/5d/8c9964e6f56dc5ee3814e2f9a12eb1bd6c9200b03aff469509377d40a5e3/stringzilla-3.12.5-cp311-cp311-musllinux_1_2_ppc64le.whl", hash = "sha256:d74d17fb66f1329d965b533b18dc135eb85a25cfe1e25c06b6936630f0bfde1b", size = 232541, upload-time = "2025-04-18T21:32:43.806Z" }, - { url = "https://files.pythonhosted.org/packages/db/a5/5ed7806e4c959378dcf35eb608603a0488843f73016ce40e81c5c0a598f3/stringzilla-3.12.5-cp311-cp311-musllinux_1_2_s390x.whl", hash = "sha256:83e1056b288171efa9e7dea7bdd2f4d7f3212d9e3e12a7e8cd2e760a2de93f8b", size = 206473, upload-time = "2025-04-18T21:32:45.34Z" }, - { url = "https://files.pythonhosted.org/packages/e9/ac/6ad92b988777fee8ea72f86c5f31d50b8d611903a8c39c7e72ed3cdbd143/stringzilla-3.12.5-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:8bae3f14abfe1bee1e6fd99c5a21e28ee1df4b8d4e2551856079cfb776cc14fc", size = 302036, upload-time = "2025-04-18T21:32:46.903Z" }, - { url = "https://files.pythonhosted.org/packages/5b/9a/3b8096592ec09995db3be9498afdd5063458df0a96bf0aa70c8bf22a6bf1/stringzilla-3.12.5-cp311-cp311-win32.whl", hash = "sha256:8de56b53a0bee3866516121002f9ec5c97bbd401aafc4a074abf9e909d11a130", size = 68531, upload-time = "2025-04-18T21:32:48.382Z" }, - { url = "https://files.pythonhosted.org/packages/b8/48/08265678340debbeb091f7056ea1113c3f0329978035955a9e205ddf0c5d/stringzilla-3.12.5-cp311-cp311-win_amd64.whl", hash = "sha256:7b8c36d426cb6011d2b97c69eb18eb859d8c56c9fcb26cf99d9eca2f8abc95bf", size = 80125, upload-time = "2025-04-18T21:32:49.72Z" }, - { url = "https://files.pythonhosted.org/packages/fa/b5/c63820c972a1a84b0b184798f5ce41da0715fa65fd240459f776c0cbb0b4/stringzilla-3.12.5-cp311-cp311-win_arm64.whl", hash = "sha256:d026d00adfaf245510ef6778eaf49def94381420efc02b3d3305a66c3d85297e", size = 69782, upload-time = "2025-04-18T21:32:51.06Z" }, - { url = "https://files.pythonhosted.org/packages/2f/02/3b70a5e69d1ebc6b6c5a9d6520e3450f39d45ec3c4e45cb5267aa590d980/stringzilla-3.12.5-cp312-cp312-macosx_10_13_universal2.whl", hash = "sha256:1171346784802f62282ef156f0168d52e7ba213fbaf566697f613fb20bd98bc2", size = 122044, upload-time = "2025-04-18T21:32:52.48Z" }, - { url = "https://files.pythonhosted.org/packages/23/83/e658a589dd2077c355926a9fb42c0669579ad1420cff963e5200bd73a0b0/stringzilla-3.12.5-cp312-cp312-macosx_10_13_x86_64.whl", hash = "sha256:c3ec9837752dfed493642952ead9829fb3c4befaa9b4f4a74f32e626a1fba664", size = 79590, upload-time = "2025-04-18T21:32:53.933Z" }, - { url = "https://files.pythonhosted.org/packages/ab/4d/0dd25abfd2889601287cf1f4b1757db36ae49f92c19a49243624b29cd328/stringzilla-3.12.5-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:baf438334499cdaa43488c359f2c5eaf8ad79dbb84727c6e05d892dcd6be2dd7", size = 79547, upload-time = "2025-04-18T21:32:55.592Z" }, - { url = "https://files.pythonhosted.org/packages/42/c7/e9da1856a35863fbb42fc00c4f5a517da9f0d8b8bfe55d067e14c1dee241/stringzilla-3.12.5-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.manylinux_2_28_aarch64.whl", hash = "sha256:a751bfc39b280e31932c8206c814f67ed0f45ac182977bb1116aa3cbfbc8bba8", size = 231921, upload-time = "2025-04-18T21:32:56.944Z" }, - { url = "https://files.pythonhosted.org/packages/cc/b3/0cfd13dc65467f5bb4cc234f947bd64b01dad873f10904ade9e453933b04/stringzilla-3.12.5-cp312-cp312-manylinux_2_17_ppc64le.manylinux2014_ppc64le.manylinux_2_28_ppc64le.whl", hash = "sha256:3bd12dd3b4a56fb93d28058f8c200835f86cb67b4fbfc83679a15e4f0ba7b0dd", size = 234814, upload-time = "2025-04-18T21:32:58.643Z" }, - { url = "https://files.pythonhosted.org/packages/40/9d/8e48d88577ab1fca6aae1c8b7275ad28a9409700d93007dc2103485c5f55/stringzilla-3.12.5-cp312-cp312-manylinux_2_17_s390x.manylinux2014_s390x.manylinux_2_28_s390x.whl", hash = "sha256:3304d0f5b74acb132154e0861c0c72bee419fd5280d30bad59580c188c79b337", size = 206471, upload-time = "2025-04-18T21:33:00.158Z" }, - { url = "https://files.pythonhosted.org/packages/78/62/dce966ec333cc256f72b2b50e1fc4d53cb9ab27623772559fab2a4372b69/stringzilla-3.12.5-cp312-cp312-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:315f9b14d56c94d414014a34722e5b9beb68befdb1b30ec82a62f8b00c9446a2", size = 212052, upload-time = "2025-04-18T21:33:01.719Z" }, - { url = "https://files.pythonhosted.org/packages/6d/69/b6078679cab6b4ea92a2895d8643875bb27398f4e5aacde5a7648e641708/stringzilla-3.12.5-cp312-cp312-manylinux_2_5_x86_64.manylinux1_x86_64.manylinux_2_28_x86_64.whl", hash = "sha256:48efbe3ea3f9dc69b4262f4858b68b0a2abf546f9be1927ef208026e2838393b", size = 308367, upload-time = "2025-04-18T21:33:03.848Z" }, - { url = "https://files.pythonhosted.org/packages/5c/d6/e41d29a18a91f1d24e0ff6edaaf47f4eeb696370640cb3b028ef88331f48/stringzilla-3.12.5-cp312-cp312-musllinux_1_2_aarch64.whl", hash = "sha256:6456fe5df5ea265e8c6c32595c7213fbe44e48b9fc8b7b6908e0d581ee427a2f", size = 227026, upload-time = "2025-04-18T21:33:05.382Z" }, - { url = "https://files.pythonhosted.org/packages/05/1b/514ec95ad68b9c00ba8e268b6b0c08d3e517f770b9b996327fc98905ff49/stringzilla-3.12.5-cp312-cp312-musllinux_1_2_armv7l.whl", hash = "sha256:ded46cc4b18d802f98af954e54cfaf32fcfb7ee37b25b1cf7bda11ea0aaa130f", size = 201951, upload-time = "2025-04-18T21:33:06.893Z" }, - { url = "https://files.pythonhosted.org/packages/96/24/f51213e77144699f5c7c3c0ce947d79f4315f6441e2f33a3b0d952d8d284/stringzilla-3.12.5-cp312-cp312-musllinux_1_2_i686.whl", hash = "sha256:91979eea022d25ed12cf6f8ac06d789bd1ffab8da5ac213d1ad21c0529745a06", size = 213551, upload-time = "2025-04-18T21:33:08.523Z" }, - { url = "https://files.pythonhosted.org/packages/64/5d/b52f1ca7e27ce6711d7f03b5e4019a27769508c6fd4a03507e023a527ec9/stringzilla-3.12.5-cp312-cp312-musllinux_1_2_ppc64le.whl", hash = "sha256:bdfd266a145085e3f7fe9041528fe2657c2c2aafefffe4f822eb9a694d325d12", size = 232001, upload-time = "2025-04-18T21:33:10.155Z" }, - { url = "https://files.pythonhosted.org/packages/fa/ed/e6938136b2a4879f01ce89ed7aa0381097c72b36038811ea8baac0787648/stringzilla-3.12.5-cp312-cp312-musllinux_1_2_s390x.whl", hash = "sha256:7a1e0d1329e773d202c8721a371ce6b56dc796b6375e4588304d31adc906d267", size = 207107, upload-time = "2025-04-18T21:33:11.713Z" }, - { url = "https://files.pythonhosted.org/packages/e2/dc/e301945f24d4d45de8a05579ec5ee3e67de2a2401a9c1958a7fb26063404/stringzilla-3.12.5-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:b2d438848942e83c0a0dcda5023fc8431535c00f671545e76f09ec08d66c57a3", size = 302701, upload-time = "2025-04-18T21:33:13.461Z" }, - { url = "https://files.pythonhosted.org/packages/90/ae/7771372a002e62dc708699e9a6b740f5171cad3a651c053219edd973f4ce/stringzilla-3.12.5-cp312-cp312-win32.whl", hash = "sha256:ef8c79f8c341a1aa36dc465cdd1640c60023b3b9bfebfcecd8a7e250f9f9927a", size = 68634, upload-time = "2025-04-18T21:33:14.999Z" }, - { url = "https://files.pythonhosted.org/packages/3b/33/48ccae51648650f3403d06e07c98826791b0a21d2b2c21eb65ea6d2e1f18/stringzilla-3.12.5-cp312-cp312-win_amd64.whl", hash = "sha256:c9b7d96e8229d5d234f9d1f9f2a8df1eac8606863d116a60618d371884d96f14", size = 80134, upload-time = "2025-04-18T21:33:16.45Z" }, - { url = "https://files.pythonhosted.org/packages/f9/c3/5c36f103f17c78120b7bbdbae4b82b1da468b7d1a318189a3c069b7ccf0b/stringzilla-3.12.5-cp312-cp312-win_arm64.whl", hash = "sha256:c20c5438bb66f1f36f447d3b122f58a41b7218d086024567c42da0a873cf28fe", size = 69740, upload-time = "2025-04-18T21:33:17.884Z" }, - { url = "https://files.pythonhosted.org/packages/3a/12/2be50b4f963e6093cc452420487576051521f2740c81c992a261586dfc76/stringzilla-3.12.5-cp313-cp313-macosx_10_13_universal2.whl", hash = "sha256:8f1d0d8ad3b5115c524dddfb882c5752f04c9a1852a33a83a5dc04f99304c1bc", size = 122052, upload-time = "2025-04-18T21:33:19.897Z" }, - { url = "https://files.pythonhosted.org/packages/0f/47/460277da6abfcfb32d0456b08bd1048dba2a12fa217f2b521780f0534367/stringzilla-3.12.5-cp313-cp313-macosx_10_13_x86_64.whl", hash = "sha256:d3140697c9fb77b7e1a7e64cafb21e8c2c7db328b584168c7591a271c78115a7", size = 79597, upload-time = "2025-04-18T21:33:21.735Z" }, - { url = "https://files.pythonhosted.org/packages/87/4e/7709811ed2a695ee36f83cf6024053f6f4fcb225e71724db7e401344ccc4/stringzilla-3.12.5-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:c4caf1eccc4e62c2380b712d51d54579618b4b7ab7321d16ac1bd3db95b7ca7c", size = 79544, upload-time = "2025-04-18T21:33:23.178Z" }, - { url = "https://files.pythonhosted.org/packages/17/3c/676843687c0abbc9fdd5befe64ae57338c65ca12cf61adf5bb188988984e/stringzilla-3.12.5-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.manylinux_2_28_aarch64.whl", hash = "sha256:d6462c127d89257925d2c06d023b6b9975e3310acad4b5d262bd48ed899ddbc7", size = 231934, upload-time = "2025-04-18T21:33:24.733Z" }, - { url = "https://files.pythonhosted.org/packages/47/a9/c99e1a4d4fc4ef67eaf40713d24fe45d7abf0885bab84d48d65912d6b5c3/stringzilla-3.12.5-cp313-cp313-manylinux_2_17_ppc64le.manylinux2014_ppc64le.manylinux_2_28_ppc64le.whl", hash = "sha256:6b04e810073c7e4e1aa97838a3c5eb51e17c1e0943b2572d007cf98c69c88ab2", size = 234830, upload-time = "2025-04-18T21:33:26.308Z" }, - { url = "https://files.pythonhosted.org/packages/80/ec/ece11b021b7f04020163ef34939ed7a8a1d19470c03f0a408928404d4e76/stringzilla-3.12.5-cp313-cp313-manylinux_2_17_s390x.manylinux2014_s390x.manylinux_2_28_s390x.whl", hash = "sha256:a49e387bde691c962483499a4e3e2741ebb577e26ea69d612e430d4d9dcddccf", size = 206525, upload-time = "2025-04-18T21:33:27.837Z" }, - { url = "https://files.pythonhosted.org/packages/27/5f/be467c238f36acde7467f1e73d9c6b9d027005216b28c20d358420caa8dc/stringzilla-3.12.5-cp313-cp313-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:891a33fb58164ed52ab99fd977cf3a88cb49be56ea9e8a4f6299a9a17876a661", size = 212112, upload-time = "2025-04-18T21:33:29.462Z" }, - { url = "https://files.pythonhosted.org/packages/2d/0b/0e0cc33a040ede908cbf6fbbe5342d230dbaa82640c66237ee804ecbebae/stringzilla-3.12.5-cp313-cp313-manylinux_2_5_x86_64.manylinux1_x86_64.manylinux_2_28_x86_64.whl", hash = "sha256:0f7e8f8edd1fe9daf17fd33807d042b61d04d5ae4b2f2b377bd098f21b1785e0", size = 308399, upload-time = "2025-04-18T21:33:31.037Z" }, - { url = "https://files.pythonhosted.org/packages/29/23/e442dcad668eb34cfb923703ec25f5ea7f2148ea15c8e7a8626de9c20ab9/stringzilla-3.12.5-cp313-cp313-musllinux_1_2_aarch64.whl", hash = "sha256:f7d8b0931a3da7bab8ca8f1dfb76229e23e928ebb0714b44f4efa1d599ab2730", size = 227031, upload-time = "2025-04-18T21:33:32.643Z" }, - { url = "https://files.pythonhosted.org/packages/f8/aa/a4d5be7897a219fcb1347106a92e0e8cafd99f00300b7946ffa1e5d1800d/stringzilla-3.12.5-cp313-cp313-musllinux_1_2_armv7l.whl", hash = "sha256:fa87b5fa1bc0c67a6c14517c32278299ac292ccfe7ba937026f537a80532255f", size = 201967, upload-time = "2025-04-18T21:33:34.768Z" }, - { url = "https://files.pythonhosted.org/packages/1c/19/448c24de9ea826d4df789d21b460d42954658cc3e9e5be126b08ff2f319f/stringzilla-3.12.5-cp313-cp313-musllinux_1_2_i686.whl", hash = "sha256:2086748bc23f42ff724981d9e5e18f28f673b6ed593d8c4ba1272bd45a7563be", size = 213594, upload-time = "2025-04-18T21:33:36.358Z" }, - { url = "https://files.pythonhosted.org/packages/f3/f4/7c9d8c1a9fb067bca85fe04398b35a3f900c9487a4cb2410fee5b1cd838c/stringzilla-3.12.5-cp313-cp313-musllinux_1_2_ppc64le.whl", hash = "sha256:5da15a319f76b7fdba403d5b93ecd982e84faa010d40a28aeb25c0864e01df46", size = 232058, upload-time = "2025-04-18T21:33:37.885Z" }, - { url = "https://files.pythonhosted.org/packages/b1/8b/3ec4aafddf7e9693ffb2adcb8d1515dafb76be41171da1a1b6d0d3b055fb/stringzilla-3.12.5-cp313-cp313-musllinux_1_2_s390x.whl", hash = "sha256:9b8408bbd14e0df3feed03c7719269f0f7e0ddb4b6a44f53eb2102a645a4c8bf", size = 207094, upload-time = "2025-04-18T21:33:39.484Z" }, - { url = "https://files.pythonhosted.org/packages/db/bf/6047e5ff3976027e1bdff104a40d5768c4b858c210c3b46740d1bc59dc39/stringzilla-3.12.5-cp313-cp313-musllinux_1_2_x86_64.whl", hash = "sha256:dab98e2e20de12b03868011f82438a5b3e5c5a215ae9c8ab3cd8c2e1dc708b90", size = 302743, upload-time = "2025-04-18T21:33:41.067Z" }, - { url = "https://files.pythonhosted.org/packages/19/bd/6de50e3b969ba417825ddd8cb6f36d34981cacb90d026769b5dca2d7e5fb/stringzilla-3.12.5-cp313-cp313-win32.whl", hash = "sha256:98d22acd6c06864df30df0860307fb6fb6ca98af0bdd0d0877fc182bf580afbd", size = 68637, upload-time = "2025-04-18T21:33:42.687Z" }, - { url = "https://files.pythonhosted.org/packages/a4/08/849dc695e49d017bc314b2e65a79c5ff1c140fc3f99b13df1e240597c8e1/stringzilla-3.12.5-cp313-cp313-win_amd64.whl", hash = "sha256:a921412385671db26dc4b078529ac6001c93445f06ff71e339a315c0e261d459", size = 80138, upload-time = "2025-04-18T21:33:44.243Z" }, - { url = "https://files.pythonhosted.org/packages/53/a1/d8d7144490b49598cdb166f4389614b251b35c531aeb5a29f424a3e42df4/stringzilla-3.12.5-cp313-cp313-win_arm64.whl", hash = "sha256:101d94f351d918144389ff316ff61efb06f645702078c48d7c4e0973b788fab9", size = 69748, upload-time = "2025-04-18T21:33:45.757Z" }, -] - -[[package]] -name = "sympy" -version = "1.14.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "mpmath" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/83/d3/803453b36afefb7c2bb238361cd4ae6125a569b4db67cd9e79846ba2d68c/sympy-1.14.0.tar.gz", hash = "sha256:d3d3fe8df1e5a0b42f0e7bdf50541697dbe7d23746e894990c030e2b05e72517", size = 7793921, upload-time = "2025-04-27T18:05:01.611Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/a2/09/77d55d46fd61b4a135c444fc97158ef34a095e5681d0a6c10b75bf356191/sympy-1.14.0-py3-none-any.whl", hash = "sha256:e091cc3e99d2141a0ba2847328f5479b05d94a6635cb96148ccb3f34671bd8f5", size = 6299353, upload-time = "2025-04-27T18:04:59.103Z" }, -] - -[[package]] -name = "tensorstore" -version = "0.1.75" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "ml-dtypes" }, - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/00/4e/5be077c63d01af420ca8a009cad3b30fef137ef37f6530c266f4f2628382/tensorstore-0.1.75.tar.gz", hash = "sha256:515cc90f5b6c316443f44794168083326fb29a0e50b0cd8fbd4cb3e0f32a3922", size = 6831417, upload-time = "2025-05-14T00:38:05.037Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/2c/d7/a4c8aef565856ef94a9b27412484f1444128c8092cfb61965c1847ff26a3/tensorstore-0.1.75-cp310-cp310-macosx_10_14_x86_64.whl", hash = "sha256:d48ea1def76d38465b362cc936a14538e62beccf7f44c01fd048f035689df13b", size = 15607121, upload-time = "2025-05-14T00:37:10.02Z" }, - { url = "https://files.pythonhosted.org/packages/70/51/b6cdfa575e66d0faff337db3220493dde154f6deb8ac7370ab31be32603a/tensorstore-0.1.75-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:110fccf719d4ae1e9eb6d3f32a22cd2dac7af994ff7a4ea62d29c2538d467d19", size = 13532935, upload-time = "2025-05-14T00:37:12.42Z" }, - { url = "https://files.pythonhosted.org/packages/c5/e2/38d558b64f42c70d3fabdef3540bd3cbe2ffb02d8c26cb83e2bde374e165/tensorstore-0.1.75-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:226e075d18ac45cda4e6b89e7129d2ea515cb558ec3e79cfe855acbaf2696187", size = 17459195, upload-time = "2025-05-14T00:37:14.26Z" }, - { url = "https://files.pythonhosted.org/packages/ea/41/87d49bf59dc2b81c8e10c3fda5ac93edd078800e324078bdf6466dd5260b/tensorstore-0.1.75-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:83f85f1012dee46f87fa37f5439c15adffd2626eda31082c88d0740edc0bdca0", size = 18830336, upload-time = "2025-05-14T00:37:25.394Z" }, - { url = "https://files.pythonhosted.org/packages/e7/0f/c3fc8c1bdff0731cac344cf634b33aa34b6116ee2134b2545cc5fa24bda3/tensorstore-0.1.75-cp310-cp310-win_amd64.whl", hash = "sha256:4e62be65c18e903db2ccd6d08016c0fc41453cde98d125ec00bad9b68253c614", size = 12601387, upload-time = "2025-05-14T00:37:27.905Z" }, - { url = "https://files.pythonhosted.org/packages/da/dc/1c0e51bca34ab1f8a22973bff1750de1224db5255a4fef67be87a91c6188/tensorstore-0.1.75-cp311-cp311-macosx_10_14_x86_64.whl", hash = "sha256:b7caa0e4d5c9915450493329c9a8cee6191a2305abffab447d2b5c5f09b9be57", size = 15607968, upload-time = "2025-05-14T00:37:30.355Z" }, - { url = "https://files.pythonhosted.org/packages/15/9a/a13df8337e13206cab83f0853093a31377847b48ec727eb8351b6ff7f683/tensorstore-0.1.75-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:095f3bc402539cc1f98dbf3fbe23e290be133f8ecedbc81ffa4629d38391c5b7", size = 13534661, upload-time = "2025-05-14T00:37:32.804Z" }, - { url = "https://files.pythonhosted.org/packages/79/fb/f7e7a06d2e1655dd1771e527f4d07a458c3a9de0954e745b8e073413b1b0/tensorstore-0.1.75-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:6ceeda98ede97b80ad61171ad31050fc1ed180b771341981a57d2d50bce4d28d", size = 17462731, upload-time = "2025-05-14T00:37:35.088Z" }, - { url = "https://files.pythonhosted.org/packages/0e/1d/1dcd6a1b9c4bb5e451ee08be7399a3c55997203b6754a7d6b71da7b21086/tensorstore-0.1.75-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:d1bc649c421ca4f3e72dad71fa0c006b08f77b26df825684fba35d2a6131840f", size = 18832874, upload-time = "2025-05-14T00:37:37.647Z" }, - { url = "https://files.pythonhosted.org/packages/51/57/9beac1a7e58340deba53ea401cabf59449237e4a2602360c1abe0ae0c770/tensorstore-0.1.75-cp311-cp311-win_amd64.whl", hash = "sha256:4f5a4a63cbb2867a70334682e4e3d8088c9a1294010de53598267092690001cc", size = 12602524, upload-time = "2025-05-14T00:37:39.906Z" }, - { url = "https://files.pythonhosted.org/packages/ac/fb/28a5f8035cadbae34bdcaf03a8e0d731fd8bc8c9804ed8f54413cbfddeda/tensorstore-0.1.75-cp312-cp312-macosx_10_14_x86_64.whl", hash = "sha256:bc092152673a993df1867bac16622f5f382816184f2244df9ff78ba7f781e642", size = 15644019, upload-time = "2025-05-14T00:37:41.892Z" }, - { url = "https://files.pythonhosted.org/packages/16/52/b289ac969d7cee8c253b2f90e5cd6b37789f704147ff7fffa8a50e7b97c4/tensorstore-0.1.75-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:d5c6c8ef6c6758f7e11a4cbc7fc4e23af5170128901df729185b7870f6dbc071", size = 13557511, upload-time = "2025-05-14T00:37:44.508Z" }, - { url = "https://files.pythonhosted.org/packages/35/50/a2c4271e2512ace24290d2d7cf166aaf6e251ef14d20255d98a96c6a9514/tensorstore-0.1.75-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:8bbb30f24aef98d43657d132833f5577bfa91497769ef6b5238c5faccf7afe35", size = 17454887, upload-time = "2025-05-14T00:37:46.918Z" }, - { url = "https://files.pythonhosted.org/packages/a3/1d/9b2610a0770a2115e4a20c1a9377e2e14efabeb55852d150832ff82346f4/tensorstore-0.1.75-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:f08d9c2b8b84c892c3c81f6025ec189f58bd7860bf624c32646e5bee81870f95", size = 18820501, upload-time = "2025-05-14T00:37:49.022Z" }, - { url = "https://files.pythonhosted.org/packages/b9/9c/06f7318bd56fe62ccd7743159cd9e133b5e0ead5b8b229a6f1f392e65666/tensorstore-0.1.75-cp312-cp312-win_amd64.whl", hash = "sha256:39d4173bdbbc1cf41e168fe730fd457a6b0c4100ba707254260f63cb9ad3ef0b", size = 12607424, upload-time = "2025-05-14T00:37:51.368Z" }, - { url = "https://files.pythonhosted.org/packages/c1/97/656252b262099fdc8b3f247c58ec147ba644f4fc4dec8f7af3ffb352704e/tensorstore-0.1.75-cp313-cp313-macosx_10_14_x86_64.whl", hash = "sha256:0d2f87ca268faf903d5ffba6157fd9aeb42e9f961cea01b98baa690f71f51a1e", size = 15644856, upload-time = "2025-05-14T00:37:53.28Z" }, - { url = "https://files.pythonhosted.org/packages/94/e1/66067a2aa5c2890c02397df65d748978de1dbbe91ce394f285f86390c149/tensorstore-0.1.75-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:17ee80f9869b5a4b0303cb37edca9c9665af7a9510fac85f59fb8de19f12efd1", size = 13557924, upload-time = "2025-05-14T00:37:55.249Z" }, - { url = "https://files.pythonhosted.org/packages/46/56/c1245f7bb674072bb0f9e8516bd60f7608ffe114e911c08ebcaefca58f46/tensorstore-0.1.75-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:f00144d23eaf511104651b4479fcb111b9befc13db3018277d358144be503ef4", size = 17454695, upload-time = "2025-05-14T00:37:58.521Z" }, - { url = "https://files.pythonhosted.org/packages/db/78/8a103a9012662fb8d85c3d6daa9c9678d49f260a21b5426e0a1616e63c42/tensorstore-0.1.75-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:5c8697cab7b24440a13df8d9e6d000c1067ed3f97204a3dae5388e9e60606834", size = 18820794, upload-time = "2025-05-14T00:38:01.253Z" }, - { url = "https://files.pythonhosted.org/packages/7d/3d/69d7997fe67fd9cb8fce07ea0f3f3e754a6ea0d2c16f1c46e178abe7da0e/tensorstore-0.1.75-cp313-cp313-win_amd64.whl", hash = "sha256:df410ca28e679c1c8a5b361267ce02fe60a9c4d78964cb984d884d15c538f2f2", size = 12607428, upload-time = "2025-05-14T00:38:03.32Z" }, -] - -[[package]] -name = "testcontainers" -version = "4.10.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "docker" }, - { name = "python-dotenv" }, - { name = "typing-extensions" }, - { name = "urllib3" }, - { name = "wrapt" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/a1/49/9c618aff1c50121d183cdfbc3a4a5cf2727a2cde1893efe6ca55c7009196/testcontainers-4.10.0.tar.gz", hash = "sha256:03f85c3e505d8b4edeb192c72a961cebbcba0dd94344ae778b4a159cb6dcf8d3", size = 63327, upload-time = "2025-04-02T16:13:27.582Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/1c/0a/824b0c1ecf224802125279c3effff2e25ed785ed046e67da6e53d928de4c/testcontainers-4.10.0-py3-none-any.whl", hash = "sha256:31ed1a81238c7e131a2a29df6db8f23717d892b592fa5a1977fd0dcd0c23fc23", size = 107414, upload-time = "2025-04-02T16:13:25.785Z" }, -] - -[[package]] -name = "testcontainers-core" -version = "0.0.1rc1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "docker" }, - { name = "wrapt" }, -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/a0/84/ac813e7aed7a527e5bc4c7cbb6e47d72498e76b8371e3805ccab96619b38/testcontainers_core-0.0.1rc1-py3-none-any.whl", hash = "sha256:69a8bf2ddb52ac2d03c26401b12c70db0453cced40372ad783d6dce417e52095", size = 11628, upload-time = "2023-01-06T16:37:25.437Z" }, -] - -[[package]] -name = "testcontainers-rabbitmq" -version = "0.0.1rc1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "pika" }, - { name = "testcontainers-core" }, -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/40/7c/a7fbec29e1a5d5b1ce928cb73a7d023b3ce211bf8879bab7101b809ce569/testcontainers_rabbitmq-0.0.1rc1-py3-none-any.whl", hash = "sha256:86424439bf8486c1fb27857d52ff655d7d8fdc68b133802a4ebe07f20f638fc7", size = 3413, upload-time = "2023-01-06T16:37:17.313Z" }, -] - -[[package]] -name = "threadpoolctl" -version = "3.6.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/b7/4d/08c89e34946fce2aec4fbb45c9016efd5f4d7f24af8e5d93296e935631d8/threadpoolctl-3.6.0.tar.gz", hash = "sha256:8ab8b4aa3491d812b623328249fab5302a68d2d71745c8a4c719a2fcaba9f44e", size = 21274, upload-time = "2025-03-13T13:49:23.031Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/32/d5/f9a850d79b0851d1d4ef6456097579a9005b31fea68726a4ae5f2d82ddd9/threadpoolctl-3.6.0-py3-none-any.whl", hash = "sha256:43a0b8fd5a2928500110039e43a5eed8480b918967083ea48dc3ab9f13c4a7fb", size = 18638, upload-time = "2025-03-13T13:49:21.846Z" }, -] - -[[package]] -name = "tifffile" -version = "2025.5.10" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version < '3.11' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version < '3.11' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", -] -dependencies = [ - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/44/d0/18fed0fc0916578a4463f775b0fbd9c5fed2392152d039df2fb533bfdd5d/tifffile-2025.5.10.tar.gz", hash = "sha256:018335d34283aa3fd8c263bae5c3c2b661ebc45548fde31504016fcae7bf1103", size = 365290, upload-time = "2025-05-10T19:22:34.386Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/5d/06/bd0a6097da704a7a7c34a94cfd771c3ea3c2f405dd214e790d22c93f6be1/tifffile-2025.5.10-py3-none-any.whl", hash = "sha256:e37147123c0542d67bc37ba5cdd67e12ea6fbe6e86c52bee037a9eb6a064e5ad", size = 226533, upload-time = "2025-05-10T19:22:27.279Z" }, -] - -[[package]] -name = "tifffile" -version = "2025.6.11" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version >= '3.13' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version >= '3.13' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.12.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", - "python_full_version == '3.11.*' and sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')", -] -dependencies = [ - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/11/9e/636e3e433c24da41dd639e0520db60750dbf5e938d023b83af8097382ea3/tifffile-2025.6.11.tar.gz", hash = "sha256:0ece4c2e7a10656957d568a093b07513c0728d30c1bd8cc12725901fffdb7143", size = 370125, upload-time = "2025-06-12T04:49:38.839Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/3a/d8/1ba8f32bfc9cb69e37edeca93738e883f478fbe84ae401f72c0d8d507841/tifffile-2025.6.11-py3-none-any.whl", hash = "sha256:32effb78b10b3a283eb92d4ebf844ae7e93e151458b0412f38518b4e6d2d7542", size = 230800, upload-time = "2025-06-12T04:49:37.458Z" }, -] - -[[package]] -name = "timm" -version = "1.0.15" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "huggingface-hub" }, - { name = "pyyaml" }, - { name = "safetensors" }, - { name = "torch", version = "2.0.1", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://pypi.org/simple" }, marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" }, marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "extra == 'extra-7-comfyui-cu128' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.15.2", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1", source = { registry = "https://pypi.org/simple" }, marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" }, marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "(platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torchvision", version = "0.22.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/bc/0c/66b0f9b4a4cb9ffdac7b52b17b37c7d3c4f75623b469e388b0c6d89b4e88/timm-1.0.15.tar.gz", hash = "sha256:756a3bc30c96565f056e608a9b559daed904617eaadb6be536f96874879b1055", size = 2230258, upload-time = "2025-02-23T05:05:55.959Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/6c/d0/179abca8b984b3deefd996f362b612c39da73b60f685921e6cd58b6125b4/timm-1.0.15-py3-none-any.whl", hash = "sha256:5a3dc460c24e322ecc7fd1f3e3eb112423ddee320cb059cc1956fbc9731748ef", size = 2361373, upload-time = "2025-02-23T05:05:53.601Z" }, -] - -[[package]] -name = "tokenizers" -version = "0.21.1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "huggingface-hub" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/92/76/5ac0c97f1117b91b7eb7323dcd61af80d72f790b4df71249a7850c195f30/tokenizers-0.21.1.tar.gz", hash = "sha256:a1bb04dc5b448985f86ecd4b05407f5a8d97cb2c0532199b2a302a604a0165ab", size = 343256, upload-time = "2025-03-13T10:51:18.189Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/a5/1f/328aee25f9115bf04262e8b4e5a2050b7b7cf44b59c74e982db7270c7f30/tokenizers-0.21.1-cp39-abi3-macosx_10_12_x86_64.whl", hash = "sha256:e78e413e9e668ad790a29456e677d9d3aa50a9ad311a40905d6861ba7692cf41", size = 2780767, upload-time = "2025-03-13T10:51:09.459Z" }, - { url = "https://files.pythonhosted.org/packages/ae/1a/4526797f3719b0287853f12c5ad563a9be09d446c44ac784cdd7c50f76ab/tokenizers-0.21.1-cp39-abi3-macosx_11_0_arm64.whl", hash = "sha256:cd51cd0a91ecc801633829fcd1fda9cf8682ed3477c6243b9a095539de4aecf3", size = 2650555, upload-time = "2025-03-13T10:51:07.692Z" }, - { url = "https://files.pythonhosted.org/packages/4d/7a/a209b29f971a9fdc1da86f917fe4524564924db50d13f0724feed37b2a4d/tokenizers-0.21.1-cp39-abi3-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:28da6b72d4fb14ee200a1bd386ff74ade8992d7f725f2bde2c495a9a98cf4d9f", size = 2937541, upload-time = "2025-03-13T10:50:56.679Z" }, - { url = "https://files.pythonhosted.org/packages/3c/1e/b788b50ffc6191e0b1fc2b0d49df8cff16fe415302e5ceb89f619d12c5bc/tokenizers-0.21.1-cp39-abi3-manylinux_2_17_armv7l.manylinux2014_armv7l.whl", hash = "sha256:34d8cfde551c9916cb92014e040806122295a6800914bab5865deb85623931cf", size = 2819058, upload-time = "2025-03-13T10:50:59.525Z" }, - { url = "https://files.pythonhosted.org/packages/36/aa/3626dfa09a0ecc5b57a8c58eeaeb7dd7ca9a37ad9dd681edab5acd55764c/tokenizers-0.21.1-cp39-abi3-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:aaa852d23e125b73d283c98f007e06d4595732104b65402f46e8ef24b588d9f8", size = 3133278, upload-time = "2025-03-13T10:51:04.678Z" }, - { url = "https://files.pythonhosted.org/packages/a4/4d/8fbc203838b3d26269f944a89459d94c858f5b3f9a9b6ee9728cdcf69161/tokenizers-0.21.1-cp39-abi3-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:a21a15d5c8e603331b8a59548bbe113564136dc0f5ad8306dd5033459a226da0", size = 3144253, upload-time = "2025-03-13T10:51:01.261Z" }, - { url = "https://files.pythonhosted.org/packages/d8/1b/2bd062adeb7c7511b847b32e356024980c0ffcf35f28947792c2d8ad2288/tokenizers-0.21.1-cp39-abi3-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:2fdbd4c067c60a0ac7eca14b6bd18a5bebace54eb757c706b47ea93204f7a37c", size = 3398225, upload-time = "2025-03-13T10:51:03.243Z" }, - { url = "https://files.pythonhosted.org/packages/8a/63/38be071b0c8e06840bc6046991636bcb30c27f6bb1e670f4f4bc87cf49cc/tokenizers-0.21.1-cp39-abi3-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:2dd9a0061e403546f7377df940e866c3e678d7d4e9643d0461ea442b4f89e61a", size = 3038874, upload-time = "2025-03-13T10:51:06.235Z" }, - { url = "https://files.pythonhosted.org/packages/ec/83/afa94193c09246417c23a3c75a8a0a96bf44ab5630a3015538d0c316dd4b/tokenizers-0.21.1-cp39-abi3-musllinux_1_2_aarch64.whl", hash = "sha256:db9484aeb2e200c43b915a1a0150ea885e35f357a5a8fabf7373af333dcc8dbf", size = 9014448, upload-time = "2025-03-13T10:51:10.927Z" }, - { url = "https://files.pythonhosted.org/packages/ae/b3/0e1a37d4f84c0f014d43701c11eb8072704f6efe8d8fc2dcdb79c47d76de/tokenizers-0.21.1-cp39-abi3-musllinux_1_2_armv7l.whl", hash = "sha256:ed248ab5279e601a30a4d67bdb897ecbe955a50f1e7bb62bd99f07dd11c2f5b6", size = 8937877, upload-time = "2025-03-13T10:51:12.688Z" }, - { url = "https://files.pythonhosted.org/packages/ac/33/ff08f50e6d615eb180a4a328c65907feb6ded0b8f990ec923969759dc379/tokenizers-0.21.1-cp39-abi3-musllinux_1_2_i686.whl", hash = "sha256:9ac78b12e541d4ce67b4dfd970e44c060a2147b9b2a21f509566d556a509c67d", size = 9186645, upload-time = "2025-03-13T10:51:14.723Z" }, - { url = "https://files.pythonhosted.org/packages/5f/aa/8ae85f69a9f6012c6f8011c6f4aa1c96154c816e9eea2e1b758601157833/tokenizers-0.21.1-cp39-abi3-musllinux_1_2_x86_64.whl", hash = "sha256:e5a69c1a4496b81a5ee5d2c1f3f7fbdf95e90a0196101b0ee89ed9956b8a168f", size = 9384380, upload-time = "2025-03-13T10:51:16.526Z" }, - { url = "https://files.pythonhosted.org/packages/e8/5b/a5d98c89f747455e8b7a9504910c865d5e51da55e825a7ae641fb5ff0a58/tokenizers-0.21.1-cp39-abi3-win32.whl", hash = "sha256:1039a3a5734944e09de1d48761ade94e00d0fa760c0e0551151d4dd851ba63e3", size = 2239506, upload-time = "2025-03-13T10:51:20.643Z" }, - { url = "https://files.pythonhosted.org/packages/e6/b6/072a8e053ae600dcc2ac0da81a23548e3b523301a442a6ca900e92ac35be/tokenizers-0.21.1-cp39-abi3-win_amd64.whl", hash = "sha256:0f0dcbcc9f6e13e675a66d7a5f2f225a736745ce484c1a4e07476a89ccdad382", size = 2435481, upload-time = "2025-03-13T10:51:19.243Z" }, -] - -[[package]] -name = "tomli" -version = "2.2.1" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/18/87/302344fed471e44a87289cf4967697d07e532f2421fdaf868a303cbae4ff/tomli-2.2.1.tar.gz", hash = "sha256:cd45e1dc79c835ce60f7404ec8119f2eb06d38b1deba146f07ced3bbc44505ff", size = 17175, upload-time = "2024-11-27T22:38:36.873Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/43/ca/75707e6efa2b37c77dadb324ae7d9571cb424e61ea73fad7c56c2d14527f/tomli-2.2.1-cp311-cp311-macosx_10_9_x86_64.whl", hash = "sha256:678e4fa69e4575eb77d103de3df8a895e1591b48e740211bd1067378c69e8249", size = 131077, upload-time = "2024-11-27T22:37:54.956Z" }, - { url = "https://files.pythonhosted.org/packages/c7/16/51ae563a8615d472fdbffc43a3f3d46588c264ac4f024f63f01283becfbb/tomli-2.2.1-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:023aa114dd824ade0100497eb2318602af309e5a55595f76b626d6d9f3b7b0a6", size = 123429, upload-time = "2024-11-27T22:37:56.698Z" }, - { url = "https://files.pythonhosted.org/packages/f1/dd/4f6cd1e7b160041db83c694abc78e100473c15d54620083dbd5aae7b990e/tomli-2.2.1-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:ece47d672db52ac607a3d9599a9d48dcb2f2f735c6c2d1f34130085bb12b112a", size = 226067, upload-time = "2024-11-27T22:37:57.63Z" }, - { url = "https://files.pythonhosted.org/packages/a9/6b/c54ede5dc70d648cc6361eaf429304b02f2871a345bbdd51e993d6cdf550/tomli-2.2.1-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:6972ca9c9cc9f0acaa56a8ca1ff51e7af152a9f87fb64623e31d5c83700080ee", size = 236030, upload-time = "2024-11-27T22:37:59.344Z" }, - { url = "https://files.pythonhosted.org/packages/1f/47/999514fa49cfaf7a92c805a86c3c43f4215621855d151b61c602abb38091/tomli-2.2.1-cp311-cp311-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:c954d2250168d28797dd4e3ac5cf812a406cd5a92674ee4c8f123c889786aa8e", size = 240898, upload-time = "2024-11-27T22:38:00.429Z" }, - { url = "https://files.pythonhosted.org/packages/73/41/0a01279a7ae09ee1573b423318e7934674ce06eb33f50936655071d81a24/tomli-2.2.1-cp311-cp311-musllinux_1_2_aarch64.whl", hash = "sha256:8dd28b3e155b80f4d54beb40a441d366adcfe740969820caf156c019fb5c7ec4", size = 229894, upload-time = "2024-11-27T22:38:02.094Z" }, - { url = "https://files.pythonhosted.org/packages/55/18/5d8bc5b0a0362311ce4d18830a5d28943667599a60d20118074ea1b01bb7/tomli-2.2.1-cp311-cp311-musllinux_1_2_i686.whl", hash = "sha256:e59e304978767a54663af13c07b3d1af22ddee3bb2fb0618ca1593e4f593a106", size = 245319, upload-time = "2024-11-27T22:38:03.206Z" }, - { url = "https://files.pythonhosted.org/packages/92/a3/7ade0576d17f3cdf5ff44d61390d4b3febb8a9fc2b480c75c47ea048c646/tomli-2.2.1-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:33580bccab0338d00994d7f16f4c4ec25b776af3ffaac1ed74e0b3fc95e885a8", size = 238273, upload-time = "2024-11-27T22:38:04.217Z" }, - { url = "https://files.pythonhosted.org/packages/72/6f/fa64ef058ac1446a1e51110c375339b3ec6be245af9d14c87c4a6412dd32/tomli-2.2.1-cp311-cp311-win32.whl", hash = "sha256:465af0e0875402f1d226519c9904f37254b3045fc5084697cefb9bdde1ff99ff", size = 98310, upload-time = "2024-11-27T22:38:05.908Z" }, - { url = "https://files.pythonhosted.org/packages/6a/1c/4a2dcde4a51b81be3530565e92eda625d94dafb46dbeb15069df4caffc34/tomli-2.2.1-cp311-cp311-win_amd64.whl", hash = "sha256:2d0f2fdd22b02c6d81637a3c95f8cd77f995846af7414c5c4b8d0545afa1bc4b", size = 108309, upload-time = "2024-11-27T22:38:06.812Z" }, - { url = "https://files.pythonhosted.org/packages/52/e1/f8af4c2fcde17500422858155aeb0d7e93477a0d59a98e56cbfe75070fd0/tomli-2.2.1-cp312-cp312-macosx_10_13_x86_64.whl", hash = "sha256:4a8f6e44de52d5e6c657c9fe83b562f5f4256d8ebbfe4ff922c495620a7f6cea", size = 132762, upload-time = "2024-11-27T22:38:07.731Z" }, - { url = "https://files.pythonhosted.org/packages/03/b8/152c68bb84fc00396b83e7bbddd5ec0bd3dd409db4195e2a9b3e398ad2e3/tomli-2.2.1-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:8d57ca8095a641b8237d5b079147646153d22552f1c637fd3ba7f4b0b29167a8", size = 123453, upload-time = "2024-11-27T22:38:09.384Z" }, - { url = "https://files.pythonhosted.org/packages/c8/d6/fc9267af9166f79ac528ff7e8c55c8181ded34eb4b0e93daa767b8841573/tomli-2.2.1-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:4e340144ad7ae1533cb897d406382b4b6fede8890a03738ff1683af800d54192", size = 233486, upload-time = "2024-11-27T22:38:10.329Z" }, - { url = "https://files.pythonhosted.org/packages/5c/51/51c3f2884d7bab89af25f678447ea7d297b53b5a3b5730a7cb2ef6069f07/tomli-2.2.1-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:db2b95f9de79181805df90bedc5a5ab4c165e6ec3fe99f970d0e302f384ad222", size = 242349, upload-time = "2024-11-27T22:38:11.443Z" }, - { url = "https://files.pythonhosted.org/packages/ab/df/bfa89627d13a5cc22402e441e8a931ef2108403db390ff3345c05253935e/tomli-2.2.1-cp312-cp312-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:40741994320b232529c802f8bc86da4e1aa9f413db394617b9a256ae0f9a7f77", size = 252159, upload-time = "2024-11-27T22:38:13.099Z" }, - { url = "https://files.pythonhosted.org/packages/9e/6e/fa2b916dced65763a5168c6ccb91066f7639bdc88b48adda990db10c8c0b/tomli-2.2.1-cp312-cp312-musllinux_1_2_aarch64.whl", hash = "sha256:400e720fe168c0f8521520190686ef8ef033fb19fc493da09779e592861b78c6", size = 237243, upload-time = "2024-11-27T22:38:14.766Z" }, - { url = "https://files.pythonhosted.org/packages/b4/04/885d3b1f650e1153cbb93a6a9782c58a972b94ea4483ae4ac5cedd5e4a09/tomli-2.2.1-cp312-cp312-musllinux_1_2_i686.whl", hash = "sha256:02abe224de6ae62c19f090f68da4e27b10af2b93213d36cf44e6e1c5abd19fdd", size = 259645, upload-time = "2024-11-27T22:38:15.843Z" }, - { url = "https://files.pythonhosted.org/packages/9c/de/6b432d66e986e501586da298e28ebeefd3edc2c780f3ad73d22566034239/tomli-2.2.1-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:b82ebccc8c8a36f2094e969560a1b836758481f3dc360ce9a3277c65f374285e", size = 244584, upload-time = "2024-11-27T22:38:17.645Z" }, - { url = "https://files.pythonhosted.org/packages/1c/9a/47c0449b98e6e7d1be6cbac02f93dd79003234ddc4aaab6ba07a9a7482e2/tomli-2.2.1-cp312-cp312-win32.whl", hash = "sha256:889f80ef92701b9dbb224e49ec87c645ce5df3fa2cc548664eb8a25e03127a98", size = 98875, upload-time = "2024-11-27T22:38:19.159Z" }, - { url = "https://files.pythonhosted.org/packages/ef/60/9b9638f081c6f1261e2688bd487625cd1e660d0a85bd469e91d8db969734/tomli-2.2.1-cp312-cp312-win_amd64.whl", hash = "sha256:7fc04e92e1d624a4a63c76474610238576942d6b8950a2d7f908a340494e67e4", size = 109418, upload-time = "2024-11-27T22:38:20.064Z" }, - { url = "https://files.pythonhosted.org/packages/04/90/2ee5f2e0362cb8a0b6499dc44f4d7d48f8fff06d28ba46e6f1eaa61a1388/tomli-2.2.1-cp313-cp313-macosx_10_13_x86_64.whl", hash = "sha256:f4039b9cbc3048b2416cc57ab3bda989a6fcf9b36cf8937f01a6e731b64f80d7", size = 132708, upload-time = "2024-11-27T22:38:21.659Z" }, - { url = "https://files.pythonhosted.org/packages/c0/ec/46b4108816de6b385141f082ba99e315501ccd0a2ea23db4a100dd3990ea/tomli-2.2.1-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:286f0ca2ffeeb5b9bd4fcc8d6c330534323ec51b2f52da063b11c502da16f30c", size = 123582, upload-time = "2024-11-27T22:38:22.693Z" }, - { url = "https://files.pythonhosted.org/packages/a0/bd/b470466d0137b37b68d24556c38a0cc819e8febe392d5b199dcd7f578365/tomli-2.2.1-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:a92ef1a44547e894e2a17d24e7557a5e85a9e1d0048b0b5e7541f76c5032cb13", size = 232543, upload-time = "2024-11-27T22:38:24.367Z" }, - { url = "https://files.pythonhosted.org/packages/d9/e5/82e80ff3b751373f7cead2815bcbe2d51c895b3c990686741a8e56ec42ab/tomli-2.2.1-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:9316dc65bed1684c9a98ee68759ceaed29d229e985297003e494aa825ebb0281", size = 241691, upload-time = "2024-11-27T22:38:26.081Z" }, - { url = "https://files.pythonhosted.org/packages/05/7e/2a110bc2713557d6a1bfb06af23dd01e7dde52b6ee7dadc589868f9abfac/tomli-2.2.1-cp313-cp313-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:e85e99945e688e32d5a35c1ff38ed0b3f41f43fad8df0bdf79f72b2ba7bc5272", size = 251170, upload-time = "2024-11-27T22:38:27.921Z" }, - { url = "https://files.pythonhosted.org/packages/64/7b/22d713946efe00e0adbcdfd6d1aa119ae03fd0b60ebed51ebb3fa9f5a2e5/tomli-2.2.1-cp313-cp313-musllinux_1_2_aarch64.whl", hash = "sha256:ac065718db92ca818f8d6141b5f66369833d4a80a9d74435a268c52bdfa73140", size = 236530, upload-time = "2024-11-27T22:38:29.591Z" }, - { url = "https://files.pythonhosted.org/packages/38/31/3a76f67da4b0cf37b742ca76beaf819dca0ebef26d78fc794a576e08accf/tomli-2.2.1-cp313-cp313-musllinux_1_2_i686.whl", hash = "sha256:d920f33822747519673ee656a4b6ac33e382eca9d331c87770faa3eef562aeb2", size = 258666, upload-time = "2024-11-27T22:38:30.639Z" }, - { url = "https://files.pythonhosted.org/packages/07/10/5af1293da642aded87e8a988753945d0cf7e00a9452d3911dd3bb354c9e2/tomli-2.2.1-cp313-cp313-musllinux_1_2_x86_64.whl", hash = "sha256:a198f10c4d1b1375d7687bc25294306e551bf1abfa4eace6650070a5c1ae2744", size = 243954, upload-time = "2024-11-27T22:38:31.702Z" }, - { url = "https://files.pythonhosted.org/packages/5b/b9/1ed31d167be802da0fc95020d04cd27b7d7065cc6fbefdd2f9186f60d7bd/tomli-2.2.1-cp313-cp313-win32.whl", hash = "sha256:d3f5614314d758649ab2ab3a62d4f2004c825922f9e370b29416484086b264ec", size = 98724, upload-time = "2024-11-27T22:38:32.837Z" }, - { url = "https://files.pythonhosted.org/packages/c7/32/b0963458706accd9afcfeb867c0f9175a741bf7b19cd424230714d722198/tomli-2.2.1-cp313-cp313-win_amd64.whl", hash = "sha256:a38aa0308e754b0e3c67e344754dff64999ff9b513e691d0e786265c93583c69", size = 109383, upload-time = "2024-11-27T22:38:34.455Z" }, - { url = "https://files.pythonhosted.org/packages/6e/c2/61d3e0f47e2b74ef40a68b9e6ad5984f6241a942f7cd3bbfbdbd03861ea9/tomli-2.2.1-py3-none-any.whl", hash = "sha256:cb55c73c5f4408779d0cf3eef9f762b9c9f147a77de7b258bef0a5628adc85cc", size = 14257, upload-time = "2024-11-27T22:38:35.385Z" }, -] - -[[package]] -name = "tomlkit" -version = "0.13.3" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/cc/18/0bbf3884e9eaa38819ebe46a7bd25dcd56b67434402b66a58c4b8e552575/tomlkit-0.13.3.tar.gz", hash = "sha256:430cf247ee57df2b94ee3fbe588e71d362a941ebb545dec29b53961d61add2a1", size = 185207, upload-time = "2025-06-05T07:13:44.947Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/bd/75/8539d011f6be8e29f339c42e633aae3cb73bffa95dd0f9adec09b9c58e85/tomlkit-0.13.3-py3-none-any.whl", hash = "sha256:c89c649d79ee40629a9fda55f8ace8c6a1b42deb912b2a8fd8d942ddadb606b0", size = 38901, upload-time = "2025-06-05T07:13:43.546Z" }, -] - -[[package]] -name = "toolz" -version = "1.0.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/8a/0b/d80dfa675bf592f636d1ea0b835eab4ec8df6e9415d8cfd766df54456123/toolz-1.0.0.tar.gz", hash = "sha256:2c86e3d9a04798ac556793bced838816296a2f085017664e4995cb40a1047a02", size = 66790, upload-time = "2024-10-04T16:17:04.001Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/03/98/eb27cc78ad3af8e302c9d8ff4977f5026676e130d28dd7578132a457170c/toolz-1.0.0-py3-none-any.whl", hash = "sha256:292c8f1c4e7516bf9086f8850935c799a874039c8bcf959d47b600e4c44a6236", size = 56383, upload-time = "2024-10-04T16:17:01.533Z" }, -] - -[[package]] -name = "torch" -version = "2.0.1" -source = { registry = "https://download.pytorch.org/whl/rocm6.3" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -dependencies = [ - { name = "filelock", marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "jinja2", marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "networkx", version = "3.4.2", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "networkx", version = "3.5", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version >= '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "sympy", marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "typing-extensions", marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://download.pytorch.org/whl/torch-2.0.1-cp310-cp310-manylinux2014_aarch64.whl", hash = "sha256:359bfaad94d1cda02ab775dc1cc386d585712329bb47b8741607ef6ef4950747" }, - { url = "https://download.pytorch.org/whl/torch-2.0.1-cp311-cp311-manylinux2014_aarch64.whl", hash = "sha256:b6019b1de4978e96daa21d6a3ebb41e88a0b474898fe251fd96189587408873e" }, -] - -[[package]] -name = "torch" -version = "2.7.1" -source = { registry = "https://download.pytorch.org/whl/cpu" } -resolution-markers = [ - "python_full_version >= '3.13' and sys_platform == 'darwin'", - "python_full_version == '3.12.*' and sys_platform == 'darwin'", - "python_full_version == '3.11.*' and sys_platform == 'darwin'", - "python_full_version < '3.11' and sys_platform == 'darwin'", -] -dependencies = [ - { name = "filelock", marker = "(sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "fsspec", marker = "(sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "jinja2", marker = "(sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "networkx", version = "3.4.2", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version < '3.11' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (python_full_version >= '3.11' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (python_full_version >= '3.11' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (python_full_version >= '3.11' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "networkx", version = "3.5", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version >= '3.11' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (python_full_version < '3.11' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (python_full_version < '3.11' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (python_full_version < '3.11' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (python_full_version < '3.11' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "setuptools", marker = "(python_full_version >= '3.12' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (python_full_version < '3.12' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (python_full_version < '3.12' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (python_full_version < '3.12' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.12' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (python_full_version < '3.12' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.12' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "sympy", marker = "(sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "typing-extensions", marker = "(sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://download.pytorch.org/whl/cpu/torch-2.7.1-cp310-none-macosx_11_0_arm64.whl", hash = "sha256:f8c3bee261b0c8e090f6347490dc6ee2aebfd661eb0f3f6aeae06d992d8ed56f" }, - { url = "https://download.pytorch.org/whl/cpu/torch-2.7.1-cp311-none-macosx_11_0_arm64.whl", hash = "sha256:68a352c7f435abb5cb47e2c032dcd1012772ae2bacb6fc8b83b0c1b11874ab3a" }, - { url = "https://download.pytorch.org/whl/cpu/torch-2.7.1-cp312-none-macosx_11_0_arm64.whl", hash = "sha256:7b4f8b2b83bd08f7d399025a9a7b323bdbb53d20566f1e0d584689bb92d82f9a" }, - { url = "https://download.pytorch.org/whl/cpu/torch-2.7.1-cp313-cp313t-macosx_14_0_arm64.whl", hash = "sha256:95af97e7b2cecdc89edc0558962a51921bf9c61538597dbec6b7cc48d31e2e13" }, - { url = "https://download.pytorch.org/whl/cpu/torch-2.7.1-cp313-none-macosx_11_0_arm64.whl", hash = "sha256:7ecd868a086468e1bcf74b91db425c1c2951a9cfcd0592c4c73377b7e42485ae" }, -] - -[[package]] -name = "torch" -version = "2.7.1" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and sys_platform == 'Linux') or (python_full_version >= '3.13' and sys_platform == 'win32')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux') or (python_full_version == '3.12.*' and sys_platform == 'win32')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux') or (python_full_version == '3.11.*' and sys_platform == 'win32')", - "(python_full_version < '3.11' and sys_platform == 'Linux') or (python_full_version < '3.11' and sys_platform == 'win32')", - "python_full_version >= '3.13' and sys_platform == 'darwin'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version == '3.12.*' and sys_platform == 'darwin'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version == '3.11.*' and sys_platform == 'darwin'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version < '3.11' and sys_platform == 'darwin'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -dependencies = [ - { name = "filelock", marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, - { name = "fsspec", marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, - { name = "jinja2", marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, - { name = "networkx", version = "3.4.2", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version < '3.11' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "networkx", version = "3.5", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version >= '3.11' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "setuptools", marker = "(python_full_version >= '3.12' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "sympy", marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, - { name = "typing-extensions", marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/6a/27/2e06cb52adf89fe6e020963529d17ed51532fc73c1e6d1b18420ef03338c/torch-2.7.1-cp310-cp310-manylinux_2_28_aarch64.whl", hash = "sha256:a103b5d782af5bd119b81dbcc7ffc6fa09904c423ff8db397a1e6ea8fd71508f", size = 99089441, upload-time = "2025-06-04T17:38:48.268Z" }, - { url = "https://files.pythonhosted.org/packages/0a/7c/0a5b3aee977596459ec45be2220370fde8e017f651fecc40522fd478cb1e/torch-2.7.1-cp310-cp310-manylinux_2_28_x86_64.whl", hash = "sha256:fe955951bdf32d182ee8ead6c3186ad54781492bf03d547d31771a01b3d6fb7d", size = 821154516, upload-time = "2025-06-04T17:36:28.556Z" }, - { url = "https://files.pythonhosted.org/packages/f9/91/3d709cfc5e15995fb3fe7a6b564ce42280d3a55676dad672205e94f34ac9/torch-2.7.1-cp310-cp310-win_amd64.whl", hash = "sha256:885453d6fba67d9991132143bf7fa06b79b24352f4506fd4d10b309f53454162", size = 216093147, upload-time = "2025-06-04T17:39:38.132Z" }, - { url = "https://files.pythonhosted.org/packages/92/f6/5da3918414e07da9866ecb9330fe6ffdebe15cb9a4c5ada7d4b6e0a6654d/torch-2.7.1-cp310-none-macosx_11_0_arm64.whl", hash = "sha256:d72acfdb86cee2a32c0ce0101606f3758f0d8bb5f8f31e7920dc2809e963aa7c", size = 68630914, upload-time = "2025-06-04T17:39:31.162Z" }, - { url = "https://files.pythonhosted.org/packages/11/56/2eae3494e3d375533034a8e8cf0ba163363e996d85f0629441fa9d9843fe/torch-2.7.1-cp311-cp311-manylinux_2_28_aarch64.whl", hash = "sha256:236f501f2e383f1cb861337bdf057712182f910f10aeaf509065d54d339e49b2", size = 99093039, upload-time = "2025-06-04T17:39:06.963Z" }, - { url = "https://files.pythonhosted.org/packages/e5/94/34b80bd172d0072c9979708ccd279c2da2f55c3ef318eceec276ab9544a4/torch-2.7.1-cp311-cp311-manylinux_2_28_x86_64.whl", hash = "sha256:06eea61f859436622e78dd0cdd51dbc8f8c6d76917a9cf0555a333f9eac31ec1", size = 821174704, upload-time = "2025-06-04T17:37:03.799Z" }, - { url = "https://files.pythonhosted.org/packages/50/9e/acf04ff375b0b49a45511c55d188bcea5c942da2aaf293096676110086d1/torch-2.7.1-cp311-cp311-win_amd64.whl", hash = "sha256:8273145a2e0a3c6f9fd2ac36762d6ee89c26d430e612b95a99885df083b04e52", size = 216095937, upload-time = "2025-06-04T17:39:24.83Z" }, - { url = "https://files.pythonhosted.org/packages/5b/2b/d36d57c66ff031f93b4fa432e86802f84991477e522adcdffd314454326b/torch-2.7.1-cp311-none-macosx_11_0_arm64.whl", hash = "sha256:aea4fc1bf433d12843eb2c6b2204861f43d8364597697074c8d38ae2507f8730", size = 68640034, upload-time = "2025-06-04T17:39:17.989Z" }, - { url = "https://files.pythonhosted.org/packages/87/93/fb505a5022a2e908d81fe9a5e0aa84c86c0d5f408173be71c6018836f34e/torch-2.7.1-cp312-cp312-manylinux_2_28_aarch64.whl", hash = "sha256:27ea1e518df4c9de73af7e8a720770f3628e7f667280bce2be7a16292697e3fa", size = 98948276, upload-time = "2025-06-04T17:39:12.852Z" }, - { url = "https://files.pythonhosted.org/packages/56/7e/67c3fe2b8c33f40af06326a3d6ae7776b3e3a01daa8f71d125d78594d874/torch-2.7.1-cp312-cp312-manylinux_2_28_x86_64.whl", hash = "sha256:c33360cfc2edd976c2633b3b66c769bdcbbf0e0b6550606d188431c81e7dd1fc", size = 821025792, upload-time = "2025-06-04T17:34:58.747Z" }, - { url = "https://files.pythonhosted.org/packages/a1/37/a37495502bc7a23bf34f89584fa5a78e25bae7b8da513bc1b8f97afb7009/torch-2.7.1-cp312-cp312-win_amd64.whl", hash = "sha256:d8bf6e1856ddd1807e79dc57e54d3335f2b62e6f316ed13ed3ecfe1fc1df3d8b", size = 216050349, upload-time = "2025-06-04T17:38:59.709Z" }, - { url = "https://files.pythonhosted.org/packages/3a/60/04b77281c730bb13460628e518c52721257814ac6c298acd25757f6a175c/torch-2.7.1-cp312-none-macosx_11_0_arm64.whl", hash = "sha256:787687087412c4bd68d315e39bc1223f08aae1d16a9e9771d95eabbb04ae98fb", size = 68645146, upload-time = "2025-06-04T17:38:52.97Z" }, - { url = "https://files.pythonhosted.org/packages/66/81/e48c9edb655ee8eb8c2a6026abdb6f8d2146abd1f150979ede807bb75dcb/torch-2.7.1-cp313-cp313-manylinux_2_28_aarch64.whl", hash = "sha256:03563603d931e70722dce0e11999d53aa80a375a3d78e6b39b9f6805ea0a8d28", size = 98946649, upload-time = "2025-06-04T17:38:43.031Z" }, - { url = "https://files.pythonhosted.org/packages/3a/24/efe2f520d75274fc06b695c616415a1e8a1021d87a13c68ff9dce733d088/torch-2.7.1-cp313-cp313-manylinux_2_28_x86_64.whl", hash = "sha256:d632f5417b6980f61404a125b999ca6ebd0b8b4bbdbb5fbbba44374ab619a412", size = 821033192, upload-time = "2025-06-04T17:38:09.146Z" }, - { url = "https://files.pythonhosted.org/packages/dd/d9/9c24d230333ff4e9b6807274f6f8d52a864210b52ec794c5def7925f4495/torch-2.7.1-cp313-cp313-win_amd64.whl", hash = "sha256:23660443e13995ee93e3d844786701ea4ca69f337027b05182f5ba053ce43b38", size = 216055668, upload-time = "2025-06-04T17:38:36.253Z" }, - { url = "https://files.pythonhosted.org/packages/95/bf/e086ee36ddcef9299f6e708d3b6c8487c1651787bb9ee2939eb2a7f74911/torch-2.7.1-cp313-cp313t-macosx_14_0_arm64.whl", hash = "sha256:0da4f4dba9f65d0d203794e619fe7ca3247a55ffdcbd17ae8fb83c8b2dc9b585", size = 68925988, upload-time = "2025-06-04T17:38:29.273Z" }, - { url = "https://files.pythonhosted.org/packages/69/6a/67090dcfe1cf9048448b31555af6efb149f7afa0a310a366adbdada32105/torch-2.7.1-cp313-cp313t-manylinux_2_28_aarch64.whl", hash = "sha256:e08d7e6f21a617fe38eeb46dd2213ded43f27c072e9165dc27300c9ef9570934", size = 99028857, upload-time = "2025-06-04T17:37:50.956Z" }, - { url = "https://files.pythonhosted.org/packages/90/1c/48b988870823d1cc381f15ec4e70ed3d65e043f43f919329b0045ae83529/torch-2.7.1-cp313-cp313t-manylinux_2_28_x86_64.whl", hash = "sha256:30207f672328a42df4f2174b8f426f354b2baa0b7cca3a0adb3d6ab5daf00dc8", size = 821098066, upload-time = "2025-06-04T17:37:33.939Z" }, - { url = "https://files.pythonhosted.org/packages/7b/eb/10050d61c9d5140c5dc04a89ed3257ef1a6b93e49dd91b95363d757071e0/torch-2.7.1-cp313-cp313t-win_amd64.whl", hash = "sha256:79042feca1c634aaf6603fe6feea8c6b30dfa140a6bbc0b973e2260c7e79a22e", size = 216336310, upload-time = "2025-06-04T17:36:09.862Z" }, - { url = "https://files.pythonhosted.org/packages/b1/29/beb45cdf5c4fc3ebe282bf5eafc8dfd925ead7299b3c97491900fe5ed844/torch-2.7.1-cp313-none-macosx_11_0_arm64.whl", hash = "sha256:988b0cbc4333618a1056d2ebad9eb10089637b659eb645434d0809d8d937b946", size = 68645708, upload-time = "2025-06-04T17:34:39.852Z" }, -] - -[[package]] -name = "torch" -version = "2.7.1+cpu" -source = { registry = "https://download.pytorch.org/whl/cpu" } -resolution-markers = [ - "(python_full_version >= '3.13' and sys_platform == 'Linux') or (python_full_version >= '3.13' and sys_platform == 'win32')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux') or (python_full_version == '3.12.*' and sys_platform == 'win32')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux') or (python_full_version == '3.11.*' and sys_platform == 'win32')", - "(python_full_version < '3.11' and sys_platform == 'Linux') or (python_full_version < '3.11' and sys_platform == 'win32')", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -dependencies = [ - { name = "filelock", marker = "(sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "fsspec", marker = "(sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "jinja2", marker = "(sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "networkx", version = "3.4.2", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version < '3.11' and sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu') or (python_full_version >= '3.11' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (python_full_version >= '3.11' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (python_full_version >= '3.11' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "networkx", version = "3.5", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version >= '3.11' and sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu') or (python_full_version < '3.11' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (python_full_version < '3.11' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (python_full_version < '3.11' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (python_full_version < '3.11' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "setuptools", marker = "(python_full_version >= '3.12' and sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu') or (python_full_version < '3.12' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (python_full_version < '3.12' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (python_full_version < '3.12' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.12' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (python_full_version < '3.12' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.12' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "sympy", marker = "(sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "typing-extensions", marker = "(sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://download.pytorch.org/whl/cpu/torch-2.7.1%2Bcpu-cp310-cp310-manylinux_2_28_aarch64.whl", hash = "sha256:c0df17cee97653d09a4e84488a33d21217f9b24208583c55cf28f0045aab0766" }, - { url = "https://download.pytorch.org/whl/cpu/torch-2.7.1%2Bcpu-cp310-cp310-manylinux_2_28_x86_64.whl", hash = "sha256:1f04a373a3f643821f721da9898ef77dce73b5b6bfc64486f0976f7fb5f90e83" }, - { url = "https://download.pytorch.org/whl/cpu/torch-2.7.1%2Bcpu-cp310-cp310-win_amd64.whl", hash = "sha256:b4cc706973655151f198d027ed34c92ab31a3db55676b44251194e1280631426" }, - { url = "https://download.pytorch.org/whl/cpu/torch-2.7.1%2Bcpu-cp311-cp311-manylinux_2_28_aarch64.whl", hash = "sha256:5fe6045b8f426bf2d0426e4fe009f1667a954ec2aeb82f1bd0bf60c6d7a85445" }, - { url = "https://download.pytorch.org/whl/cpu/torch-2.7.1%2Bcpu-cp311-cp311-manylinux_2_28_x86_64.whl", hash = "sha256:a1684793e352f03fa14f78857e55d65de4ada8405ded1da2bf4f452179c4b779" }, - { url = "https://download.pytorch.org/whl/cpu/torch-2.7.1%2Bcpu-cp311-cp311-win_amd64.whl", hash = "sha256:7b977eccbc85ae2bd19d6998de7b1f1f4bd3c04eaffd3015deb7934389783399" }, - { url = "https://download.pytorch.org/whl/cpu/torch-2.7.1%2Bcpu-cp312-cp312-manylinux_2_28_aarch64.whl", hash = "sha256:3bf2db5adf77b433844f080887ade049c4705ddf9fe1a32023ff84ff735aa5ad" }, - { url = "https://download.pytorch.org/whl/cpu/torch-2.7.1%2Bcpu-cp312-cp312-manylinux_2_28_x86_64.whl", hash = "sha256:8f8b3cfc53010a4b4a3c7ecb88c212e9decc4f5eeb6af75c3c803937d2d60947" }, - { url = "https://download.pytorch.org/whl/cpu/torch-2.7.1%2Bcpu-cp312-cp312-win_amd64.whl", hash = "sha256:0bc887068772233f532b51a3e8c8cfc682ae62bef74bf4e0c53526c8b9e4138f" }, - { url = "https://download.pytorch.org/whl/cpu/torch-2.7.1%2Bcpu-cp313-cp313-manylinux_2_28_aarch64.whl", hash = "sha256:eb17646792ac4374ffc87e42369f45d21eff17c790868963b90483ef0b6db4ef" }, - { url = "https://download.pytorch.org/whl/cpu/torch-2.7.1%2Bcpu-cp313-cp313-manylinux_2_28_x86_64.whl", hash = "sha256:84ea1f6a1d15663037d01b121d6e33bb9da3c90af8e069e5072c30f413455a57" }, - { url = "https://download.pytorch.org/whl/cpu/torch-2.7.1%2Bcpu-cp313-cp313-win_amd64.whl", hash = "sha256:b66f77f6f67317344ee083aa7ac4751a14395fcb38060d564bf513978d267153" }, - { url = "https://download.pytorch.org/whl/cpu/torch-2.7.1%2Bcpu-cp313-cp313t-manylinux_2_28_aarch64.whl", hash = "sha256:56136a2aca6707df3c8811e46ea2d379eaafd18e656e2fd51e8e4d0ca995651b" }, - { url = "https://download.pytorch.org/whl/cpu/torch-2.7.1%2Bcpu-cp313-cp313t-manylinux_2_28_x86_64.whl", hash = "sha256:355614185a2aea7155f9c88a20bfd49de5f3063866f3cf9b2f21b6e9e59e31e0" }, - { url = "https://download.pytorch.org/whl/cpu/torch-2.7.1%2Bcpu-cp313-cp313t-win_amd64.whl", hash = "sha256:464bca1bc9452f2ccd676514688896e66b9488f2a0268ecd3ac497cf09c5aac1" }, -] - -[[package]] -name = "torch" -version = "2.7.1+cu126" -source = { registry = "https://download.pytorch.org/whl/cu126" } -resolution-markers = [ - "(python_full_version >= '3.13' and sys_platform == 'Linux') or (python_full_version >= '3.13' and sys_platform == 'win32')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux') or (python_full_version == '3.12.*' and sys_platform == 'win32')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux') or (python_full_version == '3.11.*' and sys_platform == 'win32')", - "(python_full_version < '3.11' and sys_platform == 'Linux') or (python_full_version < '3.11' and sys_platform == 'win32')", - "python_full_version >= '3.13' and sys_platform == 'darwin'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version == '3.12.*' and sys_platform == 'darwin'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version == '3.11.*' and sys_platform == 'darwin'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version < '3.11' and sys_platform == 'darwin'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -dependencies = [ - { name = "filelock", marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "fsspec", marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "jinja2", marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "networkx", version = "3.4.2", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version < '3.11' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "networkx", version = "3.5", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version >= '3.11' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-cublas-cu12", version = "12.6.4.1", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-cuda-cupti-cu12", version = "12.6.80", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-cuda-nvrtc-cu12", version = "12.6.77", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-cuda-runtime-cu12", version = "12.6.77", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-cudnn-cu12", version = "9.5.1.17", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-cufft-cu12", version = "11.3.0.4", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-cufile-cu12", version = "1.11.1.6", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-curand-cu12", version = "10.3.7.77", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-cusolver-cu12", version = "11.7.1.2", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-cusparse-cu12", version = "12.5.4.2", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-cusparselt-cu12", marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-nccl-cu12", marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-nvjitlink-cu12", version = "12.6.85", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-nvtx-cu12", version = "12.6.77", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "setuptools", marker = "(python_full_version >= '3.12' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "sympy", marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "triton", marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "typing-extensions", marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://download.pytorch.org/whl/cu126/torch-2.7.1%2Bcu126-cp310-cp310-manylinux_2_28_x86_64.whl", hash = "sha256:03b83a0f2c1e90afafd7a5728b956e211bb3e6c56ea3d7d8c7638a659e448d5f" }, - { url = "https://download.pytorch.org/whl/cu126/torch-2.7.1%2Bcu126-cp310-cp310-win_amd64.whl", hash = "sha256:30119a54e1b4ccefe20dfe5d4b13f6aef76c17ec605b40e26d39789db00906f2" }, - { url = "https://download.pytorch.org/whl/cu126/torch-2.7.1%2Bcu126-cp311-cp311-manylinux_2_28_x86_64.whl", hash = "sha256:e1a8465165708c2e2e90786ade8a3e1b1d01eca1f022792cd397caad9d8c21bc" }, - { url = "https://download.pytorch.org/whl/cu126/torch-2.7.1%2Bcu126-cp311-cp311-win_amd64.whl", hash = "sha256:f3af23387ac106b5b01dbef0eb021883e0c00ff4073477b7ce1cbade5ef5038d" }, - { url = "https://download.pytorch.org/whl/cu126/torch-2.7.1%2Bcu126-cp312-cp312-manylinux_2_28_x86_64.whl", hash = "sha256:63bce0590bc540fc16139e2be0177847585182b8c5e68d7f9213789d1d96c978" }, - { url = "https://download.pytorch.org/whl/cu126/torch-2.7.1%2Bcu126-cp312-cp312-win_amd64.whl", hash = "sha256:7d897b5ff67e778de4a2a05d4528377003105e29854fd73ecbe965287533f08b" }, - { url = "https://download.pytorch.org/whl/cu126/torch-2.7.1%2Bcu126-cp313-cp313-manylinux_2_28_x86_64.whl", hash = "sha256:a05c0001fd1d0ceae9cda8c8c1b8a16ed5def858fe996c9237a28016559dad52" }, - { url = "https://download.pytorch.org/whl/cu126/torch-2.7.1%2Bcu126-cp313-cp313-win_amd64.whl", hash = "sha256:a38a903c9b55cea1217100e0851b25659765b6bb8cd75e6de6bbf0063a2cd51e" }, - { url = "https://download.pytorch.org/whl/cu126/torch-2.7.1%2Bcu126-cp313-cp313t-manylinux_2_28_x86_64.whl", hash = "sha256:27d396231f33dc6103ba26ec6ec2ec5939d9850b599e32da711b038af272954e" }, - { url = "https://download.pytorch.org/whl/cu126/torch-2.7.1%2Bcu126-cp313-cp313t-win_amd64.whl", hash = "sha256:d4e68a1aeb2a6272d0234b7575089fc70757a93d24dccde8e962a3b18aef77d1" }, -] - -[[package]] -name = "torch" -version = "2.7.1+cu128" -source = { registry = "https://download.pytorch.org/whl/cu128" } -resolution-markers = [ - "(python_full_version >= '3.13' and sys_platform == 'Linux') or (python_full_version >= '3.13' and sys_platform == 'win32')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux') or (python_full_version == '3.12.*' and sys_platform == 'win32')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux') or (python_full_version == '3.11.*' and sys_platform == 'win32')", - "(python_full_version < '3.11' and sys_platform == 'Linux') or (python_full_version < '3.11' and sys_platform == 'win32')", - "python_full_version >= '3.13' and sys_platform == 'darwin'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version == '3.12.*' and sys_platform == 'darwin'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version == '3.11.*' and sys_platform == 'darwin'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version < '3.11' and sys_platform == 'darwin'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -dependencies = [ - { name = "filelock", marker = "extra == 'extra-7-comfyui-cu128' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "fsspec", marker = "extra == 'extra-7-comfyui-cu128' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "jinja2", marker = "extra == 'extra-7-comfyui-cu128' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "networkx", version = "3.4.2", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version < '3.11' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "networkx", version = "3.5", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version >= '3.11' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-cublas-cu12", version = "12.8.3.14", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-cuda-cupti-cu12", version = "12.8.57", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-cuda-nvrtc-cu12", version = "12.8.61", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-cuda-runtime-cu12", version = "12.8.57", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-cudnn-cu12", version = "9.7.1.26", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-cufft-cu12", version = "11.3.3.41", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-cufile-cu12", version = "1.13.0.11", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-curand-cu12", version = "10.3.9.55", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-cusolver-cu12", version = "11.7.2.55", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-cusparse-cu12", version = "12.5.7.53", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-cusparselt-cu12", marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-nccl-cu12", marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-nvjitlink-cu12", version = "12.8.61", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "nvidia-nvtx-cu12", version = "12.8.55", source = { registry = "https://pypi.org/simple" }, marker = "(platform_machine == 'x86_64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'x86_64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "setuptools", marker = "(python_full_version >= '3.12' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "sympy", marker = "extra == 'extra-7-comfyui-cu128' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "triton", marker = "(sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "typing-extensions", marker = "extra == 'extra-7-comfyui-cu128' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://download.pytorch.org/whl/cu128/torch-2.7.1%2Bcu128-cp310-cp310-manylinux_2_28_aarch64.whl", hash = "sha256:aca3472608e3c92df5166537595687b53a6c997082478b372427b043dbed98d0" }, - { url = "https://download.pytorch.org/whl/cu128/torch-2.7.1%2Bcu128-cp310-cp310-manylinux_2_28_x86_64.whl", hash = "sha256:d6c3cba198dc93f93422a8545f48a6697890366e4b9701f54351fc27e2304bd3" }, - { url = "https://download.pytorch.org/whl/cu128/torch-2.7.1%2Bcu128-cp310-cp310-win_amd64.whl", hash = "sha256:5174f02de8ca14df87c8e333c4c39cf3ce93a323c9d470d690301d110a053b3c" }, - { url = "https://download.pytorch.org/whl/cu128/torch-2.7.1%2Bcu128-cp311-cp311-manylinux_2_28_aarch64.whl", hash = "sha256:3a0954c54fd7cb9f45beab1272dece2a05b0e77023c1da33ba32a7919661260f" }, - { url = "https://download.pytorch.org/whl/cu128/torch-2.7.1%2Bcu128-cp311-cp311-manylinux_2_28_x86_64.whl", hash = "sha256:c301dc280458afd95450af794924c98fe07522dd148ff384739b810e3e3179f2" }, - { url = "https://download.pytorch.org/whl/cu128/torch-2.7.1%2Bcu128-cp311-cp311-win_amd64.whl", hash = "sha256:138c66dcd0ed2f07aafba3ed8b7958e2bed893694990e0b4b55b6b2b4a336aa6" }, - { url = "https://download.pytorch.org/whl/cu128/torch-2.7.1%2Bcu128-cp312-cp312-manylinux_2_28_aarch64.whl", hash = "sha256:268e54db9f0bc2b7b9eb089852d3e592c2dea2facc3db494100c3d3b796549fa" }, - { url = "https://download.pytorch.org/whl/cu128/torch-2.7.1%2Bcu128-cp312-cp312-manylinux_2_28_x86_64.whl", hash = "sha256:0b64f7d0a6f2a739ed052ba959f7b67c677028c9566ce51997f9f90fe573ddaa" }, - { url = "https://download.pytorch.org/whl/cu128/torch-2.7.1%2Bcu128-cp312-cp312-win_amd64.whl", hash = "sha256:2bb8c05d48ba815b316879a18195d53a6472a03e297d971e916753f8e1053d30" }, - { url = "https://download.pytorch.org/whl/cu128/torch-2.7.1%2Bcu128-cp313-cp313-manylinux_2_28_aarch64.whl", hash = "sha256:d56d29a6ad7758ba5173cc2b0c51c93e126e2b0a918e874101dc66545283967f" }, - { url = "https://download.pytorch.org/whl/cu128/torch-2.7.1%2Bcu128-cp313-cp313-manylinux_2_28_x86_64.whl", hash = "sha256:9560425f9ea1af1791507e8ca70d5b9ecf62fed7ca226a95fcd58d0eb2cca78f" }, - { url = "https://download.pytorch.org/whl/cu128/torch-2.7.1%2Bcu128-cp313-cp313-win_amd64.whl", hash = "sha256:500ad5b670483f62d4052e41948a3fb19e8c8de65b99f8d418d879cbb15a82d6" }, - { url = "https://download.pytorch.org/whl/cu128/torch-2.7.1%2Bcu128-cp313-cp313t-manylinux_2_28_aarch64.whl", hash = "sha256:f112465fdf42eb1297c6dddda1a8b7f411914428b704e1b8a47870c52e290909" }, - { url = "https://download.pytorch.org/whl/cu128/torch-2.7.1%2Bcu128-cp313-cp313t-manylinux_2_28_x86_64.whl", hash = "sha256:c355db49c218ada70321d5c5c9bb3077312738b99113c8f3723ef596b554a7b9" }, - { url = "https://download.pytorch.org/whl/cu128/torch-2.7.1%2Bcu128-cp313-cp313t-win_amd64.whl", hash = "sha256:e27e5f7e74179fb5d814a0412e5026e4b50c9e0081e9050bc4c28c992a276eb1" }, -] - -[[package]] -name = "torch" -version = "2.7.1+rocm6.3" -source = { registry = "https://download.pytorch.org/whl/rocm6.3" } -resolution-markers = [ - "python_full_version >= '3.13' and sys_platform == 'Linux'", - "python_full_version == '3.12.*' and sys_platform == 'Linux'", - "python_full_version == '3.11.*' and sys_platform == 'Linux'", - "python_full_version < '3.11' and sys_platform == 'Linux'", - "python_full_version >= '3.13' and sys_platform == 'win32'", - "python_full_version == '3.12.*' and sys_platform == 'win32'", - "python_full_version == '3.11.*' and sys_platform == 'win32'", - "python_full_version < '3.11' and sys_platform == 'win32'", - "python_full_version >= '3.13' and sys_platform == 'darwin'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "python_full_version == '3.12.*' and sys_platform == 'darwin'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "python_full_version == '3.11.*' and sys_platform == 'darwin'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "python_full_version < '3.11' and sys_platform == 'darwin'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux'", -] -dependencies = [ - { name = "filelock", marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "fsspec", marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "jinja2", marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "networkx", version = "3.4.2", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.11' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "networkx", version = "3.5", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version >= '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.11' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.11' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.11' and sys_platform == 'win32' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "setuptools", marker = "(python_full_version >= '3.12' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.12' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.12' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.12' and sys_platform == 'win32' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.12' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "sympy", marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "typing-extensions", marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://download.pytorch.org/whl/rocm6.3/torch-2.7.1%2Brocm6.3-cp310-cp310-manylinux_2_28_x86_64.whl", hash = "sha256:23890206702342b89bff0e022bc77b9d6c11522ed27a2c6b562cd81cbbb74cb6" }, - { url = "https://download.pytorch.org/whl/rocm6.3/torch-2.7.1%2Brocm6.3-cp311-cp311-manylinux_2_28_x86_64.whl", hash = "sha256:73b7eb3777ffe6b73bf9881686dd659bd71231ac87ac3696d2477e2fe0c036fc" }, - { url = "https://download.pytorch.org/whl/rocm6.3/torch-2.7.1%2Brocm6.3-cp312-cp312-manylinux_2_28_x86_64.whl", hash = "sha256:b0c10342f64a34998ae8d5084aa1beae7e11defa46a4e05fe9aa6f09ffb0db37" }, - { url = "https://download.pytorch.org/whl/rocm6.3/torch-2.7.1%2Brocm6.3-cp313-cp313-manylinux_2_28_x86_64.whl", hash = "sha256:1650ff47f4cd45e5ba222e943e6e0697eb5f1cff15045ffdafe4feb8c279cb93" }, - { url = "https://download.pytorch.org/whl/rocm6.3/torch-2.7.1%2Brocm6.3-cp313-cp313t-manylinux_2_28_x86_64.whl", hash = "sha256:adfc55a2704c7b58a3475a409fe6ff619bbc4abbe28127fbcf12cc17e441fd1a" }, -] - -[[package]] -name = "torchaudio" -version = "2.0.2" -source = { registry = "https://download.pytorch.org/whl/rocm6.3" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -dependencies = [ - { name = "torch", version = "2.0.1", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://download.pytorch.org/whl/torchaudio-2.0.2-cp310-cp310-manylinux2014_aarch64.whl", hash = "sha256:dadf237b4fd155a3d213bdfeffeded47f5a553d383817500438b44f24fa53851" }, - { url = "https://download.pytorch.org/whl/torchaudio-2.0.2-cp311-cp311-manylinux2014_aarch64.whl", hash = "sha256:b22aceaa1ec5a3310cc15642d19dd00d53a7ce399b9096ad1dea0b24e5097af3" }, -] - -[[package]] -name = "torchaudio" -version = "2.7.1" -source = { registry = "https://download.pytorch.org/whl/cpu" } -resolution-markers = [ - "python_full_version >= '3.13' and sys_platform == 'darwin'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "python_full_version == '3.12.*' and sys_platform == 'darwin'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "python_full_version == '3.11.*' and sys_platform == 'darwin'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "python_full_version < '3.11' and sys_platform == 'darwin'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux'", -] -dependencies = [ - { name = "torch", version = "2.7.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://download.pytorch.org/whl/cpu/torchaudio-2.7.1-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:4739af57d0eb94347d1c6a1b5668be78a7383afe826dde18a04883b9f9f263b1" }, - { url = "https://download.pytorch.org/whl/cpu/torchaudio-2.7.1-cp310-cp310-manylinux_2_28_aarch64.whl", hash = "sha256:c089dbfc14c5f47091b7bf3f6bf2bbac93b86619299d04d9c102f4ad53758990" }, - { url = "https://download.pytorch.org/whl/cpu/torchaudio-2.7.1-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:d5a62f88c629035913f506df03f710c48fc8bb9637191933f27c67088d5ca136" }, - { url = "https://download.pytorch.org/whl/cpu/torchaudio-2.7.1-cp311-cp311-manylinux_2_28_aarch64.whl", hash = "sha256:53bc4ba12e7468be34a7ca2ee837ee5c8bd5755b25c12f665af9339cae37e265" }, - { url = "https://download.pytorch.org/whl/cpu/torchaudio-2.7.1-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:9306dcfc4586cebd7647a93fe9a448e791c4f83934da616b9433b75597a1f978" }, - { url = "https://download.pytorch.org/whl/cpu/torchaudio-2.7.1-cp312-cp312-manylinux_2_28_aarch64.whl", hash = "sha256:d66bd76b226fdd4135c97650e1b7eb63fb7659b4ed0e3a778898e41dbba21b61" }, - { url = "https://download.pytorch.org/whl/cpu/torchaudio-2.7.1-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:e5f0599a507f4683546878ed9667e1b32d7ca3c8a957e4c15c6b302378ef4dee" }, - { url = "https://download.pytorch.org/whl/cpu/torchaudio-2.7.1-cp313-cp313-manylinux_2_28_aarch64.whl", hash = "sha256:271f717844e5c7f9e05c8328de817bf90f46d83281c791e94f54d4edea2f5817" }, - { url = "https://download.pytorch.org/whl/cpu/torchaudio-2.7.1-cp313-cp313t-macosx_11_0_arm64.whl", hash = "sha256:18560955b8beb2a8d39a6bfae20a442337afcefb3dfd4ee007ce82233a796799" }, - { url = "https://download.pytorch.org/whl/cpu/torchaudio-2.7.1-cp313-cp313t-manylinux_2_28_aarch64.whl", hash = "sha256:1850475ef9101ea0b3593fe93ff6ee4e7a20598f6da6510761220b9fe56eb7fa" }, -] - -[[package]] -name = "torchaudio" -version = "2.7.1" -source = { registry = "https://download.pytorch.org/whl/cu128" } -resolution-markers = [ - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux'", -] -dependencies = [ - { name = "torch", version = "2.7.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://download.pytorch.org/whl/cu128/torchaudio-2.7.1-cp310-cp310-manylinux_2_28_aarch64.whl", hash = "sha256:80f199f643d7f8e5435c1c88e7fa8c6b08eab6ebc1ec915c9b69e83a1503dc91" }, - { url = "https://download.pytorch.org/whl/cu128/torchaudio-2.7.1-cp311-cp311-manylinux_2_28_aarch64.whl", hash = "sha256:aa130165f67ef873c53c8580559e5baca08ea189835419279efbf35a58587bf8" }, - { url = "https://download.pytorch.org/whl/cu128/torchaudio-2.7.1-cp312-cp312-manylinux_2_28_aarch64.whl", hash = "sha256:e187fbd6fd771dadee097893785e9f62869739ca21f3509c855eeabd35c05ed3" }, - { url = "https://download.pytorch.org/whl/cu128/torchaudio-2.7.1-cp313-cp313-manylinux_2_28_aarch64.whl", hash = "sha256:7c93b53896804a31c1cb53ab56fe86b8c74f0bbab45cac8478d6555e466a5bc5" }, - { url = "https://download.pytorch.org/whl/cu128/torchaudio-2.7.1-cp313-cp313t-manylinux_2_28_aarch64.whl", hash = "sha256:d193101d2f7cc0bfff5961c52eec66972d0d000e7d0d28928f94468e5a96a48e" }, -] - -[[package]] -name = "torchaudio" -version = "2.7.1" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and sys_platform == 'Linux') or (python_full_version >= '3.13' and sys_platform == 'win32')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux') or (python_full_version == '3.12.*' and sys_platform == 'win32')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux') or (python_full_version == '3.11.*' and sys_platform == 'win32')", - "(python_full_version < '3.11' and sys_platform == 'Linux') or (python_full_version < '3.11' and sys_platform == 'win32')", - "python_full_version >= '3.13' and sys_platform == 'darwin'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version == '3.12.*' and sys_platform == 'darwin'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version == '3.11.*' and sys_platform == 'darwin'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version < '3.11' and sys_platform == 'darwin'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -dependencies = [ - { name = "torch", version = "2.7.1", source = { registry = "https://pypi.org/simple" }, marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/da/71/bfc6d2b28ede6c4c5446901cfa4d98fa25b2606eb12e641baccec16fcde0/torchaudio-2.7.1-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:4739af57d0eb94347d1c6a1b5668be78a7383afe826dde18a04883b9f9f263b1", size = 1842457, upload-time = "2025-06-04T17:44:12.073Z" }, - { url = "https://files.pythonhosted.org/packages/e6/8c/35eea5138ccd4abf38b163743d5ab4a8b25349bafa8bdf3d629e7f3036b9/torchaudio-2.7.1-cp310-cp310-manylinux_2_28_aarch64.whl", hash = "sha256:c089dbfc14c5f47091b7bf3f6bf2bbac93b86619299d04d9c102f4ad53758990", size = 1680682, upload-time = "2025-06-04T17:44:11.056Z" }, - { url = "https://files.pythonhosted.org/packages/7d/dc/7569889c1fc95ebf18b0295bc4fdebafbbb89ba9e0018c7e9b0844bae011/torchaudio-2.7.1-cp310-cp310-manylinux_2_28_x86_64.whl", hash = "sha256:6bb1e6db22fa2aad6b89b2a455ec5c6dc31df2635dbfafa213394f8b07b09516", size = 3498891, upload-time = "2025-06-04T17:43:52.161Z" }, - { url = "https://files.pythonhosted.org/packages/b3/e0/ff0ac4234798a0b6b1398fa878a2e7d22f1d06d4327feb312d9e77e079bd/torchaudio-2.7.1-cp310-cp310-win_amd64.whl", hash = "sha256:2ba4df6e3ad35cb1e5bd162cf86b492526138f6476f5a06b10725b8880c618eb", size = 2483343, upload-time = "2025-06-04T17:43:57.779Z" }, - { url = "https://files.pythonhosted.org/packages/85/a2/52e6760d352584ae1ab139d97647bdc51d1eb7d480b688fe69c72616c956/torchaudio-2.7.1-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:d5a62f88c629035913f506df03f710c48fc8bb9637191933f27c67088d5ca136", size = 1849254, upload-time = "2025-06-04T17:44:05.392Z" }, - { url = "https://files.pythonhosted.org/packages/df/e6/0f3835895f9d0b8900ca4a7196932b13b74156ad9ffb76e7aacfc5bb4157/torchaudio-2.7.1-cp311-cp311-manylinux_2_28_aarch64.whl", hash = "sha256:53bc4ba12e7468be34a7ca2ee837ee5c8bd5755b25c12f665af9339cae37e265", size = 1686156, upload-time = "2025-06-04T17:44:09.39Z" }, - { url = "https://files.pythonhosted.org/packages/0d/c5/8ba8869ac5607bbd83ea864bda2c628f8b7b55a9200f8147687995e95a49/torchaudio-2.7.1-cp311-cp311-manylinux_2_28_x86_64.whl", hash = "sha256:f8bd69354a397753b9dea9699d9e1251f8496fbbdf3028c7086a57a615bf33c3", size = 3508053, upload-time = "2025-06-04T17:43:49.398Z" }, - { url = "https://files.pythonhosted.org/packages/78/cc/11709b2cbf841eda124918523088d9aaa1509ae4400f346192037e6de6c6/torchaudio-2.7.1-cp311-cp311-win_amd64.whl", hash = "sha256:0ae0678ad27355eebea5a9fdd9ae9bfec444f8405f9b6c60026905ba3665c43a", size = 2488974, upload-time = "2025-06-04T17:44:04.294Z" }, - { url = "https://files.pythonhosted.org/packages/0b/d1/eb8bc3b3502dddb1b789567b7b19668b1d32817266887b9f381494cfe463/torchaudio-2.7.1-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:9306dcfc4586cebd7647a93fe9a448e791c4f83934da616b9433b75597a1f978", size = 1846897, upload-time = "2025-06-04T17:44:07.79Z" }, - { url = "https://files.pythonhosted.org/packages/62/7d/6c15f15d3edc5271abc808f70713644b50f0f7bfb85a09dba8b5735fbad3/torchaudio-2.7.1-cp312-cp312-manylinux_2_28_aarch64.whl", hash = "sha256:d66bd76b226fdd4135c97650e1b7eb63fb7659b4ed0e3a778898e41dbba21b61", size = 1686680, upload-time = "2025-06-04T17:43:58.986Z" }, - { url = "https://files.pythonhosted.org/packages/48/65/0f46ba74cdc67ea9a8c37c8acfb5194d81639e481e85903c076bcd97188c/torchaudio-2.7.1-cp312-cp312-manylinux_2_28_x86_64.whl", hash = "sha256:9cbcdaab77ad9a73711acffee58f4eebc8a0685289a938a3fa6f660af9489aee", size = 3506966, upload-time = "2025-06-04T17:44:06.537Z" }, - { url = "https://files.pythonhosted.org/packages/52/29/06f887baf22cbba85ae331b71b110b115bf11b3968f5914a50c17dde5ab7/torchaudio-2.7.1-cp312-cp312-win_amd64.whl", hash = "sha256:9cfb8f6ace8e01e2b89de74eb893ba5ce936b88b415383605b0a4d974009dec7", size = 2484265, upload-time = "2025-06-04T17:44:00.277Z" }, - { url = "https://files.pythonhosted.org/packages/b6/ee/6e308868b9467e1b51da9d781cb73dd5aadca7c8b6256f88ce5d18a7fb77/torchaudio-2.7.1-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:e5f0599a507f4683546878ed9667e1b32d7ca3c8a957e4c15c6b302378ef4dee", size = 1847208, upload-time = "2025-06-04T17:44:01.365Z" }, - { url = "https://files.pythonhosted.org/packages/3a/f9/ca0e0960526e6deaa476d168b877480a3fbae5d44668a54de963a9800097/torchaudio-2.7.1-cp313-cp313-manylinux_2_28_aarch64.whl", hash = "sha256:271f717844e5c7f9e05c8328de817bf90f46d83281c791e94f54d4edea2f5817", size = 1686311, upload-time = "2025-06-04T17:44:02.785Z" }, - { url = "https://files.pythonhosted.org/packages/bb/ab/83f282ca5475ae34c58520a4a97b6d69438bc699d70d16432deb19791cda/torchaudio-2.7.1-cp313-cp313-manylinux_2_28_x86_64.whl", hash = "sha256:1862b063d8d4e55cb4862bcbd63568545f549825a3c5605bd312224c3ebb1919", size = 3507174, upload-time = "2025-06-04T17:43:46.526Z" }, - { url = "https://files.pythonhosted.org/packages/12/91/dbd17a6eda4b0504d9b4f1f721a1654456e39f7178b8462344f942100865/torchaudio-2.7.1-cp313-cp313-win_amd64.whl", hash = "sha256:edb4deaa6f95acd5522912ed643303d0b86d79a6f15914362f5a5d49baaf5d13", size = 2484503, upload-time = "2025-06-04T17:43:48.169Z" }, - { url = "https://files.pythonhosted.org/packages/73/5e/da52d2fa9f7cc89512b63dd8a88fb3e097a89815f440cc16159b216ec611/torchaudio-2.7.1-cp313-cp313t-macosx_11_0_arm64.whl", hash = "sha256:18560955b8beb2a8d39a6bfae20a442337afcefb3dfd4ee007ce82233a796799", size = 1929983, upload-time = "2025-06-04T17:43:56.659Z" }, - { url = "https://files.pythonhosted.org/packages/f7/16/9d03dc62613f276f9666eb0609164287df23986b67d20b53e78d21a3d8d8/torchaudio-2.7.1-cp313-cp313t-manylinux_2_28_aarch64.whl", hash = "sha256:1850475ef9101ea0b3593fe93ff6ee4e7a20598f6da6510761220b9fe56eb7fa", size = 1700436, upload-time = "2025-06-04T17:43:55.589Z" }, - { url = "https://files.pythonhosted.org/packages/83/45/57a437fe41b302fc79b4eb78fdb3e480ff42c66270e7505eedf0b000969c/torchaudio-2.7.1-cp313-cp313t-manylinux_2_28_x86_64.whl", hash = "sha256:98257fc14dd493ba5a3258fb6d61d27cd64a48ee79537c3964c4da26b9bf295f", size = 3521631, upload-time = "2025-06-04T17:43:50.628Z" }, - { url = "https://files.pythonhosted.org/packages/91/5e/9262a7e41e47bc87eb245c4fc485eb26ff41a05886b241c003440c9e0107/torchaudio-2.7.1-cp313-cp313t-win_amd64.whl", hash = "sha256:c802e0dcbf38669007327bb52f065573cc5cac106eaca987f6e1a32e6282263a", size = 2534956, upload-time = "2025-06-04T17:43:42.324Z" }, -] - -[[package]] -name = "torchaudio" -version = "2.7.1+cpu" -source = { registry = "https://download.pytorch.org/whl/cpu" } -resolution-markers = [ - "(python_full_version >= '3.13' and sys_platform == 'Linux') or (python_full_version >= '3.13' and sys_platform == 'win32')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux') or (python_full_version == '3.12.*' and sys_platform == 'win32')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux') or (python_full_version == '3.11.*' and sys_platform == 'win32')", - "(python_full_version < '3.11' and sys_platform == 'Linux') or (python_full_version < '3.11' and sys_platform == 'win32')", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -dependencies = [ - { name = "torch", version = "2.7.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://download.pytorch.org/whl/cpu/torchaudio-2.7.1%2Bcpu-cp310-cp310-manylinux_2_28_x86_64.whl", hash = "sha256:a36569e17ff4519a21f2113e9a19a8def0d70e2fd9fabc9105ca57dee3809443" }, - { url = "https://download.pytorch.org/whl/cpu/torchaudio-2.7.1%2Bcpu-cp310-cp310-win_amd64.whl", hash = "sha256:d7bd84b934f365e537e519838e9a5e7e6aef0d94e3d1419e8734f58b1142f326" }, - { url = "https://download.pytorch.org/whl/cpu/torchaudio-2.7.1%2Bcpu-cp311-cp311-manylinux_2_28_x86_64.whl", hash = "sha256:79b75d9f8dadad5da128fd6677fe717669ce580c0d54c8407792854ac8b97349" }, - { url = "https://download.pytorch.org/whl/cpu/torchaudio-2.7.1%2Bcpu-cp311-cp311-win_amd64.whl", hash = "sha256:c6b82f209797d0b6e46c33a76facb39987141c453f85d9d0fa849363d47c2f42" }, - { url = "https://download.pytorch.org/whl/cpu/torchaudio-2.7.1%2Bcpu-cp312-cp312-manylinux_2_28_x86_64.whl", hash = "sha256:65bf843345ae05629b7f71609bab0808004dabfce6cf48ea508a5d4f5419ca74" }, - { url = "https://download.pytorch.org/whl/cpu/torchaudio-2.7.1%2Bcpu-cp312-cp312-win_amd64.whl", hash = "sha256:a71ef774991658188721f53ebf05c8858b2baf0abb17b65bf447b294f3e63e2e" }, - { url = "https://download.pytorch.org/whl/cpu/torchaudio-2.7.1%2Bcpu-cp313-cp313-manylinux_2_28_x86_64.whl", hash = "sha256:e169a2b62e55342f2f30e17640054707c8e339045a1ccc2db33517e9debb2767" }, - { url = "https://download.pytorch.org/whl/cpu/torchaudio-2.7.1%2Bcpu-cp313-cp313-win_amd64.whl", hash = "sha256:6d4855a0d40d700b6a20b5d2691cfc9ea2296419e3ab0442ee2a1e8d0b73242a" }, - { url = "https://download.pytorch.org/whl/cpu/torchaudio-2.7.1%2Bcpu-cp313-cp313t-manylinux_2_28_x86_64.whl", hash = "sha256:2ec85e79386c3e68ae67ac74033118253f0c7a64a8343a58b2df802e42ca9f74" }, - { url = "https://download.pytorch.org/whl/cpu/torchaudio-2.7.1%2Bcpu-cp313-cp313t-win_amd64.whl", hash = "sha256:5856ce75fb0cfb2a0d8be4e3f9def122414f009aad4347161ad80f5b8f708fa4" }, -] - -[[package]] -name = "torchaudio" -version = "2.7.1+cu126" -source = { registry = "https://download.pytorch.org/whl/cu126" } -resolution-markers = [ - "(python_full_version >= '3.13' and sys_platform == 'Linux') or (python_full_version >= '3.13' and sys_platform == 'win32')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux') or (python_full_version == '3.12.*' and sys_platform == 'win32')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux') or (python_full_version == '3.11.*' and sys_platform == 'win32')", - "(python_full_version < '3.11' and sys_platform == 'Linux') or (python_full_version < '3.11' and sys_platform == 'win32')", - "python_full_version >= '3.13' and sys_platform == 'darwin'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version == '3.12.*' and sys_platform == 'darwin'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version == '3.11.*' and sys_platform == 'darwin'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version < '3.11' and sys_platform == 'darwin'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -dependencies = [ - { name = "torch", version = "2.7.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" }, marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://download.pytorch.org/whl/cu126/torchaudio-2.7.1%2Bcu126-cp310-cp310-manylinux_2_28_x86_64.whl", hash = "sha256:d9a65c7f7100748802030257efd22535decd74eba310d2b2b9c41489c77cbe1d" }, - { url = "https://download.pytorch.org/whl/cu126/torchaudio-2.7.1%2Bcu126-cp310-cp310-win_amd64.whl", hash = "sha256:9c6e00c79c09572a65eb54652d12f00fa79df63847552f61f10b7705fd0aca0b" }, - { url = "https://download.pytorch.org/whl/cu126/torchaudio-2.7.1%2Bcu126-cp311-cp311-manylinux_2_28_x86_64.whl", hash = "sha256:1e9231eb156400a53d8041688f7567ac92c8758332225e364c35d68603cae2da" }, - { url = "https://download.pytorch.org/whl/cu126/torchaudio-2.7.1%2Bcu126-cp311-cp311-win_amd64.whl", hash = "sha256:fb9d04a635ab9856bf70c47926e3d47976c36aeb60779e6c4639ac2a630f9b0f" }, - { url = "https://download.pytorch.org/whl/cu126/torchaudio-2.7.1%2Bcu126-cp312-cp312-manylinux_2_28_x86_64.whl", hash = "sha256:560692b35b4c0325b4b11e793574e04565769f462a9146ad254d6d0411b8c7f4" }, - { url = "https://download.pytorch.org/whl/cu126/torchaudio-2.7.1%2Bcu126-cp312-cp312-win_amd64.whl", hash = "sha256:33e67c2da5da68c075a065062cc39115b7af29890120c4773cfd24a9ea05a428" }, - { url = "https://download.pytorch.org/whl/cu126/torchaudio-2.7.1%2Bcu126-cp313-cp313-manylinux_2_28_x86_64.whl", hash = "sha256:759de378d1fe4f4a5a56d58f51b4a05a9aa9681ae7b9469e638d9ed321a73e95" }, - { url = "https://download.pytorch.org/whl/cu126/torchaudio-2.7.1%2Bcu126-cp313-cp313-win_amd64.whl", hash = "sha256:d3a5f160336aa7ec262f1361755c5da4e451571ed69f3cb8435b09bd7a2a0227" }, - { url = "https://download.pytorch.org/whl/cu126/torchaudio-2.7.1%2Bcu126-cp313-cp313t-manylinux_2_28_x86_64.whl", hash = "sha256:38484cd84566b96a12e7371ea0f5a91ce35708c8c2aaa223342da833e094ee6d" }, - { url = "https://download.pytorch.org/whl/cu126/torchaudio-2.7.1%2Bcu126-cp313-cp313t-win_amd64.whl", hash = "sha256:c293d7e8d5d86d855313a940862c8d1506536a80ea44eca1ab020579b4f8bb0b" }, -] - -[[package]] -name = "torchaudio" -version = "2.7.1+cu128" -source = { registry = "https://download.pytorch.org/whl/cu128" } -resolution-markers = [ - "(python_full_version >= '3.13' and sys_platform == 'Linux') or (python_full_version >= '3.13' and sys_platform == 'win32')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux') or (python_full_version == '3.12.*' and sys_platform == 'win32')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux') or (python_full_version == '3.11.*' and sys_platform == 'win32')", - "(python_full_version < '3.11' and sys_platform == 'Linux') or (python_full_version < '3.11' and sys_platform == 'win32')", - "python_full_version >= '3.13' and sys_platform == 'darwin'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version == '3.12.*' and sys_platform == 'darwin'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version == '3.11.*' and sys_platform == 'darwin'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version < '3.11' and sys_platform == 'darwin'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -dependencies = [ - { name = "torch", version = "2.7.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "(platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://download.pytorch.org/whl/cu128/torchaudio-2.7.1%2Bcu128-cp310-cp310-manylinux_2_28_x86_64.whl", hash = "sha256:2ba0816eee659e343851a9c5dc60c8e1eb819a3969b29268fab27d3143273d78" }, - { url = "https://download.pytorch.org/whl/cu128/torchaudio-2.7.1%2Bcu128-cp310-cp310-win_amd64.whl", hash = "sha256:b1e56a999a06a5deaebfb991dc676aaa60d98139907d99badbc6dca6456637ee" }, - { url = "https://download.pytorch.org/whl/cu128/torchaudio-2.7.1%2Bcu128-cp311-cp311-manylinux_2_28_x86_64.whl", hash = "sha256:84ec727f1fdafdf85dd1c018a6d3bfabeb5665b10e0b5f273a675eb730f59ce5" }, - { url = "https://download.pytorch.org/whl/cu128/torchaudio-2.7.1%2Bcu128-cp311-cp311-win_amd64.whl", hash = "sha256:37a42de8c0f601dc0bc7dcccc4049644ef5adcf45920dd5813c339121e5b5a8c" }, - { url = "https://download.pytorch.org/whl/cu128/torchaudio-2.7.1%2Bcu128-cp312-cp312-manylinux_2_28_x86_64.whl", hash = "sha256:0c1d407f934d44f87935b139991d8872f81f88f8a6be9b7bd25918bf744e2be6" }, - { url = "https://download.pytorch.org/whl/cu128/torchaudio-2.7.1%2Bcu128-cp312-cp312-win_amd64.whl", hash = "sha256:4586e3106701b06a4f9377f5c1da9e1d8555e16bd58fd7d810aa3f6cf50bd713" }, - { url = "https://download.pytorch.org/whl/cu128/torchaudio-2.7.1%2Bcu128-cp313-cp313-manylinux_2_28_x86_64.whl", hash = "sha256:7e97ea8a5d5e56108d1c071416613bc61a0e3531c2e6ba6a9b646232d6e41088" }, - { url = "https://download.pytorch.org/whl/cu128/torchaudio-2.7.1%2Bcu128-cp313-cp313-win_amd64.whl", hash = "sha256:170ca262fad47188ce35010fd34d5b3661c46a2c053383fd72ef653f713329ce" }, - { url = "https://download.pytorch.org/whl/cu128/torchaudio-2.7.1%2Bcu128-cp313-cp313t-manylinux_2_28_x86_64.whl", hash = "sha256:84fb5c546faced5e835ff8edde419fa407513f7ff21cc05e2b4a8978463b16b7" }, - { url = "https://download.pytorch.org/whl/cu128/torchaudio-2.7.1%2Bcu128-cp313-cp313t-win_amd64.whl", hash = "sha256:cb435329019d441d8177db2d84e8d397881896d100efb4f4c15f0d3732f92a81" }, -] - -[[package]] -name = "torchaudio" -version = "2.7.1+rocm6.3" -source = { registry = "https://download.pytorch.org/whl/rocm6.3" } -resolution-markers = [ - "python_full_version >= '3.13' and sys_platform == 'Linux'", - "python_full_version == '3.12.*' and sys_platform == 'Linux'", - "python_full_version == '3.11.*' and sys_platform == 'Linux'", - "python_full_version < '3.11' and sys_platform == 'Linux'", - "python_full_version >= '3.13' and sys_platform == 'win32'", - "python_full_version == '3.12.*' and sys_platform == 'win32'", - "python_full_version == '3.11.*' and sys_platform == 'win32'", - "python_full_version < '3.11' and sys_platform == 'win32'", - "python_full_version >= '3.13' and sys_platform == 'darwin'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "python_full_version == '3.12.*' and sys_platform == 'darwin'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "python_full_version == '3.11.*' and sys_platform == 'darwin'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "python_full_version < '3.11' and sys_platform == 'darwin'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux'", -] -dependencies = [ - { name = "torch", version = "2.7.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://download.pytorch.org/whl/rocm6.3/torchaudio-2.7.1%2Brocm6.3-cp310-cp310-manylinux_2_28_x86_64.whl", hash = "sha256:81aff1ae49ccc8951fb1353318087285c9b14a2e5b4ac97b3b8c2b8e47815e8d" }, - { url = "https://download.pytorch.org/whl/rocm6.3/torchaudio-2.7.1%2Brocm6.3-cp311-cp311-manylinux_2_28_x86_64.whl", hash = "sha256:9a9807f562e04d09f867f5bbfcf72d9e6752f3f9a55ea673fd6cf03f55d23c1f" }, - { url = "https://download.pytorch.org/whl/rocm6.3/torchaudio-2.7.1%2Brocm6.3-cp312-cp312-manylinux_2_28_x86_64.whl", hash = "sha256:dd485df55ab7b387594070d47dd8bdba81dc77de82e5ba38fc6784d053455272" }, - { url = "https://download.pytorch.org/whl/rocm6.3/torchaudio-2.7.1%2Brocm6.3-cp313-cp313-manylinux_2_28_x86_64.whl", hash = "sha256:5d4027426412d55b9333033d99067320ebd4b508d121fdb1a6164df37cf91532" }, - { url = "https://download.pytorch.org/whl/rocm6.3/torchaudio-2.7.1%2Brocm6.3-cp313-cp313t-manylinux_2_28_x86_64.whl", hash = "sha256:709aacc841fdb775e1a162600e34524114d57680c9cb5c9214aa14ba21bee54f" }, -] - -[[package]] -name = "torchdiffeq" -version = "0.2.5" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "scipy" }, - { name = "torch", version = "2.0.1", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://pypi.org/simple" }, marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" }, marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "extra == 'extra-7-comfyui-cu128' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/87/ec/a40aa124660f0ee65e6760cb53df6a82ad91a1a3ef1da5e747f1336644dd/torchdiffeq-0.2.5.tar.gz", hash = "sha256:b50d3760d13fd138dcceac651f4b80396f44fefcebd037a033fecfeaa9cc12e7", size = 31197, upload-time = "2024-11-21T20:20:11.552Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/b9/35/537f64f2d0b3cfebaae0f903b4e3a3b239abcc99d0f73cb15b9cee9b8212/torchdiffeq-0.2.5-py3-none-any.whl", hash = "sha256:aa1db4bed13bd04952f28a53cdf4336d1ab60417c1d9698d7a239fec1cf2bcf8", size = 32902, upload-time = "2024-11-21T20:20:09.938Z" }, -] - -[[package]] -name = "torchinfo" -version = "1.8.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/53/d9/2b811d1c0812e9ef23e6cf2dbe022becbe6c5ab065e33fd80ee05c0cd996/torchinfo-1.8.0.tar.gz", hash = "sha256:72e94b0e9a3e64dc583a8e5b7940b8938a1ac0f033f795457f27e6f4e7afa2e9", size = 25880, upload-time = "2023-05-14T19:23:26.377Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/72/25/973bd6128381951b23cdcd8a9870c6dcfc5606cb864df8eabd82e529f9c1/torchinfo-1.8.0-py3-none-any.whl", hash = "sha256:2e911c2918603f945c26ff21a3a838d12709223dc4ccf243407bce8b6e897b46", size = 23377, upload-time = "2023-05-14T19:23:24.141Z" }, -] - -[[package]] -name = "torchmetrics" -version = "1.7.3" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "lightning-utilities" }, - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "packaging" }, - { name = "torch", version = "2.0.1", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://pypi.org/simple" }, marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" }, marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "extra == 'extra-7-comfyui-cu128' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/48/22/8b16c4ec34d93ee15024924cbbe84fbd235bb3e1df2cc8f48c865c1528e7/torchmetrics-1.7.3.tar.gz", hash = "sha256:08450a19cdb67ba1608aac0b213e5dc73033e11b60ad4719696ebcede591621e", size = 566545, upload-time = "2025-06-13T15:39:37.498Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/6f/f2/bed7da46003c26ed44fc7fa3ecc98a84216f0d4758e5e6a3693754d490d9/torchmetrics-1.7.3-py3-none-any.whl", hash = "sha256:7b6fd43e92f0a1071c8bcb029637f252b0630699140a93ed8817ce7afe9db34e", size = 962639, upload-time = "2025-06-13T15:39:35.69Z" }, -] - -[[package]] -name = "torchsde" -version = "0.2.6" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "scipy" }, - { name = "torch", version = "2.0.1", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://pypi.org/simple" }, marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform != 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" }, marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "extra == 'extra-7-comfyui-cu128' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "trampoline" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/71/a5/ae18ee6de023b3a5462122a43a4c9812c11d275cc585a3d08bf24945c02a/torchsde-0.2.6.tar.gz", hash = "sha256:81d074d3504f9d190f1694fb526395afbe4608ee43a88adb1262a639e5b4778b", size = 48840, upload-time = "2023-09-26T21:52:20.614Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/dd/1f/b67ebd7e19ffe259f05d3cf4547326725c3113d640c277030be3e9998d6f/torchsde-0.2.6-py3-none-any.whl", hash = "sha256:19bf7ff02eec7e8e46ba1cdb4aa0f9db1c51d492524a16975234b467f7fc463b", size = 61232, upload-time = "2023-09-26T21:52:19.274Z" }, -] - -[[package]] -name = "torchvision" -version = "0.15.2" -source = { registry = "https://download.pytorch.org/whl/rocm6.3" } -resolution-markers = [ - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -dependencies = [ - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version >= '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "pillow", marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "requests", marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.0.1", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://download.pytorch.org/whl/torchvision-0.15.2-cp310-cp310-manylinux2014_aarch64.whl", hash = "sha256:1eefebf5fbd01a95fe8f003d623d941601c94b5cec547b420da89cb369d9cf96" }, - { url = "https://download.pytorch.org/whl/torchvision-0.15.2-cp311-cp311-manylinux2014_aarch64.whl", hash = "sha256:b02a7ffeaa61448737f39a4210b8ee60234bda0515a0c0d8562f884454105b0f" }, -] - -[[package]] -name = "torchvision" -version = "0.22.1" -source = { registry = "https://download.pytorch.org/whl/cpu" } -resolution-markers = [ - "python_full_version >= '3.13' and sys_platform == 'darwin'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "python_full_version == '3.12.*' and sys_platform == 'darwin'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "python_full_version == '3.11.*' and sys_platform == 'darwin'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "python_full_version < '3.11' and sys_platform == 'darwin'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux'", -] -dependencies = [ - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (python_full_version < '3.11' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (python_full_version >= '3.11' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (python_full_version >= '3.11' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (python_full_version >= '3.11' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version >= '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (python_full_version >= '3.11' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (python_full_version < '3.11' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (python_full_version < '3.11' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (python_full_version < '3.11' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (python_full_version < '3.11' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "pillow", marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://download.pytorch.org/whl/cpu/torchvision-0.22.1-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:3b47d8369ee568c067795c0da0b4078f39a9dfea6f3bc1f3ac87530dfda1dd56" }, - { url = "https://download.pytorch.org/whl/cpu/torchvision-0.22.1-cp310-cp310-manylinux_2_28_aarch64.whl", hash = "sha256:990de4d657a41ed71680cd8be2e98ebcab55371f30993dc9bd2e676441f7180e" }, - { url = "https://download.pytorch.org/whl/cpu/torchvision-0.22.1-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:4addf626e2b57fc22fd6d329cf1346d474497672e6af8383b7b5b636fba94a53" }, - { url = "https://download.pytorch.org/whl/cpu/torchvision-0.22.1-cp311-cp311-manylinux_2_28_aarch64.whl", hash = "sha256:8b4a53a6067d63adba0c52f2b8dd2290db649d642021674ee43c0c922f0c6a69" }, - { url = "https://download.pytorch.org/whl/cpu/torchvision-0.22.1-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:153f1790e505bd6da123e21eee6e83e2e155df05c0fe7d56347303067d8543c5" }, - { url = "https://download.pytorch.org/whl/cpu/torchvision-0.22.1-cp312-cp312-manylinux_2_28_aarch64.whl", hash = "sha256:964414eef19459d55a10e886e2fca50677550e243586d1678f65e3f6f6bac47a" }, - { url = "https://download.pytorch.org/whl/cpu/torchvision-0.22.1-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:9c3ae3319624c43cc8127020f46c14aa878406781f0899bb6283ae474afeafbf" }, - { url = "https://download.pytorch.org/whl/cpu/torchvision-0.22.1-cp313-cp313-manylinux_2_28_aarch64.whl", hash = "sha256:4a614a6a408d2ed74208d0ea6c28a2fbb68290e9a7df206c5fef3f0b6865d307" }, - { url = "https://download.pytorch.org/whl/cpu/torchvision-0.22.1-cp313-cp313t-macosx_11_0_arm64.whl", hash = "sha256:043d9e35ed69c2e586aff6eb9e2887382e7863707115668ac9d140da58f42cba" }, - { url = "https://download.pytorch.org/whl/cpu/torchvision-0.22.1-cp313-cp313t-manylinux_2_28_aarch64.whl", hash = "sha256:27142bcc8a984227a6dcf560985e83f52b82a7d3f5fe9051af586a2ccc46ef26" }, -] - -[[package]] -name = "torchvision" -version = "0.22.1" -source = { registry = "https://download.pytorch.org/whl/cu128" } -resolution-markers = [ - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux'", -] -dependencies = [ - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (python_full_version >= '3.11' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version >= '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (python_full_version < '3.11' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "pillow", marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://download.pytorch.org/whl/cu128/torchvision-0.22.1-cp310-cp310-manylinux_2_28_aarch64.whl", hash = "sha256:3a41b87628c0d6095839c43a1dd706670e7e5a56edc5860e700e1ba22c3ef8af" }, - { url = "https://download.pytorch.org/whl/cu128/torchvision-0.22.1-cp311-cp311-manylinux_2_28_aarch64.whl", hash = "sha256:299fbd935f02b424e9166b7689de57067e24a228edc00abd5faf84f86c0643a0" }, - { url = "https://download.pytorch.org/whl/cu128/torchvision-0.22.1-cp312-cp312-manylinux_2_28_aarch64.whl", hash = "sha256:2ad7fe412b821333fc05b4046263d77c14ba86f3965366adbada8dc397ea45b4" }, - { url = "https://download.pytorch.org/whl/cu128/torchvision-0.22.1-cp313-cp313-manylinux_2_28_aarch64.whl", hash = "sha256:75f519ebe412ced95d727c71c30c68084cc6fd36347b88f338e88ff9d07a3ac8" }, - { url = "https://download.pytorch.org/whl/cu128/torchvision-0.22.1-cp313-cp313t-manylinux_2_28_aarch64.whl", hash = "sha256:f6565fd22e04e51f9600f34a3a20b120ee9f5a73161bfcb79c826225054aa44e" }, -] - -[[package]] -name = "torchvision" -version = "0.22.1" -source = { registry = "https://pypi.org/simple" } -resolution-markers = [ - "(python_full_version >= '3.13' and sys_platform == 'Linux') or (python_full_version >= '3.13' and sys_platform == 'win32')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux') or (python_full_version == '3.12.*' and sys_platform == 'win32')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux') or (python_full_version == '3.11.*' and sys_platform == 'win32')", - "(python_full_version < '3.11' and sys_platform == 'Linux') or (python_full_version < '3.11' and sys_platform == 'win32')", - "python_full_version >= '3.13' and sys_platform == 'darwin'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version == '3.12.*' and sys_platform == 'darwin'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version == '3.11.*' and sys_platform == 'darwin'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version < '3.11' and sys_platform == 'darwin'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -dependencies = [ - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version < '3.11' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version >= '3.11' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "pillow", marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1", source = { registry = "https://pypi.org/simple" }, marker = "(extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra != 'extra-7-comfyui-cu128' and extra != 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/15/2c/7b67117b14c6cc84ae3126ca6981abfa3af2ac54eb5252b80d9475fb40df/torchvision-0.22.1-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:3b47d8369ee568c067795c0da0b4078f39a9dfea6f3bc1f3ac87530dfda1dd56", size = 1947825, upload-time = "2025-06-04T17:43:15.523Z" }, - { url = "https://files.pythonhosted.org/packages/6c/9f/c4dcf1d232b75e28bc37e21209ab2458d6d60235e16163544ed693de54cb/torchvision-0.22.1-cp310-cp310-manylinux_2_28_aarch64.whl", hash = "sha256:990de4d657a41ed71680cd8be2e98ebcab55371f30993dc9bd2e676441f7180e", size = 2512611, upload-time = "2025-06-04T17:43:03.951Z" }, - { url = "https://files.pythonhosted.org/packages/e2/99/db71d62d12628111d59147095527a0ab492bdfecfba718d174c04ae6c505/torchvision-0.22.1-cp310-cp310-manylinux_2_28_x86_64.whl", hash = "sha256:3347f690c2eed6d02aa0edfb9b01d321e7f7cf1051992d96d8d196c39b881d49", size = 7485668, upload-time = "2025-06-04T17:43:09.453Z" }, - { url = "https://files.pythonhosted.org/packages/32/ff/4a93a4623c3e5f97e8552af0f9f81d289dcf7f2ac71f1493f1c93a6b973d/torchvision-0.22.1-cp310-cp310-win_amd64.whl", hash = "sha256:86ad938f5a6ca645f0d5fb19484b1762492c2188c0ffb05c602e9e9945b7b371", size = 1707961, upload-time = "2025-06-04T17:43:13.038Z" }, - { url = "https://files.pythonhosted.org/packages/f6/00/bdab236ef19da050290abc2b5203ff9945c84a1f2c7aab73e8e9c8c85669/torchvision-0.22.1-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:4addf626e2b57fc22fd6d329cf1346d474497672e6af8383b7b5b636fba94a53", size = 1947827, upload-time = "2025-06-04T17:43:10.84Z" }, - { url = "https://files.pythonhosted.org/packages/ac/d0/18f951b2be3cfe48c0027b349dcc6fde950e3dc95dd83e037e86f284f6fd/torchvision-0.22.1-cp311-cp311-manylinux_2_28_aarch64.whl", hash = "sha256:8b4a53a6067d63adba0c52f2b8dd2290db649d642021674ee43c0c922f0c6a69", size = 2514021, upload-time = "2025-06-04T17:43:07.608Z" }, - { url = "https://files.pythonhosted.org/packages/c3/1a/63eb241598b36d37a0221e10af357da34bd33402ccf5c0765e389642218a/torchvision-0.22.1-cp311-cp311-manylinux_2_28_x86_64.whl", hash = "sha256:b7866a3b326413e67724ac46f1ee594996735e10521ba9e6cdbe0fa3cd98c2f2", size = 7487300, upload-time = "2025-06-04T17:42:58.349Z" }, - { url = "https://files.pythonhosted.org/packages/e5/73/1b009b42fe4a7774ba19c23c26bb0f020d68525c417a348b166f1c56044f/torchvision-0.22.1-cp311-cp311-win_amd64.whl", hash = "sha256:bb3f6df6f8fd415ce38ec4fd338376ad40c62e86052d7fc706a0dd51efac1718", size = 1707989, upload-time = "2025-06-04T17:43:14.332Z" }, - { url = "https://files.pythonhosted.org/packages/02/90/f4e99a5112dc221cf68a485e853cc3d9f3f1787cb950b895f3ea26d1ea98/torchvision-0.22.1-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:153f1790e505bd6da123e21eee6e83e2e155df05c0fe7d56347303067d8543c5", size = 1947827, upload-time = "2025-06-04T17:43:11.945Z" }, - { url = "https://files.pythonhosted.org/packages/25/f6/53e65384cdbbe732cc2106bb04f7fb908487e4fb02ae4a1613ce6904a122/torchvision-0.22.1-cp312-cp312-manylinux_2_28_aarch64.whl", hash = "sha256:964414eef19459d55a10e886e2fca50677550e243586d1678f65e3f6f6bac47a", size = 2514576, upload-time = "2025-06-04T17:43:02.707Z" }, - { url = "https://files.pythonhosted.org/packages/17/8b/155f99042f9319bd7759536779b2a5b67cbd4f89c380854670850f89a2f4/torchvision-0.22.1-cp312-cp312-manylinux_2_28_x86_64.whl", hash = "sha256:699c2d70d33951187f6ed910ea05720b9b4aaac1dcc1135f53162ce7d42481d3", size = 7485962, upload-time = "2025-06-04T17:42:43.606Z" }, - { url = "https://files.pythonhosted.org/packages/05/17/e45d5cd3627efdb47587a0634179a3533593436219de3f20c743672d2a79/torchvision-0.22.1-cp312-cp312-win_amd64.whl", hash = "sha256:75e0897da7a8e43d78632f66f2bdc4f6e26da8d3f021a7c0fa83746073c2597b", size = 1707992, upload-time = "2025-06-04T17:42:53.207Z" }, - { url = "https://files.pythonhosted.org/packages/7a/30/fecdd09fb973e963da68207fe9f3d03ec6f39a935516dc2a98397bf495c6/torchvision-0.22.1-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:9c3ae3319624c43cc8127020f46c14aa878406781f0899bb6283ae474afeafbf", size = 1947818, upload-time = "2025-06-04T17:42:51.954Z" }, - { url = "https://files.pythonhosted.org/packages/55/f4/b45f6cd92fa0acfac5e31b8e9258232f25bcdb0709a604e8b8a39d76e411/torchvision-0.22.1-cp313-cp313-manylinux_2_28_aarch64.whl", hash = "sha256:4a614a6a408d2ed74208d0ea6c28a2fbb68290e9a7df206c5fef3f0b6865d307", size = 2471597, upload-time = "2025-06-04T17:42:48.838Z" }, - { url = "https://files.pythonhosted.org/packages/8d/b0/3cffd6a285b5ffee3fe4a31caff49e350c98c5963854474d1c4f7a51dea5/torchvision-0.22.1-cp313-cp313-manylinux_2_28_x86_64.whl", hash = "sha256:7ee682be589bb1a002b7704f06b8ec0b89e4b9068f48e79307d2c6e937a9fdf4", size = 7485894, upload-time = "2025-06-04T17:43:01.371Z" }, - { url = "https://files.pythonhosted.org/packages/fd/1d/0ede596fedc2080d18108149921278b59f220fbb398f29619495337b0f86/torchvision-0.22.1-cp313-cp313-win_amd64.whl", hash = "sha256:2566cafcfa47ecfdbeed04bab8cef1307c8d4ef75046f7624b9e55f384880dfe", size = 1708020, upload-time = "2025-06-04T17:43:06.085Z" }, - { url = "https://files.pythonhosted.org/packages/0f/ca/e9a06bd61ee8e04fb4962a3fb524fe6ee4051662db07840b702a9f339b24/torchvision-0.22.1-cp313-cp313t-macosx_11_0_arm64.whl", hash = "sha256:043d9e35ed69c2e586aff6eb9e2887382e7863707115668ac9d140da58f42cba", size = 2137623, upload-time = "2025-06-04T17:43:05.028Z" }, - { url = "https://files.pythonhosted.org/packages/ab/c8/2ebe90f18e7ffa2120f5c3eab62aa86923185f78d2d051a455ea91461608/torchvision-0.22.1-cp313-cp313t-manylinux_2_28_aarch64.whl", hash = "sha256:27142bcc8a984227a6dcf560985e83f52b82a7d3f5fe9051af586a2ccc46ef26", size = 2476561, upload-time = "2025-06-04T17:42:59.691Z" }, - { url = "https://files.pythonhosted.org/packages/94/8b/04c6b15f8c29b39f0679589753091cec8b192ab296d4fdaf9055544c4ec9/torchvision-0.22.1-cp313-cp313t-manylinux_2_28_x86_64.whl", hash = "sha256:ef46e065502f7300ad6abc98554131c35dc4c837b978d91306658f1a65c00baa", size = 7658543, upload-time = "2025-06-04T17:42:46.064Z" }, - { url = "https://files.pythonhosted.org/packages/ab/c0/131628e6d42682b0502c63fd7f647b8b5ca4bd94088f6c85ca7225db8ac4/torchvision-0.22.1-cp313-cp313t-win_amd64.whl", hash = "sha256:7414eeacfb941fa21acddcd725f1617da5630ec822e498660a4b864d7d998075", size = 1629892, upload-time = "2025-06-04T17:42:57.156Z" }, -] - -[[package]] -name = "torchvision" -version = "0.22.1+cpu" -source = { registry = "https://download.pytorch.org/whl/cpu" } -resolution-markers = [ - "(python_full_version >= '3.13' and sys_platform == 'Linux') or (python_full_version >= '3.13' and sys_platform == 'win32')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux') or (python_full_version == '3.12.*' and sys_platform == 'win32')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux') or (python_full_version == '3.11.*' and sys_platform == 'win32')", - "(python_full_version < '3.11' and sys_platform == 'Linux') or (python_full_version < '3.11' and sys_platform == 'win32')", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -dependencies = [ - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (python_full_version >= '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (python_full_version >= '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (python_full_version >= '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu') or (python_full_version >= '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (python_full_version >= '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (python_full_version >= '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version >= '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (python_full_version < '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (python_full_version < '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (python_full_version < '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (python_full_version < '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.11' and sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu') or (python_full_version < '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (python_full_version < '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (python_full_version < '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (python_full_version < '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "pillow", marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cpu", source = { registry = "https://download.pytorch.org/whl/cpu" }, marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cpu') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra != 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://download.pytorch.org/whl/cpu/torchvision-0.22.1%2Bcpu-cp310-cp310-manylinux_2_28_x86_64.whl", hash = "sha256:e31f1273a8dd9760906288036ac3c8f5fef25eed393da0491db150d7be78910d" }, - { url = "https://download.pytorch.org/whl/cpu/torchvision-0.22.1%2Bcpu-cp310-cp310-win_amd64.whl", hash = "sha256:445e442b94c365f7fd96596347c8a5a7fcfcbfca17a23baa8c9dcc8cb00fceee" }, - { url = "https://download.pytorch.org/whl/cpu/torchvision-0.22.1%2Bcpu-cp311-cp311-manylinux_2_28_x86_64.whl", hash = "sha256:4e0cbc165a472605d0c13da68ae22e84b17a6b815d5e600834777823e1bcb658" }, - { url = "https://download.pytorch.org/whl/cpu/torchvision-0.22.1%2Bcpu-cp311-cp311-win_amd64.whl", hash = "sha256:9482adee074f60a45fd69892f7488281aadfda7836948c94b0a9b0caf55d1d67" }, - { url = "https://download.pytorch.org/whl/cpu/torchvision-0.22.1%2Bcpu-cp312-cp312-manylinux_2_28_x86_64.whl", hash = "sha256:b5fa7044bd82c6358e8229351c98070cf3a7bf4a6e89ea46352ae6c65745ef94" }, - { url = "https://download.pytorch.org/whl/cpu/torchvision-0.22.1%2Bcpu-cp312-cp312-win_amd64.whl", hash = "sha256:433cb4dbced7291f17064cea08ac1e5aebd02ec190e1c207d117ad62a8961f2b" }, - { url = "https://download.pytorch.org/whl/cpu/torchvision-0.22.1%2Bcpu-cp313-cp313-manylinux_2_28_x86_64.whl", hash = "sha256:a93c21f18c33a819616b3dda7655aa4de40b219682c654175b6bbeb65ecc2e5f" }, - { url = "https://download.pytorch.org/whl/cpu/torchvision-0.22.1%2Bcpu-cp313-cp313-win_amd64.whl", hash = "sha256:34c914ad4728b81848ac802c5fc5eeb8de8ff4058cc59c1463a74ce4f4fbf0d8" }, - { url = "https://download.pytorch.org/whl/cpu/torchvision-0.22.1%2Bcpu-cp313-cp313t-manylinux_2_28_x86_64.whl", hash = "sha256:ab7ae82529887c704c1b5d1d5198f65dc777d04fc3858b374503a6deedb82b19" }, - { url = "https://download.pytorch.org/whl/cpu/torchvision-0.22.1%2Bcpu-cp313-cp313t-win_amd64.whl", hash = "sha256:b2d1c4bdbfd8e6c779dc810a6171b56224f1332fc46986810d4081bed1633804" }, -] - -[[package]] -name = "torchvision" -version = "0.22.1+cu126" -source = { registry = "https://download.pytorch.org/whl/cu126" } -resolution-markers = [ - "(python_full_version >= '3.13' and sys_platform == 'Linux') or (python_full_version >= '3.13' and sys_platform == 'win32')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux') or (python_full_version == '3.12.*' and sys_platform == 'win32')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux') or (python_full_version == '3.11.*' and sys_platform == 'win32')", - "(python_full_version < '3.11' and sys_platform == 'Linux') or (python_full_version < '3.11' and sys_platform == 'win32')", - "python_full_version >= '3.13' and sys_platform == 'darwin'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version == '3.12.*' and sys_platform == 'darwin'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version == '3.11.*' and sys_platform == 'darwin'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version < '3.11' and sys_platform == 'darwin'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -dependencies = [ - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version < '3.11' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version >= '3.11' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "pillow", marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu126", source = { registry = "https://download.pytorch.org/whl/cu126" }, marker = "extra == 'extra-7-comfyui-cu126' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://download.pytorch.org/whl/cu126/torchvision-0.22.1%2Bcu126-cp310-cp310-manylinux_2_28_x86_64.whl", hash = "sha256:d697c146e2d83e2ff283d355ac7b39abe407da433b18060c4c78f2b84f14d252" }, - { url = "https://download.pytorch.org/whl/cu126/torchvision-0.22.1%2Bcu126-cp310-cp310-win_amd64.whl", hash = "sha256:9f571c9afbe6431a1eaf163885cdb7bf46eb482ed36e050bb0e40cc41e16de01" }, - { url = "https://download.pytorch.org/whl/cu126/torchvision-0.22.1%2Bcu126-cp311-cp311-manylinux_2_28_x86_64.whl", hash = "sha256:b49a0e0c10680e8ee8cb703227640a4b6376d5a285fe73b3254f304707cd8d2f" }, - { url = "https://download.pytorch.org/whl/cu126/torchvision-0.22.1%2Bcu126-cp311-cp311-win_amd64.whl", hash = "sha256:a2f2dec920c2f023e406caf342fae0d9071eeaca54fc0367ef66136765e6de5b" }, - { url = "https://download.pytorch.org/whl/cu126/torchvision-0.22.1%2Bcu126-cp312-cp312-manylinux_2_28_x86_64.whl", hash = "sha256:d6f17966552bb117d931db49bf49f19d2488631ff4c0b68a5215dd8739507b2e" }, - { url = "https://download.pytorch.org/whl/cu126/torchvision-0.22.1%2Bcu126-cp312-cp312-win_amd64.whl", hash = "sha256:8a46582304fdff54a953522851c91b4d6f35b1d5c48a7d81f7d893edf015ce91" }, - { url = "https://download.pytorch.org/whl/cu126/torchvision-0.22.1%2Bcu126-cp313-cp313-manylinux_2_28_x86_64.whl", hash = "sha256:ea4ac7eb55e419ee2f8e78177dddccea95a8ce7c3162abd695a77d05e410db29" }, - { url = "https://download.pytorch.org/whl/cu126/torchvision-0.22.1%2Bcu126-cp313-cp313-win_amd64.whl", hash = "sha256:e3239e98f08834730dedba81bcb539cc5fbfa227ed673483e6cf161acb916ade" }, - { url = "https://download.pytorch.org/whl/cu126/torchvision-0.22.1%2Bcu126-cp313-cp313t-manylinux_2_28_x86_64.whl", hash = "sha256:e29593b8454250607095315bd550d108b163b126ac856d991ac77e801ece802e" }, - { url = "https://download.pytorch.org/whl/cu126/torchvision-0.22.1%2Bcu126-cp313-cp313t-win_amd64.whl", hash = "sha256:a05eeaf478e34ad345534311ce4fffc42f1f0a874973e9efadb3b4990c8c6787" }, -] - -[[package]] -name = "torchvision" -version = "0.22.1+cu128" -source = { registry = "https://download.pytorch.org/whl/cu128" } -resolution-markers = [ - "(python_full_version >= '3.13' and sys_platform == 'Linux') or (python_full_version >= '3.13' and sys_platform == 'win32')", - "(python_full_version == '3.12.*' and sys_platform == 'Linux') or (python_full_version == '3.12.*' and sys_platform == 'win32')", - "(python_full_version == '3.11.*' and sys_platform == 'Linux') or (python_full_version == '3.11.*' and sys_platform == 'win32')", - "(python_full_version < '3.11' and sys_platform == 'Linux') or (python_full_version < '3.11' and sys_platform == 'win32')", - "python_full_version >= '3.13' and sys_platform == 'darwin'", - "(python_full_version >= '3.13' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version >= '3.13' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version == '3.12.*' and sys_platform == 'darwin'", - "(python_full_version == '3.12.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.12.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version == '3.11.*' and sys_platform == 'darwin'", - "(python_full_version == '3.11.*' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version == '3.11.*' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", - "python_full_version < '3.11' and sys_platform == 'darwin'", - "(python_full_version < '3.11' and platform_machine != 'aarch64' and sys_platform == 'linux') or (python_full_version < '3.11' and sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32')", -] -dependencies = [ - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version < '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128') or (python_full_version < '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version >= '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128') or (python_full_version < '3.11' and platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.11' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128') or (platform_machine == 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "pillow", marker = "(platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+cu128", source = { registry = "https://download.pytorch.org/whl/cu128" }, marker = "(platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://download.pytorch.org/whl/cu128/torchvision-0.22.1%2Bcu128-cp310-cp310-manylinux_2_28_x86_64.whl", hash = "sha256:538f4db667286d939b4eee0a66d31ed21b51186668006b0e0ffe20338ecc7e00" }, - { url = "https://download.pytorch.org/whl/cu128/torchvision-0.22.1%2Bcu128-cp310-cp310-win_amd64.whl", hash = "sha256:ad48ba3c3ffd48027e3a8de42fcea131a53a524ee9416ca4efb22f9ac6b7328d" }, - { url = "https://download.pytorch.org/whl/cu128/torchvision-0.22.1%2Bcu128-cp311-cp311-manylinux_2_28_x86_64.whl", hash = "sha256:92568ac46b13a8c88b61589800b1b9c4629be091ea7ce080fc6fc622e11e0915" }, - { url = "https://download.pytorch.org/whl/cu128/torchvision-0.22.1%2Bcu128-cp311-cp311-win_amd64.whl", hash = "sha256:85ecd729c947151eccea502853be6efc2c0029dc26e6e5148e04684aed008390" }, - { url = "https://download.pytorch.org/whl/cu128/torchvision-0.22.1%2Bcu128-cp312-cp312-manylinux_2_28_x86_64.whl", hash = "sha256:f64ef9bb91d71ab35d8384912a19f7419e35928685bc67544d58f45148334373" }, - { url = "https://download.pytorch.org/whl/cu128/torchvision-0.22.1%2Bcu128-cp312-cp312-win_amd64.whl", hash = "sha256:650561ba326d21021243f5e064133dc62dc64d52f79623db5cd76637a9665f96" }, - { url = "https://download.pytorch.org/whl/cu128/torchvision-0.22.1%2Bcu128-cp313-cp313-manylinux_2_28_x86_64.whl", hash = "sha256:bc4fef193917b51db6b409acd3ffdec9286d877baac0aee5dcfbb72592d00bfc" }, - { url = "https://download.pytorch.org/whl/cu128/torchvision-0.22.1%2Bcu128-cp313-cp313-win_amd64.whl", hash = "sha256:eb784cc75a66f3336a04ff3a992bf74160842132db69e8bdbb58b5ab9422c345" }, - { url = "https://download.pytorch.org/whl/cu128/torchvision-0.22.1%2Bcu128-cp313-cp313t-manylinux_2_28_x86_64.whl", hash = "sha256:02faf51fbf5070592768fa935327d13a484b745faef38b0fee01d85cfb35f5bc" }, - { url = "https://download.pytorch.org/whl/cu128/torchvision-0.22.1%2Bcu128-cp313-cp313t-win_amd64.whl", hash = "sha256:e5320bb2c9f69636f3dc18abc3291fe8c8e448cb9ef0112510a5413a5af3f8f2" }, -] - -[[package]] -name = "torchvision" -version = "0.22.1+rocm6.3" -source = { registry = "https://download.pytorch.org/whl/rocm6.3" } -resolution-markers = [ - "python_full_version >= '3.13' and sys_platform == 'Linux'", - "python_full_version == '3.12.*' and sys_platform == 'Linux'", - "python_full_version == '3.11.*' and sys_platform == 'Linux'", - "python_full_version < '3.11' and sys_platform == 'Linux'", - "python_full_version >= '3.13' and sys_platform == 'win32'", - "python_full_version == '3.12.*' and sys_platform == 'win32'", - "python_full_version == '3.11.*' and sys_platform == 'win32'", - "python_full_version < '3.11' and sys_platform == 'win32'", - "python_full_version >= '3.13' and sys_platform == 'darwin'", - "python_full_version >= '3.13' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "python_full_version == '3.12.*' and sys_platform == 'darwin'", - "python_full_version == '3.12.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "python_full_version == '3.11.*' and sys_platform == 'darwin'", - "python_full_version == '3.11.*' and platform_machine == 'aarch64' and sys_platform == 'linux'", - "python_full_version < '3.11' and sys_platform == 'darwin'", - "python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux'", -] -dependencies = [ - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version < '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'win32' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.11' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "(python_full_version >= '3.11' and platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.11' and sys_platform == 'Linux' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.11' and sys_platform == 'darwin' and extra == 'extra-7-comfyui-rocm') or (python_full_version >= '3.11' and sys_platform == 'win32' and extra == 'extra-7-comfyui-rocm') or (python_full_version < '3.11' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'Linux' and sys_platform != 'darwin' and sys_platform != 'linux' and sys_platform != 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'Linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'win32' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "pillow", marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, - { name = "torch", version = "2.7.1+rocm6.3", source = { registry = "https://download.pytorch.org/whl/rocm6.3" }, marker = "(platform_machine == 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-rocm') or (platform_machine != 'aarch64' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'Linux' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'win32' and extra != 'extra-7-comfyui-cpu' and extra != 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://download.pytorch.org/whl/rocm6.3/torchvision-0.22.1%2Brocm6.3-cp310-cp310-manylinux_2_28_x86_64.whl", hash = "sha256:35b6e1ba34b009042e9dc00ed3f82a2b1700b738bd942615e68cd5e41faadb99" }, - { url = "https://download.pytorch.org/whl/rocm6.3/torchvision-0.22.1%2Brocm6.3-cp311-cp311-manylinux_2_28_x86_64.whl", hash = "sha256:c150162c2e1de371e5a52c0eb4a98541f307e01716cfe5c850f25c7caa3d3fc4" }, - { url = "https://download.pytorch.org/whl/rocm6.3/torchvision-0.22.1%2Brocm6.3-cp312-cp312-manylinux_2_28_x86_64.whl", hash = "sha256:0dce205fb04d9eb2f6feb74faf17cba9180aff70a8c8ac084912ce41b2dc0ab7" }, - { url = "https://download.pytorch.org/whl/rocm6.3/torchvision-0.22.1%2Brocm6.3-cp313-cp313-manylinux_2_28_x86_64.whl", hash = "sha256:565ace3680d37c7d39ec8da758333fa13fafb30317b6d4c3b389d46430f11a2b" }, - { url = "https://download.pytorch.org/whl/rocm6.3/torchvision-0.22.1%2Brocm6.3-cp313-cp313t-manylinux_2_28_x86_64.whl", hash = "sha256:c377ae873066de8441fe9f7783b3ff88ced7996df7e3556ef32b95fd977fb351" }, -] - -[[package]] -name = "tqdm" -version = "4.67.1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "colorama", marker = "sys_platform == 'win32' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/a8/4b/29b4ef32e036bb34e4ab51796dd745cdba7ed47ad142a9f4a1eb8e0c744d/tqdm-4.67.1.tar.gz", hash = "sha256:f8aef9c52c08c13a65f30ea34f4e5aac3fd1a34959879d7e59e63027286627f2", size = 169737, upload-time = "2024-11-24T20:12:22.481Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/d0/30/dc54f88dd4a2b5dc8a0279bdd7270e735851848b762aeb1c1184ed1f6b14/tqdm-4.67.1-py3-none-any.whl", hash = "sha256:26445eca388f82e72884e0d580d5464cd801a3ea01e63e5601bdff9ba6a48de2", size = 78540, upload-time = "2024-11-24T20:12:19.698Z" }, -] - -[[package]] -name = "trampoline" -version = "0.1.2" -source = { registry = "https://pypi.org/simple" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/73/54/d2805324fb746d8da86d3844bee4f55c0cfd6c136de61b713772d44c5bea/trampoline-0.1.2-py3-none-any.whl", hash = "sha256:36cc9a4ff9811843d177fc0e0740efbd7da39eadfe6e50c9e2937cbc06d899d9", size = 5173, upload-time = "2018-08-18T01:00:41.215Z" }, -] - -[[package]] -name = "transformers" -version = "4.52.4" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "filelock" }, - { name = "huggingface-hub" }, - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "packaging" }, - { name = "pyyaml" }, - { name = "regex" }, - { name = "requests" }, - { name = "safetensors" }, - { name = "tokenizers" }, - { name = "tqdm" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/da/a9/275037087f9d846580b02f2d7cae0e0a6955d46f84583d0151d6227bd416/transformers-4.52.4.tar.gz", hash = "sha256:aff3764441c1adc192a08dba49740d3cbbcb72d850586075aed6bd89b98203e6", size = 8945376, upload-time = "2025-05-30T09:17:17.947Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/96/f2/25b27b396af03d5b64e61976b14f7209e2939e9e806c10749b6d277c273e/transformers-4.52.4-py3-none-any.whl", hash = "sha256:203f5c19416d5877e36e88633943761719538a25d9775977a24fe77a1e5adfc7", size = 10460375, upload-time = "2025-05-30T09:17:14.477Z" }, -] - -[[package]] -name = "treescope" -version = "0.1.9" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "numpy", version = "2.2.6", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version < '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, - { name = "numpy", version = "2.3.0", source = { registry = "https://pypi.org/simple" }, marker = "python_full_version >= '3.11' or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm')" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/26/27/80ad254da167e0055d5679aefd224ab08844a4cd55aeee7ef72c999d5fc6/treescope-0.1.9.tar.gz", hash = "sha256:ba6cdbdc9c5b52691d5f3bb4c5d5c7daa5627119acac8640b46d37e6aabe63a6", size = 544385, upload-time = "2025-02-17T19:58:01.712Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/e4/09/b7e7bc5f21313d227e4fb98d2037646457ec06746327c5dd8ffed75e41e1/treescope-0.1.9-py3-none-any.whl", hash = "sha256:68677013a9f0228212fccf835f3fb037be07ae8b4c5f6f58eefab11198f83cf7", size = 182162, upload-time = "2025-02-17T19:57:57.7Z" }, -] - -[[package]] -name = "triton" -version = "3.3.1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "setuptools", marker = "(platform_machine != 'aarch64' and sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cu126') or (sys_platform != 'darwin' and sys_platform != 'linux' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-cu128') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'darwin' and extra == 'extra-7-comfyui-cu128' and extra == 'extra-7-comfyui-rocm') or (sys_platform == 'linux' and extra == 'extra-7-comfyui-cu126' and extra == 'extra-7-comfyui-rocm') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu126') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-cu128') or (extra == 'extra-7-comfyui-cpu' and extra == 'extra-7-comfyui-rocm')" }, -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/8d/a9/549e51e9b1b2c9b854fd761a1d23df0ba2fbc60bd0c13b489ffa518cfcb7/triton-3.3.1-cp310-cp310-manylinux_2_27_x86_64.manylinux_2_28_x86_64.whl", hash = "sha256:b74db445b1c562844d3cfad6e9679c72e93fdfb1a90a24052b03bb5c49d1242e", size = 155600257, upload-time = "2025-05-29T23:39:36.085Z" }, - { url = "https://files.pythonhosted.org/packages/21/2f/3e56ea7b58f80ff68899b1dbe810ff257c9d177d288c6b0f55bf2fe4eb50/triton-3.3.1-cp311-cp311-manylinux_2_27_x86_64.manylinux_2_28_x86_64.whl", hash = "sha256:b31e3aa26f8cb3cc5bf4e187bf737cbacf17311e1112b781d4a059353dfd731b", size = 155689937, upload-time = "2025-05-29T23:39:44.182Z" }, - { url = "https://files.pythonhosted.org/packages/24/5f/950fb373bf9c01ad4eb5a8cd5eaf32cdf9e238c02f9293557a2129b9c4ac/triton-3.3.1-cp312-cp312-manylinux_2_27_x86_64.manylinux_2_28_x86_64.whl", hash = "sha256:9999e83aba21e1a78c1f36f21bce621b77bcaa530277a50484a7cb4a822f6e43", size = 155669138, upload-time = "2025-05-29T23:39:51.771Z" }, - { url = "https://files.pythonhosted.org/packages/74/1f/dfb531f90a2d367d914adfee771babbd3f1a5b26c3f5fbc458dee21daa78/triton-3.3.1-cp313-cp313-manylinux_2_27_x86_64.manylinux_2_28_x86_64.whl", hash = "sha256:b89d846b5a4198317fec27a5d3a609ea96b6d557ff44b56c23176546023c4240", size = 155673035, upload-time = "2025-05-29T23:40:02.468Z" }, - { url = "https://files.pythonhosted.org/packages/28/71/bd20ffcb7a64c753dc2463489a61bf69d531f308e390ad06390268c4ea04/triton-3.3.1-cp313-cp313t-manylinux_2_27_x86_64.manylinux_2_28_x86_64.whl", hash = "sha256:a3198adb9d78b77818a5388bff89fa72ff36f9da0bc689db2f0a651a67ce6a42", size = 155735832, upload-time = "2025-05-29T23:40:10.522Z" }, -] - -[[package]] -name = "triton-windows" -version = "3.3.1.post19" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "setuptools", marker = "sys_platform == 'Linux' or sys_platform == 'win32'" }, -] -wheels = [ - { url = "https://files.pythonhosted.org/packages/87/95/ad9d2b6f9849d534d25de7ff74009d769671794da78226c6f67d6b0de9e5/triton_windows-3.3.1.post19-cp310-cp310-win_amd64.whl", hash = "sha256:667566ff34d0fc4e09c1226f35524d074d3e125ea188c98caf107b8de8228c90", size = 41915003, upload-time = "2025-05-30T15:12:10.422Z" }, - { url = "https://files.pythonhosted.org/packages/e5/77/7dfe26a49020824a75601eb4327f3245f17b409abf6a632a082eaadb50bf/triton_windows-3.3.1.post19-cp311-cp311-win_amd64.whl", hash = "sha256:f9d80e12b55a842b2ec0c029cc3df4cc1301f839c6396ec93ded35fc80e11a28", size = 41915203, upload-time = "2025-05-30T15:12:20.836Z" }, - { url = "https://files.pythonhosted.org/packages/c6/c8/443ff6e9b5bdd1da6ebca5ea05343f27ccd04c91be5632d8e609523bcd85/triton_windows-3.3.1.post19-cp312-cp312-win_amd64.whl", hash = "sha256:ba04c251fb26f7a77ef18f7bed15221d14c24e60b66a023162a750517aedc216", size = 41915618, upload-time = "2025-05-30T15:12:31.032Z" }, - { url = "https://files.pythonhosted.org/packages/e0/9b/778979b558f3fe541a42379bd8822c31075bc3e9cf53ed6e5688c7dbf972/triton_windows-3.3.1.post19-cp313-cp313-win_amd64.whl", hash = "sha256:743e538f989609e57f8f9ee6d1442e4d1035997366f81d6bc89e2debcdd37f9e", size = 41915222, upload-time = "2025-05-30T15:12:41.58Z" }, -] - -[[package]] -name = "typer" -version = "0.16.0" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "click" }, - { name = "rich" }, - { name = "shellingham" }, - { name = "typing-extensions" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/c5/8c/7d682431efca5fd290017663ea4588bf6f2c6aad085c7f108c5dbc316e70/typer-0.16.0.tar.gz", hash = "sha256:af377ffaee1dbe37ae9440cb4e8f11686ea5ce4e9bae01b84ae7c63b87f1dd3b", size = 102625, upload-time = "2025-05-26T14:30:31.824Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/76/42/3efaf858001d2c2913de7f354563e3a3a2f0decae3efe98427125a8f441e/typer-0.16.0-py3-none-any.whl", hash = "sha256:1f79bed11d4d02d4310e3c1b7ba594183bcedb0ac73b27a9e5f28f6fb5b98855", size = 46317, upload-time = "2025-05-26T14:30:30.523Z" }, -] - -[[package]] -name = "typing-extensions" -version = "4.14.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/d1/bc/51647cd02527e87d05cb083ccc402f93e441606ff1f01739a62c8ad09ba5/typing_extensions-4.14.0.tar.gz", hash = "sha256:8676b788e32f02ab42d9e7c61324048ae4c6d844a399eebace3d4979d75ceef4", size = 107423, upload-time = "2025-06-02T14:52:11.399Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/69/e0/552843e0d356fbb5256d21449fa957fa4eff3bbc135a74a691ee70c7c5da/typing_extensions-4.14.0-py3-none-any.whl", hash = "sha256:a1514509136dd0b477638fc68d6a91497af5076466ad0fa6c338e44e359944af", size = 43839, upload-time = "2025-06-02T14:52:10.026Z" }, -] - -[[package]] -name = "typing-inspection" -version = "0.4.1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "typing-extensions" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/f8/b1/0c11f5058406b3af7609f121aaa6b609744687f1d158b3c3a5bf4cc94238/typing_inspection-0.4.1.tar.gz", hash = "sha256:6ae134cc0203c33377d43188d4064e9b357dba58cff3185f22924610e70a9d28", size = 75726, upload-time = "2025-05-21T18:55:23.885Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/17/69/cd203477f944c353c31bade965f880aa1061fd6bf05ded0726ca845b6ff7/typing_inspection-0.4.1-py3-none-any.whl", hash = "sha256:389055682238f53b04f7badcb49b989835495a96700ced5dab2d8feae4b26f51", size = 14552, upload-time = "2025-05-21T18:55:22.152Z" }, -] - -[[package]] -name = "urllib3" -version = "2.4.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/8a/78/16493d9c386d8e60e442a35feac5e00f0913c0f4b7c217c11e8ec2ff53e0/urllib3-2.4.0.tar.gz", hash = "sha256:414bc6535b787febd7567804cc015fee39daab8ad86268f1310a9250697de466", size = 390672, upload-time = "2025-04-10T15:23:39.232Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/6b/11/cc635220681e93a0183390e26485430ca2c7b5f9d33b15c74c2861cb8091/urllib3-2.4.0-py3-none-any.whl", hash = "sha256:4e16665048960a0900c702d4a66415956a584919c03361cac9f1df5c5dd7e813", size = 128680, upload-time = "2025-04-10T15:23:37.377Z" }, -] - -[[package]] -name = "vtracer" -version = "0.6.11" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/e8/ad/2c89d6f2858ec8a1ac093144ebe6cfefc9307920ce95ad4ff045bb72b228/vtracer-0.6.11.tar.gz", hash = "sha256:407e147362366e14e2666155bf328814bdc345899a6cce18a7729724ff25c01e", size = 24054, upload-time = "2024-05-02T22:09:06.661Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/ec/f7/62f075e0012d5b9e888e731d1050ce6a411d2da58ed0ff90502448a079f3/vtracer-0.6.11-cp310-cp310-macosx_10_12_x86_64.whl", hash = "sha256:91d4d681b8b7d1a5a68e010c44a9c80fb2c1afb7e957e3f35b1cb7469ac224f4", size = 964382, upload-time = "2024-05-02T22:06:17.362Z" }, - { url = "https://files.pythonhosted.org/packages/d0/f5/8296f2dc015f5e6bf6842fffcca14845b5790c4ac1e1a869cad54d3e03d8/vtracer-0.6.11-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:1b5a66cba5ba96bd0898161bc78893bbcbc87b5bb87a2be9ea9389b71a86eb87", size = 921907, upload-time = "2024-05-02T22:06:19.72Z" }, - { url = "https://files.pythonhosted.org/packages/7a/c0/362af16c875516dcfecbb5769a23c62ebf9bc8dea06dbc65d8f5af039a33/vtracer-0.6.11-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:88d7bfd3f2605fe62d97ff24de6a16c31bdc0d191fc2a7ed8bc3c0fe04d8c7f0", size = 1791784, upload-time = "2024-05-02T22:06:21.625Z" }, - { url = "https://files.pythonhosted.org/packages/55/73/e8d5b34f2a3bda584df338a48b392028739e711fed8633729e6e5a84b5ca/vtracer-0.6.11-cp310-cp310-manylinux_2_17_armv7l.manylinux2014_armv7l.whl", hash = "sha256:35761bf24eeb6e1d45f1899bfda47c60376b2a13ca6bd981a960bbd904ed5937", size = 1801748, upload-time = "2024-05-02T22:06:24.045Z" }, - { url = "https://files.pythonhosted.org/packages/aa/93/db9552e01dadbdb0eab116dde0452b3125eab7574e54e4245f210ab3b380/vtracer-0.6.11-cp310-cp310-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:979dac594344ea707fb5134c86e0d6080114c2d52e62c0910d058818b12d8da4", size = 1899872, upload-time = "2024-05-02T22:06:26.736Z" }, - { url = "https://files.pythonhosted.org/packages/ec/c4/a54a84b8c2c20e94b6afdfd2b4919e421c654bcbea8313fc14841131ff3c/vtracer-0.6.11-cp310-cp310-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:db1c4b04bbeab83a2a442f6a88bdf247184b79e0e9c05b076b162b70c5cd1ead", size = 1883931, upload-time = "2024-05-02T22:06:29.346Z" }, - { url = "https://files.pythonhosted.org/packages/27/f3/536a2eab991985aaa07ccf2a1bba702eb244d1399b4782ffc01582e47616/vtracer-0.6.11-cp310-cp310-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:fa8f6391d6572c5a55c7865d613a1774cbe88581080045984993fd2021e1608b", size = 2024713, upload-time = "2024-05-02T22:06:31.386Z" }, - { url = "https://files.pythonhosted.org/packages/c8/77/d20803727cce004e01147d39a75a6102589647a5537e88691eb8b5e57120/vtracer-0.6.11-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:03cd974619657b2b5614d1936be5b59ebfdbc9f611e4c939c9a7c84712314df3", size = 1817972, upload-time = "2024-05-02T22:06:33.341Z" }, - { url = "https://files.pythonhosted.org/packages/a6/66/90d65348bfe4c56e80284d128e0fca391b67ef6d234a6e9ca08cde0fb70c/vtracer-0.6.11-cp310-none-win32.whl", hash = "sha256:e6a67492f103e85540e52b09c6cc947819a8630083696fdea5be466e812ae519", size = 770332, upload-time = "2024-05-02T22:06:35.758Z" }, - { url = "https://files.pythonhosted.org/packages/33/87/948a6f113f68d7775b184356b4decc33bb1a43497efa89721c8415f9cf37/vtracer-0.6.11-cp310-none-win_amd64.whl", hash = "sha256:ea65c0a6cd06df28e1d5e4c58e60c3dfae3241ce75b628b5256dded636781ff0", size = 789110, upload-time = "2024-05-02T22:06:38.091Z" }, - { url = "https://files.pythonhosted.org/packages/0c/cf/cb669600592335dc781b0da1e200ffe9af2840ddffc7a83fab5a1763b4d7/vtracer-0.6.11-cp311-cp311-macosx_10_12_x86_64.whl", hash = "sha256:9868a771c264a4895ea61d86b7445754b896be3b3f287d56331de0ea0a6ed4f6", size = 964427, upload-time = "2024-05-02T22:06:40.535Z" }, - { url = "https://files.pythonhosted.org/packages/47/17/061011d5e00e06eb6673e5735957d957f1c720c21f80437b9fd0e8d133f8/vtracer-0.6.11-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:0dd57915987a5c62d78ba17cf620a27a8297983d481675313328f75f59ff1840", size = 921986, upload-time = "2024-05-02T22:06:42.446Z" }, - { url = "https://files.pythonhosted.org/packages/a8/c6/f0e6790566a0065b7de6bdba5183855d16e56d79d327f4d557aee3e4d6d8/vtracer-0.6.11-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:9414748c8877ea38f5a6d5942ad994185d9c13761f85316620c97cd53bc8d197", size = 1791843, upload-time = "2024-05-02T22:06:44.686Z" }, - { url = "https://files.pythonhosted.org/packages/51/19/be6807507b9343bfe3d3b522629e26c8219e4fe02f6bc519702de852f0ac/vtracer-0.6.11-cp311-cp311-manylinux_2_17_armv7l.manylinux2014_armv7l.whl", hash = "sha256:5eb28a6f3de3f4a65d81a0cd60afe3ffa0ed65480f5f06ba18be4019aae255d5", size = 1801752, upload-time = "2024-05-02T22:06:46.396Z" }, - { url = "https://files.pythonhosted.org/packages/35/78/10d63f3fc9375e6e5214dfdff3f4211b06686c0ce08e825265ad5ee5a358/vtracer-0.6.11-cp311-cp311-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:9eaffb399d023d1ea5fb8ae5faf0e6248692a7c34d1e3bed04e50f307b242158", size = 1899852, upload-time = "2024-05-02T22:06:49.251Z" }, - { url = "https://files.pythonhosted.org/packages/20/9b/ae66bc451d8b99586cdf2394ca2cf44062063a976360c78a34f996375daf/vtracer-0.6.11-cp311-cp311-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:82920d1c4afe0c3c7ad075bbe63b2b3e3e4884c98f1773f078630947a88e0718", size = 1883863, upload-time = "2024-05-02T22:06:51.705Z" }, - { url = "https://files.pythonhosted.org/packages/0c/bc/cfe4478f9fe1358eaf60b91c99c72107526c277bc1216f5d6d5747c2f5f7/vtracer-0.6.11-cp311-cp311-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:93c07a5c3456648708f688664334fe6e66b5cd897c8ddad7d2442700056de6a5", size = 2024774, upload-time = "2024-05-02T22:06:54.076Z" }, - { url = "https://files.pythonhosted.org/packages/b7/ac/aa376c4d7ba6597fc4f9aadbccfb1fc84d3911e48ecfbf9acf1dcacd3167/vtracer-0.6.11-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:62f752f5e6d46a334e064368ff47b72550c4f460aad7ff2ede1f790ba6f65b33", size = 1818085, upload-time = "2024-05-02T22:06:56.24Z" }, - { url = "https://files.pythonhosted.org/packages/dd/03/2a98e4f38636ce75f0ef99ff4725a0837a3c7753de578a3d722b7ff9444d/vtracer-0.6.11-cp311-none-win32.whl", hash = "sha256:bca8d8f1c92184abcc6ec76b2f06c75f4172f05812794efe8ec4eff057435bff", size = 770331, upload-time = "2024-05-02T22:06:58.004Z" }, - { url = "https://files.pythonhosted.org/packages/3f/86/6cf264f55d0505c6ca36fb6de2139b67bd74a74a50cbd2b58b5ccde37cf7/vtracer-0.6.11-cp311-none-win_amd64.whl", hash = "sha256:efec6250df8a4e27a8c9d8e101093726b3de4d65a7df1f426c813974dbc19960", size = 789117, upload-time = "2024-05-02T22:07:00.311Z" }, - { url = "https://files.pythonhosted.org/packages/ec/78/f91da19e1f4769317fe14a6bacb2be9e21b8fa6262dbd7021e2ab33545f8/vtracer-0.6.11-cp312-cp312-macosx_10_12_x86_64.whl", hash = "sha256:4ac53a37dd1729f16ed64feae4f40b8dae1cf61dfe0d6bf26e9d399d48a25250", size = 963913, upload-time = "2024-05-02T22:07:02.339Z" }, - { url = "https://files.pythonhosted.org/packages/82/4e/4a7728b8d9eca037a0e2e9e08c5b94af61d1590afb1f378b5928c53c16a5/vtracer-0.6.11-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:e48a726e0f1b1d80d8d199e17ae3f95c048b5907f764134e257a79e543e30278", size = 921907, upload-time = "2024-05-02T22:07:04.07Z" }, - { url = "https://files.pythonhosted.org/packages/7e/fa/45e7c7a2add37e5647c05928731b8fd0685e48b220979f05beeabf754bb9/vtracer-0.6.11-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:67e17c5ac4cfa697c8686e563db84e027b9fb1c8b06b797285f58abd6e147eff", size = 1790996, upload-time = "2024-05-02T22:07:06.164Z" }, - { url = "https://files.pythonhosted.org/packages/c7/2c/c5e2c3a195478eb7b2d723d34a7f1011b3bc8b7916b540bea1b24b26d829/vtracer-0.6.11-cp312-cp312-manylinux_2_17_armv7l.manylinux2014_armv7l.whl", hash = "sha256:3229dd4f32d316d4fad14a6671583e57d0c7eec604bf6f91a8765c8fc7cc6610", size = 1801203, upload-time = "2024-05-02T22:07:08.076Z" }, - { url = "https://files.pythonhosted.org/packages/7b/b7/6880f045f727b8cece6c1e4a3e03cf8198685a93a22daffddccda05dcabf/vtracer-0.6.11-cp312-cp312-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:be93615d159947e050cfd26e89a0916c8e3674c2ab2ef1c87ce31579a0900eca", size = 1898368, upload-time = "2024-05-02T22:07:10.618Z" }, - { url = "https://files.pythonhosted.org/packages/7e/df/76855a3bc29a5474958d46f6a51f9d4bcc64124aa11b69087f1e1d4d5708/vtracer-0.6.11-cp312-cp312-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:1644d2f7942a27109bc8ca4de8116fc4234135ecea20ef8e0350ddd4cbbf9972", size = 1882947, upload-time = "2024-05-02T22:07:12.982Z" }, - { url = "https://files.pythonhosted.org/packages/ea/cb/14ed02290f514325551e2fd3015b09f29ca330d51219767fca74dc4bb506/vtracer-0.6.11-cp312-cp312-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:6a47ed4d19834fc7e9e5387f85c160895552cb81a3eb4171e2087dc9e4841551", size = 2013341, upload-time = "2024-05-02T22:07:14.838Z" }, - { url = "https://files.pythonhosted.org/packages/96/24/07a0a4d12d31c49513823a15deea3c735580819eb67af914676df5cb9c8e/vtracer-0.6.11-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:1f804d3b4f23b512a5bcf687944e1eb7a38069e0b2bec4edf4ae9810a13d5953", size = 1816606, upload-time = "2024-05-02T22:07:16.944Z" }, - { url = "https://files.pythonhosted.org/packages/2e/e1/b659c9c5a3799a0755de1697d07af4ae81d8148a865e60ff0cc89c69cfe7/vtracer-0.6.11-cp312-none-win32.whl", hash = "sha256:63ae0ec7ba3db067b5e9979aa05219e79dc181b9013d2cdc4fea4dfb22818eb9", size = 770494, upload-time = "2024-05-02T22:07:19.143Z" }, - { url = "https://files.pythonhosted.org/packages/c1/a0/49b1bdeb1df5d6a4d2ccca739a6c4ab9699082fa7ae77fa352b96113b4ea/vtracer-0.6.11-cp312-none-win_amd64.whl", hash = "sha256:5f2174a6f2da741672f3322daf0d59fc24705632a5c4ecb633cb74d5cf1c0c16", size = 789552, upload-time = "2024-05-02T22:07:20.785Z" }, - { url = "https://files.pythonhosted.org/packages/29/31/6f0e0399f0d3ca03390aa79284a83da81d1ee161de3d257e47433aad51cb/vtracer-0.6.11-pp310-pypy310_pp73-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:650dad7cc650fa607b762476865cb8f76314f15c9197c93789885ab964f3b90c", size = 1791851, upload-time = "2024-05-02T22:08:14.465Z" }, - { url = "https://files.pythonhosted.org/packages/22/2f/341b4e2834430e1dafc1ea477c30dc835fe2b11c06f3b1a09b93fd9c3156/vtracer-0.6.11-pp310-pypy310_pp73-manylinux_2_17_armv7l.manylinux2014_armv7l.whl", hash = "sha256:64733282d1736c4e7849b875865f1a3f3e0c637e584dd17a47691b747392e235", size = 1802241, upload-time = "2024-05-02T22:08:16.507Z" }, - { url = "https://files.pythonhosted.org/packages/13/2c/f26389bb5ea77ae05a6c750abe2233b020c09feb109790ac3e2e8c71d4dc/vtracer-0.6.11-pp310-pypy310_pp73-manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:23911ee68ecb36acad3bd1f46bfbb4c8e33ed527937f0b1a3ab9e047e422783d", size = 1899574, upload-time = "2024-05-02T22:08:18.51Z" }, - { url = "https://files.pythonhosted.org/packages/90/48/0fc0e82ba0d645d799a6f8f6f9b04fe40ffa5e772ccb315b63a1f826b53f/vtracer-0.6.11-pp310-pypy310_pp73-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:c913a7c63ae9309044c0e768978aba0e032b2000e9b67fd3fb2ae0a5bb88a72d", size = 1883297, upload-time = "2024-05-02T22:08:20.445Z" }, - { url = "https://files.pythonhosted.org/packages/18/29/2a9381571663151a560d834151e8d2e7c998fde46b9907e3cdfc5cbcbd90/vtracer-0.6.11-pp310-pypy310_pp73-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:a2d4c1295e5fdb1c857f0b9f0eedb706550b0531f0cedae07df1b45bc2509a60", size = 2024939, upload-time = "2024-05-02T22:08:22.713Z" }, - { url = "https://files.pythonhosted.org/packages/7e/04/38c6a4110460d3c42fbb75860fdc3c60ef238a8d12654f8e0fffad1f424f/vtracer-0.6.11-pp310-pypy310_pp73-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:80e263c67263a9b7af3a4b78d8b49c33f223e8017fc937b64f224ce3c632d1bb", size = 1814125, upload-time = "2024-05-02T22:08:24.76Z" }, -] - -[[package]] -name = "wadler-lindig" -version = "0.1.6" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/4d/c8/e2112ecb627e01c9e2911f9b388167231c23a114946946d046f4e9535118/wadler_lindig-0.1.6.tar.gz", hash = "sha256:8b6adad9718291a7d82fb088a596b93659ce2346321ca76819810affbc66102b", size = 15812, upload-time = "2025-05-14T22:26:16.012Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/d1/9a/937038f3efc70871fb26b0ee6148efcfcfb96643c517c2aaddd7ed07ad76/wadler_lindig-0.1.6-py3-none-any.whl", hash = "sha256:d707f63994c7d3e1e125e7fb7e196f4adb6f80f4a11beb955c6da937754026a3", size = 20483, upload-time = "2025-05-14T22:26:14.574Z" }, -] - -[[package]] -name = "watchdog" -version = "6.0.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/db/7d/7f3d619e951c88ed75c6037b246ddcf2d322812ee8ea189be89511721d54/watchdog-6.0.0.tar.gz", hash = "sha256:9ddf7c82fda3ae8e24decda1338ede66e1c99883db93711d8fb941eaa2d8c282", size = 131220, upload-time = "2024-11-01T14:07:13.037Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/0c/56/90994d789c61df619bfc5ce2ecdabd5eeff564e1eb47512bd01b5e019569/watchdog-6.0.0-cp310-cp310-macosx_10_9_universal2.whl", hash = "sha256:d1cdb490583ebd691c012b3d6dae011000fe42edb7a82ece80965b42abd61f26", size = 96390, upload-time = "2024-11-01T14:06:24.793Z" }, - { url = "https://files.pythonhosted.org/packages/55/46/9a67ee697342ddf3c6daa97e3a587a56d6c4052f881ed926a849fcf7371c/watchdog-6.0.0-cp310-cp310-macosx_10_9_x86_64.whl", hash = "sha256:bc64ab3bdb6a04d69d4023b29422170b74681784ffb9463ed4870cf2f3e66112", size = 88389, upload-time = "2024-11-01T14:06:27.112Z" }, - { url = "https://files.pythonhosted.org/packages/44/65/91b0985747c52064d8701e1075eb96f8c40a79df889e59a399453adfb882/watchdog-6.0.0-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:c897ac1b55c5a1461e16dae288d22bb2e412ba9807df8397a635d88f671d36c3", size = 89020, upload-time = "2024-11-01T14:06:29.876Z" }, - { url = "https://files.pythonhosted.org/packages/e0/24/d9be5cd6642a6aa68352ded4b4b10fb0d7889cb7f45814fb92cecd35f101/watchdog-6.0.0-cp311-cp311-macosx_10_9_universal2.whl", hash = "sha256:6eb11feb5a0d452ee41f824e271ca311a09e250441c262ca2fd7ebcf2461a06c", size = 96393, upload-time = "2024-11-01T14:06:31.756Z" }, - { url = "https://files.pythonhosted.org/packages/63/7a/6013b0d8dbc56adca7fdd4f0beed381c59f6752341b12fa0886fa7afc78b/watchdog-6.0.0-cp311-cp311-macosx_10_9_x86_64.whl", hash = "sha256:ef810fbf7b781a5a593894e4f439773830bdecb885e6880d957d5b9382a960d2", size = 88392, upload-time = "2024-11-01T14:06:32.99Z" }, - { url = "https://files.pythonhosted.org/packages/d1/40/b75381494851556de56281e053700e46bff5b37bf4c7267e858640af5a7f/watchdog-6.0.0-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:afd0fe1b2270917c5e23c2a65ce50c2a4abb63daafb0d419fde368e272a76b7c", size = 89019, upload-time = "2024-11-01T14:06:34.963Z" }, - { url = "https://files.pythonhosted.org/packages/39/ea/3930d07dafc9e286ed356a679aa02d777c06e9bfd1164fa7c19c288a5483/watchdog-6.0.0-cp312-cp312-macosx_10_13_universal2.whl", hash = "sha256:bdd4e6f14b8b18c334febb9c4425a878a2ac20efd1e0b231978e7b150f92a948", size = 96471, upload-time = "2024-11-01T14:06:37.745Z" }, - { url = "https://files.pythonhosted.org/packages/12/87/48361531f70b1f87928b045df868a9fd4e253d9ae087fa4cf3f7113be363/watchdog-6.0.0-cp312-cp312-macosx_10_13_x86_64.whl", hash = "sha256:c7c15dda13c4eb00d6fb6fc508b3c0ed88b9d5d374056b239c4ad1611125c860", size = 88449, upload-time = "2024-11-01T14:06:39.748Z" }, - { url = "https://files.pythonhosted.org/packages/5b/7e/8f322f5e600812e6f9a31b75d242631068ca8f4ef0582dd3ae6e72daecc8/watchdog-6.0.0-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:6f10cb2d5902447c7d0da897e2c6768bca89174d0c6e1e30abec5421af97a5b0", size = 89054, upload-time = "2024-11-01T14:06:41.009Z" }, - { url = "https://files.pythonhosted.org/packages/68/98/b0345cabdce2041a01293ba483333582891a3bd5769b08eceb0d406056ef/watchdog-6.0.0-cp313-cp313-macosx_10_13_universal2.whl", hash = "sha256:490ab2ef84f11129844c23fb14ecf30ef3d8a6abafd3754a6f75ca1e6654136c", size = 96480, upload-time = "2024-11-01T14:06:42.952Z" }, - { url = "https://files.pythonhosted.org/packages/85/83/cdf13902c626b28eedef7ec4f10745c52aad8a8fe7eb04ed7b1f111ca20e/watchdog-6.0.0-cp313-cp313-macosx_10_13_x86_64.whl", hash = "sha256:76aae96b00ae814b181bb25b1b98076d5fc84e8a53cd8885a318b42b6d3a5134", size = 88451, upload-time = "2024-11-01T14:06:45.084Z" }, - { url = "https://files.pythonhosted.org/packages/fe/c4/225c87bae08c8b9ec99030cd48ae9c4eca050a59bf5c2255853e18c87b50/watchdog-6.0.0-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:a175f755fc2279e0b7312c0035d52e27211a5bc39719dd529625b1930917345b", size = 89057, upload-time = "2024-11-01T14:06:47.324Z" }, - { url = "https://files.pythonhosted.org/packages/30/ad/d17b5d42e28a8b91f8ed01cb949da092827afb9995d4559fd448d0472763/watchdog-6.0.0-pp310-pypy310_pp73-macosx_10_15_x86_64.whl", hash = "sha256:c7ac31a19f4545dd92fc25d200694098f42c9a8e391bc00bdd362c5736dbf881", size = 87902, upload-time = "2024-11-01T14:06:53.119Z" }, - { url = "https://files.pythonhosted.org/packages/5c/ca/c3649991d140ff6ab67bfc85ab42b165ead119c9e12211e08089d763ece5/watchdog-6.0.0-pp310-pypy310_pp73-macosx_11_0_arm64.whl", hash = "sha256:9513f27a1a582d9808cf21a07dae516f0fab1cf2d7683a742c498b93eedabb11", size = 88380, upload-time = "2024-11-01T14:06:55.19Z" }, - { url = "https://files.pythonhosted.org/packages/a9/c7/ca4bf3e518cb57a686b2feb4f55a1892fd9a3dd13f470fca14e00f80ea36/watchdog-6.0.0-py3-none-manylinux2014_aarch64.whl", hash = "sha256:7607498efa04a3542ae3e05e64da8202e58159aa1fa4acddf7678d34a35d4f13", size = 79079, upload-time = "2024-11-01T14:06:59.472Z" }, - { url = "https://files.pythonhosted.org/packages/5c/51/d46dc9332f9a647593c947b4b88e2381c8dfc0942d15b8edc0310fa4abb1/watchdog-6.0.0-py3-none-manylinux2014_armv7l.whl", hash = "sha256:9041567ee8953024c83343288ccc458fd0a2d811d6a0fd68c4c22609e3490379", size = 79078, upload-time = "2024-11-01T14:07:01.431Z" }, - { url = "https://files.pythonhosted.org/packages/d4/57/04edbf5e169cd318d5f07b4766fee38e825d64b6913ca157ca32d1a42267/watchdog-6.0.0-py3-none-manylinux2014_i686.whl", hash = "sha256:82dc3e3143c7e38ec49d61af98d6558288c415eac98486a5c581726e0737c00e", size = 79076, upload-time = "2024-11-01T14:07:02.568Z" }, - { url = "https://files.pythonhosted.org/packages/ab/cc/da8422b300e13cb187d2203f20b9253e91058aaf7db65b74142013478e66/watchdog-6.0.0-py3-none-manylinux2014_ppc64.whl", hash = "sha256:212ac9b8bf1161dc91bd09c048048a95ca3a4c4f5e5d4a7d1b1a7d5752a7f96f", size = 79077, upload-time = "2024-11-01T14:07:03.893Z" }, - { url = "https://files.pythonhosted.org/packages/2c/3b/b8964e04ae1a025c44ba8e4291f86e97fac443bca31de8bd98d3263d2fcf/watchdog-6.0.0-py3-none-manylinux2014_ppc64le.whl", hash = "sha256:e3df4cbb9a450c6d49318f6d14f4bbc80d763fa587ba46ec86f99f9e6876bb26", size = 79078, upload-time = "2024-11-01T14:07:05.189Z" }, - { url = "https://files.pythonhosted.org/packages/62/ae/a696eb424bedff7407801c257d4b1afda455fe40821a2be430e173660e81/watchdog-6.0.0-py3-none-manylinux2014_s390x.whl", hash = "sha256:2cce7cfc2008eb51feb6aab51251fd79b85d9894e98ba847408f662b3395ca3c", size = 79077, upload-time = "2024-11-01T14:07:06.376Z" }, - { url = "https://files.pythonhosted.org/packages/b5/e8/dbf020b4d98251a9860752a094d09a65e1b436ad181faf929983f697048f/watchdog-6.0.0-py3-none-manylinux2014_x86_64.whl", hash = "sha256:20ffe5b202af80ab4266dcd3e91aae72bf2da48c0d33bdb15c66658e685e94e2", size = 79078, upload-time = "2024-11-01T14:07:07.547Z" }, - { url = "https://files.pythonhosted.org/packages/07/f6/d0e5b343768e8bcb4cda79f0f2f55051bf26177ecd5651f84c07567461cf/watchdog-6.0.0-py3-none-win32.whl", hash = "sha256:07df1fdd701c5d4c8e55ef6cf55b8f0120fe1aef7ef39a1c6fc6bc2e606d517a", size = 79065, upload-time = "2024-11-01T14:07:09.525Z" }, - { url = "https://files.pythonhosted.org/packages/db/d9/c495884c6e548fce18a8f40568ff120bc3a4b7b99813081c8ac0c936fa64/watchdog-6.0.0-py3-none-win_amd64.whl", hash = "sha256:cbafb470cf848d93b5d013e2ecb245d4aa1c8fd0504e863ccefa32445359d680", size = 79070, upload-time = "2024-11-01T14:07:10.686Z" }, - { url = "https://files.pythonhosted.org/packages/33/e8/e40370e6d74ddba47f002a32919d91310d6074130fe4e17dabcafc15cbf1/watchdog-6.0.0-py3-none-win_ia64.whl", hash = "sha256:a1914259fa9e1454315171103c6a30961236f508b9b623eae470268bbcc6a22f", size = 79067, upload-time = "2024-11-01T14:07:11.845Z" }, -] - -[[package]] -name = "wcwidth" -version = "0.2.13" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/6c/63/53559446a878410fc5a5974feb13d31d78d752eb18aeba59c7fef1af7598/wcwidth-0.2.13.tar.gz", hash = "sha256:72ea0c06399eb286d978fdedb6923a9eb47e1c486ce63e9b4e64fc18303972b5", size = 101301, upload-time = "2024-01-06T02:10:57.829Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/fd/84/fd2ba7aafacbad3c4201d395674fc6348826569da3c0937e75505ead3528/wcwidth-0.2.13-py2.py3-none-any.whl", hash = "sha256:3da69048e4540d84af32131829ff948f1e022c1c6bdb8d6102117aac784f6859", size = 34166, upload-time = "2024-01-06T02:10:55.763Z" }, -] - -[[package]] -name = "websocket-client" -version = "1.8.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/e6/30/fba0d96b4b5fbf5948ed3f4681f7da2f9f64512e1d303f94b4cc174c24a5/websocket_client-1.8.0.tar.gz", hash = "sha256:3239df9f44da632f96012472805d40a23281a991027ce11d2f45a6f24ac4c3da", size = 54648, upload-time = "2024-04-23T22:16:16.976Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/5a/84/44687a29792a70e111c5c477230a72c4b957d88d16141199bf9acb7537a3/websocket_client-1.8.0-py3-none-any.whl", hash = "sha256:17b44cc997f5c498e809b22cdf2d9c7a9e71c02c8cc2b6c56e7c2d1239bfa526", size = 58826, upload-time = "2024-04-23T22:16:14.422Z" }, -] - -[[package]] -name = "wrapt" -version = "1.17.2" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/c3/fc/e91cc220803d7bc4db93fb02facd8461c37364151b8494762cc88b0fbcef/wrapt-1.17.2.tar.gz", hash = "sha256:41388e9d4d1522446fe79d3213196bd9e3b301a336965b9e27ca2788ebd122f3", size = 55531, upload-time = "2025-01-14T10:35:45.465Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/5a/d1/1daec934997e8b160040c78d7b31789f19b122110a75eca3d4e8da0049e1/wrapt-1.17.2-cp310-cp310-macosx_10_9_universal2.whl", hash = "sha256:3d57c572081fed831ad2d26fd430d565b76aa277ed1d30ff4d40670b1c0dd984", size = 53307, upload-time = "2025-01-14T10:33:13.616Z" }, - { url = "https://files.pythonhosted.org/packages/1b/7b/13369d42651b809389c1a7153baa01d9700430576c81a2f5c5e460df0ed9/wrapt-1.17.2-cp310-cp310-macosx_10_9_x86_64.whl", hash = "sha256:b5e251054542ae57ac7f3fba5d10bfff615b6c2fb09abeb37d2f1463f841ae22", size = 38486, upload-time = "2025-01-14T10:33:15.947Z" }, - { url = "https://files.pythonhosted.org/packages/62/bf/e0105016f907c30b4bd9e377867c48c34dc9c6c0c104556c9c9126bd89ed/wrapt-1.17.2-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:80dd7db6a7cb57ffbc279c4394246414ec99537ae81ffd702443335a61dbf3a7", size = 38777, upload-time = "2025-01-14T10:33:17.462Z" }, - { url = "https://files.pythonhosted.org/packages/27/70/0f6e0679845cbf8b165e027d43402a55494779295c4b08414097b258ac87/wrapt-1.17.2-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:0a6e821770cf99cc586d33833b2ff32faebdbe886bd6322395606cf55153246c", size = 83314, upload-time = "2025-01-14T10:33:21.282Z" }, - { url = "https://files.pythonhosted.org/packages/0f/77/0576d841bf84af8579124a93d216f55d6f74374e4445264cb378a6ed33eb/wrapt-1.17.2-cp310-cp310-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:b60fb58b90c6d63779cb0c0c54eeb38941bae3ecf7a73c764c52c88c2dcb9d72", size = 74947, upload-time = "2025-01-14T10:33:24.414Z" }, - { url = "https://files.pythonhosted.org/packages/90/ec/00759565518f268ed707dcc40f7eeec38637d46b098a1f5143bff488fe97/wrapt-1.17.2-cp310-cp310-manylinux_2_5_x86_64.manylinux1_x86_64.manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:b870b5df5b71d8c3359d21be8f0d6c485fa0ebdb6477dda51a1ea54a9b558061", size = 82778, upload-time = "2025-01-14T10:33:26.152Z" }, - { url = "https://files.pythonhosted.org/packages/f8/5a/7cffd26b1c607b0b0c8a9ca9d75757ad7620c9c0a9b4a25d3f8a1480fafc/wrapt-1.17.2-cp310-cp310-musllinux_1_2_aarch64.whl", hash = "sha256:4011d137b9955791f9084749cba9a367c68d50ab8d11d64c50ba1688c9b457f2", size = 81716, upload-time = "2025-01-14T10:33:27.372Z" }, - { url = "https://files.pythonhosted.org/packages/7e/09/dccf68fa98e862df7e6a60a61d43d644b7d095a5fc36dbb591bbd4a1c7b2/wrapt-1.17.2-cp310-cp310-musllinux_1_2_i686.whl", hash = "sha256:1473400e5b2733e58b396a04eb7f35f541e1fb976d0c0724d0223dd607e0f74c", size = 74548, upload-time = "2025-01-14T10:33:28.52Z" }, - { url = "https://files.pythonhosted.org/packages/b7/8e/067021fa3c8814952c5e228d916963c1115b983e21393289de15128e867e/wrapt-1.17.2-cp310-cp310-musllinux_1_2_x86_64.whl", hash = "sha256:3cedbfa9c940fdad3e6e941db7138e26ce8aad38ab5fe9dcfadfed9db7a54e62", size = 81334, upload-time = "2025-01-14T10:33:29.643Z" }, - { url = "https://files.pythonhosted.org/packages/4b/0d/9d4b5219ae4393f718699ca1c05f5ebc0c40d076f7e65fd48f5f693294fb/wrapt-1.17.2-cp310-cp310-win32.whl", hash = "sha256:582530701bff1dec6779efa00c516496968edd851fba224fbd86e46cc6b73563", size = 36427, upload-time = "2025-01-14T10:33:30.832Z" }, - { url = "https://files.pythonhosted.org/packages/72/6a/c5a83e8f61aec1e1aeef939807602fb880e5872371e95df2137142f5c58e/wrapt-1.17.2-cp310-cp310-win_amd64.whl", hash = "sha256:58705da316756681ad3c9c73fd15499aa4d8c69f9fd38dc8a35e06c12468582f", size = 38774, upload-time = "2025-01-14T10:33:32.897Z" }, - { url = "https://files.pythonhosted.org/packages/cd/f7/a2aab2cbc7a665efab072344a8949a71081eed1d2f451f7f7d2b966594a2/wrapt-1.17.2-cp311-cp311-macosx_10_9_universal2.whl", hash = "sha256:ff04ef6eec3eee8a5efef2401495967a916feaa353643defcc03fc74fe213b58", size = 53308, upload-time = "2025-01-14T10:33:33.992Z" }, - { url = "https://files.pythonhosted.org/packages/50/ff/149aba8365fdacef52b31a258c4dc1c57c79759c335eff0b3316a2664a64/wrapt-1.17.2-cp311-cp311-macosx_10_9_x86_64.whl", hash = "sha256:4db983e7bca53819efdbd64590ee96c9213894272c776966ca6306b73e4affda", size = 38488, upload-time = "2025-01-14T10:33:35.264Z" }, - { url = "https://files.pythonhosted.org/packages/65/46/5a917ce85b5c3b490d35c02bf71aedaa9f2f63f2d15d9949cc4ba56e8ba9/wrapt-1.17.2-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:9abc77a4ce4c6f2a3168ff34b1da9b0f311a8f1cfd694ec96b0603dff1c79438", size = 38776, upload-time = "2025-01-14T10:33:38.28Z" }, - { url = "https://files.pythonhosted.org/packages/ca/74/336c918d2915a4943501c77566db41d1bd6e9f4dbc317f356b9a244dfe83/wrapt-1.17.2-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:0b929ac182f5ace000d459c59c2c9c33047e20e935f8e39371fa6e3b85d56f4a", size = 83776, upload-time = "2025-01-14T10:33:40.678Z" }, - { url = "https://files.pythonhosted.org/packages/09/99/c0c844a5ccde0fe5761d4305485297f91d67cf2a1a824c5f282e661ec7ff/wrapt-1.17.2-cp311-cp311-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:f09b286faeff3c750a879d336fb6d8713206fc97af3adc14def0cdd349df6000", size = 75420, upload-time = "2025-01-14T10:33:41.868Z" }, - { url = "https://files.pythonhosted.org/packages/b4/b0/9fc566b0fe08b282c850063591a756057c3247b2362b9286429ec5bf1721/wrapt-1.17.2-cp311-cp311-manylinux_2_5_x86_64.manylinux1_x86_64.manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:1a7ed2d9d039bd41e889f6fb9364554052ca21ce823580f6a07c4ec245c1f5d6", size = 83199, upload-time = "2025-01-14T10:33:43.598Z" }, - { url = "https://files.pythonhosted.org/packages/9d/4b/71996e62d543b0a0bd95dda485219856def3347e3e9380cc0d6cf10cfb2f/wrapt-1.17.2-cp311-cp311-musllinux_1_2_aarch64.whl", hash = "sha256:129a150f5c445165ff941fc02ee27df65940fcb8a22a61828b1853c98763a64b", size = 82307, upload-time = "2025-01-14T10:33:48.499Z" }, - { url = "https://files.pythonhosted.org/packages/39/35/0282c0d8789c0dc9bcc738911776c762a701f95cfe113fb8f0b40e45c2b9/wrapt-1.17.2-cp311-cp311-musllinux_1_2_i686.whl", hash = "sha256:1fb5699e4464afe5c7e65fa51d4f99e0b2eadcc176e4aa33600a3df7801d6662", size = 75025, upload-time = "2025-01-14T10:33:51.191Z" }, - { url = "https://files.pythonhosted.org/packages/4f/6d/90c9fd2c3c6fee181feecb620d95105370198b6b98a0770cba090441a828/wrapt-1.17.2-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:9a2bce789a5ea90e51a02dfcc39e31b7f1e662bc3317979aa7e5538e3a034f72", size = 81879, upload-time = "2025-01-14T10:33:52.328Z" }, - { url = "https://files.pythonhosted.org/packages/8f/fa/9fb6e594f2ce03ef03eddbdb5f4f90acb1452221a5351116c7c4708ac865/wrapt-1.17.2-cp311-cp311-win32.whl", hash = "sha256:4afd5814270fdf6380616b321fd31435a462019d834f83c8611a0ce7484c7317", size = 36419, upload-time = "2025-01-14T10:33:53.551Z" }, - { url = "https://files.pythonhosted.org/packages/47/f8/fb1773491a253cbc123c5d5dc15c86041f746ed30416535f2a8df1f4a392/wrapt-1.17.2-cp311-cp311-win_amd64.whl", hash = "sha256:acc130bc0375999da18e3d19e5a86403667ac0c4042a094fefb7eec8ebac7cf3", size = 38773, upload-time = "2025-01-14T10:33:56.323Z" }, - { url = "https://files.pythonhosted.org/packages/a1/bd/ab55f849fd1f9a58ed7ea47f5559ff09741b25f00c191231f9f059c83949/wrapt-1.17.2-cp312-cp312-macosx_10_13_universal2.whl", hash = "sha256:d5e2439eecc762cd85e7bd37161d4714aa03a33c5ba884e26c81559817ca0925", size = 53799, upload-time = "2025-01-14T10:33:57.4Z" }, - { url = "https://files.pythonhosted.org/packages/53/18/75ddc64c3f63988f5a1d7e10fb204ffe5762bc663f8023f18ecaf31a332e/wrapt-1.17.2-cp312-cp312-macosx_10_13_x86_64.whl", hash = "sha256:3fc7cb4c1c744f8c05cd5f9438a3caa6ab94ce8344e952d7c45a8ed59dd88392", size = 38821, upload-time = "2025-01-14T10:33:59.334Z" }, - { url = "https://files.pythonhosted.org/packages/48/2a/97928387d6ed1c1ebbfd4efc4133a0633546bec8481a2dd5ec961313a1c7/wrapt-1.17.2-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:8fdbdb757d5390f7c675e558fd3186d590973244fab0c5fe63d373ade3e99d40", size = 38919, upload-time = "2025-01-14T10:34:04.093Z" }, - { url = "https://files.pythonhosted.org/packages/73/54/3bfe5a1febbbccb7a2f77de47b989c0b85ed3a6a41614b104204a788c20e/wrapt-1.17.2-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:5bb1d0dbf99411f3d871deb6faa9aabb9d4e744d67dcaaa05399af89d847a91d", size = 88721, upload-time = "2025-01-14T10:34:07.163Z" }, - { url = "https://files.pythonhosted.org/packages/25/cb/7262bc1b0300b4b64af50c2720ef958c2c1917525238d661c3e9a2b71b7b/wrapt-1.17.2-cp312-cp312-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:d18a4865f46b8579d44e4fe1e2bcbc6472ad83d98e22a26c963d46e4c125ef0b", size = 80899, upload-time = "2025-01-14T10:34:09.82Z" }, - { url = "https://files.pythonhosted.org/packages/2a/5a/04cde32b07a7431d4ed0553a76fdb7a61270e78c5fd5a603e190ac389f14/wrapt-1.17.2-cp312-cp312-manylinux_2_5_x86_64.manylinux1_x86_64.manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:bc570b5f14a79734437cb7b0500376b6b791153314986074486e0b0fa8d71d98", size = 89222, upload-time = "2025-01-14T10:34:11.258Z" }, - { url = "https://files.pythonhosted.org/packages/09/28/2e45a4f4771fcfb109e244d5dbe54259e970362a311b67a965555ba65026/wrapt-1.17.2-cp312-cp312-musllinux_1_2_aarch64.whl", hash = "sha256:6d9187b01bebc3875bac9b087948a2bccefe464a7d8f627cf6e48b1bbae30f82", size = 86707, upload-time = "2025-01-14T10:34:12.49Z" }, - { url = "https://files.pythonhosted.org/packages/c6/d2/dcb56bf5f32fcd4bd9aacc77b50a539abdd5b6536872413fd3f428b21bed/wrapt-1.17.2-cp312-cp312-musllinux_1_2_i686.whl", hash = "sha256:9e8659775f1adf02eb1e6f109751268e493c73716ca5761f8acb695e52a756ae", size = 79685, upload-time = "2025-01-14T10:34:15.043Z" }, - { url = "https://files.pythonhosted.org/packages/80/4e/eb8b353e36711347893f502ce91c770b0b0929f8f0bed2670a6856e667a9/wrapt-1.17.2-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:e8b2816ebef96d83657b56306152a93909a83f23994f4b30ad4573b00bd11bb9", size = 87567, upload-time = "2025-01-14T10:34:16.563Z" }, - { url = "https://files.pythonhosted.org/packages/17/27/4fe749a54e7fae6e7146f1c7d914d28ef599dacd4416566c055564080fe2/wrapt-1.17.2-cp312-cp312-win32.whl", hash = "sha256:468090021f391fe0056ad3e807e3d9034e0fd01adcd3bdfba977b6fdf4213ea9", size = 36672, upload-time = "2025-01-14T10:34:17.727Z" }, - { url = "https://files.pythonhosted.org/packages/15/06/1dbf478ea45c03e78a6a8c4be4fdc3c3bddea5c8de8a93bc971415e47f0f/wrapt-1.17.2-cp312-cp312-win_amd64.whl", hash = "sha256:ec89ed91f2fa8e3f52ae53cd3cf640d6feff92ba90d62236a81e4e563ac0e991", size = 38865, upload-time = "2025-01-14T10:34:19.577Z" }, - { url = "https://files.pythonhosted.org/packages/ce/b9/0ffd557a92f3b11d4c5d5e0c5e4ad057bd9eb8586615cdaf901409920b14/wrapt-1.17.2-cp313-cp313-macosx_10_13_universal2.whl", hash = "sha256:6ed6ffac43aecfe6d86ec5b74b06a5be33d5bb9243d055141e8cabb12aa08125", size = 53800, upload-time = "2025-01-14T10:34:21.571Z" }, - { url = "https://files.pythonhosted.org/packages/c0/ef/8be90a0b7e73c32e550c73cfb2fa09db62234227ece47b0e80a05073b375/wrapt-1.17.2-cp313-cp313-macosx_10_13_x86_64.whl", hash = "sha256:35621ae4c00e056adb0009f8e86e28eb4a41a4bfa8f9bfa9fca7d343fe94f998", size = 38824, upload-time = "2025-01-14T10:34:22.999Z" }, - { url = "https://files.pythonhosted.org/packages/36/89/0aae34c10fe524cce30fe5fc433210376bce94cf74d05b0d68344c8ba46e/wrapt-1.17.2-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:a604bf7a053f8362d27eb9fefd2097f82600b856d5abe996d623babd067b1ab5", size = 38920, upload-time = "2025-01-14T10:34:25.386Z" }, - { url = "https://files.pythonhosted.org/packages/3b/24/11c4510de906d77e0cfb5197f1b1445d4fec42c9a39ea853d482698ac681/wrapt-1.17.2-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:5cbabee4f083b6b4cd282f5b817a867cf0b1028c54d445b7ec7cfe6505057cf8", size = 88690, upload-time = "2025-01-14T10:34:28.058Z" }, - { url = "https://files.pythonhosted.org/packages/71/d7/cfcf842291267bf455b3e266c0c29dcb675b5540ee8b50ba1699abf3af45/wrapt-1.17.2-cp313-cp313-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:49703ce2ddc220df165bd2962f8e03b84c89fee2d65e1c24a7defff6f988f4d6", size = 80861, upload-time = "2025-01-14T10:34:29.167Z" }, - { url = "https://files.pythonhosted.org/packages/d5/66/5d973e9f3e7370fd686fb47a9af3319418ed925c27d72ce16b791231576d/wrapt-1.17.2-cp313-cp313-manylinux_2_5_x86_64.manylinux1_x86_64.manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:8112e52c5822fc4253f3901b676c55ddf288614dc7011634e2719718eaa187dc", size = 89174, upload-time = "2025-01-14T10:34:31.702Z" }, - { url = "https://files.pythonhosted.org/packages/a7/d3/8e17bb70f6ae25dabc1aaf990f86824e4fd98ee9cadf197054e068500d27/wrapt-1.17.2-cp313-cp313-musllinux_1_2_aarch64.whl", hash = "sha256:9fee687dce376205d9a494e9c121e27183b2a3df18037f89d69bd7b35bcf59e2", size = 86721, upload-time = "2025-01-14T10:34:32.91Z" }, - { url = "https://files.pythonhosted.org/packages/6f/54/f170dfb278fe1c30d0ff864513cff526d624ab8de3254b20abb9cffedc24/wrapt-1.17.2-cp313-cp313-musllinux_1_2_i686.whl", hash = "sha256:18983c537e04d11cf027fbb60a1e8dfd5190e2b60cc27bc0808e653e7b218d1b", size = 79763, upload-time = "2025-01-14T10:34:34.903Z" }, - { url = "https://files.pythonhosted.org/packages/4a/98/de07243751f1c4a9b15c76019250210dd3486ce098c3d80d5f729cba029c/wrapt-1.17.2-cp313-cp313-musllinux_1_2_x86_64.whl", hash = "sha256:703919b1633412ab54bcf920ab388735832fdcb9f9a00ae49387f0fe67dad504", size = 87585, upload-time = "2025-01-14T10:34:36.13Z" }, - { url = "https://files.pythonhosted.org/packages/f9/f0/13925f4bd6548013038cdeb11ee2cbd4e37c30f8bfd5db9e5a2a370d6e20/wrapt-1.17.2-cp313-cp313-win32.whl", hash = "sha256:abbb9e76177c35d4e8568e58650aa6926040d6a9f6f03435b7a522bf1c487f9a", size = 36676, upload-time = "2025-01-14T10:34:37.962Z" }, - { url = "https://files.pythonhosted.org/packages/bf/ae/743f16ef8c2e3628df3ddfd652b7d4c555d12c84b53f3d8218498f4ade9b/wrapt-1.17.2-cp313-cp313-win_amd64.whl", hash = "sha256:69606d7bb691b50a4240ce6b22ebb319c1cfb164e5f6569835058196e0f3a845", size = 38871, upload-time = "2025-01-14T10:34:39.13Z" }, - { url = "https://files.pythonhosted.org/packages/3d/bc/30f903f891a82d402ffb5fda27ec1d621cc97cb74c16fea0b6141f1d4e87/wrapt-1.17.2-cp313-cp313t-macosx_10_13_universal2.whl", hash = "sha256:4a721d3c943dae44f8e243b380cb645a709ba5bd35d3ad27bc2ed947e9c68192", size = 56312, upload-time = "2025-01-14T10:34:40.604Z" }, - { url = "https://files.pythonhosted.org/packages/8a/04/c97273eb491b5f1c918857cd26f314b74fc9b29224521f5b83f872253725/wrapt-1.17.2-cp313-cp313t-macosx_10_13_x86_64.whl", hash = "sha256:766d8bbefcb9e00c3ac3b000d9acc51f1b399513f44d77dfe0eb026ad7c9a19b", size = 40062, upload-time = "2025-01-14T10:34:45.011Z" }, - { url = "https://files.pythonhosted.org/packages/4e/ca/3b7afa1eae3a9e7fefe499db9b96813f41828b9fdb016ee836c4c379dadb/wrapt-1.17.2-cp313-cp313t-macosx_11_0_arm64.whl", hash = "sha256:e496a8ce2c256da1eb98bd15803a79bee00fc351f5dfb9ea82594a3f058309e0", size = 40155, upload-time = "2025-01-14T10:34:47.25Z" }, - { url = "https://files.pythonhosted.org/packages/89/be/7c1baed43290775cb9030c774bc53c860db140397047cc49aedaf0a15477/wrapt-1.17.2-cp313-cp313t-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:40d615e4fe22f4ad3528448c193b218e077656ca9ccb22ce2cb20db730f8d306", size = 113471, upload-time = "2025-01-14T10:34:50.934Z" }, - { url = "https://files.pythonhosted.org/packages/32/98/4ed894cf012b6d6aae5f5cc974006bdeb92f0241775addad3f8cd6ab71c8/wrapt-1.17.2-cp313-cp313t-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:a5aaeff38654462bc4b09023918b7f21790efb807f54c000a39d41d69cf552cb", size = 101208, upload-time = "2025-01-14T10:34:52.297Z" }, - { url = "https://files.pythonhosted.org/packages/ea/fd/0c30f2301ca94e655e5e057012e83284ce8c545df7661a78d8bfca2fac7a/wrapt-1.17.2-cp313-cp313t-manylinux_2_5_x86_64.manylinux1_x86_64.manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:9a7d15bbd2bc99e92e39f49a04653062ee6085c0e18b3b7512a4f2fe91f2d681", size = 109339, upload-time = "2025-01-14T10:34:53.489Z" }, - { url = "https://files.pythonhosted.org/packages/75/56/05d000de894c4cfcb84bcd6b1df6214297b8089a7bd324c21a4765e49b14/wrapt-1.17.2-cp313-cp313t-musllinux_1_2_aarch64.whl", hash = "sha256:e3890b508a23299083e065f435a492b5435eba6e304a7114d2f919d400888cc6", size = 110232, upload-time = "2025-01-14T10:34:55.327Z" }, - { url = "https://files.pythonhosted.org/packages/53/f8/c3f6b2cf9b9277fb0813418e1503e68414cd036b3b099c823379c9575e6d/wrapt-1.17.2-cp313-cp313t-musllinux_1_2_i686.whl", hash = "sha256:8c8b293cd65ad716d13d8dd3624e42e5a19cc2a2f1acc74b30c2c13f15cb61a6", size = 100476, upload-time = "2025-01-14T10:34:58.055Z" }, - { url = "https://files.pythonhosted.org/packages/a7/b1/0bb11e29aa5139d90b770ebbfa167267b1fc548d2302c30c8f7572851738/wrapt-1.17.2-cp313-cp313t-musllinux_1_2_x86_64.whl", hash = "sha256:4c82b8785d98cdd9fed4cac84d765d234ed3251bd6afe34cb7ac523cb93e8b4f", size = 106377, upload-time = "2025-01-14T10:34:59.3Z" }, - { url = "https://files.pythonhosted.org/packages/6a/e1/0122853035b40b3f333bbb25f1939fc1045e21dd518f7f0922b60c156f7c/wrapt-1.17.2-cp313-cp313t-win32.whl", hash = "sha256:13e6afb7fe71fe7485a4550a8844cc9ffbe263c0f1a1eea569bc7091d4898555", size = 37986, upload-time = "2025-01-14T10:35:00.498Z" }, - { url = "https://files.pythonhosted.org/packages/09/5e/1655cf481e079c1f22d0cabdd4e51733679932718dc23bf2db175f329b76/wrapt-1.17.2-cp313-cp313t-win_amd64.whl", hash = "sha256:eaf675418ed6b3b31c7a989fd007fa7c3be66ce14e5c3b27336383604c9da85c", size = 40750, upload-time = "2025-01-14T10:35:03.378Z" }, - { url = "https://files.pythonhosted.org/packages/2d/82/f56956041adef78f849db6b289b282e72b55ab8045a75abad81898c28d19/wrapt-1.17.2-py3-none-any.whl", hash = "sha256:b18f2d1533a71f069c7f82d524a52599053d4c7166e9dd374ae2136b7f40f7c8", size = 23594, upload-time = "2025-01-14T10:35:44.018Z" }, -] - -[[package]] -name = "yarl" -version = "1.20.1" -source = { registry = "https://pypi.org/simple" } -dependencies = [ - { name = "idna" }, - { name = "multidict" }, - { name = "propcache" }, -] -sdist = { url = "https://files.pythonhosted.org/packages/3c/fb/efaa23fa4e45537b827620f04cf8f3cd658b76642205162e072703a5b963/yarl-1.20.1.tar.gz", hash = "sha256:d017a4997ee50c91fd5466cef416231bb82177b93b029906cefc542ce14c35ac", size = 186428, upload-time = "2025-06-10T00:46:09.923Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/cb/65/7fed0d774abf47487c64be14e9223749468922817b5e8792b8a64792a1bb/yarl-1.20.1-cp310-cp310-macosx_10_9_universal2.whl", hash = "sha256:6032e6da6abd41e4acda34d75a816012717000fa6839f37124a47fcefc49bec4", size = 132910, upload-time = "2025-06-10T00:42:31.108Z" }, - { url = "https://files.pythonhosted.org/packages/8a/7b/988f55a52da99df9e56dc733b8e4e5a6ae2090081dc2754fc8fd34e60aa0/yarl-1.20.1-cp310-cp310-macosx_10_9_x86_64.whl", hash = "sha256:2c7b34d804b8cf9b214f05015c4fee2ebe7ed05cf581e7192c06555c71f4446a", size = 90644, upload-time = "2025-06-10T00:42:33.851Z" }, - { url = "https://files.pythonhosted.org/packages/f7/de/30d98f03e95d30c7e3cc093759982d038c8833ec2451001d45ef4854edc1/yarl-1.20.1-cp310-cp310-macosx_11_0_arm64.whl", hash = "sha256:0c869f2651cc77465f6cd01d938d91a11d9ea5d798738c1dc077f3de0b5e5fed", size = 89322, upload-time = "2025-06-10T00:42:35.688Z" }, - { url = "https://files.pythonhosted.org/packages/e0/7a/f2f314f5ebfe9200724b0b748de2186b927acb334cf964fd312eb86fc286/yarl-1.20.1-cp310-cp310-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:62915e6688eb4d180d93840cda4110995ad50c459bf931b8b3775b37c264af1e", size = 323786, upload-time = "2025-06-10T00:42:37.817Z" }, - { url = "https://files.pythonhosted.org/packages/15/3f/718d26f189db96d993d14b984ce91de52e76309d0fd1d4296f34039856aa/yarl-1.20.1-cp310-cp310-manylinux_2_17_armv7l.manylinux2014_armv7l.manylinux_2_31_armv7l.whl", hash = "sha256:41ebd28167bc6af8abb97fec1a399f412eec5fd61a3ccbe2305a18b84fb4ca73", size = 319627, upload-time = "2025-06-10T00:42:39.937Z" }, - { url = "https://files.pythonhosted.org/packages/a5/76/8fcfbf5fa2369157b9898962a4a7d96764b287b085b5b3d9ffae69cdefd1/yarl-1.20.1-cp310-cp310-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:21242b4288a6d56f04ea193adde174b7e347ac46ce6bc84989ff7c1b1ecea84e", size = 339149, upload-time = "2025-06-10T00:42:42.627Z" }, - { url = "https://files.pythonhosted.org/packages/3c/95/d7fc301cc4661785967acc04f54a4a42d5124905e27db27bb578aac49b5c/yarl-1.20.1-cp310-cp310-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:bea21cdae6c7eb02ba02a475f37463abfe0a01f5d7200121b03e605d6a0439f8", size = 333327, upload-time = "2025-06-10T00:42:44.842Z" }, - { url = "https://files.pythonhosted.org/packages/65/94/e21269718349582eee81efc5c1c08ee71c816bfc1585b77d0ec3f58089eb/yarl-1.20.1-cp310-cp310-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:1f8a891e4a22a89f5dde7862994485e19db246b70bb288d3ce73a34422e55b23", size = 326054, upload-time = "2025-06-10T00:42:47.149Z" }, - { url = "https://files.pythonhosted.org/packages/32/ae/8616d1f07853704523519f6131d21f092e567c5af93de7e3e94b38d7f065/yarl-1.20.1-cp310-cp310-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:dd803820d44c8853a109a34e3660e5a61beae12970da479cf44aa2954019bf70", size = 315035, upload-time = "2025-06-10T00:42:48.852Z" }, - { url = "https://files.pythonhosted.org/packages/48/aa/0ace06280861ef055855333707db5e49c6e3a08840a7ce62682259d0a6c0/yarl-1.20.1-cp310-cp310-musllinux_1_2_aarch64.whl", hash = "sha256:b982fa7f74c80d5c0c7b5b38f908971e513380a10fecea528091405f519b9ebb", size = 338962, upload-time = "2025-06-10T00:42:51.024Z" }, - { url = "https://files.pythonhosted.org/packages/20/52/1e9d0e6916f45a8fb50e6844f01cb34692455f1acd548606cbda8134cd1e/yarl-1.20.1-cp310-cp310-musllinux_1_2_armv7l.whl", hash = "sha256:33f29ecfe0330c570d997bcf1afd304377f2e48f61447f37e846a6058a4d33b2", size = 335399, upload-time = "2025-06-10T00:42:53.007Z" }, - { url = "https://files.pythonhosted.org/packages/f2/65/60452df742952c630e82f394cd409de10610481d9043aa14c61bf846b7b1/yarl-1.20.1-cp310-cp310-musllinux_1_2_i686.whl", hash = "sha256:835ab2cfc74d5eb4a6a528c57f05688099da41cf4957cf08cad38647e4a83b30", size = 338649, upload-time = "2025-06-10T00:42:54.964Z" }, - { url = "https://files.pythonhosted.org/packages/7b/f5/6cd4ff38dcde57a70f23719a838665ee17079640c77087404c3d34da6727/yarl-1.20.1-cp310-cp310-musllinux_1_2_ppc64le.whl", hash = "sha256:46b5e0ccf1943a9a6e766b2c2b8c732c55b34e28be57d8daa2b3c1d1d4009309", size = 358563, upload-time = "2025-06-10T00:42:57.28Z" }, - { url = "https://files.pythonhosted.org/packages/d1/90/c42eefd79d0d8222cb3227bdd51b640c0c1d0aa33fe4cc86c36eccba77d3/yarl-1.20.1-cp310-cp310-musllinux_1_2_s390x.whl", hash = "sha256:df47c55f7d74127d1b11251fe6397d84afdde0d53b90bedb46a23c0e534f9d24", size = 357609, upload-time = "2025-06-10T00:42:59.055Z" }, - { url = "https://files.pythonhosted.org/packages/03/c8/cea6b232cb4617514232e0f8a718153a95b5d82b5290711b201545825532/yarl-1.20.1-cp310-cp310-musllinux_1_2_x86_64.whl", hash = "sha256:76d12524d05841276b0e22573f28d5fbcb67589836772ae9244d90dd7d66aa13", size = 350224, upload-time = "2025-06-10T00:43:01.248Z" }, - { url = "https://files.pythonhosted.org/packages/ce/a3/eaa0ab9712f1f3d01faf43cf6f1f7210ce4ea4a7e9b28b489a2261ca8db9/yarl-1.20.1-cp310-cp310-win32.whl", hash = "sha256:6c4fbf6b02d70e512d7ade4b1f998f237137f1417ab07ec06358ea04f69134f8", size = 81753, upload-time = "2025-06-10T00:43:03.486Z" }, - { url = "https://files.pythonhosted.org/packages/8f/34/e4abde70a9256465fe31c88ed02c3f8502b7b5dead693a4f350a06413f28/yarl-1.20.1-cp310-cp310-win_amd64.whl", hash = "sha256:aef6c4d69554d44b7f9d923245f8ad9a707d971e6209d51279196d8e8fe1ae16", size = 86817, upload-time = "2025-06-10T00:43:05.231Z" }, - { url = "https://files.pythonhosted.org/packages/b1/18/893b50efc2350e47a874c5c2d67e55a0ea5df91186b2a6f5ac52eff887cd/yarl-1.20.1-cp311-cp311-macosx_10_9_universal2.whl", hash = "sha256:47ee6188fea634bdfaeb2cc420f5b3b17332e6225ce88149a17c413c77ff269e", size = 133833, upload-time = "2025-06-10T00:43:07.393Z" }, - { url = "https://files.pythonhosted.org/packages/89/ed/b8773448030e6fc47fa797f099ab9eab151a43a25717f9ac043844ad5ea3/yarl-1.20.1-cp311-cp311-macosx_10_9_x86_64.whl", hash = "sha256:d0f6500f69e8402d513e5eedb77a4e1818691e8f45e6b687147963514d84b44b", size = 91070, upload-time = "2025-06-10T00:43:09.538Z" }, - { url = "https://files.pythonhosted.org/packages/e3/e3/409bd17b1e42619bf69f60e4f031ce1ccb29bd7380117a55529e76933464/yarl-1.20.1-cp311-cp311-macosx_11_0_arm64.whl", hash = "sha256:7a8900a42fcdaad568de58887c7b2f602962356908eedb7628eaf6021a6e435b", size = 89818, upload-time = "2025-06-10T00:43:11.575Z" }, - { url = "https://files.pythonhosted.org/packages/f8/77/64d8431a4d77c856eb2d82aa3de2ad6741365245a29b3a9543cd598ed8c5/yarl-1.20.1-cp311-cp311-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:bad6d131fda8ef508b36be3ece16d0902e80b88ea7200f030a0f6c11d9e508d4", size = 347003, upload-time = "2025-06-10T00:43:14.088Z" }, - { url = "https://files.pythonhosted.org/packages/8d/d2/0c7e4def093dcef0bd9fa22d4d24b023788b0a33b8d0088b51aa51e21e99/yarl-1.20.1-cp311-cp311-manylinux_2_17_armv7l.manylinux2014_armv7l.manylinux_2_31_armv7l.whl", hash = "sha256:df018d92fe22aaebb679a7f89fe0c0f368ec497e3dda6cb81a567610f04501f1", size = 336537, upload-time = "2025-06-10T00:43:16.431Z" }, - { url = "https://files.pythonhosted.org/packages/f0/f3/fc514f4b2cf02cb59d10cbfe228691d25929ce8f72a38db07d3febc3f706/yarl-1.20.1-cp311-cp311-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:8f969afbb0a9b63c18d0feecf0db09d164b7a44a053e78a7d05f5df163e43833", size = 362358, upload-time = "2025-06-10T00:43:18.704Z" }, - { url = "https://files.pythonhosted.org/packages/ea/6d/a313ac8d8391381ff9006ac05f1d4331cee3b1efaa833a53d12253733255/yarl-1.20.1-cp311-cp311-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:812303eb4aa98e302886ccda58d6b099e3576b1b9276161469c25803a8db277d", size = 357362, upload-time = "2025-06-10T00:43:20.888Z" }, - { url = "https://files.pythonhosted.org/packages/00/70/8f78a95d6935a70263d46caa3dd18e1f223cf2f2ff2037baa01a22bc5b22/yarl-1.20.1-cp311-cp311-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:98c4a7d166635147924aa0bf9bfe8d8abad6fffa6102de9c99ea04a1376f91e8", size = 348979, upload-time = "2025-06-10T00:43:23.169Z" }, - { url = "https://files.pythonhosted.org/packages/cb/05/42773027968968f4f15143553970ee36ead27038d627f457cc44bbbeecf3/yarl-1.20.1-cp311-cp311-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:12e768f966538e81e6e7550f9086a6236b16e26cd964cf4df35349970f3551cf", size = 337274, upload-time = "2025-06-10T00:43:27.111Z" }, - { url = "https://files.pythonhosted.org/packages/05/be/665634aa196954156741ea591d2f946f1b78ceee8bb8f28488bf28c0dd62/yarl-1.20.1-cp311-cp311-musllinux_1_2_aarch64.whl", hash = "sha256:fe41919b9d899661c5c28a8b4b0acf704510b88f27f0934ac7a7bebdd8938d5e", size = 363294, upload-time = "2025-06-10T00:43:28.96Z" }, - { url = "https://files.pythonhosted.org/packages/eb/90/73448401d36fa4e210ece5579895731f190d5119c4b66b43b52182e88cd5/yarl-1.20.1-cp311-cp311-musllinux_1_2_armv7l.whl", hash = "sha256:8601bc010d1d7780592f3fc1bdc6c72e2b6466ea34569778422943e1a1f3c389", size = 358169, upload-time = "2025-06-10T00:43:30.701Z" }, - { url = "https://files.pythonhosted.org/packages/c3/b0/fce922d46dc1eb43c811f1889f7daa6001b27a4005587e94878570300881/yarl-1.20.1-cp311-cp311-musllinux_1_2_i686.whl", hash = "sha256:daadbdc1f2a9033a2399c42646fbd46da7992e868a5fe9513860122d7fe7a73f", size = 362776, upload-time = "2025-06-10T00:43:32.51Z" }, - { url = "https://files.pythonhosted.org/packages/f1/0d/b172628fce039dae8977fd22caeff3eeebffd52e86060413f5673767c427/yarl-1.20.1-cp311-cp311-musllinux_1_2_ppc64le.whl", hash = "sha256:03aa1e041727cb438ca762628109ef1333498b122e4c76dd858d186a37cec845", size = 381341, upload-time = "2025-06-10T00:43:34.543Z" }, - { url = "https://files.pythonhosted.org/packages/6b/9b/5b886d7671f4580209e855974fe1cecec409aa4a89ea58b8f0560dc529b1/yarl-1.20.1-cp311-cp311-musllinux_1_2_s390x.whl", hash = "sha256:642980ef5e0fa1de5fa96d905c7e00cb2c47cb468bfcac5a18c58e27dbf8d8d1", size = 379988, upload-time = "2025-06-10T00:43:36.489Z" }, - { url = "https://files.pythonhosted.org/packages/73/be/75ef5fd0fcd8f083a5d13f78fd3f009528132a1f2a1d7c925c39fa20aa79/yarl-1.20.1-cp311-cp311-musllinux_1_2_x86_64.whl", hash = "sha256:86971e2795584fe8c002356d3b97ef6c61862720eeff03db2a7c86b678d85b3e", size = 371113, upload-time = "2025-06-10T00:43:38.592Z" }, - { url = "https://files.pythonhosted.org/packages/50/4f/62faab3b479dfdcb741fe9e3f0323e2a7d5cd1ab2edc73221d57ad4834b2/yarl-1.20.1-cp311-cp311-win32.whl", hash = "sha256:597f40615b8d25812f14562699e287f0dcc035d25eb74da72cae043bb884d773", size = 81485, upload-time = "2025-06-10T00:43:41.038Z" }, - { url = "https://files.pythonhosted.org/packages/f0/09/d9c7942f8f05c32ec72cd5c8e041c8b29b5807328b68b4801ff2511d4d5e/yarl-1.20.1-cp311-cp311-win_amd64.whl", hash = "sha256:26ef53a9e726e61e9cd1cda6b478f17e350fb5800b4bd1cd9fe81c4d91cfeb2e", size = 86686, upload-time = "2025-06-10T00:43:42.692Z" }, - { url = "https://files.pythonhosted.org/packages/5f/9a/cb7fad7d73c69f296eda6815e4a2c7ed53fc70c2f136479a91c8e5fbdb6d/yarl-1.20.1-cp312-cp312-macosx_10_13_universal2.whl", hash = "sha256:bdcc4cd244e58593a4379fe60fdee5ac0331f8eb70320a24d591a3be197b94a9", size = 133667, upload-time = "2025-06-10T00:43:44.369Z" }, - { url = "https://files.pythonhosted.org/packages/67/38/688577a1cb1e656e3971fb66a3492501c5a5df56d99722e57c98249e5b8a/yarl-1.20.1-cp312-cp312-macosx_10_13_x86_64.whl", hash = "sha256:b29a2c385a5f5b9c7d9347e5812b6f7ab267193c62d282a540b4fc528c8a9d2a", size = 91025, upload-time = "2025-06-10T00:43:46.295Z" }, - { url = "https://files.pythonhosted.org/packages/50/ec/72991ae51febeb11a42813fc259f0d4c8e0507f2b74b5514618d8b640365/yarl-1.20.1-cp312-cp312-macosx_11_0_arm64.whl", hash = "sha256:1112ae8154186dfe2de4732197f59c05a83dc814849a5ced892b708033f40dc2", size = 89709, upload-time = "2025-06-10T00:43:48.22Z" }, - { url = "https://files.pythonhosted.org/packages/99/da/4d798025490e89426e9f976702e5f9482005c548c579bdae792a4c37769e/yarl-1.20.1-cp312-cp312-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:90bbd29c4fe234233f7fa2b9b121fb63c321830e5d05b45153a2ca68f7d310ee", size = 352287, upload-time = "2025-06-10T00:43:49.924Z" }, - { url = "https://files.pythonhosted.org/packages/1a/26/54a15c6a567aac1c61b18aa0f4b8aa2e285a52d547d1be8bf48abe2b3991/yarl-1.20.1-cp312-cp312-manylinux_2_17_armv7l.manylinux2014_armv7l.manylinux_2_31_armv7l.whl", hash = "sha256:680e19c7ce3710ac4cd964e90dad99bf9b5029372ba0c7cbfcd55e54d90ea819", size = 345429, upload-time = "2025-06-10T00:43:51.7Z" }, - { url = "https://files.pythonhosted.org/packages/d6/95/9dcf2386cb875b234353b93ec43e40219e14900e046bf6ac118f94b1e353/yarl-1.20.1-cp312-cp312-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:4a979218c1fdb4246a05efc2cc23859d47c89af463a90b99b7c56094daf25a16", size = 365429, upload-time = "2025-06-10T00:43:53.494Z" }, - { url = "https://files.pythonhosted.org/packages/91/b2/33a8750f6a4bc224242a635f5f2cff6d6ad5ba651f6edcccf721992c21a0/yarl-1.20.1-cp312-cp312-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:255b468adf57b4a7b65d8aad5b5138dce6a0752c139965711bdcb81bc370e1b6", size = 363862, upload-time = "2025-06-10T00:43:55.766Z" }, - { url = "https://files.pythonhosted.org/packages/98/28/3ab7acc5b51f4434b181b0cee8f1f4b77a65919700a355fb3617f9488874/yarl-1.20.1-cp312-cp312-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:a97d67108e79cfe22e2b430d80d7571ae57d19f17cda8bb967057ca8a7bf5bfd", size = 355616, upload-time = "2025-06-10T00:43:58.056Z" }, - { url = "https://files.pythonhosted.org/packages/36/a3/f666894aa947a371724ec7cd2e5daa78ee8a777b21509b4252dd7bd15e29/yarl-1.20.1-cp312-cp312-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:8570d998db4ddbfb9a590b185a0a33dbf8aafb831d07a5257b4ec9948df9cb0a", size = 339954, upload-time = "2025-06-10T00:43:59.773Z" }, - { url = "https://files.pythonhosted.org/packages/f1/81/5f466427e09773c04219d3450d7a1256138a010b6c9f0af2d48565e9ad13/yarl-1.20.1-cp312-cp312-musllinux_1_2_aarch64.whl", hash = "sha256:97c75596019baae7c71ccf1d8cc4738bc08134060d0adfcbe5642f778d1dca38", size = 365575, upload-time = "2025-06-10T00:44:02.051Z" }, - { url = "https://files.pythonhosted.org/packages/2e/e3/e4b0ad8403e97e6c9972dd587388940a032f030ebec196ab81a3b8e94d31/yarl-1.20.1-cp312-cp312-musllinux_1_2_armv7l.whl", hash = "sha256:1c48912653e63aef91ff988c5432832692ac5a1d8f0fb8a33091520b5bbe19ef", size = 365061, upload-time = "2025-06-10T00:44:04.196Z" }, - { url = "https://files.pythonhosted.org/packages/ac/99/b8a142e79eb86c926f9f06452eb13ecb1bb5713bd01dc0038faf5452e544/yarl-1.20.1-cp312-cp312-musllinux_1_2_i686.whl", hash = "sha256:4c3ae28f3ae1563c50f3d37f064ddb1511ecc1d5584e88c6b7c63cf7702a6d5f", size = 364142, upload-time = "2025-06-10T00:44:06.527Z" }, - { url = "https://files.pythonhosted.org/packages/34/f2/08ed34a4a506d82a1a3e5bab99ccd930a040f9b6449e9fd050320e45845c/yarl-1.20.1-cp312-cp312-musllinux_1_2_ppc64le.whl", hash = "sha256:c5e9642f27036283550f5f57dc6156c51084b458570b9d0d96100c8bebb186a8", size = 381894, upload-time = "2025-06-10T00:44:08.379Z" }, - { url = "https://files.pythonhosted.org/packages/92/f8/9a3fbf0968eac704f681726eff595dce9b49c8a25cd92bf83df209668285/yarl-1.20.1-cp312-cp312-musllinux_1_2_s390x.whl", hash = "sha256:2c26b0c49220d5799f7b22c6838409ee9bc58ee5c95361a4d7831f03cc225b5a", size = 383378, upload-time = "2025-06-10T00:44:10.51Z" }, - { url = "https://files.pythonhosted.org/packages/af/85/9363f77bdfa1e4d690957cd39d192c4cacd1c58965df0470a4905253b54f/yarl-1.20.1-cp312-cp312-musllinux_1_2_x86_64.whl", hash = "sha256:564ab3d517e3d01c408c67f2e5247aad4019dcf1969982aba3974b4093279004", size = 374069, upload-time = "2025-06-10T00:44:12.834Z" }, - { url = "https://files.pythonhosted.org/packages/35/99/9918c8739ba271dcd935400cff8b32e3cd319eaf02fcd023d5dcd487a7c8/yarl-1.20.1-cp312-cp312-win32.whl", hash = "sha256:daea0d313868da1cf2fac6b2d3a25c6e3a9e879483244be38c8e6a41f1d876a5", size = 81249, upload-time = "2025-06-10T00:44:14.731Z" }, - { url = "https://files.pythonhosted.org/packages/eb/83/5d9092950565481b413b31a23e75dd3418ff0a277d6e0abf3729d4d1ce25/yarl-1.20.1-cp312-cp312-win_amd64.whl", hash = "sha256:48ea7d7f9be0487339828a4de0360d7ce0efc06524a48e1810f945c45b813698", size = 86710, upload-time = "2025-06-10T00:44:16.716Z" }, - { url = "https://files.pythonhosted.org/packages/8a/e1/2411b6d7f769a07687acee88a062af5833cf1966b7266f3d8dfb3d3dc7d3/yarl-1.20.1-cp313-cp313-macosx_10_13_universal2.whl", hash = "sha256:0b5ff0fbb7c9f1b1b5ab53330acbfc5247893069e7716840c8e7d5bb7355038a", size = 131811, upload-time = "2025-06-10T00:44:18.933Z" }, - { url = "https://files.pythonhosted.org/packages/b2/27/584394e1cb76fb771371770eccad35de400e7b434ce3142c2dd27392c968/yarl-1.20.1-cp313-cp313-macosx_10_13_x86_64.whl", hash = "sha256:14f326acd845c2b2e2eb38fb1346c94f7f3b01a4f5c788f8144f9b630bfff9a3", size = 90078, upload-time = "2025-06-10T00:44:20.635Z" }, - { url = "https://files.pythonhosted.org/packages/bf/9a/3246ae92d4049099f52d9b0fe3486e3b500e29b7ea872d0f152966fc209d/yarl-1.20.1-cp313-cp313-macosx_11_0_arm64.whl", hash = "sha256:f60e4ad5db23f0b96e49c018596707c3ae89f5d0bd97f0ad3684bcbad899f1e7", size = 88748, upload-time = "2025-06-10T00:44:22.34Z" }, - { url = "https://files.pythonhosted.org/packages/a3/25/35afe384e31115a1a801fbcf84012d7a066d89035befae7c5d4284df1e03/yarl-1.20.1-cp313-cp313-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:49bdd1b8e00ce57e68ba51916e4bb04461746e794e7c4d4bbc42ba2f18297691", size = 349595, upload-time = "2025-06-10T00:44:24.314Z" }, - { url = "https://files.pythonhosted.org/packages/28/2d/8aca6cb2cabc8f12efcb82749b9cefecbccfc7b0384e56cd71058ccee433/yarl-1.20.1-cp313-cp313-manylinux_2_17_armv7l.manylinux2014_armv7l.manylinux_2_31_armv7l.whl", hash = "sha256:66252d780b45189975abfed839616e8fd2dbacbdc262105ad7742c6ae58f3e31", size = 342616, upload-time = "2025-06-10T00:44:26.167Z" }, - { url = "https://files.pythonhosted.org/packages/0b/e9/1312633d16b31acf0098d30440ca855e3492d66623dafb8e25b03d00c3da/yarl-1.20.1-cp313-cp313-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:59174e7332f5d153d8f7452a102b103e2e74035ad085f404df2e40e663a22b28", size = 361324, upload-time = "2025-06-10T00:44:27.915Z" }, - { url = "https://files.pythonhosted.org/packages/bc/a0/688cc99463f12f7669eec7c8acc71ef56a1521b99eab7cd3abb75af887b0/yarl-1.20.1-cp313-cp313-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:e3968ec7d92a0c0f9ac34d5ecfd03869ec0cab0697c91a45db3fbbd95fe1b653", size = 359676, upload-time = "2025-06-10T00:44:30.041Z" }, - { url = "https://files.pythonhosted.org/packages/af/44/46407d7f7a56e9a85a4c207724c9f2c545c060380718eea9088f222ba697/yarl-1.20.1-cp313-cp313-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:d1a4fbb50e14396ba3d375f68bfe02215d8e7bc3ec49da8341fe3157f59d2ff5", size = 352614, upload-time = "2025-06-10T00:44:32.171Z" }, - { url = "https://files.pythonhosted.org/packages/b1/91/31163295e82b8d5485d31d9cf7754d973d41915cadce070491778d9c9825/yarl-1.20.1-cp313-cp313-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:11a62c839c3a8eac2410e951301309426f368388ff2f33799052787035793b02", size = 336766, upload-time = "2025-06-10T00:44:34.494Z" }, - { url = "https://files.pythonhosted.org/packages/b4/8e/c41a5bc482121f51c083c4c2bcd16b9e01e1cf8729e380273a952513a21f/yarl-1.20.1-cp313-cp313-musllinux_1_2_aarch64.whl", hash = "sha256:041eaa14f73ff5a8986b4388ac6bb43a77f2ea09bf1913df7a35d4646db69e53", size = 364615, upload-time = "2025-06-10T00:44:36.856Z" }, - { url = "https://files.pythonhosted.org/packages/e3/5b/61a3b054238d33d70ea06ebba7e58597891b71c699e247df35cc984ab393/yarl-1.20.1-cp313-cp313-musllinux_1_2_armv7l.whl", hash = "sha256:377fae2fef158e8fd9d60b4c8751387b8d1fb121d3d0b8e9b0be07d1b41e83dc", size = 360982, upload-time = "2025-06-10T00:44:39.141Z" }, - { url = "https://files.pythonhosted.org/packages/df/a3/6a72fb83f8d478cb201d14927bc8040af901811a88e0ff2da7842dd0ed19/yarl-1.20.1-cp313-cp313-musllinux_1_2_i686.whl", hash = "sha256:1c92f4390e407513f619d49319023664643d3339bd5e5a56a3bebe01bc67ec04", size = 369792, upload-time = "2025-06-10T00:44:40.934Z" }, - { url = "https://files.pythonhosted.org/packages/7c/af/4cc3c36dfc7c077f8dedb561eb21f69e1e9f2456b91b593882b0b18c19dc/yarl-1.20.1-cp313-cp313-musllinux_1_2_ppc64le.whl", hash = "sha256:d25ddcf954df1754ab0f86bb696af765c5bfaba39b74095f27eececa049ef9a4", size = 382049, upload-time = "2025-06-10T00:44:42.854Z" }, - { url = "https://files.pythonhosted.org/packages/19/3a/e54e2c4752160115183a66dc9ee75a153f81f3ab2ba4bf79c3c53b33de34/yarl-1.20.1-cp313-cp313-musllinux_1_2_s390x.whl", hash = "sha256:909313577e9619dcff8c31a0ea2aa0a2a828341d92673015456b3ae492e7317b", size = 384774, upload-time = "2025-06-10T00:44:45.275Z" }, - { url = "https://files.pythonhosted.org/packages/9c/20/200ae86dabfca89060ec6447649f219b4cbd94531e425e50d57e5f5ac330/yarl-1.20.1-cp313-cp313-musllinux_1_2_x86_64.whl", hash = "sha256:793fd0580cb9664548c6b83c63b43c477212c0260891ddf86809e1c06c8b08f1", size = 374252, upload-time = "2025-06-10T00:44:47.31Z" }, - { url = "https://files.pythonhosted.org/packages/83/75/11ee332f2f516b3d094e89448da73d557687f7d137d5a0f48c40ff211487/yarl-1.20.1-cp313-cp313-win32.whl", hash = "sha256:468f6e40285de5a5b3c44981ca3a319a4b208ccc07d526b20b12aeedcfa654b7", size = 81198, upload-time = "2025-06-10T00:44:49.164Z" }, - { url = "https://files.pythonhosted.org/packages/ba/ba/39b1ecbf51620b40ab402b0fc817f0ff750f6d92712b44689c2c215be89d/yarl-1.20.1-cp313-cp313-win_amd64.whl", hash = "sha256:495b4ef2fea40596bfc0affe3837411d6aa3371abcf31aac0ccc4bdd64d4ef5c", size = 86346, upload-time = "2025-06-10T00:44:51.182Z" }, - { url = "https://files.pythonhosted.org/packages/43/c7/669c52519dca4c95153c8ad96dd123c79f354a376346b198f438e56ffeb4/yarl-1.20.1-cp313-cp313t-macosx_10_13_universal2.whl", hash = "sha256:f60233b98423aab21d249a30eb27c389c14929f47be8430efa7dbd91493a729d", size = 138826, upload-time = "2025-06-10T00:44:52.883Z" }, - { url = "https://files.pythonhosted.org/packages/6a/42/fc0053719b44f6ad04a75d7f05e0e9674d45ef62f2d9ad2c1163e5c05827/yarl-1.20.1-cp313-cp313t-macosx_10_13_x86_64.whl", hash = "sha256:6f3eff4cc3f03d650d8755c6eefc844edde99d641d0dcf4da3ab27141a5f8ddf", size = 93217, upload-time = "2025-06-10T00:44:54.658Z" }, - { url = "https://files.pythonhosted.org/packages/4f/7f/fa59c4c27e2a076bba0d959386e26eba77eb52ea4a0aac48e3515c186b4c/yarl-1.20.1-cp313-cp313t-macosx_11_0_arm64.whl", hash = "sha256:69ff8439d8ba832d6bed88af2c2b3445977eba9a4588b787b32945871c2444e3", size = 92700, upload-time = "2025-06-10T00:44:56.784Z" }, - { url = "https://files.pythonhosted.org/packages/2f/d4/062b2f48e7c93481e88eff97a6312dca15ea200e959f23e96d8ab898c5b8/yarl-1.20.1-cp313-cp313t-manylinux_2_17_aarch64.manylinux2014_aarch64.whl", hash = "sha256:3cf34efa60eb81dd2645a2e13e00bb98b76c35ab5061a3989c7a70f78c85006d", size = 347644, upload-time = "2025-06-10T00:44:59.071Z" }, - { url = "https://files.pythonhosted.org/packages/89/47/78b7f40d13c8f62b499cc702fdf69e090455518ae544c00a3bf4afc9fc77/yarl-1.20.1-cp313-cp313t-manylinux_2_17_armv7l.manylinux2014_armv7l.manylinux_2_31_armv7l.whl", hash = "sha256:8e0fe9364ad0fddab2688ce72cb7a8e61ea42eff3c7caeeb83874a5d479c896c", size = 323452, upload-time = "2025-06-10T00:45:01.605Z" }, - { url = "https://files.pythonhosted.org/packages/eb/2b/490d3b2dc66f52987d4ee0d3090a147ea67732ce6b4d61e362c1846d0d32/yarl-1.20.1-cp313-cp313t-manylinux_2_17_ppc64le.manylinux2014_ppc64le.whl", hash = "sha256:8f64fbf81878ba914562c672024089e3401974a39767747691c65080a67b18c1", size = 346378, upload-time = "2025-06-10T00:45:03.946Z" }, - { url = "https://files.pythonhosted.org/packages/66/ad/775da9c8a94ce925d1537f939a4f17d782efef1f973039d821cbe4bcc211/yarl-1.20.1-cp313-cp313t-manylinux_2_17_s390x.manylinux2014_s390x.whl", hash = "sha256:f6342d643bf9a1de97e512e45e4b9560a043347e779a173250824f8b254bd5ce", size = 353261, upload-time = "2025-06-10T00:45:05.992Z" }, - { url = "https://files.pythonhosted.org/packages/4b/23/0ed0922b47a4f5c6eb9065d5ff1e459747226ddce5c6a4c111e728c9f701/yarl-1.20.1-cp313-cp313t-manylinux_2_17_x86_64.manylinux2014_x86_64.whl", hash = "sha256:56dac5f452ed25eef0f6e3c6a066c6ab68971d96a9fb441791cad0efba6140d3", size = 335987, upload-time = "2025-06-10T00:45:08.227Z" }, - { url = "https://files.pythonhosted.org/packages/3e/49/bc728a7fe7d0e9336e2b78f0958a2d6b288ba89f25a1762407a222bf53c3/yarl-1.20.1-cp313-cp313t-manylinux_2_5_i686.manylinux1_i686.manylinux_2_17_i686.manylinux2014_i686.whl", hash = "sha256:c7d7f497126d65e2cad8dc5f97d34c27b19199b6414a40cb36b52f41b79014be", size = 329361, upload-time = "2025-06-10T00:45:10.11Z" }, - { url = "https://files.pythonhosted.org/packages/93/8f/b811b9d1f617c83c907e7082a76e2b92b655400e61730cd61a1f67178393/yarl-1.20.1-cp313-cp313t-musllinux_1_2_aarch64.whl", hash = "sha256:67e708dfb8e78d8a19169818eeb5c7a80717562de9051bf2413aca8e3696bf16", size = 346460, upload-time = "2025-06-10T00:45:12.055Z" }, - { url = "https://files.pythonhosted.org/packages/70/fd/af94f04f275f95da2c3b8b5e1d49e3e79f1ed8b6ceb0f1664cbd902773ff/yarl-1.20.1-cp313-cp313t-musllinux_1_2_armv7l.whl", hash = "sha256:595c07bc79af2494365cc96ddeb772f76272364ef7c80fb892ef9d0649586513", size = 334486, upload-time = "2025-06-10T00:45:13.995Z" }, - { url = "https://files.pythonhosted.org/packages/84/65/04c62e82704e7dd0a9b3f61dbaa8447f8507655fd16c51da0637b39b2910/yarl-1.20.1-cp313-cp313t-musllinux_1_2_i686.whl", hash = "sha256:7bdd2f80f4a7df852ab9ab49484a4dee8030023aa536df41f2d922fd57bf023f", size = 342219, upload-time = "2025-06-10T00:45:16.479Z" }, - { url = "https://files.pythonhosted.org/packages/91/95/459ca62eb958381b342d94ab9a4b6aec1ddec1f7057c487e926f03c06d30/yarl-1.20.1-cp313-cp313t-musllinux_1_2_ppc64le.whl", hash = "sha256:c03bfebc4ae8d862f853a9757199677ab74ec25424d0ebd68a0027e9c639a390", size = 350693, upload-time = "2025-06-10T00:45:18.399Z" }, - { url = "https://files.pythonhosted.org/packages/a6/00/d393e82dd955ad20617abc546a8f1aee40534d599ff555ea053d0ec9bf03/yarl-1.20.1-cp313-cp313t-musllinux_1_2_s390x.whl", hash = "sha256:344d1103e9c1523f32a5ed704d576172d2cabed3122ea90b1d4e11fe17c66458", size = 355803, upload-time = "2025-06-10T00:45:20.677Z" }, - { url = "https://files.pythonhosted.org/packages/9e/ed/c5fb04869b99b717985e244fd93029c7a8e8febdfcffa06093e32d7d44e7/yarl-1.20.1-cp313-cp313t-musllinux_1_2_x86_64.whl", hash = "sha256:88cab98aa4e13e1ade8c141daeedd300a4603b7132819c484841bb7af3edce9e", size = 341709, upload-time = "2025-06-10T00:45:23.221Z" }, - { url = "https://files.pythonhosted.org/packages/24/fd/725b8e73ac2a50e78a4534ac43c6addf5c1c2d65380dd48a9169cc6739a9/yarl-1.20.1-cp313-cp313t-win32.whl", hash = "sha256:b121ff6a7cbd4abc28985b6028235491941b9fe8fe226e6fdc539c977ea1739d", size = 86591, upload-time = "2025-06-10T00:45:25.793Z" }, - { url = "https://files.pythonhosted.org/packages/94/c3/b2e9f38bc3e11191981d57ea08cab2166e74ea770024a646617c9cddd9f6/yarl-1.20.1-cp313-cp313t-win_amd64.whl", hash = "sha256:541d050a355bbbc27e55d906bc91cb6fe42f96c01413dd0f4ed5a5240513874f", size = 93003, upload-time = "2025-06-10T00:45:27.752Z" }, - { url = "https://files.pythonhosted.org/packages/b4/2d/2345fce04cfd4bee161bf1e7d9cdc702e3e16109021035dbb24db654a622/yarl-1.20.1-py3-none-any.whl", hash = "sha256:83b8eb083fe4683c6115795d9fc1cfaf2cbbefb19b3a1cb68f6527460f483a77", size = 46542, upload-time = "2025-06-10T00:46:07.521Z" }, -] - -[[package]] -name = "zipp" -version = "3.23.0" -source = { registry = "https://pypi.org/simple" } -sdist = { url = "https://files.pythonhosted.org/packages/e3/02/0f2892c661036d50ede074e376733dca2ae7c6eb617489437771209d4180/zipp-3.23.0.tar.gz", hash = "sha256:a07157588a12518c9d4034df3fbbee09c814741a33ff63c05fa29d26a2404166", size = 25547, upload-time = "2025-06-08T17:06:39.4Z" } -wheels = [ - { url = "https://files.pythonhosted.org/packages/2e/54/647ade08bf0db230bfea292f893923872fd20be6ac6f53b2b936ba839d75/zipp-3.23.0-py3-none-any.whl", hash = "sha256:071652d6115ed432f5ce1d34c336c0adfd6a884660d1e9712a256d3d3bd4b14e", size = 10276, upload-time = "2025-06-08T17:06:38.034Z" }, -]