prefect-client 3.1.4__py3-none-any.whl → 3.1.6__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.
Files changed (96) hide show
  1. prefect/__init__.py +3 -0
  2. prefect/_internal/compatibility/migration.py +1 -1
  3. prefect/_internal/concurrency/api.py +52 -52
  4. prefect/_internal/concurrency/calls.py +59 -35
  5. prefect/_internal/concurrency/cancellation.py +34 -18
  6. prefect/_internal/concurrency/event_loop.py +7 -6
  7. prefect/_internal/concurrency/threads.py +41 -33
  8. prefect/_internal/concurrency/waiters.py +28 -21
  9. prefect/_internal/pydantic/v1_schema.py +2 -2
  10. prefect/_internal/pydantic/v2_schema.py +10 -9
  11. prefect/_internal/schemas/bases.py +10 -11
  12. prefect/_internal/schemas/validators.py +2 -1
  13. prefect/_version.py +3 -3
  14. prefect/automations.py +53 -47
  15. prefect/blocks/abstract.py +12 -10
  16. prefect/blocks/core.py +4 -2
  17. prefect/cache_policies.py +11 -11
  18. prefect/client/__init__.py +3 -1
  19. prefect/client/base.py +36 -37
  20. prefect/client/cloud.py +26 -19
  21. prefect/client/collections.py +2 -2
  22. prefect/client/orchestration.py +366 -277
  23. prefect/client/schemas/__init__.py +24 -0
  24. prefect/client/schemas/actions.py +132 -120
  25. prefect/client/schemas/filters.py +5 -0
  26. prefect/client/schemas/objects.py +113 -85
  27. prefect/client/schemas/responses.py +21 -18
  28. prefect/client/schemas/schedules.py +136 -93
  29. prefect/client/subscriptions.py +28 -14
  30. prefect/client/utilities.py +32 -36
  31. prefect/concurrency/asyncio.py +6 -9
  32. prefect/concurrency/services.py +3 -0
  33. prefect/concurrency/sync.py +35 -5
  34. prefect/context.py +39 -31
  35. prefect/deployments/flow_runs.py +3 -5
  36. prefect/docker/__init__.py +1 -1
  37. prefect/events/schemas/events.py +25 -20
  38. prefect/events/utilities.py +1 -2
  39. prefect/filesystems.py +3 -3
  40. prefect/flow_engine.py +755 -138
  41. prefect/flow_runs.py +3 -3
  42. prefect/flows.py +214 -170
  43. prefect/logging/configuration.py +1 -1
  44. prefect/logging/highlighters.py +1 -2
  45. prefect/logging/loggers.py +30 -20
  46. prefect/main.py +17 -24
  47. prefect/runner/runner.py +43 -21
  48. prefect/runner/server.py +30 -32
  49. prefect/runner/submit.py +3 -6
  50. prefect/runner/utils.py +6 -6
  51. prefect/runtime/flow_run.py +7 -0
  52. prefect/settings/constants.py +2 -2
  53. prefect/settings/legacy.py +1 -1
  54. prefect/settings/models/server/events.py +10 -0
  55. prefect/settings/sources.py +9 -2
  56. prefect/task_engine.py +72 -19
  57. prefect/task_runners.py +2 -2
  58. prefect/tasks.py +46 -33
  59. prefect/telemetry/bootstrap.py +15 -2
  60. prefect/telemetry/run_telemetry.py +107 -0
  61. prefect/transactions.py +14 -14
  62. prefect/types/__init__.py +20 -3
  63. prefect/utilities/_engine.py +96 -0
  64. prefect/utilities/annotations.py +25 -18
  65. prefect/utilities/asyncutils.py +126 -140
  66. prefect/utilities/callables.py +87 -78
  67. prefect/utilities/collections.py +278 -117
  68. prefect/utilities/compat.py +13 -21
  69. prefect/utilities/context.py +6 -5
  70. prefect/utilities/dispatch.py +23 -12
  71. prefect/utilities/dockerutils.py +33 -32
  72. prefect/utilities/engine.py +126 -239
  73. prefect/utilities/filesystem.py +18 -15
  74. prefect/utilities/hashing.py +10 -11
  75. prefect/utilities/importtools.py +40 -27
  76. prefect/utilities/math.py +9 -5
  77. prefect/utilities/names.py +3 -3
  78. prefect/utilities/processutils.py +121 -57
  79. prefect/utilities/pydantic.py +41 -36
  80. prefect/utilities/render_swagger.py +22 -12
  81. prefect/utilities/schema_tools/__init__.py +2 -1
  82. prefect/utilities/schema_tools/hydration.py +50 -43
  83. prefect/utilities/schema_tools/validation.py +52 -42
  84. prefect/utilities/services.py +13 -12
  85. prefect/utilities/templating.py +45 -45
  86. prefect/utilities/text.py +2 -1
  87. prefect/utilities/timeout.py +4 -4
  88. prefect/utilities/urls.py +9 -4
  89. prefect/utilities/visualization.py +46 -24
  90. prefect/variables.py +9 -8
  91. prefect/workers/base.py +18 -10
  92. {prefect_client-3.1.4.dist-info → prefect_client-3.1.6.dist-info}/METADATA +5 -5
  93. {prefect_client-3.1.4.dist-info → prefect_client-3.1.6.dist-info}/RECORD +96 -94
  94. {prefect_client-3.1.4.dist-info → prefect_client-3.1.6.dist-info}/WHEEL +1 -1
  95. {prefect_client-3.1.4.dist-info → prefect_client-3.1.6.dist-info}/LICENSE +0 -0
  96. {prefect_client-3.1.4.dist-info → prefect_client-3.1.6.dist-info}/top_level.txt +0 -0
