You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airflow.apache.org by po...@apache.org on 2023/08/26 19:44:51 UTC

[airflow] branch remove-eager-upgrade-from-dockerfile updated (ad388763b3 -> a85cb5abd6)

This is an automated email from the ASF dual-hosted git repository.

potiuk pushed a change to branch remove-eager-upgrade-from-dockerfile
in repository https://gitbox.apache.org/repos/asf/airflow.git


    omit ad388763b3 Remove "eager upgrade" from PROD image completely
     new a85cb5abd6 Remove "eager upgrade" from PROD image completely

This update added new revisions after undoing existing revisions.
That is to say, some revisions that were in the old version of the
branch are not in the new version.  This situation occurs
when a user --force pushes a change and generates a repository
containing something like this:

 * -- * -- B -- O -- O -- O   (ad388763b3)
            \
             N -- N -- N   refs/heads/remove-eager-upgrade-from-dockerfile (a85cb5abd6)

You should already have received notification emails for all of the O
revisions, and so the following emails describe only the N revisions
from the common base, B.

Any revisions marked "omit" are not gone; other references still
refer to them.  Any revisions marked "discard" are gone forever.

The 1 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


Summary of changes:


[airflow] 01/01: Remove "eager upgrade" from PROD image completely

Posted by po...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

potiuk pushed a commit to branch remove-eager-upgrade-from-dockerfile
in repository https://gitbox.apache.org/repos/asf/airflow.git

commit a85cb5abd6cc5ffcc516f5b1158a907883eeb23e
Author: Jarek Potiuk <ja...@potiuk.com>
AuthorDate: Fri Aug 18 23:14:18 2023 +0200

    Remove "eager upgrade" from PROD image completely
    
    There were still some left-overs of EAGER_UPGRADE in PROD image
    building. Howwever "eager upgrade" only makes sense for CI images.
    PROD images when being built should use eager upgrades as they
    are produced in the CI image step.
    
    This PR does the following:
    
    * removes eager upgrade parameters from PROD image
    * instead, prod image build has a new flag for installing
      the images: --use-constraints-for-context-packages which will
      automatically use constraints from "docker-context-files" if
      they are present there.
    * modifies the CI workflows to upload constraints as artifacts
      and download them for PROD image build when "eager upgrade"
      has been used and directs it to use "source" constraints
    * adds back support to "upgrade to newer dependencies" label
      that makes it easy to test "eager upgrade"
    
    As the result, when PROD image is build in CI:
    
    * when regular PR is run, it will use latest github "source" constraints
    * whwn "eager upgrade" PR is run, it will use the eager-upgrade
      constraints that were generated during CI build
---
 .github/actions/build-ci-images/action.yml         |   6 +
 .github/actions/build-prod-images/action.yml       |   9 +-
 Dockerfile                                         |  52 ++++--
 .../airflow_breeze/commands/ci_image_commands.py   |   2 +
 .../commands/ci_image_commands_config.py           |   1 +
 .../commands/production_image_commands.py          |  41 ++---
 .../commands/production_image_commands_config.py   |   4 +-
 dev/breeze/src/airflow_breeze/global_constants.py  |   1 +
 .../src/airflow_breeze/params/build_ci_params.py   |   5 +-
 .../src/airflow_breeze/params/build_prod_params.py |   7 +-
 .../airflow_breeze/params/common_build_params.py   |  14 +-
 .../src/airflow_breeze/utils/common_options.py     |   9 +
 .../src/airflow_breeze/utils/selective_checks.py   |   9 +-
 dev/breeze/tests/test_selective_checks.py          |  21 ++-
 images/breeze/output-commands-hash.txt             |   8 +-
 images/breeze/output-commands.svg                  | 108 ++++++------
 images/breeze/output_ci-image.svg                  |  24 +--
 images/breeze/output_ci-image_build.svg            | 174 +++++++++----------
 images/breeze/output_prod-image.svg                |  24 +--
 images/breeze/output_prod-image_build.svg          | 186 ++++++++++-----------
 .../docker/install_from_docker_context_files.sh    |  45 +++--
 21 files changed, 428 insertions(+), 322 deletions(-)

diff --git a/.github/actions/build-ci-images/action.yml b/.github/actions/build-ci-images/action.yml
index ed613c29ce..d43a425284 100644
--- a/.github/actions/build-ci-images/action.yml
+++ b/.github/actions/build-ci-images/action.yml
@@ -48,6 +48,12 @@ runs:
           cat "files/constraints-${PYTHON_VERSION}/*.md" >> $GITHUB_STEP_SUMMARY || true
         done
       if: env.UPGRADE_TO_NEWER_DEPENDENCIES != 'false'
+    - name: "Upload constraint artifacts"
+      uses: actions/upload-artifact@v3
+      with:
+        name: constraints
+        path: ./files/constraints-*/constraints-*.txt
+        retention-days: 7
     - name: "Fix ownership"
       shell: bash
       run: breeze ci fix-ownership
