Skip to content

Commit

Permalink
fix: minor typos (PrefectHQ#10813)
Browse files Browse the repository at this point in the history
  • Loading branch information
mj0nez authored Sep 25, 2023
1 parent d739f53 commit 271b76d
Show file tree
Hide file tree
Showing 97 changed files with 171 additions and 171 deletions.
18 changes: 9 additions & 9 deletions RELEASE-NOTES.md
Original file line number Diff line number Diff line change
Expand Up @@ -477,7 +477,7 @@ See the [flows documentation](https://docs.prefect.io/latest/concepts/flows/#vis
### Documentation
- Elevate Guides in navigation and remove migration guide — https://github.com/PrefectHQ/prefect/pull/10361
- Update notes about community support — https://github.com/PrefectHQ/prefect/pull/10322
- Update concepts page to clean up table and remove unneccessary header — https://github.com/PrefectHQ/prefect/pull/10374
- Update concepts page to clean up table and remove unnecessary header — https://github.com/PrefectHQ/prefect/pull/10374
- Improve headings on deployments concept page — https://github.com/PrefectHQ/prefect/pull/10366
- Update the storage guide for Bitbucket to add `x-token-auth`https://github.com/PrefectHQ/prefect/pull/10379
- Add Planetary Computer collection — https://github.com/PrefectHQ/prefect/pull/10387
Expand Down Expand Up @@ -1285,7 +1285,7 @@ See the following pull requests for implementation details:

### Fixes
- Fix bug where `SIGTERM` was not properly captured as a flow run crash for flow runs created by a deployment — https://github.com/PrefectHQ/prefect/pull/9543
- Fix deadlock when logging is overriden from an asynchronous context — https://github.com/PrefectHQ/prefect/pull/9602
- Fix deadlock when logging is overridden from an asynchronous context — https://github.com/PrefectHQ/prefect/pull/9602
- Fix orchestration race conditions by adding lock for update to flow run state transitions — https://github.com/PrefectHQ/prefect/pull/9590
- Fix date range filter on flow runs page — https://github.com/PrefectHQ/prefect/pull/9636
- Fix bug where ephemeral server raised exceptions client-side — https://github.com/PrefectHQ/prefect/pull/9637
Expand Down Expand Up @@ -1417,7 +1417,7 @@ See the [pull request](https://github.com/PrefectHQ/prefect/pull/9418) for imple
### Enhancements
- Prevent unnecessarily verbose logs by updating `log_prints` to ignore prints where a custom `file` is used — https://github.com/PrefectHQ/prefect/pull/9358
- Create a process work pool by default when a new worker is started with a new work pool name and no type — https://github.com/PrefectHQ/prefect/pull/9326
- Add support for asyncronous project steps — https://github.com/PrefectHQ/prefect/pull/9388
- Add support for asynchronous project steps — https://github.com/PrefectHQ/prefect/pull/9388
- Update `critical_service_loop` to retry on all 5XX HTTP status codes — https://github.com/PrefectHQ/prefect/pull/9400
- Add backoff on failure to agent critical loop services — https://github.com/PrefectHQ/prefect/pull/9402
- Add print statement to `git pull` to isolate issues between clone and execution — https://github.com/PrefectHQ/prefect/pull/9328
Expand Down Expand Up @@ -2246,7 +2246,7 @@ if __name__ == "__main__":
## Release 2.8.2

### Fixes
- Reenable plugin loading in `prefect` module init — https://github.com/PrefectHQ/prefect/pull/8569
- Re-enable plugin loading in `prefect` module init — https://github.com/PrefectHQ/prefect/pull/8569

### Documentation
- Fix logging format override example — https://github.com/PrefectHQ/prefect/pull/8565
Expand Down Expand Up @@ -2411,7 +2411,7 @@ To learn more about work pools, check out the [docs](https://docs.prefect.io/con
### Fixes
- Fix `prefect dev start` command — https://github.com/PrefectHQ/prefect/pull/8176
- Fix display of long log messages when in the UI — https://github.com/PrefectHQ/prefect/pull/8449
- Update `get_run_logger` to accomodate returning `logging.LoggerAdapter`https://github.com/PrefectHQ/prefect/pull/8422
- Update `get_run_logger` to accommodate returning `logging.LoggerAdapter`https://github.com/PrefectHQ/prefect/pull/8422
- Restore Prefect wrapper around HTTP errors for nicer error messages — https://github.com/PrefectHQ/prefect/pull/8391
- Fix display of work pool flow run filter in the UI — https://github.com/PrefectHQ/prefect/pull/8453

Expand Down Expand Up @@ -2528,7 +2528,7 @@ Updated profile 'default'.
- Update Docker images to update preinstalled packages on build — https://github.com/PrefectHQ/prefect/pull/8288
- Add PREFECT_LOGGING_TO_API_WHEN_MISSING_FLOW to allow loggers to be used outside of flows — https://github.com/PrefectHQ/prefect/pull/8311
- Display Runs before Deployments on flow pages — https://github.com/PrefectHQ/prefect/pull/8386
- Clearify output CLI message when switching profiles — https://github.com/PrefectHQ/prefect/pull/8383
- Clarify output CLI message when switching profiles — https://github.com/PrefectHQ/prefect/pull/8383

### Fixes
- Fix bug preventing agents from properly updating Cancelling runs to a Cancelled state — https://github.com/PrefectHQ/prefect/pull/8315
Expand Down Expand Up @@ -3994,13 +3994,13 @@ Blocks are a convenient way to secure store and retrieve configuration. Now, ret

## 2.0b14

### Retreive the state of your tasks or flows with the `return_state` kwarg
### Retrieve the state of your tasks or flows with the `return_state` kwarg
Beginning with 2.0b9, Prefect 2.0 began returning function results, instead of Prefect futures and states, by default. States are still an important concept in Prefect 2. They can be used to dictate and understand the behavior of your flows. Now, you can access the state for _any_ task or flow with the new `return_state` kwarg. Just set `return_state=True` in you flow or task call and you can access its state with the `.result()` method, even if it's been submitted to a task runner.

### `prefect cloud` commands are easier to use
The `prefect cloud login` command no longer overwrites your current profile with a new API URL and auth key. Instead, the command will prompt you to create a new profile when logging into Prefect Cloud 2.0. Subsequent calls to prefect cloud login using the same key will simply "log in" to prefect cloud by switching to the profile associated with that authentication key.

The new `prefect cloud workspace ls` command lists availible workspaces.
The new `prefect cloud workspace ls` command lists available workspaces.

### Other improvements and bug fixes
- The anchor datetime (aka start datetime) for all newly created interval schedules will be the current date & time
Expand Down Expand Up @@ -4338,7 +4338,7 @@ You might not see these fixes in your day-to-day, but we're dedicated to improvi

### Bug fixes

- The CLI no longer displays tracebacks on sucessful exit.
- The CLI no longer displays tracebacks on successful exit.
- Returning pandas objects from tasks does not error.
- Flows are listed correctly in the UI dashboard.

Expand Down
2 changes: 1 addition & 1 deletion docs/cloud/cloud-quickstart.md
Original file line number Diff line number Diff line change
Expand Up @@ -23,7 +23,7 @@ Get started with Prefect Cloud in just a few steps:
1. [Run a flow](#run-a-flow-with-prefect-cloud) locally and view flow run execution in Prefect Cloud.

<!--
TK commented out until video udpated
TK commented out until video updated
TK to hide TOC for video: add hide: toc
Prefer to follow this tutorial in a video? We've got exactly what you need. Happy engineering!
Expand Down
2 changes: 1 addition & 1 deletion docs/cloud/index.md
Original file line number Diff line number Diff line change
Expand Up @@ -19,7 +19,7 @@ search:

Prefect Cloud is a workflow orchestration platform that provides all the capabilities of Prefect server plus additional features, such as:

- automations, events, and webhooks so you can create for event-driven workfows
- automations, events, and webhooks so you can create for event-driven workflows
- workspaces, RBAC, SSO, audit logs and related user management tools for collaboration
- push work pools for running flows on serverless infrastructure without a worker
- error summaries powered by Marvin AI to help you resolve errors faster
Expand Down
4 changes: 2 additions & 2 deletions docs/concepts/automations.md
Original file line number Diff line number Diff line change
Expand Up @@ -50,7 +50,7 @@ Triggers specify the conditions under which your action should be performed. Tri
- Custom event triggers

!!! note "Automations API"
The [automations API](https://app.prefect.cloud/api/docs#tag/Automations) enables further programatic customization of trigger and action policies based on arbitrary [events](https://app.prefect.cloud/api/docs#tag/Events).
The [automations API](https://app.prefect.cloud/api/docs#tag/Automations) enables further programmatic customization of trigger and action policies based on arbitrary [events](https://app.prefect.cloud/api/docs#tag/Events).

Importantly, triggers can be configured not only in reaction to events, but also proactively: to trigger in the absence of an event you expect to see.

Expand Down Expand Up @@ -233,7 +233,7 @@ You can access properties of the underlying flow run objects including:
- [work_queue](/api-ref/server/schemas/core/#prefect.server.schemas.core.WorkQueue)
- [work_pool](/api-ref/server/schemas/core/#prefect.server.schemas.core.WorkPool)

In addition to its native properites, each object includes an `id` along with `created` and `updated` timestamps.
In addition to its native properties, each object includes an `id` along with `created` and `updated` timestamps.

The `flow_run|ui_url` token returns the URL for viewing the flow run in Prefect Cloud.

Expand Down
2 changes: 1 addition & 1 deletion docs/concepts/states.md
Original file line number Diff line number Diff line change
Expand Up @@ -50,7 +50,7 @@ The full complement of states and state types includes:
| Pending | PENDING | No | The run has been submitted to run, but is waiting on necessary preconditions to be satisfied. |
| Running | RUNNING | No | The run code is currently executing. |
| Retrying | RUNNING | No | The run code is currently executing after previously not complete successfully. |
| Paused | PAUSED | No | The run code has stopped executing until it recieves manual approval to proceed. |
| Paused | PAUSED | No | The run code has stopped executing until it receives manual approval to proceed. |
| Cancelling | CANCELLING | No | The infrastructure on which the code was running is being cleaned up. |
| Cancelled | CANCELLED | Yes | The run did not complete because a user determined that it should not. |
| Completed | COMPLETED | Yes | The run completed successfully. |
Expand Down
2 changes: 1 addition & 1 deletion docs/concepts/task-runners.md
Original file line number Diff line number Diff line change
@@ -1,5 +1,5 @@
---
description: Prefect task runners let you specify the executors for tasks in a flow run, including returning a PrefectFuture contianing both results and state.
description: Prefect task runners let you specify the executors for tasks in a flow run, including returning a PrefectFuture containing both results and state.
tags:
- tasks
- task runners
Expand Down
2 changes: 1 addition & 1 deletion docs/contributing/style.md
Original file line number Diff line number Diff line change
Expand Up @@ -190,7 +190,7 @@ Additionally:
- Capitalize placeholder labels and wrap them in less than (<) and greater than (>) signs.
- Utilize `textwrap.dedent` to remove extraneous spacing for strings that are written with triple quotes (""").

Placholder Example:
Placeholder Example:
```bash
Create a work queue with tags:
prefect work-queue create '<WORK QUEUE NAME>' -t '<OPTIONAL TAG 1>' -t '<OPTIONAL TAG 2>'
Expand Down
4 changes: 2 additions & 2 deletions docs/contributing/versioning.md
Original file line number Diff line number Diff line change
Expand Up @@ -13,7 +13,7 @@ search:

Versions are composed of three parts: MAJOR.MINOR.PATCH. For example, the version 2.5.0 has a major version of 2, a minor version of 5, and patch version of 0.

Ocassionally, we will add a suffix to the version such as `rc`, `a`, or `b`. These indicate pre-release versions that users can opt-into installing to test functionality before it is ready for release.
Occasionally, we will add a suffix to the version such as `rc`, `a`, or `b`. These indicate pre-release versions that users can opt-into installing to test functionality before it is ready for release.

Each release will increase one of the version numbers. If we increase a number other than the patch version, the versions to the right of it will be reset to zero.

Expand All @@ -24,7 +24,7 @@ Prefect will increase the major version when significant and widespread changes
Prefect will increase the minor version when:

- Introducing a new concept that changes how Prefect can be used
- Changing an existing concept in a way that fundementally alters how it is used
- Changing an existing concept in a way that fundamentally alters how it is used
- Removing a deprecated feature

Prefect will increase the patch version when:
Expand Down
2 changes: 1 addition & 1 deletion docs/guides/runtime-context.md
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,7 @@ search:

Prefect tracks information about the current flow or task run with a run context. The run context can be thought of as a global variable that allows the Prefect engine to determine relationships between your runs, e.g. which flow your task is called from.

The run context itself contains many internal objects used by Prefect to manage execution of your run and is only available in specific situtations. For this reason, we expose a simple interface that only includes the items you care about and dynamically retrieves additional information when necessary. We call this the "runtime context" as it contains information that can only be accessed when a run is happening.
The run context itself contains many internal objects used by Prefect to manage execution of your run and is only available in specific situations. For this reason, we expose a simple interface that only includes the items you care about and dynamically retrieves additional information when necessary. We call this the "runtime context" as it contains information that can only be accessed when a run is happening.

!!! tip "Mock values via environment variable"
Oftentimes, you may want to mock certain values for testing purposes. For example, by manually setting an ID or a scheduled start time to ensure your code is functioning properly. Starting in version `2.10.3`, you can mock values in runtime via environment variable using the schema `PREFECT__RUNTIME__{SUBMODULE}__{KEY_NAME}=value`:
Expand Down
2 changes: 1 addition & 1 deletion flows/deployment_run.py
Original file line number Diff line number Diff line change
Expand Up @@ -8,7 +8,7 @@
import prefect
from prefect.deployments import Deployment

# The version oldest verison this test runs with
# The version oldest version this test runs with
SUPPORTED_VERSION = "2.6.0"


Expand Down
2 changes: 1 addition & 1 deletion flows/deployment_storage.py
Original file line number Diff line number Diff line change
Expand Up @@ -10,7 +10,7 @@
from prefect.deployments import Deployment
from prefect.filesystems import LocalFileSystem

# The version oldest verison this test runs with
# The version oldest version this test runs with
SUPPORTED_VERSION = "2.6.0"


Expand Down
2 changes: 1 addition & 1 deletion src/prefect/_internal/compatibility/experimental.py
Original file line number Diff line number Diff line change
Expand Up @@ -38,7 +38,7 @@

class ExperimentalWarning(Warning):
"""
A warning related to expirimental code.
A warning related to experimental code.
"""


Expand Down
4 changes: 2 additions & 2 deletions src/prefect/_internal/concurrency/calls.py
Original file line number Diff line number Diff line change
Expand Up @@ -120,7 +120,7 @@ def cancel(self):
if self._cancel_scope is None:
return False
elif not self._cancel_scope.cancelled():
# Perfom cancellation
# Perform cancellation
if not self._cancel_scope.cancel():
return False

Expand Down Expand Up @@ -366,7 +366,7 @@ def __call__(self) -> T:
"""
Execute the call and return its result.
All executions during excecution of the call are re-raised.
All executions during execution of the call are re-raised.
"""
coro = self.run()

Expand Down
2 changes: 1 addition & 1 deletion src/prefect/_internal/concurrency/inspection.py
Original file line number Diff line number Diff line change
Expand Up @@ -10,7 +10,7 @@
from typing import List

"""
The following functions are dervived from dask/distributed which is licensed under the
The following functions are derived from dask/distributed which is licensed under the
BSD 3-Clause License.
Copyright (c) 2015, Anaconda, Inc. and contributors
Expand Down
4 changes: 2 additions & 2 deletions src/prefect/_internal/concurrency/services.py
Original file line number Diff line number Diff line change
Expand Up @@ -102,7 +102,7 @@ def send(self, item: T):
if self._stopped:
raise RuntimeError("Cannot put items in a stopped service instance.")

logger.debug("Service %r enqueing item %r", self, item)
logger.debug("Service %r enqueuing item %r", self, item)
self._queue.put_nowait(self._prepare_item(item))

def _prepare_item(self, item: T) -> T:
Expand Down Expand Up @@ -223,7 +223,7 @@ def drain_all(cls, timeout: Optional[float] = None) -> Union[Awaitable, None]:
[asyncio.wrap_future(fut) for fut in futures], timeout=timeout
)
if futures
# `wait` errors if it receieves an empty list but we need to return a
# `wait` errors if it receives an empty list but we need to return a
# coroutine still
else asyncio.sleep(0)
)
Expand Down
2 changes: 1 addition & 1 deletion src/prefect/_version.py
Original file line number Diff line number Diff line change
Expand Up @@ -330,7 +330,7 @@ def git_pieces_from_vcs(tag_prefix, root, verbose, runner=run_command):
# TAG-NUM-gHEX
mo = re.search(r"^(.+)-(\d+)-g([0-9a-f]+)$", git_describe)
if not mo:
# unparseable. Maybe git-describe is misbehaving?
# unparsable. Maybe git-describe is misbehaving?
pieces["error"] = "unable to parse git-describe output: '%s'" % describe_out
return pieces

Expand Down
4 changes: 2 additions & 2 deletions src/prefect/agent.py
Original file line number Diff line number Diff line change
Expand Up @@ -469,7 +469,7 @@ async def submit_run(self, flow_run: FlowRun) -> None:
)
except Exception:
self.logger.exception(
"An error occured while setting the `infrastructure_pid`"
"An error occurred while setting the `infrastructure_pid`"
f" on flow run {flow_run.id!r}. The flow run will not be"
" cancellable."
)
Expand Down Expand Up @@ -510,7 +510,7 @@ async def _submit_run_and_capture_errors(
)
else:
self.logger.exception(
f"An error occured while monitoring flow run '{flow_run.id}'. "
f"An error occurred while monitoring flow run '{flow_run.id}'. "
"The flow run will not be marked as failed, but an issue may have "
"occurred."
)
Expand Down
4 changes: 2 additions & 2 deletions src/prefect/blocks/core.py
Original file line number Diff line number Diff line change
Expand Up @@ -667,14 +667,14 @@ def _event_method_called_resources(self) -> Optional[ResourceTuple]:
@classmethod
def get_block_class_from_schema(cls: Type[Self], schema: BlockSchema) -> Type[Self]:
"""
Retieve the block class implementation given a schema.
Retrieve the block class implementation given a schema.
"""
return cls.get_block_class_from_key(block_schema_to_key(schema))

@classmethod
def get_block_class_from_key(cls: Type[Self], key: str) -> Type[Self]:
"""
Retieve the block class implementation given a key.
Retrieve the block class implementation given a key.
"""
# Ensure collections are imported and have the opportunity to register types
# before looking up the block class
Expand Down
2 changes: 1 addition & 1 deletion src/prefect/cli/dev.py
Original file line number Diff line number Diff line change
Expand Up @@ -357,7 +357,7 @@ def build_image(
Build a docker image for development.
"""
exit_with_error_if_not_editable_install()
# TODO: Once https://github.com/tiangolo/typer/issues/354 is addresesd, the
# TODO: Once https://github.com/tiangolo/typer/issues/354 is addressed, the
# default can be set in the function signature
arch = arch or platform.machine()
python_version = python_version or python_version_minor()
Expand Down
2 changes: 1 addition & 1 deletion src/prefect/cli/flow_run.py
Original file line number Diff line number Diff line change
Expand Up @@ -141,7 +141,7 @@ async def cancel(id: UUID):
f" '{result.details.reason}'"
)

exit_with_success(f"Flow run '{id}' was succcessfully scheduled for cancellation.")
exit_with_success(f"Flow run '{id}' was successfully scheduled for cancellation.")


@flow_run_app.command()
Expand Down
2 changes: 1 addition & 1 deletion src/prefect/cli/profile.py
Original file line number Diff line number Diff line change
Expand Up @@ -271,7 +271,7 @@ async def check_orion_connection():
return ConnectionStatus.CLOUD_UNAUTHORIZED
except httpx.HTTPStatusError as exc:
if exc.response.status_code == status.HTTP_404_NOT_FOUND:
# if the route does not exist, attmpt to connect as a hosted Prefect
# if the route does not exist, attempt to connect as a hosted Prefect
# instance
try:
# inform the user if Prefect API endpoints exist, but there are
Expand Down
2 changes: 1 addition & 1 deletion src/prefect/cli/server.py
Original file line number Diff line number Diff line change
Expand Up @@ -75,7 +75,7 @@ def generate_welcome_blurb(base_url, ui_enabled: bool):

dashboard_disabled = textwrap.dedent(
"""
The dashboard is disabled. Set `PREFECT_UI_ENABLED=1` to reenable it.
The dashboard is disabled. Set `PREFECT_UI_ENABLED=1` to re-enable it.
"""
)

Expand Down
2 changes: 1 addition & 1 deletion src/prefect/client/schemas/objects.py
Original file line number Diff line number Diff line change
Expand Up @@ -1212,7 +1212,7 @@ def evaluate_health_status(
self, late_runs_count: int, last_polled: Optional[DateTimeTZ] = None
) -> bool:
"""
Given empirical information about the state of the work queue, evaulate its health status.
Given empirical information about the state of the work queue, evaluate its health status.
Args:
late_runs: the count of late runs for the work queue.
Expand Down
Loading

0 comments on commit 271b76d

Please sign in to comment.