@@ -58,7 +58,7 @@ def load_logging_config(path: Path) -> dict:
58
58
  return flatdict_to_dict(flat_config)
59
59
 
60
60
 
61
- def setup_logging(incremental: Optional[bool] = None) -> dict:
61
+ def setup_logging(incremental: Optional[bool] = None) -> dict[str, Any]:
62
62
  """
63
63
  Sets up logging.
64
64
 
@@ -45,8 +45,7 @@ class StateHighlighter(RegexHighlighter):
45
45
 
46
46
  base_style = "state."
47
47
  highlights = [
48
- rf"(?P<{state.value.lower()}_state>{state.value.title()})"
49
- for state in StateType
48
+ rf"(?P<{state.lower()}_state>{state.title()})" for state in StateType
50
49
  ] + [
51
50
  r"(?P<cached_state>Cached)(?=\(type=COMPLETED\))" # Highlight only "Cached"
52
51
  ]
@@ -4,12 +4,11 @@ import sys
4
4
  from builtins import print
5
5
  from contextlib import contextmanager
6
6
  from functools import lru_cache
7
- from logging import LoggerAdapter, LogRecord
8
- from typing import TYPE_CHECKING, Dict, List, Optional, Union
7
+ from logging import LogRecord
8
+ from typing import TYPE_CHECKING, Any, Dict, List, Optional, Union
9
9
 
10
10
  from typing_extensions import Self
11
11
 
12
- import prefect
13
12
  from prefect.exceptions import MissingContextError
14
13
  from prefect.logging.filters import ObfuscateApiKeyFilter
15
14
  from prefect.telemetry.logging import add_telemetry_log_handler
@@ -22,8 +21,13 @@ if TYPE_CHECKING:
22
21
  from prefect.tasks import Task
23
22
  from prefect.workers.base import BaseWorker
24
23
 
24
+ if sys.version_info >= (3, 12):
25
+ LoggingAdapter = logging.LoggerAdapter[logging.Logger]
26
+ else:
27
+ LoggingAdapter = logging.LoggerAdapter
25
28
 
26
- class PrefectLogAdapter(logging.LoggerAdapter):
29
+
30
+ class PrefectLogAdapter(LoggingAdapter):
27
31
  """
28
32
  Adapter that ensures extra kwargs are passed through correctly; without this
29
33
  the `extra` fields set on the adapter would overshadow any provided on a
@@ -83,8 +87,8 @@ def get_logger(name: Optional[str] = None) -> logging.Logger:
83
87
 
84
88
 
85
89
  def get_run_logger(
86
- context: Optional["RunContext"] = None, **kwargs: str
87
- ) -> Union[logging.Logger, logging.LoggerAdapter]:
90
+ context: Optional["RunContext"] = None, **kwargs: Any
91
+ ) -> Union[logging.Logger, LoggingAdapter]:
88
92
  """
89
93
  Get a Prefect logger for the current task run or flow run.
90
94
 
@@ -103,15 +107,17 @@ def get_run_logger(
103
107
  Raises:
104
108
  MissingContextError: If no context can be found
105
109
  """
110
+ from prefect.context import FlowRunContext, TaskRunContext
111
+
106
112
  # Check for existing contexts
107
- task_run_context = prefect.context.TaskRunContext.get()
108
- flow_run_context = prefect.context.FlowRunContext.get()
113
+ task_run_context = TaskRunContext.get()
114
+ flow_run_context = FlowRunContext.get()
109
115
 
110
116
  # Apply the context override
