prefect-client 3.0.5__tar.gz → 3.0.6__tar.gz
This diff represents the content of publicly available package versions that have been released to one of the supported registries. The information contained in this diff is provided for informational purposes only and reflects changes between package versions as they appear in their respective public registries.
- {prefect-client-3.0.5/src/prefect_client.egg-info → prefect-client-3.0.6}/PKG-INFO +1 -1
- {prefect-client-3.0.5 → prefect-client-3.0.6}/setup.cfg +1 -1
- {prefect-client-3.0.5 → prefect-client-3.0.6}/setup.py +2 -5
- prefect-client-3.0.6/src/prefect/_version.py +21 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/futures.py +13 -13
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/task_engine.py +2 -2
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/task_runners.py +2 -2
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/dockerutils.py +3 -2
- {prefect-client-3.0.5 → prefect-client-3.0.6/src/prefect_client.egg-info}/PKG-INFO +1 -1
- prefect-client-3.0.5/src/prefect/_version.py +0 -716
- {prefect-client-3.0.5 → prefect-client-3.0.6}/LICENSE +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/MANIFEST.in +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/README.md +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/requirements-client.txt +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/requirements-dev.txt +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/requirements.txt +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/.prefectignore +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/_logging.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/compatibility/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/compatibility/deprecated.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/compatibility/migration.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/concurrency/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/concurrency/api.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/concurrency/calls.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/concurrency/cancellation.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/concurrency/event_loop.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/concurrency/inspection.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/concurrency/primitives.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/concurrency/services.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/concurrency/threads.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/concurrency/waiters.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/integrations.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/pydantic/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/pydantic/annotations/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/pydantic/annotations/pendulum.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/pydantic/schemas.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/pydantic/v1_schema.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/pydantic/v2_schema.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/pydantic/v2_validated_func.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/pytz.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/retries.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/schemas/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/schemas/bases.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/schemas/fields.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/schemas/serializers.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/_internal/schemas/validators.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/agent.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/artifacts.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/automations.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/blocks/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/blocks/abstract.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/blocks/core.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/blocks/fields.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/blocks/notifications.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/blocks/redis.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/blocks/system.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/blocks/webhook.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/cache_policies.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/client/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/client/base.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/client/cloud.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/client/collections.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/client/constants.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/client/orchestration.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/client/schemas/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/client/schemas/actions.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/client/schemas/filters.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/client/schemas/objects.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/client/schemas/responses.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/client/schemas/schedules.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/client/schemas/sorting.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/client/subscriptions.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/client/types/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/client/types/flexible_schedule_list.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/client/utilities.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/concurrency/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/concurrency/asyncio.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/concurrency/context.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/concurrency/events.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/concurrency/services.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/concurrency/sync.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/concurrency/v1/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/concurrency/v1/asyncio.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/concurrency/v1/context.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/concurrency/v1/events.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/concurrency/v1/services.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/concurrency/v1/sync.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/context.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/deployments/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/deployments/base.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/deployments/deployments.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/deployments/flow_runs.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/deployments/runner.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/deployments/schedules.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/deployments/steps/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/deployments/steps/core.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/deployments/steps/pull.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/deployments/steps/utility.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/docker/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/docker/docker_image.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/engine.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/events/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/events/actions.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/events/cli/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/events/cli/automations.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/events/clients.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/events/filters.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/events/related.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/events/schemas/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/events/schemas/automations.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/events/schemas/deployment_triggers.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/events/schemas/events.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/events/schemas/labelling.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/events/utilities.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/events/worker.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/exceptions.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/filesystems.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/flow_engine.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/flow_runs.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/flows.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/infrastructure/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/infrastructure/base.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/infrastructure/provisioners/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/infrastructure/provisioners/cloud_run.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/infrastructure/provisioners/container_instance.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/infrastructure/provisioners/ecs.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/infrastructure/provisioners/modal.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/input/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/input/actions.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/input/run_input.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/locking/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/locking/filesystem.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/locking/memory.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/locking/protocol.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/logging/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/logging/configuration.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/logging/filters.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/logging/formatters.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/logging/handlers.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/logging/highlighters.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/logging/loggers.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/logging/logging.yml +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/main.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/plugins.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/profiles.toml +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/py.typed +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/records/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/records/base.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/records/filesystem.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/records/memory.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/records/result_store.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/results.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/runner/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/runner/runner.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/runner/server.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/runner/storage.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/runner/submit.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/runner/utils.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/runtime/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/runtime/deployment.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/runtime/flow_run.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/runtime/task_run.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/serializers.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/server/api/collections_data/views/aggregate-worker-metadata.json +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/server/api/static/prefect-logo-mark-gradient.png +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/settings.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/states.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/task_runs.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/task_worker.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/tasks.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/transactions.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/types/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/types/entrypoint.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/annotations.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/asyncutils.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/callables.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/collections.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/compat.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/context.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/dispatch.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/engine.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/filesystem.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/hashing.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/importtools.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/math.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/names.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/processutils.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/pydantic.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/render_swagger.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/schema_tools/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/schema_tools/hydration.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/schema_tools/validation.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/services.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/slugify.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/templating.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/text.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/timeout.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/urls.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/utilities/visualization.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/variables.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/workers/__init__.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/workers/base.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/workers/block.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/workers/cloud.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/workers/process.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/workers/server.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect/workers/utilities.py +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect_client.egg-info/SOURCES.txt +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect_client.egg-info/dependency_links.txt +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect_client.egg-info/requires.txt +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/src/prefect_client.egg-info/top_level.txt +0 -0
- {prefect-client-3.0.5 → prefect-client-3.0.6}/versioneer.py +0 -0
@@ -57,7 +57,7 @@ ignore_missing_imports = True
|
|
57
57
|
|
58
58
|
[versioneer]
|
59
59
|
VCS = git
|
60
|
-
style = pep440
|
60
|
+
style = pep440-pre
|
61
61
|
versionfile_source = src/prefect/_version.py
|
62
62
|
versionfile_build = prefect/_version.py
|
63
63
|
version_regex = ^(\d+\.\d+\.\d+(?:[a-zA-Z0-9]+(?:\.[a-zA-Z0-9]+)*)?)$
|
@@ -3,10 +3,6 @@ from setuptools import find_packages, setup
|
|
3
3
|
|
4
4
|
install_requires = open("requirements-client.txt").read().strip().split("\n")
|
5
5
|
|
6
|
-
# grab and use the first three version digits (the generated tag)
|
7
|
-
_version = versioneer.get_version().split(".")
|
8
|
-
client_version = ".".join(_version[:3]).split("+")[0]
|
9
|
-
|
10
6
|
setup(
|
11
7
|
# Package metadata
|
12
8
|
name="prefect-client",
|
@@ -23,7 +19,8 @@ setup(
|
|
23
19
|
long_description=open("README.md").read(),
|
24
20
|
long_description_content_type="text/markdown",
|
25
21
|
# Versioning
|
26
|
-
version=
|
22
|
+
version=versioneer.get_version(),
|
23
|
+
cmdclass=versioneer.get_cmdclass(),
|
27
24
|
# Package setup
|
28
25
|
packages=find_packages(where="src"),
|
29
26
|
package_dir={"": "src"},
|
@@ -0,0 +1,21 @@
|
|
1
|
+
|
2
|
+
# This file was generated by 'versioneer.py' (0.29) from
|
3
|
+
# revision-control system data, or from the parent directory name of an
|
4
|
+
# unpacked source archive. Distribution tarballs contain a pre-generated copy
|
5
|
+
# of this file.
|
6
|
+
|
7
|
+
import json
|
8
|
+
|
9
|
+
version_json = '''
|
10
|
+
{
|
11
|
+
"date": "2024-10-09T14:11:05-0400",
|
12
|
+
"dirty": true,
|
13
|
+
"error": null,
|
14
|
+
"full-revisionid": "aa5171d6067327a5390b820f414341b0a25df7e8",
|
15
|
+
"version": "3.0.6"
|
16
|
+
}
|
17
|
+
''' # END VERSION_JSON
|
18
|
+
|
19
|
+
|
20
|
+
def get_versions():
|
21
|
+
return json.loads(version_json)
|
@@ -116,7 +116,7 @@ class PrefectWrappedFuture(PrefectFuture, abc.ABC, Generic[R, F]):
|
|
116
116
|
"""The underlying future object wrapped by this Prefect future"""
|
117
117
|
return self._wrapped_future
|
118
118
|
|
119
|
-
def add_done_callback(self, fn: Callable[[PrefectFuture], None]):
|
119
|
+
def add_done_callback(self, fn: Callable[[PrefectFuture[R]], None]):
|
120
120
|
if not self._final_state:
|
121
121
|
|
122
122
|
def call_with_self(future):
|
@@ -193,7 +193,7 @@ class PrefectDistributedFuture(PrefectFuture[R]):
|
|
193
193
|
any task run scheduled in Prefect's API.
|
194
194
|
"""
|
195
195
|
|
196
|
-
done_callbacks: List[Callable[[PrefectFuture], None]] = []
|
196
|
+
done_callbacks: List[Callable[[PrefectFuture[R]], None]] = []
|
197
197
|
waiter = None
|
198
198
|
|
199
199
|
def wait(self, timeout: Optional[float] = None) -> None:
|
@@ -257,7 +257,7 @@ class PrefectDistributedFuture(PrefectFuture[R]):
|
|
257
257
|
raise_on_failure=raise_on_failure, fetch=True
|
258
258
|
)
|
259
259
|
|
260
|
-
def add_done_callback(self, fn: Callable[[PrefectFuture], None]):
|
260
|
+
def add_done_callback(self, fn: Callable[[PrefectFuture[R]], None]):
|
261
261
|
if self._final_state:
|
262
262
|
fn(self)
|
263
263
|
return
|
@@ -331,9 +331,9 @@ class PrefectFutureList(list, Iterator, Generic[F]):
|
|
331
331
|
|
332
332
|
|
333
333
|
def as_completed(
|
334
|
-
futures: List[PrefectFuture], timeout: Optional[float] = None
|
335
|
-
) -> Generator[PrefectFuture, None]:
|
336
|
-
unique_futures: Set[PrefectFuture] = set(futures)
|
334
|
+
futures: List[PrefectFuture[R]], timeout: Optional[float] = None
|
335
|
+
) -> Generator[PrefectFuture[R], None]:
|
336
|
+
unique_futures: Set[PrefectFuture[R]] = set(futures)
|
337
337
|
total_futures = len(unique_futures)
|
338
338
|
try:
|
339
339
|
with timeout_context(timeout):
|
@@ -373,7 +373,7 @@ def as_completed(
|
|
373
373
|
DoneAndNotDoneFutures = collections.namedtuple("DoneAndNotDoneFutures", "done not_done")
|
374
374
|
|
375
375
|
|
376
|
-
def wait(futures: List[PrefectFuture], timeout=None) -> DoneAndNotDoneFutures:
|
376
|
+
def wait(futures: List[PrefectFuture[R]], timeout=None) -> DoneAndNotDoneFutures:
|
377
377
|
"""
|
378
378
|
Wait for the futures in the given sequence to complete.
|
379
379
|
|
@@ -404,10 +404,10 @@ def wait(futures: List[PrefectFuture], timeout=None) -> DoneAndNotDoneFutures:
|
|
404
404
|
print(f"Not Done: {len(not_done)}")
|
405
405
|
```
|
406
406
|
"""
|
407
|
-
|
408
|
-
done = {f for f in
|
409
|
-
not_done =
|
410
|
-
if len(done) == len(
|
407
|
+
_futures = set(futures)
|
408
|
+
done = {f for f in _futures if f._final_state}
|
409
|
+
not_done = _futures - done
|
410
|
+
if len(done) == len(_futures):
|
411
411
|
return DoneAndNotDoneFutures(done, not_done)
|
412
412
|
try:
|
413
413
|
with timeout_context(timeout):
|
@@ -422,7 +422,7 @@ def wait(futures: List[PrefectFuture], timeout=None) -> DoneAndNotDoneFutures:
|
|
422
422
|
|
423
423
|
|
424
424
|
def resolve_futures_to_states(
|
425
|
-
expr: Union[PrefectFuture, Any],
|
425
|
+
expr: Union[PrefectFuture[R], Any],
|
426
426
|
) -> Union[State, Any]:
|
427
427
|
"""
|
428
428
|
Given a Python built-in collection, recursively find `PrefectFutures` and build a
|
@@ -431,7 +431,7 @@ def resolve_futures_to_states(
|
|
431
431
|
|
432
432
|
Unsupported object types will be returned without modification.
|
433
433
|
"""
|
434
|
-
futures: Set[PrefectFuture] = set()
|
434
|
+
futures: Set[PrefectFuture[R]] = set()
|
435
435
|
|
436
436
|
def _collect_futures(futures, expr, context):
|
437
437
|
# Expressions inside quotes should not be traversed
|
@@ -658,7 +658,7 @@ class SyncTaskRunEngine(BaseTaskRunEngine[P, R]):
|
|
658
658
|
|
659
659
|
with self.setup_run_context():
|
660
660
|
# setup_run_context might update the task run name, so log creation here
|
661
|
-
self.logger.
|
661
|
+
self.logger.debug(
|
662
662
|
f"Created task run {self.task_run.name!r} for task {self.task.name!r}"
|
663
663
|
)
|
664
664
|
yield self
|
@@ -1167,7 +1167,7 @@ class AsyncTaskRunEngine(BaseTaskRunEngine[P, R]):
|
|
1167
1167
|
|
1168
1168
|
async with self.setup_run_context():
|
1169
1169
|
# setup_run_context might update the task run name, so log creation here
|
1170
|
-
self.logger.
|
1170
|
+
self.logger.debug(
|
1171
1171
|
f"Created task run {self.task_run.name!r} for task {self.task.name!r}"
|
1172
1172
|
)
|
1173
1173
|
yield self
|
@@ -278,11 +278,11 @@ class ThreadPoolTaskRunner(TaskRunner[PrefectConcurrentFuture]):
|
|
278
278
|
|
279
279
|
flow_run_ctx = FlowRunContext.get()
|
280
280
|
if flow_run_ctx:
|
281
|
-
get_run_logger(flow_run_ctx).
|
281
|
+
get_run_logger(flow_run_ctx).debug(
|
282
282
|
f"Submitting task {task.name} to thread pool executor..."
|
283
283
|
)
|
284
284
|
else:
|
285
|
-
self.logger.
|
285
|
+
self.logger.debug(f"Submitting task {task.name} to thread pool executor...")
|
286
286
|
|
287
287
|
submit_kwargs = dict(
|
288
288
|
task=task,
|
@@ -22,6 +22,7 @@ from typing import (
|
|
22
22
|
from urllib.parse import urlsplit
|
23
23
|
|
24
24
|
import pendulum
|
25
|
+
from packaging.version import Version
|
25
26
|
from typing_extensions import Self
|
26
27
|
|
27
28
|
import prefect
|
@@ -55,8 +56,8 @@ def get_prefect_image_name(
|
|
55
56
|
minor level e.g. '3.9'.
|
56
57
|
flavor: An optional alternative image flavor to build, like 'conda'
|
57
58
|
"""
|
58
|
-
parsed_version = (prefect_version or prefect.__version__)
|
59
|
-
is_prod_build =
|
59
|
+
parsed_version = Version(prefect_version or prefect.__version__)
|
60
|
+
is_prod_build = parsed_version.post is None
|
60
61
|
prefect_version = (
|
61
62
|
parsed_version[0]
|
62
63
|
if is_prod_build
|