prefect-client 2.16.3__py3-none-any.whl → 2.16.5__py3-none-any.whl
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/__init__.py +4 -1
- prefect/_internal/compatibility/deprecated.py +28 -0
- prefect/_internal/concurrency/calls.py +3 -2
- prefect/_internal/pydantic/__init__.py +2 -0
- prefect/_internal/pydantic/_compat.py +180 -0
- prefect/agent.py +14 -6
- prefect/artifacts.py +185 -0
- prefect/client/base.py +80 -10
- prefect/client/cloud.py +1 -1
- prefect/client/orchestration.py +62 -1
- prefect/client/schemas/actions.py +2 -0
- prefect/client/schemas/objects.py +16 -0
- prefect/client/schemas/responses.py +1 -0
- prefect/client/subscriptions.py +13 -7
- prefect/client/utilities.py +55 -28
- prefect/deployments/deployments.py +49 -23
- prefect/deployments/schedules.py +13 -0
- prefect/deprecated/data_documents.py +2 -2
- prefect/deprecated/packaging/__init__.py +12 -0
- prefect/{packaging → deprecated/packaging}/base.py +21 -0
- prefect/{packaging → deprecated/packaging}/docker.py +18 -2
- prefect/{packaging → deprecated/packaging}/file.py +21 -3
- prefect/{packaging → deprecated/packaging}/orion.py +21 -3
- prefect/{packaging → deprecated/packaging}/serializers.py +22 -1
- prefect/engine.py +10 -6
- prefect/events/clients.py +9 -3
- prefect/events/related.py +1 -1
- prefect/events/schemas.py +45 -1
- prefect/filesystems.py +39 -1
- prefect/flows.py +12 -4
- prefect/infrastructure/base.py +15 -0
- prefect/infrastructure/container.py +23 -0
- prefect/infrastructure/kubernetes.py +17 -0
- prefect/infrastructure/process.py +16 -0
- prefect/server/api/collections_data/views/aggregate-worker-metadata.json +14 -2
- prefect/settings.py +62 -8
- prefect/task_server.py +28 -5
- prefect/tasks.py +44 -3
- prefect/utilities/callables.py +3 -1
- prefect/utilities/schema_tools/__init__.py +11 -0
- prefect/variables.py +4 -4
- prefect/workers/base.py +6 -1
- {prefect_client-2.16.3.dist-info → prefect_client-2.16.5.dist-info}/METADATA +2 -1
- {prefect_client-2.16.3.dist-info → prefect_client-2.16.5.dist-info}/RECORD +47 -45
- {prefect_client-2.16.3.dist-info → prefect_client-2.16.5.dist-info}/WHEEL +1 -1
- prefect/packaging/__init__.py +0 -8
- {prefect_client-2.16.3.dist-info → prefect_client-2.16.5.dist-info}/LICENSE +0 -0
- {prefect_client-2.16.3.dist-info → prefect_client-2.16.5.dist-info}/top_level.txt +0 -0
prefect/settings.py
CHANGED
@@ -102,7 +102,10 @@ T = TypeVar("T")
|
|
102
102
|
|
103
103
|
DEFAULT_PROFILES_PATH = Path(__file__).parent.joinpath("profiles.toml")
|
104
104
|
|
105
|
-
REMOVED_EXPERIMENTAL_FLAGS = {
|
105
|
+
REMOVED_EXPERIMENTAL_FLAGS = {
|
106
|
+
"PREFECT_EXPERIMENTAL_ENABLE_ENHANCED_SCHEDULING_UI",
|
107
|
+
"PREFECT_EXPERIMENTAL_ENABLE_ENHANCED_DEPLOYMENT_PARAMETERS",
|
108
|
+
}
|
106
109
|
|
107
110
|
|
108
111
|
class Setting(Generic[T]):
|
@@ -592,6 +595,16 @@ PREFECT_API_TLS_INSECURE_SKIP_VERIFY = Setting(
|
|
592
595
|
This is recommended only during development, e.g. when using self-signed certificates.
|
593
596
|
"""
|
594
597
|
|
598
|
+
PREFECT_API_SSL_CERT_FILE = Setting(
|
599
|
+
str,
|
600
|
+
default=os.environ.get("SSL_CERT_FILE"),
|
601
|
+
)
|
602
|
+
"""
|
603
|
+
This configuration settings option specifies the path to an SSL certificate file.
|
604
|
+
When set, it allows the application to use the specified certificate for secure communication.
|
605
|
+
If left unset, the setting will default to the value provided by the `SSL_CERT_FILE` environment variable.
|
606
|
+
"""
|
607
|
+
|
595
608
|
PREFECT_API_URL = Setting(
|
596
609
|
str,
|
597
610
|
default=None,
|
@@ -657,6 +670,21 @@ A comma-separated list of extra HTTP status codes to retry on. Defaults to an em
|
|
657
670
|
may result in unexpected behavior.
|
658
671
|
"""
|
659
672
|
|
673
|
+
PREFECT_CLIENT_CSRF_SUPPORT_ENABLED = Setting(bool, default=True)
|
674
|
+
"""
|
675
|
+
Determines if CSRF token handling is active in the Prefect client for API
|
676
|
+
requests.
|
677
|
+
|
678
|
+
When enabled (`True`), the client automatically manages CSRF tokens by
|
679
|
+
retrieving, storing, and including them in applicable state-changing requests
|
680
|
+
(POST, PUT, PATCH, DELETE) to the API.
|
681
|
+
|
682
|
+
Disabling this setting (`False`) means the client will not handle CSRF tokens,
|
683
|
+
which might be suitable for environments where CSRF protection is disabled.
|
684
|
+
|
685
|
+
Defaults to `True`, ensuring CSRF protection is enabled by default.
|
686
|
+
"""
|
687
|
+
|
660
688
|
PREFECT_CLOUD_API_URL = Setting(
|
661
689
|
str,
|
662
690
|
default="https://api.prefect.cloud/api",
|
@@ -1207,6 +1235,33 @@ Note this setting only applies when calling `prefect server start`; if hosting t
|
|
1207
1235
|
API with another tool you will need to configure this there instead.
|
1208
1236
|
"""
|
1209
1237
|
|
1238
|
+
PREFECT_SERVER_CSRF_PROTECTION_ENABLED = Setting(bool, default=False)
|
1239
|
+
"""
|
1240
|
+
Controls the activation of CSRF protection for the Prefect server API.
|
1241
|
+
|
1242
|
+
When enabled (`True`), the server enforces CSRF validation checks on incoming
|
1243
|
+
state-changing requests (POST, PUT, PATCH, DELETE), requiring a valid CSRF
|
1244
|
+
token to be included in the request headers or body. This adds a layer of
|
1245
|
+
security by preventing unauthorized or malicious sites from making requests on
|
1246
|
+
behalf of authenticated users.
|
1247
|
+
|
1248
|
+
It is recommended to enable this setting in production environments where the
|
1249
|
+
API is exposed to web clients to safeguard against CSRF attacks.
|
1250
|
+
|
1251
|
+
Note: Enabling this setting requires corresponding support in the client for
|
1252
|
+
CSRF token management. See PREFECT_CLIENT_CSRF_SUPPORT_ENABLED for more.
|
1253
|
+
"""
|
1254
|
+
|
1255
|
+
PREFECT_SERVER_CSRF_TOKEN_EXPIRATION = Setting(timedelta, default=timedelta(hours=1))
|
1256
|
+
"""
|
1257
|
+
Specifies the duration for which a CSRF token remains valid after being issued
|
1258
|
+
by the server.
|
1259
|
+
|
1260
|
+
The default expiration time is set to 1 hour, which offers a reasonable
|
1261
|
+
compromise. Adjust this setting based on your specific security requirements
|
1262
|
+
and usage patterns.
|
1263
|
+
"""
|
1264
|
+
|
1210
1265
|
PREFECT_UI_ENABLED = Setting(
|
1211
1266
|
bool,
|
1212
1267
|
default=True,
|
@@ -1292,12 +1347,12 @@ PREFECT_API_MAX_FLOW_RUN_GRAPH_ARTIFACTS = Setting(int, default=10000)
|
|
1292
1347
|
The maximum number of artifacts to show on a flow run graph on the v2 API
|
1293
1348
|
"""
|
1294
1349
|
|
1295
|
-
PREFECT_EXPERIMENTAL_ENABLE_ARTIFACTS_ON_FLOW_RUN_GRAPH = Setting(bool, default=
|
1350
|
+
PREFECT_EXPERIMENTAL_ENABLE_ARTIFACTS_ON_FLOW_RUN_GRAPH = Setting(bool, default=True)
|
1296
1351
|
"""
|
1297
1352
|
Whether or not to enable artifacts on the flow run graph.
|
1298
1353
|
"""
|
1299
1354
|
|
1300
|
-
PREFECT_EXPERIMENTAL_ENABLE_STATES_ON_FLOW_RUN_GRAPH = Setting(bool, default=
|
1355
|
+
PREFECT_EXPERIMENTAL_ENABLE_STATES_ON_FLOW_RUN_GRAPH = Setting(bool, default=True)
|
1301
1356
|
"""
|
1302
1357
|
Whether or not to enable flow run states on the flow run graph.
|
1303
1358
|
"""
|
@@ -1342,11 +1397,6 @@ PREFECT_EXPERIMENTAL_ENABLE_ENHANCED_CANCELLATION = Setting(bool, default=True)
|
|
1342
1397
|
Whether or not to enable experimental enhanced flow run cancellation.
|
1343
1398
|
"""
|
1344
1399
|
|
1345
|
-
PREFECT_EXPERIMENTAL_ENABLE_ENHANCED_DEPLOYMENT_PARAMETERS = Setting(bool, default=True)
|
1346
|
-
"""
|
1347
|
-
Whether or not to enable enhanced deployment parameters.
|
1348
|
-
"""
|
1349
|
-
|
1350
1400
|
PREFECT_EXPERIMENTAL_WARN_ENHANCED_CANCELLATION = Setting(bool, default=False)
|
1351
1401
|
"""
|
1352
1402
|
Whether or not to warn when experimental enhanced flow run cancellation is used.
|
@@ -1525,6 +1575,10 @@ PREFECT_EXPERIMENTAL_ENABLE_WORK_QUEUE_STATUS = Setting(bool, default=True)
|
|
1525
1575
|
Whether or not to enable experimental work queue status in-place of work queue health.
|
1526
1576
|
"""
|
1527
1577
|
|
1578
|
+
PREFECT_EXPERIMENTAL_ENABLE_PYDANTIC_V2_INTERNALS = Setting(bool, default=False)
|
1579
|
+
"""
|
1580
|
+
Whether or not to enable internal experimental Pydantic v2 behavior.
|
1581
|
+
"""
|
1528
1582
|
|
1529
1583
|
# Defaults -----------------------------------------------------------------------------
|
1530
1584
|
|
prefect/task_server.py
CHANGED
@@ -6,18 +6,20 @@ import socket
|
|
6
6
|
import sys
|
7
7
|
from contextlib import AsyncExitStack
|
8
8
|
from functools import partial
|
9
|
-
from typing import Optional, Type
|
9
|
+
from typing import List, Optional, Type
|
10
10
|
|
11
11
|
import anyio
|
12
|
+
from websockets.exceptions import InvalidStatusCode
|
12
13
|
|
13
14
|
from prefect import Task, get_client
|
14
15
|
from prefect._internal.concurrency.api import create_call, from_sync
|
15
16
|
from prefect.client.schemas.objects import TaskRun
|
16
17
|
from prefect.client.subscriptions import Subscription
|
17
|
-
from prefect.engine import propose_state
|
18
|
+
from prefect.engine import emit_task_run_state_change_event, propose_state
|
18
19
|
from prefect.logging.loggers import get_logger
|
19
20
|
from prefect.results import ResultFactory
|
20
21
|
from prefect.settings import (
|
22
|
+
PREFECT_API_URL,
|
21
23
|
PREFECT_EXPERIMENTAL_ENABLE_TASK_SCHEDULING,
|
22
24
|
PREFECT_TASK_SCHEDULING_DELETE_FAILED_SUBMISSIONS,
|
23
25
|
)
|
@@ -70,7 +72,7 @@ class TaskServer:
|
|
70
72
|
*tasks: Task,
|
71
73
|
task_runner: Optional[Type[BaseTaskRunner]] = None,
|
72
74
|
):
|
73
|
-
self.tasks:
|
75
|
+
self.tasks: List[Task] = tasks
|
74
76
|
|
75
77
|
self.task_runner: BaseTaskRunner = task_runner or ConcurrentTaskRunner()
|
76
78
|
self.started: bool = False
|
@@ -107,7 +109,19 @@ class TaskServer:
|
|
107
109
|
_register_signal(signal.SIGTERM, self.handle_sigterm)
|
108
110
|
|
109
111
|
async with asyncnullcontext() if self.started else self:
|
110
|
-
|
112
|
+
logger.info("Starting task server...")
|
113
|
+
try:
|
114
|
+
await self._subscribe_to_task_scheduling()
|
115
|
+
except InvalidStatusCode as exc:
|
116
|
+
if exc.status_code == 403:
|
117
|
+
logger.error(
|
118
|
+
"Could not establish a connection to the `/task_runs/subscriptions/scheduled`"
|
119
|
+
f" endpoint found at:\n\n {PREFECT_API_URL.value()}"
|
120
|
+
"\n\nPlease double-check the values of your"
|
121
|
+
" `PREFECT_API_URL` and `PREFECT_API_KEY` environment variables."
|
122
|
+
)
|
123
|
+
else:
|
124
|
+
raise
|
111
125
|
|
112
126
|
@sync_compatible
|
113
127
|
async def stop(self):
|
@@ -124,6 +138,9 @@ class TaskServer:
|
|
124
138
|
raise StopTaskServer
|
125
139
|
|
126
140
|
async def _subscribe_to_task_scheduling(self):
|
141
|
+
logger.info(
|
142
|
+
f"Subscribing to tasks: {' | '.join(t.task_key.split('.')[-1] for t in self.tasks)}"
|
143
|
+
)
|
127
144
|
async for task_run in Subscription(
|
128
145
|
model=TaskRun,
|
129
146
|
path="/task_runs/subscriptions/scheduled",
|
@@ -138,7 +155,7 @@ class TaskServer:
|
|
138
155
|
f"Found task run: {task_run.name!r} in state: {task_run.state.name!r}"
|
139
156
|
)
|
140
157
|
|
141
|
-
task = next((t for t in self.tasks if t.
|
158
|
+
task = next((t for t in self.tasks if t.task_key == task_run.task_key), None)
|
142
159
|
|
143
160
|
if not task:
|
144
161
|
if PREFECT_TASK_SCHEDULING_DELETE_FAILED_SUBMISSIONS.value():
|
@@ -188,6 +205,12 @@ class TaskServer:
|
|
188
205
|
" Task run may have already begun execution."
|
189
206
|
)
|
190
207
|
|
208
|
+
emit_task_run_state_change_event(
|
209
|
+
task_run=task_run,
|
210
|
+
initial_state=task_run.state,
|
211
|
+
validated_state=state,
|
212
|
+
)
|
213
|
+
|
191
214
|
self._runs_task_group.start_soon(
|
192
215
|
partial(
|
193
216
|
submit_autonomous_task_run_to_engine,
|
prefect/tasks.py
CHANGED
@@ -6,6 +6,7 @@ Module containing the base workflow task class and decorator - for most use case
|
|
6
6
|
|
7
7
|
import datetime
|
8
8
|
import inspect
|
9
|
+
import os
|
9
10
|
import warnings
|
10
11
|
from copy import copy
|
11
12
|
from functools import partial, update_wrapper
|
@@ -40,6 +41,7 @@ from prefect.settings import (
|
|
40
41
|
PREFECT_TASK_DEFAULT_RETRY_DELAY_SECONDS,
|
41
42
|
)
|
42
43
|
from prefect.states import State
|
44
|
+
from prefect.task_runners import BaseTaskRunner
|
43
45
|
from prefect.utilities.annotations import NotSet
|
44
46
|
from prefect.utilities.asyncutils import Async, Sync
|
45
47
|
from prefect.utilities.callables import (
|
@@ -281,7 +283,14 @@ class Task(Generic[P, R]):
|
|
281
283
|
if not hasattr(self.fn, "__qualname__"):
|
282
284
|
self.task_key = to_qualified_name(type(self.fn))
|
283
285
|
else:
|
284
|
-
|
286
|
+
try:
|
287
|
+
task_origin_hash = hash_objects(
|
288
|
+
self.name, os.path.abspath(inspect.getsourcefile(self.fn))
|
289
|
+
)
|
290
|
+
except TypeError:
|
291
|
+
task_origin_hash = "unknown-source-file"
|
292
|
+
|
293
|
+
self.task_key = f"{self.fn.__qualname__}-{task_origin_hash}"
|
285
294
|
|
286
295
|
self.cache_key_fn = cache_key_fn
|
287
296
|
self.cache_expiration = cache_expiration
|
@@ -382,8 +391,12 @@ class Task(Generic[P, R]):
|
|
382
391
|
timeout_seconds: Union[int, float] = None,
|
383
392
|
log_prints: Optional[bool] = NotSet,
|
384
393
|
refresh_cache: Optional[bool] = NotSet,
|
385
|
-
on_completion: Optional[
|
386
|
-
|
394
|
+
on_completion: Optional[
|
395
|
+
List[Callable[["Task", TaskRun, State], Union[Awaitable[None], None]]]
|
396
|
+
] = None,
|
397
|
+
on_failure: Optional[
|
398
|
+
List[Callable[["Task", TaskRun, State], Union[Awaitable[None], None]]]
|
399
|
+
] = None,
|
387
400
|
retry_condition_fn: Optional[Callable[["Task", TaskRun, State], bool]] = None,
|
388
401
|
viz_return_value: Optional[Any] = None,
|
389
402
|
):
|
@@ -1025,6 +1038,34 @@ class Task(Generic[P, R]):
|
|
1025
1038
|
mapped=True,
|
1026
1039
|
)
|
1027
1040
|
|
1041
|
+
def serve(self, task_runner: Optional[BaseTaskRunner] = None) -> "Task":
|
1042
|
+
"""Serve the task using the provided task runner. This method is used to
|
1043
|
+
establish a websocket connection with the Prefect server and listen for
|
1044
|
+
submitted task runs to execute.
|
1045
|
+
|
1046
|
+
Args:
|
1047
|
+
task_runner: The task runner to use for serving the task. If not provided,
|
1048
|
+
the default ConcurrentTaskRunner will be used.
|
1049
|
+
|
1050
|
+
Examples:
|
1051
|
+
Serve a task using the default task runner
|
1052
|
+
>>> @task
|
1053
|
+
>>> def my_task():
|
1054
|
+
>>> return 1
|
1055
|
+
|
1056
|
+
>>> my_task.serve()
|
1057
|
+
"""
|
1058
|
+
|
1059
|
+
if not PREFECT_EXPERIMENTAL_ENABLE_TASK_SCHEDULING:
|
1060
|
+
raise ValueError(
|
1061
|
+
"Task's `serve` method is an experimental feature and must be enabled with "
|
1062
|
+
"`prefect config set PREFECT_EXPERIMENTAL_ENABLE_TASK_SCHEDULING=True`"
|
1063
|
+
)
|
1064
|
+
|
1065
|
+
from prefect.task_server import serve
|
1066
|
+
|
1067
|
+
serve(self, task_runner=task_runner)
|
1068
|
+
|
1028
1069
|
|
1029
1070
|
@overload
|
1030
1071
|
def task(__fn: Callable[P, R]) -> Task[P, R]:
|
prefect/utilities/callables.py
CHANGED
@@ -1,6 +1,7 @@
|
|
1
1
|
"""
|
2
2
|
Utilities for working with Python callables.
|
3
3
|
"""
|
4
|
+
|
4
5
|
import inspect
|
5
6
|
from functools import partial
|
6
7
|
from typing import Any, Callable, Dict, Iterable, List, Optional, Tuple
|
@@ -312,8 +313,9 @@ def parameter_schema(fn: Callable) -> ParameterSchema:
|
|
312
313
|
ParameterSchema: the argument schema
|
313
314
|
"""
|
314
315
|
try:
|
315
|
-
signature = inspect.signature(fn, eval_str=True)
|
316
|
+
signature = inspect.signature(fn, eval_str=True) # novm
|
316
317
|
except (NameError, TypeError):
|
318
|
+
# `eval_str` is not available in Python < 3.10
|
317
319
|
signature = inspect.signature(fn)
|
318
320
|
|
319
321
|
model_fields = {}
|
@@ -0,0 +1,11 @@
|
|
1
|
+
from .hydration import HydrationContext, HydrationError, hydrate
|
2
|
+
from .validation import CircularSchemaRefError, ValidationError, validate
|
3
|
+
|
4
|
+
__all__ = [
|
5
|
+
"CircularSchemaRefError",
|
6
|
+
"HydrationContext",
|
7
|
+
"HydrationError",
|
8
|
+
"ValidationError",
|
9
|
+
"hydrate",
|
10
|
+
"validate",
|
11
|
+
]
|
prefect/variables.py
CHANGED
@@ -1,12 +1,12 @@
|
|
1
1
|
from typing import Optional
|
2
2
|
|
3
3
|
from prefect.client.orchestration import PrefectClient
|
4
|
-
from prefect.client.utilities import
|
4
|
+
from prefect.client.utilities import get_or_create_client
|
5
5
|
from prefect.utilities.asyncutils import sync_compatible
|
6
6
|
|
7
7
|
|
8
8
|
@sync_compatible
|
9
|
-
async def get(name: str, default: str = None) -> Optional[str]:
|
9
|
+
async def get(name: str, default: Optional[str] = None) -> Optional[str]:
|
10
10
|
"""
|
11
11
|
Get a variable by name. If doesn't exist return the default.
|
12
12
|
```
|
@@ -29,10 +29,10 @@ async def get(name: str, default: str = None) -> Optional[str]:
|
|
29
29
|
return variable.value if variable else default
|
30
30
|
|
31
31
|
|
32
|
-
@inject_client
|
33
32
|
async def _get_variable_by_name(
|
34
33
|
name: str,
|
35
|
-
client: PrefectClient,
|
34
|
+
client: Optional[PrefectClient] = None,
|
36
35
|
):
|
36
|
+
client, _ = get_or_create_client(client)
|
37
37
|
variable = await client.read_variable_by_name(name)
|
38
38
|
return variable
|
prefect/workers/base.py
CHANGED
@@ -966,9 +966,14 @@ class BaseWorker(abc.ABC):
|
|
966
966
|
) -> BaseJobConfiguration:
|
967
967
|
deployment = await self._client.read_deployment(flow_run.deployment_id)
|
968
968
|
flow = await self._client.read_flow(flow_run.flow_id)
|
969
|
+
|
970
|
+
deployment_vars = deployment.infra_overrides or {}
|
971
|
+
flow_run_vars = flow_run.job_variables or {}
|
972
|
+
job_variables = {**deployment_vars, **flow_run_vars}
|
973
|
+
|
969
974
|
configuration = await self.job_configuration.from_template_and_values(
|
970
975
|
base_job_template=self._work_pool.base_job_template,
|
971
|
-
values=
|
976
|
+
values=job_variables,
|
972
977
|
client=self._client,
|
973
978
|
)
|
974
979
|
configuration.prepare_for_flow_run(
|
@@ -1,6 +1,6 @@
|
|
1
1
|
Metadata-Version: 2.1
|
2
2
|
Name: prefect-client
|
3
|
-
Version: 2.16.
|
3
|
+
Version: 2.16.5
|
4
4
|
Summary: Workflow orchestration and management.
|
5
5
|
Home-page: https://www.prefect.io
|
6
6
|
Author: Prefect Technologies, Inc.
|
@@ -34,6 +34,7 @@ Requires-Dist: graphviz >=0.20.1
|
|
34
34
|
Requires-Dist: griffe >=0.20.0
|
35
35
|
Requires-Dist: httpcore <2.0.0,>=0.15.0
|
36
36
|
Requires-Dist: httpx[http2] !=0.23.2,>=0.23
|
37
|
+
Requires-Dist: importlib-resources <6.2.0,>=6.1.3
|
37
38
|
Requires-Dist: jsonpatch <2.0,>=1.32
|
38
39
|
Requires-Dist: jsonschema <5.0.0,>=3.2.0
|
39
40
|
Requires-Dist: orjson <4.0,>=3.7
|
@@ -1,13 +1,14 @@
|
|
1
1
|
prefect/.prefectignore,sha256=awSprvKT0vI8a64mEOLrMxhxqcO-b0ERQeYpA2rNKVQ,390
|
2
|
-
prefect/__init__.py,sha256=
|
2
|
+
prefect/__init__.py,sha256=FqZ2FacBZq5wr-RnLQphwqXN0atLdu9bDC2YtmZi-AU,5456
|
3
3
|
prefect/_version.py,sha256=fQguBh1dzT7Baahj504O5RrsLlSyg3Zrx42OpgdPnFc,22378
|
4
|
-
prefect/agent.py,sha256=
|
4
|
+
prefect/agent.py,sha256=ZHRiQo13SC8F_flWaoWskVopM1DZKgZVwx9kkg_z0A0,27791
|
5
|
+
prefect/artifacts.py,sha256=QLnFkVaBpMQp9fLWkHlayZOUCp2OI6lPmAkUbT-NMLo,5274
|
5
6
|
prefect/context.py,sha256=QK_U3ym-h2i1Y_EOSr4BQeeMN0AIOpG81LQS7k1RiRA,18103
|
6
|
-
prefect/engine.py,sha256=
|
7
|
+
prefect/engine.py,sha256=kWU4jJQm3ApiJiuq3rZysyZZC2zBQc3DdJuYfpydmIE,110127
|
7
8
|
prefect/exceptions.py,sha256=84rpsDLp0cn_v2gE1TnK_NZXh27NJtzgZQtARVKyVEE,10953
|
8
|
-
prefect/filesystems.py,sha256=
|
9
|
+
prefect/filesystems.py,sha256=HkBczs0r69yJQRWsPUVJiU2JKK6NPrkPvSSVIUrvMpQ,36444
|
9
10
|
prefect/flow_runs.py,sha256=mFHLavZk1yZ62H3UazuNDBZWAF7AqKttA4rMcHgsVSw,3119
|
10
|
-
prefect/flows.py,sha256=
|
11
|
+
prefect/flows.py,sha256=CvQ_sGsJNA7zs4i9l4jaZpReon_RznSeK8vZ4TbpSY0,70275
|
11
12
|
prefect/futures.py,sha256=RaWfYIXtH7RsWxQ5QWTTlAzwtVV8XWpXaZT_hLq35vQ,12590
|
12
13
|
prefect/manifests.py,sha256=xfwEEozSEqPK2Lro4dfgdTnjVbQx-aCECNBnf7vO7ZQ,808
|
13
14
|
prefect/plugins.py,sha256=0C-D3-dKi06JZ44XEGmLjCiAkefbE_lKX-g3urzdbQ4,4163
|
@@ -15,22 +16,22 @@ prefect/profiles.toml,sha256=1Tz7nKBDTDXL_6KPJSeB7ok0Vx_aQJ_p0AUmbnzDLzw,39
|
|
15
16
|
prefect/py.typed,sha256=47DEQpj8HBSa-_TImW-5JCeuQeRkm5NMpJWZG3hSuFU,0
|
16
17
|
prefect/results.py,sha256=FgudRagwoNKVKR5590I4AN0mxgYoyXG_7Q1HVoMXdaU,24731
|
17
18
|
prefect/serializers.py,sha256=sSbe40Ipj-d6VuzBae5k2ao9lkMUZpIXcLtD7f2a7cE,10852
|
18
|
-
prefect/settings.py,sha256=
|
19
|
+
prefect/settings.py,sha256=3xU5DQQglwa7MFnYQ6GqhWHbdIis81Ehnj1fMa7d30M,71067
|
19
20
|
prefect/states.py,sha256=-Ud4AUom3Qu-HQ4hOLvfVZuuF-b_ibaqtzmL7V949Ac,20839
|
20
21
|
prefect/task_engine.py,sha256=_2I7XLwoT_nNhpzTMa_52aQKjsDoaW6WpzwIHYEWZS0,2598
|
21
22
|
prefect/task_runners.py,sha256=HXUg5UqhZRN2QNBqMdGE1lKhwFhT8TaRN75ScgLbnw8,11012
|
22
|
-
prefect/task_server.py,sha256=
|
23
|
-
prefect/tasks.py,sha256=
|
24
|
-
prefect/variables.py,sha256=
|
23
|
+
prefect/task_server.py,sha256=6sJAQ6re5ahAHF9IjYkr05mUgefUB6Ga0BeKicgH84A,10532
|
24
|
+
prefect/tasks.py,sha256=AFDCyb0p0r8mamiFMu220-DfGMLSjq-uRi4vL6oxQOE,50477
|
25
|
+
prefect/variables.py,sha256=sk3pfwfPY5lKLt4Qi7OQJPeYipzYip3gidgA9gydcpI,978
|
25
26
|
prefect/_internal/__init__.py,sha256=47DEQpj8HBSa-_TImW-5JCeuQeRkm5NMpJWZG3hSuFU,0
|
26
27
|
prefect/_internal/_logging.py,sha256=HvNHY-8P469o5u4LYEDBTem69XZEt1QUeUaLToijpak,810
|
27
28
|
prefect/_internal/pytz.py,sha256=47Y28jKxUvgw7vaEvN-Xl0laiVdMLXC8IRUEk7oHz1Q,13749
|
28
29
|
prefect/_internal/compatibility/__init__.py,sha256=47DEQpj8HBSa-_TImW-5JCeuQeRkm5NMpJWZG3hSuFU,0
|
29
|
-
prefect/_internal/compatibility/deprecated.py,sha256=
|
30
|
+
prefect/_internal/compatibility/deprecated.py,sha256=5vd4iIzpeGftFdtVaP6PCKNQRiNcgr5O1ZjkGtBvQFE,7566
|
30
31
|
prefect/_internal/compatibility/experimental.py,sha256=bQ2ia6MjgIu1SAWpkGVza87wSz5aTo58X_z3JawqleQ,7442
|
31
32
|
prefect/_internal/concurrency/__init__.py,sha256=ncKwi1NhE3umSFGSKRk9wEVKzN1z1ZD-fmY4EDZHH_U,2142
|
32
33
|
prefect/_internal/concurrency/api.py,sha256=I6OHx53rP7f8GI_O-VHLook1wJfM5Wbe6i2OlAcEcjs,8765
|
33
|
-
prefect/_internal/concurrency/calls.py,sha256=
|
34
|
+
prefect/_internal/concurrency/calls.py,sha256=SVMR1yPTQJtBX095WfRk6cMTq4YKf_L6G77qtaTyN3I,15564
|
34
35
|
prefect/_internal/concurrency/cancellation.py,sha256=eiVsdG5BE_2HCvkQGzIcZ6Gw4ANmchcPRzHsI9wtP3Y,18201
|
35
36
|
prefect/_internal/concurrency/event_loop.py,sha256=rOxUa7e95xP4ionH3o0gRpUzzG6aZMQUituLpMTvTFo,2596
|
36
37
|
prefect/_internal/concurrency/inspection.py,sha256=GWFoSzgs8bZZGNN-Im9sQ-0t0Dqdn8EbwPR1UY3Mhro,3452
|
@@ -38,7 +39,8 @@ prefect/_internal/concurrency/primitives.py,sha256=kxCPD9yLtCeqt-JIHjevL4Zt5FvrF
|
|
38
39
|
prefect/_internal/concurrency/services.py,sha256=aggJd4IUSB6ufppRYdRT-36daEg1JSpJCvK635R8meg,11951
|
39
40
|
prefect/_internal/concurrency/threads.py,sha256=-tReWZL9_XMkRS35SydAfeePH2vqCqb1CGM8lgrKT1I,7846
|
40
41
|
prefect/_internal/concurrency/waiters.py,sha256=DXTD_bbVEUhcTplYQFX8mGmL6nsqJGEDfvS0TmHmIQk,9475
|
41
|
-
prefect/_internal/pydantic/__init__.py,sha256=
|
42
|
+
prefect/_internal/pydantic/__init__.py,sha256=zhbVYT051zywa0rF7Q62jaVFH2D2no3CTCJ1ZXktmR8,482
|
43
|
+
prefect/_internal/pydantic/_compat.py,sha256=YTRAmOTTYybXKJtwsPjee40shpWCtAYlI7RZbPADVO0,6532
|
42
44
|
prefect/_internal/pydantic/schemas.py,sha256=tsRKq5yEIgiRbWMl3BPnbfNaKyDN6pq8WSs0M8SQMm4,452
|
43
45
|
prefect/_internal/pydantic/v2_schema.py,sha256=fySqjMCFoJpRs7wN6c5qoVKePbDbWcXYUoYOs5eFzL0,3485
|
44
46
|
prefect/_internal/pydantic/v2_validated_func.py,sha256=44I4o8jjiS7TYep-E6UYMwjpYH5F1WwJFajW81A3wts,3823
|
@@ -137,18 +139,18 @@ prefect/blocks/notifications.py,sha256=gtr2irqxlvQ5aJTUioG1VfsdSL1xu5e8pWxAYzf49
|
|
137
139
|
prefect/blocks/system.py,sha256=Nlp-3315Hye3FJ5uhDovSPGBIEKi5UbCkAcy3hDxhKk,3057
|
138
140
|
prefect/blocks/webhook.py,sha256=hhyWck7mAPfD_12bl40dJedNC9HIaqs7z13iYcZZ14o,2005
|
139
141
|
prefect/client/__init__.py,sha256=yJ5FRF9RxNUio2V_HmyKCKw5G6CZO0h8cv6xA_Hkpcc,477
|
140
|
-
prefect/client/base.py,sha256=
|
141
|
-
prefect/client/cloud.py,sha256=
|
142
|
+
prefect/client/base.py,sha256=VsJWgaSEyIbHo2MfIkBuErahYwXnU68P3R-n83jx2LI,15211
|
143
|
+
prefect/client/cloud.py,sha256=rrxwmYE9yH4HIewu-xG0HY4P7rwP9gFNitBMYQybcvE,3998
|
142
144
|
prefect/client/collections.py,sha256=I9EgbTg4Fn57gn8vwP_WdDmgnATbx9gfkm2jjhCORjw,1037
|
143
145
|
prefect/client/constants.py,sha256=Z_GG8KF70vbbXxpJuqW5pLnwzujTVeHbcYYRikNmGH0,29
|
144
|
-
prefect/client/orchestration.py,sha256=
|
145
|
-
prefect/client/subscriptions.py,sha256=
|
146
|
-
prefect/client/utilities.py,sha256=
|
146
|
+
prefect/client/orchestration.py,sha256=HnBg-i5vrbzhn0KaXgJDbGST5KDsmEv5oJFyWDemHZ0,111199
|
147
|
+
prefect/client/subscriptions.py,sha256=3kqPH3F-CwyrR5wygCpJMjRjM_gcQjd54Qjih6FcLlA,3372
|
148
|
+
prefect/client/utilities.py,sha256=oGU8dJIq7ExEF4WFt-0aSPNX0JP7uH6NmfRlNhfJu00,2660
|
147
149
|
prefect/client/schemas/__init__.py,sha256=KlyqFV-hMulMkNstBn_0ijoHoIwJZaBj6B1r07UmgvE,607
|
148
|
-
prefect/client/schemas/actions.py,sha256=
|
150
|
+
prefect/client/schemas/actions.py,sha256=hoJ6q10z6lS-GA2osURjBp-rD0lOzJA2qGu6Opnonjo,25937
|
149
151
|
prefect/client/schemas/filters.py,sha256=r6gnxZREnmE8Glt2SF6vPxHr0SIeiFBjTrrN32cw-Mo,35514
|
150
|
-
prefect/client/schemas/objects.py,sha256=
|
151
|
-
prefect/client/schemas/responses.py,sha256=
|
152
|
+
prefect/client/schemas/objects.py,sha256=U3rNUzQspoenwxpb_1b5PcVsX5s2KSNPW9wl1EbGqAE,55562
|
153
|
+
prefect/client/schemas/responses.py,sha256=hErSClfLjt3Ys18YZyZS6dyjVf3eLkiAF6mjEgF4LGg,9344
|
152
154
|
prefect/client/schemas/schedules.py,sha256=ncGWmmBzZvf5G4AL27E0kWGiJxGX-haR2_-GUNvFlv4,14829
|
153
155
|
prefect/client/schemas/sorting.py,sha256=Y-ea8k_vTUKAPKIxqGebwLSXM7x1s5mJ_4-sDd1Ivi8,2276
|
154
156
|
prefect/concurrency/__init__.py,sha256=47DEQpj8HBSa-_TImW-5JCeuQeRkm5NMpJWZG3hSuFU,0
|
@@ -159,29 +161,35 @@ prefect/concurrency/services.py,sha256=LQQXBFNUQTlAnHbdrr6GYcEExpGSaQzb-ZiqKk4rQ
|
|
159
161
|
prefect/concurrency/sync.py,sha256=AChhkA6hykgnnPmIeOp87jauLL0p_lrSwMwUoeuYprI,2148
|
160
162
|
prefect/deployments/__init__.py,sha256=HcC8IEOMaTz98M8uGsxAGITW11PS744XNsQBFz62Qow,441
|
161
163
|
prefect/deployments/base.py,sha256=8K4V3FXz0Fm5sMSLZ-5jRo59LSgEmtElURXrugVJxv8,21450
|
162
|
-
prefect/deployments/deployments.py,sha256=
|
164
|
+
prefect/deployments/deployments.py,sha256=vYZ7xbnjLgEvR8pDwoMlka_TNtISiPGx515EXeaaVOc,42663
|
163
165
|
prefect/deployments/runner.py,sha256=AV8HJfQ6t7mTadAc-ogmyjQY1SqTtEAdOlPNj0EMtqU,45129
|
164
|
-
prefect/deployments/schedules.py,sha256=
|
166
|
+
prefect/deployments/schedules.py,sha256=23GDCAKOP-aAEKGappwTrM4HU67ndVH7NR4Dq0neU_U,1884
|
165
167
|
prefect/deployments/steps/__init__.py,sha256=3pZWONAZzenDszqNQT3bmTFilnvjB6xMolMz9tr5pLw,229
|
166
168
|
prefect/deployments/steps/core.py,sha256=Mg2F5GBJyO-jBAAP7PGtIu1sZgNsvmw5Jn5Qj-bUlgk,6617
|
167
169
|
prefect/deployments/steps/pull.py,sha256=VXyMXedH9JNPFQ0Cs54qlTgL1EJ8Y6IbvxPKjAduqpA,7602
|
168
170
|
prefect/deployments/steps/utility.py,sha256=EhoitdNqsQHUL5MBmVyOL9lSwNXweZvFiw03eIkzveU,8134
|
169
171
|
prefect/deprecated/__init__.py,sha256=47DEQpj8HBSa-_TImW-5JCeuQeRkm5NMpJWZG3hSuFU,0
|
170
|
-
prefect/deprecated/data_documents.py,sha256=
|
172
|
+
prefect/deprecated/data_documents.py,sha256=9BV2eNNTw1aq1q4xQGhYdUoYWiK7jYL5kIMK6DMDBsg,9664
|
173
|
+
prefect/deprecated/packaging/__init__.py,sha256=UsmNuLPYdIVnws2N_uRa53qlWw_5CnunsMMvB-kKW6w,406
|
174
|
+
prefect/deprecated/packaging/base.py,sha256=LoqyJigxYDZxiYwf-KslzkHTybf2mEaUuXD8OJSP7tM,2656
|
175
|
+
prefect/deprecated/packaging/docker.py,sha256=5l7zIfDXN8fOcIQKjRre3BZyBE4P0lhdv6_Knuc-3As,5269
|
176
|
+
prefect/deprecated/packaging/file.py,sha256=CdyI9Gk9Zknce2BZZX04GvPP2u-O3z3y2cwydm0Fl_k,2861
|
177
|
+
prefect/deprecated/packaging/orion.py,sha256=Kz7PCWJbto01CRSUBPjENfX5PvMCcKlcjTtUBcGSM_8,2517
|
178
|
+
prefect/deprecated/packaging/serializers.py,sha256=cHKyraPKoScYyHkiNukf1Pi_QFmm_SrGuLbTnOy_id8,7035
|
171
179
|
prefect/events/__init__.py,sha256=2tQCrDogstn-w65lKyf9ahu_wbWhPaaDK_oxH2v1558,173
|
172
180
|
prefect/events/actions.py,sha256=wYc52xin_CLrNZaou05FdGdLZ5VEhT2lKM_k-MQEJ34,1398
|
173
|
-
prefect/events/clients.py,sha256=
|
181
|
+
prefect/events/clients.py,sha256=_4_QV6TWnG-dOIXWaudMprxmdjUaqMc8BgZHYdnGuHU,13975
|
174
182
|
prefect/events/filters.py,sha256=vSWHGDCCsi_znQs3gZomCxh-Q498ukn_QHJ7H8q16do,6922
|
175
183
|
prefect/events/instrument.py,sha256=uNiD7AnkfuiwTsCMgNyJURmY9H2tXNfLCb3EC5FL0Qw,3805
|
176
|
-
prefect/events/related.py,sha256=
|
177
|
-
prefect/events/schemas.py,sha256=
|
184
|
+
prefect/events/related.py,sha256=jMsCL6VKgMmMcVF4TXdJxQQRT5sxCuAu6piAxSOJxxs,6746
|
185
|
+
prefect/events/schemas.py,sha256=x1Wy7btsI6RZ5FSBmdMVmU4WD8ZPANGoJ8uDJgW9VJc,19475
|
178
186
|
prefect/events/utilities.py,sha256=gUEJA_kVuYASCqDpGX0HwDW0yczMX0AdgmxXbxhzWbM,2452
|
179
187
|
prefect/events/worker.py,sha256=Z6MZmcCyXZtWi4vEtnFyvnzIEBW7HD14lEH1Crye3gY,2716
|
180
188
|
prefect/infrastructure/__init__.py,sha256=Fm1Rhc4I7ZfJePpUAl1F4iNEtcDugoT650WXXt6xoCM,770
|
181
|
-
prefect/infrastructure/base.py,sha256=
|
182
|
-
prefect/infrastructure/container.py,sha256=
|
183
|
-
prefect/infrastructure/kubernetes.py,sha256=
|
184
|
-
prefect/infrastructure/process.py,sha256=
|
189
|
+
prefect/infrastructure/base.py,sha256=s2nNbwXnqHV-sBy7LeZzV1IVjqAO0zv795HM4RHOvQI,10880
|
190
|
+
prefect/infrastructure/container.py,sha256=RuWqxSgwwoAxJ9FquYH12wEUizMQM9_b-e5p13ZVscI,31851
|
191
|
+
prefect/infrastructure/kubernetes.py,sha256=S6VyX-DSI1FOwKCIVZSJ7NBlin_3WtjHWYpLxarEmNA,37215
|
192
|
+
prefect/infrastructure/process.py,sha256=e03OmOOvXx08KNCQZas0D7SqHq4_b6QelLvIMkmxJlo,11943
|
185
193
|
prefect/infrastructure/provisioners/__init__.py,sha256=LXkoifKIqgdaoAtseF1bqKNQYVRCmREvME-89Aops9g,1616
|
186
194
|
prefect/infrastructure/provisioners/cloud_run.py,sha256=kqk8yRZ4gfGJLgCEJL8vNYvRyONe2Mc4e_0DHeEb0iM,17658
|
187
195
|
prefect/infrastructure/provisioners/container_instance.py,sha256=KgJ6-vbq32VLCBiYgrCeG68wa6DfJvA2AmJHCeOY5q8,41231
|
@@ -198,12 +206,6 @@ prefect/logging/handlers.py,sha256=zypWVA9EbaKMimRnZWxjmYYmZE04pB7OP5zKwkrOYHQ,1
|
|
198
206
|
prefect/logging/highlighters.py,sha256=BpSXOy0n3lFVvlKWa7jC-HetAiClFi9jnQtEq5-rgok,1681
|
199
207
|
prefect/logging/loggers.py,sha256=Ci8KgqKCG8R6fDAlnR8iiLTVTYuPIvaFIfcY-AFgCLM,9323
|
200
208
|
prefect/logging/logging.yml,sha256=UkEewf0c3_dURI2uCU4RrxkhI5Devoa1s93fl7hilcg,3160
|
201
|
-
prefect/packaging/__init__.py,sha256=s21JuSXPNgm6EP6zU1R_vPHsgbfy1KadQ75394Iqc9A,241
|
202
|
-
prefect/packaging/base.py,sha256=s2TXx1awmjmnzffWbzuH3uB6A5hTyGasRi21zwxhkEc,1953
|
203
|
-
prefect/packaging/docker.py,sha256=Tsng_xT2V4vDpEvzJNiyhpitIGhz7zWzl4j3qSfbZVo,4714
|
204
|
-
prefect/packaging/file.py,sha256=LdYUpAJfBzaYABCwVs4jMKVyo2DC6psEFGpwJ-iKUd4,2279
|
205
|
-
prefect/packaging/orion.py,sha256=ctWh8s3UztYfOTsZ0sfumebI0dbNDOTriDNXohtEC-k,1935
|
206
|
-
prefect/packaging/serializers.py,sha256=1x5GjcBSYrE-YMmrpYYZi2ObTs7MM6YEM3LS0e6mHAk,6321
|
207
209
|
prefect/runner/__init__.py,sha256=d3DFUXy5BYd8Z4cppNN_6RTSddmr-KfnQ5Yw5vh8WL8,96
|
208
210
|
prefect/runner/runner.py,sha256=OP_RKrgWVKNQwmISmSSGN3oyd5CbrANtOBNHmGyx3Cs,48077
|
209
211
|
prefect/runner/server.py,sha256=xPEgn3NDAWUuXcv62fkr-xV7Bogz9BPMXzsNM6ryDMQ,10647
|
@@ -214,7 +216,7 @@ prefect/runtime/__init__.py,sha256=iYmfK1HmXiXXCQK77wDloOqZmY7SFF5iyr37jRzuf-c,4
|
|
214
216
|
prefect/runtime/deployment.py,sha256=UWNXH-3-NNVxLCl5XnDKiofo4a5j8w_42ns1OSQMixg,4751
|
215
217
|
prefect/runtime/flow_run.py,sha256=aFM3e9xqpeZQ4WkvZQXD0lmXu2fNVVVA1etSN3ZI9aE,8444
|
216
218
|
prefect/runtime/task_run.py,sha256=_np3pjBHWkvEtSe-QElEAGwUct629vVx_sahPr-H8gM,3402
|
217
|
-
prefect/server/api/collections_data/views/aggregate-worker-metadata.json,sha256=
|
219
|
+
prefect/server/api/collections_data/views/aggregate-worker-metadata.json,sha256=Gwv5t_RXgqI77MRk5EV0cWVXRrxZ3_wMWxypV1F2ypI,78423
|
218
220
|
prefect/server/api/static/prefect-logo-mark-gradient.png,sha256=ylRjJkI_JHCw8VbQasNnXQHwZW-sH-IQiUGSD3aWP1E,73430
|
219
221
|
prefect/software/__init__.py,sha256=cn7Hesmkv3unA3NynEiyB0Cj2jAzV17yfwjVsS5Ecso,106
|
220
222
|
prefect/software/base.py,sha256=GV6a5RrLx3JaOg1RI44jZTsI_qbqNWbWF3uVO5csnHM,1464
|
@@ -224,7 +226,7 @@ prefect/software/python.py,sha256=reuEJFZPJ5PrDMfK3BuPpYieHNkOXJAyCAaopQcjDqE,17
|
|
224
226
|
prefect/utilities/__init__.py,sha256=47DEQpj8HBSa-_TImW-5JCeuQeRkm5NMpJWZG3hSuFU,0
|
225
227
|
prefect/utilities/annotations.py,sha256=p33yhh1Zx8BZUlTtl8gKRbpwWU9FVnZ8cfYrcd5KxDI,3103
|
226
228
|
prefect/utilities/asyncutils.py,sha256=dNVKZKLVdNOhQObPf-224l3uWyKnt1jSFpReMpWFwT4,15674
|
227
|
-
prefect/utilities/callables.py,sha256=
|
229
|
+
prefect/utilities/callables.py,sha256=5G2K_ZAnNoWoY7DqESKpbf4ltF5fkGRlJUvDwBGD7t0,11603
|
228
230
|
prefect/utilities/collections.py,sha256=D_DT489rTCwyzZb021i0xp8osBkkQgSW9XLOoLBzgkg,15436
|
229
231
|
prefect/utilities/compat.py,sha256=mNQZDnzyKaOqy-OV-DnmH_dc7CNF5nQgW_EsA4xMr7g,906
|
230
232
|
prefect/utilities/context.py,sha256=nb_Kui1q9cYK5fLy84baoBzko5-mOToQkd1AnZhwyq8,418
|
@@ -244,17 +246,17 @@ prefect/utilities/templating.py,sha256=t32Gcsvvm8ibzdqXwcWzY7JkwftPn73FiiLYEnQWy
|
|
244
246
|
prefect/utilities/text.py,sha256=eXGIsCcZ7h_6hy8T5GDQjL8GiKyktoOqavYub0QjgO4,445
|
245
247
|
prefect/utilities/validation.py,sha256=60AseIr0F1XlygAuqweswz288i7YP4LlLY00s1dM2cg,1985
|
246
248
|
prefect/utilities/visualization.py,sha256=iGkYtroroYY9Rsiw1ok1bLv9FwsNyjtiK-0vBPL-ZWI,6491
|
247
|
-
prefect/utilities/schema_tools/__init__.py,sha256=
|
249
|
+
prefect/utilities/schema_tools/__init__.py,sha256=YtbTThhL8nPEYm3ByTHeOLcj2fm8fXrsxB-ioBWoIek,284
|
248
250
|
prefect/utilities/schema_tools/hydration.py,sha256=SS53N9afZHWT7enJND3Hwnl6vdSnvr-SrJIYKvV_F-o,5823
|
249
251
|
prefect/utilities/schema_tools/validation.py,sha256=b4ZsyrUlU7riaQP9NMQ6FlayzG46SrSE7pKGNCFWscM,7974
|
250
252
|
prefect/workers/__init__.py,sha256=6el2Q856CuRPa5Hdrbm9QyAWB_ovcT2bImSFsoWI46k,66
|
251
|
-
prefect/workers/base.py,sha256=
|
253
|
+
prefect/workers/base.py,sha256=7K1D7Dyls0tMpT1ATsfzbq5BP96j15spjTM_OEmXuXM,44644
|
252
254
|
prefect/workers/block.py,sha256=lvKlaWdA-DCCXDX23HHK9M5urEq4x2wmpKtU9ft3a7k,7767
|
253
255
|
prefect/workers/process.py,sha256=Kxj_eZYh6R8t8253LYIIafiG7dodCF8RZABwd3Ng_R0,10253
|
254
256
|
prefect/workers/server.py,sha256=WVZJxR8nTMzK0ov0BD0xw5OyQpT26AxlXbsGQ1OrxeQ,1551
|
255
257
|
prefect/workers/utilities.py,sha256=VfPfAlGtTuDj0-Kb8WlMgAuOfgXCdrGAnKMapPSBrwc,2483
|
256
|
-
prefect_client-2.16.
|
257
|
-
prefect_client-2.16.
|
258
|
-
prefect_client-2.16.
|
259
|
-
prefect_client-2.16.
|
260
|
-
prefect_client-2.16.
|
258
|
+
prefect_client-2.16.5.dist-info/LICENSE,sha256=MCxsn8osAkzfxKC4CC_dLcUkU8DZLkyihZ8mGs3Ah3Q,11357
|
259
|
+
prefect_client-2.16.5.dist-info/METADATA,sha256=A58u55jaNnt77urHhD1faDHXMlL8cClM78JMOFrLwhw,7349
|
260
|
+
prefect_client-2.16.5.dist-info/WHEEL,sha256=GJ7t_kWBFywbagK5eo9IoUwLW6oyOeTKmQ-9iHFVNxQ,92
|
261
|
+
prefect_client-2.16.5.dist-info/top_level.txt,sha256=MJZYJgFdbRc2woQCeB4vM6T33tr01TmkEhRcns6H_H4,8
|
262
|
+
prefect_client-2.16.5.dist-info/RECORD,,
|
prefect/packaging/__init__.py
DELETED
File without changes
|
File without changes
|