prefect-client 3.0.7__tar.gz → 3.0.9__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.7/src/prefect_client.egg-info → prefect-client-3.0.9}/PKG-INFO +1 -1
- {prefect-client-3.0.7 → prefect-client-3.0.9}/setup.cfg +1 -1
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_version.py +3 -3
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/context.py +13 -21
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/runner/runner.py +36 -35
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/settings.py +127 -196
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/task_worker.py +6 -1
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/collections.py +0 -70
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/dockerutils.py +1 -1
- {prefect-client-3.0.7 → prefect-client-3.0.9/src/prefect_client.egg-info}/PKG-INFO +1 -1
- {prefect-client-3.0.7 → prefect-client-3.0.9}/versioneer.py +1 -5
- {prefect-client-3.0.7 → prefect-client-3.0.9}/LICENSE +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/MANIFEST.in +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/README.md +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/requirements-client.txt +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/requirements-dev.txt +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/requirements.txt +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/setup.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/.prefectignore +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/_logging.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/compatibility/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/compatibility/deprecated.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/compatibility/migration.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/concurrency/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/concurrency/api.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/concurrency/calls.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/concurrency/cancellation.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/concurrency/event_loop.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/concurrency/inspection.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/concurrency/primitives.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/concurrency/services.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/concurrency/threads.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/concurrency/waiters.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/integrations.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/pydantic/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/pydantic/annotations/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/pydantic/annotations/pendulum.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/pydantic/schemas.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/pydantic/v1_schema.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/pydantic/v2_schema.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/pydantic/v2_validated_func.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/pytz.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/retries.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/schemas/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/schemas/bases.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/schemas/fields.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/schemas/serializers.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/_internal/schemas/validators.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/agent.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/artifacts.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/automations.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/blocks/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/blocks/abstract.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/blocks/core.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/blocks/fields.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/blocks/notifications.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/blocks/redis.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/blocks/system.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/blocks/webhook.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/cache_policies.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/client/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/client/base.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/client/cloud.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/client/collections.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/client/constants.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/client/orchestration.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/client/schemas/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/client/schemas/actions.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/client/schemas/filters.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/client/schemas/objects.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/client/schemas/responses.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/client/schemas/schedules.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/client/schemas/sorting.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/client/subscriptions.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/client/types/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/client/types/flexible_schedule_list.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/client/utilities.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/concurrency/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/concurrency/asyncio.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/concurrency/context.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/concurrency/events.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/concurrency/services.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/concurrency/sync.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/concurrency/v1/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/concurrency/v1/asyncio.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/concurrency/v1/context.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/concurrency/v1/events.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/concurrency/v1/services.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/concurrency/v1/sync.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/deployments/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/deployments/base.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/deployments/deployments.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/deployments/flow_runs.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/deployments/runner.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/deployments/schedules.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/deployments/steps/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/deployments/steps/core.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/deployments/steps/pull.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/deployments/steps/utility.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/docker/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/docker/docker_image.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/engine.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/events/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/events/actions.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/events/cli/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/events/cli/automations.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/events/clients.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/events/filters.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/events/related.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/events/schemas/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/events/schemas/automations.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/events/schemas/deployment_triggers.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/events/schemas/events.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/events/schemas/labelling.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/events/utilities.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/events/worker.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/exceptions.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/filesystems.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/flow_engine.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/flow_runs.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/flows.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/futures.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/infrastructure/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/infrastructure/base.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/infrastructure/provisioners/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/infrastructure/provisioners/cloud_run.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/infrastructure/provisioners/container_instance.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/infrastructure/provisioners/ecs.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/infrastructure/provisioners/modal.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/input/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/input/actions.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/input/run_input.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/locking/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/locking/filesystem.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/locking/memory.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/locking/protocol.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/logging/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/logging/configuration.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/logging/filters.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/logging/formatters.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/logging/handlers.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/logging/highlighters.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/logging/loggers.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/logging/logging.yml +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/main.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/plugins.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/profiles.toml +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/py.typed +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/records/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/records/base.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/records/filesystem.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/records/memory.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/records/result_store.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/results.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/runner/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/runner/server.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/runner/storage.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/runner/submit.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/runner/utils.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/runtime/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/runtime/deployment.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/runtime/flow_run.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/runtime/task_run.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/serializers.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/server/api/collections_data/views/aggregate-worker-metadata.json +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/server/api/static/prefect-logo-mark-gradient.png +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/states.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/task_engine.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/task_runners.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/task_runs.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/tasks.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/transactions.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/types/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/types/entrypoint.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/annotations.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/asyncutils.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/callables.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/compat.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/context.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/dispatch.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/engine.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/filesystem.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/hashing.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/importtools.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/math.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/names.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/processutils.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/pydantic.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/render_swagger.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/schema_tools/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/schema_tools/hydration.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/schema_tools/validation.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/services.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/slugify.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/templating.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/text.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/timeout.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/urls.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/utilities/visualization.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/variables.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/workers/__init__.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/workers/base.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/workers/block.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/workers/cloud.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/workers/process.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/workers/server.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect/workers/utilities.py +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect_client.egg-info/SOURCES.txt +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect_client.egg-info/dependency_links.txt +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/src/prefect_client.egg-info/requires.txt +0 -0
- {prefect-client-3.0.7 → prefect-client-3.0.9}/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-15T10:11:48-0400",
|
12
12
|
"dirty": true,
|
13
13
|
"error": null,
|
14
|
-
"full-revisionid": "
|
15
|
-
"version": "3.0.
|
14
|
+
"full-revisionid": "fd8cef25431a01f5b6ff2f031c2d53b3094797cb",
|
15
|
+
"version": "3.0.9"
|
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.
|
@@ -41,6 +41,7 @@ import subprocess
|
|
41
41
|
import sys
|
42
42
|
import tempfile
|
43
43
|
import threading
|
44
|
+
from contextlib import AsyncExitStack
|
44
45
|
from copy import deepcopy
|
45
46
|
from functools import partial
|
46
47
|
from pathlib import Path
|
@@ -185,6 +186,7 @@ class Runner:
|
|
185
186
|
self.query_seconds = query_seconds or PREFECT_RUNNER_POLL_FREQUENCY.value()
|
186
187
|
self._prefetch_seconds = prefetch_seconds
|
187
188
|
|
189
|
+
self._exit_stack = AsyncExitStack()
|
188
190
|
self._limiter: Optional[anyio.CapacityLimiter] = None
|
189
191
|
self._client = get_client()
|
190
192
|
self._submitting_flow_run_ids = set()
|
@@ -398,38 +400,37 @@ class Runner:
|
|
398
400
|
start_client_metrics_server()
|
399
401
|
|
400
402
|
async with self as runner:
|
401
|
-
|
402
|
-
|
403
|
-
|
404
|
-
|
405
|
-
|
406
|
-
|
407
|
-
|
408
|
-
|
409
|
-
|
410
|
-
jitter_range=0.3,
|
411
|
-
)
|
403
|
+
for storage in self._storage_objs:
|
404
|
+
if storage.pull_interval:
|
405
|
+
self._runs_task_group.start_soon(
|
406
|
+
partial(
|
407
|
+
critical_service_loop,
|
408
|
+
workload=storage.pull_code,
|
409
|
+
interval=storage.pull_interval,
|
410
|
+
run_once=run_once,
|
411
|
+
jitter_range=0.3,
|
412
412
|
)
|
413
|
-
else:
|
414
|
-
tg.start_soon(storage.pull_code)
|
415
|
-
tg.start_soon(
|
416
|
-
partial(
|
417
|
-
critical_service_loop,
|
418
|
-
workload=runner._get_and_submit_flow_runs,
|
419
|
-
interval=self.query_seconds,
|
420
|
-
run_once=run_once,
|
421
|
-
jitter_range=0.3,
|
422
413
|
)
|
414
|
+
else:
|
415
|
+
self._runs_task_group.start_soon(storage.pull_code)
|
416
|
+
self._runs_task_group.start_soon(
|
417
|
+
partial(
|
418
|
+
critical_service_loop,
|
419
|
+
workload=runner._get_and_submit_flow_runs,
|
420
|
+
interval=self.query_seconds,
|
421
|
+
run_once=run_once,
|
422
|
+
jitter_range=0.3,
|
423
423
|
)
|
424
|
-
|
425
|
-
|
426
|
-
|
427
|
-
|
428
|
-
|
429
|
-
|
430
|
-
|
431
|
-
|
424
|
+
)
|
425
|
+
self._runs_task_group.start_soon(
|
426
|
+
partial(
|
427
|
+
critical_service_loop,
|
428
|
+
workload=runner._check_for_cancelled_flow_runs,
|
429
|
+
interval=self.query_seconds * 2,
|
430
|
+
run_once=run_once,
|
431
|
+
jitter_range=0.3,
|
432
432
|
)
|
433
|
+
)
|
433
434
|
|
434
435
|
def execute_in_background(self, func, *args, **kwargs):
|
435
436
|
"""
|
@@ -1264,14 +1265,16 @@ class Runner:
|
|
1264
1265
|
if not hasattr(self, "_loop") or not self._loop:
|
1265
1266
|
self._loop = asyncio.get_event_loop()
|
1266
1267
|
|
1268
|
+
await self._exit_stack.__aenter__()
|
1269
|
+
|
1270
|
+
await self._exit_stack.enter_async_context(self._client)
|
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._exit_stack.enter_async_context(self._runs_task_group)
|
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
|
-
|
1273
|
-
await self._client.__aenter__()
|
1274
|
-
await self._runs_task_group.__aenter__()
|
1277
|
+
await self._exit_stack.enter_async_context(self._loops_task_group)
|
1275
1278
|
|
1276
1279
|
self.started = True
|
1277
1280
|
return self
|
@@ -1283,11 +1286,9 @@ class Runner:
|
|
1283
1286
|
self.started = False
|
1284
1287
|
for scope in self._scheduled_task_scopes:
|
1285
1288
|
scope.cancel()
|
1286
|
-
|
1287
|
-
await self._runs_task_group.__aexit__(*exc_info)
|
1288
|
-
if self._client:
|
1289
|
-
await self._client.__aexit__(*exc_info)
|
1289
|
+
await self._exit_stack.__aexit__(*exc_info)
|
1290
1290
|
shutil.rmtree(str(self._tmp_dir))
|
1291
|
+
del self._runs_task_group, self._loops_task_group
|
1291
1292
|
|
1292
1293
|
def __repr__(self):
|
1293
1294
|
return f"Runner(name={self.name!r})"
|