prefect-client 3.3.4.dev3__py3-none-any.whl → 3.3.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/_build_info.py +3 -3
- prefect/_experimental/bundles.py +14 -2
- prefect/cache_policies.py +4 -4
- prefect/events/clients.py +10 -4
- prefect/flows.py +142 -3
- prefect/locking/memory.py +11 -9
- prefect/results.py +9 -0
- prefect/runner/runner.py +8 -3
- prefect/server/api/deployments.py +1 -0
- prefect/states.py +2 -2
- prefect/task_engine.py +12 -6
- prefect/tasks.py +0 -5
- prefect/telemetry/instrumentation.py +2 -2
- prefect/transactions.py +345 -71
- prefect/workers/base.py +166 -7
- prefect/workers/process.py +60 -3
- {prefect_client-3.3.4.dev3.dist-info → prefect_client-3.3.5.dist-info}/METADATA +1 -1
- {prefect_client-3.3.4.dev3.dist-info → prefect_client-3.3.5.dist-info}/RECORD +20 -20
- {prefect_client-3.3.4.dev3.dist-info → prefect_client-3.3.5.dist-info}/WHEEL +0 -0
- {prefect_client-3.3.4.dev3.dist-info → prefect_client-3.3.5.dist-info}/licenses/LICENSE +0 -0
prefect/workers/base.py
CHANGED
@@ -3,7 +3,11 @@ from __future__ import annotations
|
|
3
3
|
import abc
|
4
4
|
import asyncio
|
5
5
|
import datetime
|
6
|
+
import json
|
7
|
+
import subprocess
|
8
|
+
import tempfile
|
6
9
|
import threading
|
10
|
+
import uuid
|
7
11
|
import warnings
|
8
12
|
from contextlib import AsyncExitStack
|
9
13
|
from functools import partial
|
@@ -21,6 +25,7 @@ from zoneinfo import ZoneInfo
|
|
21
25
|
import anyio
|
22
26
|
import anyio.abc
|
23
27
|
import httpx
|
28
|
+
from exceptiongroup import BaseExceptionGroup, ExceptionGroup
|
24
29
|
from importlib_metadata import (
|
25
30
|
distributions, # type: ignore[reportUnknownVariableType] incomplete typing
|
26
31
|
)
|
@@ -35,6 +40,7 @@ from prefect._internal.schemas.validators import return_v_or_none
|
|
35
40
|
from prefect.client.base import ServerType
|
36
41
|
from prefect.client.orchestration import PrefectClient, get_client
|
37
42
|
from prefect.client.schemas.actions import WorkPoolCreate, WorkPoolUpdate
|
43
|
+
from prefect.client.schemas.objects import Flow as APIFlow
|
38
44
|
from prefect.client.schemas.objects import (
|
39
45
|
Integration,
|
40
46
|
StateType,
|
@@ -48,6 +54,7 @@ from prefect.exceptions import (
|
|
48
54
|
Abort,
|
49
55
|
ObjectNotFound,
|
50
56
|
)
|
57
|
+
from prefect.futures import PrefectFlowRunFuture
|
51
58
|
from prefect.logging.loggers import (
|
52
59
|
PrefectLogAdapter,
|
53
60
|
flow_run_logger,
|
@@ -81,11 +88,12 @@ from prefect.utilities.templating import (
|
|
81
88
|
from prefect.utilities.urls import url_for
|
82
89
|
|
83
90
|
if TYPE_CHECKING:
|
84
|
-
from prefect.client.schemas.objects import
|
91
|
+
from prefect.client.schemas.objects import FlowRun
|
85
92
|
from prefect.client.schemas.responses import (
|
86
93
|
DeploymentResponse,
|
87
94
|
WorkerFlowRunResponse,
|
88
95
|
)
|
96
|
+
from prefect.flows import Flow
|
89
97
|
|
90
98
|
|
91
99
|
class BaseJobConfiguration(BaseModel):
|
@@ -217,7 +225,7 @@ class BaseJobConfiguration(BaseModel):
|
|
217
225
|
self,
|
218
226
|
flow_run: "FlowRun",
|
219
227
|
deployment: "DeploymentResponse | None" = None,
|
220
|
-
flow: "
|
228
|
+
flow: "APIFlow | None" = None,
|
221
229
|
work_pool: "WorkPool | None" = None,
|
222
230
|
worker_name: str | None = None,
|
223
231
|
) -> None:
|
@@ -314,7 +322,7 @@ class BaseJobConfiguration(BaseModel):
|
|
314
322
|
return labels
|
315
323
|
|
316
324
|
@staticmethod
|
317
|
-
def _base_flow_labels(flow: "
|
325
|
+
def _base_flow_labels(flow: "APIFlow | None") -> dict[str, str]:
|
318
326
|
if flow is None:
|
319
327
|
return {}
|
320
328
|
|
@@ -418,6 +426,7 @@ class BaseWorkerResult(BaseModel, abc.ABC):
|
|
418
426
|
C = TypeVar("C", bound=BaseJobConfiguration)
|
419
427
|
V = TypeVar("V", bound=BaseVariables)
|
420
428
|
R = TypeVar("R", bound=BaseWorkerResult)
|
429
|
+
FR = TypeVar("FR") # used to capture the return type of a flow
|
421
430
|
|
422
431
|
|
423
432
|
@register_base_type
|
@@ -685,6 +694,146 @@ class BaseWorker(abc.ABC, Generic[C, V, R]):
|
|
685
694
|
"Workers must implement a method for running submitted flow runs"
|
686
695
|
)
|
687
696
|
|
697
|
+
async def submit(
|
698
|
+
self,
|
699
|
+
flow: "Flow[..., FR]",
|
700
|
+
parameters: dict[str, Any] | None = None,
|
701
|
+
job_variables: dict[str, Any] | None = None,
|
702
|
+
) -> "PrefectFlowRunFuture[FR]":
|
703
|
+
"""
|
704
|
+
EXPERIMENTAL: The interface for this method is subject to change.
|
705
|
+
|
706
|
+
Submits a flow to run via the worker.
|
707
|
+
|
708
|
+
Args:
|
709
|
+
flow: The flow to submit
|
710
|
+
parameters: The parameters to pass to the flow
|
711
|
+
|
712
|
+
Returns:
|
713
|
+
A flow run object
|
714
|
+
"""
|
715
|
+
warnings.warn(
|
716
|
+
"Ad-hoc flow submission via workers is experimental. The interface "
|
717
|
+
"and behavior of this feature are subject to change.",
|
718
|
+
category=FutureWarning,
|
719
|
+
)
|
720
|
+
if self._runs_task_group is None:
|
721
|
+
raise RuntimeError("Worker not properly initialized")
|
722
|
+
|
723
|
+
flow_run = await self._runs_task_group.start(
|
724
|
+
partial(
|
725
|
+
self._submit_adhoc_run,
|
726
|
+
flow=flow,
|
727
|
+
parameters=parameters,
|
728
|
+
job_variables=job_variables,
|
729
|
+
),
|
730
|
+
)
|
731
|
+
return PrefectFlowRunFuture(flow_run_id=flow_run.id)
|
732
|
+
|
733
|
+
async def _submit_adhoc_run(
|
734
|
+
self,
|
735
|
+
flow: "Flow[..., FR]",
|
736
|
+
parameters: dict[str, Any] | None = None,
|
737
|
+
job_variables: dict[str, Any] | None = None,
|
738
|
+
task_status: anyio.abc.TaskStatus["FlowRun"] | None = None,
|
739
|
+
):
|
740
|
+
"""
|
741
|
+
Submits a flow run to the Kubernetes worker.
|
742
|
+
"""
|
743
|
+
from prefect._experimental.bundles import (
|
744
|
+
convert_step_to_command,
|
745
|
+
create_bundle_for_flow_run,
|
746
|
+
)
|
747
|
+
|
748
|
+
if (
|
749
|
+
self.work_pool.storage_configuration.bundle_upload_step is None
|
750
|
+
or self.work_pool.storage_configuration.bundle_execution_step is None
|
751
|
+
):
|
752
|
+
raise RuntimeError(
|
753
|
+
f"Storage is not configured for work pool {self.work_pool.name!r}. "
|
754
|
+
"Please configure storage for the work pool by running `prefect "
|
755
|
+
"work-pool storage configure`."
|
756
|
+
)
|
757
|
+
|
758
|
+
bundle_key = str(uuid.uuid4())
|
759
|
+
upload_command = convert_step_to_command(
|
760
|
+
self.work_pool.storage_configuration.bundle_upload_step,
|
761
|
+
bundle_key,
|
762
|
+
quiet=True,
|
763
|
+
)
|
764
|
+
execute_command = convert_step_to_command(
|
765
|
+
self.work_pool.storage_configuration.bundle_execution_step, bundle_key
|
766
|
+
)
|
767
|
+
|
768
|
+
job_variables = (job_variables or {}) | {"command": " ".join(execute_command)}
|
769
|
+
flow_run = await self.client.create_flow_run(
|
770
|
+
flow,
|
771
|
+
parameters=parameters,
|
772
|
+
state=Pending(),
|
773
|
+
job_variables=job_variables,
|
774
|
+
work_pool_name=self.work_pool.name,
|
775
|
+
)
|
776
|
+
if task_status is not None:
|
777
|
+
# Emit the flow run object to .submit to allow it to return a future as soon as possible
|
778
|
+
task_status.started(flow_run)
|
779
|
+
# Avoid an API call to get the flow
|
780
|
+
api_flow = APIFlow(id=flow_run.flow_id, name=flow.name, labels={})
|
781
|
+
logger = self.get_flow_run_logger(flow_run)
|
782
|
+
|
783
|
+
configuration = await self.job_configuration.from_template_and_values(
|
784
|
+
base_job_template=self.work_pool.base_job_template,
|
785
|
+
values=job_variables,
|
786
|
+
client=self._client,
|
787
|
+
)
|
788
|
+
configuration.prepare_for_flow_run(
|
789
|
+
flow_run=flow_run,
|
790
|
+
flow=api_flow,
|
791
|
+
work_pool=self.work_pool,
|
792
|
+
worker_name=self.name,
|
793
|
+
)
|
794
|
+
|
795
|
+
bundle = create_bundle_for_flow_run(flow=flow, flow_run=flow_run)
|
796
|
+
|
797
|
+
with tempfile.TemporaryDirectory() as temp_dir:
|
798
|
+
await (
|
799
|
+
anyio.Path(temp_dir)
|
800
|
+
.joinpath(bundle_key)
|
801
|
+
.write_bytes(json.dumps(bundle).encode("utf-8"))
|
802
|
+
)
|
803
|
+
|
804
|
+
try:
|
805
|
+
full_command = upload_command + [bundle_key]
|
806
|
+
logger.debug(
|
807
|
+
"Uploading execution bundle with command: %s", full_command
|
808
|
+
)
|
809
|
+
await anyio.run_process(
|
810
|
+
full_command,
|
811
|
+
cwd=temp_dir,
|
812
|
+
)
|
813
|
+
except subprocess.CalledProcessError as e:
|
814
|
+
raise RuntimeError(e.stderr.decode("utf-8")) from e
|
815
|
+
|
816
|
+
logger.debug("Successfully uploaded execution bundle")
|
817
|
+
|
818
|
+
try:
|
819
|
+
result = await self.run(flow_run, configuration)
|
820
|
+
|
821
|
+
if result.status_code != 0:
|
822
|
+
await self._propose_crashed_state(
|
823
|
+
flow_run,
|
824
|
+
(
|
825
|
+
"Flow run infrastructure exited with non-zero status code"
|
826
|
+
f" {result.status_code}."
|
827
|
+
),
|
828
|
+
)
|
829
|
+
except Exception as exc:
|
830
|
+
# This flow run was being submitted and did not start successfully
|
831
|
+
logger.exception(
|
832
|
+
f"Failed to submit flow run '{flow_run.id}' to infrastructure."
|
833
|
+
)
|
834
|
+
message = f"Flow run could not be submitted to infrastructure:\n{exc!r}"
|
835
|
+
await self._propose_crashed_state(flow_run, message, client=self.client)
|
836
|
+
|
688
837
|
@classmethod
|
689
838
|
def __dispatch_key__(cls) -> str | None:
|
690
839
|
if cls.__name__ == "BaseWorker":
|
@@ -1230,11 +1379,13 @@ class BaseWorker(abc.ABC, Generic[C, V, R]):
|
|
1230
1379
|
exc_info=True,
|
1231
1380
|
)
|
1232
1381
|
|
1233
|
-
async def _propose_crashed_state(
|
1382
|
+
async def _propose_crashed_state(
|
1383
|
+
self, flow_run: "FlowRun", message: str, client: PrefectClient | None = None
|
1384
|
+
) -> None:
|
1234
1385
|
run_logger = self.get_flow_run_logger(flow_run)
|
1235
1386
|
try:
|
1236
1387
|
state = await propose_state(
|
1237
|
-
self.client,
|
1388
|
+
client or self.client,
|
1238
1389
|
Crashed(message=message),
|
1239
1390
|
flow_run_id=flow_run.id,
|
1240
1391
|
)
|
@@ -1345,8 +1496,16 @@ class BaseWorker(abc.ABC, Generic[C, V, R]):
|
|
1345
1496
|
return self
|
1346
1497
|
|
1347
1498
|
async def __aexit__(self, *exc_info: Any) -> None:
|
1348
|
-
|
1349
|
-
|
1499
|
+
try:
|
1500
|
+
self._logger.debug("Exiting worker context...")
|
1501
|
+
await self.teardown(*exc_info)
|
1502
|
+
except (ExceptionGroup, BaseExceptionGroup) as exc:
|
1503
|
+
# For less verbose tracebacks
|
1504
|
+
exceptions = exc.exceptions
|
1505
|
+
if len(exceptions) == 1:
|
1506
|
+
raise exceptions[0] from None
|
1507
|
+
else:
|
1508
|
+
raise
|
1350
1509
|
|
1351
1510
|
def __repr__(self) -> str:
|
1352
1511
|
return f"Worker(pool={self._work_pool_name!r}, name={self.name!r})"
|
prefect/workers/process.py
CHANGED
@@ -22,15 +22,17 @@ import tempfile
|
|
22
22
|
import threading
|
23
23
|
from functools import partial
|
24
24
|
from pathlib import Path
|
25
|
-
from typing import TYPE_CHECKING, Any, Callable, Optional
|
25
|
+
from typing import TYPE_CHECKING, Any, Callable, Optional, TypeVar
|
26
26
|
|
27
27
|
import anyio
|
28
28
|
import anyio.abc
|
29
29
|
from pydantic import Field, field_validator
|
30
30
|
|
31
31
|
from prefect._internal.schemas.validators import validate_working_dir
|
32
|
+
from prefect.client.schemas.objects import Flow as APIFlow
|
32
33
|
from prefect.runner.runner import Runner
|
33
34
|
from prefect.settings import PREFECT_WORKER_QUERY_SECONDS
|
35
|
+
from prefect.states import Pending
|
34
36
|
from prefect.utilities.processutils import get_sys_executable
|
35
37
|
from prefect.utilities.services import critical_service_loop
|
36
38
|
from prefect.workers.base import (
|
@@ -41,8 +43,11 @@ from prefect.workers.base import (
|
|
41
43
|
)
|
42
44
|
|
43
45
|
if TYPE_CHECKING:
|
44
|
-
from prefect.client.schemas.objects import
|
46
|
+
from prefect.client.schemas.objects import FlowRun, WorkPool
|
45
47
|
from prefect.client.schemas.responses import DeploymentResponse
|
48
|
+
from prefect.flows import Flow
|
49
|
+
|
50
|
+
FR = TypeVar("FR") # used to capture the return type of a flow
|
46
51
|
|
47
52
|
|
48
53
|
class ProcessJobConfiguration(BaseJobConfiguration):
|
@@ -60,7 +65,7 @@ class ProcessJobConfiguration(BaseJobConfiguration):
|
|
60
65
|
self,
|
61
66
|
flow_run: "FlowRun",
|
62
67
|
deployment: "DeploymentResponse | None" = None,
|
63
|
-
flow: "
|
68
|
+
flow: "APIFlow | None" = None,
|
64
69
|
work_pool: "WorkPool | None" = None,
|
65
70
|
worker_name: str | None = None,
|
66
71
|
) -> None:
|
@@ -231,6 +236,58 @@ class ProcessWorker(
|
|
231
236
|
status_code=process.returncode, identifier=str(process.pid)
|
232
237
|
)
|
233
238
|
|
239
|
+
async def _submit_adhoc_run(
|
240
|
+
self,
|
241
|
+
flow: "Flow[..., FR]",
|
242
|
+
parameters: dict[str, Any] | None = None,
|
243
|
+
job_variables: dict[str, Any] | None = None,
|
244
|
+
task_status: anyio.abc.TaskStatus["FlowRun"] | None = None,
|
245
|
+
):
|
246
|
+
from prefect._experimental.bundles import (
|
247
|
+
create_bundle_for_flow_run,
|
248
|
+
)
|
249
|
+
|
250
|
+
flow_run = await self.client.create_flow_run(
|
251
|
+
flow,
|
252
|
+
parameters=parameters,
|
253
|
+
state=Pending(),
|
254
|
+
job_variables=job_variables,
|
255
|
+
work_pool_name=self.work_pool.name,
|
256
|
+
)
|
257
|
+
if task_status is not None:
|
258
|
+
# Emit the flow run object to .submit to allow it to return a future as soon as possible
|
259
|
+
task_status.started(flow_run)
|
260
|
+
|
261
|
+
api_flow = APIFlow(id=flow_run.flow_id, name=flow.name, labels={})
|
262
|
+
logger = self.get_flow_run_logger(flow_run)
|
263
|
+
|
264
|
+
configuration = await self.job_configuration.from_template_and_values(
|
265
|
+
base_job_template=self.work_pool.base_job_template,
|
266
|
+
values=job_variables or {},
|
267
|
+
client=self._client,
|
268
|
+
)
|
269
|
+
configuration.prepare_for_flow_run(
|
270
|
+
flow_run=flow_run,
|
271
|
+
flow=api_flow,
|
272
|
+
work_pool=self.work_pool,
|
273
|
+
worker_name=self.name,
|
274
|
+
)
|
275
|
+
|
276
|
+
bundle = create_bundle_for_flow_run(flow=flow, flow_run=flow_run)
|
277
|
+
|
278
|
+
logger.debug("Executing flow run bundle in subprocess...")
|
279
|
+
try:
|
280
|
+
await self._runner.execute_bundle(
|
281
|
+
bundle=bundle,
|
282
|
+
cwd=configuration.working_dir,
|
283
|
+
env=configuration.env,
|
284
|
+
)
|
285
|
+
except Exception:
|
286
|
+
logger.exception("Error executing flow run bundle in subprocess")
|
287
|
+
await self._propose_crashed_state(flow_run, "Flow run execution failed")
|
288
|
+
finally:
|
289
|
+
logger.debug("Flow run bundle execution complete")
|
290
|
+
|
234
291
|
async def __aenter__(self) -> ProcessWorker:
|
235
292
|
await super().__aenter__()
|
236
293
|
self._runner = await self._exit_stack.enter_async_context(
|
@@ -1,37 +1,37 @@
|
|
1
1
|
prefect/.prefectignore,sha256=awSprvKT0vI8a64mEOLrMxhxqcO-b0ERQeYpA2rNKVQ,390
|
2
2
|
prefect/__init__.py,sha256=iCdcC5ZmeewikCdnPEP6YBAjPNV5dvfxpYCTpw30Hkw,3685
|
3
3
|
prefect/__main__.py,sha256=WFjw3kaYJY6pOTA7WDOgqjsz8zUEUZHCcj3P5wyVa-g,66
|
4
|
-
prefect/_build_info.py,sha256=
|
4
|
+
prefect/_build_info.py,sha256=nw1x64oHIjXXnpkO36llFI2_Puomw6XEngk2T1D9U5U,180
|
5
5
|
prefect/_result_records.py,sha256=S6QmsODkehGVSzbMm6ig022PYbI6gNKz671p_8kBYx4,7789
|
6
6
|
prefect/_waiters.py,sha256=Ia2ITaXdHzevtyWIgJoOg95lrEXQqNEOquHvw3T33UQ,9026
|
7
7
|
prefect/agent.py,sha256=dPvG1jDGD5HSH7aM2utwtk6RaJ9qg13XjkA0lAIgQmY,287
|
8
8
|
prefect/artifacts.py,sha256=dMBUOAWnUamzjb5HSqwB5-GR2Qb-Gxee26XG5NDCUuw,22720
|
9
9
|
prefect/automations.py,sha256=ZzPxn2tINdlXTQo805V4rIlbXuNWxd7cdb3gTJxZIeY,12567
|
10
|
-
prefect/cache_policies.py,sha256=
|
10
|
+
prefect/cache_policies.py,sha256=jH1aDW6vItTcsEytuTCrNYyjbq87IQPwdOgF0yxiUts,12749
|
11
11
|
prefect/context.py,sha256=LYEOlz7ZkuSDj7TmrE4mByy3N3TquFkIE2hEy0WHW1Y,23798
|
12
12
|
prefect/engine.py,sha256=uB5JN4l045i5JTlRQNT1x7MwlSiGQ5Bop2Q6jHHOgxY,3699
|
13
13
|
prefect/exceptions.py,sha256=wZLQQMRB_DyiYkeEdIC5OKwbba5A94Dlnics-lrWI7A,11581
|
14
14
|
prefect/filesystems.py,sha256=v5YqGB4uXf9Ew2VuB9VCSkawvYMMVvEtZf7w1VmAmr8,18036
|
15
15
|
prefect/flow_engine.py,sha256=hZpTYEtwTPMtwVoTCrfD93igN7rlKeG_0kyCvdU4aYE,58876
|
16
16
|
prefect/flow_runs.py,sha256=dbHcXsOq1UsNM7vyJV9gboCTylmdUwQ_-W4NQt4R4ds,17267
|
17
|
-
prefect/flows.py,sha256=
|
17
|
+
prefect/flows.py,sha256=8gWWoZB8S8j8Iwz0TTc5F-f_8sTFucGm53aaue5vUi4,114116
|
18
18
|
prefect/futures.py,sha256=ZD5rdgUHA4sfxwHaPToumOUKlyn4d989JHR7eI97-Hs,23271
|
19
19
|
prefect/main.py,sha256=8V-qLB4GjEVCkGRgGXeaIk-JIXY8Z9FozcNluj4Sm9E,2589
|
20
20
|
prefect/plugins.py,sha256=FPRLR2mWVBMuOnlzeiTD9krlHONZH2rtYLD753JQDNQ,2516
|
21
21
|
prefect/py.typed,sha256=47DEQpj8HBSa-_TImW-5JCeuQeRkm5NMpJWZG3hSuFU,0
|
22
|
-
prefect/results.py,sha256=
|
22
|
+
prefect/results.py,sha256=3zuO8a4EGtti5AP4zLSnoES1YMKP1CugergxJdZa0-8,37140
|
23
23
|
prefect/schedules.py,sha256=dhq4OhImRvcmtxF7UH1m8RbwYdHT5RQsp_FrxVXfODE,7289
|
24
24
|
prefect/serializers.py,sha256=QI0oEal_BO4HQaWSjr6ReSwT55Hn4sbSOXxGgQI1-y0,9249
|
25
|
-
prefect/states.py,sha256=
|
26
|
-
prefect/task_engine.py,sha256=
|
25
|
+
prefect/states.py,sha256=rh7l1bnIYpTXdlXt5nnpz66y9KLjBWAJrN9Eo5RwgQs,26023
|
26
|
+
prefect/task_engine.py,sha256=wLOj7dPuIBBDZkvsqxWv7wLpUOhGnRb3N5s0ia2y5So,61576
|
27
27
|
prefect/task_runners.py,sha256=Ce_ngocfq_X-NA5zhPj13IdVmzZ5h6gXlmfxYWs2AXA,15828
|
28
28
|
prefect/task_runs.py,sha256=7LIzfo3fondCyEUpU05sYFN5IfpZigBDXrhG5yc-8t0,9039
|
29
29
|
prefect/task_worker.py,sha256=gMj_rl4EjTrnJ5YSOXinC6y-7KSK7fRQt_UYbZbrrV8,17879
|
30
|
-
prefect/tasks.py,sha256=
|
31
|
-
prefect/transactions.py,sha256=
|
30
|
+
prefect/tasks.py,sha256=EpMw5O1B9pAFVraC0KzytMOKi8iy7ZYnKWRs7WtvogU,74742
|
31
|
+
prefect/transactions.py,sha256=uIoPNudzJzH6NrMJhrgr5lyh6JxOJQqT1GvrXt69yNw,26068
|
32
32
|
prefect/variables.py,sha256=dCK3vX7TbkqXZhnNT_v7rcGh3ISRqoR6pJVLpoll3Js,8342
|
33
33
|
prefect/_experimental/__init__.py,sha256=47DEQpj8HBSa-_TImW-5JCeuQeRkm5NMpJWZG3hSuFU,0
|
34
|
-
prefect/_experimental/bundles.py,sha256=
|
34
|
+
prefect/_experimental/bundles.py,sha256=E5nRaLVTbYCrACXZcRJCd4ssOcQU-Z26ewCb_7tPeTM,6687
|
35
35
|
prefect/_experimental/lineage.py,sha256=8LssReoq7eLtQScUCu-7FCtrWoRZstXKRdpO0PxgbKg,9958
|
36
36
|
prefect/_experimental/sla/__init__.py,sha256=47DEQpj8HBSa-_TImW-5JCeuQeRkm5NMpJWZG3hSuFU,0
|
37
37
|
prefect/_experimental/sla/client.py,sha256=XTkYHFZiBy_O7RgUyGEdl9MxaHP-6fEAKBk3ksNQobU,3611
|
@@ -146,7 +146,7 @@ prefect/docker/__init__.py,sha256=z6wdc6UFfiBG2jb9Jk64uCWVM04JKVWeVyDWwuuon8M,52
|
|
146
146
|
prefect/docker/docker_image.py,sha256=bR_pEq5-FDxlwTj8CP_7nwZ_MiGK6KxIi8v7DRjy1Kg,3138
|
147
147
|
prefect/events/__init__.py,sha256=GtKl2bE--pJduTxelH2xy7SadlLJmmis8WR1EYixhuA,2094
|
148
148
|
prefect/events/actions.py,sha256=A7jS8bo4zWGnrt3QfSoQs0uYC1xfKXio3IfU0XtTb5s,9129
|
149
|
-
prefect/events/clients.py,sha256=
|
149
|
+
prefect/events/clients.py,sha256=g_LNcPtYd1Erbz1q4UI33e5dmPjQv_OeejoYGkASs5w,27581
|
150
150
|
prefect/events/filters.py,sha256=2hVfzc3Rdgy0mBHDutWxT__LJY0zpVM8greWX3y6kjM,8233
|
151
151
|
prefect/events/related.py,sha256=CTeexYUmmA93V4gsR33GIFmw-SS-X_ouOpRg-oeq-BU,6672
|
152
152
|
prefect/events/utilities.py,sha256=ww34bTMENCNwcp6RhhgzG0KgXOvKGe0MKmBdSJ8NpZY,3043
|
@@ -171,7 +171,7 @@ prefect/input/actions.py,sha256=BDx26b6ZYCTr0kbWBp73Or7UXnLIv1lnm0jow6Simxw,3871
|
|
171
171
|
prefect/input/run_input.py,sha256=GoM4LR3oqAFLf2sPCR1yITY9tNSZT8kAd4gaC-v-a-c,22703
|
172
172
|
prefect/locking/__init__.py,sha256=47DEQpj8HBSa-_TImW-5JCeuQeRkm5NMpJWZG3hSuFU,0
|
173
173
|
prefect/locking/filesystem.py,sha256=RVE4_5lgKi1iea0NZVQlyct5GU4fVAtCPPEdRMDaQHw,8128
|
174
|
-
prefect/locking/memory.py,sha256=
|
174
|
+
prefect/locking/memory.py,sha256=EFQnhAO94jEy4TyS880DbsJ42CHT5WNuNc6Wj8dYrKc,7842
|
175
175
|
prefect/locking/protocol.py,sha256=RsfvlaHTTEJ0YvYWSqFGoZuT2w4FPPxyQlHqjoyNGuE,4240
|
176
176
|
prefect/logging/__init__.py,sha256=DpRZzZeWeiDHFlMDEQdknRzbxpL0ObFh5IqqS9iaZwQ,170
|
177
177
|
prefect/logging/configuration.py,sha256=ZBAOgwE34VSZFSiP4gBEd0S9m645_mEs3dFhiwPj58o,3303
|
@@ -182,7 +182,7 @@ prefect/logging/highlighters.py,sha256=BCf_LNhFInIfGPqwuu8YVrGa4wVxNc4YXo2pYgftp
|
|
182
182
|
prefect/logging/loggers.py,sha256=rwFJv0i3dhdKr25XX-xUkQy4Vv4dy18bTy366jrC0OQ,12741
|
183
183
|
prefect/logging/logging.yml,sha256=tT7gTyC4NmngFSqFkCdHaw7R0GPNPDDsTCGZQByiJAQ,3169
|
184
184
|
prefect/runner/__init__.py,sha256=pQBd9wVrUVUDUFJlgiweKSnbahoBZwqnd2O2jkhrULY,158
|
185
|
-
prefect/runner/runner.py,sha256=
|
185
|
+
prefect/runner/runner.py,sha256=jv87XyaJ89uK0VzKpMzL3HfXgKZky8JlRs-gW04no5Y,65117
|
186
186
|
prefect/runner/server.py,sha256=YRYFNoYddA9XfiTIYtudxrnD1vCX-PaOLhvyGUOb9AQ,11966
|
187
187
|
prefect/runner/storage.py,sha256=L7aSjie5L6qbXYCDqYDX3ouQ_NsNMlmfjPeaWOC-ncs,28043
|
188
188
|
prefect/runner/submit.py,sha256=qOEj-NChQ6RYFV35hHEVMTklrNmKwaGs2mR78ku9H0o,9474
|
@@ -205,7 +205,7 @@ prefect/server/api/concurrency_limits.py,sha256=E5TB2cJPIZjnxnm1pGxUJnwMDz5CS58g
|
|
205
205
|
prefect/server/api/concurrency_limits_v2.py,sha256=PGjG7W2Z65OojNTP0ezFu2z69plXo1N8paqwHlHAPj0,10183
|
206
206
|
prefect/server/api/csrf_token.py,sha256=BwysSjQAhre7O0OY_LF3ZcIiO53FdMQroNT11Q6OcOM,1344
|
207
207
|
prefect/server/api/dependencies.py,sha256=VujfcIGn41TGJxUunFHVabY5hE-6nY6uSHyhNFj8PdI,6634
|
208
|
-
prefect/server/api/deployments.py,sha256=
|
208
|
+
prefect/server/api/deployments.py,sha256=HQwgiFQXHJ0bpNFRrhW6cY0rQFua0JJfcsMnPyj1H8I,37963
|
209
209
|
prefect/server/api/events.py,sha256=3-Qdt6ORxFv3nLoogQqvd72zEulJSoAmcqZto2OULuk,9907
|
210
210
|
prefect/server/api/flow_run_notification_policies.py,sha256=F8xNm6bgZTC3nFe9xCUJS4NlU9tLXZ8fShtJqmhT2m4,4828
|
211
211
|
prefect/server/api/flow_run_states.py,sha256=lIdxVE9CqLgtDCuH9bTaKkzHNL81FPrr11liPzvONrw,1661
|
@@ -269,7 +269,7 @@ prefect/settings/models/server/tasks.py,sha256=_CaOUfh3WDXvUhmHXmR-MkTRaQqocZck4
|
|
269
269
|
prefect/settings/models/server/ui.py,sha256=hShsi4rPBtdJA2WnT1Er0tWqu-e5wUum8NkNgucShkk,1867
|
270
270
|
prefect/telemetry/__init__.py,sha256=AbpHGcgLb-kRsJGnwFEktk7uzpZOCcBY74-YBdrKVGs,1
|
271
271
|
prefect/telemetry/bootstrap.py,sha256=XaYlK4OTaloQX63AG7IfvGD7yH5LOsXfol4pPfaXSBI,1537
|
272
|
-
prefect/telemetry/instrumentation.py,sha256=
|
272
|
+
prefect/telemetry/instrumentation.py,sha256=5b8b5183IrmBgH722c2TIQHpjBrE0vlRqcKpfwRG0a0,4732
|
273
273
|
prefect/telemetry/logging.py,sha256=ktIVTXbdZ46v6fUhoHNidFrpvpNJR-Pj-hQ4V9b40W4,789
|
274
274
|
prefect/telemetry/processors.py,sha256=jw6j6LviOVxw3IBJe7cSjsxFk0zzY43jUmy6C9pcfCE,2272
|
275
275
|
prefect/telemetry/run_telemetry.py,sha256=_FbjiPqPemu4xvZuI2YBPwXeRJ2BcKRJ6qgO4UMzKKE,8571
|
@@ -310,13 +310,13 @@ prefect/utilities/schema_tools/__init__.py,sha256=At3rMHd2g_Em2P3_dFQlFgqR_EpBwr
|
|
310
310
|
prefect/utilities/schema_tools/hydration.py,sha256=NkRhWkNfxxFmVGhNDfmxdK_xeKaEhs3a42q83Sg9cT4,9436
|
311
311
|
prefect/utilities/schema_tools/validation.py,sha256=Wix26IVR-ZJ32-6MX2pHhrwm3reB-Q4iB6_phn85OKE,10743
|
312
312
|
prefect/workers/__init__.py,sha256=EaM1F0RZ-XIJaGeTKLsXDnfOPHzVWk5bk0_c4BVS44M,64
|
313
|
-
prefect/workers/base.py,sha256=
|
313
|
+
prefect/workers/base.py,sha256=l7ghNeSJh6DXiDdsnLmQor2-b82YaZJIz5TpFSn2dFY,59171
|
314
314
|
prefect/workers/block.py,sha256=dPvG1jDGD5HSH7aM2utwtk6RaJ9qg13XjkA0lAIgQmY,287
|
315
315
|
prefect/workers/cloud.py,sha256=dPvG1jDGD5HSH7aM2utwtk6RaJ9qg13XjkA0lAIgQmY,287
|
316
|
-
prefect/workers/process.py,sha256=
|
316
|
+
prefect/workers/process.py,sha256=Yi5D0U5AQ51wHT86GdwtImXSefe0gJf3LGq4r4z9zwM,11090
|
317
317
|
prefect/workers/server.py,sha256=2pmVeJZiVbEK02SO6BEZaBIvHMsn6G8LzjW8BXyiTtk,1952
|
318
318
|
prefect/workers/utilities.py,sha256=VfPfAlGtTuDj0-Kb8WlMgAuOfgXCdrGAnKMapPSBrwc,2483
|
319
|
-
prefect_client-3.3.
|
320
|
-
prefect_client-3.3.
|
321
|
-
prefect_client-3.3.
|
322
|
-
prefect_client-3.3.
|
319
|
+
prefect_client-3.3.5.dist-info/METADATA,sha256=MYtvXhz041ZOvLWgl-b5JZI4LyH4jAhZrGeHMtvIC4A,7451
|
320
|
+
prefect_client-3.3.5.dist-info/WHEEL,sha256=qtCwoSJWgHk21S1Kb4ihdzI2rlJ1ZKaIurTj_ngOhyQ,87
|
321
|
+
prefect_client-3.3.5.dist-info/licenses/LICENSE,sha256=MCxsn8osAkzfxKC4CC_dLcUkU8DZLkyihZ8mGs3Ah3Q,11357
|
322
|
+
prefect_client-3.3.5.dist-info/RECORD,,
|
File without changes
|
File without changes
|