diff --git a/.github/actions/build-prod-images/action.yml b/.github/actions/build-prod-images/action.yml
index 0086345b69..feac8c2ef2 100644
--- a/.github/actions/build-prod-images/action.yml
+++ b/.github/actions/build-prod-images/action.yml
@@ -56,11 +56,18 @@ runs:
     - name: "Move dist packages to docker-context files"
       shell: bash
       run: mv -v ./dist/*.whl ./docker-context-files
+    - name: "Download constraints from the CI build"
+      uses: actions/download-artifact@v3
+      with:
+        name: constraints
+        path: ./docker-context-files
+      if: env.UPGRADE_TO_NEWER_DEPENDENCIES != 'false'
     - name: "Build & Push PROD images ${{ env.IMAGE_TAG }}:${{ env.PYTHON_VERSIONS }}"
       shell: bash
       run: >
         breeze prod-image build --tag-as-latest --run-in-parallel --push
-        --install-packages-from-context --upgrade-on-failure
+        --install-packages-from-context --airflow-constraints-mode constraints-source-providers
+        --use-constraints-for-context-packages
       env:
         COMMIT_SHA: ${{ github.sha }}
     - name: "Fix ownership"
diff --git a/Dockerfile b/Dockerfile
index 43f085ce6a..8a4d93211c 100644
--- a/Dockerfile
+++ b/Dockerfile
@@ -593,17 +593,42 @@ function install_airflow_and_providers_from_docker_context_files(){
         return
     fi
 
-    echo
-    echo "${COLOR_BLUE}Force re-installing airflow and providers from local files with eager upgrade${COLOR_RESET}"
-    echo
-    # force reinstall all airflow + provider package local files with eager upgrade
-    set -x
-    pip install "${pip_flags[@]}" --root-user-action ignore --upgrade --upgrade-strategy eager \
-        ${ADDITIONAL_PIP_INSTALL_FLAGS} \
-        ${reinstalling_apache_airflow_package} ${reinstalling_apache_airflow_providers_packages} \
-        ${EAGER_UPGRADE_ADDITIONAL_REQUIREMENTS=}
-    set +x
+    if [[ ${USE_CONSTRAINTS_FOR_CONTEXT_PACKAGES=} == "true" ]]; then
+        local python_version
+        python_version=$(python -c 'import sys; print(f"{sys.version_info.major}.{sys.version_info.minor}")')
+        local local_constraints_file=/docker-context-files/constraints-"${python_version}"/${AIRFLOW_CONSTRAINTS_MODE}-"${python_version}".txt
 
+        if [[ -f "${local_constraints_file}" ]]; then
+            echo
+            echo "${COLOR_BLUE}Installing docker-context-files packages with constraints found in ${local_constraints_file}${COLOR_RESET}"
+            echo
+            # force reinstall all airflow + provider packages with constraints found in
+            set -x
+            pip install "${pip_flags[@]}" --root-user-action ignore --upgrade \
+                ${ADDITIONAL_PIP_INSTALL_FLAGS} --constraint "${local_constraints_file}" \
+                ${reinstalling_apache_airflow_package} ${reinstalling_apache_airflow_providers_packages}
+            set +x
+        else
+            echo
+            echo "${COLOR_BLUE}Installing docker-context-files packages with constraints from GitHub${COLOR_RESET}"
+            echo
+            set -x
+            pip install "${pip_flags[@]}" --root-user-action ignore \
+                ${ADDITIONAL_PIP_INSTALL_FLAGS} \
+                --constraint "${AIRFLOW_CONSTRAINTS_LOCATION}" \
+                ${reinstalling_apache_airflow_package} ${reinstalling_apache_airflow_providers_packages}
+            set +x
+        fi
+    else
+        echo
+        echo "${COLOR_BLUE}Installing docker-context-files packages without constraints${COLOR_RESET}"
+        echo
+        set -x
+        pip install "${pip_flags[@]}" --root-user-action ignore \
+            ${ADDITIONAL_PIP_INSTALL_FLAGS} \
+            ${reinstalling_apache_airflow_package} ${reinstalling_apache_airflow_providers_packages}
+        set +x
+    fi
     common::install_pip_version
     pip check
 }
@@ -1280,6 +1305,12 @@ COPY --from=scripts common.sh install_pip_version.sh \
 # is installed from docker-context files rather than from PyPI)
 ARG INSTALL_PACKAGES_FROM_CONTEXT="false"
 
+# Normally constraints are not used when context packages are build - because we might have packages
+# that are conflicting with Airflow constraints, however there are cases when we want to use constraints
+# for example in CI builds when we already have source-package constraints - either from github branch or
+# from eager-upgraded constraints by the CI builds
+ARG USE_CONSTRAINTS_FOR_CONTEXT_PACKAGES="false"
+
 # In case of Production build image segment we want to pre-install main version of airflow
 # dependencies from GitHub so that we do not have to always reinstall it from the scratch.
 # The Airflow (and providers in case INSTALL_PROVIDERS_FROM_SOURCES is "false")
@@ -1304,6 +1335,7 @@ ARG VERSION_SUFFIX_FOR_PYPI=""
 
 ENV ADDITIONAL_PYTHON_DEPS=${ADDITIONAL_PYTHON_DEPS} \
     INSTALL_PACKAGES_FROM_CONTEXT=${INSTALL_PACKAGES_FROM_CONTEXT} \
+    USE_CONSTRAINTS_FOR_CONTEXT_PACKAGES=${USE_CONSTRAINTS_FOR_CONTEXT_PACKAGES} \
     VERSION_SUFFIX_FOR_PYPI=${VERSION_SUFFIX_FOR_PYPI}
 
 WORKDIR ${AIRFLOW_HOME}
diff --git a/dev/breeze/src/airflow_breeze/commands/ci_image_commands.py b/dev/breeze/src/airflow_breeze/commands/ci_image_commands.py
index 2eecbfff3c..9d343ed571 100644
--- a/dev/breeze/src/airflow_breeze/commands/ci_image_commands.py
+++ b/dev/breeze/src/airflow_breeze/commands/ci_image_commands.py
@@ -43,6 +43,7 @@ from airflow_breeze.utils.common_options import (
     option_airflow_constraints_mode_ci,
     option_airflow_constraints_reference_build,
     option_answer,
+    option_build_progress,
     option_build_timeout_minutes,
     option_builder,
     option_commit_sha,
@@ -226,6 +227,7 @@ def kill_process_group(build_process_group_id: int):
 @option_additional_dev_apt_command
 @option_additional_dev_apt_env
 @option_builder
+@option_build_progress
 @option_build_timeout_minutes
 @option_commit_sha
 @option_dev_apt_command
diff --git a/dev/breeze/src/airflow_breeze/commands/ci_image_commands_config.py b/dev/breeze/src/airflow_breeze/commands/ci_image_commands_config.py
index 58509c3c57..6e88b70abe 100644
--- a/dev/breeze/src/airflow_breeze/commands/ci_image_commands_config.py
+++ b/dev/breeze/src/airflow_breeze/commands/ci_image_commands_config.py
@@ -36,6 +36,7 @@ CI_IMAGE_TOOLS_PARAMETERS: dict[str, list[dict[str, str | list[str]]]] = {
                 "--tag-as-latest",
                 "--docker-cache",
                 "--force-build",
+                "--build-progress",
             ],
         },
         {
diff --git a/dev/breeze/src/airflow_breeze/commands/production_image_commands.py b/dev/breeze/src/airflow_breeze/commands/production_image_commands.py
index 7cbede2041..3c8b3b14cf 100644
--- a/dev/breeze/src/airflow_breeze/commands/production_image_commands.py
+++ b/dev/breeze/src/airflow_breeze/commands/production_image_commands.py
@@ -39,6 +39,7 @@ from airflow_breeze.utils.common_options import (
     option_airflow_constraints_location,
     option_airflow_constraints_mode_prod,
     option_airflow_constraints_reference_build,
+    option_build_progress,
     option_builder,
     option_commit_sha,
     option_debug_resources,
@@ -67,8 +68,6 @@ from airflow_breeze.utils.common_options import (
     option_runtime_apt_deps,
     option_skip_cleanup,
     option_tag_as_latest,
-    option_upgrade_on_failure,
-    option_upgrade_to_newer_dependencies,
     option_verbose,
     option_verify,
     option_version_suffix_for_pypi,
@@ -156,8 +155,6 @@ def prod_image():
 @option_debug_resources
 @option_include_success_outputs
 @option_python_versions
-@option_upgrade_to_newer_dependencies
-@option_upgrade_on_failure
 @option_platform_multiple
 @option_github_token
 @option_docker_cache
@@ -178,6 +175,12 @@ def prod_image():
     "Implies --disable-airflow-repo-cache.",
     is_flag=True,
 )
+@click.option(
+    "--use-constraints-for-context-packages",
+    help="Uses constraints for context packages installation - "
+    "either from constraints store in docker-context-files or from github.",
+    is_flag=True,
+)
 @click.option(
     "--cleanup-context",
     help="Clean up docker context files before running build (cannot be used together"
@@ -213,6 +216,7 @@ def prod_image():
 @option_additional_runtime_apt_env
 @option_additional_runtime_apt_command
 @option_builder
+@option_build_progress
 @option_dev_apt_command
 @option_dev_apt_deps
 @option_python_image
@@ -434,7 +438,12 @@ def check_docker_context_files(install_packages_from_context: bool):
     :param install_packages_from_context: whether we want to install from docker-context-files
     """
     context_file = DOCKER_CONTEXT_DIR.rglob("*")
-    any_context_files = any(context.is_file() and context.name != ".README.md" for context in context_file)
+    any_context_files = any(
+        context.is_file()
+        and context.name not in (".README.md", ".DS_Store")
+        and not context.parent.name.startswith("constraints")
+        for context in context_file
+    )
     if not any_context_files and install_packages_from_context:
         get_console().print("[warning]\nERROR! You want to install packages from docker-context-files")
         get_console().print("[warning]\n but there are no packages to install in this folder.")
@@ -501,24 +510,6 @@ def run_build_production_image(
             text=True,
             output=output,
         )
-        if (
-            build_command_result.returncode != 0
-            and prod_image_params.upgrade_on_failure
-            and not prod_image_params.upgrade_to_newer_dependencies
-        ):
-            prod_image_params.upgrade_to_newer_dependencies = True
-            get_console().print("[warning]Attempting to build with upgrade_to_newer_dependencies on failure")
-            build_command_result = run_command(
-                prepare_docker_build_command(
-                    image_params=prod_image_params,
-                ),
-                cwd=AIRFLOW_SOURCES_ROOT,
-                check=False,
-                text=True,
-                env=env,
-                output=output,
-            )
-        if build_command_result.returncode == 0:
-            if prod_image_params.tag_as_latest:
-                build_command_result = tag_image_as_latest(image_params=prod_image_params, output=output)
+        if build_command_result.returncode == 0 and prod_image_params.tag_as_latest:
+            build_command_result = tag_image_as_latest(image_params=prod_image_params, output=output)
     return build_command_result.returncode, f"Image build: {prod_image_params.python}"
diff --git a/dev/breeze/src/airflow_breeze/commands/production_image_commands_config.py b/dev/breeze/src/airflow_breeze/commands/production_image_commands_config.py
index 148788afc4..8ffc636521 100644
--- a/dev/breeze/src/airflow_breeze/commands/production_image_commands_config.py
+++ b/dev/breeze/src/airflow_breeze/commands/production_image_commands_config.py
@@ -31,11 +31,10 @@ PRODUCTION_IMAGE_TOOLS_PARAMETERS: dict[str, list[dict[str, str | list[str]]]] =
             "options": [
                 "--python",
                 "--install-airflow-version",
-                "--upgrade-to-newer-dependencies",
-                "--upgrade-on-failure",
                 "--image-tag",
                 "--tag-as-latest",
                 "--docker-cache",
+                "--build-progress",
             ],
         },
         {
@@ -79,6 +78,7 @@ PRODUCTION_IMAGE_TOOLS_PARAMETERS: dict[str, list[dict[str, str | list[str]]]] =
             "name": "Customization options (for specific customization needs)",
             "options": [
                 "--install-packages-from-context",
+                "--use-constraints-for-context-packages",
                 "--cleanup-context",
                 "--disable-mysql-client-installation",
                 "--disable-mssql-client-installation",
diff --git a/dev/breeze/src/airflow_breeze/global_constants.py b/dev/breeze/src/airflow_breeze/global_constants.py
index 8827a4962f..9a09513cb6 100644
--- a/dev/breeze/src/airflow_breeze/global_constants.py
+++ b/dev/breeze/src/airflow_breeze/global_constants.py
@@ -147,6 +147,7 @@ ALLOWED_PACKAGE_FORMATS = ["wheel", "sdist", "both"]
 ALLOWED_INSTALLATION_PACKAGE_FORMATS = ["wheel", "sdist"]
 ALLOWED_INSTALLATION_METHODS = [".", "apache-airflow"]
 ALLOWED_BUILD_CACHE = ["registry", "local", "disabled"]
+ALLOWED_BUILD_PROGRESS = ["auto", "plain", "tty"]
 MULTI_PLATFORM = "linux/amd64,linux/arm64"
 SINGLE_PLATFORMS = ["linux/amd64", "linux/arm64"]
 ALLOWED_PLATFORMS = [*SINGLE_PLATFORMS, MULTI_PLATFORM]
diff --git a/dev/breeze/src/airflow_breeze/params/build_ci_params.py b/dev/breeze/src/airflow_breeze/params/build_ci_params.py
index 1f49f0597b..a713c280b5 100644
--- a/dev/breeze/src/airflow_breeze/params/build_ci_params.py
+++ b/dev/breeze/src/airflow_breeze/params/build_ci_params.py
@@ -36,6 +36,8 @@ class BuildCiParams(CommonBuildParams):
     airflow_extras: str = "devel_ci"
     airflow_pre_cached_pip_packages: bool = True
     force_build: bool = False
+    upgrade_to_newer_dependencies: bool = False
+    upgrade_on_failure: bool = False
     eager_upgrade_additional_requirements: str = ""
     skip_provider_dependencies_check: bool = False
 
@@ -66,7 +68,7 @@ class BuildCiParams(CommonBuildParams):
                         f"EAGER_UPGRADE_ADDITIONAL_REQUIREMENTS={eager_upgrade_arg}",
                     ]
                 )
-        return extra_ci_flags
+        return super().extra_docker_build_flags + extra_ci_flags
 
     @property
     def md5sum_cache_dir(self) -> Path:
@@ -111,6 +113,7 @@ class BuildCiParams(CommonBuildParams):
             "additional_python_deps",
             "version_suffix_for_pypi",
             "commit_sha",
+            "build_progress",
         ]
 
     def __post_init__(self):
diff --git a/dev/breeze/src/airflow_breeze/params/build_prod_params.py b/dev/breeze/src/airflow_breeze/params/build_prod_params.py
index e45eafa326..585c7dc0c9 100644
--- a/dev/breeze/src/airflow_breeze/params/build_prod_params.py
+++ b/dev/breeze/src/airflow_breeze/params/build_prod_params.py
@@ -52,6 +52,7 @@ class BuildProdParams(CommonBuildParams):
     install_airflow_reference: str = ""
     install_airflow_version: str = ""
     install_packages_from_context: bool = False
+    use_constraints_for_context_packages: bool = False
     installation_method: str = "."
     runtime_apt_command: str = ""
     runtime_apt_deps: str = ""
@@ -159,7 +160,6 @@ class BuildProdParams(CommonBuildParams):
                     f"AIRFLOW_CONSTRAINTS_REFERENCE={self.airflow_constraints_reference}",
                 ]
             )
-
         maintainers = json.dumps([{"name": "Apache Airflow PMC", "email": "dev@airflow.apache.org"}])
         logo_url = "https://github.com/apache/airflow/raw/main/docs/apache-airflow/img/logos/wordmark_1.png"
         readme_url = "https://raw.githubusercontent.com/apache/airflow/main/docs/docker-stack/README.md"
@@ -175,7 +175,7 @@ class BuildProdParams(CommonBuildParams):
                 f"io.artifacthub.package.logo-url={logo_url}",
             ]
         )
-        return extra_build_flags
+        return super().extra_docker_build_flags + extra_build_flags
 
     @property
     def airflow_pre_cached_pip_packages(self) -> str:
@@ -221,7 +221,6 @@ class BuildProdParams(CommonBuildParams):
             "install_postgres_client",
             "install_providers_from_sources",
             "python_base_image",
-            "upgrade_to_newer_dependencies",
         ]
 
     @property
@@ -242,4 +241,6 @@ class BuildProdParams(CommonBuildParams):
             "runtime_apt_deps",
             "version_suffix_for_pypi",
             "commit_sha",
+            "build_progress",
+            "use_constraints_for_context_packages",
         ]
diff --git a/dev/breeze/src/airflow_breeze/params/common_build_params.py b/dev/breeze/src/airflow_breeze/params/common_build_params.py
index 90874f67b3..fc1de2a4ed 100644
--- a/dev/breeze/src/airflow_breeze/params/common_build_params.py
+++ b/dev/breeze/src/airflow_breeze/params/common_build_params.py
@@ -22,7 +22,11 @@ from dataclasses import dataclass
 from datetime import datetime
 
 from airflow_breeze.branch_defaults import AIRFLOW_BRANCH, DEFAULT_AIRFLOW_CONSTRAINTS_BRANCH
-from airflow_breeze.global_constants import APACHE_AIRFLOW_GITHUB_REPOSITORY, DOCKER_DEFAULT_PLATFORM
+from airflow_breeze.global_constants import (
+    ALLOWED_BUILD_PROGRESS,
+    APACHE_AIRFLOW_GITHUB_REPOSITORY,
+    DOCKER_DEFAULT_PLATFORM,
+)
 from airflow_breeze.utils.console import get_console
 from airflow_breeze.utils.platforms import get_real_platform
 
@@ -46,6 +50,7 @@ class CommonBuildParams:
     airflow_constraints_location: str = ""
     build_id: int = 0
     builder: str = "autodetect"
+    build_progress: str = ALLOWED_BUILD_PROGRESS[0]
     constraints_github_repository: str = APACHE_AIRFLOW_GITHUB_REPOSITORY
     commit_sha: str = ""
     dev_apt_command: str = ""
@@ -62,8 +67,6 @@ class CommonBuildParams:
     push: bool = False
     python: str = "3.8"
     tag_as_latest: bool = False
-    upgrade_to_newer_dependencies: bool = False
-    upgrade_on_failure: bool = False
     dry_run: bool = False
     version_suffix_for_pypi: str = ""
     verbose: bool = False
@@ -96,7 +99,10 @@ class CommonBuildParams:
 
     @property
     def extra_docker_build_flags(self) -> list[str]:
-        raise NotImplementedError()
+        extra_flass = []
+        if self.build_progress:
+            extra_flass.append(f"--progress={self.build_progress}")
+        return extra_flass
 
     @property
     def docker_cache_directive(self) -> list[str]:
diff --git a/dev/breeze/src/airflow_breeze/utils/common_options.py b/dev/breeze/src/airflow_breeze/utils/common_options.py
index c5bfe688f2..01cff73e27 100644
--- a/dev/breeze/src/airflow_breeze/utils/common_options.py
+++ b/dev/breeze/src/airflow_breeze/utils/common_options.py
@@ -25,6 +25,7 @@ from airflow_breeze.global_constants import (
     ALL_HISTORICAL_PYTHON_VERSIONS,
     ALLOWED_BACKENDS,
     ALLOWED_BUILD_CACHE,
+    ALLOWED_BUILD_PROGRESS,
     ALLOWED_CELERY_BROKERS,
     ALLOWED_CONSTRAINTS_MODES_CI,
     ALLOWED_CONSTRAINTS_MODES_PROD,
@@ -511,6 +512,14 @@ option_builder = click.option(
     show_default=True,
     default="autodetect",
 )
+option_build_progress = click.option(
+    "--build-progress",
+    help="Build progress.",
+    type=BetterChoice(ALLOWED_BUILD_PROGRESS),
+    envvar="BUILD_PROGRESS",
+    show_default=True,
+    default=ALLOWED_BUILD_PROGRESS[0],
+)
 option_include_success_outputs = click.option(
     "--include-success-outputs",
     help="Whether to include outputs of successful parallel runs (skipped by default).",
diff --git a/dev/breeze/src/airflow_breeze/utils/selective_checks.py b/dev/breeze/src/airflow_breeze/utils/selective_checks.py
index c6b9aa00b4..e6b350df19 100644
--- a/dev/breeze/src/airflow_breeze/utils/selective_checks.py
+++ b/dev/breeze/src/airflow_breeze/utils/selective_checks.py
@@ -68,6 +68,7 @@ from airflow_breeze.utils.provider_dependencies import DEPENDENCIES, get_related
 FULL_TESTS_NEEDED_LABEL = "full tests needed"
 DEBUG_CI_RESOURCES_LABEL = "debug ci resources"
 USE_PUBLIC_RUNNERS_LABEL = "use public runners"
+UPGRADE_TO_NEWER_DEPENDENCIES_LABEL = "upgrade to newer dependencies"
 
 
 class FileGroupForCi(Enum):
@@ -685,9 +686,11 @@ class SelectiveChecks:
 
     @cached_property
     def upgrade_to_newer_dependencies(self) -> bool:
-        return len(
-            self._matching_files(FileGroupForCi.SETUP_FILES, CI_FILE_GROUP_MATCHES)
-        ) > 0 or self._github_event in [GithubEvents.PUSH, GithubEvents.SCHEDULE]
+        return (
+            len(self._matching_files(FileGroupForCi.SETUP_FILES, CI_FILE_GROUP_MATCHES)) > 0
+            or self._github_event in [GithubEvents.PUSH, GithubEvents.SCHEDULE]
+            or UPGRADE_TO_NEWER_DEPENDENCIES_LABEL in self._pr_labels
+        )
 
     @cached_property
     def docs_filter_list_as_string(self) -> str | None:
diff --git a/dev/breeze/tests/test_selective_checks.py b/dev/breeze/tests/test_selective_checks.py
index 413fe8be71..7711efc526 100644
--- a/dev/breeze/tests/test_selective_checks.py
+++ b/dev/breeze/tests/test_selective_checks.py
@@ -900,13 +900,14 @@ def test_no_commit_provided_trigger_full_build_for_any_event_type(github_event):
 
 
 @pytest.mark.parametrize(
-    "files, expected_outputs,",
+    "files, expected_outputs, pr_labels",
     [
         pytest.param(
             ("airflow/models/dag.py",),
             {
                 "upgrade-to-newer-dependencies": "false",
             },
+            (),
             id="Regular source changed",
         ),
         pytest.param(
@@ -914,6 +915,7 @@ def test_no_commit_provided_trigger_full_build_for_any_event_type(github_event):
             {
                 "upgrade-to-newer-dependencies": "true",
             },
+            (),
             id="Setup.py changed",
         ),
         pytest.param(
@@ -921,6 +923,7 @@ def test_no_commit_provided_trigger_full_build_for_any_event_type(github_event):
             {
                 "upgrade-to-newer-dependencies": "true",
             },
+            (),
             id="Setup.cfg changed",
         ),
         pytest.param(
@@ -928,6 +931,7 @@ def test_no_commit_provided_trigger_full_build_for_any_event_type(github_event):
             {
                 "upgrade-to-newer-dependencies": "false",
             },
+            (),
             id="Provider.yaml changed",
         ),
         pytest.param(
@@ -935,17 +939,28 @@ def test_no_commit_provided_trigger_full_build_for_any_event_type(github_event):
             {
                 "upgrade-to-newer-dependencies": "true",
             },
+            (),
             id="Generated provider_dependencies changed",
         ),
+        pytest.param(
+            ("airflow/models/dag.py",),
+            {
+                "upgrade-to-newer-dependencies": "true",
+            },
+            ("upgrade to newer dependencies",),
+            id="Regular source changed",
+        ),
     ],
 )
-def test_upgrade_to_newer_dependencies(files: tuple[str, ...], expected_outputs: dict[str, str]):
+def test_upgrade_to_newer_dependencies(
+    files: tuple[str, ...], expected_outputs: dict[str, str], pr_labels: tuple[str]
+):
     stderr = SelectiveChecks(
         files=files,
         commit_ref="HEAD",
         github_event=GithubEvents.PULL_REQUEST,
-        pr_labels=(),
         default_branch="main",
+        pr_labels=pr_labels,
     )
     assert_outputs_are_printed(expected_outputs, str(stderr))
 
diff --git a/images/breeze/output-commands-hash.txt b/images/breeze/output-commands-hash.txt
index bed222b5cc..94498d7b19 100644
--- a/images/breeze/output-commands-hash.txt
+++ b/images/breeze/output-commands-hash.txt
@@ -10,10 +10,10 @@ ci:get-workflow-info:8246038093359b9c3c110043419473e2
 ci:resource-check:bfcca92f18a403ca630955074eb5e9ad
 ci:selective-check:6657ed5d42affb7264b5efcc86f17a2a
 ci:5315c29bd9f68725ef92e4db8aff5cda
-ci-image:build:5606d9d3c3db807228b6c6458e4c5018
+ci-image:build:0598b5423e61a2431b2449135475f9ff
 ci-image:pull:7f14482a588f018f76df84719e77723f
 ci-image:verify:c90dc7e20fce2351eb89d8d1ebbd35e7
-ci-image:627399747ac8a202cd8a8c03c9bdabbf
+ci-image:6b058951af1e540d9c2f5c2c7af23183
 cleanup:8d92d453a6700f6d8cb11fb6a8b50461
 compile-www-assets:0963f1409f0aa1e3b137cddd4cc52e87
 down:4580f5b3b178ea00182694f134a751f3
@@ -32,10 +32,10 @@ k8s:status:1529ccd444b41c4b0b5f943289957100
 k8s:tests:2a1e2928faea2eddafaff94176a46690
 k8s:upload-k8s-image:6b3a20cdeb692f3c3d727f6b9e68c901
 k8s:c73e0ebdff75d89e35af6e324a3bc527
-prod-image:build:10cc859b7d898581bf9b2a24c19c1032
+prod-image:build:c1bd48b7f61eb2f0b82c0161235a4d66
 prod-image:pull:76f1f27e6119928412abecf153fce4bb
 prod-image:verify:bd2b78738a7c388dbad6076c41a9f906
-prod-image:d9b47217a12f73f214bcd2938bbab84a
+prod-image:887b1eb302942c62c40164f8e5e9d5f5
 release-management:add-back-references:7e3a4e6d3f7932773cfb256059f7c2c8
 release-management:create-minor-branch:a3834afc4aa5d1e98002c9e9e7a9931d
 release-management:generate-constraints:b8fcaf8f0acd35ed5dbd48659bdb6485
diff --git a/images/breeze/output-commands.svg b/images/breeze/output-commands.svg
index 51829ca34b..8b9d38fa91 100644
--- a/images/breeze/output-commands.svg
+++ b/images/breeze/output-commands.svg
@@ -35,8 +35,8 @@
     .breeze-help-r1 { fill: #c5c8c6;font-weight: bold }
 .breeze-help-r2 { fill: #c5c8c6 }
 .breeze-help-r3 { fill: #d0b344;font-weight: bold }
-.breeze-help-r4 { fill: #68a0b3;font-weight: bold }
-.breeze-help-r5 { fill: #868887 }
+.breeze-help-r4 { fill: #868887 }
+.breeze-help-r5 { fill: #68a0b3;font-weight: bold }
 .breeze-help-r6 { fill: #98a84b;font-weight: bold }
 .breeze-help-r7 { fill: #8d7b39 }
     </style>
@@ -217,59 +217,59 @@
     
     <g class="breeze-help-matrix">
     <text class="breeze-help-r2" x="1464" y="20" textLength="12.2" clip-path="url(#breeze-help-line-0)">
-</text><text class="breeze-help-r3" x="12.2" y="44.4" textLength="85.4" clip-path="url(#breeze-help-line-1)">Usage:&#160;</text><text class="breeze-help-r1" x="97.6" y="44.4" textLength="97.6" clip-path="url(#breeze-help-line-1)">breeze&#160;[</text><text class="breeze-help-r4" x="195.2" y="44.4" textLength="85.4" clip-path="url(#breeze-help-line-1)">OPTIONS</text><text class="breeze-help-r1" x="280.6" y="44.4" textLength="24.4" clip-path="url(#breeze-help-line-1)">]&#160;</text><text cl [...]
+</text><text class="breeze-help-r3" x="12.2" y="44.4" textLength="85.4" clip-path="url(#breeze-help-line-1)">Usage:&#160;</text><text class="breeze-help-r1" x="97.6" y="44.4" textLength="414.8" clip-path="url(#breeze-help-line-1)">breeze&#160;[OPTIONS]&#160;COMMAND&#160;[ARGS]...</text><text class="breeze-help-r2" x="1464" y="44.4" textLength="12.2" clip-path="url(#breeze-help-line-1)">
 </text><text class="breeze-help-r2" x="1464" y="68.8" textLength="12.2" clip-path="url(#breeze-help-line-2)">
-</text><text class="breeze-help-r5" x="0" y="93.2" textLength="24.4" clip-path="url(#breeze-help-line-3)">╭─</text><text class="breeze-help-r5" x="24.4" y="93.2" textLength="158.6" clip-path="url(#breeze-help-line-3)">&#160;Basic&#160;flags&#160;</text><text class="breeze-help-r5" x="183" y="93.2" textLength="1256.6" clip-path="url(#breeze-help-line-3)">───────────────────────────────────────────────────────────────────────────────────────────────────────</text><text class="breeze-help-r [...]
-</text><text class="breeze-help-r5" x="0" y="117.6" textLength="12.2" clip-path="url(#breeze-help-line-4)">│</text><text class="breeze-help-r4" x="24.4" y="117.6" textLength="12.2" clip-path="url(#breeze-help-line-4)">-</text><text class="breeze-help-r4" x="36.6" y="117.6" textLength="85.4" clip-path="url(#breeze-help-line-4)">-python</text><text class="breeze-help-r6" x="305" y="117.6" textLength="24.4" clip-path="url(#breeze-help-line-4)">-p</text><text class="breeze-help-r2" x="353.8" [...]
-</text><text class="breeze-help-r5" x="0" y="142" textLength="12.2" clip-path="url(#breeze-help-line-5)">│</text><text class="breeze-help-r5" x="353.8" y="142" textLength="732" clip-path="url(#breeze-help-line-5)">[default:&#160;3.8]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;& [...]
-</text><text class="breeze-help-r5" x="0" y="166.4" textLength="12.2" clip-path="url(#breeze-help-line-6)">│</text><text class="breeze-help-r4" x="24.4" y="166.4" textLength="12.2" clip-path="url(#breeze-help-line-6)">-</text><text class="breeze-help-r4" x="36.6" y="166.4" textLength="97.6" clip-path="url(#breeze-help-line-6)">-backend</text><text class="breeze-help-r6" x="305" y="166.4" textLength="24.4" clip-path="url(#breeze-help-line-6)">-b</text><text class="breeze-help-r2" x="353.8 [...]
-</text><text class="breeze-help-r5" x="0" y="190.8" textLength="12.2" clip-path="url(#breeze-help-line-7)">│</text><text class="breeze-help-r4" x="24.4" y="190.8" textLength="12.2" clip-path="url(#breeze-help-line-7)">-</text><text class="breeze-help-r4" x="36.6" y="190.8" textLength="109.8" clip-path="url(#breeze-help-line-7)">-postgres</text><text class="breeze-help-r4" x="146.4" y="190.8" textLength="97.6" clip-path="url(#breeze-help-line-7)">-version</text><text class="breeze-help-r6 [...]
-</text><text class="breeze-help-r5" x="0" y="215.2" textLength="12.2" clip-path="url(#breeze-help-line-8)">│</text><text class="breeze-help-r4" x="24.4" y="215.2" textLength="12.2" clip-path="url(#breeze-help-line-8)">-</text><text class="breeze-help-r4" x="36.6" y="215.2" textLength="73.2" clip-path="url(#breeze-help-line-8)">-mysql</text><text class="breeze-help-r4" x="109.8" y="215.2" textLength="97.6" clip-path="url(#breeze-help-line-8)">-version</text><text class="breeze-help-r6" x= [...]
-</text><text class="breeze-help-r5" x="0" y="239.6" textLength="12.2" clip-path="url(#breeze-help-line-9)">│</text><text class="breeze-help-r4" x="24.4" y="239.6" textLength="12.2" clip-path="url(#breeze-help-line-9)">-</text><text class="breeze-help-r4" x="36.6" y="239.6" textLength="73.2" clip-path="url(#breeze-help-line-9)">-mssql</text><text class="breeze-help-r4" x="109.8" y="239.6" textLength="97.6" clip-path="url(#breeze-help-line-9)">-version</text><text class="breeze-help-r6" x= [...]
-</text><text class="breeze-help-r5" x="0" y="264" textLength="12.2" clip-path="url(#breeze-help-line-10)">│</text><text class="breeze-help-r4" x="24.4" y="264" textLength="12.2" clip-path="url(#breeze-help-line-10)">-</text><text class="breeze-help-r4" x="36.6" y="264" textLength="146.4" clip-path="url(#breeze-help-line-10)">-integration</text><text class="breeze-help-r2" x="353.8" y="264" textLength="1085.8" clip-path="url(#breeze-help-line-10)">Integration(s)&#160;to&#160;enable&#160;w [...]
-</text><text class="breeze-help-r5" x="0" y="288.4" textLength="12.2" clip-path="url(#breeze-help-line-11)">│</text><text class="breeze-help-r7" x="353.8" y="288.4" textLength="1085.8" clip-path="url(#breeze-help-line-11)">(all&#160;|&#160;all-testable&#160;|&#160;cassandra&#160;|&#160;celery&#160;|&#160;kafka&#160;|&#160;kerberos&#160;|&#160;mongo&#160;|&#160;otel&#160;|&#160;pinot&#160;|&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r5" x="1451.8" y="288.4" textLength="1 [...]
-</text><text class="breeze-help-r5" x="0" y="312.8" textLength="12.2" clip-path="url(#breeze-help-line-12)">│</text><text class="breeze-help-r7" x="353.8" y="312.8" textLength="1085.8" clip-path="url(#breeze-help-line-12)">statsd&#160;|&#160;statsd&#160;|&#160;trino)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#1 [...]
-</text><text class="breeze-help-r5" x="0" y="337.2" textLength="12.2" clip-path="url(#breeze-help-line-13)">│</text><text class="breeze-help-r4" x="24.4" y="337.2" textLength="12.2" clip-path="url(#breeze-help-line-13)">-</text><text class="breeze-help-r4" x="36.6" y="337.2" textLength="97.6" clip-path="url(#breeze-help-line-13)">-forward</text><text class="breeze-help-r4" x="134.2" y="337.2" textLength="146.4" clip-path="url(#breeze-help-line-13)">-credentials</text><text class="breeze- [...]
-</text><text class="breeze-help-r5" x="0" y="361.6" textLength="12.2" clip-path="url(#breeze-help-line-14)">│</text><text class="breeze-help-r4" x="24.4" y="361.6" textLength="12.2" clip-path="url(#breeze-help-line-14)">-</text><text class="breeze-help-r4" x="36.6" y="361.6" textLength="36.6" clip-path="url(#breeze-help-line-14)">-db</text><text class="breeze-help-r4" x="73.2" y="361.6" textLength="73.2" clip-path="url(#breeze-help-line-14)">-reset</text><text class="breeze-help-r6" x="3 [...]
-</text><text class="breeze-help-r5" x="0" y="386" textLength="12.2" clip-path="url(#breeze-help-line-15)">│</text><text class="breeze-help-r4" x="24.4" y="386" textLength="12.2" clip-path="url(#breeze-help-line-15)">-</text><text class="breeze-help-r4" x="36.6" y="386" textLength="48.8" clip-path="url(#breeze-help-line-15)">-max</text><text class="breeze-help-r4" x="85.4" y="386" textLength="61" clip-path="url(#breeze-help-line-15)">-time</text><text class="breeze-help-r2" x="353.8" y="3 [...]
-</text><text class="breeze-help-r5" x="0" y="410.4" textLength="12.2" clip-path="url(#breeze-help-line-16)">│</text><text class="breeze-help-r7" x="353.8" y="410.4" textLength="1049.2" clip-path="url(#breeze-help-line-16)">(INTEGER&#160;RANGE)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#1 [...]
-</text><text class="breeze-help-r5" x="0" y="434.8" textLength="12.2" clip-path="url(#breeze-help-line-17)">│</text><text class="breeze-help-r4" x="24.4" y="434.8" textLength="12.2" clip-path="url(#breeze-help-line-17)">-</text><text class="breeze-help-r4" x="36.6" y="434.8" textLength="85.4" clip-path="url(#breeze-help-line-17)">-github</text><text class="breeze-help-r4" x="122" y="434.8" textLength="134.2" clip-path="url(#breeze-help-line-17)">-repository</text><text class="breeze-help [...]
-</text><text class="breeze-help-r5" x="0" y="459.2" textLength="12.2" clip-path="url(#breeze-help-line-18)">│</text><text class="breeze-help-r4" x="24.4" y="459.2" textLength="12.2" clip-path="url(#breeze-help-line-18)">-</text><text class="breeze-help-r4" x="36.6" y="459.2" textLength="97.6" clip-path="url(#breeze-help-line-18)">-builder</text><text class="breeze-help-r2" x="353.8" y="459.2" textLength="756.4" clip-path="url(#breeze-help-line-18)">Buildx&#160;builder&#160;used&#160;to&# [...]
-</text><text class="breeze-help-r5" x="0" y="483.6" textLength="12.2" clip-path="url(#breeze-help-line-19)">│</text><text class="breeze-help-r5" x="353.8" y="483.6" textLength="756.4" clip-path="url(#breeze-help-line-19)">[default:&#160;autodetect]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#16 [...]
-</text><text class="breeze-help-r5" x="0" y="508" textLength="1464" clip-path="url(#breeze-help-line-20)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-help-r2" x="1464" y="508" textLength="12.2" clip-path="url(#breeze-help-line-20)">
-</text><text class="breeze-help-r5" x="0" y="532.4" textLength="24.4" clip-path="url(#breeze-help-line-21)">╭─</text><text class="breeze-help-r5" x="24.4" y="532.4" textLength="195.2" clip-path="url(#breeze-help-line-21)">&#160;Common&#160;options&#160;</text><text class="breeze-help-r5" x="219.6" y="532.4" textLength="1220" clip-path="url(#breeze-help-line-21)">────────────────────────────────────────────────────────────────────────────────────────────────────</text><text class="breeze- [...]
-</text><text class="breeze-help-r5" x="0" y="556.8" textLength="12.2" clip-path="url(#breeze-help-line-22)">│</text><text class="breeze-help-r4" x="24.4" y="556.8" textLength="12.2" clip-path="url(#breeze-help-line-22)">-</text><text class="breeze-help-r4" x="36.6" y="556.8" textLength="97.6" clip-path="url(#breeze-help-line-22)">-verbose</text><text class="breeze-help-r6" x="158.6" y="556.8" textLength="24.4" clip-path="url(#breeze-help-line-22)">-v</text><text class="breeze-help-r2" x= [...]
-</text><text class="breeze-help-r5" x="0" y="581.2" textLength="12.2" clip-path="url(#breeze-help-line-23)">│</text><text class="breeze-help-r4" x="24.4" y="581.2" textLength="12.2" clip-path="url(#breeze-help-line-23)">-</text><text class="breeze-help-r4" x="36.6" y="581.2" textLength="48.8" clip-path="url(#breeze-help-line-23)">-dry</text><text class="breeze-help-r4" x="85.4" y="581.2" textLength="48.8" clip-path="url(#breeze-help-line-23)">-run</text><text class="breeze-help-r6" x="15 [...]
-</text><text class="breeze-help-r5" x="0" y="605.6" textLength="12.2" clip-path="url(#breeze-help-line-24)">│</text><text class="breeze-help-r4" x="24.4" y="605.6" textLength="12.2" clip-path="url(#breeze-help-line-24)">-</text><text class="breeze-help-r4" x="36.6" y="605.6" textLength="85.4" clip-path="url(#breeze-help-line-24)">-answer</text><text class="breeze-help-r6" x="158.6" y="605.6" textLength="24.4" clip-path="url(#breeze-help-line-24)">-a</text><text class="breeze-help-r2" x=" [...]
-</text><text class="breeze-help-r5" x="0" y="630" textLength="12.2" clip-path="url(#breeze-help-line-25)">│</text><text class="breeze-help-r4" x="24.4" y="630" textLength="12.2" clip-path="url(#breeze-help-line-25)">-</text><text class="breeze-help-r4" x="36.6" y="630" textLength="61" clip-path="url(#breeze-help-line-25)">-help</text><text class="breeze-help-r6" x="158.6" y="630" textLength="24.4" clip-path="url(#breeze-help-line-25)">-h</text><text class="breeze-help-r2" x="207.4" y="63 [...]
-</text><text class="breeze-help-r5" x="0" y="654.4" textLength="1464" clip-path="url(#breeze-help-line-26)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-help-r2" x="1464" y="654.4" textLength="12.2" clip-path="url(#breeze-help-line-26)">
-</text><text class="breeze-help-r5" x="0" y="678.8" textLength="24.4" clip-path="url(#breeze-help-line-27)">╭─</text><text class="breeze-help-r5" x="24.4" y="678.8" textLength="244" clip-path="url(#breeze-help-line-27)">&#160;Developer&#160;commands&#160;</text><text class="breeze-help-r5" x="268.4" y="678.8" textLength="1171.2" clip-path="url(#breeze-help-line-27)">────────────────────────────────────────────────────────────────────────────────────────────────</text><text class="breeze- [...]
-</text><text class="breeze-help-r5" x="0" y="703.2" textLength="12.2" clip-path="url(#breeze-help-line-28)">│</text><text class="breeze-help-r4" x="24.4" y="703.2" textLength="219.6" clip-path="url(#breeze-help-line-28)">start-airflow&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="268.4" y="703.2" textLength="1171.2" clip-path="url(#breeze-help-line-28)">Enter&#160;breeze&#160;environment&#160;and&#160;starts&#160;all&#160;Airflow&#160;components&#160;in&#160;the&#16 [...]
-</text><text class="breeze-help-r5" x="0" y="727.6" textLength="12.2" clip-path="url(#breeze-help-line-29)">│</text><text class="breeze-help-r2" x="268.4" y="727.6" textLength="1171.2" clip-path="url(#breeze-help-line-29)">if&#160;contents&#160;of&#160;www&#160;directory&#160;changed.&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#1 [...]
-</text><text class="breeze-help-r5" x="0" y="752" textLength="12.2" clip-path="url(#breeze-help-line-30)">│</text><text class="breeze-help-r4" x="24.4" y="752" textLength="219.6" clip-path="url(#breeze-help-line-30)">static-checks&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="268.4" y="752" textLength="1171.2" clip-path="url(#breeze-help-line-30)">Run&#160;static&#160;checks.&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&# [...]
-</text><text class="breeze-help-r5" x="0" y="776.4" textLength="12.2" clip-path="url(#breeze-help-line-31)">│</text><text class="breeze-help-r4" x="24.4" y="776.4" textLength="219.6" clip-path="url(#breeze-help-line-31)">build-docs&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="268.4" y="776.4" textLength="1171.2" clip-path="url(#breeze-help-line-31)">Build&#160;documents.&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160; [...]
-</text><text class="breeze-help-r5" x="0" y="800.8" textLength="12.2" clip-path="url(#breeze-help-line-32)">│</text><text class="breeze-help-r4" x="24.4" y="800.8" textLength="219.6" clip-path="url(#breeze-help-line-32)">down&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="268.4" y="800.8" textLength="1171.2" clip-path="url(#breeze-help-line-32)">Stop&#160;running&#160;breeze&#160;environment.&#160;&#160;&#160;&#16 [...]
-</text><text class="breeze-help-r5" x="0" y="825.2" textLength="12.2" clip-path="url(#breeze-help-line-33)">│</text><text class="breeze-help-r4" x="24.4" y="825.2" textLength="219.6" clip-path="url(#breeze-help-line-33)">shell&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="268.4" y="825.2" textLength="1171.2" clip-path="url(#breeze-help-line-33)">Enter&#160;breeze&#160;environment.&#160;this&#160;is&#160;the&#160;defaul [...]
-</text><text class="breeze-help-r5" x="0" y="849.6" textLength="12.2" clip-path="url(#breeze-help-line-34)">│</text><text class="breeze-help-r4" x="24.4" y="849.6" textLength="219.6" clip-path="url(#breeze-help-line-34)">exec&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="268.4" y="849.6" textLength="1171.2" clip-path="url(#breeze-help-line-34)">Joins&#160;the&#160;interactive&#160;shell&#160;of&#160;running&#160; [...]
-</text><text class="breeze-help-r5" x="0" y="874" textLength="12.2" clip-path="url(#breeze-help-line-35)">│</text><text class="breeze-help-r4" x="24.4" y="874" textLength="219.6" clip-path="url(#breeze-help-line-35)">compile-www-assets</text><text class="breeze-help-r2" x="268.4" y="874" textLength="1171.2" clip-path="url(#breeze-help-line-35)">Compiles&#160;www&#160;assets.&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;& [...]
-</text><text class="breeze-help-r5" x="0" y="898.4" textLength="12.2" clip-path="url(#breeze-help-line-36)">│</text><text class="breeze-help-r4" x="24.4" y="898.4" textLength="219.6" clip-path="url(#breeze-help-line-36)">cleanup&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="268.4" y="898.4" textLength="805.2" clip-path="url(#breeze-help-line-36)">Cleans&#160;the&#160;cache&#160;of&#160;parameters,&#160;docker&#160;cache&#160;and&# [...]
-</text><text class="breeze-help-r5" x="0" y="922.8" textLength="1464" clip-path="url(#breeze-help-line-37)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-help-r2" x="1464" y="922.8" textLength="12.2" clip-path="url(#breeze-help-line-37)">
-</text><text class="breeze-help-r5" x="0" y="947.2" textLength="24.4" clip-path="url(#breeze-help-line-38)">╭─</text><text class="breeze-help-r5" x="24.4" y="947.2" textLength="219.6" clip-path="url(#breeze-help-line-38)">&#160;Testing&#160;commands&#160;</text><text class="breeze-help-r5" x="244" y="947.2" textLength="1195.6" clip-path="url(#breeze-help-line-38)">──────────────────────────────────────────────────────────────────────────────────────────────────</text><text class="breeze- [...]
-</text><text class="breeze-help-r5" x="0" y="971.6" textLength="12.2" clip-path="url(#breeze-help-line-39)">│</text><text class="breeze-help-r4" x="24.4" y="971.6" textLength="183" clip-path="url(#breeze-help-line-39)">testing&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="231.8" y="971.6" textLength="1207.8" clip-path="url(#breeze-help-line-39)">Tools&#160;that&#160;developers&#160;can&#160;use&#160;to&#160;run&#160;tests&#160;&#160;&#160;&#160;&#1 [...]
-</text><text class="breeze-help-r5" x="0" y="996" textLength="12.2" clip-path="url(#breeze-help-line-40)">│</text><text class="breeze-help-r4" x="24.4" y="996" textLength="183" clip-path="url(#breeze-help-line-40)">k8s&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="231.8" y="996" textLength="1207.8" clip-path="url(#breeze-help-line-40)">Tools&#160;that&#160;developers&#160;use&#160;to&#160;run&#160;Kubernetes&#160;tests&#160; [...]
-</text><text class="breeze-help-r5" x="0" y="1020.4" textLength="1464" clip-path="url(#breeze-help-line-41)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-help-r2" x="1464" y="1020.4" textLength="12.2" clip-path="url(#breeze-help-line-41)">
-</text><text class="breeze-help-r5" x="0" y="1044.8" textLength="24.4" clip-path="url(#breeze-help-line-42)">╭─</text><text class="breeze-help-r5" x="24.4" y="1044.8" textLength="195.2" clip-path="url(#breeze-help-line-42)">&#160;Image&#160;commands&#160;</text><text class="breeze-help-r5" x="219.6" y="1044.8" textLength="1220" clip-path="url(#breeze-help-line-42)">────────────────────────────────────────────────────────────────────────────────────────────────────</text><text class="bree [...]
-</text><text class="breeze-help-r5" x="0" y="1069.2" textLength="12.2" clip-path="url(#breeze-help-line-43)">│</text><text class="breeze-help-r4" x="24.4" y="1069.2" textLength="207.4" clip-path="url(#breeze-help-line-43)">ci-image&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="256.2" y="1069.2" textLength="597.8" clip-path="url(#breeze-help-line-43)">Tools&#160;that&#160;developers&#160;can&#160;use&#160;to&#160;manually&#160;manage&#160;</te [...]
-</text><text class="breeze-help-r5" x="0" y="1093.6" textLength="12.2" clip-path="url(#breeze-help-line-44)">│</text><text class="breeze-help-r4" x="24.4" y="1093.6" textLength="207.4" clip-path="url(#breeze-help-line-44)">prod-image&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="256.2" y="1093.6" textLength="597.8" clip-path="url(#breeze-help-line-44)">Tools&#160;that&#160;developers&#160;can&#160;use&#160;to&#160;manually&#160;manage&#160;</text><text c [...]
-</text><text class="breeze-help-r5" x="0" y="1118" textLength="1464" clip-path="url(#breeze-help-line-45)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-help-r2" x="1464" y="1118" textLength="12.2" clip-path="url(#breeze-help-line-45)">
-</text><text class="breeze-help-r5" x="0" y="1142.4" textLength="24.4" clip-path="url(#breeze-help-line-46)">╭─</text><text class="breeze-help-r5" x="24.4" y="1142.4" textLength="353.8" clip-path="url(#breeze-help-line-46)">&#160;Release&#160;management&#160;commands&#160;</text><text class="breeze-help-r5" x="378.2" y="1142.4" textLength="1061.4" clip-path="url(#breeze-help-line-46)">───────────────────────────────────────────────────────────────────────────────────────</text><text clas [...]
-</text><text class="breeze-help-r5" x="0" y="1166.8" textLength="12.2" clip-path="url(#breeze-help-line-47)">│</text><text class="breeze-help-r4" x="24.4" y="1166.8" textLength="280.6" clip-path="url(#breeze-help-line-47)">release-management&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="329.4" y="1166.8" textLength="1110.2" clip-path="url(#breeze-help-line-47)">Tools&#160;that&#160;release&#160;managers&#160;can&#160;use&#160;to&#160;prepare&#160;and&#160;manage&#16 [...]
-</text><text class="breeze-help-r5" x="0" y="1191.2" textLength="12.2" clip-path="url(#breeze-help-line-48)">│</text><text class="breeze-help-r4" x="24.4" y="1191.2" textLength="280.6" clip-path="url(#breeze-help-line-48)">sbom&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="329.4" y="1191.2" textLength="1110.2" clip-path="url(#breeze-help-line-48)">Tools&#160;that&#160;release&#160;ma [...]
-</text><text class="breeze-help-r5" x="0" y="1215.6" textLength="1464" clip-path="url(#breeze-help-line-49)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-help-r2" x="1464" y="1215.6" textLength="12.2" clip-path="url(#breeze-help-line-49)">
-</text><text class="breeze-help-r5" x="0" y="1240" textLength="24.4" clip-path="url(#breeze-help-line-50)">╭─</text><text class="breeze-help-r5" x="24.4" y="1240" textLength="195.2" clip-path="url(#breeze-help-line-50)">&#160;Other&#160;commands&#160;</text><text class="breeze-help-r5" x="219.6" y="1240" textLength="1220" clip-path="url(#breeze-help-line-50)">────────────────────────────────────────────────────────────────────────────────────────────────────</text><text class="breeze-hel [...]
-</text><text class="breeze-help-r5" x="0" y="1264.4" textLength="12.2" clip-path="url(#breeze-help-line-51)">│</text><text class="breeze-help-r4" x="24.4" y="1264.4" textLength="122" clip-path="url(#breeze-help-line-51)">setup&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="170.8" y="1264.4" textLength="1268.8" clip-path="url(#breeze-help-line-51)">Tools&#160;that&#160;developers&#160;can&#160;use&#160;to&#160;configure&#160;Breeze&#160;&#160;&#160;&#160;&#160;&#160;& [...]
-</text><text class="breeze-help-r5" x="0" y="1288.8" textLength="12.2" clip-path="url(#breeze-help-line-52)">│</text><text class="breeze-help-r4" x="24.4" y="1288.8" textLength="122" clip-path="url(#breeze-help-line-52)">ci&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="170.8" y="1288.8" textLength="134.2" clip-path="url(#breeze-help-line-52)">Tools&#160;that&#160;</text><text class="breeze-help-r4" x="305" y="1288.8" textLength="24.4" clip-path="ur [...]
-</text><text class="breeze-help-r5" x="0" y="1313.2" textLength="1464" clip-path="url(#breeze-help-line-53)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-help-r2" x="1464" y="1313.2" textLength="12.2" clip-path="url(#breeze-help-line-53)">
+</text><text class="breeze-help-r4" x="0" y="93.2" textLength="24.4" clip-path="url(#breeze-help-line-3)">╭─</text><text class="breeze-help-r4" x="24.4" y="93.2" textLength="158.6" clip-path="url(#breeze-help-line-3)">&#160;Basic&#160;flags&#160;</text><text class="breeze-help-r4" x="183" y="93.2" textLength="1256.6" clip-path="url(#breeze-help-line-3)">───────────────────────────────────────────────────────────────────────────────────────────────────────</text><text class="breeze-help-r [...]
+</text><text class="breeze-help-r4" x="0" y="117.6" textLength="12.2" clip-path="url(#breeze-help-line-4)">│</text><text class="breeze-help-r5" x="24.4" y="117.6" textLength="12.2" clip-path="url(#breeze-help-line-4)">-</text><text class="breeze-help-r5" x="36.6" y="117.6" textLength="85.4" clip-path="url(#breeze-help-line-4)">-python</text><text class="breeze-help-r6" x="305" y="117.6" textLength="24.4" clip-path="url(#breeze-help-line-4)">-p</text><text class="breeze-help-r2" x="353.8" [...]
+</text><text class="breeze-help-r4" x="0" y="142" textLength="12.2" clip-path="url(#breeze-help-line-5)">│</text><text class="breeze-help-r4" x="353.8" y="142" textLength="732" clip-path="url(#breeze-help-line-5)">[default:&#160;3.8]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;& [...]
+</text><text class="breeze-help-r4" x="0" y="166.4" textLength="12.2" clip-path="url(#breeze-help-line-6)">│</text><text class="breeze-help-r5" x="24.4" y="166.4" textLength="12.2" clip-path="url(#breeze-help-line-6)">-</text><text class="breeze-help-r5" x="36.6" y="166.4" textLength="97.6" clip-path="url(#breeze-help-line-6)">-backend</text><text class="breeze-help-r6" x="305" y="166.4" textLength="24.4" clip-path="url(#breeze-help-line-6)">-b</text><text class="breeze-help-r2" x="353.8 [...]
+</text><text class="breeze-help-r4" x="0" y="190.8" textLength="12.2" clip-path="url(#breeze-help-line-7)">│</text><text class="breeze-help-r5" x="24.4" y="190.8" textLength="12.2" clip-path="url(#breeze-help-line-7)">-</text><text class="breeze-help-r5" x="36.6" y="190.8" textLength="109.8" clip-path="url(#breeze-help-line-7)">-postgres</text><text class="breeze-help-r5" x="146.4" y="190.8" textLength="97.6" clip-path="url(#breeze-help-line-7)">-version</text><text class="breeze-help-r6 [...]
+</text><text class="breeze-help-r4" x="0" y="215.2" textLength="12.2" clip-path="url(#breeze-help-line-8)">│</text><text class="breeze-help-r5" x="24.4" y="215.2" textLength="12.2" clip-path="url(#breeze-help-line-8)">-</text><text class="breeze-help-r5" x="36.6" y="215.2" textLength="73.2" clip-path="url(#breeze-help-line-8)">-mysql</text><text class="breeze-help-r5" x="109.8" y="215.2" textLength="97.6" clip-path="url(#breeze-help-line-8)">-version</text><text class="breeze-help-r6" x= [...]
+</text><text class="breeze-help-r4" x="0" y="239.6" textLength="12.2" clip-path="url(#breeze-help-line-9)">│</text><text class="breeze-help-r5" x="24.4" y="239.6" textLength="12.2" clip-path="url(#breeze-help-line-9)">-</text><text class="breeze-help-r5" x="36.6" y="239.6" textLength="73.2" clip-path="url(#breeze-help-line-9)">-mssql</text><text class="breeze-help-r5" x="109.8" y="239.6" textLength="97.6" clip-path="url(#breeze-help-line-9)">-version</text><text class="breeze-help-r6" x= [...]
+</text><text class="breeze-help-r4" x="0" y="264" textLength="12.2" clip-path="url(#breeze-help-line-10)">│</text><text class="breeze-help-r5" x="24.4" y="264" textLength="12.2" clip-path="url(#breeze-help-line-10)">-</text><text class="breeze-help-r5" x="36.6" y="264" textLength="146.4" clip-path="url(#breeze-help-line-10)">-integration</text><text class="breeze-help-r2" x="353.8" y="264" textLength="1085.8" clip-path="url(#breeze-help-line-10)">Integration(s)&#160;to&#160;enable&#160;w [...]
+</text><text class="breeze-help-r4" x="0" y="288.4" textLength="12.2" clip-path="url(#breeze-help-line-11)">│</text><text class="breeze-help-r7" x="353.8" y="288.4" textLength="1085.8" clip-path="url(#breeze-help-line-11)">(all&#160;|&#160;all-testable&#160;|&#160;cassandra&#160;|&#160;celery&#160;|&#160;kafka&#160;|&#160;kerberos&#160;|&#160;mongo&#160;|&#160;otel&#160;|&#160;pinot&#160;|&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r4" x="1451.8" y="288.4" textLength="1 [...]
+</text><text class="breeze-help-r4" x="0" y="312.8" textLength="12.2" clip-path="url(#breeze-help-line-12)">│</text><text class="breeze-help-r7" x="353.8" y="312.8" textLength="1085.8" clip-path="url(#breeze-help-line-12)">statsd&#160;|&#160;statsd&#160;|&#160;trino)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#1 [...]
+</text><text class="breeze-help-r4" x="0" y="337.2" textLength="12.2" clip-path="url(#breeze-help-line-13)">│</text><text class="breeze-help-r5" x="24.4" y="337.2" textLength="12.2" clip-path="url(#breeze-help-line-13)">-</text><text class="breeze-help-r5" x="36.6" y="337.2" textLength="97.6" clip-path="url(#breeze-help-line-13)">-forward</text><text class="breeze-help-r5" x="134.2" y="337.2" textLength="146.4" clip-path="url(#breeze-help-line-13)">-credentials</text><text class="breeze- [...]
+</text><text class="breeze-help-r4" x="0" y="361.6" textLength="12.2" clip-path="url(#breeze-help-line-14)">│</text><text class="breeze-help-r5" x="24.4" y="361.6" textLength="12.2" clip-path="url(#breeze-help-line-14)">-</text><text class="breeze-help-r5" x="36.6" y="361.6" textLength="36.6" clip-path="url(#breeze-help-line-14)">-db</text><text class="breeze-help-r5" x="73.2" y="361.6" textLength="73.2" clip-path="url(#breeze-help-line-14)">-reset</text><text class="breeze-help-r6" x="3 [...]
+</text><text class="breeze-help-r4" x="0" y="386" textLength="12.2" clip-path="url(#breeze-help-line-15)">│</text><text class="breeze-help-r5" x="24.4" y="386" textLength="12.2" clip-path="url(#breeze-help-line-15)">-</text><text class="breeze-help-r5" x="36.6" y="386" textLength="48.8" clip-path="url(#breeze-help-line-15)">-max</text><text class="breeze-help-r5" x="85.4" y="386" textLength="61" clip-path="url(#breeze-help-line-15)">-time</text><text class="breeze-help-r2" x="353.8" y="3 [...]
+</text><text class="breeze-help-r4" x="0" y="410.4" textLength="12.2" clip-path="url(#breeze-help-line-16)">│</text><text class="breeze-help-r7" x="353.8" y="410.4" textLength="1049.2" clip-path="url(#breeze-help-line-16)">(INTEGER&#160;RANGE)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#1 [...]
+</text><text class="breeze-help-r4" x="0" y="434.8" textLength="12.2" clip-path="url(#breeze-help-line-17)">│</text><text class="breeze-help-r5" x="24.4" y="434.8" textLength="12.2" clip-path="url(#breeze-help-line-17)">-</text><text class="breeze-help-r5" x="36.6" y="434.8" textLength="85.4" clip-path="url(#breeze-help-line-17)">-github</text><text class="breeze-help-r5" x="122" y="434.8" textLength="134.2" clip-path="url(#breeze-help-line-17)">-repository</text><text class="breeze-help [...]
+</text><text class="breeze-help-r4" x="0" y="459.2" textLength="12.2" clip-path="url(#breeze-help-line-18)">│</text><text class="breeze-help-r5" x="24.4" y="459.2" textLength="12.2" clip-path="url(#breeze-help-line-18)">-</text><text class="breeze-help-r5" x="36.6" y="459.2" textLength="97.6" clip-path="url(#breeze-help-line-18)">-builder</text><text class="breeze-help-r2" x="353.8" y="459.2" textLength="756.4" clip-path="url(#breeze-help-line-18)">Buildx&#160;builder&#160;used&#160;to&# [...]
+</text><text class="breeze-help-r4" x="0" y="483.6" textLength="12.2" clip-path="url(#breeze-help-line-19)">│</text><text class="breeze-help-r4" x="353.8" y="483.6" textLength="756.4" clip-path="url(#breeze-help-line-19)">[default:&#160;autodetect]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#16 [...]
+</text><text class="breeze-help-r4" x="0" y="508" textLength="1464" clip-path="url(#breeze-help-line-20)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-help-r2" x="1464" y="508" textLength="12.2" clip-path="url(#breeze-help-line-20)">
+</text><text class="breeze-help-r4" x="0" y="532.4" textLength="24.4" clip-path="url(#breeze-help-line-21)">╭─</text><text class="breeze-help-r4" x="24.4" y="532.4" textLength="195.2" clip-path="url(#breeze-help-line-21)">&#160;Common&#160;options&#160;</text><text class="breeze-help-r4" x="219.6" y="532.4" textLength="1220" clip-path="url(#breeze-help-line-21)">────────────────────────────────────────────────────────────────────────────────────────────────────</text><text class="breeze- [...]
+</text><text class="breeze-help-r4" x="0" y="556.8" textLength="12.2" clip-path="url(#breeze-help-line-22)">│</text><text class="breeze-help-r5" x="24.4" y="556.8" textLength="12.2" clip-path="url(#breeze-help-line-22)">-</text><text class="breeze-help-r5" x="36.6" y="556.8" textLength="97.6" clip-path="url(#breeze-help-line-22)">-verbose</text><text class="breeze-help-r6" x="158.6" y="556.8" textLength="24.4" clip-path="url(#breeze-help-line-22)">-v</text><text class="breeze-help-r2" x= [...]
+</text><text class="breeze-help-r4" x="0" y="581.2" textLength="12.2" clip-path="url(#breeze-help-line-23)">│</text><text class="breeze-help-r5" x="24.4" y="581.2" textLength="12.2" clip-path="url(#breeze-help-line-23)">-</text><text class="breeze-help-r5" x="36.6" y="581.2" textLength="48.8" clip-path="url(#breeze-help-line-23)">-dry</text><text class="breeze-help-r5" x="85.4" y="581.2" textLength="48.8" clip-path="url(#breeze-help-line-23)">-run</text><text class="breeze-help-r6" x="15 [...]
+</text><text class="breeze-help-r4" x="0" y="605.6" textLength="12.2" clip-path="url(#breeze-help-line-24)">│</text><text class="breeze-help-r5" x="24.4" y="605.6" textLength="12.2" clip-path="url(#breeze-help-line-24)">-</text><text class="breeze-help-r5" x="36.6" y="605.6" textLength="85.4" clip-path="url(#breeze-help-line-24)">-answer</text><text class="breeze-help-r6" x="158.6" y="605.6" textLength="24.4" clip-path="url(#breeze-help-line-24)">-a</text><text class="breeze-help-r2" x=" [...]
+</text><text class="breeze-help-r4" x="0" y="630" textLength="12.2" clip-path="url(#breeze-help-line-25)">│</text><text class="breeze-help-r5" x="24.4" y="630" textLength="12.2" clip-path="url(#breeze-help-line-25)">-</text><text class="breeze-help-r5" x="36.6" y="630" textLength="61" clip-path="url(#breeze-help-line-25)">-help</text><text class="breeze-help-r6" x="158.6" y="630" textLength="24.4" clip-path="url(#breeze-help-line-25)">-h</text><text class="breeze-help-r2" x="207.4" y="63 [...]
+</text><text class="breeze-help-r4" x="0" y="654.4" textLength="1464" clip-path="url(#breeze-help-line-26)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-help-r2" x="1464" y="654.4" textLength="12.2" clip-path="url(#breeze-help-line-26)">
+</text><text class="breeze-help-r4" x="0" y="678.8" textLength="24.4" clip-path="url(#breeze-help-line-27)">╭─</text><text class="breeze-help-r4" x="24.4" y="678.8" textLength="244" clip-path="url(#breeze-help-line-27)">&#160;Developer&#160;commands&#160;</text><text class="breeze-help-r4" x="268.4" y="678.8" textLength="1171.2" clip-path="url(#breeze-help-line-27)">────────────────────────────────────────────────────────────────────────────────────────────────</text><text class="breeze- [...]
+</text><text class="breeze-help-r4" x="0" y="703.2" textLength="12.2" clip-path="url(#breeze-help-line-28)">│</text><text class="breeze-help-r5" x="24.4" y="703.2" textLength="219.6" clip-path="url(#breeze-help-line-28)">start-airflow&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="268.4" y="703.2" textLength="1171.2" clip-path="url(#breeze-help-line-28)">Enter&#160;breeze&#160;environment&#160;and&#160;starts&#160;all&#160;Airflow&#160;components&#160;in&#160;the&#16 [...]
+</text><text class="breeze-help-r4" x="0" y="727.6" textLength="12.2" clip-path="url(#breeze-help-line-29)">│</text><text class="breeze-help-r2" x="268.4" y="727.6" textLength="1171.2" clip-path="url(#breeze-help-line-29)">if&#160;contents&#160;of&#160;www&#160;directory&#160;changed.&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#1 [...]
+</text><text class="breeze-help-r4" x="0" y="752" textLength="12.2" clip-path="url(#breeze-help-line-30)">│</text><text class="breeze-help-r5" x="24.4" y="752" textLength="219.6" clip-path="url(#breeze-help-line-30)">static-checks&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="268.4" y="752" textLength="1171.2" clip-path="url(#breeze-help-line-30)">Run&#160;static&#160;checks.&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&# [...]
+</text><text class="breeze-help-r4" x="0" y="776.4" textLength="12.2" clip-path="url(#breeze-help-line-31)">│</text><text class="breeze-help-r5" x="24.4" y="776.4" textLength="219.6" clip-path="url(#breeze-help-line-31)">build-docs&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="268.4" y="776.4" textLength="1171.2" clip-path="url(#breeze-help-line-31)">Build&#160;documents.&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160; [...]
+</text><text class="breeze-help-r4" x="0" y="800.8" textLength="12.2" clip-path="url(#breeze-help-line-32)">│</text><text class="breeze-help-r5" x="24.4" y="800.8" textLength="219.6" clip-path="url(#breeze-help-line-32)">down&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="268.4" y="800.8" textLength="1171.2" clip-path="url(#breeze-help-line-32)">Stop&#160;running&#160;breeze&#160;environment.&#160;&#160;&#160;&#16 [...]
+</text><text class="breeze-help-r4" x="0" y="825.2" textLength="12.2" clip-path="url(#breeze-help-line-33)">│</text><text class="breeze-help-r5" x="24.4" y="825.2" textLength="219.6" clip-path="url(#breeze-help-line-33)">shell&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="268.4" y="825.2" textLength="1171.2" clip-path="url(#breeze-help-line-33)">Enter&#160;breeze&#160;environment.&#160;this&#160;is&#160;the&#160;defaul [...]
+</text><text class="breeze-help-r4" x="0" y="849.6" textLength="12.2" clip-path="url(#breeze-help-line-34)">│</text><text class="breeze-help-r5" x="24.4" y="849.6" textLength="219.6" clip-path="url(#breeze-help-line-34)">exec&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="268.4" y="849.6" textLength="1171.2" clip-path="url(#breeze-help-line-34)">Joins&#160;the&#160;interactive&#160;shell&#160;of&#160;running&#160; [...]
+</text><text class="breeze-help-r4" x="0" y="874" textLength="12.2" clip-path="url(#breeze-help-line-35)">│</text><text class="breeze-help-r5" x="24.4" y="874" textLength="219.6" clip-path="url(#breeze-help-line-35)">compile-www-assets</text><text class="breeze-help-r2" x="268.4" y="874" textLength="1171.2" clip-path="url(#breeze-help-line-35)">Compiles&#160;www&#160;assets.&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;& [...]
+</text><text class="breeze-help-r4" x="0" y="898.4" textLength="12.2" clip-path="url(#breeze-help-line-36)">│</text><text class="breeze-help-r5" x="24.4" y="898.4" textLength="219.6" clip-path="url(#breeze-help-line-36)">cleanup&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="268.4" y="898.4" textLength="1171.2" clip-path="url(#breeze-help-line-36)">Cleans&#160;the&#160;cache&#160;of&#160;parameters,&#160;docker&#160;cache&#160;and& [...]
+</text><text class="breeze-help-r4" x="0" y="922.8" textLength="1464" clip-path="url(#breeze-help-line-37)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-help-r2" x="1464" y="922.8" textLength="12.2" clip-path="url(#breeze-help-line-37)">
+</text><text class="breeze-help-r4" x="0" y="947.2" textLength="24.4" clip-path="url(#breeze-help-line-38)">╭─</text><text class="breeze-help-r4" x="24.4" y="947.2" textLength="219.6" clip-path="url(#breeze-help-line-38)">&#160;Testing&#160;commands&#160;</text><text class="breeze-help-r4" x="244" y="947.2" textLength="1195.6" clip-path="url(#breeze-help-line-38)">──────────────────────────────────────────────────────────────────────────────────────────────────</text><text class="breeze- [...]
+</text><text class="breeze-help-r4" x="0" y="971.6" textLength="12.2" clip-path="url(#breeze-help-line-39)">│</text><text class="breeze-help-r5" x="24.4" y="971.6" textLength="183" clip-path="url(#breeze-help-line-39)">testing&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="231.8" y="971.6" textLength="1207.8" clip-path="url(#breeze-help-line-39)">Tools&#160;that&#160;developers&#160;can&#160;use&#160;to&#160;run&#160;tests&#160;&#160;&#160;&#160;&#1 [...]
+</text><text class="breeze-help-r4" x="0" y="996" textLength="12.2" clip-path="url(#breeze-help-line-40)">│</text><text class="breeze-help-r5" x="24.4" y="996" textLength="183" clip-path="url(#breeze-help-line-40)">k8s&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="231.8" y="996" textLength="1207.8" clip-path="url(#breeze-help-line-40)">Tools&#160;that&#160;developers&#160;use&#160;to&#160;run&#160;Kubernetes&#160;tests&#160; [...]
+</text><text class="breeze-help-r4" x="0" y="1020.4" textLength="1464" clip-path="url(#breeze-help-line-41)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-help-r2" x="1464" y="1020.4" textLength="12.2" clip-path="url(#breeze-help-line-41)">
+</text><text class="breeze-help-r4" x="0" y="1044.8" textLength="24.4" clip-path="url(#breeze-help-line-42)">╭─</text><text class="breeze-help-r4" x="24.4" y="1044.8" textLength="195.2" clip-path="url(#breeze-help-line-42)">&#160;Image&#160;commands&#160;</text><text class="breeze-help-r4" x="219.6" y="1044.8" textLength="1220" clip-path="url(#breeze-help-line-42)">────────────────────────────────────────────────────────────────────────────────────────────────────</text><text class="bree [...]
+</text><text class="breeze-help-r4" x="0" y="1069.2" textLength="12.2" clip-path="url(#breeze-help-line-43)">│</text><text class="breeze-help-r5" x="24.4" y="1069.2" textLength="207.4" clip-path="url(#breeze-help-line-43)">ci-image&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="256.2" y="1069.2" textLength="1183.4" clip-path="url(#breeze-help-line-43)">Tools&#160;that&#160;developers&#160;can&#160;use&#160;to&#160;manually&#160;manage&#160;CI& [...]
+</text><text class="breeze-help-r4" x="0" y="1093.6" textLength="12.2" clip-path="url(#breeze-help-line-44)">│</text><text class="breeze-help-r5" x="24.4" y="1093.6" textLength="207.4" clip-path="url(#breeze-help-line-44)">prod-image&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="256.2" y="1093.6" textLength="1183.4" clip-path="url(#breeze-help-line-44)">Tools&#160;that&#160;developers&#160;can&#160;use&#160;to&#160;manually&#160;manage&#160;PROD&#160;ima [...]
+</text><text class="breeze-help-r4" x="0" y="1118" textLength="1464" clip-path="url(#breeze-help-line-45)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-help-r2" x="1464" y="1118" textLength="12.2" clip-path="url(#breeze-help-line-45)">
+</text><text class="breeze-help-r4" x="0" y="1142.4" textLength="24.4" clip-path="url(#breeze-help-line-46)">╭─</text><text class="breeze-help-r4" x="24.4" y="1142.4" textLength="353.8" clip-path="url(#breeze-help-line-46)">&#160;Release&#160;management&#160;commands&#160;</text><text class="breeze-help-r4" x="378.2" y="1142.4" textLength="1061.4" clip-path="url(#breeze-help-line-46)">───────────────────────────────────────────────────────────────────────────────────────</text><text clas [...]
+</text><text class="breeze-help-r4" x="0" y="1166.8" textLength="12.2" clip-path="url(#breeze-help-line-47)">│</text><text class="breeze-help-r5" x="24.4" y="1166.8" textLength="280.6" clip-path="url(#breeze-help-line-47)">release-management&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="329.4" y="1166.8" textLength="1110.2" clip-path="url(#breeze-help-line-47)">Tools&#160;that&#160;release&#160;managers&#160;can&#160;use&#160;to&#160;prepare&#160;and&#160;manage&#16 [...]
+</text><text class="breeze-help-r4" x="0" y="1191.2" textLength="12.2" clip-path="url(#breeze-help-line-48)">│</text><text class="breeze-help-r5" x="24.4" y="1191.2" textLength="280.6" clip-path="url(#breeze-help-line-48)">sbom&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="329.4" y="1191.2" textLength="1110.2" clip-path="url(#breeze-help-line-48)">Tools&#160;that&#160;release&#160;ma [...]
+</text><text class="breeze-help-r4" x="0" y="1215.6" textLength="1464" clip-path="url(#breeze-help-line-49)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-help-r2" x="1464" y="1215.6" textLength="12.2" clip-path="url(#breeze-help-line-49)">
+</text><text class="breeze-help-r4" x="0" y="1240" textLength="24.4" clip-path="url(#breeze-help-line-50)">╭─</text><text class="breeze-help-r4" x="24.4" y="1240" textLength="195.2" clip-path="url(#breeze-help-line-50)">&#160;Other&#160;commands&#160;</text><text class="breeze-help-r4" x="219.6" y="1240" textLength="1220" clip-path="url(#breeze-help-line-50)">────────────────────────────────────────────────────────────────────────────────────────────────────</text><text class="breeze-hel [...]
+</text><text class="breeze-help-r4" x="0" y="1264.4" textLength="12.2" clip-path="url(#breeze-help-line-51)">│</text><text class="breeze-help-r5" x="24.4" y="1264.4" textLength="122" clip-path="url(#breeze-help-line-51)">setup&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="170.8" y="1264.4" textLength="1268.8" clip-path="url(#breeze-help-line-51)">Tools&#160;that&#160;developers&#160;can&#160;use&#160;to&#160;configure&#160;Breeze&#160;&#160;&#160;&#160;&#160;&#160;& [...]
+</text><text class="breeze-help-r4" x="0" y="1288.8" textLength="12.2" clip-path="url(#breeze-help-line-52)">│</text><text class="breeze-help-r5" x="24.4" y="1288.8" textLength="122" clip-path="url(#breeze-help-line-52)">ci&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-help-r2" x="170.8" y="1288.8" textLength="1268.8" clip-path="url(#breeze-help-line-52)">Tools&#160;that&#160;CI&#160;workflows&#160;use&#160;to&#160;cleanup/manage&#160;CI&#160;environment&#160; [...]
+</text><text class="breeze-help-r4" x="0" y="1313.2" textLength="1464" clip-path="url(#breeze-help-line-53)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-help-r2" x="1464" y="1313.2" textLength="12.2" clip-path="url(#breeze-help-line-53)">
 </text>
     </g>
     </g>
diff --git a/images/breeze/output_ci-image.svg b/images/breeze/output_ci-image.svg
index bf1df9347a..3025e6e470 100644
--- a/images/breeze/output_ci-image.svg
+++ b/images/breeze/output_ci-image.svg
@@ -35,8 +35,8 @@
     .breeze-ci-image-r1 { fill: #c5c8c6;font-weight: bold }
 .breeze-ci-image-r2 { fill: #c5c8c6 }
 .breeze-ci-image-r3 { fill: #d0b344;font-weight: bold }
-.breeze-ci-image-r4 { fill: #68a0b3;font-weight: bold }
-.breeze-ci-image-r5 { fill: #868887 }
+.breeze-ci-image-r4 { fill: #868887 }
+.breeze-ci-image-r5 { fill: #68a0b3;font-weight: bold }
 .breeze-ci-image-r6 { fill: #98a84b;font-weight: bold }
     </style>
 
@@ -93,18 +93,18 @@
     
     <g class="breeze-ci-image-matrix">
     <text class="breeze-ci-image-r2" x="1464" y="20" textLength="12.2" clip-path="url(#breeze-ci-image-line-0)">
-</text><text class="breeze-ci-image-r3" x="12.2" y="44.4" textLength="85.4" clip-path="url(#breeze-ci-image-line-1)">Usage:&#160;</text><text class="breeze-ci-image-r1" x="97.6" y="44.4" textLength="207.4" clip-path="url(#breeze-ci-image-line-1)">breeze&#160;ci-image&#160;[</text><text class="breeze-ci-image-r4" x="305" y="44.4" textLength="85.4" clip-path="url(#breeze-ci-image-line-1)">OPTIONS</text><text class="breeze-ci-image-r1" x="390.4" y="44.4" textLength="24.4" clip-path="url(#br [...]
+</text><text class="breeze-ci-image-r3" x="12.2" y="44.4" textLength="85.4" clip-path="url(#breeze-ci-image-line-1)">Usage:&#160;</text><text class="breeze-ci-image-r1" x="97.6" y="44.4" textLength="524.6" clip-path="url(#breeze-ci-image-line-1)">breeze&#160;ci-image&#160;[OPTIONS]&#160;COMMAND&#160;[ARGS]...</text><text class="breeze-ci-image-r2" x="1464" y="44.4" textLength="12.2" clip-path="url(#breeze-ci-image-line-1)">
 </text><text class="breeze-ci-image-r2" x="1464" y="68.8" textLength="12.2" clip-path="url(#breeze-ci-image-line-2)">
-</text><text class="breeze-ci-image-r2" x="12.2" y="93.2" textLength="597.8" clip-path="url(#breeze-ci-image-line-3)">Tools&#160;that&#160;developers&#160;can&#160;use&#160;to&#160;manually&#160;manage&#160;</text><text class="breeze-ci-image-r4" x="610" y="93.2" textLength="24.4" clip-path="url(#breeze-ci-image-line-3)">CI</text><text class="breeze-ci-image-r2" x="634.4" y="93.2" textLength="85.4" clip-path="url(#breeze-ci-image-line-3)">&#160;images</text><text class="breeze-ci-image-r [...]
+</text><text class="breeze-ci-image-r2" x="12.2" y="93.2" textLength="707.6" clip-path="url(#breeze-ci-image-line-3)">Tools&#160;that&#160;developers&#160;can&#160;use&#160;to&#160;manually&#160;manage&#160;CI&#160;images</text><text class="breeze-ci-image-r2" x="1464" y="93.2" textLength="12.2" clip-path="url(#breeze-ci-image-line-3)">
 </text><text class="breeze-ci-image-r2" x="1464" y="117.6" textLength="12.2" clip-path="url(#breeze-ci-image-line-4)">
-</text><text class="breeze-ci-image-r5" x="0" y="142" textLength="24.4" clip-path="url(#breeze-ci-image-line-5)">╭─</text><text class="breeze-ci-image-r5" x="24.4" y="142" textLength="195.2" clip-path="url(#breeze-ci-image-line-5)">&#160;Common&#160;options&#160;</text><text class="breeze-ci-image-r5" x="219.6" y="142" textLength="1220" clip-path="url(#breeze-ci-image-line-5)">────────────────────────────────────────────────────────────────────────────────────────────────────</text><text [...]
-</text><text class="breeze-ci-image-r5" x="0" y="166.4" textLength="12.2" clip-path="url(#breeze-ci-image-line-6)">│</text><text class="breeze-ci-image-r4" x="24.4" y="166.4" textLength="12.2" clip-path="url(#breeze-ci-image-line-6)">-</text><text class="breeze-ci-image-r4" x="36.6" y="166.4" textLength="61" clip-path="url(#breeze-ci-image-line-6)">-help</text><text class="breeze-ci-image-r6" x="122" y="166.4" textLength="24.4" clip-path="url(#breeze-ci-image-line-6)">-h</text><text clas [...]
-</text><text class="breeze-ci-image-r5" x="0" y="190.8" textLength="1464" clip-path="url(#breeze-ci-image-line-7)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-ci-image-r2" x="1464" y="190.8" textLength="12.2" clip-path="url(#breeze-ci-image-line-7)">
-</text><text class="breeze-ci-image-r5" x="0" y="215.2" textLength="24.4" clip-path="url(#breeze-ci-image-line-8)">╭─</text><text class="breeze-ci-image-r5" x="24.4" y="215.2" textLength="195.2" clip-path="url(#breeze-ci-image-line-8)">&#160;CI&#160;Image&#160;tools&#160;</text><text class="breeze-ci-image-r5" x="219.6" y="215.2" textLength="1220" clip-path="url(#breeze-ci-image-line-8)">────────────────────────────────────────────────────────────────────────────────────────────────────< [...]
-</text><text class="breeze-ci-image-r5" x="0" y="239.6" textLength="12.2" clip-path="url(#breeze-ci-image-line-9)">│</text><text class="breeze-ci-image-r4" x="24.4" y="239.6" textLength="97.6" clip-path="url(#breeze-ci-image-line-9)">build&#160;&#160;&#160;</text><text class="breeze-ci-image-r2" x="146.4" y="239.6" textLength="73.2" clip-path="url(#breeze-ci-image-line-9)">Build&#160;</text><text class="breeze-ci-image-r4" x="219.6" y="239.6" textLength="24.4" clip-path="url(#breeze-ci-i [...]
-</text><text class="breeze-ci-image-r5" x="0" y="264" textLength="12.2" clip-path="url(#breeze-ci-image-line-10)">│</text><text class="breeze-ci-image-r4" x="24.4" y="264" textLength="97.6" clip-path="url(#breeze-ci-image-line-10)">pull&#160;&#160;&#160;&#160;</text><text class="breeze-ci-image-r2" x="146.4" y="264" textLength="329.4" clip-path="url(#breeze-ci-image-line-10)">Pull&#160;and&#160;optionally&#160;verify&#160;</text><text class="breeze-ci-image-r4" x="475.8" y="264" textLeng [...]
-</text><text class="breeze-ci-image-r5" x="0" y="288.4" textLength="12.2" clip-path="url(#breeze-ci-image-line-11)">│</text><text class="breeze-ci-image-r4" x="24.4" y="288.4" textLength="97.6" clip-path="url(#breeze-ci-image-line-11)">verify&#160;&#160;</text><text class="breeze-ci-image-r2" x="146.4" y="288.4" textLength="85.4" clip-path="url(#breeze-ci-image-line-11)">Verify&#160;</text><text class="breeze-ci-image-r4" x="231.8" y="288.4" textLength="24.4" clip-path="url(#breeze-ci-im [...]
-</text><text class="breeze-ci-image-r5" x="0" y="312.8" textLength="1464" clip-path="url(#breeze-ci-image-line-12)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-ci-image-r2" x="1464" y="312.8" textLength="12.2" clip-path="url(#breeze-ci-image-line-12)">
+</text><text class="breeze-ci-image-r4" x="0" y="142" textLength="24.4" clip-path="url(#breeze-ci-image-line-5)">╭─</text><text class="breeze-ci-image-r4" x="24.4" y="142" textLength="195.2" clip-path="url(#breeze-ci-image-line-5)">&#160;Common&#160;options&#160;</text><text class="breeze-ci-image-r4" x="219.6" y="142" textLength="1220" clip-path="url(#breeze-ci-image-line-5)">────────────────────────────────────────────────────────────────────────────────────────────────────</text><text [...]
+</text><text class="breeze-ci-image-r4" x="0" y="166.4" textLength="12.2" clip-path="url(#breeze-ci-image-line-6)">│</text><text class="breeze-ci-image-r5" x="24.4" y="166.4" textLength="12.2" clip-path="url(#breeze-ci-image-line-6)">-</text><text class="breeze-ci-image-r5" x="36.6" y="166.4" textLength="61" clip-path="url(#breeze-ci-image-line-6)">-help</text><text class="breeze-ci-image-r6" x="122" y="166.4" textLength="24.4" clip-path="url(#breeze-ci-image-line-6)">-h</text><text clas [...]
+</text><text class="breeze-ci-image-r4" x="0" y="190.8" textLength="1464" clip-path="url(#breeze-ci-image-line-7)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-ci-image-r2" x="1464" y="190.8" textLength="12.2" clip-path="url(#breeze-ci-image-line-7)">
+</text><text class="breeze-ci-image-r4" x="0" y="215.2" textLength="24.4" clip-path="url(#breeze-ci-image-line-8)">╭─</text><text class="breeze-ci-image-r4" x="24.4" y="215.2" textLength="195.2" clip-path="url(#breeze-ci-image-line-8)">&#160;CI&#160;Image&#160;tools&#160;</text><text class="breeze-ci-image-r4" x="219.6" y="215.2" textLength="1220" clip-path="url(#breeze-ci-image-line-8)">────────────────────────────────────────────────────────────────────────────────────────────────────< [...]
+</text><text class="breeze-ci-image-r4" x="0" y="239.6" textLength="12.2" clip-path="url(#breeze-ci-image-line-9)">│</text><text class="breeze-ci-image-r5" x="24.4" y="239.6" textLength="97.6" clip-path="url(#breeze-ci-image-line-9)">build&#160;&#160;&#160;</text><text class="breeze-ci-image-r2" x="146.4" y="239.6" textLength="1293.2" clip-path="url(#breeze-ci-image-line-9)">Build&#160;CI&#160;image.&#160;Include&#160;building&#160;multiple&#160;images&#160;for&#160;all&#160;python&#160; [...]
+</text><text class="breeze-ci-image-r4" x="0" y="264" textLength="12.2" clip-path="url(#breeze-ci-image-line-10)">│</text><text class="breeze-ci-image-r5" x="24.4" y="264" textLength="97.6" clip-path="url(#breeze-ci-image-line-10)">pull&#160;&#160;&#160;&#160;</text><text class="breeze-ci-image-r2" x="146.4" y="264" textLength="1293.2" clip-path="url(#breeze-ci-image-line-10)">Pull&#160;and&#160;optionally&#160;verify&#160;CI&#160;images&#160;-&#160;possibly&#160;in&#160;parallel&#160;fo [...]
+</text><text class="breeze-ci-image-r4" x="0" y="288.4" textLength="12.2" clip-path="url(#breeze-ci-image-line-11)">│</text><text class="breeze-ci-image-r5" x="24.4" y="288.4" textLength="97.6" clip-path="url(#breeze-ci-image-line-11)">verify&#160;&#160;</text><text class="breeze-ci-image-r2" x="146.4" y="288.4" textLength="1293.2" clip-path="url(#breeze-ci-image-line-11)">Verify&#160;CI&#160;image.&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160; [...]
+</text><text class="breeze-ci-image-r4" x="0" y="312.8" textLength="1464" clip-path="url(#breeze-ci-image-line-12)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-ci-image-r2" x="1464" y="312.8" textLength="12.2" clip-path="url(#breeze-ci-image-line-12)">
 </text>
     </g>
     </g>
diff --git a/images/breeze/output_ci-image_build.svg b/images/breeze/output_ci-image_build.svg
index 1418e4c43c..2f6e1d26a7 100644
--- a/images/breeze/output_ci-image_build.svg
+++ b/images/breeze/output_ci-image_build.svg
@@ -1,4 +1,4 @@
-<svg class="rich-terminal" viewBox="0 0 1482 2075.2" xmlns="http://www.w3.org/2000/svg">
+<svg class="rich-terminal" viewBox="0 0 1482 2099.6" xmlns="http://www.w3.org/2000/svg">
     <!-- Generated with Rich https://www.textualize.io -->
     <style>
 
@@ -35,15 +35,15 @@
     .breeze-ci-image-build-r1 { fill: #c5c8c6;font-weight: bold }
 .breeze-ci-image-build-r2 { fill: #c5c8c6 }
 .breeze-ci-image-build-r3 { fill: #d0b344;font-weight: bold }
-.breeze-ci-image-build-r4 { fill: #68a0b3;font-weight: bold }
-.breeze-ci-image-build-r5 { fill: #868887 }
+.breeze-ci-image-build-r4 { fill: #868887 }
+.breeze-ci-image-build-r5 { fill: #68a0b3;font-weight: bold }
 .breeze-ci-image-build-r6 { fill: #98a84b;font-weight: bold }
 .breeze-ci-image-build-r7 { fill: #8d7b39 }
     </style>
 
     <defs>
     <clipPath id="breeze-ci-image-build-clip-terminal">
-      <rect x="0" y="0" width="1463.0" height="2024.1999999999998" />
+      <rect x="0" y="0" width="1463.0" height="2048.6" />
     </clipPath>
     <clipPath id="breeze-ci-image-build-line-0">
     <rect x="0" y="1.5" width="1464" height="24.65"/>
@@ -291,9 +291,12 @@
 <clipPath id="breeze-ci-image-build-line-81">
     <rect x="0" y="1977.9" width="1464" height="24.65"/>
             </clipPath>
+<clipPath id="breeze-ci-image-build-line-82">
+    <rect x="0" y="2002.3" width="1464" height="24.65"/>
+            </clipPath>
     </defs>
 
-    <rect fill="#292929" stroke="rgba(255,255,255,0.35)" stroke-width="1" x="1" y="1" width="1480" height="2073.2" rx="8"/><text class="breeze-ci-image-build-title" fill="#c5c8c6" text-anchor="middle" x="740" y="27">Command:&#160;ci-image&#160;build</text>
+    <rect fill="#292929" stroke="rgba(255,255,255,0.35)" stroke-width="1" x="1" y="1" width="1480" height="2097.6" rx="8"/><text class="breeze-ci-image-build-title" fill="#c5c8c6" text-anchor="middle" x="740" y="27">Command:&#160;ci-image&#160;build</text>
             <g transform="translate(26,22)">
             <circle cx="0" cy="0" r="7" fill="#ff5f57"/>
             <circle cx="22" cy="0" r="7" fill="#febc2e"/>
@@ -304,88 +307,89 @@
     
     <g class="breeze-ci-image-build-matrix">
     <text class="breeze-ci-image-build-r2" x="1464" y="20" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-0)">
-</text><text class="breeze-ci-image-build-r3" x="12.2" y="44.4" textLength="85.4" clip-path="url(#breeze-ci-image-build-line-1)">Usage:&#160;</text><text class="breeze-ci-image-build-r1" x="97.6" y="44.4" textLength="280.6" clip-path="url(#breeze-ci-image-build-line-1)">breeze&#160;ci-image&#160;build&#160;[</text><text class="breeze-ci-image-build-r4" x="378.2" y="44.4" textLength="85.4" clip-path="url(#breeze-ci-image-build-line-1)">OPTIONS</text><text class="breeze-ci-image-build-r1"  [...]
+</text><text class="breeze-ci-image-build-r3" x="12.2" y="44.4" textLength="85.4" clip-path="url(#breeze-ci-image-build-line-1)">Usage:&#160;</text><text class="breeze-ci-image-build-r1" x="97.6" y="44.4" textLength="378.2" clip-path="url(#breeze-ci-image-build-line-1)">breeze&#160;ci-image&#160;build&#160;[OPTIONS]</text><text class="breeze-ci-image-build-r2" x="1464" y="44.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-1)">
 </text><text class="breeze-ci-image-build-r2" x="1464" y="68.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-2)">
-</text><text class="breeze-ci-image-build-r2" x="12.2" y="93.2" textLength="73.2" clip-path="url(#breeze-ci-image-build-line-3)">Build&#160;</text><text class="breeze-ci-image-build-r4" x="85.4" y="93.2" textLength="24.4" clip-path="url(#breeze-ci-image-build-line-3)">CI</text><text class="breeze-ci-image-build-r2" x="109.8" y="93.2" textLength="793" clip-path="url(#breeze-ci-image-build-line-3)">&#160;image.&#160;Include&#160;building&#160;multiple&#160;images&#160;for&#160;all&#160;pyt [...]
+</text><text class="breeze-ci-image-build-r2" x="12.2" y="93.2" textLength="890.6" clip-path="url(#breeze-ci-image-build-line-3)">Build&#160;CI&#160;image.&#160;Include&#160;building&#160;multiple&#160;images&#160;for&#160;all&#160;python&#160;versions.</text><text class="breeze-ci-image-build-r2" x="1464" y="93.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-3)">
 </text><text class="breeze-ci-image-build-r2" x="1464" y="117.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-4)">
-</text><text class="breeze-ci-image-build-r5" x="0" y="142" textLength="24.4" clip-path="url(#breeze-ci-image-build-line-5)">╭─</text><text class="breeze-ci-image-build-r5" x="24.4" y="142" textLength="158.6" clip-path="url(#breeze-ci-image-build-line-5)">&#160;Basic&#160;usage&#160;</text><text class="breeze-ci-image-build-r5" x="183" y="142" textLength="1256.6" clip-path="url(#breeze-ci-image-build-line-5)">─────────────────────────────────────────────────────────────────────────────── [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="166.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-6)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="166.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-6)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="166.4" textLength="85.4" clip-path="url(#breeze-ci-image-build-line-6)">-python</text><text class="breeze-ci-image-build-r6" x="427" y="166.4" textLength="24.4" clip-path="url [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="190.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-7)">│</text><text class="breeze-ci-image-build-r7" x="475.8" y="190.8" textLength="732" clip-path="url(#breeze-ci-image-build-line-7)">(&gt;3.8&lt;&#160;|&#160;3.9&#160;|&#160;3.10&#160;|&#160;3.11)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#1 [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="215.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-8)">│</text><text class="breeze-ci-image-build-r5" x="475.8" y="215.2" textLength="732" clip-path="url(#breeze-ci-image-build-line-8)">[default:&#160;3.8]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160 [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="239.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-9)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="239.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-9)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="239.6" textLength="97.6" clip-path="url(#breeze-ci-image-build-line-9)">-upgrade</text><text class="breeze-ci-image-build-r4" x="134.2" y="239.6" textLength="268.4" clip-path= [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="264" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-10)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="264" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-10)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="264" textLength="97.6" clip-path="url(#breeze-ci-image-build-line-10)">-upgrade</text><text class="breeze-ci-image-build-r4" x="134.2" y="264" textLength="134.2" clip-path="url( [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="288.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-11)">│</text><text class="breeze-ci-image-build-r2" x="475.8" y="288.4" textLength="963.8" clip-path="url(#breeze-ci-image-build-line-11)">fails.&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&# [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="312.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-12)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="312.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-12)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="312.8" textLength="73.2" clip-path="url(#breeze-ci-image-build-line-12)">-image</text><text class="breeze-ci-image-build-r4" x="109.8" y="312.8" textLength="48.8" clip-path= [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="337.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-13)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="337.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-13)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="337.2" textLength="48.8" clip-path="url(#breeze-ci-image-build-line-13)">-tag</text><text class="breeze-ci-image-build-r4" x="85.4" y="337.2" textLength="122" clip-path="url [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="361.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-14)">│</text><text class="breeze-ci-image-build-r2" x="475.8" y="361.6" textLength="414.8" clip-path="url(#breeze-ci-image-build-line-14)">when&#160;you&#160;build&#160;or&#160;pull&#160;image&#160;with&#160;</text><text class="breeze-ci-image-build-r4" x="890.6" y="361.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-14)">-</text><text class="breeze-c [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="386" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-15)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="386" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-15)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="386" textLength="85.4" clip-path="url(#breeze-ci-image-build-line-15)">-docker</text><text class="breeze-ci-image-build-r4" x="122" y="386" textLength="73.2" clip-path="url(#bre [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="410.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-16)">│</text><text class="breeze-ci-image-build-r5" x="475.8" y="410.4" textLength="549" clip-path="url(#breeze-ci-image-build-line-16)">[default:&#160;registry]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-ci-image-build-r5" x="145 [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="434.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-17)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="434.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-17)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="434.8" textLength="73.2" clip-path="url(#breeze-ci-image-build-line-17)">-force</text><text class="breeze-ci-image-build-r4" x="109.8" y="434.8" textLength="73.2" clip-path= [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="459.2" textLength="1464" clip-path="url(#breeze-ci-image-build-line-18)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-ci-image-build-r2" x="1464" y="459.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-18)">
-</text><text class="breeze-ci-image-build-r5" x="0" y="483.6" textLength="24.4" clip-path="url(#breeze-ci-image-build-line-19)">╭─</text><text class="breeze-ci-image-build-r5" x="24.4" y="483.6" textLength="353.8" clip-path="url(#breeze-ci-image-build-line-19)">&#160;Building&#160;images&#160;in&#160;parallel&#160;</text><text class="breeze-ci-image-build-r5" x="378.2" y="483.6" textLength="1061.4" clip-path="url(#breeze-ci-image-build-line-19)">────────────────────────────────────────── [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="508" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-20)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="508" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-20)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="508" textLength="48.8" clip-path="url(#breeze-ci-image-build-line-20)">-run</text><text class="breeze-ci-image-build-r4" x="85.4" y="508" textLength="146.4" clip-path="url(#bree [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="532.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-21)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="532.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-21)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="532.4" textLength="146.4" clip-path="url(#breeze-ci-image-build-line-21)">-parallelism</text><text class="breeze-ci-image-build-r2" x="378.2" y="532.4" textLength="915" clip [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="556.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-22)">│</text><text class="breeze-ci-image-build-r7" x="378.2" y="556.8" textLength="915" clip-path="url(#breeze-ci-image-build-line-22)">(INTEGER&#160;RANGE)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&# [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="581.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-23)">│</text><text class="breeze-ci-image-build-r5" x="378.2" y="581.2" textLength="915" clip-path="url(#breeze-ci-image-build-line-23)">[default:&#160;4;&#160;1&lt;=x&lt;=8]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#1 [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="605.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-24)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="605.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-24)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="605.6" textLength="85.4" clip-path="url(#breeze-ci-image-build-line-24)">-python</text><text class="breeze-ci-image-build-r4" x="122" y="605.6" textLength="109.8" clip-path= [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="630" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-25)">│</text><text class="breeze-ci-image-build-r5" x="378.2" y="630" textLength="951.6" clip-path="url(#breeze-ci-image-build-line-25)">[default:&#160;3.8&#160;3.9&#160;3.10&#160;3.11]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160; [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="654.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-26)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="654.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-26)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="654.4" textLength="61" clip-path="url(#breeze-ci-image-build-line-26)">-skip</text><text class="breeze-ci-image-build-r4" x="97.6" y="654.4" textLength="97.6" clip-path="url [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="678.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-27)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="678.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-27)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="678.8" textLength="73.2" clip-path="url(#breeze-ci-image-build-line-27)">-debug</text><text class="breeze-ci-image-build-r4" x="109.8" y="678.8" textLength="122" clip-path=" [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="703.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-28)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="703.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-28)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="703.2" textLength="97.6" clip-path="url(#breeze-ci-image-build-line-28)">-include</text><text class="breeze-ci-image-build-r4" x="134.2" y="703.2" textLength="195.2" clip-pa [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="727.6" textLength="1464" clip-path="url(#breeze-ci-image-build-line-29)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-ci-image-build-r2" x="1464" y="727.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-29)">
-</text><text class="breeze-ci-image-build-r5" x="0" y="752" textLength="24.4" clip-path="url(#breeze-ci-image-build-line-30)">╭─</text><text class="breeze-ci-image-build-r5" x="24.4" y="752" textLength="439.2" clip-path="url(#breeze-ci-image-build-line-30)">&#160;Advanced&#160;options&#160;(for&#160;power&#160;users)&#160;</text><text class="breeze-ci-image-build-r5" x="463.6" y="752" textLength="976" clip-path="url(#breeze-ci-image-build-line-30)">─────────────────────────────────────── [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="776.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-31)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="776.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-31)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="776.4" textLength="97.6" clip-path="url(#breeze-ci-image-build-line-31)">-install</text><text class="breeze-ci-image-build-r4" x="134.2" y="776.4" textLength="280.6" clip-pa [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="800.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-32)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="800.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-32)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="800.8" textLength="97.6" clip-path="url(#breeze-ci-image-build-line-32)">-airflow</text><text class="breeze-ci-image-build-r4" x="134.2" y="800.8" textLength="256.2" clip-pa [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="825.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-33)">│</text><text class="breeze-ci-image-build-r2" x="463.6" y="825.2" textLength="366" clip-path="url(#breeze-ci-image-build-line-33)">file.&#160;It&#160;could&#160;be&#160;full&#160;remote&#160;</text><text class="breeze-ci-image-build-r4" x="829.6" y="825.2" textLength="36.6" clip-path="url(#breeze-ci-image-build-line-33)">URL</text><text class="breeze-ci-image-b [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="849.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-34)">│</text><text class="breeze-ci-image-build-r2" x="463.6" y="849.6" textLength="976" clip-path="url(#breeze-ci-image-build-line-34)">`docker-context-files`&#160;(in&#160;this&#160;case&#160;it&#160;has&#160;to&#160;start&#160;with&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#1 [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="874" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-35)">│</text><text class="breeze-ci-image-build-r2" x="463.6" y="874" textLength="976" clip-path="url(#breeze-ci-image-build-line-35)">/opt/airflow/docker-context-files).&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#1 [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="898.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-36)">│</text><text class="breeze-ci-image-build-r7" x="463.6" y="898.4" textLength="976" clip-path="url(#breeze-ci-image-build-line-36)">(TEXT)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#16 [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="922.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-37)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="922.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-37)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="922.8" textLength="97.6" clip-path="url(#breeze-ci-image-build-line-37)">-airflow</text><text class="breeze-ci-image-build-r4" x="134.2" y="922.8" textLength="207.4" clip-pa [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="947.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-38)">│</text><text class="breeze-ci-image-build-r7" x="463.6" y="947.2" textLength="866.2" clip-path="url(#breeze-ci-image-build-line-38)">(constraints-source-providers&#160;|&#160;constraints&#160;|&#160;constraints-no-providers)</text><text class="breeze-ci-image-build-r5" x="1451.8" y="947.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-38)">│</tex [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="971.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-39)">│</text><text class="breeze-ci-image-build-r5" x="463.6" y="971.6" textLength="866.2" clip-path="url(#breeze-ci-image-build-line-39)">[default:&#160;constraints-source-providers]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160; [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="996" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-40)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="996" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-40)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="996" textLength="97.6" clip-path="url(#breeze-ci-image-build-line-40)">-airflow</text><text class="breeze-ci-image-build-r4" x="134.2" y="996" textLength="268.4" clip-path="url( [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1020.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-41)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="1020.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-41)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="1020.4" textLength="85.4" clip-path="url(#breeze-ci-image-build-line-41)">-python</text><text class="breeze-ci-image-build-r4" x="122" y="1020.4" textLength="73.2" clip-pa [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1044.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-42)">│</text><text class="breeze-ci-image-build-r2" x="463.6" y="1044.8" textLength="280.6" clip-path="url(#breeze-ci-image-build-line-42)">something&#160;like:&#160;python:</text><text class="breeze-ci-image-build-r4" x="744.2" y="1044.8" textLength="85.4" clip-path="url(#breeze-ci-image-build-line-42)">VERSION</text><text class="breeze-ci-image-build-r2" x="829.6" [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1069.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-43)">│</text><text class="breeze-ci-image-build-r7" x="463.6" y="1069.2" textLength="976" clip-path="url(#breeze-ci-image-build-line-43)">(TEXT)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&# [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1093.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-44)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="1093.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-44)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="1093.6" textLength="134.2" clip-path="url(#breeze-ci-image-build-line-44)">-additional</text><text class="breeze-ci-image-build-r4" x="170.8" y="1093.6" textLength="146.4" [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1118" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-45)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="1118" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-45)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="1118" textLength="134.2" clip-path="url(#breeze-ci-image-build-line-45)">-additional</text><text class="breeze-ci-image-build-r4" x="170.8" y="1118" textLength="85.4" clip-pat [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1142.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-46)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="1142.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-46)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="1142.4" textLength="134.2" clip-path="url(#breeze-ci-image-build-line-46)">-additional</text><text class="breeze-ci-image-build-r4" x="170.8" y="1142.4" textLength="219.6" [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1166.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-47)">│</text><text class="breeze-ci-image-build-r2" x="463.6" y="1166.8" textLength="976" clip-path="url(#breeze-ci-image-build-line-47)">itself).&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160; [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1191.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-48)">│</text><text class="breeze-ci-image-build-r7" x="463.6" y="1191.2" textLength="976" clip-path="url(#breeze-ci-image-build-line-48)">(TEXT)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&# [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1215.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-49)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="1215.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-49)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="1215.6" textLength="134.2" clip-path="url(#breeze-ci-image-build-line-49)">-additional</text><text class="breeze-ci-image-build-r4" x="170.8" y="1215.6" textLength="158.6" [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1240" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-50)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="1240" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-50)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="1240" textLength="134.2" clip-path="url(#breeze-ci-image-build-line-50)">-additional</text><text class="breeze-ci-image-build-r4" x="170.8" y="1240" textLength="146.4" clip-pa [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1264.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-51)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="1264.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-51)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="1264.4" textLength="134.2" clip-path="url(#breeze-ci-image-build-line-51)">-additional</text><text class="breeze-ci-image-build-r4" x="170.8" y="1264.4" textLength="195.2" [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1288.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-52)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="1288.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-52)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="1288.8" textLength="48.8" clip-path="url(#breeze-ci-image-build-line-52)">-dev</text><text class="breeze-ci-image-build-r4" x="85.4" y="1288.8" textLength="109.8" clip-pat [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1313.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-53)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="1313.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-53)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="1313.2" textLength="48.8" clip-path="url(#breeze-ci-image-build-line-53)">-dev</text><text class="breeze-ci-image-build-r4" x="85.4" y="1313.2" textLength="146.4" clip-pat [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1337.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-54)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="1337.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-54)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="1337.6" textLength="97.6" clip-path="url(#breeze-ci-image-build-line-54)">-version</text><text class="breeze-ci-image-build-r4" x="134.2" y="1337.6" textLength="195.2" cli [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1362" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-55)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="1362" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-55)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="1362" textLength="85.4" clip-path="url(#breeze-ci-image-build-line-55)">-commit</text><text class="breeze-ci-image-build-r4" x="122" y="1362" textLength="48.8" clip-path="url( [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1386.4" textLength="1464" clip-path="url(#breeze-ci-image-build-line-56)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-ci-image-build-r2" x="1464" y="1386.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-56)">
-</text><text class="breeze-ci-image-build-r5" x="0" y="1410.8" textLength="24.4" clip-path="url(#breeze-ci-image-build-line-57)">╭─</text><text class="breeze-ci-image-build-r5" x="24.4" y="1410.8" textLength="268.4" clip-path="url(#breeze-ci-image-build-line-57)">&#160;Backtracking&#160;options&#160;</text><text class="breeze-ci-image-build-r5" x="292.8" y="1410.8" textLength="1146.8" clip-path="url(#breeze-ci-image-build-line-57)">──────────────────────────────────────────────────────── [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1435.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-58)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="1435.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-58)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="1435.2" textLength="73.2" clip-path="url(#breeze-ci-image-build-line-58)">-build</text><text class="breeze-ci-image-build-r4" x="109.8" y="1435.2" textLength="195.2" clip- [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1459.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-59)">│</text><text class="breeze-ci-image-build-r2" x="549" y="1459.6" textLength="890.6" clip-path="url(#breeze-ci-image-build-line-59)">backtracking&#160;problems.&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160 [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1484" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-60)">│</text><text class="breeze-ci-image-build-r7" x="549" y="1484" textLength="890.6" clip-path="url(#breeze-ci-image-build-line-60)">(INTEGER)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#1 [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1508.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-61)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="1508.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-61)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="1508.4" textLength="73.2" clip-path="url(#breeze-ci-image-build-line-61)">-eager</text><text class="breeze-ci-image-build-r4" x="109.8" y="1508.4" textLength="390.4" clip- [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1532.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-62)">│</text><text class="breeze-ci-image-build-r2" x="549" y="1532.8" textLength="890.6" clip-path="url(#breeze-ci-image-build-line-62)">(see&#160;`breeze&#160;ci&#160;find-backtracking-candidates`).&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1557.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-63)">│</text><text class="breeze-ci-image-build-r7" x="549" y="1557.2" textLength="890.6" clip-path="url(#breeze-ci-image-build-line-63)">(TEXT)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&# [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1581.6" textLength="1464" clip-path="url(#breeze-ci-image-build-line-64)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-ci-image-build-r2" x="1464" y="1581.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-64)">
-</text><text class="breeze-ci-image-build-r5" x="0" y="1606" textLength="24.4" clip-path="url(#breeze-ci-image-build-line-65)">╭─</text><text class="breeze-ci-image-build-r5" x="24.4" y="1606" textLength="622.2" clip-path="url(#breeze-ci-image-build-line-65)">&#160;Preparing&#160;cache&#160;and&#160;push&#160;(for&#160;maintainers&#160;and&#160;CI)&#160;</text><text class="breeze-ci-image-build-r5" x="646.6" y="1606" textLength="793" clip-path="url(#breeze-ci-image-build-line-65)">────── [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1630.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-66)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="1630.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-66)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="1630.4" textLength="97.6" clip-path="url(#breeze-ci-image-build-line-66)">-builder</text><text class="breeze-ci-image-build-r2" x="341.6" y="1630.4" textLength="756.4" cli [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1654.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-67)">│</text><text class="breeze-ci-image-build-r5" x="341.6" y="1654.8" textLength="756.4" clip-path="url(#breeze-ci-image-build-line-67)">[default:&#160;autodetect]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#16 [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1679.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-68)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="1679.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-68)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="1679.2" textLength="109.8" clip-path="url(#breeze-ci-image-build-line-68)">-platform</text><text class="breeze-ci-image-build-r2" x="341.6" y="1679.2" textLength="329.4" c [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1703.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-69)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="1703.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-69)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="1703.6" textLength="61" clip-path="url(#breeze-ci-image-build-line-69)">-push</text><text class="breeze-ci-image-build-r2" x="341.6" y="1703.6" textLength="353.8" clip-pat [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1728" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-70)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="1728" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-70)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="1728" textLength="97.6" clip-path="url(#breeze-ci-image-build-line-70)">-prepare</text><text class="breeze-ci-image-build-r4" x="134.2" y="1728" textLength="158.6" clip-path=" [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1752.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-71)">│</text><text class="breeze-ci-image-build-r2" x="341.6" y="1752.4" textLength="1098" clip-path="url(#breeze-ci-image-build-line-71)">image).&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160; [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1776.8" textLength="1464" clip-path="url(#breeze-ci-image-build-line-72)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-ci-image-build-r2" x="1464" y="1776.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-72)">
-</text><text class="breeze-ci-image-build-r5" x="0" y="1801.2" textLength="24.4" clip-path="url(#breeze-ci-image-build-line-73)">╭─</text><text class="breeze-ci-image-build-r5" x="24.4" y="1801.2" textLength="280.6" clip-path="url(#breeze-ci-image-build-line-73)">&#160;Github&#160;authentication&#160;</text><text class="breeze-ci-image-build-r5" x="305" y="1801.2" textLength="1134.6" clip-path="url(#breeze-ci-image-build-line-73)">───────────────────────────────────────────────────────── [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1825.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-74)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="1825.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-74)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="1825.6" textLength="85.4" clip-path="url(#breeze-ci-image-build-line-74)">-github</text><text class="breeze-ci-image-build-r4" x="122" y="1825.6" textLength="134.2" clip-p [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1850" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-75)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="1850" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-75)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="1850" textLength="85.4" clip-path="url(#breeze-ci-image-build-line-75)">-github</text><text class="breeze-ci-image-build-r4" x="122" y="1850" textLength="73.2" clip-path="url( [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1874.4" textLength="1464" clip-path="url(#breeze-ci-image-build-line-76)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-ci-image-build-r2" x="1464" y="1874.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-76)">
-</text><text class="breeze-ci-image-build-r5" x="0" y="1898.8" textLength="24.4" clip-path="url(#breeze-ci-image-build-line-77)">╭─</text><text class="breeze-ci-image-build-r5" x="24.4" y="1898.8" textLength="195.2" clip-path="url(#breeze-ci-image-build-line-77)">&#160;Common&#160;options&#160;</text><text class="breeze-ci-image-build-r5" x="219.6" y="1898.8" textLength="1220" clip-path="url(#breeze-ci-image-build-line-77)">──────────────────────────────────────────────────────────────── [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1923.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-78)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="1923.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-78)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="1923.2" textLength="97.6" clip-path="url(#breeze-ci-image-build-line-78)">-verbose</text><text class="breeze-ci-image-build-r6" x="158.6" y="1923.2" textLength="24.4" clip [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1947.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-79)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="1947.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-79)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="1947.6" textLength="48.8" clip-path="url(#breeze-ci-image-build-line-79)">-dry</text><text class="breeze-ci-image-build-r4" x="85.4" y="1947.6" textLength="48.8" clip-path [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1972" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-80)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="1972" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-80)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="1972" textLength="85.4" clip-path="url(#breeze-ci-image-build-line-80)">-answer</text><text class="breeze-ci-image-build-r6" x="158.6" y="1972" textLength="24.4" clip-path="ur [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="1996.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-81)">│</text><text class="breeze-ci-image-build-r4" x="24.4" y="1996.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-81)">-</text><text class="breeze-ci-image-build-r4" x="36.6" y="1996.4" textLength="61" clip-path="url(#breeze-ci-image-build-line-81)">-help</text><text class="breeze-ci-image-build-r6" x="158.6" y="1996.4" textLength="24.4" clip-path [...]
-</text><text class="breeze-ci-image-build-r5" x="0" y="2020.8" textLength="1464" clip-path="url(#breeze-ci-image-build-line-82)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-ci-image-build-r2" x="1464" y="2020.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-82)">
+</text><text class="breeze-ci-image-build-r4" x="0" y="142" textLength="24.4" clip-path="url(#breeze-ci-image-build-line-5)">╭─</text><text class="breeze-ci-image-build-r4" x="24.4" y="142" textLength="158.6" clip-path="url(#breeze-ci-image-build-line-5)">&#160;Basic&#160;usage&#160;</text><text class="breeze-ci-image-build-r4" x="183" y="142" textLength="1256.6" clip-path="url(#breeze-ci-image-build-line-5)">─────────────────────────────────────────────────────────────────────────────── [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="166.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-6)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="166.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-6)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="166.4" textLength="85.4" clip-path="url(#breeze-ci-image-build-line-6)">-python</text><text class="breeze-ci-image-build-r6" x="427" y="166.4" textLength="24.4" clip-path="url [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="190.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-7)">│</text><text class="breeze-ci-image-build-r7" x="475.8" y="190.8" textLength="732" clip-path="url(#breeze-ci-image-build-line-7)">(&gt;3.8&lt;&#160;|&#160;3.9&#160;|&#160;3.10&#160;|&#160;3.11)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#1 [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="215.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-8)">│</text><text class="breeze-ci-image-build-r4" x="475.8" y="215.2" textLength="732" clip-path="url(#breeze-ci-image-build-line-8)">[default:&#160;3.8]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160 [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="239.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-9)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="239.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-9)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="239.6" textLength="97.6" clip-path="url(#breeze-ci-image-build-line-9)">-upgrade</text><text class="breeze-ci-image-build-r5" x="134.2" y="239.6" textLength="268.4" clip-path= [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="264" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-10)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="264" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-10)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="264" textLength="97.6" clip-path="url(#breeze-ci-image-build-line-10)">-upgrade</text><text class="breeze-ci-image-build-r5" x="134.2" y="264" textLength="134.2" clip-path="url( [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="288.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-11)">│</text><text class="breeze-ci-image-build-r2" x="475.8" y="288.4" textLength="963.8" clip-path="url(#breeze-ci-image-build-line-11)">fails.&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&# [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="312.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-12)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="312.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-12)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="312.8" textLength="73.2" clip-path="url(#breeze-ci-image-build-line-12)">-image</text><text class="breeze-ci-image-build-r5" x="109.8" y="312.8" textLength="48.8" clip-path= [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="337.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-13)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="337.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-13)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="337.2" textLength="48.8" clip-path="url(#breeze-ci-image-build-line-13)">-tag</text><text class="breeze-ci-image-build-r5" x="85.4" y="337.2" textLength="122" clip-path="url [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="361.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-14)">│</text><text class="breeze-ci-image-build-r2" x="475.8" y="361.6" textLength="414.8" clip-path="url(#breeze-ci-image-build-line-14)">when&#160;you&#160;build&#160;or&#160;pull&#160;image&#160;with&#160;</text><text class="breeze-ci-image-build-r5" x="890.6" y="361.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-14)">-</text><text class="breeze-c [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="386" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-15)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="386" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-15)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="386" textLength="85.4" clip-path="url(#breeze-ci-image-build-line-15)">-docker</text><text class="breeze-ci-image-build-r5" x="122" y="386" textLength="73.2" clip-path="url(#bre [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="410.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-16)">│</text><text class="breeze-ci-image-build-r4" x="475.8" y="410.4" textLength="549" clip-path="url(#breeze-ci-image-build-line-16)">[default:&#160;registry]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-ci-image-build-r4" x="145 [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="434.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-17)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="434.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-17)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="434.8" textLength="73.2" clip-path="url(#breeze-ci-image-build-line-17)">-force</text><text class="breeze-ci-image-build-r5" x="109.8" y="434.8" textLength="73.2" clip-path= [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="459.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-18)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="459.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-18)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="459.2" textLength="73.2" clip-path="url(#breeze-ci-image-build-line-18)">-build</text><text class="breeze-ci-image-build-r5" x="109.8" y="459.2" textLength="109.8" clip-path [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="483.6" textLength="1464" clip-path="url(#breeze-ci-image-build-line-19)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-ci-image-build-r2" x="1464" y="483.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-19)">
+</text><text class="breeze-ci-image-build-r4" x="0" y="508" textLength="24.4" clip-path="url(#breeze-ci-image-build-line-20)">╭─</text><text class="breeze-ci-image-build-r4" x="24.4" y="508" textLength="353.8" clip-path="url(#breeze-ci-image-build-line-20)">&#160;Building&#160;images&#160;in&#160;parallel&#160;</text><text class="breeze-ci-image-build-r4" x="378.2" y="508" textLength="1061.4" clip-path="url(#breeze-ci-image-build-line-20)">──────────────────────────────────────────────── [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="532.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-21)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="532.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-21)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="532.4" textLength="48.8" clip-path="url(#breeze-ci-image-build-line-21)">-run</text><text class="breeze-ci-image-build-r5" x="85.4" y="532.4" textLength="146.4" clip-path="u [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="556.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-22)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="556.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-22)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="556.8" textLength="146.4" clip-path="url(#breeze-ci-image-build-line-22)">-parallelism</text><text class="breeze-ci-image-build-r2" x="378.2" y="556.8" textLength="915" clip [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="581.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-23)">│</text><text class="breeze-ci-image-build-r7" x="378.2" y="581.2" textLength="915" clip-path="url(#breeze-ci-image-build-line-23)">(INTEGER&#160;RANGE)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&# [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="605.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-24)">│</text><text class="breeze-ci-image-build-r4" x="378.2" y="605.6" textLength="915" clip-path="url(#breeze-ci-image-build-line-24)">[default:&#160;4;&#160;1&lt;=x&lt;=8]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#1 [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="630" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-25)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="630" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-25)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="630" textLength="85.4" clip-path="url(#breeze-ci-image-build-line-25)">-python</text><text class="breeze-ci-image-build-r5" x="122" y="630" textLength="109.8" clip-path="url(#br [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="654.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-26)">│</text><text class="breeze-ci-image-build-r4" x="378.2" y="654.4" textLength="951.6" clip-path="url(#breeze-ci-image-build-line-26)">[default:&#160;3.8&#160;3.9&#160;3.10&#160;3.11]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&# [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="678.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-27)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="678.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-27)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="678.8" textLength="61" clip-path="url(#breeze-ci-image-build-line-27)">-skip</text><text class="breeze-ci-image-build-r5" x="97.6" y="678.8" textLength="97.6" clip-path="url [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="703.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-28)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="703.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-28)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="703.2" textLength="73.2" clip-path="url(#breeze-ci-image-build-line-28)">-debug</text><text class="breeze-ci-image-build-r5" x="109.8" y="703.2" textLength="122" clip-path=" [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="727.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-29)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="727.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-29)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="727.6" textLength="97.6" clip-path="url(#breeze-ci-image-build-line-29)">-include</text><text class="breeze-ci-image-build-r5" x="134.2" y="727.6" textLength="195.2" clip-pa [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="752" textLength="1464" clip-path="url(#breeze-ci-image-build-line-30)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-ci-image-build-r2" x="1464" y="752" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-30)">
+</text><text class="breeze-ci-image-build-r4" x="0" y="776.4" textLength="24.4" clip-path="url(#breeze-ci-image-build-line-31)">╭─</text><text class="breeze-ci-image-build-r4" x="24.4" y="776.4" textLength="439.2" clip-path="url(#breeze-ci-image-build-line-31)">&#160;Advanced&#160;options&#160;(for&#160;power&#160;users)&#160;</text><text class="breeze-ci-image-build-r4" x="463.6" y="776.4" textLength="976" clip-path="url(#breeze-ci-image-build-line-31)">───────────────────────────────── [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="800.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-32)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="800.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-32)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="800.8" textLength="97.6" clip-path="url(#breeze-ci-image-build-line-32)">-install</text><text class="breeze-ci-image-build-r5" x="134.2" y="800.8" textLength="280.6" clip-pa [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="825.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-33)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="825.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-33)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="825.2" textLength="97.6" clip-path="url(#breeze-ci-image-build-line-33)">-airflow</text><text class="breeze-ci-image-build-r5" x="134.2" y="825.2" textLength="256.2" clip-pa [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="849.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-34)">│</text><text class="breeze-ci-image-build-r2" x="463.6" y="849.6" textLength="976" clip-path="url(#breeze-ci-image-build-line-34)">file.&#160;It&#160;could&#160;be&#160;full&#160;remote&#160;URL&#160;to&#160;the&#160;location&#160;file,&#160;or&#160;local&#160;file&#160;placed&#160;in&#160;</text><text class="breeze-ci-image-build-r4" x="1451.8" y="849.6" textL [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="874" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-35)">│</text><text class="breeze-ci-image-build-r2" x="463.6" y="874" textLength="976" clip-path="url(#breeze-ci-image-build-line-35)">`docker-context-files`&#160;(in&#160;this&#160;case&#160;it&#160;has&#160;to&#160;start&#160;with&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;< [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="898.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-36)">│</text><text class="breeze-ci-image-build-r2" x="463.6" y="898.4" textLength="976" clip-path="url(#breeze-ci-image-build-line-36)">/opt/airflow/docker-context-files).&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160 [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="922.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-37)">│</text><text class="breeze-ci-image-build-r7" x="463.6" y="922.8" textLength="976" clip-path="url(#breeze-ci-image-build-line-37)">(TEXT)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#16 [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="947.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-38)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="947.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-38)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="947.2" textLength="97.6" clip-path="url(#breeze-ci-image-build-line-38)">-airflow</text><text class="breeze-ci-image-build-r5" x="134.2" y="947.2" textLength="207.4" clip-pa [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="971.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-39)">│</text><text class="breeze-ci-image-build-r7" x="463.6" y="971.6" textLength="866.2" clip-path="url(#breeze-ci-image-build-line-39)">(constraints-source-providers&#160;|&#160;constraints&#160;|&#160;constraints-no-providers)</text><text class="breeze-ci-image-build-r4" x="1451.8" y="971.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-39)">│</tex [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="996" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-40)">│</text><text class="breeze-ci-image-build-r4" x="463.6" y="996" textLength="866.2" clip-path="url(#breeze-ci-image-build-line-40)">[default:&#160;constraints-source-providers]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#16 [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1020.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-41)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="1020.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-41)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="1020.4" textLength="97.6" clip-path="url(#breeze-ci-image-build-line-41)">-airflow</text><text class="breeze-ci-image-build-r5" x="134.2" y="1020.4" textLength="268.4" cli [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1044.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-42)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="1044.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-42)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="1044.8" textLength="85.4" clip-path="url(#breeze-ci-image-build-line-42)">-python</text><text class="breeze-ci-image-build-r5" x="122" y="1044.8" textLength="73.2" clip-pa [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1069.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-43)">│</text><text class="breeze-ci-image-build-r2" x="463.6" y="1069.2" textLength="976" clip-path="url(#breeze-ci-image-build-line-43)">something&#160;like:&#160;python:VERSION-slim-bullseye.&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;& [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1093.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-44)">│</text><text class="breeze-ci-image-build-r7" x="463.6" y="1093.6" textLength="976" clip-path="url(#breeze-ci-image-build-line-44)">(TEXT)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&# [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1118" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-45)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="1118" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-45)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="1118" textLength="134.2" clip-path="url(#breeze-ci-image-build-line-45)">-additional</text><text class="breeze-ci-image-build-r5" x="170.8" y="1118" textLength="146.4" clip-pa [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1142.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-46)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="1142.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-46)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="1142.4" textLength="134.2" clip-path="url(#breeze-ci-image-build-line-46)">-additional</text><text class="breeze-ci-image-build-r5" x="170.8" y="1142.4" textLength="85.4"  [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1166.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-47)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="1166.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-47)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="1166.8" textLength="134.2" clip-path="url(#breeze-ci-image-build-line-47)">-additional</text><text class="breeze-ci-image-build-r5" x="170.8" y="1166.8" textLength="219.6" [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1191.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-48)">│</text><text class="breeze-ci-image-build-r2" x="463.6" y="1191.2" textLength="976" clip-path="url(#breeze-ci-image-build-line-48)">itself).&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160; [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1215.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-49)">│</text><text class="breeze-ci-image-build-r7" x="463.6" y="1215.6" textLength="976" clip-path="url(#breeze-ci-image-build-line-49)">(TEXT)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&# [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1240" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-50)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="1240" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-50)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="1240" textLength="134.2" clip-path="url(#breeze-ci-image-build-line-50)">-additional</text><text class="breeze-ci-image-build-r5" x="170.8" y="1240" textLength="158.6" clip-pa [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1264.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-51)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="1264.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-51)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="1264.4" textLength="134.2" clip-path="url(#breeze-ci-image-build-line-51)">-additional</text><text class="breeze-ci-image-build-r5" x="170.8" y="1264.4" textLength="146.4" [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1288.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-52)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="1288.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-52)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="1288.8" textLength="134.2" clip-path="url(#breeze-ci-image-build-line-52)">-additional</text><text class="breeze-ci-image-build-r5" x="170.8" y="1288.8" textLength="195.2" [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1313.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-53)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="1313.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-53)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="1313.2" textLength="48.8" clip-path="url(#breeze-ci-image-build-line-53)">-dev</text><text class="breeze-ci-image-build-r5" x="85.4" y="1313.2" textLength="109.8" clip-pat [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1337.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-54)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="1337.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-54)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="1337.6" textLength="48.8" clip-path="url(#breeze-ci-image-build-line-54)">-dev</text><text class="breeze-ci-image-build-r5" x="85.4" y="1337.6" textLength="146.4" clip-pat [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1362" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-55)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="1362" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-55)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="1362" textLength="97.6" clip-path="url(#breeze-ci-image-build-line-55)">-version</text><text class="breeze-ci-image-build-r5" x="134.2" y="1362" textLength="195.2" clip-path=" [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1386.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-56)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="1386.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-56)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="1386.4" textLength="85.4" clip-path="url(#breeze-ci-image-build-line-56)">-commit</text><text class="breeze-ci-image-build-r5" x="122" y="1386.4" textLength="48.8" clip-pa [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1410.8" textLength="1464" clip-path="url(#breeze-ci-image-build-line-57)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-ci-image-build-r2" x="1464" y="1410.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-57)">
+</text><text class="breeze-ci-image-build-r4" x="0" y="1435.2" textLength="24.4" clip-path="url(#breeze-ci-image-build-line-58)">╭─</text><text class="breeze-ci-image-build-r4" x="24.4" y="1435.2" textLength="268.4" clip-path="url(#breeze-ci-image-build-line-58)">&#160;Backtracking&#160;options&#160;</text><text class="breeze-ci-image-build-r4" x="292.8" y="1435.2" textLength="1146.8" clip-path="url(#breeze-ci-image-build-line-58)">──────────────────────────────────────────────────────── [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1459.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-59)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="1459.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-59)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="1459.6" textLength="73.2" clip-path="url(#breeze-ci-image-build-line-59)">-build</text><text class="breeze-ci-image-build-r5" x="109.8" y="1459.6" textLength="195.2" clip- [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1484" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-60)">│</text><text class="breeze-ci-image-build-r2" x="549" y="1484" textLength="890.6" clip-path="url(#breeze-ci-image-build-line-60)">backtracking&#160;problems.&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#1 [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1508.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-61)">│</text><text class="breeze-ci-image-build-r7" x="549" y="1508.4" textLength="890.6" clip-path="url(#breeze-ci-image-build-line-61)">(INTEGER)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160 [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1532.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-62)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="1532.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-62)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="1532.8" textLength="73.2" clip-path="url(#breeze-ci-image-build-line-62)">-eager</text><text class="breeze-ci-image-build-r5" x="109.8" y="1532.8" textLength="390.4" clip- [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1557.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-63)">│</text><text class="breeze-ci-image-build-r2" x="549" y="1557.2" textLength="890.6" clip-path="url(#breeze-ci-image-build-line-63)">(see&#160;`breeze&#160;ci&#160;find-backtracking-candidates`).&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1581.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-64)">│</text><text class="breeze-ci-image-build-r7" x="549" y="1581.6" textLength="890.6" clip-path="url(#breeze-ci-image-build-line-64)">(TEXT)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&# [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1606" textLength="1464" clip-path="url(#breeze-ci-image-build-line-65)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-ci-image-build-r2" x="1464" y="1606" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-65)">
+</text><text class="breeze-ci-image-build-r4" x="0" y="1630.4" textLength="24.4" clip-path="url(#breeze-ci-image-build-line-66)">╭─</text><text class="breeze-ci-image-build-r4" x="24.4" y="1630.4" textLength="622.2" clip-path="url(#breeze-ci-image-build-line-66)">&#160;Preparing&#160;cache&#160;and&#160;push&#160;(for&#160;maintainers&#160;and&#160;CI)&#160;</text><text class="breeze-ci-image-build-r4" x="646.6" y="1630.4" textLength="793" clip-path="url(#breeze-ci-image-build-line-66)"> [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1654.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-67)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="1654.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-67)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="1654.8" textLength="97.6" clip-path="url(#breeze-ci-image-build-line-67)">-builder</text><text class="breeze-ci-image-build-r2" x="341.6" y="1654.8" textLength="756.4" cli [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1679.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-68)">│</text><text class="breeze-ci-image-build-r4" x="341.6" y="1679.2" textLength="756.4" clip-path="url(#breeze-ci-image-build-line-68)">[default:&#160;autodetect]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#16 [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1703.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-69)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="1703.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-69)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="1703.6" textLength="109.8" clip-path="url(#breeze-ci-image-build-line-69)">-platform</text><text class="breeze-ci-image-build-r2" x="341.6" y="1703.6" textLength="329.4" c [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1728" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-70)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="1728" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-70)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="1728" textLength="61" clip-path="url(#breeze-ci-image-build-line-70)">-push</text><text class="breeze-ci-image-build-r2" x="341.6" y="1728" textLength="353.8" clip-path="url(# [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1752.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-71)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="1752.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-71)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="1752.4" textLength="97.6" clip-path="url(#breeze-ci-image-build-line-71)">-prepare</text><text class="breeze-ci-image-build-r5" x="134.2" y="1752.4" textLength="158.6" cli [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1776.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-72)">│</text><text class="breeze-ci-image-build-r2" x="341.6" y="1776.8" textLength="1098" clip-path="url(#breeze-ci-image-build-line-72)">image).&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160; [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1801.2" textLength="1464" clip-path="url(#breeze-ci-image-build-line-73)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-ci-image-build-r2" x="1464" y="1801.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-73)">
+</text><text class="breeze-ci-image-build-r4" x="0" y="1825.6" textLength="24.4" clip-path="url(#breeze-ci-image-build-line-74)">╭─</text><text class="breeze-ci-image-build-r4" x="24.4" y="1825.6" textLength="280.6" clip-path="url(#breeze-ci-image-build-line-74)">&#160;Github&#160;authentication&#160;</text><text class="breeze-ci-image-build-r4" x="305" y="1825.6" textLength="1134.6" clip-path="url(#breeze-ci-image-build-line-74)">───────────────────────────────────────────────────────── [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1850" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-75)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="1850" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-75)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="1850" textLength="85.4" clip-path="url(#breeze-ci-image-build-line-75)">-github</text><text class="breeze-ci-image-build-r5" x="122" y="1850" textLength="134.2" clip-path="url [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1874.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-76)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="1874.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-76)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="1874.4" textLength="85.4" clip-path="url(#breeze-ci-image-build-line-76)">-github</text><text class="breeze-ci-image-build-r5" x="122" y="1874.4" textLength="73.2" clip-pa [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1898.8" textLength="1464" clip-path="url(#breeze-ci-image-build-line-77)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-ci-image-build-r2" x="1464" y="1898.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-77)">
+</text><text class="breeze-ci-image-build-r4" x="0" y="1923.2" textLength="24.4" clip-path="url(#breeze-ci-image-build-line-78)">╭─</text><text class="breeze-ci-image-build-r4" x="24.4" y="1923.2" textLength="195.2" clip-path="url(#breeze-ci-image-build-line-78)">&#160;Common&#160;options&#160;</text><text class="breeze-ci-image-build-r4" x="219.6" y="1923.2" textLength="1220" clip-path="url(#breeze-ci-image-build-line-78)">──────────────────────────────────────────────────────────────── [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1947.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-79)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="1947.6" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-79)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="1947.6" textLength="97.6" clip-path="url(#breeze-ci-image-build-line-79)">-verbose</text><text class="breeze-ci-image-build-r6" x="158.6" y="1947.6" textLength="24.4" clip [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1972" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-80)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="1972" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-80)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="1972" textLength="48.8" clip-path="url(#breeze-ci-image-build-line-80)">-dry</text><text class="breeze-ci-image-build-r5" x="85.4" y="1972" textLength="48.8" clip-path="url(#b [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="1996.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-81)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="1996.4" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-81)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="1996.4" textLength="85.4" clip-path="url(#breeze-ci-image-build-line-81)">-answer</text><text class="breeze-ci-image-build-r6" x="158.6" y="1996.4" textLength="24.4" clip- [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="2020.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-82)">│</text><text class="breeze-ci-image-build-r5" x="24.4" y="2020.8" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-82)">-</text><text class="breeze-ci-image-build-r5" x="36.6" y="2020.8" textLength="61" clip-path="url(#breeze-ci-image-build-line-82)">-help</text><text class="breeze-ci-image-build-r6" x="158.6" y="2020.8" textLength="24.4" clip-path [...]
+</text><text class="breeze-ci-image-build-r4" x="0" y="2045.2" textLength="1464" clip-path="url(#breeze-ci-image-build-line-83)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-ci-image-build-r2" x="1464" y="2045.2" textLength="12.2" clip-path="url(#breeze-ci-image-build-line-83)">
 </text>
     </g>
     </g>
diff --git a/images/breeze/output_prod-image.svg b/images/breeze/output_prod-image.svg
index 35bf4ae86b..cd179a225e 100644
--- a/images/breeze/output_prod-image.svg
+++ b/images/breeze/output_prod-image.svg
@@ -35,8 +35,8 @@
     .breeze-prod-image-r1 { fill: #c5c8c6;font-weight: bold }
 .breeze-prod-image-r2 { fill: #c5c8c6 }
 .breeze-prod-image-r3 { fill: #d0b344;font-weight: bold }
-.breeze-prod-image-r4 { fill: #68a0b3;font-weight: bold }
-.breeze-prod-image-r5 { fill: #868887 }
+.breeze-prod-image-r4 { fill: #868887 }
+.breeze-prod-image-r5 { fill: #68a0b3;font-weight: bold }
 .breeze-prod-image-r6 { fill: #98a84b;font-weight: bold }
     </style>
 
@@ -93,18 +93,18 @@
     
     <g class="breeze-prod-image-matrix">
     <text class="breeze-prod-image-r2" x="1464" y="20" textLength="12.2" clip-path="url(#breeze-prod-image-line-0)">
-</text><text class="breeze-prod-image-r3" x="12.2" y="44.4" textLength="85.4" clip-path="url(#breeze-prod-image-line-1)">Usage:&#160;</text><text class="breeze-prod-image-r1" x="97.6" y="44.4" textLength="231.8" clip-path="url(#breeze-prod-image-line-1)">breeze&#160;prod-image&#160;[</text><text class="breeze-prod-image-r4" x="329.4" y="44.4" textLength="85.4" clip-path="url(#breeze-prod-image-line-1)">OPTIONS</text><text class="breeze-prod-image-r1" x="414.8" y="44.4" textLength="24.4"  [...]
+</text><text class="breeze-prod-image-r3" x="12.2" y="44.4" textLength="85.4" clip-path="url(#breeze-prod-image-line-1)">Usage:&#160;</text><text class="breeze-prod-image-r1" x="97.6" y="44.4" textLength="549" clip-path="url(#breeze-prod-image-line-1)">breeze&#160;prod-image&#160;[OPTIONS]&#160;COMMAND&#160;[ARGS]...</text><text class="breeze-prod-image-r2" x="1464" y="44.4" textLength="12.2" clip-path="url(#breeze-prod-image-line-1)">
 </text><text class="breeze-prod-image-r2" x="1464" y="68.8" textLength="12.2" clip-path="url(#breeze-prod-image-line-2)">
-</text><text class="breeze-prod-image-r2" x="12.2" y="93.2" textLength="597.8" clip-path="url(#breeze-prod-image-line-3)">Tools&#160;that&#160;developers&#160;can&#160;use&#160;to&#160;manually&#160;manage&#160;</text><text class="breeze-prod-image-r4" x="610" y="93.2" textLength="48.8" clip-path="url(#breeze-prod-image-line-3)">PROD</text><text class="breeze-prod-image-r2" x="658.8" y="93.2" textLength="85.4" clip-path="url(#breeze-prod-image-line-3)">&#160;images</text><text class="bre [...]
+</text><text class="breeze-prod-image-r2" x="12.2" y="93.2" textLength="732" clip-path="url(#breeze-prod-image-line-3)">Tools&#160;that&#160;developers&#160;can&#160;use&#160;to&#160;manually&#160;manage&#160;PROD&#160;images</text><text class="breeze-prod-image-r2" x="1464" y="93.2" textLength="12.2" clip-path="url(#breeze-prod-image-line-3)">
 </text><text class="breeze-prod-image-r2" x="1464" y="117.6" textLength="12.2" clip-path="url(#breeze-prod-image-line-4)">
-</text><text class="breeze-prod-image-r5" x="0" y="142" textLength="24.4" clip-path="url(#breeze-prod-image-line-5)">╭─</text><text class="breeze-prod-image-r5" x="24.4" y="142" textLength="195.2" clip-path="url(#breeze-prod-image-line-5)">&#160;Common&#160;options&#160;</text><text class="breeze-prod-image-r5" x="219.6" y="142" textLength="1220" clip-path="url(#breeze-prod-image-line-5)">──────────────────────────────────────────────────────────────────────────────────────────────────── [...]
-</text><text class="breeze-prod-image-r5" x="0" y="166.4" textLength="12.2" clip-path="url(#breeze-prod-image-line-6)">│</text><text class="breeze-prod-image-r4" x="24.4" y="166.4" textLength="12.2" clip-path="url(#breeze-prod-image-line-6)">-</text><text class="breeze-prod-image-r4" x="36.6" y="166.4" textLength="61" clip-path="url(#breeze-prod-image-line-6)">-help</text><text class="breeze-prod-image-r6" x="122" y="166.4" textLength="24.4" clip-path="url(#breeze-prod-image-line-6)">-h< [...]
-</text><text class="breeze-prod-image-r5" x="0" y="190.8" textLength="1464" clip-path="url(#breeze-prod-image-line-7)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-prod-image-r2" x="1464" y="190.8" textLength="12.2" clip-path="url(#breeze-prod-image-line-7)">
-</text><text class="breeze-prod-image-r5" x="0" y="215.2" textLength="24.4" clip-path="url(#breeze-prod-image-line-8)">╭─</text><text class="breeze-prod-image-r5" x="24.4" y="215.2" textLength="292.8" clip-path="url(#breeze-prod-image-line-8)">&#160;Production&#160;Image&#160;tools&#160;</text><text class="breeze-prod-image-r5" x="317.2" y="215.2" textLength="1122.4" clip-path="url(#breeze-prod-image-line-8)">─────────────────────────────────────────────────────────────────────────────── [...]
-</text><text class="breeze-prod-image-r5" x="0" y="239.6" textLength="12.2" clip-path="url(#breeze-prod-image-line-9)">│</text><text class="breeze-prod-image-r4" x="24.4" y="239.6" textLength="85.4" clip-path="url(#breeze-prod-image-line-9)">build&#160;&#160;</text><text class="breeze-prod-image-r2" x="134.2" y="239.6" textLength="1305.4" clip-path="url(#breeze-prod-image-line-9)">Build&#160;Production&#160;image.&#160;Include&#160;building&#160;multiple&#160;images&#160;for&#160;all&#16 [...]
-</text><text class="breeze-prod-image-r5" x="0" y="264" textLength="12.2" clip-path="url(#breeze-prod-image-line-10)">│</text><text class="breeze-prod-image-r4" x="24.4" y="264" textLength="85.4" clip-path="url(#breeze-prod-image-line-10)">pull&#160;&#160;&#160;</text><text class="breeze-prod-image-r2" x="134.2" y="264" textLength="1305.4" clip-path="url(#breeze-prod-image-line-10)">Pull&#160;and&#160;optionally&#160;verify&#160;Production&#160;images&#160;-&#160;possibly&#160;in&#160;pa [...]
-</text><text class="breeze-prod-image-r5" x="0" y="288.4" textLength="12.2" clip-path="url(#breeze-prod-image-line-11)">│</text><text class="breeze-prod-image-r4" x="24.4" y="288.4" textLength="85.4" clip-path="url(#breeze-prod-image-line-11)">verify&#160;</text><text class="breeze-prod-image-r2" x="134.2" y="288.4" textLength="1305.4" clip-path="url(#breeze-prod-image-line-11)">Verify&#160;Production&#160;image.&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#16 [...]
-</text><text class="breeze-prod-image-r5" x="0" y="312.8" textLength="1464" clip-path="url(#breeze-prod-image-line-12)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-prod-image-r2" x="1464" y="312.8" textLength="12.2" clip-path="url(#breeze-prod-image-line-12)">
+</text><text class="breeze-prod-image-r4" x="0" y="142" textLength="24.4" clip-path="url(#breeze-prod-image-line-5)">╭─</text><text class="breeze-prod-image-r4" x="24.4" y="142" textLength="195.2" clip-path="url(#breeze-prod-image-line-5)">&#160;Common&#160;options&#160;</text><text class="breeze-prod-image-r4" x="219.6" y="142" textLength="1220" clip-path="url(#breeze-prod-image-line-5)">──────────────────────────────────────────────────────────────────────────────────────────────────── [...]
+</text><text class="breeze-prod-image-r4" x="0" y="166.4" textLength="12.2" clip-path="url(#breeze-prod-image-line-6)">│</text><text class="breeze-prod-image-r5" x="24.4" y="166.4" textLength="12.2" clip-path="url(#breeze-prod-image-line-6)">-</text><text class="breeze-prod-image-r5" x="36.6" y="166.4" textLength="61" clip-path="url(#breeze-prod-image-line-6)">-help</text><text class="breeze-prod-image-r6" x="122" y="166.4" textLength="24.4" clip-path="url(#breeze-prod-image-line-6)">-h< [...]
+</text><text class="breeze-prod-image-r4" x="0" y="190.8" textLength="1464" clip-path="url(#breeze-prod-image-line-7)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-prod-image-r2" x="1464" y="190.8" textLength="12.2" clip-path="url(#breeze-prod-image-line-7)">
+</text><text class="breeze-prod-image-r4" x="0" y="215.2" textLength="24.4" clip-path="url(#breeze-prod-image-line-8)">╭─</text><text class="breeze-prod-image-r4" x="24.4" y="215.2" textLength="292.8" clip-path="url(#breeze-prod-image-line-8)">&#160;Production&#160;Image&#160;tools&#160;</text><text class="breeze-prod-image-r4" x="317.2" y="215.2" textLength="1122.4" clip-path="url(#breeze-prod-image-line-8)">─────────────────────────────────────────────────────────────────────────────── [...]
+</text><text class="breeze-prod-image-r4" x="0" y="239.6" textLength="12.2" clip-path="url(#breeze-prod-image-line-9)">│</text><text class="breeze-prod-image-r5" x="24.4" y="239.6" textLength="85.4" clip-path="url(#breeze-prod-image-line-9)">build&#160;&#160;</text><text class="breeze-prod-image-r2" x="134.2" y="239.6" textLength="1305.4" clip-path="url(#breeze-prod-image-line-9)">Build&#160;Production&#160;image.&#160;Include&#160;building&#160;multiple&#160;images&#160;for&#160;all&#16 [...]
+</text><text class="breeze-prod-image-r4" x="0" y="264" textLength="12.2" clip-path="url(#breeze-prod-image-line-10)">│</text><text class="breeze-prod-image-r5" x="24.4" y="264" textLength="85.4" clip-path="url(#breeze-prod-image-line-10)">pull&#160;&#160;&#160;</text><text class="breeze-prod-image-r2" x="134.2" y="264" textLength="1305.4" clip-path="url(#breeze-prod-image-line-10)">Pull&#160;and&#160;optionally&#160;verify&#160;Production&#160;images&#160;-&#160;possibly&#160;in&#160;pa [...]
+</text><text class="breeze-prod-image-r4" x="0" y="288.4" textLength="12.2" clip-path="url(#breeze-prod-image-line-11)">│</text><text class="breeze-prod-image-r5" x="24.4" y="288.4" textLength="85.4" clip-path="url(#breeze-prod-image-line-11)">verify&#160;</text><text class="breeze-prod-image-r2" x="134.2" y="288.4" textLength="1305.4" clip-path="url(#breeze-prod-image-line-11)">Verify&#160;Production&#160;image.&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#16 [...]
+</text><text class="breeze-prod-image-r4" x="0" y="312.8" textLength="1464" clip-path="url(#breeze-prod-image-line-12)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-prod-image-r2" x="1464" y="312.8" textLength="12.2" clip-path="url(#breeze-prod-image-line-12)">
 </text>
     </g>
     </g>
diff --git a/images/breeze/output_prod-image_build.svg b/images/breeze/output_prod-image_build.svg
index 3b3973b945..1424dc9ee3 100644
--- a/images/breeze/output_prod-image_build.svg
+++ b/images/breeze/output_prod-image_build.svg
@@ -35,8 +35,8 @@
     .breeze-prod-image-build-r1 { fill: #c5c8c6;font-weight: bold }
 .breeze-prod-image-build-r2 { fill: #c5c8c6 }
 .breeze-prod-image-build-r3 { fill: #d0b344;font-weight: bold }
-.breeze-prod-image-build-r4 { fill: #68a0b3;font-weight: bold }
-.breeze-prod-image-build-r5 { fill: #868887 }
+.breeze-prod-image-build-r4 { fill: #868887 }
+.breeze-prod-image-build-r5 { fill: #68a0b3;font-weight: bold }
 .breeze-prod-image-build-r6 { fill: #98a84b;font-weight: bold }
 .breeze-prod-image-build-r7 { fill: #8d7b39 }
     </style>
@@ -340,100 +340,100 @@
     
     <g class="breeze-prod-image-build-matrix">
     <text class="breeze-prod-image-build-r2" x="1464" y="20" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-0)">
-</text><text class="breeze-prod-image-build-r3" x="12.2" y="44.4" textLength="85.4" clip-path="url(#breeze-prod-image-build-line-1)">Usage:&#160;</text><text class="breeze-prod-image-build-r1" x="97.6" y="44.4" textLength="305" clip-path="url(#breeze-prod-image-build-line-1)">breeze&#160;prod-image&#160;build&#160;[</text><text class="breeze-prod-image-build-r4" x="402.6" y="44.4" textLength="85.4" clip-path="url(#breeze-prod-image-build-line-1)">OPTIONS</text><text class="breeze-prod-im [...]
+</text><text class="breeze-prod-image-build-r3" x="12.2" y="44.4" textLength="85.4" clip-path="url(#breeze-prod-image-build-line-1)">Usage:&#160;</text><text class="breeze-prod-image-build-r1" x="97.6" y="44.4" textLength="402.6" clip-path="url(#breeze-prod-image-build-line-1)">breeze&#160;prod-image&#160;build&#160;[OPTIONS]</text><text class="breeze-prod-image-build-r2" x="1464" y="44.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-1)">
 </text><text class="breeze-prod-image-build-r2" x="1464" y="68.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-2)">
 </text><text class="breeze-prod-image-build-r2" x="12.2" y="93.2" textLength="1293.2" clip-path="url(#breeze-prod-image-build-line-3)">Build&#160;Production&#160;image.&#160;Include&#160;building&#160;multiple&#160;images&#160;for&#160;all&#160;or&#160;selected&#160;Python&#160;versions&#160;sequentially.</text><text class="breeze-prod-image-build-r2" x="1464" y="93.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-3)">
 </text><text class="breeze-prod-image-build-r2" x="1464" y="117.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-4)">
-</text><text class="breeze-prod-image-build-r5" x="0" y="142" textLength="24.4" clip-path="url(#breeze-prod-image-build-line-5)">╭─</text><text class="breeze-prod-image-build-r5" x="24.4" y="142" textLength="158.6" clip-path="url(#breeze-prod-image-build-line-5)">&#160;Basic&#160;usage&#160;</text><text class="breeze-prod-image-build-r5" x="183" y="142" textLength="1256.6" clip-path="url(#breeze-prod-image-build-line-5)">─────────────────────────────────────────────────────────────────── [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="166.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-6)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="166.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-6)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="166.4" textLength="85.4" clip-path="url(#breeze-prod-image-build-line-6)">-python</text><text class="breeze-prod-image-build-r6" x="427" y="166.4" textLength="24.4"  [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="190.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-7)">│</text><text class="breeze-prod-image-build-r7" x="475.8" y="190.8" textLength="732" clip-path="url(#breeze-prod-image-build-line-7)">(&gt;3.8&lt;&#160;|&#160;3.9&#160;|&#160;3.10&#160;|&#160;3.11)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;& [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="215.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-8)">│</text><text class="breeze-prod-image-build-r5" x="475.8" y="215.2" textLength="732" clip-path="url(#breeze-prod-image-build-line-8)">[default:&#160;3.8]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#1 [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="239.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-9)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="239.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-9)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="239.6" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-9)">-install</text><text class="breeze-prod-image-build-r4" x="134.2" y="239.6" textLength="195 [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="264" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-10)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="264" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-10)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="264" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-10)">-upgrade</text><text class="breeze-prod-image-build-r4" x="134.2" y="264" textLength="268.4" c [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="288.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-11)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="288.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-11)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="288.4" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-11)">-upgrade</text><text class="breeze-prod-image-build-r4" x="134.2" y="288.4" textLength=" [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="312.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-12)">│</text><text class="breeze-prod-image-build-r2" x="475.8" y="312.8" textLength="963.8" clip-path="url(#breeze-prod-image-build-line-12)">fails.&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160; [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="337.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-13)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="337.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-13)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="337.2" textLength="73.2" clip-path="url(#breeze-prod-image-build-line-13)">-image</text><text class="breeze-prod-image-build-r4" x="109.8" y="337.2" textLength="48 [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="361.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-14)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="361.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-14)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="361.6" textLength="48.8" clip-path="url(#breeze-prod-image-build-line-14)">-tag</text><text class="breeze-prod-image-build-r4" x="85.4" y="361.6" textLength="122"  [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="386" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-15)">│</text><text class="breeze-prod-image-build-r2" x="475.8" y="386" textLength="414.8" clip-path="url(#breeze-prod-image-build-line-15)">when&#160;you&#160;build&#160;or&#160;pull&#160;image&#160;with&#160;</text><text class="breeze-prod-image-build-r4" x="890.6" y="386" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-15)">-</text><text class="br [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="410.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-16)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="410.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-16)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="410.4" textLength="85.4" clip-path="url(#breeze-prod-image-build-line-16)">-docker</text><text class="breeze-prod-image-build-r4" x="122" y="410.4" textLength="73. [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="434.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-17)">│</text><text class="breeze-prod-image-build-r5" x="475.8" y="434.8" textLength="549" clip-path="url(#breeze-prod-image-build-line-17)">[default:&#160;registry]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-prod-image-build- [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="459.2" textLength="1464" clip-path="url(#breeze-prod-image-build-line-18)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-prod-image-build-r2" x="1464" y="459.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-18)">
-</text><text class="breeze-prod-image-build-r5" x="0" y="483.6" textLength="24.4" clip-path="url(#breeze-prod-image-build-line-19)">╭─</text><text class="breeze-prod-image-build-r5" x="24.4" y="483.6" textLength="353.8" clip-path="url(#breeze-prod-image-build-line-19)">&#160;Building&#160;images&#160;in&#160;parallel&#160;</text><text class="breeze-prod-image-build-r5" x="378.2" y="483.6" textLength="1061.4" clip-path="url(#breeze-prod-image-build-line-19)">────────────────────────────── [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="508" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-20)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="508" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-20)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="508" textLength="48.8" clip-path="url(#breeze-prod-image-build-line-20)">-run</text><text class="breeze-prod-image-build-r4" x="85.4" y="508" textLength="146.4" clip-p [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="532.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-21)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="532.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-21)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="532.4" textLength="146.4" clip-path="url(#breeze-prod-image-build-line-21)">-parallelism</text><text class="breeze-prod-image-build-r2" x="378.2" y="532.4" textLen [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="556.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-22)">│</text><text class="breeze-prod-image-build-r7" x="378.2" y="556.8" textLength="915" clip-path="url(#breeze-prod-image-build-line-22)">(INTEGER&#160;RANGE)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160; [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="581.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-23)">│</text><text class="breeze-prod-image-build-r5" x="378.2" y="581.2" textLength="915" clip-path="url(#breeze-prod-image-build-line-23)">[default:&#160;4;&#160;1&lt;=x&lt;=8]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;& [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="605.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-24)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="605.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-24)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="605.6" textLength="85.4" clip-path="url(#breeze-prod-image-build-line-24)">-python</text><text class="breeze-prod-image-build-r4" x="122" y="605.6" textLength="109 [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="630" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-25)">│</text><text class="breeze-prod-image-build-r5" x="378.2" y="630" textLength="951.6" clip-path="url(#breeze-prod-image-build-line-25)">[default:&#160;3.8&#160;3.9&#160;3.10&#160;3.11]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#16 [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="654.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-26)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="654.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-26)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="654.4" textLength="61" clip-path="url(#breeze-prod-image-build-line-26)">-skip</text><text class="breeze-prod-image-build-r4" x="97.6" y="654.4" textLength="97.6"  [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="678.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-27)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="678.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-27)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="678.8" textLength="73.2" clip-path="url(#breeze-prod-image-build-line-27)">-debug</text><text class="breeze-prod-image-build-r4" x="109.8" y="678.8" textLength="12 [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="703.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-28)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="703.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-28)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="703.2" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-28)">-include</text><text class="breeze-prod-image-build-r4" x="134.2" y="703.2" textLength=" [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="727.6" textLength="1464" clip-path="url(#breeze-prod-image-build-line-29)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-prod-image-build-r2" x="1464" y="727.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-29)">
-</text><text class="breeze-prod-image-build-r5" x="0" y="752" textLength="24.4" clip-path="url(#breeze-prod-image-build-line-30)">╭─</text><text class="breeze-prod-image-build-r5" x="24.4" y="752" textLength="390.4" clip-path="url(#breeze-prod-image-build-line-30)">&#160;Options&#160;for&#160;customizing&#160;images&#160;</text><text class="breeze-prod-image-build-r5" x="414.8" y="752" textLength="1024.8" clip-path="url(#breeze-prod-image-build-line-30)">───────────────────────────────── [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="776.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-31)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="776.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-31)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="776.4" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-31)">-install</text><text class="breeze-prod-image-build-r4" x="134.2" y="776.4" textLength=" [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="800.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-32)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="800.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-32)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="800.8" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-32)">-airflow</text><text class="breeze-prod-image-build-r4" x="134.2" y="800.8" textLength=" [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="825.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-33)">│</text><text class="breeze-prod-image-build-r7" x="463.6" y="825.2" textLength="976" clip-path="url(#breeze-prod-image-build-line-33)">(TEXT)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&# [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="849.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-34)">│</text><text class="breeze-prod-image-build-r5" x="463.6" y="849.6" textLength="976" clip-path="url(#breeze-prod-image-build-line-34)">[default:&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160 [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="874" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-35)">│</text><text class="breeze-prod-image-build-r5" x="463.6" y="874" textLength="976" clip-path="url(#breeze-prod-image-build-line-35)">aiobotocore,amazon,async,celery,cncf.kubernetes,daskexecutor,docker,elasticsear…</text><text class="breeze-prod-image-build-r5" x="1451.8" y="874" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-35)">│</text><text [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="898.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-36)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="898.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-36)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="898.4" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-36)">-airflow</text><text class="breeze-prod-image-build-r4" x="134.2" y="898.4" textLength=" [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="922.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-37)">│</text><text class="breeze-prod-image-build-r2" x="463.6" y="922.8" textLength="366" clip-path="url(#breeze-prod-image-build-line-37)">file.&#160;It&#160;could&#160;be&#160;full&#160;remote&#160;</text><text class="breeze-prod-image-build-r4" x="829.6" y="922.8" textLength="36.6" clip-path="url(#breeze-prod-image-build-line-37)">URL</text><text class="breez [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="947.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-38)">│</text><text class="breeze-prod-image-build-r2" x="463.6" y="947.2" textLength="976" clip-path="url(#breeze-prod-image-build-line-38)">`docker-context-files`&#160;(in&#160;this&#160;case&#160;it&#160;has&#160;to&#160;start&#160;with&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;& [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="971.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-39)">│</text><text class="breeze-prod-image-build-r2" x="463.6" y="971.6" textLength="976" clip-path="url(#breeze-prod-image-build-line-39)">/opt/airflow/docker-context-files).&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#1 [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="996" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-40)">│</text><text class="breeze-prod-image-build-r7" x="463.6" y="996" textLength="976" clip-path="url(#breeze-prod-image-build-line-40)">(TEXT)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160; [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1020.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-41)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1020.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-41)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1020.4" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-41)">-airflow</text><text class="breeze-prod-image-build-r4" x="134.2" y="1020.4" textLeng [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1044.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-42)">│</text><text class="breeze-prod-image-build-r7" x="463.6" y="1044.8" textLength="866.2" clip-path="url(#breeze-prod-image-build-line-42)">(constraints&#160;|&#160;constraints-no-providers&#160;|&#160;constraints-source-providers)</text><text class="breeze-prod-image-build-r5" x="1451.8" y="1044.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-l [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1069.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-43)">│</text><text class="breeze-prod-image-build-r5" x="463.6" y="1069.2" textLength="866.2" clip-path="url(#breeze-prod-image-build-line-43)">[default:&#160;constraints]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;& [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1093.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-44)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1093.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-44)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1093.6" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-44)">-airflow</text><text class="breeze-prod-image-build-r4" x="134.2" y="1093.6" textLeng [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1118" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-45)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1118" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-45)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1118" textLength="85.4" clip-path="url(#breeze-prod-image-build-line-45)">-python</text><text class="breeze-prod-image-build-r4" x="122" y="1118" textLength="73.2" c [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1142.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-46)">│</text><text class="breeze-prod-image-build-r2" x="463.6" y="1142.4" textLength="280.6" clip-path="url(#breeze-prod-image-build-line-46)">something&#160;like:&#160;python:</text><text class="breeze-prod-image-build-r4" x="744.2" y="1142.4" textLength="85.4" clip-path="url(#breeze-prod-image-build-line-46)">VERSION</text><text class="breeze-prod-image-build [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1166.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-47)">│</text><text class="breeze-prod-image-build-r7" x="463.6" y="1166.8" textLength="976" clip-path="url(#breeze-prod-image-build-line-47)">(TEXT)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160; [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1191.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-48)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1191.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-48)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1191.2" textLength="134.2" clip-path="url(#breeze-prod-image-build-line-48)">-additional</text><text class="breeze-prod-image-build-r4" x="170.8" y="1191.2" text [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1215.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-49)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1215.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-49)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1215.6" textLength="134.2" clip-path="url(#breeze-prod-image-build-line-49)">-additional</text><text class="breeze-prod-image-build-r4" x="170.8" y="1215.6" text [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1240" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-50)">│</text><text class="breeze-prod-image-build-r2" x="463.6" y="1240" textLength="976" clip-path="url(#breeze-prod-image-build-line-50)">itself).&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&# [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1264.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-51)">│</text><text class="breeze-prod-image-build-r7" x="463.6" y="1264.4" textLength="976" clip-path="url(#breeze-prod-image-build-line-51)">(TEXT)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160; [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1288.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-52)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1288.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-52)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1288.8" textLength="134.2" clip-path="url(#breeze-prod-image-build-line-52)">-additional</text><text class="breeze-prod-image-build-r4" x="170.8" y="1288.8" text [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1313.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-53)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1313.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-53)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1313.2" textLength="134.2" clip-path="url(#breeze-prod-image-build-line-53)">-additional</text><text class="breeze-prod-image-build-r4" x="170.8" y="1313.2" text [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1337.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-54)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1337.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-54)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1337.6" textLength="134.2" clip-path="url(#breeze-prod-image-build-line-54)">-additional</text><text class="breeze-prod-image-build-r4" x="170.8" y="1337.6" text [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1362" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-55)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1362" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-55)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1362" textLength="134.2" clip-path="url(#breeze-prod-image-build-line-55)">-additional</text><text class="breeze-prod-image-build-r4" x="170.8" y="1362" textLength=" [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1386.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-56)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1386.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-56)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1386.4" textLength="134.2" clip-path="url(#breeze-prod-image-build-line-56)">-additional</text><text class="breeze-prod-image-build-r4" x="170.8" y="1386.4" text [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1410.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-57)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1410.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-57)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1410.8" textLength="134.2" clip-path="url(#breeze-prod-image-build-line-57)">-additional</text><text class="breeze-prod-image-build-r4" x="170.8" y="1410.8" text [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1435.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-58)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1435.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-58)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1435.2" textLength="134.2" clip-path="url(#breeze-prod-image-build-line-58)">-additional</text><text class="breeze-prod-image-build-r4" x="170.8" y="1435.2" text [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1459.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-59)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1459.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-59)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1459.6" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-59)">-runtime</text><text class="breeze-prod-image-build-r4" x="134.2" y="1459.6" textLeng [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1484" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-60)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1484" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-60)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1484" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-60)">-runtime</text><text class="breeze-prod-image-build-r4" x="134.2" y="1484" textLength="146. [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1508.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-61)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1508.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-61)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1508.4" textLength="48.8" clip-path="url(#breeze-prod-image-build-line-61)">-dev</text><text class="breeze-prod-image-build-r4" x="85.4" y="1508.4" textLength="1 [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1532.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-62)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1532.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-62)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1532.8" textLength="48.8" clip-path="url(#breeze-prod-image-build-line-62)">-dev</text><text class="breeze-prod-image-build-r4" x="85.4" y="1532.8" textLength="1 [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1557.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-63)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1557.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-63)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1557.2" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-63)">-version</text><text class="breeze-prod-image-build-r4" x="134.2" y="1557.2" textLeng [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1581.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-64)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1581.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-64)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1581.6" textLength="85.4" clip-path="url(#breeze-prod-image-build-line-64)">-commit</text><text class="breeze-prod-image-build-r4" x="122" y="1581.6" textLength= [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1606" textLength="1464" clip-path="url(#breeze-prod-image-build-line-65)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-prod-image-build-r2" x="1464" y="1606" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-65)">
-</text><text class="breeze-prod-image-build-r5" x="0" y="1630.4" textLength="24.4" clip-path="url(#breeze-prod-image-build-line-66)">╭─</text><text class="breeze-prod-image-build-r5" x="24.4" y="1630.4" textLength="707.6" clip-path="url(#breeze-prod-image-build-line-66)">&#160;Customization&#160;options&#160;(for&#160;specific&#160;customization&#160;needs)&#160;</text><text class="breeze-prod-image-build-r5" x="732" y="1630.4" textLength="707.6" clip-path="url(#breeze-prod-image-build-l [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1654.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-67)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1654.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-67)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1654.8" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-67)">-install</text><text class="breeze-prod-image-build-r4" x="134.2" y="1654.8" textLeng [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1679.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-68)">│</text><text class="breeze-prod-image-build-r2" x="536.8" y="1679.2" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-68)">Implies&#160;</text><text class="breeze-prod-image-build-r4" x="634.4" y="1679.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-68)">-</text><text class="breeze-prod-image-build-r4" x="646.6" y="1679.2" t [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1703.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-69)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1703.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-69)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1703.6" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-69)">-cleanup</text><text class="breeze-prod-image-build-r4" x="134.2" y="1703.6" textLeng [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1728" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-70)">│</text><text class="breeze-prod-image-build-r2" x="536.8" y="1728" textLength="170.8" clip-path="url(#breeze-prod-image-build-line-70)">together&#160;with&#160;</text><text class="breeze-prod-image-build-r4" x="707.6" y="1728" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-70)">-</text><text class="breeze-prod-image-build-r4" x="719.8" y="172 [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1752.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-71)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1752.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-71)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1752.4" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-71)">-disable</text><text class="breeze-prod-image-build-r4" x="134.2" y="1752.4" textLeng [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1776.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-72)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1776.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-72)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1776.8" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-72)">-disable</text><text class="breeze-prod-image-build-r4" x="134.2" y="1776.8" textLeng [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1801.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-73)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1801.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-73)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1801.2" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-73)">-disable</text><text class="breeze-prod-image-build-r4" x="134.2" y="1801.2" textLeng [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1825.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-74)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1825.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-74)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1825.6" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-74)">-disable</text><text class="breeze-prod-image-build-r4" x="134.2" y="1825.6" textLeng [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1850" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-75)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1850" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-75)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1850" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-75)">-install</text><text class="breeze-prod-image-build-r4" x="134.2" y="1850" textLength="219. [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1874.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-76)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1874.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-76)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1874.4" textLength="158.6" clip-path="url(#breeze-prod-image-build-line-76)">-installation</text><text class="breeze-prod-image-build-r4" x="195.2" y="1874.4" te [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1898.8" textLength="1464" clip-path="url(#breeze-prod-image-build-line-77)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-prod-image-build-r2" x="1464" y="1898.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-77)">
-</text><text class="breeze-prod-image-build-r5" x="0" y="1923.2" textLength="24.4" clip-path="url(#breeze-prod-image-build-line-78)">╭─</text><text class="breeze-prod-image-build-r5" x="24.4" y="1923.2" textLength="622.2" clip-path="url(#breeze-prod-image-build-line-78)">&#160;Preparing&#160;cache&#160;and&#160;push&#160;(for&#160;maintainers&#160;and&#160;CI)&#160;</text><text class="breeze-prod-image-build-r5" x="646.6" y="1923.2" textLength="793" clip-path="url(#breeze-prod-image-buil [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1947.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-79)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1947.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-79)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1947.6" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-79)">-builder</text><text class="breeze-prod-image-build-r2" x="341.6" y="1947.6" textLeng [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1972" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-80)">│</text><text class="breeze-prod-image-build-r5" x="341.6" y="1972" textLength="756.4" clip-path="url(#breeze-prod-image-build-line-80)">[default:&#160;autodetect]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160; [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="1996.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-81)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="1996.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-81)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="1996.4" textLength="109.8" clip-path="url(#breeze-prod-image-build-line-81)">-platform</text><text class="breeze-prod-image-build-r2" x="341.6" y="1996.4" textLe [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="2020.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-82)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="2020.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-82)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="2020.8" textLength="61" clip-path="url(#breeze-prod-image-build-line-82)">-push</text><text class="breeze-prod-image-build-r2" x="341.6" y="2020.8" textLength="3 [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="2045.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-83)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="2045.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-83)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="2045.2" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-83)">-prepare</text><text class="breeze-prod-image-build-r4" x="134.2" y="2045.2" textLeng [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="2069.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-84)">│</text><text class="breeze-prod-image-build-r2" x="341.6" y="2069.6" textLength="1098" clip-path="url(#breeze-prod-image-build-line-84)">image).&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#16 [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="2094" textLength="1464" clip-path="url(#breeze-prod-image-build-line-85)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-prod-image-build-r2" x="1464" y="2094" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-85)">
-</text><text class="breeze-prod-image-build-r5" x="0" y="2118.4" textLength="24.4" clip-path="url(#breeze-prod-image-build-line-86)">╭─</text><text class="breeze-prod-image-build-r5" x="24.4" y="2118.4" textLength="280.6" clip-path="url(#breeze-prod-image-build-line-86)">&#160;Github&#160;authentication&#160;</text><text class="breeze-prod-image-build-r5" x="305" y="2118.4" textLength="1134.6" clip-path="url(#breeze-prod-image-build-line-86)">───────────────────────────────────────────── [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="2142.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-87)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="2142.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-87)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="2142.8" textLength="85.4" clip-path="url(#breeze-prod-image-build-line-87)">-github</text><text class="breeze-prod-image-build-r4" x="122" y="2142.8" textLength= [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="2167.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-88)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="2167.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-88)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="2167.2" textLength="85.4" clip-path="url(#breeze-prod-image-build-line-88)">-github</text><text class="breeze-prod-image-build-r4" x="122" y="2167.2" textLength= [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="2191.6" textLength="1464" clip-path="url(#breeze-prod-image-build-line-89)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-prod-image-build-r2" x="1464" y="2191.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-89)">
-</text><text class="breeze-prod-image-build-r5" x="0" y="2216" textLength="24.4" clip-path="url(#breeze-prod-image-build-line-90)">╭─</text><text class="breeze-prod-image-build-r5" x="24.4" y="2216" textLength="195.2" clip-path="url(#breeze-prod-image-build-line-90)">&#160;Common&#160;options&#160;</text><text class="breeze-prod-image-build-r5" x="219.6" y="2216" textLength="1220" clip-path="url(#breeze-prod-image-build-line-90)">────────────────────────────────────────────────────────── [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="2240.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-91)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="2240.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-91)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="2240.4" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-91)">-verbose</text><text class="breeze-prod-image-build-r6" x="158.6" y="2240.4" textLeng [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="2264.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-92)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="2264.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-92)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="2264.8" textLength="48.8" clip-path="url(#breeze-prod-image-build-line-92)">-dry</text><text class="breeze-prod-image-build-r4" x="85.4" y="2264.8" textLength="4 [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="2289.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-93)">│</text><text class="breeze-prod-image-build-r4" x="24.4" y="2289.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-93)">-</text><text class="breeze-prod-image-build-r4" x="36.6" y="2289.2" textLength="61" clip-path="url(#breeze-prod-image-build-line-93)">-help</text><text class="breeze-prod-image-build-r6" x="158.6" y="2289.2" textLength="2 [...]
-</text><text class="breeze-prod-image-build-r5" x="0" y="2313.6" textLength="1464" clip-path="url(#breeze-prod-image-build-line-94)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-prod-image-build-r2" x="1464" y="2313.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-94)">
+</text><text class="breeze-prod-image-build-r4" x="0" y="142" textLength="24.4" clip-path="url(#breeze-prod-image-build-line-5)">╭─</text><text class="breeze-prod-image-build-r4" x="24.4" y="142" textLength="158.6" clip-path="url(#breeze-prod-image-build-line-5)">&#160;Basic&#160;usage&#160;</text><text class="breeze-prod-image-build-r4" x="183" y="142" textLength="1256.6" clip-path="url(#breeze-prod-image-build-line-5)">─────────────────────────────────────────────────────────────────── [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="166.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-6)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="166.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-6)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="166.4" textLength="85.4" clip-path="url(#breeze-prod-image-build-line-6)">-python</text><text class="breeze-prod-image-build-r6" x="353.8" y="166.4" textLength="24.4 [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="190.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-7)">│</text><text class="breeze-prod-image-build-r7" x="402.6" y="190.8" textLength="732" clip-path="url(#breeze-prod-image-build-line-7)">(&gt;3.8&lt;&#160;|&#160;3.9&#160;|&#160;3.10&#160;|&#160;3.11)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;& [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="215.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-8)">│</text><text class="breeze-prod-image-build-r4" x="402.6" y="215.2" textLength="732" clip-path="url(#breeze-prod-image-build-line-8)">[default:&#160;3.8]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#1 [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="239.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-9)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="239.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-9)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="239.6" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-9)">-install</text><text class="breeze-prod-image-build-r5" x="134.2" y="239.6" textLength="195 [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="264" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-10)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="264" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-10)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="264" textLength="73.2" clip-path="url(#breeze-prod-image-build-line-10)">-image</text><text class="breeze-prod-image-build-r5" x="109.8" y="264" textLength="48.8" clip [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="288.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-11)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="288.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-11)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="288.4" textLength="48.8" clip-path="url(#breeze-prod-image-build-line-11)">-tag</text><text class="breeze-prod-image-build-r5" x="85.4" y="288.4" textLength="122"  [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="312.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-12)">│</text><text class="breeze-prod-image-build-r2" x="402.6" y="312.8" textLength="353.8" clip-path="url(#breeze-prod-image-build-line-12)">you&#160;build&#160;or&#160;pull&#160;image&#160;with&#160;</text><text class="breeze-prod-image-build-r5" x="756.4" y="312.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-12)">-</text><text class="breeze [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="337.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-13)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="337.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-13)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="337.2" textLength="85.4" clip-path="url(#breeze-prod-image-build-line-13)">-docker</text><text class="breeze-prod-image-build-r5" x="122" y="337.2" textLength="73. [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="361.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-14)">│</text><text class="breeze-prod-image-build-r4" x="402.6" y="361.6" textLength="549" clip-path="url(#breeze-prod-image-build-line-14)">[default:&#160;registry]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-prod-image-build- [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="386" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-15)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="386" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-15)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="386" textLength="73.2" clip-path="url(#breeze-prod-image-build-line-15)">-build</text><text class="breeze-prod-image-build-r5" x="109.8" y="386" textLength="109.8" cli [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="410.4" textLength="1464" clip-path="url(#breeze-prod-image-build-line-16)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-prod-image-build-r2" x="1464" y="410.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-16)">
+</text><text class="breeze-prod-image-build-r4" x="0" y="434.8" textLength="24.4" clip-path="url(#breeze-prod-image-build-line-17)">╭─</text><text class="breeze-prod-image-build-r4" x="24.4" y="434.8" textLength="353.8" clip-path="url(#breeze-prod-image-build-line-17)">&#160;Building&#160;images&#160;in&#160;parallel&#160;</text><text class="breeze-prod-image-build-r4" x="378.2" y="434.8" textLength="1061.4" clip-path="url(#breeze-prod-image-build-line-17)">────────────────────────────── [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="459.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-18)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="459.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-18)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="459.2" textLength="48.8" clip-path="url(#breeze-prod-image-build-line-18)">-run</text><text class="breeze-prod-image-build-r5" x="85.4" y="459.2" textLength="146.4 [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="483.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-19)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="483.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-19)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="483.6" textLength="146.4" clip-path="url(#breeze-prod-image-build-line-19)">-parallelism</text><text class="breeze-prod-image-build-r2" x="378.2" y="483.6" textLen [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="508" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-20)">│</text><text class="breeze-prod-image-build-r7" x="378.2" y="508" textLength="915" clip-path="url(#breeze-prod-image-build-line-20)">(INTEGER&#160;RANGE)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#16 [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="532.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-21)">│</text><text class="breeze-prod-image-build-r4" x="378.2" y="532.4" textLength="915" clip-path="url(#breeze-prod-image-build-line-21)">[default:&#160;4;&#160;1&lt;=x&lt;=8]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;& [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="556.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-22)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="556.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-22)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="556.8" textLength="85.4" clip-path="url(#breeze-prod-image-build-line-22)">-python</text><text class="breeze-prod-image-build-r5" x="122" y="556.8" textLength="109 [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="581.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-23)">│</text><text class="breeze-prod-image-build-r4" x="378.2" y="581.2" textLength="951.6" clip-path="url(#breeze-prod-image-build-line-23)">[default:&#160;3.8&#160;3.9&#160;3.10&#160;3.11]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160; [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="605.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-24)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="605.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-24)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="605.6" textLength="61" clip-path="url(#breeze-prod-image-build-line-24)">-skip</text><text class="breeze-prod-image-build-r5" x="97.6" y="605.6" textLength="97.6"  [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="630" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-25)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="630" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-25)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="630" textLength="73.2" clip-path="url(#breeze-prod-image-build-line-25)">-debug</text><text class="breeze-prod-image-build-r5" x="109.8" y="630" textLength="122" clip- [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="654.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-26)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="654.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-26)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="654.4" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-26)">-include</text><text class="breeze-prod-image-build-r5" x="134.2" y="654.4" textLength=" [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="678.8" textLength="1464" clip-path="url(#breeze-prod-image-build-line-27)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-prod-image-build-r2" x="1464" y="678.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-27)">
+</text><text class="breeze-prod-image-build-r4" x="0" y="703.2" textLength="24.4" clip-path="url(#breeze-prod-image-build-line-28)">╭─</text><text class="breeze-prod-image-build-r4" x="24.4" y="703.2" textLength="390.4" clip-path="url(#breeze-prod-image-build-line-28)">&#160;Options&#160;for&#160;customizing&#160;images&#160;</text><text class="breeze-prod-image-build-r4" x="414.8" y="703.2" textLength="1024.8" clip-path="url(#breeze-prod-image-build-line-28)">─────────────────────────── [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="727.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-29)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="727.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-29)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="727.6" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-29)">-install</text><text class="breeze-prod-image-build-r5" x="134.2" y="727.6" textLength=" [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="752" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-30)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="752" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-30)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="752" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-30)">-airflow</text><text class="breeze-prod-image-build-r5" x="134.2" y="752" textLength="85.4" cl [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="776.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-31)">│</text><text class="breeze-prod-image-build-r7" x="463.6" y="776.4" textLength="976" clip-path="url(#breeze-prod-image-build-line-31)">(TEXT)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&# [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="800.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-32)">│</text><text class="breeze-prod-image-build-r4" x="463.6" y="800.8" textLength="976" clip-path="url(#breeze-prod-image-build-line-32)">[default:&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160 [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="825.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-33)">│</text><text class="breeze-prod-image-build-r4" x="463.6" y="825.2" textLength="976" clip-path="url(#breeze-prod-image-build-line-33)">aiobotocore,amazon,async,celery,cncf.kubernetes,daskexecutor,docker,elasticsear…</text><text class="breeze-prod-image-build-r4" x="1451.8" y="825.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-33)">│</text [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="849.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-34)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="849.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-34)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="849.6" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-34)">-airflow</text><text class="breeze-prod-image-build-r5" x="134.2" y="849.6" textLength=" [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="874" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-35)">│</text><text class="breeze-prod-image-build-r2" x="463.6" y="874" textLength="976" clip-path="url(#breeze-prod-image-build-line-35)">file.&#160;It&#160;could&#160;be&#160;full&#160;remote&#160;URL&#160;to&#160;the&#160;location&#160;file,&#160;or&#160;local&#160;file&#160;placed&#160;in&#160;</text><text class="breeze-prod-image-build-r4" x="1451.8" y="874" t [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="898.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-36)">│</text><text class="breeze-prod-image-build-r2" x="463.6" y="898.4" textLength="976" clip-path="url(#breeze-prod-image-build-line-36)">`docker-context-files`&#160;(in&#160;this&#160;case&#160;it&#160;has&#160;to&#160;start&#160;with&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;& [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="922.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-37)">│</text><text class="breeze-prod-image-build-r2" x="463.6" y="922.8" textLength="976" clip-path="url(#breeze-prod-image-build-line-37)">/opt/airflow/docker-context-files).&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#1 [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="947.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-38)">│</text><text class="breeze-prod-image-build-r7" x="463.6" y="947.2" textLength="976" clip-path="url(#breeze-prod-image-build-line-38)">(TEXT)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&# [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="971.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-39)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="971.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-39)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="971.6" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-39)">-airflow</text><text class="breeze-prod-image-build-r5" x="134.2" y="971.6" textLength=" [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="996" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-40)">│</text><text class="breeze-prod-image-build-r7" x="463.6" y="996" textLength="866.2" clip-path="url(#breeze-prod-image-build-line-40)">(constraints&#160;|&#160;constraints-no-providers&#160;|&#160;constraints-source-providers)</text><text class="breeze-prod-image-build-r4" x="1451.8" y="996" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-40)"> [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1020.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-41)">│</text><text class="breeze-prod-image-build-r4" x="463.6" y="1020.4" textLength="866.2" clip-path="url(#breeze-prod-image-build-line-41)">[default:&#160;constraints]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;& [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1044.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-42)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1044.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-42)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1044.8" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-42)">-airflow</text><text class="breeze-prod-image-build-r5" x="134.2" y="1044.8" textLeng [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1069.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-43)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1069.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-43)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1069.2" textLength="85.4" clip-path="url(#breeze-prod-image-build-line-43)">-python</text><text class="breeze-prod-image-build-r5" x="122" y="1069.2" textLength= [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1093.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-44)">│</text><text class="breeze-prod-image-build-r2" x="463.6" y="1093.6" textLength="976" clip-path="url(#breeze-prod-image-build-line-44)">something&#160;like:&#160;python:VERSION-slim-bullseye.&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160 [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1118" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-45)">│</text><text class="breeze-prod-image-build-r7" x="463.6" y="1118" textLength="976" clip-path="url(#breeze-prod-image-build-line-45)">(TEXT)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#16 [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1142.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-46)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1142.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-46)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1142.4" textLength="134.2" clip-path="url(#breeze-prod-image-build-line-46)">-additional</text><text class="breeze-prod-image-build-r5" x="170.8" y="1142.4" text [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1166.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-47)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1166.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-47)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1166.8" textLength="134.2" clip-path="url(#breeze-prod-image-build-line-47)">-additional</text><text class="breeze-prod-image-build-r5" x="170.8" y="1166.8" text [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1191.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-48)">│</text><text class="breeze-prod-image-build-r2" x="463.6" y="1191.2" textLength="976" clip-path="url(#breeze-prod-image-build-line-48)">itself).&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#16 [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1215.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-49)">│</text><text class="breeze-prod-image-build-r7" x="463.6" y="1215.6" textLength="976" clip-path="url(#breeze-prod-image-build-line-49)">(TEXT)&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160; [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1240" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-50)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1240" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-50)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1240" textLength="134.2" clip-path="url(#breeze-prod-image-build-line-50)">-additional</text><text class="breeze-prod-image-build-r5" x="170.8" y="1240" textLength=" [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1264.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-51)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1264.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-51)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1264.4" textLength="134.2" clip-path="url(#breeze-prod-image-build-line-51)">-additional</text><text class="breeze-prod-image-build-r5" x="170.8" y="1264.4" text [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1288.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-52)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1288.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-52)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1288.8" textLength="134.2" clip-path="url(#breeze-prod-image-build-line-52)">-additional</text><text class="breeze-prod-image-build-r5" x="170.8" y="1288.8" text [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1313.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-53)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1313.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-53)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1313.2" textLength="134.2" clip-path="url(#breeze-prod-image-build-line-53)">-additional</text><text class="breeze-prod-image-build-r5" x="170.8" y="1313.2" text [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1337.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-54)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1337.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-54)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1337.6" textLength="134.2" clip-path="url(#breeze-prod-image-build-line-54)">-additional</text><text class="breeze-prod-image-build-r5" x="170.8" y="1337.6" text [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1362" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-55)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1362" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-55)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1362" textLength="134.2" clip-path="url(#breeze-prod-image-build-line-55)">-additional</text><text class="breeze-prod-image-build-r5" x="170.8" y="1362" textLength=" [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1386.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-56)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1386.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-56)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1386.4" textLength="134.2" clip-path="url(#breeze-prod-image-build-line-56)">-additional</text><text class="breeze-prod-image-build-r5" x="170.8" y="1386.4" text [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1410.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-57)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1410.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-57)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1410.8" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-57)">-runtime</text><text class="breeze-prod-image-build-r5" x="134.2" y="1410.8" textLeng [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1435.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-58)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1435.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-58)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1435.2" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-58)">-runtime</text><text class="breeze-prod-image-build-r5" x="134.2" y="1435.2" textLeng [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1459.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-59)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1459.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-59)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1459.6" textLength="48.8" clip-path="url(#breeze-prod-image-build-line-59)">-dev</text><text class="breeze-prod-image-build-r5" x="85.4" y="1459.6" textLength="1 [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1484" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-60)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1484" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-60)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1484" textLength="48.8" clip-path="url(#breeze-prod-image-build-line-60)">-dev</text><text class="breeze-prod-image-build-r5" x="85.4" y="1484" textLength="146.4" cl [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1508.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-61)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1508.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-61)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1508.4" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-61)">-version</text><text class="breeze-prod-image-build-r5" x="134.2" y="1508.4" textLeng [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1532.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-62)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1532.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-62)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1532.8" textLength="85.4" clip-path="url(#breeze-prod-image-build-line-62)">-commit</text><text class="breeze-prod-image-build-r5" x="122" y="1532.8" textLength= [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1557.2" textLength="1464" clip-path="url(#breeze-prod-image-build-line-63)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-prod-image-build-r2" x="1464" y="1557.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-63)">
+</text><text class="breeze-prod-image-build-r4" x="0" y="1581.6" textLength="24.4" clip-path="url(#breeze-prod-image-build-line-64)">╭─</text><text class="breeze-prod-image-build-r4" x="24.4" y="1581.6" textLength="707.6" clip-path="url(#breeze-prod-image-build-line-64)">&#160;Customization&#160;options&#160;(for&#160;specific&#160;customization&#160;needs)&#160;</text><text class="breeze-prod-image-build-r4" x="732" y="1581.6" textLength="707.6" clip-path="url(#breeze-prod-image-build-l [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1606" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-65)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1606" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-65)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1606" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-65)">-install</text><text class="breeze-prod-image-build-r5" x="134.2" y="1606" textLength="268. [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1630.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-66)">│</text><text class="breeze-prod-image-build-r2" x="536.8" y="1630.4" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-66)">Implies&#160;</text><text class="breeze-prod-image-build-r5" x="634.4" y="1630.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-66)">-</text><text class="breeze-prod-image-build-r5" x="646.6" y="1630.4" t [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1654.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-67)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1654.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-67)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1654.8" textLength="48.8" clip-path="url(#breeze-prod-image-build-line-67)">-use</text><text class="breeze-prod-image-build-r5" x="85.4" y="1654.8" textLength="4 [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1679.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-68)">│</text><text class="breeze-prod-image-build-r2" x="536.8" y="1679.2" textLength="902.8" clip-path="url(#breeze-prod-image-build-line-68)">constraints&#160;store&#160;in&#160;docker-context-files&#160;or&#160;from&#160;github.&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;</text><text class="breeze-prod [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1703.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-69)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1703.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-69)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1703.6" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-69)">-cleanup</text><text class="breeze-prod-image-build-r5" x="134.2" y="1703.6" textLeng [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1728" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-70)">│</text><text class="breeze-prod-image-build-r2" x="536.8" y="1728" textLength="170.8" clip-path="url(#breeze-prod-image-build-line-70)">together&#160;with&#160;</text><text class="breeze-prod-image-build-r5" x="707.6" y="1728" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-70)">-</text><text class="breeze-prod-image-build-r5" x="719.8" y="172 [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1752.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-71)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1752.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-71)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1752.4" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-71)">-disable</text><text class="breeze-prod-image-build-r5" x="134.2" y="1752.4" textLeng [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1776.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-72)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1776.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-72)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1776.8" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-72)">-disable</text><text class="breeze-prod-image-build-r5" x="134.2" y="1776.8" textLeng [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1801.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-73)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1801.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-73)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1801.2" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-73)">-disable</text><text class="breeze-prod-image-build-r5" x="134.2" y="1801.2" textLeng [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1825.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-74)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1825.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-74)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1825.6" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-74)">-disable</text><text class="breeze-prod-image-build-r5" x="134.2" y="1825.6" textLeng [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1850" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-75)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1850" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-75)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1850" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-75)">-install</text><text class="breeze-prod-image-build-r5" x="134.2" y="1850" textLength="219. [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1874.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-76)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1874.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-76)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1874.4" textLength="158.6" clip-path="url(#breeze-prod-image-build-line-76)">-installation</text><text class="breeze-prod-image-build-r5" x="195.2" y="1874.4" te [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1898.8" textLength="1464" clip-path="url(#breeze-prod-image-build-line-77)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-prod-image-build-r2" x="1464" y="1898.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-77)">
+</text><text class="breeze-prod-image-build-r4" x="0" y="1923.2" textLength="24.4" clip-path="url(#breeze-prod-image-build-line-78)">╭─</text><text class="breeze-prod-image-build-r4" x="24.4" y="1923.2" textLength="622.2" clip-path="url(#breeze-prod-image-build-line-78)">&#160;Preparing&#160;cache&#160;and&#160;push&#160;(for&#160;maintainers&#160;and&#160;CI)&#160;</text><text class="breeze-prod-image-build-r4" x="646.6" y="1923.2" textLength="793" clip-path="url(#breeze-prod-image-buil [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1947.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-79)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1947.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-79)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1947.6" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-79)">-builder</text><text class="breeze-prod-image-build-r2" x="341.6" y="1947.6" textLeng [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1972" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-80)">│</text><text class="breeze-prod-image-build-r4" x="341.6" y="1972" textLength="756.4" clip-path="url(#breeze-prod-image-build-line-80)">[default:&#160;autodetect]&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160; [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="1996.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-81)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="1996.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-81)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="1996.4" textLength="109.8" clip-path="url(#breeze-prod-image-build-line-81)">-platform</text><text class="breeze-prod-image-build-r2" x="341.6" y="1996.4" textLe [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="2020.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-82)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="2020.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-82)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="2020.8" textLength="61" clip-path="url(#breeze-prod-image-build-line-82)">-push</text><text class="breeze-prod-image-build-r2" x="341.6" y="2020.8" textLength="3 [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="2045.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-83)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="2045.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-83)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="2045.2" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-83)">-prepare</text><text class="breeze-prod-image-build-r5" x="134.2" y="2045.2" textLeng [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="2069.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-84)">│</text><text class="breeze-prod-image-build-r2" x="341.6" y="2069.6" textLength="1098" clip-path="url(#breeze-prod-image-build-line-84)">image).&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#160;&#16 [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="2094" textLength="1464" clip-path="url(#breeze-prod-image-build-line-85)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-prod-image-build-r2" x="1464" y="2094" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-85)">
+</text><text class="breeze-prod-image-build-r4" x="0" y="2118.4" textLength="24.4" clip-path="url(#breeze-prod-image-build-line-86)">╭─</text><text class="breeze-prod-image-build-r4" x="24.4" y="2118.4" textLength="280.6" clip-path="url(#breeze-prod-image-build-line-86)">&#160;Github&#160;authentication&#160;</text><text class="breeze-prod-image-build-r4" x="305" y="2118.4" textLength="1134.6" clip-path="url(#breeze-prod-image-build-line-86)">───────────────────────────────────────────── [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="2142.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-87)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="2142.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-87)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="2142.8" textLength="85.4" clip-path="url(#breeze-prod-image-build-line-87)">-github</text><text class="breeze-prod-image-build-r5" x="122" y="2142.8" textLength= [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="2167.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-88)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="2167.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-88)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="2167.2" textLength="85.4" clip-path="url(#breeze-prod-image-build-line-88)">-github</text><text class="breeze-prod-image-build-r5" x="122" y="2167.2" textLength= [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="2191.6" textLength="1464" clip-path="url(#breeze-prod-image-build-line-89)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-prod-image-build-r2" x="1464" y="2191.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-89)">
+</text><text class="breeze-prod-image-build-r4" x="0" y="2216" textLength="24.4" clip-path="url(#breeze-prod-image-build-line-90)">╭─</text><text class="breeze-prod-image-build-r4" x="24.4" y="2216" textLength="195.2" clip-path="url(#breeze-prod-image-build-line-90)">&#160;Common&#160;options&#160;</text><text class="breeze-prod-image-build-r4" x="219.6" y="2216" textLength="1220" clip-path="url(#breeze-prod-image-build-line-90)">────────────────────────────────────────────────────────── [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="2240.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-91)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="2240.4" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-91)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="2240.4" textLength="97.6" clip-path="url(#breeze-prod-image-build-line-91)">-verbose</text><text class="breeze-prod-image-build-r6" x="158.6" y="2240.4" textLeng [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="2264.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-92)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="2264.8" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-92)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="2264.8" textLength="48.8" clip-path="url(#breeze-prod-image-build-line-92)">-dry</text><text class="breeze-prod-image-build-r5" x="85.4" y="2264.8" textLength="4 [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="2289.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-93)">│</text><text class="breeze-prod-image-build-r5" x="24.4" y="2289.2" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-93)">-</text><text class="breeze-prod-image-build-r5" x="36.6" y="2289.2" textLength="61" clip-path="url(#breeze-prod-image-build-line-93)">-help</text><text class="breeze-prod-image-build-r6" x="158.6" y="2289.2" textLength="2 [...]
+</text><text class="breeze-prod-image-build-r4" x="0" y="2313.6" textLength="1464" clip-path="url(#breeze-prod-image-build-line-94)">╰──────────────────────────────────────────────────────────────────────────────────────────────────────────────────────╯</text><text class="breeze-prod-image-build-r2" x="1464" y="2313.6" textLength="12.2" clip-path="url(#breeze-prod-image-build-line-94)">
 </text>
     </g>
     </g>
diff --git a/scripts/docker/install_from_docker_context_files.sh b/scripts/docker/install_from_docker_context_files.sh
index fa08f47626..cdb66875ac 100644
--- a/scripts/docker/install_from_docker_context_files.sh
+++ b/scripts/docker/install_from_docker_context_files.sh
@@ -74,17 +74,42 @@ function install_airflow_and_providers_from_docker_context_files(){
         return
     fi
 
-    echo
-    echo "${COLOR_BLUE}Force re-installing airflow and providers from local files with eager upgrade${COLOR_RESET}"
-    echo
-    # force reinstall all airflow + provider package local files with eager upgrade
-    set -x
-    pip install "${pip_flags[@]}" --root-user-action ignore --upgrade --upgrade-strategy eager \
-        ${ADDITIONAL_PIP_INSTALL_FLAGS} \
-        ${reinstalling_apache_airflow_package} ${reinstalling_apache_airflow_providers_packages} \
-        ${EAGER_UPGRADE_ADDITIONAL_REQUIREMENTS=}
-    set +x
+    if [[ ${USE_CONSTRAINTS_FOR_CONTEXT_PACKAGES=} == "true" ]]; then
+        local python_version
+        python_version=$(python -c 'import sys; print(f"{sys.version_info.major}.{sys.version_info.minor}")')
+        local local_constraints_file=/docker-context-files/constraints-"${python_version}"/${AIRFLOW_CONSTRAINTS_MODE}-"${python_version}".txt
 
+        if [[ -f "${local_constraints_file}" ]]; then
+            echo
+            echo "${COLOR_BLUE}Installing docker-context-files packages with constraints found in ${local_constraints_file}${COLOR_RESET}"
+            echo
+            # force reinstall all airflow + provider packages with constraints found in
+            set -x
+            pip install "${pip_flags[@]}" --root-user-action ignore --upgrade \
+                ${ADDITIONAL_PIP_INSTALL_FLAGS} --constraint "${local_constraints_file}" \
+                ${reinstalling_apache_airflow_package} ${reinstalling_apache_airflow_providers_packages}
+            set +x
+        else
+            echo
+            echo "${COLOR_BLUE}Installing docker-context-files packages with constraints from GitHub${COLOR_RESET}"
+            echo
+            set -x
+            pip install "${pip_flags[@]}" --root-user-action ignore \
+                ${ADDITIONAL_PIP_INSTALL_FLAGS} \
+                --constraint "${AIRFLOW_CONSTRAINTS_LOCATION}" \
+                ${reinstalling_apache_airflow_package} ${reinstalling_apache_airflow_providers_packages}
+            set +x
+        fi
+    else
+        echo
+        echo "${COLOR_BLUE}Installing docker-context-files packages without constraints${COLOR_RESET}"
+        echo
+        set -x
+        pip install "${pip_flags[@]}" --root-user-action ignore \
+            ${ADDITIONAL_PIP_INSTALL_FLAGS} \
+            ${reinstalling_apache_airflow_package} ${reinstalling_apache_airflow_providers_packages}
+        set +x
+    fi
     common::install_pip_version
     pip check
 }