Skip to content

Commit

Permalink
Use raw links instead of markdown
Browse files Browse the repository at this point in the history
  • Loading branch information
mitchnielsen committed Feb 27, 2025
1 parent c5d885f commit 9abad69
Show file tree
Hide file tree
Showing 23 changed files with 66 additions and 66 deletions.
44 changes: 22 additions & 22 deletions docs/v3/api-ref/rest-api/server/schema.json
Original file line number Diff line number Diff line change
Expand Up @@ -58,7 +58,7 @@
"Flows"
],
"summary": "Create Flow",
"description": "Gracefully creates a new flow from the provided schema. If a flow with the\nsame name already exists, the existing flow is returned.\n\nFor more information, see [flows](https://docs.prefect.io/v3/develop/write-flows).",
"description": "Gracefully creates a new flow from the provided schema. If a flow with the\nsame name already exists, the existing flow is returned.\n\nFor more information, see https://docs.prefect.io/v3/develop/write-flows.",
"operationId": "create_flow_flows__post",
"parameters": [
{
Expand Down Expand Up @@ -483,7 +483,7 @@
"Flow Runs"
],
"summary": "Create Flow Run",
"description": "Create a flow run. If a flow run with the same flow_id and\nidempotency key already exists, the existing flow run will be returned.\n\nIf no state is provided, the flow run will be created in a PENDING state.\n\nFor more information, see [flow runs](https://docs.prefect.io/v3/develop/write-flows).",
"description": "Create a flow run. If a flow run with the same flow_id and\nidempotency key already exists, the existing flow run will be returned.\n\nIf no state is provided, the flow run will be created in a PENDING state.\n\nFor more information, see https://docs.prefect.io/v3/develop/write-flows.",
"operationId": "create_flow_run_flow_runs__post",
"parameters": [
{
Expand Down Expand Up @@ -1593,7 +1593,7 @@
"Task Runs"
],
"summary": "Create Task Run",
"description": "Create a task run. If a task run with the same flow_run_id,\ntask_key, and dynamic_key already exists, the existing task\nrun will be returned.\n\nIf no state is provided, the task run will be created in a PENDING state.\n\nFor more information, see [write and run tasks](https://docs.prefect.io/v3/develop/write-tasks).",
"description": "Create a task run. If a task run with the same flow_run_id,\ntask_key, and dynamic_key already exists, the existing task\nrun will be returned.\n\nIf no state is provided, the task run will be created in a PENDING state.\n\nFor more information, see https://docs.prefect.io/v3/develop/write-tasks.",
"operationId": "create_task_run_task_runs__post",
"parameters": [
{
Expand Down Expand Up @@ -2034,7 +2034,7 @@
"Flow Run States"
],
"summary": "Read Flow Run State",
"description": "Get a flow run state by id.\n\nFor more information, see [write and run flows](https://docs.prefect.io/v3/develop/write-flows#final-state-determination).",
"description": "Get a flow run state by id.\n\nFor more information, see https://docs.prefect.io/v3/develop/write-flows#final-state-determination.",
"operationId": "read_flow_run_state_flow_run_states__id__get",
"parameters": [
{
Expand Down Expand Up @@ -2146,7 +2146,7 @@
"Task Run States"
],
"summary": "Read Task Run State",
"description": "Get a task run state by id.\n\nFor more information, see [write and run tasks](https://docs.prefect.io/v3/develop/write-tasks).",
"description": "Get a task run state by id.\n\nFor more information, see https://docs.prefect.io/v3/develop/write-tasks.",
"operationId": "read_task_run_state_task_run_states__id__get",
"parameters": [
{
Expand Down Expand Up @@ -2258,7 +2258,7 @@
"Flow Run Notification Policies"
],
"summary": "Create Flow Run Notification Policy",
"description": "Creates a new flow run notification policy.\n\nFor more information, see [trigger actions on events](https://docs.prefect.io/v3/automate/events/automations-triggers#sending-notifications-with-automations).",
"description": "Creates a new flow run notification policy.\n\nFor more information, see https://docs.prefect.io/v3/automate/events/automations-triggers#sending-notifications-with-automations.",
"operationId": "create_flow_run_notification_policy_flow_run_notification_policies__post",
"parameters": [
{
Expand Down Expand Up @@ -2524,7 +2524,7 @@
"Deployments"
],
"summary": "Create Deployment",
"description": "Gracefully creates a new deployment from the provided schema. If a deployment with\nthe same name and flow_id already exists, the deployment is updated.\n\nIf the deployment has an active schedule, flow runs will be scheduled.\nWhen upserting, any scheduled runs from the existing deployment will be deleted.\n\nFor more information, see [deployments](https://docs.prefect.io/v3/deploy).",
"description": "Gracefully creates a new deployment from the provided schema. If a deployment with\nthe same name and flow_id already exists, the deployment is updated.\n\nIf the deployment has an active schedule, flow runs will be scheduled.\nWhen upserting, any scheduled runs from the existing deployment will be deleted.\n\nFor more information, see https://docs.prefect.io/v3/deploy.",
"operationId": "create_deployment_deployments__post",
"parameters": [
{
Expand Down Expand Up @@ -3775,7 +3775,7 @@
"Logs"
],
"summary": "Create Logs",
"description": "Create new logs from the provided schema.\n\nFor more information, see [configure logging](https://docs.prefect.io/v3/develop/logging).",
"description": "Create new logs from the provided schema.\n\nFor more information, see https://docs.prefect.io/v3/develop/logging.",
"operationId": "create_logs_logs__post",
"parameters": [
{
Expand Down Expand Up @@ -3886,7 +3886,7 @@
"Concurrency Limits"
],
"summary": "Create Concurrency Limit",
"description": "Create a task run concurrency limit.\n\nFor more information, see [manage concurrency](https://docs.prefect.io/v3/develop/task-run-limits).",
"description": "Create a task run concurrency limit.\n\nFor more information, see https://docs.prefect.io/v3/develop/task-run-limits.",
"operationId": "create_concurrency_limit_concurrency_limits__post",
"parameters": [
{
Expand Down Expand Up @@ -4369,7 +4369,7 @@
"Concurrency Limits V2"
],
"summary": "Create Concurrency Limit V2",
"description": "Create a task run concurrency limit.\n\nFor more information, see [manage concurrency](https://docs.prefect.io/v3/develop/global-concurrency-limits).",
"description": "Create a task run concurrency limit.\n\nFor more information, see https://docs.prefect.io/v3/develop/global-concurrency-limits.",
"operationId": "create_concurrency_limit_v2_v2_concurrency_limits__post",
"parameters": [
{
Expand Down Expand Up @@ -4764,7 +4764,7 @@
"Block types"
],
"summary": "Create Block Type",
"description": "Create a new block type.\n\nFor more information, see [securely store typed configuration](https://docs.prefect.io/v3/develop/blocks).",
"description": "Create a new block type.\n\nFor more information, see https://docs.prefect.io/v3/develop/blocks.",
"operationId": "create_block_type_block_types__post",
"parameters": [
{
Expand Down Expand Up @@ -5272,7 +5272,7 @@
"Block documents"
],
"summary": "Create Block Document",
"description": "Create a new block document.\n\nFor more information, see [securely store typed configuration](https://docs.prefect.io/v3/develop/blocks).",
"description": "Create a new block document.\n\nFor more information, see https://docs.prefect.io/v3/develop/blocks.",
"operationId": "create_block_document_block_documents__post",
"parameters": [
{
Expand Down Expand Up @@ -5600,7 +5600,7 @@
"Work Pools"
],
"summary": "Create Work Pool",
"description": "Creates a new work pool. If a work pool with the same\nname already exists, an error will be raised.\n\nFor more information, see [work pools](https://docs.prefect.io/v3/deploy/infrastructure-concepts/work-pools).",
"description": "Creates a new work pool. If a work pool with the same\nname already exists, an error will be raised.\n\nFor more information, see https://docs.prefect.io/v3/deploy/infrastructure-concepts/work-pools.",
"operationId": "create_work_pool_work_pools__post",
"parameters": [
{
Expand Down Expand Up @@ -5983,7 +5983,7 @@
"Work Pools"
],
"summary": "Create Work Queue",
"description": "Creates a new work pool queue. If a work pool queue with the same\nname already exists, an error will be raised.\n\nFor more information, see [work queues](https://docs.prefect.io/v3/deploy/infrastructure-concepts/work-pools#work-queues).",
"description": "Creates a new work pool queue. If a work pool queue with the same\nname already exists, an error will be raised.\n\nFor more information, see https://docs.prefect.io/v3/deploy/infrastructure-concepts/work-pools#work-queues.",
"operationId": "create_work_queue_work_pools__work_pool_name__queues_post",
"parameters": [
{
Expand Down Expand Up @@ -6482,7 +6482,7 @@
"Task Workers"
],
"summary": "Read Task Workers",
"description": "Read active task workers. Optionally filter by task keys.\n\nFor more information, see [run tasks in the background](https://docs.prefect.io/v3/develop/deferred-tasks).",
"description": "Read active task workers. Optionally filter by task keys.\n\nFor more information, see https://docs.prefect.io/v3/develop/deferred-tasks.",
"operationId": "read_task_workers_task_workers_filter_post",
"parameters": [
{
Expand Down Expand Up @@ -6538,7 +6538,7 @@
"Work Queues"
],
"summary": "Create Work Queue",
"description": "Creates a new work queue.\n\nIf a work queue with the same name already exists, an error\nwill be raised.\n\nFor more information, see [work queues](https://docs.prefect.io/v3/deploy/infrastructure-concepts/work-pools#work-queues).",
"description": "Creates a new work queue.\n\nIf a work queue with the same name already exists, an error\nwill be raised.\n\nFor more information, see https://docs.prefect.io/v3/deploy/infrastructure-concepts/work-pools#work-queues.",
"operationId": "create_work_queue_work_queues__post",
"parameters": [
{
Expand Down Expand Up @@ -7000,7 +7000,7 @@
"Artifacts"
],
"summary": "Create Artifact",
"description": "Create an artifact.\n\nFor more information, see [create run artifacts](https://docs.prefect.io/v3/develop/artifacts).",
"description": "Create an artifact.\n\nFor more information, see https://docs.prefect.io/v3/develop/artifacts.",
"operationId": "create_artifact_artifacts__post",
"parameters": [
{
Expand Down Expand Up @@ -7482,7 +7482,7 @@
"Block schemas"
],
"summary": "Create Block Schema",
"description": "Create a block schema.\n\nFor more information, see [securely store typed configuration](https://docs.prefect.io/v3/develop/blocks).",
"description": "Create a block schema.\n\nFor more information, see https://docs.prefect.io/v3/develop/blocks.",
"operationId": "create_block_schema_block_schemas__post",
"parameters": [
{
Expand Down Expand Up @@ -7763,7 +7763,7 @@
"Block capabilities"
],
"summary": "Read Available Block Capabilities",
"description": "Get available block capabilities.\n\nFor more information, see [securely store typed configuration](https://docs.prefect.io/v3/develop/blocks).",
"description": "Get available block capabilities.\n\nFor more information, see https://docs.prefect.io/v3/develop/blocks.",
"operationId": "read_available_block_capabilities_block_capabilities__get",
"parameters": [
{
Expand Down Expand Up @@ -7863,7 +7863,7 @@
"Variables"
],
"summary": "Create Variable",
"description": "Create a variable.\n\nFor more information, see [get and set variables](https://docs.prefect.io/v3/develop/variables).",
"description": "Create a variable.\n\nFor more information, see https://docs.prefect.io/v3/develop/variables.",
"operationId": "create_variable_variables__post",
"parameters": [
{
Expand Down Expand Up @@ -8367,7 +8367,7 @@
"Events"
],
"summary": "Create Events",
"description": "Record a batch of Events.\n\nFor more information, see [track activity through events](https://docs.prefect.io/v3/automate/events/events).",
"description": "Record a batch of Events.\n\nFor more information, see https://docs.prefect.io/v3/automate/events/events.",
"operationId": "create_events_events_post",
"parameters": [
{
Expand Down Expand Up @@ -8586,7 +8586,7 @@
"Automations"
],
"summary": "Create Automation",
"description": "Create an automation.\n\nFor more information, see [automate](https://docs.prefect.io/v3/automate).",
"description": "Create an automation.\n\nFor more information, see https://docs.prefect.io/v3/automate.",
"operationId": "create_automation_automations__post",
"parameters": [
{
Expand Down
2 changes: 1 addition & 1 deletion src/prefect/server/api/artifacts.py
Original file line number Diff line number Diff line change
Expand Up @@ -29,7 +29,7 @@ async def create_artifact(
"""
Create an artifact.
For more information, see [create run artifacts](https://docs.prefect.io/v3/develop/artifacts).
For more information, see https://docs.prefect.io/v3/develop/artifacts.
"""
artifact = core.Artifact(**artifact.model_dump())

Expand Down
2 changes: 1 addition & 1 deletion src/prefect/server/api/automations.py
Original file line number Diff line number Diff line change
Expand Up @@ -42,7 +42,7 @@ async def create_automation(
"""
Create an automation.
For more information, see [automate](https://docs.prefect.io/v3/automate).
For more information, see https://docs.prefect.io/v3/automate.
"""
# reset any client-provided IDs on the provided triggers
automation.trigger.reset_ids()
Expand Down
2 changes: 1 addition & 1 deletion src/prefect/server/api/block_capabilities.py
Original file line number Diff line number Diff line change
Expand Up @@ -22,7 +22,7 @@ async def read_available_block_capabilities(
"""
Get available block capabilities.
For more information, see [securely store typed configuration](https://docs.prefect.io/v3/develop/blocks).
For more information, see https://docs.prefect.io/v3/develop/blocks.
"""
async with db.session_context() as session:
return await models.block_schemas.read_available_block_capabilities(
Expand Down
2 changes: 1 addition & 1 deletion src/prefect/server/api/block_documents.py
Original file line number Diff line number Diff line change
Expand Up @@ -25,7 +25,7 @@ async def create_block_document(
"""
Create a new block document.
For more information, see [securely store typed configuration](https://docs.prefect.io/v3/develop/blocks).
For more information, see https://docs.prefect.io/v3/develop/blocks.
"""
async with db.session_context(begin_transaction=True) as session:
if block_document.name is not None:
Expand Down
2 changes: 1 addition & 1 deletion src/prefect/server/api/block_schemas.py
Original file line number Diff line number Diff line change
Expand Up @@ -33,7 +33,7 @@ async def create_block_schema(
"""
Create a block schema.
For more information, see [securely store typed configuration](https://docs.prefect.io/v3/develop/blocks).
For more information, see https://docs.prefect.io/v3/develop/blocks.
"""
from prefect.blocks.core import Block

Expand Down
2 changes: 1 addition & 1 deletion src/prefect/server/api/block_types.py
Original file line number Diff line number Diff line change
Expand Up @@ -21,7 +21,7 @@ async def create_block_type(
"""
Create a new block type.
For more information, see [securely store typed configuration](https://docs.prefect.io/v3/develop/blocks).
For more information, see https://docs.prefect.io/v3/develop/blocks.
"""
# API-created blocks cannot start with the word "Prefect"
# as it is reserved for system use
Expand Down
2 changes: 1 addition & 1 deletion src/prefect/server/api/concurrency_limits.py
Original file line number Diff line number Diff line change
Expand Up @@ -31,7 +31,7 @@ async def create_concurrency_limit(
"""
Create a task run concurrency limit.
For more information, see [manage concurrency](https://docs.prefect.io/v3/develop/task-run-limits).
For more information, see https://docs.prefect.io/v3/develop/task-run-limits.
"""
# hydrate the input model into a full model
concurrency_limit_model = schemas.core.ConcurrencyLimit(
Expand Down
2 changes: 1 addition & 1 deletion src/prefect/server/api/concurrency_limits_v2.py
Original file line number Diff line number Diff line change
Expand Up @@ -24,7 +24,7 @@ async def create_concurrency_limit_v2(
"""
Create a task run concurrency limit.
For more information, see [manage concurrency](https://docs.prefect.io/v3/develop/global-concurrency-limits).
For more information, see https://docs.prefect.io/v3/develop/global-concurrency-limits.
"""
async with db.session_context(begin_transaction=True) as session:
model = await models.concurrency_limits_v2.create_concurrency_limit(
Expand Down
2 changes: 1 addition & 1 deletion src/prefect/server/api/deployments.py
Original file line number Diff line number Diff line change
Expand Up @@ -69,7 +69,7 @@ async def create_deployment(
If the deployment has an active schedule, flow runs will be scheduled.
When upserting, any scheduled runs from the existing deployment will be deleted.
For more information, see [deployments](https://docs.prefect.io/v3/deploy).
For more information, see https://docs.prefect.io/v3/deploy.
"""

data = deployment.model_dump(exclude_unset=True)
Expand Down
2 changes: 1 addition & 1 deletion src/prefect/server/api/events.py
Original file line number Diff line number Diff line change
Expand Up @@ -51,7 +51,7 @@ async def create_events(
"""
Record a batch of Events.
For more information, see [track activity through events](https://docs.prefect.io/v3/automate/events/events).
For more information, see https://docs.prefect.io/v3/automate/events/events.
"""
if ephemeral_request:
await EventsPipeline().process_events(events)
Expand Down
2 changes: 1 addition & 1 deletion src/prefect/server/api/flow_run_notification_policies.py
Original file line number Diff line number Diff line change
Expand Up @@ -26,7 +26,7 @@ async def create_flow_run_notification_policy(
"""
Creates a new flow run notification policy.
For more information, see [trigger actions on events](https://docs.prefect.io/v3/automate/events/automations-triggers#sending-notifications-with-automations).
For more information, see https://docs.prefect.io/v3/automate/events/automations-triggers#sending-notifications-with-automations.
"""
async with db.session_context(begin_transaction=True) as session:
return await models.flow_run_notification_policies.create_flow_run_notification_policy(
Expand Down
2 changes: 1 addition & 1 deletion src/prefect/server/api/flow_run_states.py
Original file line number Diff line number Diff line change
Expand Up @@ -27,7 +27,7 @@ async def read_flow_run_state(
"""
Get a flow run state by id.
For more information, see [write and run flows](https://docs.prefect.io/v3/develop/write-flows#final-state-determination).
For more information, see https://docs.prefect.io/v3/develop/write-flows#final-state-determination.
"""
async with db.session_context() as session:
flow_run_state = await models.flow_run_states.read_flow_run_state(
Expand Down
2 changes: 1 addition & 1 deletion src/prefect/server/api/flow_runs.py
Original file line number Diff line number Diff line change
Expand Up @@ -75,7 +75,7 @@ async def create_flow_run(
If no state is provided, the flow run will be created in a PENDING state.
For more information, see [flow runs](https://docs.prefect.io/v3/develop/write-flows).
For more information, see https://docs.prefect.io/v3/develop/write-flows.
"""
# hydrate the input model into a full flow run / state model
flow_run_object = schemas.core.FlowRun(
Expand Down
Loading

0 comments on commit 9abad69

Please sign in to comment.