111
117
  if context:
112
- if isinstance(context, prefect.context.FlowRunContext):
118
+ if isinstance(context, FlowRunContext):
113
119
  flow_run_context = context
114
- elif isinstance(context, prefect.context.TaskRunContext):
120
+ elif isinstance(context, TaskRunContext):
115
121
  task_run_context = context
116
122
  else:
117
123
  raise TypeError(
@@ -130,7 +136,9 @@ def get_run_logger(
130
136
  )
131
137
  elif flow_run_context:
132
138
  logger = flow_run_logger(
133
- flow_run=flow_run_context.flow_run, flow=flow_run_context.flow, **kwargs
139
+ flow_run=flow_run_context.flow_run, # type: ignore
140
+ flow=flow_run_context.flow,
141
+ **kwargs,
134
142
  )
135
143
  elif (
136
144
  get_logger("prefect.flow_run").disabled
@@ -151,9 +159,9 @@ def get_run_logger(
151
159
 
152
160
  def flow_run_logger(
153
161
  flow_run: Union["FlowRun", "ClientFlowRun"],
154
- flow: Optional["Flow"] = None,
162
+ flow: Optional["Flow[Any, Any]"] = None,
155
163
  **kwargs: str,
156
- ) -> LoggerAdapter:
164
+ ) -> LoggingAdapter:
157
165
  """
158
166
  Create a flow run logger with the run's metadata attached.
159
167
 
@@ -177,10 +185,10 @@ def flow_run_logger(
177
185
 
178
186
  def task_run_logger(
179
187
  task_run: "TaskRun",
180
- task: "Task" = None,
181
- flow_run: "FlowRun" = None,
182
- flow: "Flow" = None,
183
- **kwargs: str,
188
+ task: Optional["Task[Any, Any]"] = None,
189
+ flow_run: Optional["FlowRun"] = None,
190
+ flow: Optional["Flow[Any, Any]"] = None,
191
+ **kwargs: Any,
184
192
  ):
185
193
  """
186
194
  Create a task run logger with the run's metadata attached.
@@ -193,8 +201,10 @@ def task_run_logger(
193
201
  If only the flow run context is available, it will be used for default values
194
202
  of `flow_run` and `flow`.
195
203
  """
204
+ from prefect.context import FlowRunContext
205
+
196
206
  if not flow_run or not flow:
197
- flow_run_context = prefect.context.FlowRunContext.get()
207
+ flow_run_context = FlowRunContext.get()
198
208
  if flow_run_context:
199
209
  flow_run = flow_run or flow_run_context.flow_run
200
210
  flow = flow or flow_run_context.flow
@@ -269,7 +279,7 @@ def disable_run_logger():
269
279
  yield
270
280
 
271
281
 
272
- def print_as_log(*args, **kwargs):
282
+ def print_as_log(*args: Any, **kwargs: Any) -> None:
273
283
  """
274
284
  A patch for `print` to send printed messages to the Prefect run logger.
275
285
 
@@ -333,7 +343,7 @@ class LogEavesdropper(logging.Handler):
333
343
  # Outputs: "Hello, world!\nAnother one!"
334
344
  """
335
345
 
336
- _target_logger: logging.Logger
346
+ _target_logger: Optional[logging.Logger]
337
347
  _lines: List[str]
338
348
 
339
349
  def __init__(self, eavesdrop_on: str, level: int = logging.NOTSET):
prefect/main.py CHANGED
@@ -1,16 +1,18 @@
1
1
  # Import user-facing API
2
+ from typing import Any
3
+
2
4
  from prefect.deployments import deploy
3
5
  from prefect.states import State
4
6
  from prefect.logging import get_run_logger
5
- from prefect.flows import flow, Flow, serve
7
+ from prefect.flows import flow, Flow, serve, aserve
6
8
  from prefect.transactions import Transaction
7
9
  from prefect.tasks import task, Task
8
10
  from prefect.context import tags
9
11
  from prefect.utilities.annotations import unmapped, allow_failure
10
12
  from prefect.results import BaseResult, ResultRecordMetadata
11
13
  from prefect.flow_runs import pause_flow_run, resume_flow_run, suspend_flow_run
12
- from prefect.client.orchestration import get_client, PrefectClient
13
- from prefect.client.cloud import get_cloud_client, CloudClient
14
+ from prefect.client.orchestration import get_client
15
+ from prefect.client.cloud import get_cloud_client
14
16
  import prefect.variables
15
17
  import prefect.runtime
16
18
 
@@ -25,28 +27,17 @@ import prefect.context
25
27
  # Perform any forward-ref updates needed for Pydantic models
26
28
  import prefect.client.schemas
27
29
 
28
- prefect.context.FlowRunContext.model_rebuild(
29
- _types_namespace={
30
- "Flow": Flow,
31
- "BaseResult": BaseResult,
32
- "ResultRecordMetadata": ResultRecordMetadata,
33
- }
34
- )
35
- prefect.context.TaskRunContext.model_rebuild(
36
- _types_namespace={"Task": Task, "BaseResult": BaseResult}
37
- )
38
- prefect.client.schemas.State.model_rebuild(
39
- _types_namespace={
40
- "BaseResult": BaseResult,
41
- "ResultRecordMetadata": ResultRecordMetadata,
42
- }
43
- )
44
- prefect.client.schemas.StateCreate.model_rebuild(
45
- _types_namespace={
46
- "BaseResult": BaseResult,
47
- "ResultRecordMetadata": ResultRecordMetadata,
48
- }
30
+ _types: dict[str, Any] = dict(
31
+ Task=Task,
32
+ Flow=Flow,
33
+ BaseResult=BaseResult,
34
+ ResultRecordMetadata=ResultRecordMetadata,
49
35
  )
36
+ prefect.context.FlowRunContext.model_rebuild(_types_namespace=_types)
37
+ prefect.context.TaskRunContext.model_rebuild(_types_namespace=_types)
38
+ prefect.client.schemas.State.model_rebuild(_types_namespace=_types)
39
+ prefect.client.schemas.StateCreate.model_rebuild(_types_namespace=_types)
40
+ prefect.client.schemas.OrchestrationResult.model_rebuild(_types_namespace=_types)
50
41
  Transaction.model_rebuild()
51
42
 
52
43
  # Configure logging
@@ -76,6 +67,7 @@ __all__ = [
76
67
  "flow",
77
68
  "Flow",
78
69
  "get_client",
70
+ "get_cloud_client",
79
71
  "get_run_logger",
80
72
  "State",
81
73
  "tags",
@@ -84,6 +76,7 @@ __all__ = [
84
76
  "Transaction",
85
77
  "unmapped",
86
78
  "serve",
79
+ "aserve",
87
80
  "deploy",
88
81
  "pause_flow_run",
89
82
  "resume_flow_run",
prefect/runner/runner.py CHANGED
@@ -43,7 +43,17 @@ import threading
43
43
  from copy import deepcopy
44
44
  from functools import partial
45
45
  from pathlib import Path
46
- from typing import TYPE_CHECKING, Callable, Dict, Iterable, List, Optional, Set, Union
46
+ from typing import (
47
+ TYPE_CHECKING,
48
+ Any,
49
+ Callable,
50
+ Dict,
51
+ Iterable,
52
+ List,
53
+ Optional,
54
+ Set,
55
+ Union,
56
+ )
47
57
  from uuid import UUID, uuid4
48
58
 
49
59
  import anyio
@@ -190,7 +200,7 @@ class Runner:
190
200
  self._cancelling_flow_run_ids = set()
191
201
  self._scheduled_task_scopes = set()
192
202
  self._deployment_ids: Set[UUID] = set()
193
- self._flow_run_process_map: Dict[UUID, Dict] = dict()
203
+ self._flow_run_process_map: dict[UUID, dict[str, Any]] = dict()
194
204
 
195
205
  self._tmp_dir: Path = (
196
206
  Path(tempfile.gettempdir()) / "runner_storage" / str(uuid4())
@@ -432,10 +442,14 @@ class Runner:
432
442
  )
433
443
  )
434
444
 
435
- def execute_in_background(self, func, *args, **kwargs):
445
+ def execute_in_background(
446
+ self, func: Callable[..., Any], *args: Any, **kwargs: Any
447
+ ):
436
448
  """
437
449
  Executes a function in the background.
438
450
  """
451
+ if TYPE_CHECKING:
452
+ assert self._loop is not None
439
453
 
440
454
  return asyncio.run_coroutine_threadsafe(func(*args, **kwargs), self._loop)
441
455
 
@@ -536,7 +550,7 @@ class Runner:
536
550
  async def _run_process(
537
551
  self,
538
552
  flow_run: "FlowRun",
539
- task_status: Optional[anyio.abc.TaskStatus] = None,
553
+ task_status: Optional[anyio.abc.TaskStatus[Any]] = None,
540
554
  entrypoint: Optional[str] = None,
541
555
  ):
542
556
  """
@@ -723,7 +737,9 @@ class Runner:
723
737
  return await self._submit_scheduled_flow_runs(flow_run_response=runs_response)
724
738
 
725
739
  async def _check_for_cancelled_flow_runs(
726
- self, should_stop: Callable = lambda: False, on_stop: Callable = lambda: None
740
+ self,
741
+ should_stop: Callable[[], bool] = lambda: False,
742
+ on_stop: Callable[[], None] = lambda: None,
727
743
  ):
728
744
  """
729
745
  Checks for flow runs with CANCELLING a cancelling state and attempts to
@@ -862,31 +878,37 @@ class Runner:
862
878
  flow: "Optional[APIFlow]",
863
879
  deployment: "Optional[Deployment]",
864
880
  ):
865
- related = []
866
- tags = []
881
+ related: list[RelatedResource] = []
882
+ tags: list[str] = []
867
883
  if deployment:
868
884
  related.append(
869
- {
870
- "prefect.resource.id": f"prefect.deployment.{deployment.id}",
871
- "prefect.resource.role": "deployment",
872
- "prefect.resource.name": deployment.name,
873
- }
885
+ RelatedResource(
886
+ {
887
+ "prefect.resource.id": f"prefect.deployment.{deployment.id}",
888
+ "prefect.resource.role": "deployment",
889
+ "prefect.resource.name": deployment.name,
890
+ }
891
+ )
874
892
  )
875
893
  tags.extend(deployment.tags)
876
894
  if flow:
877
895
  related.append(
896
+ RelatedResource(
897
+ {
898
+ "prefect.resource.id": f"prefect.flow.{flow.id}",
899
+ "prefect.resource.role": "flow",
900
+ "prefect.resource.name": flow.name,
901
+ }
902
+ )
903
+ )
904
+ related.append(
905
+ RelatedResource(
878
906
  {
879
- "prefect.resource.id": f"prefect.flow.{flow.id}",
880
- "prefect.resource.role": "flow",
881
- "prefect.resource.name": flow.name,
907
+ "prefect.resource.id": f"prefect.flow-run.{flow_run.id}",
908
+ "prefect.resource.role": "flow-run",
909
+ "prefect.resource.name": flow_run.name,
882
910
  }
883
911
  )
884
- related.append(
885
- {
886
- "prefect.resource.id": f"prefect.flow-run.{flow_run.id}",
887
- "prefect.resource.role": "flow-run",
888
- "prefect.resource.name": flow_run.name,
889
- }
890
912
  )
891
913
  tags.extend(flow_run.tags)
892
914
 
prefect/runner/server.py CHANGED
@@ -1,5 +1,5 @@
1
1
  import uuid
2
- from typing import TYPE_CHECKING, Any, Callable, Dict, Optional, Tuple
2
+ from typing import TYPE_CHECKING, Any, Callable, Coroutine, Hashable, Optional, Tuple
3
3
 
4
4
  import pendulum
5
5
  import uvicorn
@@ -22,7 +22,7 @@ from prefect.settings import (
22
22
  PREFECT_RUNNER_SERVER_MISSED_POLLS_TOLERANCE,
23
23
  PREFECT_RUNNER_SERVER_PORT,
24
24
  )
25
- from prefect.utilities.asyncutils import sync_compatible
25
+ from prefect.utilities.asyncutils import run_coro_as_sync
26
26
  from prefect.utilities.importtools import load_script_as_module
27
27
 
28
28
  if TYPE_CHECKING:
@@ -38,11 +38,13 @@ RunnableEndpoint = Literal["deployment", "flow", "task"]
38
38
 
39
39
  class RunnerGenericFlowRunRequest(BaseModel):
40
40
  entrypoint: str
41
- parameters: Optional[Dict[str, Any]] = None
41
+ parameters: Optional[dict[str, Any]] = None
42
42
  parent_task_run_id: Optional[uuid.UUID] = None
43
43
 
44
44
 
45
- def perform_health_check(runner, delay_threshold: Optional[int] = None) -> JSONResponse:
45
+ def perform_health_check(
46
+ runner: "Runner", delay_threshold: Optional[int] = None
47
+ ) -> Callable[..., JSONResponse]:
46
48
  if delay_threshold is None:
47
49
  delay_threshold = (
48
50
  PREFECT_RUNNER_SERVER_MISSED_POLLS_TOLERANCE.value()
@@ -63,15 +65,15 @@ def perform_health_check(runner, delay_threshold: Optional[int] = None) -> JSONR
63
65
  return _health_check
64
66
 
65
67
 
66
- def run_count(runner) -> int:
67
- def _run_count():
68
- run_count = len(runner._flow_run_process_map)
68
+ def run_count(runner: "Runner") -> Callable[..., int]:
69
+ def _run_count() -> int:
70
+ run_count = len(runner._flow_run_process_map) # pyright: ignore[reportPrivateUsage]
69
71
  return run_count
70
72
 
71
73
  return _run_count
72
74
 
73
75
 
74
- def shutdown(runner) -> int:
76
+ def shutdown(runner: "Runner") -> Callable[..., JSONResponse]:
75
77
  def _shutdown():
76
78
  runner.stop()
77
79
  return JSONResponse(status_code=status.HTTP_200_OK, content={"message": "OK"})
@@ -81,9 +83,9 @@ def shutdown(runner) -> int:
81
83
 
82
84
  async def _build_endpoint_for_deployment(
83
85
  deployment: "DeploymentResponse", runner: "Runner"
84
- ) -> Callable:
86
+ ) -> Callable[..., Coroutine[Any, Any, JSONResponse]]:
85
87
  async def _create_flow_run_for_deployment(
86
- body: Optional[Dict[Any, Any]] = None,
88
+ body: Optional[dict[Any, Any]] = None,
87
89
  ) -> JSONResponse:
88
90
  body = body or {}
89
91
  if deployment.enforce_parameter_schema and deployment.parameter_openapi_schema:
@@ -116,11 +118,11 @@ async def _build_endpoint_for_deployment(
116
118
 
117
119
  async def get_deployment_router(
118
120
  runner: "Runner",
119
- ) -> Tuple[APIRouter, Dict[str, Dict]]:
121
+ ) -> Tuple[APIRouter, dict[Hashable, Any]]:
120
122
  router = APIRouter()
121
- schemas = {}
123
+ schemas: dict[Hashable, Any] = {}
122
124
  async with get_client() as client:
123
- for deployment_id in runner._deployment_ids:
125
+ for deployment_id in runner._deployment_ids: # pyright: ignore[reportPrivateUsage]
124
126
  deployment = await client.read_deployment(deployment_id)
125
127
  router.add_api_route(
126
128
  f"/deployment/{deployment.id}/run",
@@ -142,21 +144,21 @@ async def get_deployment_router(
142
144
  return router, schemas
143
145
 
144
146
 
145
- async def get_subflow_schemas(runner: "Runner") -> Dict[str, Dict]:
147
+ async def get_subflow_schemas(runner: "Runner") -> dict[str, dict[str, Any]]:
146
148
  """
147
149
  Load available subflow schemas by filtering for only those subflows in the
148
150
  deployment entrypoint's import space.
149
151
  """
150
- schemas = {}
152
+ schemas: dict[str, dict[str, Any]] = {}
151
153
  async with get_client() as client:
152
- for deployment_id in runner._deployment_ids:
154
+ for deployment_id in runner._deployment_ids: # pyright: ignore[reportPrivateUsage]
153
155
  deployment = await client.read_deployment(deployment_id)
154
156
  if deployment.entrypoint is None:
155
157
  continue
156
158
 
157
159
  script = deployment.entrypoint.split(":")[0]
158
160
  module = load_script_as_module(script)
159
- subflows = [
161
+ subflows: list[Flow[Any, Any]] = [
160
162
  obj for obj in module.__dict__.values() if isinstance(obj, Flow)
161
163
  ]
162
164
  for flow in subflows:
@@ -165,7 +167,7 @@ async def get_subflow_schemas(runner: "Runner") -> Dict[str, Dict]:
165
167
  return schemas
166
168
 
167
169
 
168
- def _flow_in_schemas(flow: Flow, schemas: Dict[str, Dict]) -> bool:
170
+ def _flow_in_schemas(flow: Flow[Any, Any], schemas: dict[str, dict[str, Any]]) -> bool:
169
171
  """
170
172
  Check if a flow is in the schemas dict, either by name or by name with
171
173
  dashes replaced with underscores.
@@ -174,7 +176,9 @@ def _flow_in_schemas(flow: Flow, schemas: Dict[str, Dict]) -> bool:
174
176
  return flow.name in schemas or flow_name_with_dashes in schemas
175
177
 
176
178
 
177
- def _flow_schema_changed(flow: Flow, schemas: Dict[str, Dict]) -> bool:
179
+ def _flow_schema_changed(
180
+ flow: Flow[Any, Any], schemas: dict[str, dict[str, Any]]
181
+ ) -> bool:
178
182
  """
179
183
  Check if a flow's schemas have changed, either by bame of by name with
180
184
  dashes replaced with underscores.
@@ -188,8 +192,8 @@ def _flow_schema_changed(flow: Flow, schemas: Dict[str, Dict]) -> bool:
188
192
 
189
193
 
190
194
  def _build_generic_endpoint_for_flows(
191
- runner: "Runner", schemas: Dict[str, Dict]
192
- ) -> Callable:
195
+ runner: "Runner", schemas: dict[str, dict[str, Any]]
196
+ ) -> Callable[..., Coroutine[Any, Any, JSONResponse]]:
193
197
  async def _create_flow_run_for_flow_from_fqn(
194
198
  body: RunnerGenericFlowRunRequest,
195
199
  ) -> JSONResponse:
@@ -241,7 +245,6 @@ def _build_generic_endpoint_for_flows(
241
245
  return _create_flow_run_for_flow_from_fqn
242
246
 
243
247
 
244
- @sync_compatible
245
248
  async def build_server(runner: "Runner") -> FastAPI:
246
249
  """
247
250
  Build a FastAPI server for a runner.
@@ -297,16 +300,11 @@ def start_webserver(runner: "Runner", log_level: Optional[str] = None) -> None:
297
300
  host = PREFECT_RUNNER_SERVER_HOST.value()
298
301
  port = PREFECT_RUNNER_SERVER_PORT.value()
299
302
  log_level = log_level or PREFECT_RUNNER_SERVER_LOG_LEVEL.value()
300
- webserver = build_server(runner)
303
+ webserver = run_coro_as_sync(build_server(runner))
304
+ if TYPE_CHECKING:
305
+ assert webserver is not None, "webserver should be built"
306
+ assert log_level is not None, "log_level should be set"
307
+
301
308
  uvicorn.run(
302
309
  webserver, host=host, port=port, log_level=log_level.lower()
303
310
  ) # Uvicorn supports only lowercase log_level
304
- # From the Uvicorn config file:
305
- # LOG_LEVELS: dict[str, int] = {
306
- # "critical": logging.CRITICAL,
307
- # "error": logging.ERROR,
308
- # "warning": logging.WARNING,
309
- # "info": logging.INFO,
310
- # "debug": logging.DEBUG,
311
- # "trace": TRACE_LOG_LEVEL,
312
- # }
prefect/runner/submit.py CHANGED
@@ -42,11 +42,8 @@ async def _submit_flow_to_runner(
42
42
  Returns:
43
43
  A `FlowRun` object representing the flow run that was submitted.
44
44
  """
45
- from prefect.utilities.engine import (
46
- _dynamic_key_for_task_run,
47
- collect_task_run_inputs,
48
- resolve_inputs,
49
- )
45
+ from prefect.utilities._engine import dynamic_key_for_task_run
46
+ from prefect.utilities.engine import collect_task_run_inputs, resolve_inputs
50
47
 
51
48
  async with get_client() as client:
52
49
  if not retry_failed_submissions:
@@ -67,7 +64,7 @@ async def _submit_flow_to_runner(
67
64
  parent_flow_run_context.flow_run.id if parent_flow_run_context else None
68
65
  ),
69
66
  dynamic_key=(
70
- _dynamic_key_for_task_run(parent_flow_run_context, dummy_task)
67
+ dynamic_key_for_task_run(parent_flow_run_context, dummy_task)
71
68
  if parent_flow_run_context
72
69
  else str(uuid.uuid4())
73
70
  ),
prefect/runner/utils.py CHANGED
@@ -1,5 +1,5 @@
1
1
  from copy import deepcopy
2
- from typing import Any, Dict
2
+ from typing import Any
3
3
 
4
4
  from fastapi import FastAPI
5
5
  from fastapi.openapi.utils import get_openapi
@@ -8,8 +8,8 @@ from prefect import __version__ as PREFECT_VERSION
8
8
 
9
9
 
10
10
  def inject_schemas_into_openapi(
11
- webserver: FastAPI, schemas_to_inject: Dict[str, Any]
12
- ) -> Dict[str, Any]:
11
+ webserver: FastAPI, schemas_to_inject: dict[str, Any]
12
+ ) -> dict[str, Any]:
13
13
  """
14
14
  Augments the webserver's OpenAPI schema with additional schemas from deployments / flows / tasks.
15
15
 
@@ -29,8 +29,8 @@ def inject_schemas_into_openapi(
29
29
 
30
30
 
31
31
  def merge_definitions(
32
- injected_schemas: Dict[str, Any], openapi_schema: Dict[str, Any]
33
- ) -> Dict[str, Any]:
32
+ injected_schemas: dict[str, Any], openapi_schema: dict[str, Any]
33
+ ) -> dict[str, Any]:
34
34
  """
35
35
  Integrates definitions from injected schemas into the OpenAPI components.
36
36
 
@@ -69,7 +69,7 @@ def update_refs_in_schema(schema_item: Any, new_ref: str) -> None:
69
69
  update_refs_in_schema(item, new_ref)
70
70
 
71
71
 
72
- def update_refs_to_components(openapi_schema: Dict[str, Any]) -> Dict[str, Any]:
72
+ def update_refs_to_components(openapi_schema: dict[str, Any]) -> dict[str, Any]:
73
73
  """
74
74
  Updates all `$ref` fields in the OpenAPI schema to reference the components section.
75
75
 
@@ -44,6 +44,7 @@ __all__ = [
44
44
  "run_count",
45
45
  "api_url",
46
46
  "ui_url",
47
+ "job_variables",
47
48
  ]
48
49
 
49
50
 
@@ -317,6 +318,11 @@ def get_flow_run_ui_url() -> Optional[str]:
317
318
  return f"{PREFECT_UI_URL.value()}/flow-runs/flow-run/{flow_run_id}"
318
319
 
319
320
 
321
+ def get_job_variables() -> Optional[Dict[str, Any]]:
322
+ flow_run_ctx = FlowRunContext.get()
323
+ return flow_run_ctx.flow_run.job_variables if flow_run_ctx else None
324
+
325
+
320
326
  FIELDS = {
321
327
  "id": get_id,
322
328
  "tags": get_tags,
@@ -331,4 +337,5 @@ FIELDS = {
331
337
  "api_url": get_flow_run_api_url,
332
338
  "ui_url": get_flow_run_ui_url,
333
339
  "flow_version": get_flow_version,
340
+ "job_variables": get_job_variables,
334
341
  }
@@ -1,8 +1,8 @@
1
1
  from pathlib import Path
2
- from typing import Tuple, Type
2
+ from typing import Any, Tuple, Type
3
3
 
4
4
  from pydantic import Secret, SecretStr
5
5
 
6
6
  DEFAULT_PREFECT_HOME = Path.home() / ".prefect"
7
7
  DEFAULT_PROFILES_PATH = Path(__file__).parent.joinpath("profiles.toml")
8
- _SECRET_TYPES: Tuple[Type, ...] = (Secret, SecretStr)
8
+ _SECRET_TYPES: Tuple[Type[Any], ...] = (Secret, SecretStr)
@@ -8,7 +8,7 @@ from pydantic_settings import BaseSettings
8
8
  from typing_extensions import Self
9
9
 
10
10
  from prefect.settings.base import PrefectBaseSettings
11
- from prefect.settings.constants import _SECRET_TYPES
11
+ from prefect.settings.constants import _SECRET_TYPES # type: ignore[reportPrivateUsage]
12
12
  from prefect.settings.context import get_current_settings
13
13
  from prefect.settings.models.root import Settings
14
14
 
@@ -135,3 +135,13 @@ class ServerEventsSettings(PrefectBaseSettings):
135
135
  "prefect_messaging_cache",
136
136
  ),
137
137
  )
138
+
139
+ maximum_event_name_length: int = Field(
140
+ default=1024,
141
+ gt=0,
142
+ description="The maximum length of an event name.",
143
+ validation_alias=AliasChoices(
144
+ AliasPath("maximum_event_name_length"),
145
+ "prefect_server_events_maximum_event_name_length",
146
+ ),
147
+ )
@@ -121,7 +121,7 @@ class ProfileSettingsTomlLoader(PydanticBaseSettingsSource):
121
121
  """Helper method to load the profile settings from the profiles.toml file"""
122
122
 
123
123
  if not self.profiles_path.exists():
124
- return {}
124
+ return self._get_default_profile()
125
125
 
126
126
  try:
127
127
  all_profile_data = toml.load(self.profiles_path)
@@ -146,9 +146,16 @@ class ProfileSettingsTomlLoader(PydanticBaseSettingsSource):
146
146
  profiles_data = all_profile_data.get("profiles", {})
147
147
 
148
148
  if not active_profile or active_profile not in profiles_data:
149
- return {}
149
+ return self._get_default_profile()
150
150
  return profiles_data[active_profile]
151
151
 
152
+ def _get_default_profile(self) -> Dict[str, Any]:
153
+ """Helper method to get the default profile"""
154
+ default_profile_data = toml.load(DEFAULT_PROFILES_PATH)
155
+ default_profile = default_profile_data.get("active", "ephemeral")
156
+ assert isinstance(default_profile, str)
157
+ return default_profile_data.get("profiles", {}).get(default_profile, {})
158
+
152
159
  def get_field_value(
153
160
  self, field: FieldInfo, field_name: str
154
161
  ) -> Tuple[Any, str, bool]: