prefect-client 3.0.8__tar.gz → 3.0.10__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.8/src/prefect_client.egg-info → prefect-client-3.0.10}/PKG-INFO +1 -1
- {prefect-client-3.0.8 → prefect-client-3.0.10}/setup.cfg +1 -1
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_version.py +3 -3
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/context.py +13 -21
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/flows.py +1 -1
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/runner/runner.py +15 -8
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/settings.py +215 -149
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/task_worker.py +6 -1
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/collections.py +70 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/dockerutils.py +1 -1
- {prefect-client-3.0.8 → prefect-client-3.0.10/src/prefect_client.egg-info}/PKG-INFO +1 -1
- {prefect-client-3.0.8 → prefect-client-3.0.10}/versioneer.py +1 -5
- {prefect-client-3.0.8 → prefect-client-3.0.10}/LICENSE +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/MANIFEST.in +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/README.md +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/requirements-client.txt +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/requirements-dev.txt +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/requirements.txt +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/setup.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/.prefectignore +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/_logging.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/compatibility/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/compatibility/deprecated.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/compatibility/migration.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/concurrency/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/concurrency/api.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/concurrency/calls.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/concurrency/cancellation.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/concurrency/event_loop.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/concurrency/inspection.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/concurrency/primitives.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/concurrency/services.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/concurrency/threads.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/concurrency/waiters.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/integrations.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/pydantic/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/pydantic/annotations/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/pydantic/annotations/pendulum.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/pydantic/schemas.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/pydantic/v1_schema.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/pydantic/v2_schema.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/pydantic/v2_validated_func.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/pytz.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/retries.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/schemas/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/schemas/bases.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/schemas/fields.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/schemas/serializers.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/_internal/schemas/validators.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/agent.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/artifacts.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/automations.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/blocks/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/blocks/abstract.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/blocks/core.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/blocks/fields.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/blocks/notifications.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/blocks/redis.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/blocks/system.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/blocks/webhook.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/cache_policies.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/client/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/client/base.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/client/cloud.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/client/collections.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/client/constants.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/client/orchestration.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/client/schemas/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/client/schemas/actions.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/client/schemas/filters.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/client/schemas/objects.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/client/schemas/responses.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/client/schemas/schedules.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/client/schemas/sorting.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/client/subscriptions.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/client/types/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/client/types/flexible_schedule_list.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/client/utilities.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/concurrency/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/concurrency/asyncio.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/concurrency/context.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/concurrency/events.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/concurrency/services.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/concurrency/sync.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/concurrency/v1/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/concurrency/v1/asyncio.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/concurrency/v1/context.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/concurrency/v1/events.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/concurrency/v1/services.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/concurrency/v1/sync.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/deployments/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/deployments/base.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/deployments/deployments.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/deployments/flow_runs.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/deployments/runner.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/deployments/schedules.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/deployments/steps/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/deployments/steps/core.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/deployments/steps/pull.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/deployments/steps/utility.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/docker/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/docker/docker_image.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/engine.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/events/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/events/actions.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/events/cli/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/events/cli/automations.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/events/clients.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/events/filters.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/events/related.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/events/schemas/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/events/schemas/automations.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/events/schemas/deployment_triggers.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/events/schemas/events.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/events/schemas/labelling.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/events/utilities.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/events/worker.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/exceptions.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/filesystems.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/flow_engine.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/flow_runs.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/futures.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/infrastructure/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/infrastructure/base.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/infrastructure/provisioners/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/infrastructure/provisioners/cloud_run.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/infrastructure/provisioners/container_instance.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/infrastructure/provisioners/ecs.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/infrastructure/provisioners/modal.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/input/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/input/actions.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/input/run_input.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/locking/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/locking/filesystem.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/locking/memory.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/locking/protocol.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/logging/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/logging/configuration.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/logging/filters.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/logging/formatters.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/logging/handlers.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/logging/highlighters.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/logging/loggers.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/logging/logging.yml +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/main.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/plugins.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/profiles.toml +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/py.typed +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/records/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/records/base.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/records/filesystem.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/records/memory.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/records/result_store.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/results.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/runner/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/runner/server.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/runner/storage.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/runner/submit.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/runner/utils.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/runtime/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/runtime/deployment.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/runtime/flow_run.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/runtime/task_run.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/serializers.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/server/api/collections_data/views/aggregate-worker-metadata.json +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/server/api/static/prefect-logo-mark-gradient.png +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/states.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/task_engine.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/task_runners.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/task_runs.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/tasks.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/transactions.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/types/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/types/entrypoint.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/annotations.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/asyncutils.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/callables.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/compat.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/context.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/dispatch.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/engine.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/filesystem.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/hashing.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/importtools.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/math.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/names.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/processutils.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/pydantic.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/render_swagger.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/schema_tools/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/schema_tools/hydration.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/schema_tools/validation.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/services.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/slugify.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/templating.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/text.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/timeout.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/urls.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/utilities/visualization.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/variables.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/workers/__init__.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/workers/base.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/workers/block.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/workers/cloud.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/workers/process.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/workers/server.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect/workers/utilities.py +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect_client.egg-info/SOURCES.txt +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect_client.egg-info/dependency_links.txt +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect_client.egg-info/requires.txt +0 -0
- {prefect-client-3.0.8 → prefect-client-3.0.10}/src/prefect_client.egg-info/top_level.txt +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
|
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]+)*)?)$
|
@@ -8,11 +8,11 @@ import json
|
|
8
8
|
|
9
9
|
version_json = '''
|
10
10
|
{
|
11
|
-
"date": "2024-10-
|
11
|
+
"date": "2024-10-15T13:31:59-0500",
|
12
12
|
"dirty": true,
|
13
13
|
"error": null,
|
14
|
-
"full-revisionid": "
|
15
|
-
"version": "3.0.
|
14
|
+
"full-revisionid": "3aa2d89362c2fe8ee429f0c2cf7e623e34588029",
|
15
|
+
"version": "3.0.10"
|
16
16
|
}
|
17
17
|
''' # END VERSION_JSON
|
18
18
|
|
@@ -453,23 +453,6 @@ class SettingsContext(ContextModel):
|
|
453
453
|
def __hash__(self) -> int:
|
454
454
|
return hash(self.settings)
|
455
455
|
|
456
|
-
def __enter__(self):
|
457
|
-
"""
|
458
|
-
Upon entrance, we ensure the home directory for the profile exists.
|
459
|
-
"""
|
460
|
-
return_value = super().__enter__()
|
461
|
-
|
462
|
-
try:
|
463
|
-
prefect_home = self.settings.home
|
464
|
-
prefect_home.mkdir(mode=0o0700, exist_ok=True)
|
465
|
-
except OSError:
|
466
|
-
warnings.warn(
|
467
|
-
(f"Failed to create the Prefect home directory at {prefect_home}"),
|
468
|
-
stacklevel=2,
|
469
|
-
)
|
470
|
-
|
471
|
-
return return_value
|
472
|
-
|
473
456
|
@classmethod
|
474
457
|
def get(cls) -> "SettingsContext":
|
475
458
|
# Return the global context instead of `None` if no context exists
|
@@ -567,9 +550,9 @@ def tags(*new_tags: str) -> Generator[Set[str], None, None]:
|
|
567
550
|
{"a", "b", "c", "d", "e", "f"}
|
568
551
|
"""
|
569
552
|
current_tags = TagsContext.get().current_tags
|
570
|
-
|
571
|
-
with TagsContext(current_tags=
|
572
|
-
yield
|
553
|
+
_new_tags = current_tags.union(new_tags)
|
554
|
+
with TagsContext(current_tags=_new_tags):
|
555
|
+
yield _new_tags
|
573
556
|
|
574
557
|
|
575
558
|
@contextmanager
|
@@ -659,7 +642,16 @@ def root_settings_context():
|
|
659
642
|
)
|
660
643
|
active_name = "ephemeral"
|
661
644
|
|
662
|
-
|
645
|
+
if not (settings := Settings()).home.exists():
|
646
|
+
try:
|
647
|
+
settings.home.mkdir(mode=0o0700, exist_ok=True)
|
648
|
+
except OSError:
|
649
|
+
warnings.warn(
|
650
|
+
(f"Failed to create the Prefect home directory at {settings.home}"),
|
651
|
+
stacklevel=2,
|
652
|
+
)
|
653
|
+
|
654
|
+
return SettingsContext(profile=profiles[active_name], settings=settings)
|
663
655
|
|
664
656
|
# Note the above context is exited and the global settings context is used by
|
665
657
|
# an override in the `SettingsContext.get` method.
|
@@ -398,10 +398,12 @@ class Runner:
|
|
398
398
|
start_client_metrics_server()
|
399
399
|
|
400
400
|
async with self as runner:
|
401
|
-
|
401
|
+
# This task group isn't included in the exit stack because we want to
|
402
|
+
# stay in this function until the runner is told to stop
|
403
|
+
async with self._loops_task_group as loops_task_group:
|
402
404
|
for storage in self._storage_objs:
|
403
405
|
if storage.pull_interval:
|
404
|
-
|
406
|
+
loops_task_group.start_soon(
|
405
407
|
partial(
|
406
408
|
critical_service_loop,
|
407
409
|
workload=storage.pull_code,
|
@@ -411,8 +413,8 @@ class Runner:
|
|
411
413
|
)
|
412
414
|
)
|
413
415
|
else:
|
414
|
-
|
415
|
-
|
416
|
+
loops_task_group.start_soon(storage.pull_code)
|
417
|
+
loops_task_group.start_soon(
|
416
418
|
partial(
|
417
419
|
critical_service_loop,
|
418
420
|
workload=runner._get_and_submit_flow_runs,
|
@@ -421,7 +423,7 @@ class Runner:
|
|
421
423
|
jitter_range=0.3,
|
422
424
|
)
|
423
425
|
)
|
424
|
-
|
426
|
+
loops_task_group.start_soon(
|
425
427
|
partial(
|
426
428
|
critical_service_loop,
|
427
429
|
workload=runner._check_for_cancelled_flow_runs,
|
@@ -1264,15 +1266,15 @@ class Runner:
|
|
1264
1266
|
if not hasattr(self, "_loop") or not self._loop:
|
1265
1267
|
self._loop = asyncio.get_event_loop()
|
1266
1268
|
|
1269
|
+
await self._client.__aenter__()
|
1270
|
+
|
1267
1271
|
if not hasattr(self, "_runs_task_group") or not self._runs_task_group:
|
1268
1272
|
self._runs_task_group: anyio.abc.TaskGroup = anyio.create_task_group()
|
1273
|
+
await self._runs_task_group.__aenter__()
|
1269
1274
|
|
1270
1275
|
if not hasattr(self, "_loops_task_group") or not self._loops_task_group:
|
1271
1276
|
self._loops_task_group: anyio.abc.TaskGroup = anyio.create_task_group()
|
1272
1277
|
|
1273
|
-
await self._client.__aenter__()
|
1274
|
-
await self._runs_task_group.__aenter__()
|
1275
|
-
|
1276
1278
|
self.started = True
|
1277
1279
|
return self
|
1278
1280
|
|
@@ -1281,13 +1283,18 @@ class Runner:
|
|
1281
1283
|
if self.pause_on_shutdown:
|
1282
1284
|
await self._pause_schedules()
|
1283
1285
|
self.started = False
|
1286
|
+
|
1284
1287
|
for scope in self._scheduled_task_scopes:
|
1285
1288
|
scope.cancel()
|
1289
|
+
|
1286
1290
|
if self._runs_task_group:
|
1287
1291
|
await self._runs_task_group.__aexit__(*exc_info)
|
1292
|
+
|
1288
1293
|
if self._client:
|
1289
1294
|
await self._client.__aexit__(*exc_info)
|
1295
|
+
|
1290
1296
|
shutil.rmtree(str(self._tmp_dir))
|
1297
|
+
del self._runs_task_group, self._loops_task_group
|
1291
1298
|
|
1292
1299
|
def __repr__(self):
|
1293
1300
|
return f"Runner(name={self.name!r})"
|