prefect-client 3.2.6__tar.gz → 3.2.7__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.2.6 → prefect_client-3.2.7}/PKG-INFO +1 -1
- prefect_client-3.2.7/src/prefect/_build_info.py +5 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/__init__.py +21 -2
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/events/schemas/automations.py +1 -1
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/flows.py +8 -2
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/logging/configuration.py +3 -1
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/server.py +9 -2
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/base.py +18 -3
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/root.py +5 -1
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/server/api.py +7 -1
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/server/database.py +14 -0
- prefect_client-3.2.6/src/prefect/_build_info.py +0 -5
- {prefect_client-3.2.6 → prefect_client-3.2.7}/.gitignore +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/LICENSE +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/README.md +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/pyproject.toml +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/.prefectignore +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/__main__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_experimental/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_experimental/bundles.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_experimental/lineage.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_experimental/sla/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_experimental/sla/client.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_experimental/sla/objects.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/_logging.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/compatibility/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/compatibility/async_dispatch.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/compatibility/deprecated.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/compatibility/migration.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/concurrency/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/concurrency/api.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/concurrency/calls.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/concurrency/cancellation.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/concurrency/event_loop.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/concurrency/inspection.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/concurrency/primitives.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/concurrency/services.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/concurrency/threads.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/concurrency/waiters.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/integrations.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/pydantic/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/pydantic/annotations/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/pydantic/annotations/pendulum.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/pydantic/schemas.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/pydantic/v1_schema.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/pydantic/v2_schema.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/pydantic/v2_validated_func.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/pytz.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/retries.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/schemas/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/schemas/bases.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/schemas/fields.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/schemas/serializers.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/schemas/validators.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_result_records.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_vendor/croniter/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_vendor/croniter/croniter.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/agent.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/artifacts.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/automations.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/blocks/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/blocks/abstract.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/blocks/core.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/blocks/fields.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/blocks/notifications.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/blocks/redis.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/blocks/system.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/blocks/webhook.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/cache_policies.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/base.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/cloud.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/collections.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/constants.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_artifacts/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_artifacts/client.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_automations/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_automations/client.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_blocks_documents/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_blocks_documents/client.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_blocks_schemas/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_blocks_schemas/client.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_blocks_types/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_blocks_types/client.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_concurrency_limits/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_concurrency_limits/client.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_deployments/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_deployments/client.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_flow_runs/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_flow_runs/client.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_flows/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_flows/client.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_logs/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_logs/client.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_variables/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_variables/client.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_work_pools/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_work_pools/client.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/base.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/routes.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/schemas/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/schemas/actions.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/schemas/filters.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/schemas/objects.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/schemas/responses.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/schemas/schedules.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/schemas/sorting.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/subscriptions.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/types/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/types/flexible_schedule_list.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/utilities.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/concurrency/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/concurrency/_asyncio.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/concurrency/_events.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/concurrency/asyncio.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/concurrency/context.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/concurrency/services.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/concurrency/sync.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/concurrency/v1/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/concurrency/v1/_asyncio.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/concurrency/v1/_events.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/concurrency/v1/asyncio.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/concurrency/v1/context.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/concurrency/v1/services.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/concurrency/v1/sync.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/context.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/deployments/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/deployments/base.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/deployments/deployments.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/deployments/flow_runs.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/deployments/runner.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/deployments/schedules.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/deployments/steps/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/deployments/steps/core.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/deployments/steps/pull.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/deployments/steps/utility.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/docker/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/docker/docker_image.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/engine.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/events/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/events/actions.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/events/cli/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/events/cli/automations.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/events/clients.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/events/filters.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/events/related.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/events/schemas/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/events/schemas/deployment_triggers.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/events/schemas/events.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/events/schemas/labelling.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/events/utilities.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/events/worker.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/exceptions.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/filesystems.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/flow_engine.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/flow_runs.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/futures.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/infrastructure/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/infrastructure/base.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/infrastructure/provisioners/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/infrastructure/provisioners/cloud_run.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/infrastructure/provisioners/coiled.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/infrastructure/provisioners/container_instance.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/infrastructure/provisioners/ecs.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/infrastructure/provisioners/modal.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/input/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/input/actions.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/input/run_input.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/locking/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/locking/filesystem.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/locking/memory.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/locking/protocol.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/logging/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/logging/filters.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/logging/formatters.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/logging/handlers.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/logging/highlighters.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/logging/loggers.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/logging/logging.yml +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/main.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/plugins.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/py.typed +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/results.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/runner/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/runner/runner.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/runner/server.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/runner/storage.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/runner/submit.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/runner/utils.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/runtime/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/runtime/deployment.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/runtime/flow_run.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/runtime/task_run.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/schedules.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/serializers.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/admin.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/artifacts.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/automations.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/block_capabilities.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/block_documents.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/block_schemas.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/block_types.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/clients.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/collections.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/collections_data/views/aggregate-worker-metadata.json +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/concurrency_limits.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/concurrency_limits_v2.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/csrf_token.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/dependencies.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/deployments.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/events.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/flow_run_notification_policies.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/flow_run_states.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/flow_runs.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/flows.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/logs.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/middleware.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/root.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/run_history.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/saved_searches.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/static/prefect-logo-mark-gradient.png +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/task_run_states.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/task_runs.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/task_workers.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/templates.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/ui/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/ui/flow_runs.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/ui/flows.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/ui/schemas.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/ui/task_runs.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/validation.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/variables.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/work_queues.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/server/api/workers.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/constants.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/context.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/legacy.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/api.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/cli.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/client.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/cloud.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/deployments.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/experiments.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/flows.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/internal.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/logging.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/results.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/runner.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/server/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/server/deployments.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/server/ephemeral.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/server/events.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/server/flow_run_graph.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/server/root.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/server/services.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/server/tasks.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/server/ui.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/tasks.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/testing.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/worker.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/profiles.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/profiles.toml +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/sources.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/states.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/task_engine.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/task_runners.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/task_runs.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/task_worker.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/tasks.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/telemetry/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/telemetry/bootstrap.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/telemetry/instrumentation.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/telemetry/logging.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/telemetry/processors.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/telemetry/run_telemetry.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/telemetry/services.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/transactions.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/types/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/types/_datetime.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/types/entrypoint.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/_deprecated.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/_engine.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/_git.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/annotations.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/asyncutils.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/callables.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/collections.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/compat.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/context.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/dispatch.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/dockerutils.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/engine.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/filesystem.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/generics.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/hashing.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/importtools.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/math.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/names.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/processutils.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/pydantic.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/render_swagger.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/schema_tools/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/schema_tools/hydration.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/schema_tools/validation.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/services.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/slugify.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/templating.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/text.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/timeout.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/urls.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/utilities/visualization.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/variables.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/workers/__init__.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/workers/base.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/workers/block.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/workers/cloud.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/workers/process.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/workers/server.py +0 -0
- {prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/workers/utilities.py +0 -0
@@ -81,6 +81,7 @@ from prefect.client.orchestration._blocks_types.client import (
|
|
81
81
|
|
82
82
|
import prefect
|
83
83
|
import prefect.exceptions
|
84
|
+
from prefect.logging.loggers import get_run_logger
|
84
85
|
import prefect.settings
|
85
86
|
import prefect.states
|
86
87
|
from prefect.client.constants import SERVER_API_VERSION
|
@@ -1182,8 +1183,17 @@ class PrefectClient(
|
|
1182
1183
|
if api_version.major != client_version.major:
|
1183
1184
|
raise RuntimeError(
|
1184
1185
|
f"Found incompatible versions: client: {client_version}, server: {api_version}. "
|
1185
|
-
|
1186
|
+
"Major versions must match."
|
1186
1187
|
)
|
1188
|
+
if api_version < client_version:
|
1189
|
+
warning_message = (
|
1190
|
+
"Your Prefect server is running an older version of Prefect than your client which may result in unexpected behavior. "
|
1191
|
+
f"Please upgrade your Prefect server from version {api_version} to version {client_version} or higher."
|
1192
|
+
)
|
1193
|
+
try:
|
1194
|
+
get_run_logger().warning(warning_message)
|
1195
|
+
except prefect.context.MissingContextError:
|
1196
|
+
self.logger.warning(warning_message)
|
1187
1197
|
|
1188
1198
|
async def __aenter__(self) -> Self:
|
1189
1199
|
"""
|
@@ -1523,8 +1533,17 @@ class SyncPrefectClient(
|
|
1523
1533
|
if api_version.major != client_version.major:
|
1524
1534
|
raise RuntimeError(
|
1525
1535
|
f"Found incompatible versions: client: {client_version}, server: {api_version}. "
|
1526
|
-
|
1536
|
+
"Major versions must match."
|
1527
1537
|
)
|
1538
|
+
if api_version < client_version:
|
1539
|
+
warning_message = (
|
1540
|
+
"Your Prefect server is running an older version of Prefect than your client which may result in unexpected behavior. "
|
1541
|
+
f"Please upgrade your Prefect server from version {api_version} to version {client_version} or higher."
|
1542
|
+
)
|
1543
|
+
try:
|
1544
|
+
get_run_logger().warning(warning_message)
|
1545
|
+
except prefect.context.MissingContextError:
|
1546
|
+
self.logger.warning(warning_message)
|
1528
1547
|
|
1529
1548
|
def set_task_run_name(self, task_run_id: UUID, name: str) -> httpx.Response:
|
1530
1549
|
task_run_data = TaskRunUpdate(name=name)
|
@@ -84,7 +84,7 @@ class Trigger(PrefectBaseModel, abc.ABC, extra="ignore"): # type: ignore[call-a
|
|
84
84
|
getattr(self, "name", None)
|
85
85
|
or f"Automation for deployment {self._deployment_id}"
|
86
86
|
),
|
87
|
-
description="",
|
87
|
+
description=getattr(self, "description", ""),
|
88
88
|
enabled=getattr(self, "enabled", True),
|
89
89
|
trigger=trigger,
|
90
90
|
actions=self.actions(),
|
@@ -2350,9 +2350,15 @@ async def load_flow_from_flow_run(
|
|
2350
2350
|
f"Running {len(deployment.pull_steps)} deployment pull step(s)"
|
2351
2351
|
)
|
2352
2352
|
|
2353
|
-
from prefect.deployments.steps.core import run_steps
|
2353
|
+
from prefect.deployments.steps.core import StepExecutionError, run_steps
|
2354
|
+
|
2355
|
+
try:
|
2356
|
+
output = await run_steps(deployment.pull_steps)
|
2357
|
+
except StepExecutionError as e:
|
2358
|
+
e = e.__cause__ or e
|
2359
|
+
run_logger.error(str(e))
|
2360
|
+
raise
|
2354
2361
|
|
2355
|
-
output = await run_steps(deployment.pull_steps)
|
2356
2362
|
if output.get("directory"):
|
2357
2363
|
run_logger.debug(f"Changing working directory to {output['directory']!r}")
|
2358
2364
|
os.chdir(output["directory"])
|
@@ -38,7 +38,9 @@ def load_logging_config(path: Path) -> dict[str, Any]:
|
|
38
38
|
warnings.filterwarnings("ignore", category=DeprecationWarning)
|
39
39
|
config = yaml.safe_load(
|
40
40
|
# Substitute settings into the template in format $SETTING / ${SETTING}
|
41
|
-
template.substitute(
|
41
|
+
template.substitute(
|
42
|
+
current_settings.to_environment_variables(include_aliases=True)
|
43
|
+
)
|
42
44
|
)
|
43
45
|
|
44
46
|
# Load overrides from the environment
|
@@ -55,6 +55,7 @@ from prefect.settings import (
|
|
55
55
|
PREFECT_DEBUG_MODE,
|
56
56
|
PREFECT_MEMO_STORE_PATH,
|
57
57
|
PREFECT_MEMOIZE_BLOCK_AUTO_REGISTRATION,
|
58
|
+
PREFECT_SERVER_API_BASE_PATH,
|
58
59
|
PREFECT_SERVER_EPHEMERAL_STARTUP_TIMEOUT_SECONDS,
|
59
60
|
PREFECT_UI_SERVE_BASE,
|
60
61
|
get_current_settings,
|
@@ -356,7 +357,10 @@ def create_api_app(
|
|
356
357
|
header_token = request.headers.get("Authorization")
|
357
358
|
|
358
359
|
# used for probes in k8s and such
|
359
|
-
if
|
360
|
+
if (
|
361
|
+
request.url.path.endswith(("health", "ready"))
|
362
|
+
and request.method.upper() == "GET"
|
363
|
+
):
|
360
364
|
return await call_next(request)
|
361
365
|
try:
|
362
366
|
if header_token is None:
|
@@ -691,7 +695,10 @@ def create_app(
|
|
691
695
|
name="static",
|
692
696
|
)
|
693
697
|
app.api_app = api_app
|
694
|
-
|
698
|
+
if PREFECT_SERVER_API_BASE_PATH:
|
699
|
+
app.mount(PREFECT_SERVER_API_BASE_PATH.value(), app=api_app, name="api")
|
700
|
+
else:
|
701
|
+
app.mount("/api", app=api_app, name="api")
|
695
702
|
app.mount("/", app=ui_app, name="ui")
|
696
703
|
|
697
704
|
def openapi():
|
@@ -92,6 +92,7 @@ class PrefectBaseSettings(BaseSettings):
|
|
92
92
|
self,
|
93
93
|
exclude_unset: bool = False,
|
94
94
|
include_secrets: bool = True,
|
95
|
+
include_aliases: bool = False,
|
95
96
|
) -> Dict[str, str]:
|
96
97
|
"""Convert the settings object to a dictionary of environment variables."""
|
97
98
|
env: Dict[str, Any] = self.model_dump(
|
@@ -105,12 +106,26 @@ class PrefectBaseSettings(BaseSettings):
|
|
105
106
|
child_env = child_settings.to_environment_variables(
|
106
107
|
exclude_unset=exclude_unset,
|
107
108
|
include_secrets=include_secrets,
|
109
|
+
include_aliases=include_aliases,
|
108
110
|
)
|
109
111
|
env_variables.update(child_env)
|
110
112
|
elif (value := env.get(key)) is not None:
|
111
|
-
|
112
|
-
|
113
|
-
|
113
|
+
validation_alias = self.model_fields[key].validation_alias
|
114
|
+
if include_aliases and validation_alias is not None:
|
115
|
+
if isinstance(validation_alias, AliasChoices):
|
116
|
+
for alias in validation_alias.choices:
|
117
|
+
if isinstance(alias, str):
|
118
|
+
env_variables[alias.upper()] = (
|
119
|
+
_to_environment_variable_value(value)
|
120
|
+
)
|
121
|
+
elif isinstance(validation_alias, str):
|
122
|
+
env_variables[validation_alias.upper()] = (
|
123
|
+
_to_environment_variable_value(value)
|
124
|
+
)
|
125
|
+
else:
|
126
|
+
env_variables[
|
127
|
+
f"{self.model_config.get('env_prefix')}{key.upper()}"
|
128
|
+
] = _to_environment_variable_value(value)
|
114
129
|
return env_variables
|
115
130
|
|
116
131
|
@model_serializer(
|
@@ -381,7 +381,11 @@ def _warn_on_misconfigured_api_url(settings: "Settings"):
|
|
381
381
|
warnings_list.append(warning)
|
382
382
|
|
383
383
|
parsed_url = urlparse(api_url)
|
384
|
-
if
|
384
|
+
if (
|
385
|
+
parsed_url.path
|
386
|
+
and "api.prefect.cloud" in api_url
|
387
|
+
and not parsed_url.path.startswith("/api")
|
388
|
+
):
|
385
389
|
warnings_list.append(
|
386
390
|
"`PREFECT_API_URL` should have `/api` after the base URL."
|
387
391
|
)
|
@@ -18,7 +18,7 @@ class ServerAPISettings(PrefectBaseSettings):
|
|
18
18
|
|
19
19
|
auth_string: Optional[SecretStr] = Field(
|
20
20
|
default=None,
|
21
|
-
description="A string to use for basic authentication with the API
|
21
|
+
description="A string to use for basic authentication with the API in the form 'user:password'.",
|
22
22
|
)
|
23
23
|
|
24
24
|
host: str = Field(
|
@@ -31,6 +31,12 @@ class ServerAPISettings(PrefectBaseSettings):
|
|
31
31
|
description="The API's port address (defaults to `4200`).",
|
32
32
|
)
|
33
33
|
|
34
|
+
base_path: Optional[str] = Field(
|
35
|
+
default=None,
|
36
|
+
description="The base URL path to serve the API under.",
|
37
|
+
examples=["/v2/api"],
|
38
|
+
)
|
39
|
+
|
34
40
|
default_limit: int = Field(
|
35
41
|
default=200,
|
36
42
|
description="The default limit applied to queries that can return multiple objects, such as `POST /flow_runs/filter`.",
|
{prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/settings/models/server/database.py
RENAMED
@@ -30,6 +30,20 @@ class SQLAlchemyConnectArgsSettings(PrefectBaseSettings):
|
|
30
30
|
description="Controls the application_name field for connections opened from the connection pool when using a PostgreSQL database with the Prefect backend.",
|
31
31
|
)
|
32
32
|
|
33
|
+
statement_cache_size: Optional[int] = Field(
|
34
|
+
default=None,
|
35
|
+
description="Controls statement cache size for PostgreSQL connections. Setting this to 0 is required when using PgBouncer in transaction mode. Defaults to None.",
|
36
|
+
)
|
37
|
+
|
38
|
+
prepared_statement_cache_size: Optional[int] = Field(
|
39
|
+
default=None,
|
40
|
+
description=(
|
41
|
+
"Controls the size of the statement cache for PostgreSQL connections. "
|
42
|
+
"When set to 0, statement caching is disabled. Defaults to None to use "
|
43
|
+
"SQLAlchemy's default behavior."
|
44
|
+
),
|
45
|
+
)
|
46
|
+
|
33
47
|
|
34
48
|
class SQLAlchemySettings(PrefectBaseSettings):
|
35
49
|
"""
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
{prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/compatibility/__init__.py
RENAMED
File without changes
|
{prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/compatibility/async_dispatch.py
RENAMED
File without changes
|
{prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/compatibility/deprecated.py
RENAMED
File without changes
|
{prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/compatibility/migration.py
RENAMED
File without changes
|
File without changes
|
File without changes
|
File without changes
|
{prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/concurrency/cancellation.py
RENAMED
File without changes
|
{prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/concurrency/event_loop.py
RENAMED
File without changes
|
{prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/concurrency/inspection.py
RENAMED
File without changes
|
{prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/concurrency/primitives.py
RENAMED
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
{prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/pydantic/annotations/__init__.py
RENAMED
File without changes
|
{prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/pydantic/annotations/pendulum.py
RENAMED
File without changes
|
File without changes
|
File without changes
|
File without changes
|
{prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/_internal/pydantic/v2_validated_func.py
RENAMED
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
{prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_artifacts/client.py
RENAMED
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
{prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_flow_runs/client.py
RENAMED
File without changes
|
{prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_flows/__init__.py
RENAMED
File without changes
|
{prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_flows/client.py
RENAMED
File without changes
|
{prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_logs/__init__.py
RENAMED
File without changes
|
{prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_logs/client.py
RENAMED
File without changes
|
File without changes
|
{prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_variables/client.py
RENAMED
File without changes
|
File without changes
|
{prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/orchestration/_work_pools/client.py
RENAMED
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
{prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/client/types/flexible_schedule_list.py
RENAMED
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
File without changes
|
{prefect_client-3.2.6 → prefect_client-3.2.7}/src/prefect/events/schemas/deployment_triggers.py
RENAMED
File without changes
|
File without changes
|
File without changes
|