diff --git a/.github/workflows/publish_testpypi.yml b/.github/workflows/publish_testpypi.yml
index 93872465..7d3fd429 100644
--- a/.github/workflows/publish_testpypi.yml
+++ b/.github/workflows/publish_testpypi.yml
@@ -28,7 +28,7 @@ jobs:
# don't modify sync file! messes up version!
- run: uv sync --all-extras --frozen # does order matter?
- run: uv build
- - run: uv run --no-sync choreo_get_browser -v --i ${{ matrix.chrome_v }}
+ - run: uv run --no-sync choreo_get_chrome -v --i ${{ matrix.chrome_v }}
- name: Reinstall from wheel
run: >
uv pip install dist/choreographer-$(uv
diff --git a/.github/workflows/test.yml b/.github/workflows/test.yml
index eb209913..2a136d02 100644
--- a/.github/workflows/test.yml
+++ b/.github/workflows/test.yml
@@ -26,7 +26,7 @@ jobs:
- name: Install choreographer
run: uv sync --all-extras
- name: Install google-chrome-for-testing
- run: uv run choreo_get_browser
+ run: uv run choreo_get_chrome
- name: Diagnose
run: uv run choreo_diagnose --no-run
timeout-minutes: 1
diff --git a/.pre-commit-config.yaml b/.pre-commit-config.yaml
index b6aaac22..9bf923b4 100644
--- a/.pre-commit-config.yaml
+++ b/.pre-commit-config.yaml
@@ -2,6 +2,7 @@
# See https://pre-commit.com/hooks.html for more hooks
%YAML 1.2
---
+exclude: "site/.*"
repos:
- repo: https://github.com/pre-commit/pre-commit-hooks
rev: v3.2.0
diff --git a/choreographer/DIR_INDEX.txt b/choreographer/DIR_INDEX.txt
deleted file mode 100644
index 709f3915..00000000
--- a/choreographer/DIR_INDEX.txt
+++ /dev/null
@@ -1,31 +0,0 @@
-Files
------
-
-_browser.py
-
-A behemoth: contains process control, future storage, and user's primary interface.
-
-_cli_utils.py
-
-Functions to be used as scripts from commandline.
-
-_pipe.py
-
-The communication layer between choreographer and the browser.
-
-_tab.py
-
-Also part of user's primary interface. Intuitive, the user interacts with a "Browser"
-which has "Tabs".
-
-Directories
------------
-
-_devtools_protocol_layer/
-
-The browser-tab interface is intuitive, but here we have the interface that Chrome's
-Devtools Protocol actually provides.
-
-_system_utils/
-
-Some utilities we use to encourage cross-platform compatibility.
diff --git a/choreographer/__init__.py b/choreographer/__init__.py
index 6c5fa1a4..d57c23f1 100644
--- a/choreographer/__init__.py
+++ b/choreographer/__init__.py
@@ -1,24 +1,25 @@
-"""choreographer is a browser controller for python."""
+"""
+choreographer is a browser controller for python.
-import choreographer._devtools_protocol_layer as protocol
+choreographer is natively async, so while there are two main entrypoints:
+classes `Browser` and `BrowserSync`, the sync version is very limited, functioning
+as a building block for more featureful implementations.
-from ._browser import Browser, BrowserClosedError, browser_which, get_browser_path
-from ._cli_utils import get_browser, get_browser_sync
-from ._pipe import BlockWarning, PipeClosedError
-from ._system_utils._tempfile import TempDirectory, TempDirWarning
-from ._tab import Tab
+See the main README for a quickstart.
+"""
+
+from .browser_async import (
+ Browser,
+ Tab,
+)
+from .browser_sync import (
+ BrowserSync,
+ TabSync,
+)
__all__ = [
- "BlockWarning",
"Browser",
- "BrowserClosedError",
- "PipeClosedError",
+ "BrowserSync",
"Tab",
- "TempDirWarning",
- "TempDirectory",
- "browser_which",
- "get_browser",
- "get_browser_path",
- "get_browser_sync",
- "protocol",
+ "TabSync",
]
diff --git a/choreographer/_brokers/__init__.py b/choreographer/_brokers/__init__.py
new file mode 100644
index 00000000..4f4148fc
--- /dev/null
+++ b/choreographer/_brokers/__init__.py
@@ -0,0 +1,10 @@
+from ._async import Broker
+from ._sync import BrokerSync
+
+__all__ = [
+ "Broker",
+ "BrokerSync",
+]
+
+# note: should brokers be responsible for closing browser on bad pipe?
+# note: should the broker be the watchdog, in that case?
diff --git a/choreographer/_brokers/_async.py b/choreographer/_brokers/_async.py
new file mode 100644
index 00000000..2bcd6f4f
--- /dev/null
+++ b/choreographer/_brokers/_async.py
@@ -0,0 +1,258 @@
+from __future__ import annotations
+
+import asyncio
+import warnings
+from typing import TYPE_CHECKING
+
+import logistro
+
+from choreographer import channels, protocol
+
+# afrom choreographer.channels import ChannelClosedError
+
+if TYPE_CHECKING:
+ from collections.abc import MutableMapping
+ from typing import Any
+
+ from choreographer.browser_async import Browser
+ from choreographer.channels._interface_type import ChannelInterface
+ from choreographer.protocol.devtools_async import Session, Target
+
+
+_logger = logistro.getLogger(__name__)
+
+
+class UnhandledMessageWarning(UserWarning):
+ pass
+
+
+class Broker:
+ """Broker is a middleware implementation for asynchronous implementations."""
+
+ _browser: Browser
+ """Browser is a reference to the Browser object this broker is brokering for."""
+ _channel: ChannelInterface
+ """
+ Channel will be the ChannelInterface implementation (pipe or websocket)
+ that the broker communicates on.
+ """
+ futures: MutableMapping[protocol.MessageKey, asyncio.Future[Any]]
+ """A mapping of all the futures for all sent commands."""
+
+ _subscriptions_futures: MutableMapping[
+ str,
+ MutableMapping[
+ str,
+ list[asyncio.Future[Any]],
+ ],
+ ]
+ """A mapping of session id: subscription: list[futures]"""
+
+ def __init__(self, browser: Browser, channel: ChannelInterface) -> None:
+ """
+ Construct a broker for a synchronous arragenment w/ both ends.
+
+ Args:
+ browser: The sync browser implementation.
+ channel: The channel the browser uses to talk on.
+
+ """
+ self._browser = browser
+ self._channel = channel
+ self._background_tasks: set[asyncio.Task[Any]] = set()
+ # if its a task you dont want canceled at close (like the close task)
+ self._background_tasks_cancellable: set[asyncio.Task[Any]] = set()
+ # if its a user task, can cancel
+ self._current_read_task: asyncio.Task[Any] | None = None
+ self.futures = {}
+ self._subscriptions_futures = {}
+
+ def new_subscription_future(
+ self,
+ session_id: str,
+ subscription: str,
+ ) -> asyncio.Future[Any]:
+ if session_id not in self._subscriptions_futures:
+ self._subscriptions_futures[session_id] = {}
+ if subscription not in self._subscriptions_futures[session_id]:
+ self._subscriptions_futures[session_id][subscription] = []
+ future = asyncio.get_running_loop().create_future()
+ self._subscriptions_futures[session_id][subscription].append(future)
+ return future
+
+ def clean(self) -> None:
+ for future in self.futures.values():
+ if not future.done():
+ future.cancel()
+ if self._current_read_task and not self._current_read_task.done():
+ self._current_read_task.cancel()
+ for session in self._subscriptions_futures.values():
+ for query in session.values():
+ for future in query:
+ if not future.done():
+ future.cancel()
+ for task in self._background_tasks_cancellable:
+ if not task.done():
+ task.cancel()
+
+ def run_read_loop(self) -> None: # noqa: C901, PLR0915 complexity
+ def check_error(result: asyncio.Future[Any]) -> None:
+ try:
+ e = result.exception()
+ if e:
+ self._background_tasks.add(
+ asyncio.create_task(self._browser.close()),
+ )
+ if not isinstance(e, asyncio.CancelledError):
+ _logger.error(f"Error in run_read_loop: {e!s}")
+ raise e
+ except asyncio.CancelledError:
+ self._background_tasks.add(asyncio.create_task(self._browser.close()))
+
+ async def read_loop() -> None: # noqa: PLR0912, C901
+ try:
+ responses = await asyncio.to_thread(
+ self._channel.read_jsons,
+ blocking=True,
+ )
+ for response in responses:
+ error = protocol.get_error_from_result(response)
+ key = protocol.calculate_message_key(response)
+ if not key and error:
+ raise protocol.DevtoolsProtocolError(response)
+ self._check_for_closed_session(response)
+ # surrounding lines overlap in idea
+ if protocol.is_event(response):
+ event_session_id = response.get(
+ "sessionId",
+ "",
+ )
+ x = self._get_target_session_by_session_id(
+ event_session_id,
+ )
+ if not x:
+ continue
+ _, event_session = x
+ if not event_session:
+ _logger.error("Found an event that returned no session.")
+ continue
+
+ session_futures = self._subscriptions_futures.get(
+ event_session_id,
+ )
+ if session_futures:
+ for query in session_futures:
+ match = (
+ query.endswith("*")
+ and response["method"].startswith(query[:-1])
+ ) or (response["method"] == query)
+ if match:
+ for future in session_futures[query]:
+ if not future.done():
+ future.set_result(response)
+ session_futures[query] = []
+
+ for query in list(event_session.subscriptions):
+ match = (
+ query.endswith("*")
+ and response["method"].startswith(query[:-1])
+ ) or (response["method"] == query)
+ _logger.debug2(
+ f"Checking subscription key: {query} "
+ f"against event method {response['method']}",
+ )
+ if match:
+ t: asyncio.Task[Any] = asyncio.create_task(
+ event_session.subscriptions[query][0](response),
+ )
+ self._background_tasks_cancellable.add(t)
+ if not event_session.subscriptions[query][1]:
+ event_session.unsubscribe(query)
+
+ elif key:
+ if key in self.futures:
+ _logger.debug(f"run_read_loop() found future for key {key}")
+ future = self.futures.pop(key)
+ elif "error" in response:
+ raise protocol.DevtoolsProtocolError(response)
+ else:
+ raise RuntimeError(f"Couldn't find a future for key: {key}")
+ future.set_result(response)
+ else:
+ warnings.warn( # noqa: B028
+ f"Unhandled message type:{response!s}",
+ UnhandledMessageWarning,
+ )
+ except channels.ChannelClosedError:
+ _logger.debug("PipeClosedError caught")
+ self._background_tasks.add(asyncio.create_task(self._browser.close()))
+ return
+ read_task = asyncio.create_task(read_loop())
+ read_task.add_done_callback(check_error)
+ self._current_read_task = read_task
+
+ read_task = asyncio.create_task(read_loop())
+ read_task.add_done_callback(check_error)
+ self._current_read_task = read_task
+
+ async def write_json(
+ self,
+ obj: protocol.BrowserCommand,
+ ) -> protocol.BrowserResponse:
+ _logger.debug2(f"In broker.write_json for {obj}")
+ protocol.verify_params(obj)
+ key = protocol.calculate_message_key(obj)
+ if not key:
+ raise RuntimeError(
+ "Message strangely formatted and "
+ "choreographer couldn't figure it out why.",
+ )
+ loop = asyncio.get_running_loop()
+ future: asyncio.Future[protocol.BrowserResponse] = loop.create_future()
+ self.futures[key] = future
+ try:
+ await asyncio.to_thread(self._channel.write_json, obj)
+ except BaseException as e: # noqa: BLE001
+ future.set_exception(e)
+ del self.futures[key]
+ return await future
+
+ def _get_target_session_by_session_id(
+ self,
+ session_id: str,
+ ) -> tuple[Target, Session] | None:
+ if session_id == "":
+ return (self._browser, self._browser.sessions[session_id])
+ for tab in self._browser.tabs.values():
+ if session_id in tab.sessions:
+ return (tab, tab.sessions[session_id])
+ if session_id in self._browser.sessions:
+ return (self._browser, self._browser.sessions[session_id])
+ return None
+
+ def _check_for_closed_session(self, response: protocol.BrowserResponse) -> bool:
+ if "method" in response and response["method"] == "Target.detachedFromTarget":
+ session_closed = response["params"].get(
+ "sessionId",
+ "",
+ )
+ if session_closed == "":
+ return True
+
+ x = self._get_target_session_by_session_id(session_closed)
+ if x:
+ target_closed, _ = x
+ else:
+ return False
+
+ if target_closed:
+ target_closed._remove_session(session_closed) # noqa: SLF001
+ _logger.debug(
+ "Using intern subscription key: "
+ "'Target.detachedFromTarget'. "
+ f"Session {session_closed} was closed.",
+ )
+ return True
+ return False
+ else:
+ return False
diff --git a/choreographer/_brokers/_sync.py b/choreographer/_brokers/_sync.py
new file mode 100644
index 00000000..297954d8
--- /dev/null
+++ b/choreographer/_brokers/_sync.py
@@ -0,0 +1,79 @@
+from __future__ import annotations
+
+import json
+from threading import Thread
+from typing import TYPE_CHECKING
+
+import logistro
+
+from choreographer import protocol
+from choreographer.channels import ChannelClosedError
+
+if TYPE_CHECKING:
+ from typing import Any
+
+ from choreographer.browser_sync import BrowserSync
+ from choreographer.channels._interface_type import ChannelInterface
+
+_logger = logistro.getLogger(__name__)
+
+
+class BrokerSync:
+ """BrokerSync is a middleware implementation for synchronous browsers."""
+
+ _browser: BrowserSync
+ """Browser is a reference to the Browser object this broker is brokering for."""
+ _channel: ChannelInterface
+ """
+ Channel will be the ChannelInterface implementation (pipe or websocket)
+ that the broker communicates on.
+ """
+
+ def __init__(self, browser: BrowserSync, channel: ChannelInterface) -> None:
+ """
+ Construct a broker for a synchronous arragenment w/ both ends.
+
+ Args:
+ browser: The sync browser implementation.
+ channel: The channel the browser uses to talk on.
+
+ """
+ self._browser = browser
+ self._channel = channel
+
+ def run_output_thread(self, **kwargs: Any) -> None:
+ """
+ Run a thread which dumps all browser messages. kwargs is passed to print.
+
+ Raises:
+ ChannelClosedError: When the channel is closed, this error is raised.
+
+ """
+
+ def run_print() -> None:
+ try:
+ while True:
+ responses = self._channel.read_jsons()
+ for response in responses:
+ print(json.dumps(response, indent=4), **kwargs) # noqa: T201 print in the point
+ except ChannelClosedError:
+ print("ChannelClosedError caught.", **kwargs) # noqa: T201 print is the point
+
+ _logger.info("Starting thread to dump output to stdout.")
+ Thread(target=run_print).start()
+
+ def write_json(self, obj: protocol.BrowserCommand) -> protocol.MessageKey | None:
+ """
+ Send an object down the channel.
+
+ Args:
+ obj: An object to be serialized to json and written to the channel.
+
+ """
+ protocol.verify_params(obj)
+ key = protocol.calculate_message_key(obj)
+ self._channel.write_json(obj)
+ return key
+
+ def clean(self) -> None:
+ pass
diff --git a/choreographer/_browser.py b/choreographer/_browser.py
deleted file mode 100644
index 69c8997c..00000000
--- a/choreographer/_browser.py
+++ /dev/null
@@ -1,748 +0,0 @@
-import asyncio
-import io
-import json
-import os
-import platform
-import subprocess
-import sys
-import warnings
-from collections import OrderedDict
-from functools import partial
-from pathlib import Path
-from threading import Thread
-
-from ._devtools_protocol_layer._protocol import (
- TARGET_NOT_FOUND,
- DevtoolsProtocolError,
- ExperimentalFeatureWarning,
- Protocol,
-)
-from ._devtools_protocol_layer._session import Session
-from ._devtools_protocol_layer._target import Target
-from ._pipe import Pipe, PipeClosedError
-from ._system_utils._system import browser_which
-from ._system_utils._tempfile import TempDirectory, TempDirWarning
-from ._tab import Tab
-
-# importing the below via __file__ causes __name__ weirdness when its exe'd ???
-chromewrapper_path = (
- Path(__file__).resolve().parent / "_system_utils" / "_chrome_wrapper.py"
-)
-
-
-class UnhandledMessageWarning(UserWarning):
- pass
-
-
-class BrowserFailedError(RuntimeError):
- pass
-
-
-class BrowserClosedError(RuntimeError):
- pass
-
-
-def get_browser_path(**kwargs):
- return os.environ.get("BROWSER_PATH", browser_which(**kwargs))
-
-
-class Browser(Target):
- # Some frameworks configure windows use SelectorEventLoop, which lacks
- # certain features, so we need to know.
- def _check_loop(self):
- # Lock
- if not self.lock:
- self.lock = asyncio.Lock()
- if (
- platform.system() == "Windows"
- and self.loop
- and isinstance(self.loop, asyncio.SelectorEventLoop)
- ):
- if self.debug:
- print("We are in a selector event loop, use loop_hack", file=sys.stderr)
- self._loop_hack = True
-
- def __init__( # noqa: PLR0915, PLR0912, C901 It's too complex
- self,
- path=None,
- *,
- headless=True,
- debug=False,
- debug_browser=False,
- **kwargs,
- ):
- ### Set some defaults
- self._env = os.environ.copy() # environment for subprocesses
- self._loop_hack = False # see _check_loop
- self.lock = None
- self.tabs = OrderedDict()
- self.sandboxed = False # this is if our processes can't use /tmp
-
- # Browser Configuration
- self.enable_sandbox = kwargs.pop("enable_sandbox", False)
- if self.enable_sandbox:
- self._env["SANDBOX_ENABLED"] = "true"
- if not path:
- skip_local = bool(
- "ubuntu" in platform.version().lower() and self.enable_sandbox,
- )
- path = get_browser_path(skip_local=skip_local)
- if not path:
- raise BrowserFailedError(
- "Could not find an acceptable browser. Please call "
- "`choreo.get_browser()`, set environmental variable "
- "BROWSER_PATH or pass `path=/path/to/browser` into "
- "the Browser() constructor. The latter two work with Edge.",
- )
- if "snap" in str(path):
- self.sandboxed = True # not chromium sandbox, snap sandbox
- self._env["BROWSER_PATH"] = str(path)
- self.headless = headless
- if headless:
- self._env["HEADLESS"] = "--headless"
- self.debug = debug
- self.enable_gpu = kwargs.pop("enable_gpu", False)
- if self.enable_gpu:
- self._env["GPU_ENABLED"] = "true"
-
- # Expert Configuration
- tmp_path = kwargs.pop("tmp_path", None)
- self.tmp_dir = TempDirectory(tmp_path, sneak=self.sandboxed)
-
- try:
- self.loop = kwargs.pop("loop", asyncio.get_running_loop())
- except RuntimeError:
- self.loop = False
- if self.loop:
- self.futures = {}
- self._check_loop()
- self.executor = kwargs.pop("executor", None)
-
- if len(kwargs):
- raise ValueError(f"Unknown keyword arguments: {kwargs}")
-
- # Set up stderr
- if debug_browser is False: # false o None
- stderr = subprocess.DEVNULL
- elif debug_browser is True:
- stderr = sys.stderr
- else:
- stderr = debug_browser
-
- if (
- stderr
- and stderr not in (subprocess.PIPE, subprocess.STDOUT, subprocess.DEVNULL)
- and not isinstance(stderr, int)
- ):
- try:
- stderr.fileno()
- except io.UnsupportedOperation:
- warnings.warn( # noqa: B028
- "A value has been passed to debug_browser which "
- "is not compatible with python's Popen. This may "
- "be because one was passed to Browser or because "
- "sys.stderr has been overridden by a framework. "
- "Browser logs will not be handled by python in this case.",
- )
- stderr = None
-
- self._stderr = stderr
-
- if debug:
- print(f"STDERR: {stderr}", file=sys.stderr)
-
- self._env["USER_DATA_DIR"] = str(self.tmp_dir.path)
-
- # Compose Resources
- self.pipe = Pipe(debug=debug)
- self.protocol = Protocol(debug=debug)
-
- # Initializing
- super().__init__("0", self) # NOTE: 0 can't really be used externally
- self._add_session(Session(self, ""))
-
- if self.debug:
- print("DEBUG REPORT:", file=sys.stderr)
- print(f"BROWSER_PATH: {self._env['BROWSER_PATH']}", file=sys.stderr)
- print(f"USER_DATA_DIR: {self._env['USER_DATA_DIR']}", file=sys.stderr)
- if not self.loop:
- self._open()
-
- # for use with `async with Browser()`
- def __aenter__(self):
- self.future_self = self.loop.create_future()
- self.loop.create_task(self._open_async())
- self.run_read_loop()
- return self.future_self
-
- def __enter__(self):
- return self
-
- # for use with `await Browser()`
- def __await__(self):
- return self.__aenter__().__await__()
-
- # ? why have to call __await__ when __aenter__ returns a future
-
- def _open(self):
- if platform.system() != "Windows":
- self.subprocess = subprocess.Popen( # noqa: S603, false positive, input fine
- [
- sys.executable,
- chromewrapper_path,
- ],
- close_fds=True,
- stdin=self.pipe.read_to_chromium,
- stdout=self.pipe.write_from_chromium,
- stderr=self._stderr,
- env=self._env,
- )
- else:
- from ._system_utils._chrome_wrapper import open_browser
-
- self.subprocess = open_browser(
- to_chromium=self.pipe.read_to_chromium,
- from_chromium=self.pipe.write_from_chromium,
- stderr=self._stderr,
- env=self._env,
- loop_hack=self._loop_hack,
- )
-
- async def _open_async(self):
- try:
- if platform.system() != "Windows":
- self.subprocess = await asyncio.create_subprocess_exec(
- sys.executable,
- chromewrapper_path,
- stdin=self.pipe.read_to_chromium,
- stdout=self.pipe.write_from_chromium,
- stderr=self._stderr,
- close_fds=True,
- env=self._env,
- )
- else:
- from ._system_utils._chrome_wrapper import open_browser
-
- self.subprocess = await open_browser(
- to_chromium=self.pipe.read_to_chromium,
- from_chromium=self.pipe.write_from_chromium,
- stderr=self._stderr,
- env=self._env,
- loop=True,
- loop_hack=self._loop_hack,
- )
- self.loop.create_task(self._watchdog())
- await self.populate_targets()
- self.future_self.set_result(self)
- except (BrowserClosedError, BrowserFailedError, asyncio.CancelledError) as e:
- raise BrowserFailedError(
- "The browser seemed to close immediately after starting. "
- "Perhaps adding debug_browser=True will help.",
- ) from e
-
- async def _is_closed_async(self, wait=0):
- if self.debug:
- print(f"is_closed called with wait: {wait}", file=sys.stderr)
- if self._loop_hack:
- # Use synchronous tools in thread
- return await asyncio.to_thread(self._is_closed, wait)
- waiter = self.subprocess.wait()
- try:
- if wait == 0: # this never works cause processing
- wait = 0.15
- await asyncio.wait_for(waiter, wait)
- except TimeoutError:
- return False
- return True
-
- def _is_closed(self, wait=0):
- if wait == 0:
- return self.subprocess.poll() is None
- else:
- try:
- self.subprocess.wait(wait)
- except subprocess.TimeoutExpired:
- return False
- return True
-
- # _sync_close and _async_close are basically the same thing
-
- def _sync_close(self): # noqa: PLR0912, C901
- if self._is_closed():
- if self.debug:
- print("Browser was already closed.", file=sys.stderr)
- return
- # check if no sessions or targets
- self.send_command("Browser.close")
- if self._is_closed():
- if self.debug:
- print("Browser.close method closed browser", file=sys.stderr)
- return
- self.pipe.close()
- if self._is_closed(wait=1):
- if self.debug:
- print(
- "pipe.close() (or slow Browser.close) method closed browser",
- file=sys.stderr,
- )
- return
-
- # Start a kill
- if platform.system() == "Windows":
- if not self._is_closed():
- subprocess.call( # noqa: S603, false positive, input fine
- ["taskkill", "/F", "/T", "/PID", str(self.subprocess.pid)], # noqa: S607 windows full path...
- stderr=subprocess.DEVNULL,
- stdout=subprocess.DEVNULL,
- )
- if self._is_closed(wait=4):
- return
- else:
- raise RuntimeError("Couldn't kill browser subprocess")
- else:
- self.subprocess.terminate()
- if self._is_closed():
- if self.debug:
- print("terminate() closed the browser", file=sys.stderr)
- return
-
- self.subprocess.kill()
- if self._is_closed(wait=4) and self.debug:
- print("kill() closed the browser", file=sys.stderr)
- return
-
- async def _async_close(self): # noqa: PLR0912, C901
- if await self._is_closed_async():
- if self.debug:
- print("Browser was already closed.", file=sys.stderr)
- return
- await asyncio.wait([self.send_command("Browser.close")], timeout=1)
- if await self._is_closed_async():
- if self.debug:
- print("Browser.close method closed browser", file=sys.stderr)
- return
- self.pipe.close()
- if await self._is_closed_async(wait=1):
- if self.debug:
- print("pipe.close() method closed browser", file=sys.stderr)
- return
-
- # Start a kill
- if platform.system() == "Windows":
- if not await self._is_closed_async():
- # could we use native asyncio process here? or hackcheck?
- await asyncio.to_thread(
- subprocess.call,
- ["taskkill", "/F", "/T", "/PID", str(self.subprocess.pid)],
- stderr=subprocess.DEVNULL,
- stdout=subprocess.DEVNULL,
- )
- if await self._is_closed_async(wait=4):
- return
- else:
- raise RuntimeError("Couldn't kill browser subprocess")
- else:
- self.subprocess.terminate()
- if await self._is_closed_async():
- if self.debug:
- print("terminate() closed the browser", file=sys.stderr)
- return
-
- self.subprocess.kill()
- if await self._is_closed_async(wait=4) and self.debug:
- print("kill() closed the browser", file=sys.stderr)
- return
-
- def close(self): # noqa: C901
- if self.loop:
-
- async def close_task(): # noqa: PLR0912, C901
- if self.lock.locked():
- return
- await self.lock.acquire()
- if not self.future_self.done():
- self.future_self.set_exception(
- BrowserFailedError(
- "Close() was called before the browser "
- "finished opening- maybe it crashed?",
- ),
- )
- for future in self.futures.values():
- if future.done():
- continue
- future.set_exception(
- BrowserClosedError(
- "Command not completed because browser closed.",
- ),
- )
- for session in self.sessions.values():
- for futures in session.subscriptions_futures.values():
- for future in futures:
- if future.done():
- continue
- future.set_exception(
- BrowserClosedError(
- "Event not complete because browser closed.",
- ),
- )
- for tab in self.tabs.values():
- for session in tab.sessions.values():
- for futures in session.subscriptions_futures.values():
- for future in futures:
- if future.done():
- continue
- future.set_exception(
- BrowserClosedError(
- "Event not completed because browser closed.",
- ),
- )
- try:
- await self._async_close()
- except ProcessLookupError:
- pass
- self.pipe.close()
- self.tmp_dir.clean()
-
- return asyncio.create_task(close_task())
- else:
- try:
- self._sync_close()
- except ProcessLookupError:
- pass
- self.pipe.close()
- self.tmp_dir.clean()
- return None
-
- async def _watchdog(self):
- self._watchdog_healthy = True
- if self.debug:
- print("Starting watchdog", file=sys.stderr)
- await self.subprocess.wait()
- if self.lock.locked():
- return
- self._watchdog_healthy = False
- if self.debug:
- print("Browser is being closed because chrom* closed", file=sys.stderr)
- await self.close()
- await asyncio.sleep(1)
- with warnings.catch_warnings():
- # ignore warnings here because
- # watchdog killing is last resort
- # and can leaves stuff in weird state
- warnings.filterwarnings("ignore", category=TempDirWarning)
- self.tmp_dir.clean()
- if self.tmp_dir.exists:
- self.tmp_dir.delete_manually()
-
- def __exit__(self, exc_type, exc_value, exc_traceback):
- self.close()
-
- async def __aexit__(self, exc_type, exc_value, exc_traceback):
- await self.close()
-
- # Basic synchronous functions
- def _add_tab(self, tab):
- if not isinstance(tab, Tab):
- raise TypeError("tab must be an object of class Tab")
- self.tabs[tab.target_id] = tab
-
- def _remove_tab(self, target_id):
- if isinstance(target_id, Tab):
- target_id = target_id.target_id
- del self.tabs[target_id]
-
- def get_tab(self):
- if self.tabs.values():
- return next(iter(self.tabs.values()))
- return None
-
- # Better functions that require asynchronous
- async def create_tab(self, url="", width=None, height=None):
- if self.lock.locked():
- raise BrowserClosedError("create_tab() called on a closed browser.")
- if self.headless and (width or height):
- warnings.warn( # noqa: B028
- "Width and height only work for headless chrome mode, "
- "they will be ignored.",
- )
- width = None
- height = None
- params = {"url": url}
- if width:
- params["width"] = width
- if height:
- params["height"] = height
-
- response = await self.browser.send_command("Target.createTarget", params=params)
- if "error" in response:
- raise RuntimeError("Could not create tab") from DevtoolsProtocolError(
- response,
- )
- target_id = response["result"]["targetId"]
- new_tab = Tab(target_id, self)
- self._add_tab(new_tab)
- await new_tab.create_session()
- return new_tab
-
- async def close_tab(self, target_id):
- if self.lock.locked():
- raise BrowserClosedError("close_tab() called on a closed browser")
- if isinstance(target_id, Target):
- target_id = target_id.target_id
- # NOTE: we don't need to manually remove sessions because
- # sessions are intrinisically handled by events
- response = await self.send_command(
- command="Target.closeTarget",
- params={"targetId": target_id},
- )
- self._remove_tab(target_id)
- if "error" in response:
- raise RuntimeError("Could not close tab") from DevtoolsProtocolError(
- response,
- )
- return response
-
- async def create_session(self):
- if self.lock.locked():
- raise BrowserClosedError("create_session() called on a closed browser")
- warnings.warn( # noqa: B028
- "Creating new sessions on Browser() only works with some "
- "versions of Chrome, it is experimental.",
- ExperimentalFeatureWarning,
- )
- response = await self.browser.send_command("Target.attachToBrowserTarget")
- if "error" in response:
- raise RuntimeError("Could not create session") from DevtoolsProtocolError(
- response,
- )
- session_id = response["result"]["sessionId"]
- new_session = Session(self, session_id)
- self._add_session(new_session)
- return new_session
-
- async def populate_targets(self):
- if self.lock.locked():
- raise BrowserClosedError("populate_targets() called on a closed browser")
- response = await self.browser.send_command("Target.getTargets")
- if "error" in response:
- raise RuntimeError("Could not get targets") from Exception(
- response["error"],
- )
-
- for json_response in response["result"]["targetInfos"]:
- if (
- json_response["type"] == "page"
- and json_response["targetId"] not in self.tabs
- ):
- target_id = json_response["targetId"]
- new_tab = Tab(target_id, self)
- try:
- await new_tab.create_session()
- except DevtoolsProtocolError as e:
- if e.code == TARGET_NOT_FOUND:
- if self.debug:
- print(
- f"Target {target_id} not found "
- "(could be closed before)",
- file=sys.stderr,
- )
- continue
- else:
- raise
- self._add_tab(new_tab)
- if self.debug:
- print(f"The target {target_id} was added", file=sys.stderr)
-
- # Output Helper for Debugging
- def run_output_thread(self, debug=None):
- if self.loop:
- raise ValueError("You must use this method without loop in the Browser")
- if not debug:
- debug = self.debug
-
- def run_print(debug):
- if debug:
- print("Starting run_print loop", file=sys.stderr)
- try:
- while True:
- responses = self.pipe.read_jsons(debug=debug)
- for response in responses:
- print(json.dumps(response, indent=4))
- except PipeClosedError:
- if self.debug:
- print("PipeClosedError caught", file=sys.stderr)
-
- Thread(target=run_print, args=(debug,)).start()
-
- def _get_target_for_session(self, session_id):
- for tab in self.tabs.values():
- if session_id in tab.sessions:
- return tab
- if session_id in self.sessions:
- return self
- return None
-
- def run_read_loop(self): # noqa: PLR0915, C901 complexity
- def check_error(result):
- e = result.exception()
- if e:
- self.close()
- if self.debug:
- print(f"Error in run_read_loop: {e!s}", file=sys.stderr)
- if not isinstance(e, asyncio.CancelledError):
- raise e
-
- async def read_loop(): # noqa: PLR0915, PLR0912, C901 complexity
- try:
- read_jsons = partial(
- self.pipe.read_jsons,
- blocking=True,
- debug=self.debug,
- )
- responses = await self.loop.run_in_executor(
- self.executor,
- read_jsons,
- )
- for response in responses:
- error = self.protocol.get_error(response)
- key = self.protocol.calculate_key(response)
- if not self.protocol.has_id(response) and error:
- raise DevtoolsProtocolError(response)
- elif self.protocol.is_event(response):
- event_session_id = response.get(
- "sessionId",
- "",
- )
- event_session = self.protocol.sessions[event_session_id]
-
- subscriptions_futures = event_session.subscriptions_futures
-
- ### THIS IS FOR SUBSCRIBE(repeating=True|False)
- for query in list(event_session.subscriptions):
- match = (
- query.endswith("*")
- and response["method"].startswith(query[:-1])
- ) or (response["method"] == query)
- if self.debug:
- print(
- f"Checking subscription key: {query} "
- "against event method {response['method']}",
- file=sys.stderr,
- )
- if match:
- self.loop.create_task(
- event_session.subscriptions[query][0](response),
- )
- if not event_session.subscriptions[query][1]:
- self.protocol.sessions[
- event_session_id
- ].unsubscribe(query)
-
- ### THIS IS FOR SUBSCRIBE_ONCE
- for query, futures in list(subscriptions_futures.items()):
- match = (
- query.endswith("*")
- and response["method"].startswith(query[:-1])
- ) or (response["method"] == query)
- if self.debug:
- print(
- f"Checking subscription key: {query} against "
- "event method {response['method']}",
- file=sys.stderr,
- )
- if match:
- for future in futures:
- if self.debug:
- print(
- f"Processing future {id(future)}",
- file=sys.stderr,
- )
- future.set_result(response)
- if self.debug:
- print(
- f"Future resolved with response {future}",
- file=sys.stderr,
- )
- del event_session.subscriptions_futures[query]
-
- ### Check for closed sessions
- if response["method"] == "Target.detachedFromTarget":
- session_closed = response["params"].get(
- "sessionId",
- "",
- )
- if session_closed == "":
- continue # browser closing anyway
- target_closed = self._get_target_for_session(session_closed)
- if target_closed:
- target_closed._remove_session(session_closed) # noqa: SLF001
- # TODO(Andrew): private access # noqa: FIX002, TD003
-
- _ = self.protocol.sessions.pop(session_closed, None)
- if self.debug:
- print(
- "Use intern subscription key: "
- "'Target.detachedFromTarget'. "
- f"Session {session_closed} was closed.",
- file=sys.stderr,
- )
-
- elif key:
- future = None
- if key in self.futures:
- if self.debug:
- print(
- f"run_read_loop() found future for key {key}",
- file=sys.stderr,
- )
- future = self.futures.pop(key)
- elif "error" in response:
- raise DevtoolsProtocolError(response)
- else:
- raise RuntimeError(f"Couldn't find a future for key: {key}")
- if error:
- future.set_result(response)
- else:
- future.set_result(response)
- else:
- warnings.warn( # noqa: B028
- f"Unhandled message type:{response!s}",
- UnhandledMessageWarning,
- )
- except PipeClosedError:
- if self.debug:
- print("PipeClosedError caught", file=sys.stderr)
- return
- f = self.loop.create_task(read_loop())
- f.add_done_callback(check_error)
-
- f = self.loop.create_task(read_loop())
- f.add_done_callback(check_error)
-
- def write_json(self, obj):
- self.protocol.verify_json(obj)
- key = self.protocol.calculate_key(obj)
- if self.loop:
- future = self.loop.create_future()
- self.futures[key] = future
- res = self.loop.run_in_executor(
- self.executor,
- self.pipe.write_json,
- obj,
- ) # ignore result
-
- def check_future(fut):
- if fut.exception():
- if self.debug:
- print(f"Write json future error: {fut!s}", file=sys.stderr)
- if not future.done():
- print("Setting future based on pipe error", file=sys.stderr)
- future.set_exception(fut.exception())
- print("Exception set", file=sys.stderr)
- self.close()
-
- res.add_done_callback(check_future)
- return future
- else:
- self.pipe.write_json(obj)
- return key
diff --git a/choreographer/_cli_utils.py b/choreographer/_cli_utils.py
deleted file mode 100644
index a0bbdd58..00000000
--- a/choreographer/_cli_utils.py
+++ /dev/null
@@ -1,153 +0,0 @@
-import argparse
-import asyncio
-import json
-import platform
-import shutil
-import sys
-import urllib.request
-import warnings
-import zipfile
-from pathlib import Path
-
-# we use arch instead of platform when singular since platform is a package
-platforms = ["linux64", "win32", "win64", "mac-x64", "mac-arm64"]
-
-default_local_exe_path = Path(__file__).resolve().parent / "browser_exe"
-
-platform_detected = platform.system()
-arch_size_detected = "64" if sys.maxsize > 2**32 else "32"
-arch_detected = "arm" if platform.processor() == "arm" else "x"
-
-if platform_detected == "Windows":
- chrome_platform_detected = "win" + arch_size_detected
-elif platform_detected == "Linux":
- chrome_platform_detected = "linux" + arch_size_detected
-elif platform_detected == "Darwin":
- chrome_platform_detected = "mac-" + arch_detected + arch_size_detected
-
-default_exe_name = None
-if platform_detected.startswith("Linux"):
- default_exe_name = (
- default_local_exe_path / f"chrome-{chrome_platform_detected}" / "chrome"
- )
-elif platform_detected.startswith("Darwin"):
- default_exe_name = (
- default_local_exe_path
- / f"chrome-{chrome_platform_detected}"
- / "Google Chrome for Testing.app"
- / "Contents"
- / "MacOS"
- / "Google Chrome for Testing"
- )
-elif platform_detected.startswith("Win"):
- default_exe_name = (
- default_local_exe_path / f"chrome-{chrome_platform_detected}" / "chrome.exe"
- )
-
-
-# https://stackoverflow.com/questions/39296101/python-zipfile-removes-execute-permissions-from-binaries
-class ZipFilePermissions(zipfile.ZipFile):
- def _extract_member(self, member, targetpath, pwd):
- if not isinstance(member, zipfile.ZipInfo):
- member = self.getinfo(member)
-
- path = super()._extract_member(member, targetpath, pwd)
- # High 16 bits are os specific (bottom is st_mode flag)
- attr = member.external_attr >> 16
- if attr != 0:
- Path(path).chmod(attr)
- return path
-
-
-def get_browser_cli():
- if "ubuntu" in platform.version().lower():
- warnings.warn( # noqa: B028
- "You are using `get_browser()` on Ubuntu."
- " Ubuntu is **very strict** about where binaries come from."
- " You have to disable the sandbox with use_sandbox=False"
- " when you initialize the browser OR you can install from Ubuntu's"
- " package manager.",
- UserWarning,
- )
- parser = argparse.ArgumentParser(description="tool to help debug problems")
- parser.add_argument("--i", "-i", type=int, dest="i")
- parser.add_argument("--arch", dest="arch")
- parser.add_argument("--path", dest="path")
- parser.add_argument(
- "-v",
- "--verbose",
- dest="verbose",
- action="store_true",
- )
- parser.set_defaults(i=-1)
- parser.set_defaults(path=default_local_exe_path)
- parser.set_defaults(arch=chrome_platform_detected)
- parser.set_defaults(verbose=False)
- parsed = parser.parse_args()
- i = parsed.i
- arch = parsed.arch
- path = Path(parsed.path)
- verbose = parsed.verbose
- if not arch or arch not in platforms:
- raise RuntimeError(
- "You must specify a platform: "
- f"linux64, win32, win64, mac-x64, mac-arm64, not {platform}",
- )
- print(get_browser_sync(arch=arch, i=i, path=path, verbose=verbose))
-
-
-def get_browser_sync(
- arch=chrome_platform_detected,
- i=-1,
- path=default_local_exe_path,
- *,
- verbose=False,
-):
- path = Path(path)
- browser_list = json.loads(
- urllib.request.urlopen(
- "https://googlechromelabs.github.io/chrome-for-testing/known-good-versions-with-downloads.json",
- ).read(),
- )
- version_obj = browser_list["versions"][i]
- if verbose:
- print(version_obj["version"])
- print(version_obj["revision"])
- chromium_sources = version_obj["downloads"]["chrome"]
- url = None
- for src in chromium_sources:
- if src["platform"] == arch:
- url = src["url"]
- break
- if not path.exists():
- path.mkdir(parents=True)
- filename = path / "chrome.zip"
- with urllib.request.urlopen(url) as response, filename.open("wb") as out_file: # noqa: S310 audit url
- shutil.copyfileobj(response, out_file)
- with ZipFilePermissions(filename, "r") as zip_ref:
- zip_ref.extractall(path)
-
- if arch.startswith("linux"):
- exe_name = path / f"chrome-{arch}" / "chrome"
- elif arch.startswith("mac"):
- exe_name = (
- path
- / f"chrome-{arch}"
- / "Google Chrome for Testing.app"
- / "Contents"
- / "MacOS"
- / "Google Chrome for Testing"
- )
- elif arch.startswith("win"):
- exe_name = path / f"chrome-{arch}" / "chrome.exe"
-
- return exe_name
-
-
-# to_thread everything
-async def get_browser(
- arch=chrome_platform_detected,
- i=-1,
- path=default_local_exe_path,
-):
- return await asyncio.to_thread(get_browser_sync, arch=arch, i=i, path=path)
diff --git a/choreographer/_devtools_protocol_layer/__init__.py b/choreographer/_devtools_protocol_layer/__init__.py
deleted file mode 100644
index 82a69b76..00000000
--- a/choreographer/_devtools_protocol_layer/__init__.py
+++ /dev/null
@@ -1,17 +0,0 @@
-from ._protocol import (
- DevtoolsProtocolError,
- ExperimentalFeatureWarning,
- MessageTypeError,
- MissingKeyError,
-)
-from ._session import Session
-from ._target import Target
-
-__all__ = [
- "DevtoolsProtocolError",
- "ExperimentalFeatureWarning",
- "MessageTypeError",
- "MissingKeyError",
- "Session",
- "Target",
-]
diff --git a/choreographer/_devtools_protocol_layer/_protocol.py b/choreographer/_devtools_protocol_layer/_protocol.py
deleted file mode 100644
index b8dbe402..00000000
--- a/choreographer/_devtools_protocol_layer/_protocol.py
+++ /dev/null
@@ -1,106 +0,0 @@
-TARGET_NOT_FOUND = -32602
-
-
-class DevtoolsProtocolError(Exception):
- def __init__(self, response):
- super().__init__(response)
- self.code = response["error"]["code"]
- self.message = response["error"]["message"]
-
-
-class MessageTypeError(TypeError):
- def __init__(self, key, value, expected_type):
- value = type(value) if not isinstance(value, type) else value
- super().__init__(
- f"Message with key {key} must have type {expected_type}, not {value}.",
- )
-
-
-class MissingKeyError(ValueError):
- def __init__(self, key, obj):
- super().__init__(
- f"Message missing required key/s {key}. Message received: {obj}",
- )
-
-
-class ExperimentalFeatureWarning(UserWarning):
- pass
-
-
-class Protocol:
- def __init__(self, *, debug=False):
- # Stored Resources
-
- # Configuration
- self.debug = debug
-
- # State
- self.sessions = {}
-
- def calculate_key(self, response):
- session_id = response.get("sessionId", "")
- message_id = response.get("id", None)
- if message_id is None:
- return None
- return (session_id, message_id)
-
- def verify_json(self, obj):
- n_keys = 0
- required_keys = {"id": int, "method": str}
- for key, type_key in required_keys.items():
- if key not in obj:
- raise MissingKeyError(key, obj)
- if not isinstance(obj[key], type_key):
- raise MessageTypeError(key, type(obj[key]), type_key)
- n_keys += 2
-
- if "params" in obj:
- n_keys += 1
- if "sessionId" in obj:
- n_keys += 1
-
- if len(obj.keys()) != n_keys:
- raise RuntimeError(
- "Message objects must have id and method keys, "
- "and may have params and sessionId keys.",
- )
-
- def match_key(self, response, key):
- session_id, message_id = key
- if ("session_id" not in response and session_id == "") or (
- "session_id" in response and response["session_id"] == session_id
- ):
- pass
- else:
- return False
-
- if "id" in response and str(response["id"]) == str(message_id):
- pass
- else:
- return False
- return True
-
- def has_id(self, response):
- return "id" in response
-
- def get_target_id(self, response):
- if "result" in response and "targetId" in response["result"]:
- return response["result"]["targetId"]
- else:
- return None
-
- def get_session_id(self, response):
- if "result" in response and "sessionId" in response["result"]:
- return response["result"]["sessionId"]
- else:
- return None
-
- def get_error(self, response):
- if "error" in response:
- return response["error"]
- else:
- return None
-
- def is_event(self, response):
- required_keys = {"method", "params"}
- return required_keys <= response.keys() and "id" not in response
diff --git a/choreographer/_devtools_protocol_layer/_session.py b/choreographer/_devtools_protocol_layer/_session.py
deleted file mode 100644
index 2c2058d8..00000000
--- a/choreographer/_devtools_protocol_layer/_session.py
+++ /dev/null
@@ -1,57 +0,0 @@
-class Session:
- def __init__(self, browser, session_id):
- if not isinstance(session_id, str):
- raise TypeError("session_id must be a string")
- # Resources
- self.browser = browser
-
- # State
- self.session_id = session_id
- self.message_id = 0
- self.subscriptions = {}
- self.subscriptions_futures = {}
-
- def send_command(self, command, params=None):
- current_id = self.message_id
- self.message_id += 1
- json_command = {
- "id": current_id,
- "method": command,
- }
-
- if self.session_id:
- json_command["sessionId"] = self.session_id
- if params:
- json_command["params"] = params
-
- return self.browser.write_json(json_command)
-
- def subscribe(self, string, callback, *, repeating=True):
- if not self.browser.loop:
- raise ValueError("You may use this method with a loop in Browser")
- if string in self.subscriptions:
- raise ValueError(
- "You are already subscribed to this string, "
- "duplicate subscriptions are not allowed.",
- )
- else:
- self.subscriptions[string] = (callback, repeating)
-
- def unsubscribe(self, string):
- if not self.browser.loop:
- raise ValueError("You may use this method with a loop in Browser")
- if string not in self.subscriptions:
- raise ValueError(
- "Cannot unsubscribe as string is not present in subscriptions",
- )
- del self.subscriptions[string]
-
- def subscribe_once(self, string):
- if not self.browser.loop:
- raise ValueError("You may use this method with a loop in Browser")
- future = self.browser.loop.create_future()
- if string not in self.subscriptions_futures:
- self.subscriptions_futures[string] = [future]
- else:
- self.subscriptions_futures[string].append(future)
- return future
diff --git a/choreographer/_devtools_protocol_layer/_target.py b/choreographer/_devtools_protocol_layer/_target.py
deleted file mode 100644
index 59392c12..00000000
--- a/choreographer/_devtools_protocol_layer/_target.py
+++ /dev/null
@@ -1,92 +0,0 @@
-import sys
-from collections import OrderedDict
-
-from ._protocol import DevtoolsProtocolError
-from ._session import Session
-
-
-class Target:
- def __init__(self, target_id, browser):
- if not isinstance(target_id, str):
- raise TypeError("target_id must be string")
- # Resources
- self.browser = browser
-
- # States
- self.sessions = OrderedDict()
- self.target_id = target_id
-
- def _add_session(self, session):
- if not isinstance(session, Session):
- raise TypeError("session must be an object of class Session")
- self.sessions[session.session_id] = session
- self.browser.protocol.sessions[session.session_id] = session
-
- def _remove_session(self, session_id):
- if isinstance(session_id, Session):
- session_id = session_id.session_id
- _ = self.sessions.pop(session_id, None)
- _ = self.browser.protocol.sessions.pop(session_id, None)
-
- async def create_session(self):
- if not self.browser.loop:
- raise RuntimeError(
- "There is no eventloop, or was not passed "
- "to browser. Cannot use async methods",
- )
- response = await self.browser.send_command(
- "Target.attachToTarget",
- params={"targetId": self.target_id, "flatten": True},
- )
- if "error" in response:
- raise RuntimeError("Could not create session") from DevtoolsProtocolError(
- response,
- )
- session_id = response["result"]["sessionId"]
- new_session = Session(self.browser, session_id)
- self._add_session(new_session)
- return new_session
-
- async def close_session(self, session_id):
- if not self.browser.loop:
- raise RuntimeError(
- "There is no eventloop, or was not passed to "
- "browser. Cannot use async methods",
- )
- if isinstance(session_id, Session):
- session_id = session_id.session_id
- response = await self.browser.send_command(
- command="Target.detachFromTarget",
- params={"sessionId": session_id},
- )
- self._remove_session(session_id)
- if "error" in response:
- raise RuntimeError("Could not close session") from DevtoolsProtocolError(
- response,
- )
- print(f"The session {session_id} has been closed", file=sys.stderr)
- return response
-
- def send_command(self, command, params=None):
- if not self.sessions.values():
- raise RuntimeError("Cannot send_command without at least one valid session")
- return next(iter(self.sessions.values())).send_command(command, params)
-
- def _get_first_session(self):
- if not self.sessions.values():
- raise RuntimeError(
- "Cannot use this method without at least one valid session",
- )
- return next(iter(self.sessions.values()))
-
- def subscribe(self, string, callback, *, repeating=True):
- session = self._get_first_session()
- session.subscribe(string, callback, repeating=repeating)
-
- def unsubscribe(self, string):
- session = self._get_first_session()
- session.unsubscribe(string)
-
- def subscribe_once(self, string):
- session = self._get_first_session()
- return session.subscribe_once(string)
diff --git a/choreographer/_pipe.py b/choreographer/_pipe.py
deleted file mode 100644
index 1dd6e1e6..00000000
--- a/choreographer/_pipe.py
+++ /dev/null
@@ -1,184 +0,0 @@
-import os
-import platform
-import sys
-import warnings
-from threading import Lock
-
-import simplejson
-
-with_block = bool(sys.version_info[:3] >= (3, 12) or platform.system() != "Windows")
-
-
-class PipeClosedError(IOError):
- pass
-
-
-class BlockWarning(UserWarning):
- pass
-
-
-class MultiEncoder(simplejson.JSONEncoder):
- """Special json encoder for numpy types."""
-
- def default(self, obj):
- if hasattr(obj, "dtype") and obj.dtype.kind == "i" and obj.shape == ():
- return int(obj)
- elif hasattr(obj, "dtype") and obj.dtype.kind == "f" and obj.shape == ():
- return float(obj)
- elif hasattr(obj, "dtype") and obj.shape != ():
- return obj.tolist()
- elif hasattr(obj, "isoformat"):
- return obj.isoformat()
- return simplejson.JSONEncoder.default(self, obj)
-
-
-class Pipe:
- def __init__(self, *, debug=False, json_encoder=MultiEncoder):
- self.read_from_chromium, self.write_from_chromium = list(os.pipe())
- self.read_to_chromium, self.write_to_chromium = list(os.pipe())
- self.debug = debug
- self.json_encoder = json_encoder
-
- # this is just a convenience to prevent multiple shutdowns
- self.shutdown_lock = Lock()
-
- def serialize(self, obj):
- message = simplejson.dumps(
- obj,
- ensure_ascii=False,
- ignore_nan=True,
- cls=self.json_encoder,
- )
- return message.encode("utf-8") + b"\0"
-
- def deserialize(self, message):
- return simplejson.loads(message)
-
- def write_json(self, obj, debug=None):
- if self.shutdown_lock.locked():
- raise PipeClosedError
- if not debug:
- debug = self.debug
- if debug:
- print(f"write_json: {obj}", file=sys.stderr)
- encoded_message = self.serialize(obj)
- if debug:
- print(f"write_json: {encoded_message}", file=sys.stderr)
- try:
- os.write(self.write_to_chromium, encoded_message)
- except OSError as e:
- self.close()
- raise PipeClosedError from e
- if debug:
- print("wrote_json.", file=sys.stderr)
-
- def read_jsons(self, *, blocking=True, debug=None): # noqa: PLR0912, C901 branches, complexity
- if self.shutdown_lock.locked():
- raise PipeClosedError
- if not with_block and not blocking:
- warnings.warn( # noqa: B028
- "Windows python version < 3.12 does not support non-blocking",
- BlockWarning,
- )
- if not debug:
- debug = self.debug
- if debug:
- print(
- f"read_jsons ({'blocking' if blocking else 'not blocking'}):",
- file=sys.stderr,
- )
- jsons = []
- try:
- if with_block:
- os.set_blocking(self.read_from_chromium, blocking)
- except OSError as e:
- self.close()
- raise PipeClosedError from e
- try:
- raw_buffer = None # if we fail in read, we already defined
- raw_buffer = os.read(
- self.read_from_chromium,
- 10000,
- ) # 10MB buffer, nbd, doesn't matter w/ this
- if not raw_buffer or raw_buffer == b"{bye}\n":
- # we seem to need {bye} even if chrome closes NOTE
- if debug:
- print("read_jsons pipe was closed, raising", file=sys.stderr)
- raise PipeClosedError
- while raw_buffer[-1] != 0:
- # still not great, return what you have
- if with_block:
- os.set_blocking(self.read_from_chromium, True)
- raw_buffer += os.read(self.read_from_chromium, 10000)
- except BlockingIOError:
- if debug:
- print("read_jsons: BlockingIOError caught.", file=sys.stderr)
- return jsons
- except OSError as e:
- self.close()
- if debug:
- print(f"caught OSError in read() {e!s}", file=sys.stderr)
- if not raw_buffer or raw_buffer == b"{bye}\n":
- raise PipeClosedError from e
- # this could be hard to test as it is a real OS corner case
- decoded_buffer = raw_buffer.decode("utf-8")
- if debug:
- print(decoded_buffer, file=sys.stderr)
- for raw_message in decoded_buffer.split("\0"):
- if raw_message:
- try:
- jsons.append(self.deserialize(raw_message))
- except simplejson.decoder.JSONDecodeError as e:
- if debug:
- print(
- f"Problem with {raw_message} in json: {e}",
- file=sys.stderr,
- )
- if debug:
- # This debug is kinda late but the jsons package
- # helps with decoding, since JSON optionally
- # allows escaping unicode characters, which chrome does (oof)
- print(f"read_jsons: {jsons[-1]}", file=sys.stderr)
- return jsons
-
- def _unblock_fd(self, fd):
- try:
- if with_block:
- os.set_blocking(fd, False)
- except BaseException as e: # noqa: BLE001 OS errors are not consistent, catch blind
- # also, best effort.
- if self.debug:
- print(f"Expected error unblocking {fd!s}: {e!s}", file=sys.stderr)
-
- def _close_fd(self, fd):
- try:
- os.close(fd)
- except BaseException as e: # noqa: BLE001 OS errors are not consistent, catch blind
- # also, best effort.
- if self.debug:
- print(f"Expected error closing {fd!s}: {e!s}", file=sys.stderr)
-
- def _fake_bye(self):
- self._unblock_fd(self.write_from_chromium)
- try:
- os.write(self.write_from_chromium, b"{bye}\n")
- except BaseException as e: # noqa: BLE001 OS errors are not consistent, catch blind
- # also, best effort.
- if self.debug:
- print(
- f"Caught expected error in self-wrte bye: {e!s}",
- file=sys.stderr,
- )
-
- def close(self):
- if self.shutdown_lock.acquire(blocking=False):
- if platform.system() == "Windows":
- self._fake_bye()
- self._unblock_fd(self.write_from_chromium)
- self._unblock_fd(self.read_from_chromium)
- self._unblock_fd(self.write_to_chromium)
- self._unblock_fd(self.read_to_chromium)
- self._close_fd(self.write_to_chromium) # no more writes
- self._close_fd(self.write_from_chromium) # we're done with writes
- self._close_fd(self.read_from_chromium) # no more attempts at read
- self._close_fd(self.read_to_chromium)
diff --git a/choreographer/_system_utils/__init__.py b/choreographer/_system_utils/__init__.py
deleted file mode 100644
index e69de29b..00000000
diff --git a/choreographer/_system_utils/_chrome_wrapper.py b/choreographer/_system_utils/_chrome_wrapper.py
deleted file mode 100644
index 0dfd5d9d..00000000
--- a/choreographer/_system_utils/_chrome_wrapper.py
+++ /dev/null
@@ -1,118 +0,0 @@
-import os
-
-# importing modules has side effects, so we do this before imports
-
-# not everyone uses the wrapper as a process
-if __name__ == "__main__":
- # chromium reads on 3, writes on 4
- os.dup2(0, 3) # make our stdin their input
- os.dup2(1, 4) # make our stdout their output
-
-import asyncio
-import platform
-import signal
-import subprocess
-import sys
-from functools import partial
-
-_inheritable = True
-
-system = platform.system()
-if system == "Windows":
- import msvcrt
-else:
- os.set_inheritable(4, _inheritable)
- os.set_inheritable(3, _inheritable)
-
-
-def open_browser( # noqa: PLR0913 too many args in func
- to_chromium,
- from_chromium,
- stderr=sys.stderr,
- env=None,
- loop=None,
- *,
- loop_hack=False,
-):
- path = env.get("BROWSER_PATH")
- if not path:
- raise RuntimeError("No browser path was passed to run")
-
- user_data_dir = env["USER_DATA_DIR"]
-
- cli = [
- path,
- "--remote-debugging-pipe",
- "--disable-breakpad",
- "--allow-file-access-from-files",
- "--enable-logging=stderr",
- f"--user-data-dir={user_data_dir}",
- "--no-first-run",
- "--enable-unsafe-swiftshader",
- ]
- if not env.get("GPU_ENABLED", False):
- cli.append("--disable-gpu")
- if not env.get("SANDBOX_ENABLED", False):
- cli.append("--no-sandbox")
-
- if "HEADLESS" in env:
- cli.append("--headless")
-
- system_dependent = {}
- if system == "Windows":
- to_chromium_handle = msvcrt.get_osfhandle(to_chromium)
- os.set_handle_inheritable(to_chromium_handle, _inheritable)
- from_chromium_handle = msvcrt.get_osfhandle(from_chromium)
- os.set_handle_inheritable(from_chromium_handle, _inheritable)
- cli += [
- f"--remote-debugging-io-pipes={to_chromium_handle!s},{from_chromium_handle!s}",
- ]
- system_dependent["creationflags"] = subprocess.CREATE_NEW_PROCESS_GROUP
- system_dependent["close_fds"] = False
- else:
- system_dependent["pass_fds"] = (to_chromium, from_chromium)
-
- if not loop:
- return subprocess.Popen( # noqa: S603 input fine.
- cli,
- stderr=stderr,
- **system_dependent,
- )
- elif loop_hack:
-
- def run():
- return subprocess.Popen( # noqa: S603 input fine.
- cli,
- stderr=stderr,
- **system_dependent,
- )
-
- return asyncio.to_thread(run)
- else:
- return asyncio.create_subprocess_exec(
- cli[0],
- *cli[1:],
- stderr=stderr,
- **system_dependent,
- )
-
-
-def kill_proc(process, _sig_num, _frame):
- process.terminate()
- process.wait(5) # 5 seconds to clean up nicely, it's a lot
- process.kill()
-
-
-if __name__ == "__main__":
- process = open_browser(to_chromium=3, from_chromium=4, env=os.environ)
- kp = partial(kill_proc, process)
- signal.signal(signal.SIGTERM, kp)
- signal.signal(signal.SIGINT, kp)
-
- process.wait()
-
- # not great but it seems that
- # pipe isn't always closed when chrome closes
- # so we pretend to be chrome and send a bye instead
- # also, above depends on async/sync, platform, etc
- print("{bye}")
diff --git a/choreographer/_system_utils/_system.py b/choreographer/_system_utils/_system.py
deleted file mode 100644
index de5f1a04..00000000
--- a/choreographer/_system_utils/_system.py
+++ /dev/null
@@ -1,106 +0,0 @@
-import os
-import platform
-import shutil
-import sys
-
-from choreographer._cli_utils import default_exe_name
-
-chrome = [
- "chrome",
- "Chrome",
- "google-chrome",
- "google-chrome-stable",
- "Chrome.app",
- "Google Chrome",
- "Google Chrome.app",
- "chromium",
- "chromium-browser",
-]
-chromium = ["chromium", "chromium-browser"]
-# firefox = // this needs to be tested
-# brave = // this needs to be tested
-
-system = platform.system()
-
-default_path_chrome = None
-
-if system == "Windows":
- default_path_chrome = [
- r"c:\Program Files\Google\Chrome\Application\chrome.exe",
- f"c:\\Users\\{os.environ.get('USER', 'default')}\\AppData\\"
- "Local\\Google\\Chrome\\Application\\chrome.exe",
- ]
-elif system == "Linux":
- default_path_chrome = [
- "/usr/bin/google-chrome-stable",
- "/usr/bin/google-chrome",
- "/usr/bin/chrome",
- ]
-else: # assume mac, or system == "Darwin"
- default_path_chrome = [
- "/Applications/Google Chrome.app/Contents/MacOS/Google Chrome",
- ]
-
-
-def which_windows_chrome():
- try:
- import re
- import winreg
-
- command = winreg.QueryValueEx(
- winreg.OpenKey(
- winreg.HKEY_CLASSES_ROOT,
- "ChromeHTML\\shell\\open\\command",
- 0,
- winreg.KEY_READ,
- ),
- "",
- )[0]
- exe = re.search('"(.*?)"', command).group(1)
- except BaseException: # noqa: BLE001 don't care why, best effort search
- return None
- return exe
-
-
-def _is_exe(path):
- try:
- return os.access(path, os.X_OK)
- except: # noqa: E722 bare except ok, weird errors, best effort.
- return False
-
-
-def browser_which(executable_name=chrome, *, debug=False, skip_local=False): # noqa: PLR0912, C901
- if debug:
- print(f"Checking {default_exe_name}", file=sys.stderr)
- if not skip_local and default_exe_name.exists():
- if debug:
- print(f"Found {default_exe_name}", file=sys.stderr)
- return default_exe_name
- path = None
- if isinstance(executable_name, str):
- executable_name = [executable_name]
- if platform.system() == "Windows":
- os.environ["NoDefaultCurrentDirectoryInExePath"] = "0" # noqa: SIM112 var name set by windows
- for exe in executable_name:
- if debug:
- print(f"looking for {exe}", file=sys.stderr)
- if platform.system() == "Windows" and exe == "chrome":
- path = which_windows_chrome()
- if path and _is_exe(path):
- return path
- path = shutil.which(exe)
- if debug:
- print(f"looking for {path}", file=sys.stderr)
- if path and _is_exe(path):
- return path
- default_path = []
- if executable_name == chrome:
- default_path = default_path_chrome
- for candidate in default_path:
- if debug:
- print(f"Looking at {candidate}", file=sys.stderr)
- if _is_exe(candidate):
- return candidate
- if debug:
- print("Found nothing...", file=sys.stderr)
- return None
diff --git a/choreographer/_tab.py b/choreographer/_tab.py
deleted file mode 100644
index 7b38db5a..00000000
--- a/choreographer/_tab.py
+++ /dev/null
@@ -1,9 +0,0 @@
-from ._devtools_protocol_layer._target import Target
-
-
-class Tab(Target):
- def __init__(self, target_id, browser):
- super().__init__(target_id, browser)
-
- async def close(self):
- return await self.browser.close_tab(target_id=self.target_id)
diff --git a/choreographer/browser_async.py b/choreographer/browser_async.py
new file mode 100644
index 00000000..8ad95a6b
--- /dev/null
+++ b/choreographer/browser_async.py
@@ -0,0 +1,381 @@
+"""Provides the async api: `Browser`, `Tab`."""
+
+from __future__ import annotations
+
+import asyncio
+import subprocess
+import warnings
+from asyncio import Lock
+from typing import TYPE_CHECKING
+
+import logistro
+
+from choreographer import protocol
+
+from ._brokers import Broker
+from .browsers import BrowserClosedError, BrowserFailedError, Chromium
+from .channels import ChannelClosedError, Pipe
+from .protocol.devtools_async import Session, Target
+from .utils import TmpDirWarning
+from .utils._kill import kill
+
+if TYPE_CHECKING:
+ from collections.abc import Generator, MutableMapping
+ from pathlib import Path
+ from types import TracebackType
+ from typing import Any, Self
+
+ from .browsers._interface_type import BrowserImplInterface
+ from .channels._interface_type import ChannelInterface
+
+_logger = logistro.getLogger(__name__)
+
+
+class Tab(Target):
+ """A wrapper for `Target`, so user can use `Tab`, not `Target`."""
+
+ async def close(self) -> None:
+ """Close the tab."""
+ await self._broker._browser.close_tab(target_id=self.target_id) # noqa: SLF001
+
+
+class Browser(Target):
+ """`Browser` is the async implementation of `Browser`."""
+
+ tabs: MutableMapping[str, Tab]
+ """A mapping by target_id of all the targets which are open tabs."""
+ targets: MutableMapping[str, Target]
+ """A mapping by target_id of ALL the targets."""
+ # Don't init instance attributes with mutables
+ _watch_dog_task: asyncio.Task[Any] | None = None
+
+ def _make_lock(self) -> None:
+ self._open_lock = Lock()
+
+ async def _is_open(self) -> bool:
+ # Did we acquire the lock? If so, return true, we locked open.
+ # If we are open, we did not lock open.
+ # fuck, go through this again
+ if self._open_lock.locked():
+ return True
+ await self._open_lock.acquire()
+ return False
+
+ def _release_lock(self) -> bool:
+ try:
+ if self._open_lock.locked():
+ self._open_lock.release()
+ return True
+ else:
+ return False
+ except RuntimeError:
+ return False
+
+ def __init__(
+ self,
+ path: str | Path | None = None,
+ *,
+ browser_cls: type[BrowserImplInterface] = Chromium,
+ channel_cls: type[ChannelInterface] = Pipe,
+ **kwargs: Any,
+ ) -> None:
+ """
+ Construct a new browser instance.
+
+ Args:
+ path: The path to the browser executable.
+ browser_cls: The type of browser (default: `Chromium`).
+ channel_cls: The type of channel to browser (default: `Pipe`).
+ kwargs: The arguments that the browser_cls takes. For example,
+ headless=True/False, enable_gpu=True/False, etc.
+
+ """
+ _logger.debug("Attempting to open new browser.")
+ self._make_lock()
+ self.tabs = {}
+ self.targets = {}
+
+ self._watchdog_healthy = True
+
+ # Compose Resources
+ self._channel = channel_cls()
+ self._broker = Broker(self, self._channel)
+ self._browser_impl = browser_cls(self._channel, path, **kwargs)
+ # if hasattr(browser_cls, "logger_parser"):
+ # parser = browser_cls.logger_parser # noqa: ERA001
+ # else
+ # parser = Non # noqa: ERA001
+ # self._logger_pipe, _ = logistro.getPipeLogger(
+ # "browser_proc",
+ # parser=parser # noqa: ERA001,
+ # ) # BUG TODO REGRESSION
+ self._logger_pipe = subprocess.DEVNULL
+
+ async def open(self) -> None:
+ """Open the browser."""
+ if await self._is_open():
+ raise RuntimeError("Can't re-open the browser")
+
+ cli = self._browser_impl.get_cli()
+ stderr = self._logger_pipe
+ env = self._browser_impl.get_env()
+ args = self._browser_impl.get_popen_args()
+
+ # asyncio's equiv doesn't work in all situations
+ def run() -> subprocess.Popen[bytes]:
+ return subprocess.Popen( # noqa: S603
+ cli,
+ stderr=stderr,
+ env=env,
+ **args,
+ )
+
+ self.subprocess = await asyncio.to_thread(run)
+
+ super().__init__("0", self._broker)
+ self._add_session(Session("", self._broker))
+
+ try:
+ self._watch_dog_task = asyncio.create_task(self._watchdog())
+ self._broker.run_read_loop()
+ await self.populate_targets()
+ except (BrowserClosedError, BrowserFailedError, asyncio.CancelledError) as e:
+ raise BrowserFailedError(
+ "The browser seemed to close immediately after starting. "
+ "Perhaps adding debug_browser=True will help.",
+ ) from e
+
+ async def __aenter__(self) -> Self:
+ """Open browser as context to launch on entry and close on exit."""
+ await self.open()
+ return self
+
+ # for use with `await Browser()`
+ def __await__(self) -> Generator[Any, Any, Browser]:
+ """If you await the `Browser()`, it will implicitly call `open()`."""
+ return self.__aenter__().__await__()
+
+ async def _is_closed(self, wait: int | None = 0) -> bool:
+ if wait == 0:
+ # poll returns None if its open
+ _is_open = self.subprocess.poll() is None
+ return not _is_open
+ else:
+ try:
+ await asyncio.to_thread(self.subprocess.wait, wait)
+ except subprocess.TimeoutExpired:
+ return False
+ return True
+
+ async def _close(self) -> None:
+ if await self._is_closed():
+ return
+
+ try:
+ await self.send_command("Browser.close")
+ except (BrowserClosedError, BrowserFailedError):
+ return
+ except ChannelClosedError:
+ pass
+
+ await asyncio.to_thread(self._channel.close)
+
+ if await self._is_closed():
+ return
+
+ await asyncio.to_thread(kill, self.subprocess)
+ if await self._is_closed(wait=4):
+ return
+ else:
+ raise RuntimeError("Couldn't close or kill browser subprocess")
+
+ async def close(self) -> None:
+ """Close the browser."""
+ if self._watch_dog_task:
+ _logger.debug("Cancelling watchdog.")
+ self._watch_dog_task.cancel()
+ if not self._release_lock():
+ return
+ try:
+ _logger.info("Trying to close browser.")
+ await self._close()
+ _logger.info("browser._close() called successfully.")
+ except ProcessLookupError:
+ pass
+ self._broker.clean()
+ _logger.info("Broker cleaned up.")
+ # if self._logger_pipe:
+ # os.close(self._logger_pipe) # noqa: ERA001 BUG TODO REGRESSION
+ _logger.info("Logging pipe closed.")
+ self._channel.close()
+ _logger.info("Browser channel closed.")
+ self._browser_impl.clean() # threading this just seems to cause problems
+ _logger.info("Browser implementation cleaned up.")
+
+ async def __aexit__(
+ self,
+ type_: type[BaseException] | None,
+ value: BaseException | None,
+ traceback: TracebackType | None,
+ ) -> None: # None instead of False is fine, eases type checking
+ """Close the browser."""
+ await self.close()
+
+ async def _watchdog(self) -> None:
+ with warnings.catch_warnings():
+ warnings.filterwarnings("ignore", category=TmpDirWarning)
+ _logger.info("Starting watchdog")
+ await asyncio.to_thread(self.subprocess.wait)
+ _logger.warning("Browser is being closed because chrom* closed")
+ self._watch_dog_task = None
+ await self.close()
+ await asyncio.sleep(1)
+ # ignore warnings here because
+ # watchdog killing is last resort
+ # and can leaves stuff in weird state
+ await asyncio.to_thread(self._browser_impl.clean)
+
+ def _add_tab(self, tab: Tab) -> None:
+ if not isinstance(tab, Tab):
+ raise TypeError(f"tab must be an object of {self._tab_type}")
+ self.tabs[tab.target_id] = tab
+
+ def _remove_tab(self, target_id: str) -> None:
+ if isinstance(target_id, Tab):
+ target_id = target_id.target_id
+ del self.tabs[target_id]
+
+ def get_tab(self) -> Tab | None:
+ """
+ Get the first tab if there is one. Useful for default tabs.
+
+ Returns:
+ A tab object.
+
+ """
+ if self.tabs.values():
+ return next(iter(self.tabs.values()))
+ return None
+
+ async def populate_targets(self) -> None:
+ """Solicit the actual browser for all targets to add to the browser object."""
+ if await self._is_closed():
+ raise BrowserClosedError("populate_targets() called on a closed browser")
+ response = await self.send_command("Target.getTargets")
+ if "error" in response:
+ raise RuntimeError("Could not get targets") from Exception(
+ response["error"],
+ )
+
+ for json_response in response["result"]["targetInfos"]:
+ if (
+ json_response["type"] == "page"
+ and json_response["targetId"] not in self.tabs
+ ):
+ target_id = json_response["targetId"]
+ new_tab = Tab(target_id, self._broker)
+ try:
+ await new_tab.create_session()
+ except protocol.DevtoolsProtocolError as e:
+ if e.code == protocol.Ecode.TARGET_NOT_FOUND:
+ _logger.warning(
+ f"Target {target_id} not found " "(could be closed before)",
+ )
+ continue
+ else:
+ raise
+ self._add_tab(new_tab)
+ _logger.debug(f"The target {target_id} was added")
+
+ async def create_session(self) -> Session:
+ """
+ Create a browser session. Only in supported browsers, is experimental.
+
+ Returns:
+ A session object.
+
+ """
+ if await self._is_closed():
+ raise BrowserClosedError("create_session() called on a closed browser")
+ warnings.warn( # noqa: B028
+ "Creating new sessions on Browser() only works with some "
+ "versions of Chrome, it is experimental.",
+ protocol.ExperimentalFeatureWarning,
+ )
+ response = await self.send_command("Target.attachToBrowserTarget")
+ if "error" in response:
+ raise RuntimeError(
+ "Could not create session",
+ ) from protocol.DevtoolsProtocolError(
+ response,
+ )
+ session_id = response["result"]["sessionId"]
+ new_session = Session(session_id, self._broker)
+ self._add_session(new_session)
+ return new_session
+
+ async def create_tab(
+ self,
+ url: str = "",
+ width: int | None = None,
+ height: int | None = None,
+ ) -> Tab:
+ """
+ Create a new tab.
+
+ Args:
+ url: the url to navigate to, default ""
+ width: the width of the tab (headless only)
+ height: the height of the tab (headless only)
+
+ Returns:
+ a tab.
+
+ """
+ if await self._is_closed():
+ raise BrowserClosedError("create_tab() called on a closed browser.")
+ params: MutableMapping[str, Any] = {"url": url}
+ if width:
+ params["width"] = width
+ if height:
+ params["height"] = height
+
+ response = await self.send_command("Target.createTarget", params=params)
+ if "error" in response:
+ raise RuntimeError(
+ "Could not create tab",
+ ) from protocol.DevtoolsProtocolError(
+ response,
+ )
+ target_id = response["result"]["targetId"]
+ new_tab = Tab(target_id, self._broker)
+ self._add_tab(new_tab)
+ await new_tab.create_session()
+ return new_tab
+
+ async def close_tab(self, target_id: str) -> protocol.BrowserResponse:
+ """
+ Close a tab by its id.
+
+ Args:
+ target_id: the targetId of the tab to close.
+
+ """
+ if await self._is_closed():
+ raise BrowserClosedError("close_tab() called on a closed browser")
+ if isinstance(target_id, Target):
+ target_id = target_id.target_id
+ # NOTE: we don't need to manually remove sessions because
+ # sessions are intrinsically handled by events
+ response = await self.send_command(
+ command="Target.closeTarget",
+ params={"targetId": target_id},
+ )
+ self._remove_tab(target_id)
+ if "error" in response:
+ raise RuntimeError(
+ "Could not close tab",
+ ) from protocol.DevtoolsProtocolError(
+ response,
+ )
+ return response
diff --git a/choreographer/browser_sync.py b/choreographer/browser_sync.py
new file mode 100644
index 00000000..47a7fe0e
--- /dev/null
+++ b/choreographer/browser_sync.py
@@ -0,0 +1,202 @@
+"""Provides the sync api: `BrowserSync`, `TabSync`."""
+
+from __future__ import annotations
+
+import subprocess
+from threading import Lock
+from typing import TYPE_CHECKING
+
+import logistro
+
+from ._brokers import BrokerSync
+from .browsers import BrowserClosedError, BrowserFailedError, Chromium
+from .channels import ChannelClosedError, Pipe
+from .protocol.devtools_sync import SessionSync, TargetSync
+from .utils._kill import kill
+
+if TYPE_CHECKING:
+ from collections.abc import MutableMapping
+ from pathlib import Path
+ from types import TracebackType
+ from typing import Any, Self
+
+ from .browsers._interface_type import BrowserImplInterface
+ from .channels._interface_type import ChannelInterface
+
+_logger = logistro.getLogger(__name__)
+
+
+class TabSync(TargetSync):
+ """A wrapper for `TargetSync`, so user can use `TabSync`, not `TargetSync`."""
+
+
+class BrowserSync(TargetSync):
+ """`BrowserSync` is the sync implementation of `Browser`."""
+
+ # A list of the types that are essential to use
+ # with this class
+
+ tabs: MutableMapping[str, TabSync]
+ """A mapping by target_id of all the targets which are open tabs."""
+ targets: MutableMapping[str, TargetSync]
+ """A mapping by target_id of ALL the targets."""
+ # Don't init instance attributes with mutables
+
+ def _make_lock(self) -> None:
+ self._open_lock = Lock()
+
+ def _is_open(self) -> bool:
+ return not self._open_lock.acquire(blocking=False)
+
+ def _release_lock(self) -> bool:
+ try:
+ if self._open_lock.locked():
+ self._open_lock.release()
+ return True
+ else:
+ return False
+ except RuntimeError:
+ return False
+
+ def __init__(
+ self,
+ path: str | Path | None = None,
+ *,
+ browser_cls: type[BrowserImplInterface] = Chromium,
+ channel_cls: type[ChannelInterface] = Pipe,
+ **kwargs: Any,
+ ) -> None:
+ """
+ Construct a new browser instance.
+
+ Args:
+ path: The path to the browser executable.
+ browser_cls: The type of browser (default: `Chromium`).
+ channel_cls: The type of channel to browser (default: `Pipe`).
+ kwargs: The arguments that the browser_cls takes. For example,
+ headless=True/False, enable_gpu=True/False, etc.
+
+ """
+ _logger.debug("Attempting to open new browser.")
+ self._make_lock()
+ self.tabs = {}
+ self.targets = {}
+
+ # Compose Resources
+ self._channel = channel_cls()
+ self._broker = BrokerSync(self, self._channel)
+ self._browser_impl = browser_cls(self._channel, path, **kwargs)
+ # if hasattr(browser_cls, "logger_parser"):
+ # parser = browser_cls.logger_parser # noqa: ERA001
+ # else: # noqa: ERA001
+ # parser = None # noqa: ERA001
+ # self._logger_pipe, _ = logistro.getPipeLogger(
+ # "browser_proc",
+ # parser=parser, # noqa: ERA001
+ # ) # BUG TODO REGRESSION
+ self._logger_pipe = subprocess.DEVNULL
+
+ def open(self) -> None:
+ """Open the browser."""
+ if self._is_open():
+ raise RuntimeError("Can't re-open the browser")
+ self.subprocess = subprocess.Popen( # noqa: S603
+ self._browser_impl.get_cli(),
+ stderr=self._logger_pipe,
+ env=self._browser_impl.get_env(),
+ **self._browser_impl.get_popen_args(),
+ )
+ super().__init__("0", self._broker)
+ self._add_session(SessionSync("", self._broker))
+
+ def __enter__(self) -> Self:
+ """Open browser as context to launch on entry and close on exit."""
+ self.open()
+ return self
+
+ def _is_closed(self, wait: int | None = 0) -> bool:
+ if wait == 0:
+ return self.subprocess.poll() is None
+ else:
+ try:
+ self.subprocess.wait(wait)
+ except subprocess.TimeoutExpired:
+ return False
+ return True
+
+ def _close(self) -> None:
+ if self._is_closed():
+ return
+
+ try:
+ self.send_command("Browser.close")
+ except (BrowserClosedError, BrowserFailedError):
+ return
+ except ChannelClosedError:
+ pass
+
+ self._channel.close()
+ if self._is_closed():
+ return
+
+ # try kiling
+ kill(self.subprocess)
+ if self._is_closed(wait=4):
+ return
+ else:
+ raise RuntimeError("Couldn't close or kill browser subprocess")
+
+ def close(self) -> None:
+ """Close the browser."""
+ self._broker.clean()
+ _logger.info("Broker cleaned up.")
+ if not self._release_lock():
+ return
+ try:
+ _logger.info("Trying to close browser.")
+ self._close()
+ _logger.info("browser._close() called successfully.")
+ except ProcessLookupError:
+ pass
+ # os.close(self._logger_pipe) # noqa: ERA001 bug regression
+ _logger.info("Logging pipe closed.")
+ self._channel.close()
+ _logger.info("Browser channel closed.")
+ self._browser_impl.clean()
+ _logger.info("Browser implementation cleaned up.")
+
+ def __exit__(
+ self,
+ type_: type[BaseException] | None,
+ value: BaseException | None,
+ traceback: TracebackType | None,
+ ) -> None: # None instead of False is fine, eases type checking
+ """Close the browser."""
+ self.close()
+
+ def _add_tab(self, tab: TabSync) -> None:
+ if not isinstance(tab, TabSync):
+ raise TypeError("tab must be an object of TabSync")
+ self.tabs[tab.target_id] = tab
+
+ def _remove_tab(self, target_id: str) -> None:
+ if isinstance(target_id, TabSync):
+ target_id = target_id.target_id
+ del self.tabs[target_id]
+
+ def get_tab(self) -> TabSync | None:
+ """Get the first tab if there is one. Useful for default tabs."""
+ if self.tabs.values():
+ return next(iter(self.tabs.values()))
+ return None
+
+ # wrap our broker for convenience
+ def start_output_thread(self, **kwargs: Any) -> None:
+ """
+ Start a separate thread that dumps all messages received to stdout.
+
+ Args:
+ kwargs: passed directly to print().
+
+ """
+ self._broker.run_output_thread(**kwargs)
diff --git a/choreographer/browsers/__init__.py b/choreographer/browsers/__init__.py
new file mode 100644
index 00000000..f0537931
--- /dev/null
+++ b/choreographer/browsers/__init__.py
@@ -0,0 +1,10 @@
+"""Contains implementations of browsers that choreographer can open."""
+
+from ._errors import BrowserClosedError, BrowserFailedError
+from .chromium import Chromium
+
+__all__ = [
+ "BrowserClosedError",
+ "BrowserFailedError",
+ "Chromium",
+]
diff --git a/choreographer/browsers/_chrome_constants.py b/choreographer/browsers/_chrome_constants.py
new file mode 100644
index 00000000..60799d19
--- /dev/null
+++ b/choreographer/browsers/_chrome_constants.py
@@ -0,0 +1,33 @@
+import os
+import platform
+
+chromium_names = ["chromium", "chromium-browser"]
+
+chrome_names = [
+ "chrome",
+ "Chrome",
+ "google-chrome",
+ "google-chrome-stable",
+ "Chrome.app",
+ "Google Chrome",
+ "Google Chrome.app",
+]
+chrome_names.extend(chromium_names)
+
+typical_chrome_paths = None
+if platform.system() == "Windows":
+ typical_chrome_paths = [
+ r"c:\Program Files\Google\Chrome\Application\chrome.exe",
+ f"c:\\Users\\{os.environ.get('USER', 'default')}\\AppData\\"
+ "Local\\Google\\Chrome\\Application\\chrome.exe",
+ ]
+elif platform.system() == "Linux":
+ typical_chrome_paths = [
+ "/usr/bin/google-chrome-stable",
+ "/usr/bin/google-chrome",
+ "/usr/bin/chrome",
+ ]
+else: # assume mac, or system == "Darwin"
+ typical_chrome_paths = [
+ "/Applications/Google Chrome.app/Contents/MacOS/Google Chrome",
+ ]
diff --git a/choreographer/browsers/_errors.py b/choreographer/browsers/_errors.py
new file mode 100644
index 00000000..5a983f8a
--- /dev/null
+++ b/choreographer/browsers/_errors.py
@@ -0,0 +1,6 @@
+class BrowserFailedError(RuntimeError):
+ """An error for when the browser fails to launch."""
+
+
+class BrowserClosedError(RuntimeError):
+ """An error for when the browser is closed accidently (during access)."""
diff --git a/choreographer/browsers/_interface_type.py b/choreographer/browsers/_interface_type.py
new file mode 100644
index 00000000..f38d007a
--- /dev/null
+++ b/choreographer/browsers/_interface_type.py
@@ -0,0 +1,28 @@
+"""Provides the basic protocol class (the abstract base) for a protocol."""
+
+from __future__ import annotations
+
+from typing import TYPE_CHECKING, Protocol
+
+if TYPE_CHECKING:
+ from collections.abc import Mapping, MutableMapping, Sequence
+ from pathlib import Path
+ from typing import Any
+
+ from choreographer.channels._interface_type import ChannelInterface
+
+
+class BrowserImplInterface(Protocol):
+ """Defines the basic interface of a channel."""
+
+ # I guess we need to include __init__?
+ def __init__(
+ self,
+ channel: ChannelInterface,
+ path: Path | str | None = None,
+ **kwargs: Any,
+ ) -> None: ...
+ def get_popen_args(self) -> Mapping[str, Any]: ...
+ def get_cli(self) -> Sequence[str]: ...
+ def get_env(self) -> MutableMapping[str, str]: ...
+ def clean(self) -> None: ...
diff --git a/choreographer/browsers/_unix_pipe_chromium_wrapper.py b/choreographer/browsers/_unix_pipe_chromium_wrapper.py
new file mode 100644
index 00000000..9a79a6b3
--- /dev/null
+++ b/choreographer/browsers/_unix_pipe_chromium_wrapper.py
@@ -0,0 +1,59 @@
+"""
+_unix_pipe_chromium_wrapper.py provides proper fds to chrome.
+
+By running chromium in a new process (this wrapper), we guarantee
+the user hasn't stolen one of our desired file descriptors, which
+the OS gives away first-come-first-serve everytime someone opens a
+file. chromium demands we use 3 and 4.
+"""
+
+from __future__ import annotations
+
+import os
+
+# importing modules has side effects, so we do this before imports
+# ruff: noqa: E402
+
+# chromium reads on 3, writes on 4
+os.dup2(0, 3) # make our stdin their input
+os.dup2(1, 4) # make our stdout their output
+
+_inheritable = True
+os.set_inheritable(4, _inheritable)
+os.set_inheritable(3, _inheritable)
+
+import signal
+import subprocess
+import sys
+from functools import partial
+from typing import TYPE_CHECKING
+
+if TYPE_CHECKING:
+ from types import FrameType
+
+# we're a wrapper, the cli is everything that came after us
+cli = sys.argv[1:]
+process = subprocess.Popen(cli, pass_fds=(3, 4)) # noqa: S603 untrusted input
+
+
+def kill_proc(
+ process: subprocess.Popen[bytes],
+ _sig_num: int,
+ _frame: FrameType | None,
+) -> None:
+ process.terminate()
+ process.wait(5) # 5 seconds to clean up nicely, it's a lot
+ process.kill()
+
+
+kp = partial(kill_proc, process)
+signal.signal(signal.SIGTERM, kp)
+signal.signal(signal.SIGINT, kp)
+
+process.wait()
+
+# not great but it seems that
+# pipe isn't always closed when chrome closes
+# so we pretend to be chrome and send a bye instead
+# also, above depends on async/sync, platform, etc
+print("{bye}") # noqa: T201 we need print here
diff --git a/choreographer/browsers/chromium.py b/choreographer/browsers/chromium.py
new file mode 100644
index 00000000..c58ba2dd
--- /dev/null
+++ b/choreographer/browsers/chromium.py
@@ -0,0 +1,221 @@
+"""Provides a class proving tools for running chromium browsers."""
+
+from __future__ import annotations
+
+import os
+import platform
+import re
+import subprocess
+import sys
+from pathlib import Path
+from typing import TYPE_CHECKING
+
+import logistro
+
+if platform.system() == "Windows":
+ import msvcrt
+
+from choreographer.channels import Pipe
+from choreographer.utils import TmpDirectory, get_browser_path
+
+from ._chrome_constants import chrome_names, typical_chrome_paths
+
+if TYPE_CHECKING:
+ import logging
+ from collections.abc import Mapping, MutableMapping, Sequence
+ from typing import Any
+
+ from choreographer.channels._interface_type import ChannelInterface
+
+_chromium_wrapper_path = (
+ Path(__file__).resolve().parent / "_unix_pipe_chromium_wrapper.py"
+)
+
+_logger = logistro.getLogger(__name__)
+
+
+def _is_exe(path: str | Path) -> bool:
+ try:
+ return os.access(path, os.X_OK)
+ except: # noqa: E722 bare except ok, weird errors, best effort.
+ return False
+
+
+_logs_parser_regex = re.compile(r"\d*:\d*:\d*\/\d*\.\d*:")
+
+
+class Chromium:
+ """
+ Chromium represents an implementation of the chromium browser.
+
+ It also includes chromium-like browsers (chrome, edge, and brave).
+ """
+
+ path: str | Path | None
+ """The path to the chromium executable."""
+ gpu_enabled: bool
+ """True if we should use the gpu. False by default for compatibility."""
+ headless: bool
+ """True if we should not show the browser, true by default."""
+ sandbox_enabled: bool
+ """True to enable the sandbox. False by default."""
+ skip_local: bool
+ """True if we want to avoid looking for our local download when searching path."""
+ tmp_dir: TmpDirectory
+ """A reference to a temporary directory object the chromium needs to store data."""
+
+ @classmethod
+ def logger_parser(
+ cls,
+ record: logging.LogRecord,
+ _old: MutableMapping[str, Any],
+ ) -> bool:
+ """
+ Parse (via `logging.Filter.parse()`) data from browser stderr for logging.
+
+ Args:
+ record: the `logging.LogRecord` object to read/modify
+ _old: data that was already stripped out.
+
+ """
+ record.msg = _logs_parser_regex.sub("", record.msg)
+ # we just eliminate their stamp, we dont' extract it
+ return True
+
+ def __init__(
+ self,
+ channel: ChannelInterface,
+ path: Path | str | None = None,
+ **kwargs: Any,
+ ) -> None:
+ """
+ Construct a chromium browser implementation.
+
+ Args:
+ channel: the `choreographer.Channel` we'll be using (WebSockets? Pipe?)
+ path: path to the browser
+ kwargs:
+ gpu_enabled (default False): Turn on GPU? Doesn't work in all envs.
+ headless (default True): Actually launch a browser?
+ sandbox_enabled (default False): Enable sandbox-
+ a persnickety thing depending on environment, OS, user, etc
+ tmp_dir (default None): Manually set the temporary directory
+
+ Raises:
+ RuntimeError: Too many kwargs, or browser not found.
+ NotImplementedError: Pipe is the only channel type it'll accept right now.
+
+ """
+ self.path = path
+ self.gpu_enabled = kwargs.pop("enable_gpu", False)
+ self.headless = kwargs.pop("headless", True)
+ self.sandbox_enabled = kwargs.pop("enable_sandbox", False)
+ self._tmp_dir_path = kwargs.pop("tmp_dir", None)
+ if kwargs:
+ raise RuntimeError(
+ "Chromium.get_cli() received " f"invalid args: {kwargs.keys()}",
+ )
+ self.skip_local = bool(
+ "ubuntu" in platform.version().lower() and self.sandbox_enabled,
+ )
+ if self.skip_local:
+ _logger.warning("Ubuntu + Sandbox won't work unless chrome from snap")
+
+ if not self.path:
+ self.path = get_browser_path(
+ executable_names=chrome_names,
+ skip_local=self.skip_local,
+ )
+ if not self.path and typical_chrome_paths:
+ # do typical chrome paths
+ for candidate in typical_chrome_paths:
+ if _is_exe(candidate):
+ self.path = candidate
+ break
+ if not self.path:
+ raise RuntimeError(
+ "Browser not found. You can use get_chrome(), "
+ "please see documentation.",
+ )
+ _logger.debug(f"Found path: {self.path}")
+ self._channel = channel
+ if not isinstance(channel, Pipe):
+ raise NotImplementedError("Websocket style channels not implemented yet.")
+
+ self.tmp_dir = TmpDirectory(
+ path=self._tmp_dir_path,
+ sneak="snap" in str(self.path),
+ )
+ _logger.info(f"Temporary directory at: {self.tmp_dir.path}")
+
+ def get_popen_args(self) -> Mapping[str, Any]:
+ """Return the args needed to runc chromium with `subprocess.Popen()`."""
+ args = {}
+ # need to check pipe
+ if platform.system() == "Windows":
+ args["creationflags"] = subprocess.CREATE_NEW_PROCESS_GROUP # type: ignore [attr-defined]
+ args["close_fds"] = False
+ else:
+ args["close_fds"] = True
+ if isinstance(self._channel, Pipe):
+ args["stdin"] = self._channel.from_choreo_to_external
+ args["stdout"] = self._channel.from_external_to_choreo
+ _logger.debug(f"Returning args: {args}")
+ return args
+
+ def get_cli(self) -> Sequence[str]:
+ """Return the CLI command for chromium."""
+ if platform.system() != "Windows":
+ cli = [
+ str(sys.executable),
+ str(_chromium_wrapper_path),
+ str(self.path),
+ ]
+ else:
+ cli = [
+ str(self.path),
+ ]
+
+ cli.extend(
+ [
+ "--disable-breakpad",
+ "--allow-file-access-from-files",
+ "--enable-logging=stderr",
+ f"--user-data-dir={self.tmp_dir.path}",
+ "--no-first-run",
+ "--enable-unsafe-swiftshader",
+ ],
+ )
+ if not self.gpu_enabled:
+ cli.append("--disable-gpu")
+ if self.headless:
+ cli.append("--headless")
+ if not self.sandbox_enabled:
+ cli.append("--no-sandbox")
+
+ if isinstance(self._channel, Pipe):
+ cli.append("--remote-debugging-pipe")
+ if platform.system() == "Windows":
+ w_handle = msvcrt.get_osfhandle(self._channel.from_choreo_to_external) # type: ignore [attr-defined]
+ r_handle = msvcrt.get_osfhandle(self._channel.from_external_to_choreo) # type: ignore [attr-defined]
+ _inheritable = True
+ os.set_handle_inheritable(w_handle, _inheritable) # type: ignore [attr-defined]
+ os.set_handle_inheritable(r_handle, _inheritable) # type: ignore [attr-defined]
+ cli += [
+ f"--remote-debugging-io-pipes={r_handle!s},{w_handle!s}",
+ ]
+ _logger.debug(f"Returning cli: {cli}")
+ return cli
+
+ def get_env(self) -> MutableMapping[str, str]:
+ """Return the env needed for chromium."""
+ _logger.debug("Returning env: same env, no modification.")
+ return os.environ.copy()
+
+ def clean(self) -> None:
+ """Clean up any leftovers form browser, like tmp files."""
+ self.tmp_dir.clean()
+
+ def __del__(self) -> None:
+ """Delete the temporary file and run `clean()`."""
+ self.clean()
diff --git a/choreographer/channels/README.txt b/choreographer/channels/README.txt
new file mode 100644
index 00000000..60174ed5
--- /dev/null
+++ b/choreographer/channels/README.txt
@@ -0,0 +1,17 @@
+Browsers often accept two communication channels: websockets and pipes.
+
+Both classes we implement will support `write_jsons()` and `read_jsons()`
+with the same interface (as well as `__init__()` and `close()`).
+
+But the browser implementation in _browsers/ will have to get specific
+information from the pipe/websocket in order to properly build the CLI
+command for the browser.
+
+For example, the CLI command needs to know the file numbers (file descriptors)
+for reading writing if using `Pipe()`, so `Pipe()` has the attributes:
+`.from_external_to_choreo` and `.from_choreo_to_external`. They're part of
+the interface as well.
+
+In the same vein, when websockets in implemented, the CLI command will
+need to know the port it's on. There may need to be a `open()` function for
+after the CLI command is run.
diff --git a/choreographer/channels/__init__.py b/choreographer/channels/__init__.py
new file mode 100644
index 00000000..6e0f0bbe
--- /dev/null
+++ b/choreographer/channels/__init__.py
@@ -0,0 +1,16 @@
+"""
+Channels are classes that choreo and the browser use to communicate.
+
+This is a low-level part of the API.
+
+"""
+
+from ._errors import BlockWarning, ChannelClosedError, JSONError
+from .pipe import Pipe
+
+__all__ = [
+ "BlockWarning",
+ "ChannelClosedError",
+ "JSONError",
+ "Pipe",
+]
diff --git a/choreographer/channels/_errors.py b/choreographer/channels/_errors.py
new file mode 100644
index 00000000..55f17a92
--- /dev/null
+++ b/choreographer/channels/_errors.py
@@ -0,0 +1,10 @@
+class BlockWarning(UserWarning):
+ """A warning for when block modification operatins used on incompatible OS."""
+
+
+class ChannelClosedError(IOError):
+ """An error to throw when the channel has closed from either end or error."""
+
+
+class JSONError(RuntimeError):
+ """Another JSONError."""
diff --git a/choreographer/channels/_interface_type.py b/choreographer/channels/_interface_type.py
new file mode 100644
index 00000000..760d9730
--- /dev/null
+++ b/choreographer/channels/_interface_type.py
@@ -0,0 +1,37 @@
+"""Provides the basic protocol class (the abstract interface) for a channel."""
+
+from __future__ import annotations
+
+from typing import TYPE_CHECKING, Protocol
+
+if TYPE_CHECKING:
+ from collections.abc import Mapping, Sequence
+ from typing import Any
+
+ from choreographer.protocol import BrowserResponse
+
+
+class ChannelInterface(Protocol):
+ """Defines the basic interface of a channel."""
+
+ # Not sure I like the obj type
+ def write_json(self, obj: Mapping[str, Any]) -> None:
+ """
+ Accept an object and send it doesnt the channel serialized.
+
+ Args:
+ obj: the object to send to the browser.
+
+ """
+
+ def read_jsons(self, *, blocking: bool = True) -> Sequence[BrowserResponse]:
+ """
+ Read all available jsons in the channel and returns a list of complete ones.
+
+ Args:
+ blocking: should this method block on read or return immediately.
+
+ """
+
+ def close(self) -> None:
+ """Close the channel."""
diff --git a/choreographer/channels/_wire.py b/choreographer/channels/_wire.py
new file mode 100644
index 00000000..36af9367
--- /dev/null
+++ b/choreographer/channels/_wire.py
@@ -0,0 +1,50 @@
+from __future__ import annotations
+
+from typing import TYPE_CHECKING
+
+import logistro
+import simplejson
+from simplejson.errors import JSONDecodeError
+
+from ._errors import JSONError
+
+if TYPE_CHECKING:
+ from typing import Any
+
+_logger = logistro.getLogger(__name__)
+
+
+class MultiEncoder(simplejson.JSONEncoder):
+ """Special json encoder for numpy types."""
+
+ def default(self, obj: Any) -> Any:
+ if hasattr(obj, "dtype") and obj.dtype.kind == "i" and obj.shape == ():
+ return int(obj)
+ elif hasattr(obj, "dtype") and obj.dtype.kind == "f" and obj.shape == ():
+ return float(obj)
+ elif hasattr(obj, "dtype") and obj.shape != ():
+ return obj.tolist()
+ elif hasattr(obj, "isoformat"):
+ return obj.isoformat()
+ return simplejson.JSONEncoder.default(self, obj)
+
+
+def serialize(obj: Any) -> bytes:
+ try:
+ message = simplejson.dumps(
+ obj,
+ ensure_ascii=False,
+ ignore_nan=True,
+ cls=MultiEncoder,
+ )
+ except JSONDecodeError as e:
+ raise JSONError from e
+ _logger.debug2(f"Serialized: {message}")
+ return message.encode("utf-8")
+
+
+def deserialize(message: str) -> Any:
+ try:
+ return simplejson.loads(message)
+ except simplejson.errors.JSONDecodeError as e:
+ raise JSONError from e
diff --git a/choreographer/channels/pipe.py b/choreographer/channels/pipe.py
new file mode 100644
index 00000000..a3d67118
--- /dev/null
+++ b/choreographer/channels/pipe.py
@@ -0,0 +1,170 @@
+"""Provides a channel based on operating system file pipes."""
+
+from __future__ import annotations
+
+import os
+import platform
+import sys
+import warnings
+from threading import Lock
+from typing import TYPE_CHECKING
+
+import logistro
+
+from . import _wire as wire
+from ._errors import BlockWarning, ChannelClosedError, JSONError
+
+if TYPE_CHECKING:
+ from collections.abc import Mapping, Sequence
+ from typing import Any
+
+ from choreographer.protocol import BrowserResponse
+
+_with_block = bool(sys.version_info[:3] >= (3, 12) or platform.system() != "Windows")
+
+_logger = logistro.getLogger(__name__)
+
+
+# if we're a pipe we expect these public attributes
+class Pipe:
+ """Defines an operating system pipe."""
+
+ from_external_to_choreo: int
+ """Consumers need this, it is the channel the browser uses to talk to choreo."""
+ from_choreo_to_external: int
+ """Consumers needs this, it is the channel choreo writes to the browser on."""
+ shutdown_lock: Lock
+ """Once this is locked, the pipe is closed and can't be reopened."""
+
+ def __init__(self) -> None:
+ """Construct a pipe using os functions."""
+ # This is where pipe listens (from browser)
+ # So pass the write to browser
+ self._read_from_browser, self._write_from_browser = list(os.pipe())
+
+ # This is where pipe writes (to browser)
+ # So pass the read to browser
+ self._read_to_browser, self._write_to_browser = list(os.pipe())
+
+ # Popen will write stdout of wrapper to this (dupping 4)
+ # Browser will write directly to this if not using wrapper
+ self.from_external_to_choreo = self._write_from_browser
+ # Popen will read this into stdin of wrapper (dupping 3)
+ # Browser will read directly from this if not using wrapper
+ # which dupes stdin to expected fd (4?)
+ self.from_choreo_to_external = self._read_to_browser
+ # These won't be used on windows directly, they'll be t-formed to
+ # windows-style handles. But let another layer handle that.
+
+ # this is just a convenience to prevent multiple shutdowns
+ self.shutdown_lock = Lock() # should be private
+
+ def write_json(self, obj: Mapping[str, Any]) -> None:
+ """
+ Send one json down the pipe.
+
+ Args:
+ obj: any python object that serializes to json.
+
+ """
+ if self.shutdown_lock.locked():
+ raise ChannelClosedError
+ encoded_message = wire.serialize(obj) + b"\0"
+ try:
+ os.write(self._write_to_browser, encoded_message)
+ except OSError as e:
+ self.close()
+ raise ChannelClosedError from e
+
+ def read_jsons( # noqa: PLR0912, C901 branches, complexity
+ self,
+ *,
+ blocking: bool = True,
+ ) -> Sequence[BrowserResponse]:
+ """
+ Read from the pipe and return one or more jsons in a list.
+
+ Args:
+ blocking: The read option can be set to block or not.
+
+ Returns:
+ A list of jsons.
+
+ """
+ if self.shutdown_lock.locked():
+ raise ChannelClosedError
+ if not _with_block and not blocking:
+ warnings.warn( # noqa: B028
+ "Windows python version < 3.12 does not support non-blocking",
+ BlockWarning,
+ )
+ jsons: list[BrowserResponse] = []
+ try:
+ if _with_block:
+ os.set_blocking(self._read_from_browser, blocking)
+ except OSError as e:
+ self.close()
+ raise ChannelClosedError from e
+ try:
+ raw_buffer = None # if we fail in read, we already defined
+ raw_buffer = os.read(
+ self._read_from_browser,
+ 10000,
+ ) # 10MB buffer, nbd, doesn't matter w/ this
+ if not raw_buffer or raw_buffer == b"{bye}\n":
+ # we seem to need {bye} even if chrome closes NOTE
+ raise ChannelClosedError
+ while raw_buffer[-1] != 0:
+ # still not great, return what you have
+ if _with_block:
+ os.set_blocking(self._read_from_browser, True)
+ raw_buffer += os.read(self._read_from_browser, 10000)
+ except BlockingIOError:
+ return jsons
+ except OSError as e:
+ self.close()
+ if not raw_buffer or raw_buffer == b"{bye}\n":
+ raise ChannelClosedError from e
+ # this could be hard to test as it is a real OS corner case
+ decoded_buffer = raw_buffer.decode("utf-8")
+ for raw_message in decoded_buffer.split("\0"):
+ if raw_message:
+ try:
+ jsons.append(wire.deserialize(raw_message))
+ except JSONError:
+ _logger.exception("JSONError decoding message.")
+ return jsons
+
+ def _unblock_fd(self, fd: int) -> None:
+ try:
+ if _with_block:
+ os.set_blocking(fd, False)
+ except BaseException: # noqa: BLE001, S110 OS errors are not consistent, catch blind + pass
+ pass
+
+ def _close_fd(self, fd: int) -> None:
+ try:
+ os.close(fd)
+ except BaseException: # noqa: BLE001, S110 OS errors are not consistent, catch blind + pass
+ pass
+
+ def _fake_bye(self) -> None:
+ self._unblock_fd(self._write_from_browser)
+ try:
+ os.write(self._write_from_browser, b"{bye}\n")
+ except BaseException: # noqa: BLE001, S110 OS errors are not consistent, catch blind + pass
+ pass
+
+ def close(self) -> None:
+ """Close the pipe."""
+ if self.shutdown_lock.acquire(blocking=False):
+ if platform.system() == "Windows":
+ self._fake_bye()
+ self._unblock_fd(self._write_from_browser)
+ self._unblock_fd(self._read_from_browser)
+ self._unblock_fd(self._write_to_browser)
+ self._unblock_fd(self._read_to_browser)
+ self._close_fd(self._write_to_browser) # no more writes
+ self._close_fd(self._write_from_browser) # we're done with writes
+ self._close_fd(self._read_from_browser) # no more attempts at read
+ self._close_fd(self._read_to_browser)
diff --git a/choreographer/cli/__init__.py b/choreographer/cli/__init__.py
new file mode 100644
index 00000000..0f9fc682
--- /dev/null
+++ b/choreographer/cli/__init__.py
@@ -0,0 +1,11 @@
+"""cli provides some tools that are used on the commandline (and to download chrome)."""
+
+from ._cli_utils import (
+ get_chrome,
+ get_chrome_sync,
+)
+
+__all__ = [
+ "get_chrome",
+ "get_chrome_sync",
+]
diff --git a/choreographer/cli/_cli_utils.py b/choreographer/cli/_cli_utils.py
new file mode 100644
index 00000000..679ac49d
--- /dev/null
+++ b/choreographer/cli/_cli_utils.py
@@ -0,0 +1,180 @@
+from __future__ import annotations
+
+import argparse
+import asyncio
+import json
+import platform
+import shutil
+import sys
+import urllib.request
+import warnings
+import zipfile
+from pathlib import Path
+
+# SOON TODO this isn't the right download path, look at uv, use sysconfig
+_default_download_path = Path(__file__).resolve().parent / "browser_exe"
+
+_chrome_for_testing_url = "https://googlechromelabs.github.io/chrome-for-testing/known-good-versions-with-downloads.json"
+
+_platforms = ["linux64", "win32", "win64", "mac-x64", "mac-arm64"]
+
+_arch_size_detected = "64" if sys.maxsize > 2**32 else "32"
+_arch_detected = "arm" if platform.processor() == "arm" else "x"
+
+if platform.system() == "Windows":
+ _chrome_platform_detected = "win" + _arch_size_detected
+elif platform.system() == "Linux":
+ _chrome_platform_detected = "linux" + _arch_size_detected
+elif platform.system() == "Darwin":
+ _chrome_platform_detected = "mac-" + _arch_detected + _arch_size_detected
+
+_default_exe_path = Path()
+if platform.system().startswith("Linux"):
+ _default_exe_path = (
+ _default_download_path / f"chrome-{_chrome_platform_detected}" / "chrome"
+ )
+elif platform.system().startswith("Darwin"):
+ _default_exe_path = (
+ _default_download_path
+ / f"chrome-{_chrome_platform_detected}"
+ / "Google Chrome for Testing.app"
+ / "Contents"
+ / "MacOS"
+ / "Google Chrome for Testing"
+ )
+elif platform.system().startswith("Win"):
+ _default_exe_path = (
+ _default_download_path / f"chrome-{_chrome_platform_detected}" / "chrome.exe"
+ )
+
+
+def get_chrome_download_path() -> Path:
+ return _default_exe_path
+
+
+# https://stackoverflow.com/questions/39296101/python-zipfile-removes-execute-permissions-from-binaries
+class _ZipFilePermissions(zipfile.ZipFile):
+ def _extract_member(self, member, targetpath, pwd): # type: ignore [no-untyped-def]
+ if not isinstance(member, zipfile.ZipInfo):
+ member = self.getinfo(member)
+
+ path = super()._extract_member(member, targetpath, pwd) # type: ignore [misc]
+ # High 16 bits are os specific (bottom is st_mode flag)
+ attr = member.external_attr >> 16
+ if attr != 0:
+ Path(path).chmod(attr)
+ return path
+
+
+def get_chrome_sync(
+ arch: str = _chrome_platform_detected,
+ i: int = -1,
+ path: str | Path = _default_download_path,
+ *,
+ verbose: bool = False,
+) -> Path | str:
+ """Download chrome synchronously: see `get_chrome()`."""
+ if isinstance(path, str):
+ path = Path(path)
+ browser_list = json.loads(
+ urllib.request.urlopen( # noqa: S310 audit url for schemes
+ _chrome_for_testing_url,
+ ).read(),
+ )
+ version_obj = browser_list["versions"][i]
+ if verbose:
+ print(version_obj["version"]) # noqa: T201 allow print in cli
+ print(version_obj["revision"]) # noqa: T201 allow print in cli
+ chromium_sources = version_obj["downloads"]["chrome"]
+ url = ""
+ for src in chromium_sources:
+ if src["platform"] == arch:
+ url = src["url"]
+ break
+ if not path.exists():
+ path.mkdir(parents=True)
+ filename = path / "chrome.zip"
+ with urllib.request.urlopen(url) as response, filename.open("wb") as out_file: # noqa: S310 audit url
+ shutil.copyfileobj(response, out_file)
+ with _ZipFilePermissions(filename, "r") as zip_ref:
+ zip_ref.extractall(path)
+
+ if arch.startswith("linux"):
+ exe_name = path / f"chrome-{arch}" / "chrome"
+ elif arch.startswith("mac"):
+ exe_name = (
+ path
+ / f"chrome-{arch}"
+ / "Google Chrome for Testing.app"
+ / "Contents"
+ / "MacOS"
+ / "Google Chrome for Testing"
+ )
+ elif arch.startswith("win"):
+ exe_name = path / f"chrome-{arch}" / "chrome.exe"
+
+ return exe_name
+
+
+async def get_chrome(
+ arch: str = _chrome_platform_detected,
+ i: int = -1,
+ path: str | Path = _default_download_path,
+ *,
+ verbose: bool = False,
+) -> Path | str:
+ """
+ Download google chrome from google-chrome-for-testing server.
+
+ Args:
+ arch: the target platform/os, as understood by google's json directory.
+ i: the chrome version: -1 being the latest version, 0 being the oldest
+ still in the testing directory.
+ path: where to download it too (the folder).
+ verbose: print out version found
+
+ """
+ return await asyncio.to_thread(
+ get_chrome_sync,
+ arch=arch,
+ i=i,
+ path=path,
+ verbose=verbose,
+ )
+
+
+def get_chrome_cli() -> None:
+ if "ubuntu" in platform.version().lower():
+ warnings.warn( # noqa: B028
+ "You are using `get_browser()` on Ubuntu."
+ " Ubuntu is **very strict** about where binaries come from."
+ " You have to disable the sandbox with use_sandbox=False"
+ " when you initialize the browser OR you can install from Ubuntu's"
+ " package manager.",
+ UserWarning,
+ )
+ parser = argparse.ArgumentParser(description="tool to help debug problems")
+ parser.add_argument("--i", "-i", type=int, dest="i")
+ parser.add_argument("--arch", dest="arch")
+ parser.add_argument("--path", dest="path")
+ parser.add_argument(
+ "-v",
+ "--verbose",
+ dest="verbose",
+ action="store_true",
+ )
+ parser.set_defaults(i=-1)
+ parser.set_defaults(path=_default_download_path)
+ parser.set_defaults(arch=_chrome_platform_detected)
+ parser.set_defaults(verbose=False)
+ parsed = parser.parse_args()
+ i = parsed.i
+ arch = parsed.arch
+ path = Path(parsed.path)
+ verbose = parsed.verbose
+ if not arch or arch not in _platforms:
+ raise RuntimeError(
+ "You must specify a platform: "
+ f"linux64, win32, win64, mac-x64, mac-arm64, not {platform}",
+ )
+ print(get_chrome_sync(arch=arch, i=i, path=path, verbose=verbose)) # noqa: T201 allow print in cli
diff --git a/choreographer/_cli_utils_no_qa.py b/choreographer/cli/_cli_utils_no_qa.py
similarity index 79%
rename from choreographer/_cli_utils_no_qa.py
rename to choreographer/cli/_cli_utils_no_qa.py
index 131658a7..ae374e88 100644
--- a/choreographer/_cli_utils_no_qa.py
+++ b/choreographer/cli/_cli_utils_no_qa.py
@@ -1,5 +1,6 @@
import argparse
-import asyncio
+
+# import asyncio
import platform
import subprocess
import sys
@@ -9,20 +10,28 @@
# ruff has line-level and file-level QA suppression
# so lets give diagnose a separate file
-# ruff: noqa: PLR0915, C901, S603, BLE001, S607, PERF203, TRY002
+# ruff: noqa: PLR0915, C901, S603, BLE001, S607, PERF203, TRY002, T201
# in order, exceptions are:
# - function complexity (statements?)
# - function complexity (algo measure)
# - validate subprocess input arguments
# - blind exception
-# - partial executable path
+# - partial executable path (bash not /bin/bash)
# - performance overhead of try-except in loop
# - make own exceptions
+# - no print
+
+def diagnose() -> None:
+ import logistro
-def diagnose():
- from choreographer import Browser, browser_which
+ logistro.getLogger().setLevel("DEBUG")
+
+ # from choreographer import BrowserSync, Browser, browser_which
+ from choreographer import BrowserSync
+ from choreographer.browsers._chrome_constants import chrome_names
+ from choreographer.utils._which import browser_which
parser = argparse.ArgumentParser(description="tool to help debug problems")
parser.add_argument("--no-run", dest="run", action="store_false")
@@ -40,7 +49,7 @@ def diagnose():
print(platform.version())
print(platform.uname())
print("BROWSER:".center(50, "*"))
- print(browser_which(debug=True))
+ print(browser_which(chrome_names))
print("VERSION INFO:".center(50, "*"))
try:
print("PIP:".center(25, "*"))
@@ -68,22 +77,23 @@ def diagnose():
if run:
try:
print("Sync Test Headless".center(50, "*"))
- browser = Browser(debug=True, debug_browser=True, headless=headless)
+ browser = BrowserSync(headless=headless)
+ browser.open()
time.sleep(3)
browser.close()
except BaseException as e:
fail.append(("Sync test headless", e))
finally:
print("Done with sync test headless".center(50, "*"))
-
- async def test_headless():
- browser = await Browser(debug=True, debug_browser=True, headless=headless)
- await asyncio.sleep(3)
- await browser.close()
+ # ruff: noqa: ERA001
+ # async def test_headless():
+ # browser = await Browser(debug=True, debug_browser=True, headless=headless)
+ # await asyncio.sleep(3)
+ # await browser.close()
try:
print("Async Test Headless".center(50, "*"))
- asyncio.run(test_headless())
+ # asyncio.run(test_headless())
except BaseException as e:
fail.append(("Async test headless", e))
finally:
diff --git a/choreographer/errors.py b/choreographer/errors.py
new file mode 100644
index 00000000..c1db5cb6
--- /dev/null
+++ b/choreographer/errors.py
@@ -0,0 +1,28 @@
+"""A compilation of the errors available in choreographer."""
+
+from ._brokers._async import UnhandledMessageWarning
+from .browsers import (
+ BrowserClosedError,
+ BrowserFailedError,
+)
+from .channels import BlockWarning, ChannelClosedError
+from .protocol import (
+ DevtoolsProtocolError,
+ ExperimentalFeatureWarning,
+ MessageTypeError,
+ MissingKeyError,
+)
+from .utils import TmpDirWarning
+
+__all__ = [
+ "BlockWarning",
+ "BrowserClosedError",
+ "BrowserFailedError",
+ "ChannelClosedError",
+ "DevtoolsProtocolError",
+ "ExperimentalFeatureWarning",
+ "MessageTypeError",
+ "MissingKeyError",
+ "TmpDirWarning",
+ "UnhandledMessageWarning",
+]
diff --git a/choreographer/protocol/__init__.py b/choreographer/protocol/__init__.py
new file mode 100644
index 00000000..7556f8cc
--- /dev/null
+++ b/choreographer/protocol/__init__.py
@@ -0,0 +1,206 @@
+"""
+Provides various implementations of Session and Target.
+
+It includes helpers and constants for the Chrome Devtools Protocol.
+"""
+
+from __future__ import annotations
+
+from collections.abc import MutableMapping
+from enum import Enum
+from typing import Any, NewType, cast
+
+BrowserResponse = NewType("BrowserResponse", MutableMapping[str, Any])
+"""The type for a response from the browser. Is really a `dict()`."""
+BrowserCommand = NewType("BrowserCommand", MutableMapping[str, Any])
+"""The type for a command to the browser. Is really a `dict()`."""
+
+MessageKey = NewType("MessageKey", tuple[str, int | None])
+"""The type for id'ing a message/response. It is `tuple(session_id, message_id)`."""
+
+
+class Ecode(Enum):
+ """Ecodes are a list of possible error codes chrome returns."""
+
+ TARGET_NOT_FOUND = -32602
+ """Self explanatory."""
+
+
+class DevtoolsProtocolError(Exception):
+ """Raise a general error reported by the devtools protocol."""
+
+ def __init__(self, response: BrowserResponse) -> None:
+ """
+ Construct a new DevtoolsProtocolError.
+
+ Args:
+ response: the json response that contains the error
+
+ """
+ super().__init__(response)
+ self.code = response["error"]["code"]
+ self.message = response["error"]["message"]
+
+
+class MessageTypeError(TypeError):
+ """An error for poorly formatted devtools protocol message."""
+
+ def __init__(self, key: str, value: Any, expected_type: type) -> None:
+ """
+ Construct a message about a poorly formed protocol message.
+
+ Args:
+ key: the key that has the badly typed value
+ value: the type of the value that is incorrect
+ expected_type: the type that was expected
+
+ """
+ value = type(value) if not isinstance(value, type) else value
+ super().__init__(
+ f"Message with key {key} must have type {expected_type}, not {value}.",
+ )
+
+
+class MissingKeyError(ValueError):
+ """An error for poorly formatted devtools protocol message."""
+
+ def __init__(self, key: str, obj: BrowserCommand) -> None:
+ """
+ Construct a MissingKeyError specifying which key was missing.
+
+ Args:
+ key: the missing key
+ obj: the message without the key
+
+ """
+ super().__init__(
+ f"Message missing required key/s {key}. Message received: {obj}",
+ )
+
+
+class ExperimentalFeatureWarning(UserWarning):
+ """An warning to report that a feature may or may not work."""
+
+
+def verify_params(obj: BrowserCommand) -> None:
+ """
+ Verify the message obj hast he proper keys and values.
+
+ Args:
+ obj: the object to check.
+
+ Raises:
+ MissingKeyError: if a key is missing.
+ MessageTypeError: if a value type is incorrect.
+ RuntimeError: if there are strange keys.
+
+ """
+ n_keys = 0
+
+ required_keys = {"id": int, "method": str}
+ for key, type_key in required_keys.items():
+ if key not in obj:
+ raise MissingKeyError(key, obj)
+ if not isinstance(obj[key], type_key):
+ raise MessageTypeError(key, type(obj[key]), type_key)
+ n_keys += 2
+
+ if "params" in obj:
+ n_keys += 1
+ if "sessionId" in obj:
+ n_keys += 1
+
+ if len(obj.keys()) != n_keys:
+ raise RuntimeError(
+ "Message objects must have id and method keys, "
+ "and may have params and sessionId keys.",
+ )
+
+
+def calculate_message_key(msg: BrowserResponse | BrowserCommand) -> MessageKey | None:
+ """
+ Given a message to/from the browser, calculate the key corresponding to the command.
+
+ Every message is uniquely identified by its sessionId and id (counter).
+
+ Args:
+ msg: the message for which to calculate the key.
+
+ """
+ session_id = msg.get("sessionId", "")
+ message_id = msg.get("id")
+ if message_id is None:
+ return None
+ return MessageKey((session_id, message_id))
+
+
+def match_message_key(response: BrowserResponse, key: MessageKey) -> bool:
+ """
+ Report True if a response matches with a certain key (sessionId, id).
+
+ Args:
+ response: the object response from the browser
+ key: the (sessionId, id) key tubple we're looking for
+
+ """
+ session_id, message_id = key
+ if ("session_id" not in response and session_id == "") or ( # is browser session
+ "session_id" in response and response["session_id"] == session_id # is session
+ ):
+ pass
+ else:
+ return False
+
+ if "id" in response and str(response["id"]) == str(message_id):
+ pass
+ else:
+ return False
+ return True
+
+
+def is_event(response: BrowserResponse) -> bool:
+ """Return true if the browser response is an event notification."""
+ required_keys = {"method", "params"}
+ return required_keys <= response.keys() and "id" not in response
+
+
+def get_target_id_from_result(response: BrowserResponse) -> str | None:
+ """
+ Extract target id from a browser response.
+
+ Args:
+ response: the browser response to extract the targetId from.
+
+ """
+ if "result" in response and "targetId" in response["result"]:
+ return cast(str, response["result"]["targetId"])
+ else:
+ return None
+
+
+def get_session_id_from_result(response: BrowserResponse) -> str | None:
+ """
+ Extract session id from a browser response.
+
+ Args:
+ response: the browser response to extract the sessionId from.
+
+ """
+ if "result" in response and "sessionId" in response["result"]:
+ return cast(str, response["result"]["sessionId"])
+ else:
+ return None
+
+
+def get_error_from_result(response: BrowserResponse) -> str | None:
+ """
+ Extract error from a browser response.
+
+ Args:
+ response: the browser response to extract the error from.
+
+ """
+ if "error" in response:
+ return cast(str, response["error"])
+ else:
+ return None
diff --git a/choreographer/protocol/devtools_async.py b/choreographer/protocol/devtools_async.py
new file mode 100644
index 00000000..8954bdba
--- /dev/null
+++ b/choreographer/protocol/devtools_async.py
@@ -0,0 +1,318 @@
+"""Provide a lower-level async interface to the Devtools Protocol."""
+
+from __future__ import annotations
+
+from typing import TYPE_CHECKING
+
+import logistro
+
+from choreographer import protocol
+
+if TYPE_CHECKING:
+ import asyncio
+ from collections.abc import Callable, Coroutine, MutableMapping
+ from typing import Any
+
+ from choreographer._brokers import Broker
+
+_logger = logistro.getLogger(__name__)
+
+
+class Session:
+ """A session is a single conversation with a single target."""
+
+ session_id: str
+ """The id of the session given by the browser."""
+ message_id: int
+ """All messages are counted per session and this is the current message id."""
+ subscriptions: MutableMapping[
+ str,
+ tuple[
+ Callable[[protocol.BrowserResponse], Coroutine[Any, Any, Any]],
+ bool,
+ ],
+ ]
+
+ def __init__(self, session_id: str, broker: Broker) -> None:
+ """
+ Construct a session from the browser as an object.
+
+ A session is like an open conversation with a target.
+ All commands are sent on sessions.
+
+ Args:
+ broker: a reference to the browser's broker
+ session_id: the id given by the browser
+
+ """
+ if not isinstance(session_id, str):
+ raise TypeError("session_id must be a string")
+ # Resources
+ self._broker = broker
+
+ # State
+ self.session_id = session_id
+ _logger.debug(f"New session: {session_id}")
+ self.message_id = 0
+ self.subscriptions = {}
+
+ async def send_command(
+ self,
+ command: str,
+ params: MutableMapping[str, Any] | None = None,
+ ) -> protocol.BrowserResponse:
+ """
+ Send a devtools command on the session.
+
+ https://chromedevtools.github.io/devtools-protocol/
+
+ Args:
+ command: devtools command to send
+ params: the parameters to send
+
+ Returns:
+ A message key (session, message id) tuple or None
+
+ """
+ current_id = self.message_id
+ self.message_id += 1
+ json_command = protocol.BrowserCommand(
+ {
+ "id": current_id,
+ "method": command,
+ },
+ )
+
+ if self.session_id:
+ json_command["sessionId"] = self.session_id
+ if params:
+ json_command["params"] = params
+ _logger.debug(
+ f"Cmd '{command}', params '{params}' on sessionId '{self.session_id}'",
+ )
+ _logger.debug2(f"In session.send_command for {json_command}")
+ return await self._broker.write_json(json_command)
+
+ def subscribe(
+ self,
+ string: str,
+ callback: Callable[[protocol.BrowserResponse], Coroutine[Any, Any, Any]],
+ *,
+ repeating: bool = True,
+ ) -> None:
+ """
+ Subscribe to an event on this session.
+
+ Args:
+ string: the name of the event. Can use * wildcard at the end.
+ callback: the callback (which takes a message dict and returns nothing)
+ repeating: default True, should the callback execute more than once
+
+ """
+ if string in self.subscriptions:
+ raise ValueError(
+ "You are already subscribed to this string, "
+ "duplicate subscriptions are not allowed.",
+ )
+ else:
+ # so this should be per session
+ # and that means we need a list of all sessions
+ self.subscriptions[string] = (callback, repeating)
+
+ def unsubscribe(self, string: str) -> None:
+ """
+ Remove a subscription.
+
+ Args:
+ string: the subscription to remove.
+
+ """
+ if string not in self.subscriptions:
+ raise ValueError(
+ "Cannot unsubscribe as string is not present in subscriptions",
+ )
+ del self.subscriptions[string]
+
+ def subscribe_once(self, string: str) -> asyncio.Future[Any]:
+ """
+ Return a future for a browser event.
+
+ Generally python asyncio doesn't recommend futures.
+
+ But in this case, one must call subscribe_once and await it later,
+ generally because they must subscribe and then provoke the event.
+
+ Args:
+ string: the event to subscribe to
+
+ Returns:
+ A future to be awaited later, the complete event.
+
+ """
+ return self._broker.new_subscription_future(self.session_id, string)
+
+
+class Target:
+ """A target like a browser, tab, or others. It sends commands. It has sessions."""
+
+ target_id: str
+ """The browser's ID of the target."""
+ sessions: MutableMapping[str, Session]
+ """A list of all the sessions for this target."""
+
+ def __init__(self, target_id: str, broker: Broker):
+ """
+ Create a target after one ahs been created by the browser.
+
+ Args:
+ broker: a reference to the browser's broker
+ target_id: the id given by the browser
+
+ """
+ if not isinstance(target_id, str):
+ raise TypeError("target_id must be string")
+ # Resources
+ self._broker = broker
+
+ # States
+ self.sessions = {}
+ self.target_id = target_id
+ _logger.info(f"Created new target {target_id}.")
+
+ def _add_session(self, session: Session) -> None:
+ if not isinstance(session, Session):
+ raise TypeError("session must be a session type class")
+ self.sessions[session.session_id] = session
+
+ def _remove_session(self, session_id: str) -> None:
+ if isinstance(session_id, Session):
+ session_id = session_id.session_id
+ _ = self.sessions.pop(session_id, None)
+
+ def get_session(self) -> Session:
+ """Retrieve the first session of the target, if it exists."""
+ if not self.sessions.values():
+ raise RuntimeError(
+ "Cannot use this method without at least one valid session",
+ )
+ session = next(iter(self.sessions.values()))
+ return session
+
+ async def send_command(
+ self,
+ command: str,
+ params: MutableMapping[str, Any] | None = None,
+ ) -> protocol.BrowserResponse:
+ """
+ Send a command to the first session in a target.
+
+ https://chromedevtools.github.io/devtools-protocol/
+
+ Args:
+ command: devtools command to send
+ params: the parameters to send
+
+ """
+ if not self.sessions.values():
+ raise RuntimeError("Cannot send_command without at least one valid session")
+ session = self.get_session()
+ _logger.debug(
+ f"Cmd '{command}', params '{params}' on sessionId '{session.session_id}'",
+ )
+ return await session.send_command(command, params)
+
+ async def create_session(self) -> Session:
+ """Create a new session on this target."""
+ response = await self._broker._browser.send_command( # noqa: SLF001 yeah we need the browser :-(
+ "Target.attachToTarget",
+ params={"targetId": self.target_id, "flatten": True},
+ )
+ if "error" in response:
+ raise RuntimeError(
+ "Could not create session",
+ ) from protocol.DevtoolsProtocolError(
+ response,
+ )
+ session_id = response["result"]["sessionId"]
+ new_session = Session(session_id, self._broker)
+ self._add_session(new_session)
+ return new_session
+
+ # async only
+ async def close_session(
+ self,
+ session_id: str,
+ ) -> protocol.BrowserResponse:
+ """
+ Close a session by session_id.
+
+ Args:
+ session_id: the session to close
+
+ """
+ if isinstance(session_id, Session):
+ session_id = session_id.session_id
+ response = await self._broker._browser.send_command( # noqa: SLF001 we need browser
+ command="Target.detachFromTarget",
+ params={"sessionId": session_id},
+ )
+
+ self._remove_session(session_id)
+ if "error" in response:
+ raise RuntimeError(
+ "Could not close session",
+ ) from protocol.DevtoolsProtocolError(
+ response,
+ )
+ _logger.debug(f"The session {session_id} has been closed")
+ return response
+ # kinda hate, why do we need this again?
+
+ def subscribe(
+ self,
+ string: str,
+ callback: Callable[[protocol.BrowserResponse], Coroutine[Any, Any, Any]],
+ *,
+ repeating: bool = True,
+ ) -> None:
+ """
+ Subscribe to an event on the main session of this target.
+
+ Args:
+ string: the name of the event. Can use * wildcard at the end.
+ callback: the callback (which takes a message dict and returns nothing)
+ repeating: default True, should the callback execute more than once
+
+ """
+ session = self.get_session()
+ session.subscribe(string, callback, repeating=repeating)
+
+ def unsubscribe(self, string: str) -> None:
+ """
+ Remove a subscription.
+
+ Args:
+ string: the subscription to remove.
+
+ """
+ session = self.get_session()
+ session.unsubscribe(string)
+
+ def subscribe_once(self, string: str) -> asyncio.Future[Any]:
+ """
+ Return a future for a browser event for the first session of this target.
+
+ Generally python asyncio doesn't recommend futures.
+
+ But in this case, one must call subscribe_once and await it later,
+ generally because they must subscribe and then provoke the event.
+
+ Args:
+ string: the event to subscribe to
+
+ Returns:
+ A future to be awaited later, the complete event.
+
+ """
+ session = self.get_session()
+ return session.subscribe_once(string)
diff --git a/choreographer/protocol/devtools_sync.py b/choreographer/protocol/devtools_sync.py
new file mode 100644
index 00000000..e98bee1e
--- /dev/null
+++ b/choreographer/protocol/devtools_sync.py
@@ -0,0 +1,155 @@
+"""Provide a lower-level sync interface to the Devtools Protocol."""
+
+from __future__ import annotations
+
+from typing import TYPE_CHECKING
+
+import logistro
+
+from choreographer import protocol
+
+if TYPE_CHECKING:
+ from collections.abc import MutableMapping
+ from typing import Any
+
+ from choreographer._brokers import BrokerSync
+
+
+_logger = logistro.getLogger(__name__)
+
+
+class SessionSync:
+ """A session is a single conversation with a single target."""
+
+ session_id: str
+ """The id of the session given by the browser."""
+ message_id: int
+ """All messages are counted per session and this is the current message id."""
+
+ def __init__(self, session_id: str, broker: BrokerSync) -> None:
+ """
+ Construct a session from the browser as an object.
+
+ A session is like an open conversation with a target.
+ All commands are sent on sessions.
+
+ Args:
+ broker: a reference to the browser's broker
+ session_id: the id given by the browser
+
+ """
+ if not isinstance(session_id, str):
+ raise TypeError("session_id must be a string")
+ # Resources
+ self._broker = broker
+
+ # State
+ self.session_id = session_id
+ _logger.debug(f"New session: {session_id}")
+ self.message_id = 0
+
+ def send_command(
+ self,
+ command: str,
+ params: MutableMapping[str, Any] | None = None,
+ ) -> Any:
+ """
+ Send a devtools command on the session.
+
+ https://chromedevtools.github.io/devtools-protocol/
+
+ Args:
+ command: devtools command to send
+ params: the parameters to send
+
+ Returns:
+ A message key (session, message id) tuple or None
+
+ """
+ current_id = self.message_id
+ self.message_id += 1
+ json_command = protocol.BrowserCommand(
+ {
+ "id": current_id,
+ "method": command,
+ },
+ )
+
+ if self.session_id:
+ json_command["sessionId"] = self.session_id
+ if params:
+ json_command["params"] = params
+ _logger.debug(
+ f"Sending {command} with {params} on session {self.session_id}",
+ )
+ return self._broker.write_json(json_command)
+
+
+class TargetSync:
+ """A target like a browser, tab, or others. It sends commands. It has sessions."""
+
+ target_id: str
+ """The browser's ID of the target."""
+ sessions: MutableMapping[str, SessionSync]
+ """A list of all the sessions for this target."""
+
+ def __init__(self, target_id: str, broker: BrokerSync):
+ """
+ Create a target after one ahs been created by the browser.
+
+ Args:
+ broker: a reference to the browser's broker
+ target_id: the id given by the browser
+
+ """
+ if not isinstance(target_id, str):
+ raise TypeError("target_id must be string")
+ # Resources
+ self._broker = broker
+
+ # States
+ self.sessions = {}
+ self.target_id = target_id
+ _logger.info(f"Created new target {target_id}.")
+
+ def _add_session(self, session: SessionSync) -> None:
+ if not isinstance(session, SessionSync):
+ raise TypeError("session must be a session type class")
+ self.sessions[session.session_id] = session
+
+ def _remove_session(self, session_id: str) -> None:
+ if isinstance(session_id, SessionSync):
+ session_id = session_id.session_id
+ _ = self.sessions.pop(session_id, None)
+
+ def get_session(self) -> SessionSync:
+ """Retrieve the first session of the target, if it exists."""
+ if not self.sessions.values():
+ raise RuntimeError(
+ "Cannot use this method without at least one valid session",
+ )
+ session = next(iter(self.sessions.values()))
+ return session
+
+ def send_command(
+ self,
+ command: str,
+ params: MutableMapping[str, Any] | None = None,
+ ) -> Any:
+ """
+ Send a command to the first session in a target.
+
+ https://chromedevtools.github.io/devtools-protocol/
+
+ Args:
+ command: devtools command to send
+ params: the parameters to send
+
+ """
+ if not self.sessions.values():
+ raise RuntimeError("Cannot send_command without at least one valid session")
+ session = self.get_session()
+ _logger.debug(
+ f"Sending {command} with {params} on session {session.session_id}",
+ )
+ return session.send_command(command, params)
diff --git a/choreographer/utils/README.txt b/choreographer/utils/README.txt
new file mode 100644
index 00000000..d76759fe
--- /dev/null
+++ b/choreographer/utils/README.txt
@@ -0,0 +1,7 @@
+sys_utils provide:
+
+a `which_browser()` function for finding the browser
+
+a more robust `TmpDirectory` class for creating and managing those
+
+a `kill()` function to be used when destroying processes.
diff --git a/choreographer/utils/__init__.py b/choreographer/utils/__init__.py
new file mode 100644
index 00000000..448a1e18
--- /dev/null
+++ b/choreographer/utils/__init__.py
@@ -0,0 +1,10 @@
+"""Contains functions and class that primarily help us with the OS."""
+
+from ._tmpfile import TmpDirectory, TmpDirWarning
+from ._which import get_browser_path
+
+__all__ = [
+ "TmpDirWarning",
+ "TmpDirectory",
+ "get_browser_path",
+]
diff --git a/choreographer/utils/_kill.py b/choreographer/utils/_kill.py
new file mode 100644
index 00000000..d7e43442
--- /dev/null
+++ b/choreographer/utils/_kill.py
@@ -0,0 +1,17 @@
+from __future__ import annotations
+
+import platform
+import subprocess
+
+
+def kill(process: subprocess.Popen[bytes]) -> None:
+ if platform.system() == "Windows":
+ subprocess.call( # noqa: S603, false positive, input fine
+ ["taskkill", "/F", "/T", "/PID", str(process.pid)], # noqa: S607 windows full path...
+ stderr=subprocess.DEVNULL,
+ stdout=subprocess.DEVNULL,
+ )
+ else:
+ process.terminate()
+ if process.poll() is None:
+ process.kill()
diff --git a/choreographer/_system_utils/_tempfile.py b/choreographer/utils/_tmpfile.py
similarity index 51%
rename from choreographer/_system_utils/_tempfile.py
rename to choreographer/utils/_tmpfile.py
index 771b57de..408eae66 100644
--- a/choreographer/_system_utils/_tempfile.py
+++ b/choreographer/utils/_tmpfile.py
@@ -1,3 +1,5 @@
+from __future__ import annotations
+
import os
import platform
import shutil
@@ -7,22 +9,50 @@
import time
import warnings
from pathlib import Path
-from threading import Thread
+from typing import TYPE_CHECKING
+
+import logistro
+
+if TYPE_CHECKING:
+ from collections.abc import Callable, MutableMapping, Sequence
+ from typing import Any
+
+_logger = logistro.getLogger(__name__)
+
+
+class TmpDirWarning(UserWarning):
+ """A warning if for whatever reason we can't eliminate the tmp dir."""
+
+
+class TmpDirectory:
+ """
+ The python stdlib `TemporaryDirectory` wrapper for easier use.
+ Python's `TemporaryDirectory` suffered a couple API changes that mean
+ you can't call it the same way for similar versions. This wrapper is
+ also much more aggressive about deleting the directory when it's done,
+ not necessarily relying on OS functions.
+ """
-class TempDirWarning(UserWarning):
- pass
+ temp_dir: tempfile.TemporaryDirectory[str]
+ """A reference to the underlying python `TemporaryDirectory` implementation."""
+ path: Path
+ """The path to the temporary directory."""
+ exists: bool
+ """A flag to indicate if the directory still exists."""
+ def __init__(self, path: str | None = None, *, sneak: bool = False):
+ """
+ Construct a wrapped `TemporaryDirectory`.
-# Python's built-in temporary directory functions are lacking
-# In short, they don't handle removal well, and there's
-# lots of API changes over recent versions.
-# Here we have our own class to deal with it.
-class TempDirectory:
- def __init__(self, path=None, *, sneak=False):
- self.debug = True # temporary! TODO
+ Args:
+ path: manually specify the directory to use
+ sneak: (default False) avoid using /tmp
+ Ubuntu's snap will sandbox /tmp
+
+ """
self._with_onexc = bool(sys.version_info[:3] >= (3, 12))
- args = {}
+ args: MutableMapping[str, Any] = {}
if path:
args = {"dir": path}
@@ -49,17 +79,18 @@ def __init__(self, path=None, *, sneak=False):
self.path = Path(self.temp_dir.name)
self.exists = True
- if self.debug:
- print(f"TEMP DIR PATH: {self.path}", file=sys.stderr)
- def delete_manually(self, *, check_only=False): # noqa: C901, PLR0912
+ def _delete_manually( # noqa: C901, PLR0912
+ self,
+ *,
+ check_only: bool = False,
+ ) -> tuple[
+ int,
+ int,
+ Sequence[tuple[Path, BaseException]],
+ ]:
if not self.path.exists():
self.exists = False
- if self.debug:
- print(
- "No retry delete manual necessary, path doesn't exist",
- file=sys.stderr,
- )
return 0, 0, []
n_dirs = 0
n_files = 0
@@ -70,24 +101,20 @@ def delete_manually(self, *, check_only=False): # noqa: C901, PLR0912
if not check_only:
for f in files:
fp = Path(root) / f
- if self.debug:
- print(f"Removing file: {fp}", file=sys.stderr)
+ _logger.debug2(f"Have file {fp}")
try:
fp.chmod(stat.S_IWUSR)
- fp.unlink()
- if self.debug:
- print("Success", file=sys.stderr)
+ fp.unlink(missing_ok=True)
+ _logger.debug2("Deleted")
except BaseException as e: # noqa: BLE001 yes catch and report
errors.append((fp, e))
for d in dirs:
fp = Path(root) / d
- if self.debug:
- print(f"Removing dir: {fp}", file=sys.stderr)
+ _logger.debug2(f"Have directory {fp}")
try:
fp.chmod(stat.S_IWUSR)
fp.rmdir()
- if self.debug:
- print("Success", file=sys.stderr)
+ _logger.debug2("Deleted")
except BaseException as e: # noqa: BLE001 yes catch and report
errors.append((fp, e))
@@ -108,7 +135,7 @@ def delete_manually(self, *, check_only=False): # noqa: C901, PLR0912
warnings.warn( # noqa: B028
"The temporary directory could not be deleted, "
f"execution will continue. errors: {errors}",
- TempDirWarning,
+ TmpDirWarning,
)
self.exists = True
else:
@@ -116,20 +143,24 @@ def delete_manually(self, *, check_only=False): # noqa: C901, PLR0912
return n_dirs, n_files, errors
- def clean(self): # noqa: C901
+ def clean(self) -> None: # noqa: C901
+ """Try several different ways to eliminate the temporary directory."""
try:
# no faith in this python implementation, always fails with windows
# very unstable recently as well, lots new arguments in tempfile package
- self.temp_dir.cleanup()
+ if hasattr(self, "temp_dir") and self.temp_dir:
+ self.temp_dir.cleanup()
self.exists = False
- except BaseException as e: # noqa: BLE001 yes catch and report
- if self.debug:
- print(
- f"First tempdir deletion failed: TempDirWarning: {e!s}",
- file=sys.stderr,
- )
-
- def remove_readonly(func, path, _excinfo):
+ _logger.info("TemporaryDirectory.cleanup() worked.")
+ except BaseException as e: # noqa: BLE001 we try many ways to clean, this is the first one
+ _logger.info(f"TemporaryDirectory.cleanup() failed. Error {e}")
+
+ # bad typing but tough
+ def remove_readonly(
+ func: Callable[[str], None],
+ path: str | Path,
+ _excinfo: Any,
+ ) -> None:
try:
Path(path).chmod(stat.S_IWUSR)
func(str(path))
@@ -143,26 +174,22 @@ def remove_readonly(func, path, _excinfo):
shutil.rmtree(self.path, onerror=remove_readonly)
self.exists = False
del self.temp_dir
+ _logger.info("shutil.rmtree worked.")
except FileNotFoundError:
- pass # it worked!
- except BaseException as e: # noqa: BLE001 yes catch like this and report and try
- if self.debug:
- print(
- f"Second tmpdir deletion failed (shutil.rmtree): {e!s}",
- file=sys.stderr,
- )
- self.delete_manually(check_only=True)
+ _logger.info("shutil.rmtree worked.")
+ except BaseException as e: # noqa: BLE001
+ self._delete_manually(check_only=True)
if not self.exists:
return
-
- def extra_clean():
- time.sleep(3)
- self.delete_manually()
-
- t = Thread(target=extra_clean)
- t.run()
- if self.debug:
- print(
- f"Tempfile still exists?: {self.path.exists()!s}",
- file=sys.stderr,
- )
+ _logger.info(f"shutil.rmtree() failed to delete temporary file. Error {e}")
+
+ def extra_clean() -> None:
+ _logger.info("Extra manual clean waiting 3 seconds.")
+ time.sleep(1)
+ _logger.info("Extra manual clean executing.")
+ self._delete_manually()
+
+ # testing doesn't look threads so I guess we'll block
+ extra_clean()
+ if self.path.exists():
+ _logger.warning("Temporary dictory couldn't be removed manually.")
diff --git a/choreographer/utils/_which.py b/choreographer/utils/_which.py
new file mode 100644
index 00000000..cbe3047a
--- /dev/null
+++ b/choreographer/utils/_which.py
@@ -0,0 +1,100 @@
+from __future__ import annotations
+
+import os
+import platform
+import shutil
+from typing import TYPE_CHECKING
+
+from choreographer.cli._cli_utils import get_chrome_download_path
+
+if TYPE_CHECKING:
+ from collections.abc import Sequence
+ from pathlib import Path
+ from typing import Any
+
+
+def _is_exe(path: str | Path) -> bool:
+ try:
+ return os.access(path, os.X_OK)
+ except: # noqa: E722 bare except ok, weird errors, best effort.
+ return False
+
+
+def _which_from_windows_reg() -> str | None:
+ try:
+ import re
+ import winreg
+
+ command = winreg.QueryValueEx( # type: ignore [attr-defined]
+ winreg.OpenKey( # type: ignore [attr-defined]
+ winreg.HKEY_CLASSES_ROOT, # type: ignore [attr-defined]
+ "ChromeHTML\\shell\\open\\command",
+ 0,
+ winreg.KEY_READ, # type: ignore [attr-defined]
+ ),
+ "",
+ )[0]
+ exe = re.search('"(.*?)"', command).group(1) # type: ignore [union-attr]
+ except BaseException: # noqa: BLE001 don't care why, best effort search
+ return None
+
+ return exe
+
+
+def browser_which(
+ executable_names: Sequence[str],
+ *,
+ skip_local: bool = False,
+) -> str | None:
+ """
+ Look for and return first name found in PATH.
+
+ Args:
+ executable_names: the list of names to look for
+ skip_local: (default False) don't look for a choreo download of anything.
+
+ """
+ path = None
+
+ if isinstance(executable_names, str):
+ executable_names = [executable_names]
+
+ local_chrome = get_chrome_download_path()
+ if (
+ local_chrome.exists()
+ and not skip_local
+ and local_chrome.name in executable_names
+ ):
+ return str(local_chrome)
+
+ if platform.system() == "Windows":
+ os.environ["NoDefaultCurrentDirectoryInExePath"] = "0" # noqa: SIM112 var name set by windows
+
+ for exe in executable_names:
+ if platform.system() == "Windows" and exe == "chrome":
+ path = _which_from_windows_reg()
+ if path and _is_exe(path):
+ return path
+ path = shutil.which(exe)
+ if path and _is_exe(path):
+ return path
+ # which didn't work
+
+ # hail mary
+ return None
+
+
+def get_browser_path(*args: Any, **kwargs: Any) -> str | None: # noqa: D417: don't pass args explicitly
+ """
+ Call `browser_which()` but check for user override first.
+
+ It looks for the browser in path.
+
+ Accepts the same arguments as `browser_which':
+
+ Args:
+ executable_names: the list of names to look for
+ skip_local: (default False) don't look for a choreo download of anything.
+
+ """
+ return os.environ.get("BROWSER_PATH", browser_which(*args, **kwargs))
diff --git a/mkdocs.yml b/mkdocs.yml
new file mode 100644
index 00000000..45efdd7b
--- /dev/null
+++ b/mkdocs.yml
@@ -0,0 +1,46 @@
+---
+### Site metadata ###
+
+site_name: choreographer
+repo_name: github
+
+
+### Build settings ###
+
+docs_dir: 'docs/'
+nav:
+ - Readme: >-
+ {
+ "dest": "README.md",
+ "src": "../README.md",
+ "replace": {"src='docs/": "src='"}
+ }
+ - User API: >-
+ {
+ "api": "choreographer",
+ "test": ["exports", "_prefix_local"],
+ "tree": "none"
+ }
+ - Developer API:
+ - >-
+ {
+ "api": "choreographer",
+ "test": ["exports", "_prefix_local"],
+ "tree": "packages"
+ }
+ # CLI tools?
+
+theme:
+ name: material
+markdown_extensions:
+ - pymdownx.highlight:
+ anchor_linenums: true
+ line_spans: __span
+ pygments_lang_class: true
+ - pymdownx.inlinehilite
+ - pymdownx.snippets
+ - pymdownx.superfences
+plugins:
+ - quimeta
+ - quicopy
+ - quiapi
diff --git a/pyproject.toml b/pyproject.toml
index 4858f517..10043c49 100644
--- a/pyproject.toml
+++ b/pyproject.toml
@@ -28,7 +28,11 @@ dependencies = [
[project.urls]
Homepage = "https://github.com/plotly/choreographer"
-Repository = "https://github.com/geopozo/logistro"
+Repository = "https://github.com/plotly/choreographer"
+
+[project.scripts]
+choreo_diagnose = "choreographer.cli._cli_utils_no_qa:diagnose"
+choreo_get_chrome = "choreographer.cli._cli_utils:get_chrome_cli"
[dependency-groups]
dev = [
@@ -37,7 +41,9 @@ dev = [
"pytest-xdist",
"async-timeout",
"poethepoet>=0.31.1",
- "numpy"
+ "numpy",
+ "mypy>=1.14.1",
+ "types-simplejson>=3.19.0.20241221",
]
# uv doens't allow dependency groups to have separate python requirements
@@ -51,9 +57,8 @@ dev = [
# "mkdocs-material>=9.5.49",
#]
-[project.scripts]
-choreo_diagnose = "choreographer._cli_utils_no_qa:diagnose"
-choreo_get_browser = "choreographer._cli_utils:get_browser_cli"
+[tool.uv.sources]
+mkquixote = { path = "../mkquixote", editable = true }
[tool.ruff.lint]
select = ["ALL"]
@@ -72,8 +77,8 @@ ignore = [
"RET508", # Allow else if unnecessary because more readable
"RUF012", # We don't do typing, so no typing
"SIM105", # Too opionated (try-except-pass)
- "T201", # no print, remove after logistro TODO
"PT003", # scope="function" implied but I like readability
+ "G004", # fstrings in my logs
]
[tool.ruff.lint.per-file-ignores]
@@ -81,21 +86,19 @@ ignore = [
"D", # ignore docstring errors
"S101", # allow assert
"INP001", # no need for __init__ in test directories
+ "T201", # if we're printing in tests, there is a reason
+ "ERA001"
]
-# Format breaks this anyway
-# [tool.ruff.lint]
-# ignore = ["E701"]
-
[tool.pytest.ini_options]
asyncio_default_fixture_loop_scope = "function"
-log_cli = true
+log_cli = false
[tool.poe.tasks]
_test_proc = "pytest -W error -n auto -v -rfE --capture=fd tests/test_process.py"
-_test_fn = "pytest -W error -n auto -v -rfE --ignore=tests/test_process.py"
-_debug-test_proc = "pytest -W error -vvx -rA --capture=tee-sys tests/test_process.py"
-_debug-test_fn = "pytest -W error -vvvx -rA --capture=tee-sys --ignore=tests/test_process.py"
+_test_fn = "pytest -W error -n auto -v -rfE --capture=fd --ignore=tests/test_process.py"
+_debug-test_proc = "pytest --log-level=1 -W error -vvx -rA --show-capture=no --capture=no tests/test_process.py"
+_debug-test_fn = "pytest --log-level=1 -W error -vvvx -rA --show-capture=no --capture=no --ignore=tests/test_process.py"
# the capture on these is weird, the mechanics are weird, i forget exactly whats its doing
[tool.poe.tasks.test]
@@ -107,5 +110,5 @@ sequence = ["_debug-test_proc", "_debug-test_fn"]
help = "Run test by test, slowly, quitting after first error"
[tool.poe.tasks.filter-test]
-cmd = "pytest -W error -vvvx -rA --capture=tee-sys"
+cmd = "pytest --log-level=1 -W error -vvvx -rA --capture=no --show-capture=no"
help = "Run any/all tests one by one with basic settings: can include filename and -k filters"
diff --git a/site/404.html b/site/404.html
new file mode 100644
index 00000000..14dd2592
--- /dev/null
+++ b/site/404.html
@@ -0,0 +1,774 @@
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+ choreographer
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+ 404 - Not found
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
\ No newline at end of file
diff --git a/site/api/choreographer.browser_async/index.html b/site/api/choreographer.browser_async/index.html
new file mode 100644
index 00000000..c865fbfb
--- /dev/null
+++ b/site/api/choreographer.browser_async/index.html
@@ -0,0 +1,1986 @@
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+ browser_async - choreographer
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+choreographer.browser_async
+
+module: browser_async
+
+
Provides the async api: Browser
, Tab
.
+
+Classes
+
+
class Tab(choreographer.protocol.devtools_async.Target):
+
+
A wrapper for Target
, so user can use Tab
, not Target
.
+
+
attributes
+
+
target_id
- The browser's ID of the target.
+
+
+
sessions
- A list of all the sessions for this target.
+
+
methods
+
+
__init__(self, target_id, broker)
+
+
+
Create a target after one ahs been created by the browser.
+
+
arguments
+
+
+
broker
+ - a reference to the browser's broker
+
+
+
target_id
+ - the id given by the browser
+
+
+
+
+
+
get_session(self)
+
+
+
Retrieve the first session of the target, if it exists.
+
+
+
+
+
send_command(self, command, params)
+
+
+
Send a command to the first session in a target.
+
https://chromedevtools.github.io/devtools-protocol/
+
+
arguments
+
+
+
command
+ - devtools command to send
+
+
+
params
+ - the parameters to send
+
+
+
+
+
+
create_session(self)
+
+
+
Create a new session on this target.
+
+
+
+
+
close_session(self, session_id)
+
+
+
Close a session by session_id.
+
+
arguments
+
+
+
session_id
+ - the session to close
+
+
+
+
+
+
subscribe(self, string, callback, repeating)
+
+
+
Subscribe to an event on the main session of this target.
+
+
arguments
+
+
+
string
+ - the name of the event. Can use * wildcard at the end.
+
+
+
callback
+ - the callback (which takes a message dict and returns nothing)
+
+
+
repeating
+ - default True, should the callback execute more than once
+
+
+
+
+
+
unsubscribe(self, string)
+
+
+
Remove a subscription.
+
+
arguments
+
+
+
string
+ - the subscription to remove.
+
+
+
+
+
+
subscribe_once(self, string)
+
+
+
Return a future for a browser event for the first session of this target.
+
Generally python asyncio doesn't recommend futures.
+
But in this case, one must call subscribe_once and await it later,
+generally because they must subscribe and then provoke the event.
+
+
arguments
+
+
+
string
+ - the event to subscribe to
+
+
+
returns
+
+
A future to be awaited later, the complete event.
+
+
+
+
+
+
+
class Browser(choreographer.protocol.devtools_async.Target):
+
+
Browser
is the async implementation of Browser
.
+
+
attributes
+
+
target_id
- The browser's ID of the target.
+
+
+
sessions
- A list of all the sessions for this target.
+
+
+
tabs
- A mapping by target_id of all the targets which are open tabs.
+
+
+
targets
- A mapping by target_id of ALL the targets.
+
+
methods
+
+
__init__(self, path, browser_cls, channel_cls, kwargs)
+
+
+
Construct a new browser instance.
+
+
arguments
+
+
+
path
+ - The path to the browser executable.
+
+
+
browser_cls
+ - The type of browser (default: Chromium
).
+
+
+
channel_cls
+ - The type of channel to browser (default: Pipe
).
+
+
+
kwargs
+ - The arguments that the browser_cls takes. For example,
+headless=True/False, enable_gpu=True/False, etc.
+
+
+
+
+
+
get_session(self)
+
+
+
Retrieve the first session of the target, if it exists.
+
+
+
+
+
send_command(self, command, params)
+
+
+
Send a command to the first session in a target.
+
https://chromedevtools.github.io/devtools-protocol/
+
+
arguments
+
+
+
command
+ - devtools command to send
+
+
+
params
+ - the parameters to send
+
+
+
+
+
+
close_session(self, session_id)
+
+
+
Close a session by session_id.
+
+
arguments
+
+
+
session_id
+ - the session to close
+
+
+
+
+
+
subscribe(self, string, callback, repeating)
+
+
+
Subscribe to an event on the main session of this target.
+
+
arguments
+
+
+
string
+ - the name of the event. Can use * wildcard at the end.
+
+
+
callback
+ - the callback (which takes a message dict and returns nothing)
+
+
+
repeating
+ - default True, should the callback execute more than once
+
+
+
+
+
+
unsubscribe(self, string)
+
+
+
Remove a subscription.
+
+
arguments
+
+
+
string
+ - the subscription to remove.
+
+
+
+
+
+
subscribe_once(self, string)
+
+
+
Return a future for a browser event for the first session of this target.
+
Generally python asyncio doesn't recommend futures.
+
But in this case, one must call subscribe_once and await it later,
+generally because they must subscribe and then provoke the event.
+
+
arguments
+
+
+
string
+ - the event to subscribe to
+
+
+
returns
+
+
A future to be awaited later, the complete event.
+
+
+
+
+
+
+
get_tab(self)
+
+
+
Get the first tab if there is one. Useful for default tabs.
+
+
returns
+
+
+
+
+
populate_targets(self)
+
+
+
Solicit the actual browser for all targets to add to the browser object.
+
+
+
+
+
create_session(self)
+
+
+
Create a browser session. Only in supported browsers, is experimental.
+
+
returns
+
+
+
+
+
create_tab(self, url, width, height)
+
+
+
arguments
+
+
+
url
+ - the url to navigate to, default ""
+
+
+
width
+ - the width of the tab (headless only)
+
+
+
height
+ - the height of the tab (headless only)
+
+
+
returns
+
+
+
+
+
close_tab(self, target_id)
+
+
+
Close a tab by its id.
+
+
arguments
+
+
+
target_id
+ - the targetId of the tab to close.
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
\ No newline at end of file
diff --git a/site/api/choreographer.browser_sync/index.html b/site/api/choreographer.browser_sync/index.html
new file mode 100644
index 00000000..131f3d7f
--- /dev/null
+++ b/site/api/choreographer.browser_sync/index.html
@@ -0,0 +1,1535 @@
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+ browser_sync - choreographer
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+choreographer.browser_sync
+
+module: browser_sync
+
+
Provides the sync api: BrowserSync
, TabSync
.
+
+Classes
+
+
class TabSync(choreographer.protocol.devtools_sync.TargetSync):
+
+
A wrapper for TargetSync
, so user can use TabSync
, not TargetSync
.
+
+
attributes
+
+
target_id
- The browser's ID of the target.
+
+
+
sessions
- A list of all the sessions for this target.
+
+
methods
+
+
__init__(self, target_id, broker)
+
+
+
Create a target after one ahs been created by the browser.
+
+
arguments
+
+
+
broker
+ - a reference to the browser's broker
+
+
+
target_id
+ - the id given by the browser
+
+
+
+
+
+
get_session(self)
+
+
+
Retrieve the first session of the target, if it exists.
+
+
+
+
+
send_command(self, command, params)
+
+
+
Send a command to the first session in a target.
+
https://chromedevtools.github.io/devtools-protocol/
+
+
arguments
+
+
+
command
+ - devtools command to send
+
+
+
params
+ - the parameters to send
+
+
+
+
+
+
+
class BrowserSync(choreographer.protocol.devtools_sync.TargetSync):
+
+
BrowserSync
is the sync implementation of Browser
.
+
+
attributes
+
+
target_id
- The browser's ID of the target.
+
+
+
sessions
- A list of all the sessions for this target.
+
+
+
tabs
- A mapping by target_id of all the targets which are open tabs.
+
+
+
targets
- A mapping by target_id of ALL the targets.
+
+
methods
+
+
__init__(self, path, browser_cls, channel_cls, kwargs)
+
+
+
Construct a new browser instance.
+
+
arguments
+
+
+
path
+ - The path to the browser executable.
+
+
+
browser_cls
+ - The type of browser (default: Chromium
).
+
+
+
channel_cls
+ - The type of channel to browser (default: Pipe
).
+
+
+
kwargs
+ - The arguments that the browser_cls takes. For example,
+headless=True/False, enable_gpu=True/False, etc.
+
+
+
+
+
+
get_session(self)
+
+
+
Retrieve the first session of the target, if it exists.
+
+
+
+
+
send_command(self, command, params)
+
+
+
Send a command to the first session in a target.
+
https://chromedevtools.github.io/devtools-protocol/
+
+
arguments
+
+
+
command
+ - devtools command to send
+
+
+
params
+ - the parameters to send
+
+
+
+
+
+
+
+
get_tab(self)
+
+
+
Get the first tab if there is one. Useful for default tabs.
+
+
+
+
+
start_output_thread(self, kwargs)
+
+
+
Start a separate thread that dumps all messages received to stdout.
+
+
arguments
+
+
+
kwargs
+ - passed directly to print().
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
\ No newline at end of file
diff --git a/site/api/choreographer.browsers.chromium/index.html b/site/api/choreographer.browsers.chromium/index.html
new file mode 100644
index 00000000..60b9fb8d
--- /dev/null
+++ b/site/api/choreographer.browsers.chromium/index.html
@@ -0,0 +1,1328 @@
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+ chromium - choreographer
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+choreographer.browsers.chromium
+
+module: chromium
+
+
Provides a class proving tools for running chromium browsers.
+
+Classes
+
+
class Chromium():
+
+
Chromium represents an implementation of the chromium browser.
+
It also includes chromium-like browsers (chrome, edge, and brave).
+
+
attributes
+
+
path
- The path to the chromium executable.
+
+
+
gpu_enabled
- True if we should use the gpu. False by default for compatibility.
+
+
+
headless
- True if we should not show the browser, true by default.
+
+
+
sandbox_enabled
- True to enable the sandbox. False by default.
+
+
+
skip_local
- True if we want to avoid looking for our local download when searching path.
+
+
+
tmp_dir
- A reference to a temporary directory object the chromium needs to store data.
+
+
methods
+
+
__init__(self, channel, path, kwargs)
+
+
+
Construct a chromium browser implementation.
+
+
arguments
+
+
+
channel
+ - the choreographer.Channel
we'll be using (WebSockets? Pipe?)
+
+
+
path
+ - path to the browser
+
+
+
+
gpu_enabled (default False)
+ - Turn on GPU? Doesn't work in all envs.
+
+
+
headless (default True)
+ - Actually launch a browser?
+
+
+
sandbox_enabled (default False)
+ - Enable sandbox-
+a persnickety thing depending on environment, OS, user, etc
+
+
+
tmp_dir (default None)
+ - Manually set the temporary directory
+
+
+
raises
+
+
+
RuntimeError
+ - Too many kwargs, or browser not found.
+
+
+
NotImplementedError
+ - Pipe is the only channel type it'll accept right now.
+
+
+
+
+
+
logger_parser(cls, record, _old)
+
+
+
Parse (via logging.Filter.parse()
) data from browser stderr for logging.
+
+
arguments
+
+
+
record
+ - the logging.LogRecord
object to read/modify
+
+
+
_old
+ - data that was already stripped out.
+
+
+
+
+
+
get_popen_args(self)
+
+
+
Return the args needed to runc chromium with subprocess.Popen()
.
+
+
+
+
+
get_cli(self)
+
+
+
Return the CLI command for chromium.
+
+
+
+
+
get_env(self)
+
+
+
Return the env needed for chromium.
+
+
+
+
+
clean(self)
+
+
+
Clean up any leftovers form browser, like tmp files.
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
\ No newline at end of file
diff --git a/site/api/choreographer.browsers/index.html b/site/api/choreographer.browsers/index.html
new file mode 100644
index 00000000..737db6ed
--- /dev/null
+++ b/site/api/choreographer.browsers/index.html
@@ -0,0 +1,1150 @@
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+ Index - choreographer
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+choreographer.browsers
+
+package: browsers
+
+
Contains implementations of browsers that choreographer can open.
+
+Classes
+
+
class BrowserClosedError(RuntimeError):
+
+
An error for when the browser is closed accidently (during access).
+
+
+
+
class BrowserFailedError(RuntimeError):
+
+
An error for when the browser fails to launch.
+
+
+
+
class Chromium():
+
+
Chromium represents an implementation of the chromium browser.
+
It also includes chromium-like browsers (chrome, edge, and brave).
+
+
attributes
+
+
path
- The path to the chromium executable.
+
+
+
gpu_enabled
- True if we should use the gpu. False by default for compatibility.
+
+
+
headless
- True if we should not show the browser, true by default.
+
+
+
sandbox_enabled
- True to enable the sandbox. False by default.
+
+
+
skip_local
- True if we want to avoid looking for our local download when searching path.
+
+
+
tmp_dir
- A reference to a temporary directory object the chromium needs to store data.
+
+
methods
+
+
__init__(self, channel, path, kwargs)
+
+
+
Construct a chromium browser implementation.
+
+
arguments
+
+
+
channel
+ - the choreographer.Channel
we'll be using (WebSockets? Pipe?)
+
+
+
path
+ - path to the browser
+
+
+
+
gpu_enabled (default False)
+ - Turn on GPU? Doesn't work in all envs.
+
+
+
headless (default True)
+ - Actually launch a browser?
+
+
+
sandbox_enabled (default False)
+ - Enable sandbox-
+a persnickety thing depending on environment, OS, user, etc
+
+
+
tmp_dir (default None)
+ - Manually set the temporary directory
+
+
+
raises
+
+
+
RuntimeError
+ - Too many kwargs, or browser not found.
+
+
+
NotImplementedError
+ - Pipe is the only channel type it'll accept right now.
+
+
+
+
+
+
logger_parser(cls, record, _old)
+
+
+
Parse (via logging.Filter.parse()
) data from browser stderr for logging.
+
+
arguments
+
+
+
record
+ - the logging.LogRecord
object to read/modify
+
+
+
_old
+ - data that was already stripped out.
+
+
+
+
+
+
get_popen_args(self)
+
+
+
Return the args needed to runc chromium with subprocess.Popen()
.
+
+
+
+
+
get_cli(self)
+
+
+
Return the CLI command for chromium.
+
+
+
+
+
get_env(self)
+
+
+
Return the env needed for chromium.
+
+
+
+
+
clean(self)
+
+
+
Clean up any leftovers form browser, like tmp files.
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
\ No newline at end of file
diff --git a/site/api/choreographer.channels.pipe/index.html b/site/api/choreographer.channels.pipe/index.html
new file mode 100644
index 00000000..668d029c
--- /dev/null
+++ b/site/api/choreographer.channels.pipe/index.html
@@ -0,0 +1,1174 @@
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+ pipe - choreographer
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+choreographer.channels.pipe
+
+module: pipe
+
+
Provides a channel based on operating system file pipes.
+
+Classes
+
+
class Pipe():
+
+
Defines an operating system pipe.
+
+
attributes
+
+
from_external_to_choreo
- Consumers need this, it is the channel the browser uses to talk to choreo.
+
+
+
from_choreo_to_external
- Consumers needs this, it is the channel choreo writes to the browser on.
+
+
+
shutdown_lock
- Once this is locked, the pipe is closed and can't be reopened.
+
+
methods
+
+
__init__(self)
+
+
+
Construct a pipe using os functions.
+
+
+
+
+
write_json(self, obj)
+
+
+
Send one json down the pipe.
+
+
arguments
+
+
+
obj
+ - any python object that serializes to json.
+
+
+
+
+
+
read_jsons(self, blocking)
+
+
+
Read from the pipe and return one or more jsons in a list.
+
+
arguments
+
+
+
blocking
+ - The read option can be set to block or not.
+
+
+
returns
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
\ No newline at end of file
diff --git a/site/api/choreographer.channels/index.html b/site/api/choreographer.channels/index.html
new file mode 100644
index 00000000..d99b8a67
--- /dev/null
+++ b/site/api/choreographer.channels/index.html
@@ -0,0 +1,1059 @@
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+ Index - choreographer
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+choreographer.channels
+
+package: channels
+
+
Channels are classes that choreo and the browser use to communicate.
+
This is a low-level part of the API.
+
+Classes
+
+
class BlockWarning(UserWarning):
+
+
A warning for when block modification operatins used on incompatible OS.
+
+
+
+
class ChannelClosedError(IOError):
+
+
An error to throw when the channel has closed from either end or error.
+
+
+
+
class JSONError(RuntimeError):
+
+
+
+
class Pipe():
+
+
Defines an operating system pipe.
+
+
attributes
+
+
from_external_to_choreo
- Consumers need this, it is the channel the browser uses to talk to choreo.
+
+
+
from_choreo_to_external
- Consumers needs this, it is the channel choreo writes to the browser on.
+
+
+
shutdown_lock
- Once this is locked, the pipe is closed and can't be reopened.
+
+
methods
+
+
__init__(self)
+
+
+
Construct a pipe using os functions.
+
+
+
+
+
write_json(self, obj)
+
+
+
Send one json down the pipe.
+
+
arguments
+
+
+
obj
+ - any python object that serializes to json.
+
+
+
+
+
+
read_jsons(self, blocking)
+
+
+
Read from the pipe and return one or more jsons in a list.
+
+
arguments
+
+
+
blocking
+ - The read option can be set to block or not.
+
+
+
returns
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
\ No newline at end of file
diff --git a/site/api/choreographer.cli/index.html b/site/api/choreographer.cli/index.html
new file mode 100644
index 00000000..7082fc02
--- /dev/null
+++ b/site/api/choreographer.cli/index.html
@@ -0,0 +1,959 @@
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+ cli - choreographer
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+choreographer.cli
+
+package: cli
+
+
cli provides some tools that are used on the commandline (and to download chrome).
+
+Functions
+get_chrome(arch, i, path, verbose)
+
+
+
Download google chrome from google-chrome-for-testing server.
+
+
arguments
+
+
+
arch
+ - the target platform/os, as understood by google's json directory.
+
+
+
i
+ - the chrome version: -1 being the latest version, 0 being the oldest
+still in the testing directory.
+
+
+
path
+ - where to download it too (the folder).
+
+
+
verbose
+ - print out version found
+
+
+
+get_chrome_sync(arch, i, path, verbose)
+
+
+
Download chrome synchronously: see get_chrome()
.
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
\ No newline at end of file
diff --git a/site/api/choreographer.errors/index.html b/site/api/choreographer.errors/index.html
new file mode 100644
index 00000000..e910c498
--- /dev/null
+++ b/site/api/choreographer.errors/index.html
@@ -0,0 +1,1442 @@
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+ errors - choreographer
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+choreographer.errors
+
+module: errors
+
+
A compilation of the errors available in choreographer.
+
+Classes
+
+
class UnhandledMessageWarning(UserWarning):
+
+
+
+
class BrowserClosedError(RuntimeError):
+
+
An error for when the browser is closed accidently (during access).
+
+
+
+
class BrowserFailedError(RuntimeError):
+
+
An error for when the browser fails to launch.
+
+
+
+
class BlockWarning(UserWarning):
+
+
A warning for when block modification operatins used on incompatible OS.
+
+
+
+
class ChannelClosedError(IOError):
+
+
An error to throw when the channel has closed from either end or error.
+
+
+
+
+
+
Raise a general error reported by the devtools protocol.
+
+
attributes
+
+
+
+
+
+
+
methods
+
+
+
+
+
Construct a new DevtoolsProtocolError.
+
+
arguments
+
+
+
response
+ - the json response that contains the error
+
+
+
+
+
+
+
class ExperimentalFeatureWarning(UserWarning):
+
+
An warning to report that a feature may or may not work.
+
+
+
+
class MessageTypeError(TypeError):
+
+
An error for poorly formatted devtools protocol message.
+
+
methods
+
+
__init__(self, key, value, expected_type)
+
+
+
Construct a message about a poorly formed protocol message.
+
+
arguments
+
+
+
key
+ - the key that has the badly typed value
+
+
+
value
+ - the type of the value that is incorrect
+
+
+
expected_type
+ - the type that was expected
+
+
+
+
+
+
+
class MissingKeyError(ValueError):
+
+
An error for poorly formatted devtools protocol message.
+
+
methods
+
+
__init__(self, key, obj)
+
+
+
Construct a MissingKeyError specifying which key was missing.
+
+
arguments
+
+
+
key
+ - the missing key
+
+
+
obj
+ - the message without the key
+
+
+
+
+
+
+
class TmpDirWarning(UserWarning):
+
+
A warning if for whatever reason we can't eliminate the tmp dir.
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
\ No newline at end of file
diff --git a/site/api/choreographer.protocol.devtools_async/index.html b/site/api/choreographer.protocol.devtools_async/index.html
new file mode 100644
index 00000000..a79776aa
--- /dev/null
+++ b/site/api/choreographer.protocol.devtools_async/index.html
@@ -0,0 +1,1663 @@
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+ devtools_async - choreographer
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+choreographer.protocol.devtools_async
+
+
+
+
Provide a lower-level async interface to the Devtools Protocol.
+
+Classes
+
+
class Session():
+
+
A session is a single conversation with a single target.
+
+
attributes
+
+
session_id
- The id of the session given by the browser.
+
+
+
message_id
- All messages are counted per session and this is the current message id.
+
+
+
subscriptions
- Not documented.
+
+
methods
+
+
__init__(self, session_id, broker)
+
+
+
Construct a session from the browser as an object.
+
A session is like an open conversation with a target.
+All commands are sent on sessions.
+
+
arguments
+
+
+
broker
+ - a reference to the browser's broker
+
+
+
session_id
+ - the id given by the browser
+
+
+
+
+
+
send_command(self, command, params)
+
+
+
Send a devtools command on the session.
+
https://chromedevtools.github.io/devtools-protocol/
+
+
arguments
+
+
+
command
+ - devtools command to send
+
+
+
params
+ - the parameters to send
+
+
+
returns
+
+
A message key (session, message id) tuple or None
+
+
+
+
+
subscribe(self, string, callback, repeating)
+
+
+
Subscribe to an event on this session.
+
+
arguments
+
+
+
string
+ - the name of the event. Can use * wildcard at the end.
+
+
+
callback
+ - the callback (which takes a message dict and returns nothing)
+
+
+
repeating
+ - default True, should the callback execute more than once
+
+
+
+
+
+
unsubscribe(self, string)
+
+
+
Remove a subscription.
+
+
arguments
+
+
+
string
+ - the subscription to remove.
+
+
+
+
+
+
subscribe_once(self, string)
+
+
+
Return a future for a browser event.
+
Generally python asyncio doesn't recommend futures.
+
But in this case, one must call subscribe_once and await it later,
+generally because they must subscribe and then provoke the event.
+
+
arguments
+
+
+
string
+ - the event to subscribe to
+
+
+
returns
+
+
A future to be awaited later, the complete event.
+
+
+
+
+
+
class Target():
+
+
A target like a browser, tab, or others. It sends commands. It has sessions.
+
+
attributes
+
+
target_id
- The browser's ID of the target.
+
+
+
sessions
- A list of all the sessions for this target.
+
+
methods
+
+
__init__(self, target_id, broker)
+
+
+
Create a target after one ahs been created by the browser.
+
+
arguments
+
+
+
broker
+ - a reference to the browser's broker
+
+
+
target_id
+ - the id given by the browser
+
+
+
+
+
+
get_session(self)
+
+
+
Retrieve the first session of the target, if it exists.
+
+
+
+
+
send_command(self, command, params)
+
+
+
Send a command to the first session in a target.
+
https://chromedevtools.github.io/devtools-protocol/
+
+
arguments
+
+
+
command
+ - devtools command to send
+
+
+
params
+ - the parameters to send
+
+
+
+
+
+
create_session(self)
+
+
+
Create a new session on this target.
+
+
+
+
+
close_session(self, session_id)
+
+
+
Close a session by session_id.
+
+
arguments
+
+
+
session_id
+ - the session to close
+
+
+
+
+
+
subscribe(self, string, callback, repeating)
+
+
+
Subscribe to an event on the main session of this target.
+
+
arguments
+
+
+
string
+ - the name of the event. Can use * wildcard at the end.
+
+
+
callback
+ - the callback (which takes a message dict and returns nothing)
+
+
+
repeating
+ - default True, should the callback execute more than once
+
+
+
+
+
+
unsubscribe(self, string)
+
+
+
Remove a subscription.
+
+
arguments
+
+
+
string
+ - the subscription to remove.
+
+
+
+
+
+
subscribe_once(self, string)
+
+
+
Return a future for a browser event for the first session of this target.
+
Generally python asyncio doesn't recommend futures.
+
But in this case, one must call subscribe_once and await it later,
+generally because they must subscribe and then provoke the event.
+
+
arguments
+
+
+
string
+ - the event to subscribe to
+
+
+
returns
+
+
A future to be awaited later, the complete event.
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
\ No newline at end of file
diff --git a/site/api/choreographer.protocol.devtools_sync/index.html b/site/api/choreographer.protocol.devtools_sync/index.html
new file mode 100644
index 00000000..3097ac02
--- /dev/null
+++ b/site/api/choreographer.protocol.devtools_sync/index.html
@@ -0,0 +1,1355 @@
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+ devtools_sync - choreographer
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+choreographer.protocol.devtools_sync
+
+
+
+
Provide a lower-level sync interface to the Devtools Protocol.
+
+Classes
+
+
class SessionSync():
+
+
A session is a single conversation with a single target.
+
+
attributes
+
+
session_id
- The id of the session given by the browser.
+
+
+
message_id
- All messages are counted per session and this is the current message id.
+
+
methods
+
+
__init__(self, session_id, broker)
+
+
+
Construct a session from the browser as an object.
+
A session is like an open conversation with a target.
+All commands are sent on sessions.
+
+
arguments
+
+
+
broker
+ - a reference to the browser's broker
+
+
+
session_id
+ - the id given by the browser
+
+
+
+
+
+
send_command(self, command, params)
+
+
+
Send a devtools command on the session.
+
https://chromedevtools.github.io/devtools-protocol/
+
+
arguments
+
+
+
command
+ - devtools command to send
+
+
+
params
+ - the parameters to send
+
+
+
returns
+
+
A message key (session, message id) tuple or None
+
+
+
+
+
+
class TargetSync():
+
+
A target like a browser, tab, or others. It sends commands. It has sessions.
+
+
attributes
+
+
target_id
- The browser's ID of the target.
+
+
+
sessions
- A list of all the sessions for this target.
+
+
methods
+
+
__init__(self, target_id, broker)
+
+
+
Create a target after one ahs been created by the browser.
+
+
arguments
+
+
+
broker
+ - a reference to the browser's broker
+
+
+
target_id
+ - the id given by the browser
+
+
+
+
+
+
get_session(self)
+
+
+
Retrieve the first session of the target, if it exists.
+
+
+
+
+
send_command(self, command, params)
+
+
+
Send a command to the first session in a target.
+
https://chromedevtools.github.io/devtools-protocol/
+
+
arguments
+
+
+
command
+ - devtools command to send
+
+
+
params
+ - the parameters to send
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
\ No newline at end of file
diff --git a/site/api/choreographer.protocol/index.html b/site/api/choreographer.protocol/index.html
new file mode 100644
index 00000000..c8bb8a63
--- /dev/null
+++ b/site/api/choreographer.protocol/index.html
@@ -0,0 +1,1367 @@
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+ Index - choreographer
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+choreographer.protocol
+
+package: protocol
+
+
Provides various implementations of Session and Target.
+
It includes helpers and constants for the Chrome Devtools Protocol.
+
+Globals
+BrowserResponse
- The type for a response from the browser. Is really a dict()
.
+BrowserCommand
- The type for a command to the browser. Is really a dict()
.
+MessageKey
- The type for id'ing a message/response. It is tuple(session_id, message_id)
.
+Functions
+verify_params(obj)
+
+
+
Verify the message obj hast he proper keys and values.
+
+
arguments
+
+
+
obj
+ - the object to check.
+
+
+
Raises
+
+
+
MissingKeyError
+- if a key is missing.
+
+
+
MessageTypeError
+- if a value type is incorrect.
+
+
+
RuntimeError
+- if there are strange keys.
+
+
+
+calculate_message_key(msg)
+
+
+
Given a message to/from the browser, calculate the key corresponding to the command.
+
Every message is uniquely identified by its sessionId and id (counter).
+
+
arguments
+
+
+
msg
+ - the message for which to calculate the key.
+
+
+
+match_message_key(response, key)
+
+
+
Report True if a response matches with a certain key (sessionId, id).
+
+
arguments
+
+
+
response
+ - the object response from the browser
+
+
+
key
+ - the (sessionId, id) key tubple we're looking for
+
+
+
+is_event(response)
+
+
+
Return true if the browser response is an event notification.
+
+
+get_target_id_from_result(response)
+
+
+
Extract target id from a browser response.
+
+
arguments
+
+
+
response
+ - the browser response to extract the targetId from.
+
+
+
+get_session_id_from_result(response)
+
+
+
Extract session id from a browser response.
+
+
arguments
+
+
+
response
+ - the browser response to extract the sessionId from.
+
+
+
+get_error_from_result(response)
+
+
+
Extract error from a browser response.
+
+
arguments
+
+
+
response
+ - the browser response to extract the error from.
+
+
+
+Classes
+
+
class Ecode(enum.Enum):
+
+
Ecodes are a list of possible error codes chrome returns.
+
+
attributes
+
+
TARGET_NOT_FOUND
- Self explanatory.
+
+
+
+
+
+
Raise a general error reported by the devtools protocol.
+
+
attributes
+
+
+
+
+
+
+
methods
+
+
+
+
+
Construct a new DevtoolsProtocolError.
+
+
arguments
+
+
+
response
+ - the json response that contains the error
+
+
+
+
+
+
+
class MessageTypeError(TypeError):
+
+
An error for poorly formatted devtools protocol message.
+
+
methods
+
+
__init__(self, key, value, expected_type)
+
+
+
Construct a message about a poorly formed protocol message.
+
+
arguments
+
+
+
key
+ - the key that has the badly typed value
+
+
+
value
+ - the type of the value that is incorrect
+
+
+
expected_type
+ - the type that was expected
+
+
+
+
+
+
+
class MissingKeyError(ValueError):
+
+
An error for poorly formatted devtools protocol message.
+
+
methods
+
+
__init__(self, key, obj)
+
+
+
Construct a MissingKeyError specifying which key was missing.
+
+
arguments
+
+
+
key
+ - the missing key
+
+
+
obj
+ - the message without the key
+
+
+
+
+
+
+
class ExperimentalFeatureWarning(UserWarning):
+
+
An warning to report that a feature may or may not work.
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
\ No newline at end of file
diff --git a/site/api/choreographer.utils/index.html b/site/api/choreographer.utils/index.html
new file mode 100644
index 00000000..85d3ec02
--- /dev/null
+++ b/site/api/choreographer.utils/index.html
@@ -0,0 +1,1212 @@
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+ utils - choreographer
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+choreographer.utils
+
+package: utils
+
+
Contains functions and class that primarily help us with the OS.
+
+Functions
+get_browser_path(args, kwargs)
+
+
+
Call browser_which()
but check for user override first.
+
It looks for the browser in path.
+
Accepts the same arguments as `browser_which':
+
+
arguments
+
+
+
executable_names
+ - the list of names to look for
+
+
+
skip_local
+ - (default False) don't look for a choreo download of anything.
+
+
+
+Classes
+
+
class TmpDirectory():
+
+
The python stdlib TemporaryDirectory
wrapper for easier use.
+
Python's TemporaryDirectory
suffered a couple API changes that mean
+you can't call it the same way for similar versions. This wrapper is
+also much more aggressive about deleting the directory when it's done,
+not necessarily relying on OS functions.
+
+
attributes
+
+
temp_dir
- A reference to the underlying python TemporaryDirectory
implementation.
+
+
+
path
- The path to the temporary directory.
+
+
+
exists
- A flag to indicate if the directory still exists.
+
+
methods
+
+
__init__(self, path, sneak)
+
+
+
Construct a wrapped TemporaryDirectory
.
+
+
arguments
+
+
+
path
+ - manually specify the directory to use
+
+
+
sneak
+ - (default False) avoid using /tmp
+Ubuntu's snap will sandbox /tmp
+
+
+
+
+
+
clean(self)
+
+
+
Try several different ways to eliminate the temporary directory.
+
+
+
+
+
+
class TmpDirWarning(UserWarning):
+
+
A warning if for whatever reason we can't eliminate the tmp dir.
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
\ No newline at end of file
diff --git a/site/api/choreographer/index.html b/site/api/choreographer/index.html
new file mode 100644
index 00000000..45c1ffad
--- /dev/null
+++ b/site/api/choreographer/index.html
@@ -0,0 +1,1994 @@
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+ Index - choreographer
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+choreographer
+
+package: choreographer
+
+
choreographer is a browser controller for python.
+
choreographer is natively async, so while there are two main entrypoints:
+classes Browser
and BrowserSync
, the sync version is very limited, functioning
+as a building block for more featureful implementations.
+
See the main README for a quickstart.
+
+Classes
+
+
class Browser(choreographer.protocol.devtools_async.Target):
+
+
Browser
is the async implementation of Browser
.
+
+
attributes
+
+
target_id
- The browser's ID of the target.
+
+
+
sessions
- A list of all the sessions for this target.
+
+
+
tabs
- A mapping by target_id of all the targets which are open tabs.
+
+
+
targets
- A mapping by target_id of ALL the targets.
+
+
methods
+
+
__init__(self, path, browser_cls, channel_cls, kwargs)
+
+
+
Construct a new browser instance.
+
+
arguments
+
+
+
path
+ - The path to the browser executable.
+
+
+
browser_cls
+ - The type of browser (default: Chromium
).
+
+
+
channel_cls
+ - The type of channel to browser (default: Pipe
).
+
+
+
kwargs
+ - The arguments that the browser_cls takes. For example,
+headless=True/False, enable_gpu=True/False, etc.
+
+
+
+
+
+
get_session(self)
+
+
+
Retrieve the first session of the target, if it exists.
+
+
+
+
+
send_command(self, command, params)
+
+
+
Send a command to the first session in a target.
+
https://chromedevtools.github.io/devtools-protocol/
+
+
arguments
+
+
+
command
+ - devtools command to send
+
+
+
params
+ - the parameters to send
+
+
+
+
+
+
close_session(self, session_id)
+
+
+
Close a session by session_id.
+
+
arguments
+
+
+
session_id
+ - the session to close
+
+
+
+
+
+
subscribe(self, string, callback, repeating)
+
+
+
Subscribe to an event on the main session of this target.
+
+
arguments
+
+
+
string
+ - the name of the event. Can use * wildcard at the end.
+
+
+
callback
+ - the callback (which takes a message dict and returns nothing)
+
+
+
repeating
+ - default True, should the callback execute more than once
+
+
+
+
+
+
unsubscribe(self, string)
+
+
+
Remove a subscription.
+
+
arguments
+
+
+
string
+ - the subscription to remove.
+
+
+
+
+
+
subscribe_once(self, string)
+
+
+
Return a future for a browser event for the first session of this target.
+
Generally python asyncio doesn't recommend futures.
+
But in this case, one must call subscribe_once and await it later,
+generally because they must subscribe and then provoke the event.
+
+
arguments
+
+
+
string
+ - the event to subscribe to
+
+
+
returns
+
+
A future to be awaited later, the complete event.
+
+
+
+
+
+
+
get_tab(self)
+
+
+
Get the first tab if there is one. Useful for default tabs.
+
+
returns
+
+
+
+
+
populate_targets(self)
+
+
+
Solicit the actual browser for all targets to add to the browser object.
+
+
+
+
+
create_session(self)
+
+
+
Create a browser session. Only in supported browsers, is experimental.
+
+
returns
+
+
+
+
+
create_tab(self, url, width, height)
+
+
+
arguments
+
+
+
url
+ - the url to navigate to, default ""
+
+
+
width
+ - the width of the tab (headless only)
+
+
+
height
+ - the height of the tab (headless only)
+
+
+
returns
+
+
+
+
+
close_tab(self, target_id)
+
+
+
Close a tab by its id.
+
+
arguments
+
+
+
target_id
+ - the targetId of the tab to close.
+
+
+
+
+
+
+
class Tab(choreographer.protocol.devtools_async.Target):
+
+
A wrapper for Target
, so user can use Tab
, not Target
.
+
+
attributes
+
+
target_id
- The browser's ID of the target.
+
+
+
sessions
- A list of all the sessions for this target.
+
+
methods
+
+
__init__(self, target_id, broker)
+
+
+
Create a target after one ahs been created by the browser.
+
+
arguments
+
+
+
broker
+ - a reference to the browser's broker
+
+
+
target_id
+ - the id given by the browser
+
+
+
+
+
+
get_session(self)
+
+
+
Retrieve the first session of the target, if it exists.
+
+
+
+
+
send_command(self, command, params)
+
+
+
Send a command to the first session in a target.
+
https://chromedevtools.github.io/devtools-protocol/
+
+
arguments
+
+
+
command
+ - devtools command to send
+
+
+
params
+ - the parameters to send
+
+
+
+
+
+
create_session(self)
+
+
+
Create a new session on this target.
+
+
+
+
+
close_session(self, session_id)
+
+
+
Close a session by session_id.
+
+
arguments
+
+
+
session_id
+ - the session to close
+
+
+
+
+
+
subscribe(self, string, callback, repeating)
+
+
+
Subscribe to an event on the main session of this target.
+
+
arguments
+
+
+
string
+ - the name of the event. Can use * wildcard at the end.
+
+
+
callback
+ - the callback (which takes a message dict and returns nothing)
+
+
+
repeating
+ - default True, should the callback execute more than once
+
+
+
+
+
+
unsubscribe(self, string)
+
+
+
Remove a subscription.
+
+
arguments
+
+
+
string
+ - the subscription to remove.
+
+
+
+
+
+
subscribe_once(self, string)
+
+
+
Return a future for a browser event for the first session of this target.
+
Generally python asyncio doesn't recommend futures.
+
But in this case, one must call subscribe_once and await it later,
+generally because they must subscribe and then provoke the event.
+
+
arguments
+
+
+
string
+ - the event to subscribe to
+
+
+
returns
+
+
A future to be awaited later, the complete event.
+
+
+
+
+
+
+
class BrowserSync(choreographer.protocol.devtools_sync.TargetSync):
+
+
BrowserSync
is the sync implementation of Browser
.
+
+
attributes
+
+
target_id
- The browser's ID of the target.
+
+
+
sessions
- A list of all the sessions for this target.
+
+
+
tabs
- A mapping by target_id of all the targets which are open tabs.
+
+
+
targets
- A mapping by target_id of ALL the targets.
+
+
methods
+
+
__init__(self, path, browser_cls, channel_cls, kwargs)
+
+
+
Construct a new browser instance.
+
+
arguments
+
+
+
path
+ - The path to the browser executable.
+
+
+
browser_cls
+ - The type of browser (default: Chromium
).
+
+
+
channel_cls
+ - The type of channel to browser (default: Pipe
).
+
+
+
kwargs
+ - The arguments that the browser_cls takes. For example,
+headless=True/False, enable_gpu=True/False, etc.
+
+
+
+
+
+
get_session(self)
+
+
+
Retrieve the first session of the target, if it exists.
+
+
+
+
+
send_command(self, command, params)
+
+
+
Send a command to the first session in a target.
+
https://chromedevtools.github.io/devtools-protocol/
+
+
arguments
+
+
+
command
+ - devtools command to send
+
+
+
params
+ - the parameters to send
+
+
+
+
+
+
+
+
get_tab(self)
+
+
+
Get the first tab if there is one. Useful for default tabs.
+
+
+
+
+
start_output_thread(self, kwargs)
+
+
+
Start a separate thread that dumps all messages received to stdout.
+
+
arguments
+
+
+
kwargs
+ - passed directly to print().
+
+
+
+
+
+
+
class TabSync(choreographer.protocol.devtools_sync.TargetSync):
+
+
A wrapper for TargetSync
, so user can use TabSync
, not TargetSync
.
+
+
attributes
+
+
target_id
- The browser's ID of the target.
+
+
+
sessions
- A list of all the sessions for this target.
+
+
methods
+
+
__init__(self, target_id, broker)
+
+
+
Create a target after one ahs been created by the browser.
+
+
arguments
+
+
+
broker
+ - a reference to the browser's broker
+
+
+
target_id
+ - the id given by the browser
+
+
+
+
+
+
get_session(self)
+
+
+
Retrieve the first session of the target, if it exists.
+
+
+
+
+
send_command(self, command, params)
+
+
+
Send a command to the first session in a target.
+
https://chromedevtools.github.io/devtools-protocol/
+
+
arguments
+
+
+
command
+ - devtools command to send
+
+
+
params
+ - the parameters to send
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
+
\ No newline at end of file
diff --git a/site/assets/images/favicon.png b/site/assets/images/favicon.png
new file mode 100644
index 00000000..1cf13b9f
Binary files /dev/null and b/site/assets/images/favicon.png differ
diff --git a/site/assets/javascripts/bundle.60a45f97.min.js b/site/assets/javascripts/bundle.60a45f97.min.js
new file mode 100644
index 00000000..f8f18f6c
--- /dev/null
+++ b/site/assets/javascripts/bundle.60a45f97.min.js
@@ -0,0 +1,16 @@
+"use strict";(()=>{var Wi=Object.create;var gr=Object.defineProperty;var Di=Object.getOwnPropertyDescriptor;var Vi=Object.getOwnPropertyNames,Vt=Object.getOwnPropertySymbols,Ni=Object.getPrototypeOf,yr=Object.prototype.hasOwnProperty,ao=Object.prototype.propertyIsEnumerable;var io=(e,t,r)=>t in e?gr(e,t,{enumerable:!0,configurable:!0,writable:!0,value:r}):e[t]=r,$=(e,t)=>{for(var r in t||(t={}))yr.call(t,r)&&io(e,r,t[r]);if(Vt)for(var r of Vt(t))ao.call(t,r)&&io(e,r,t[r]);return e};var so=(e,t)=>{var r={};for(var o in e)yr.call(e,o)&&t.indexOf(o)<0&&(r[o]=e[o]);if(e!=null&&Vt)for(var o of Vt(e))t.indexOf(o)<0&&ao.call(e,o)&&(r[o]=e[o]);return r};var xr=(e,t)=>()=>(t||e((t={exports:{}}).exports,t),t.exports);var zi=(e,t,r,o)=>{if(t&&typeof t=="object"||typeof t=="function")for(let n of Vi(t))!yr.call(e,n)&&n!==r&&gr(e,n,{get:()=>t[n],enumerable:!(o=Di(t,n))||o.enumerable});return e};var Mt=(e,t,r)=>(r=e!=null?Wi(Ni(e)):{},zi(t||!e||!e.__esModule?gr(r,"default",{value:e,enumerable:!0}):r,e));var co=(e,t,r)=>new Promise((o,n)=>{var i=p=>{try{s(r.next(p))}catch(c){n(c)}},a=p=>{try{s(r.throw(p))}catch(c){n(c)}},s=p=>p.done?o(p.value):Promise.resolve(p.value).then(i,a);s((r=r.apply(e,t)).next())});var lo=xr((Er,po)=>{(function(e,t){typeof Er=="object"&&typeof po!="undefined"?t():typeof define=="function"&&define.amd?define(t):t()})(Er,function(){"use strict";function e(r){var o=!0,n=!1,i=null,a={text:!0,search:!0,url:!0,tel:!0,email:!0,password:!0,number:!0,date:!0,month:!0,week:!0,time:!0,datetime:!0,"datetime-local":!0};function s(k){return!!(k&&k!==document&&k.nodeName!=="HTML"&&k.nodeName!=="BODY"&&"classList"in k&&"contains"in k.classList)}function p(k){var ft=k.type,qe=k.tagName;return!!(qe==="INPUT"&&a[ft]&&!k.readOnly||qe==="TEXTAREA"&&!k.readOnly||k.isContentEditable)}function c(k){k.classList.contains("focus-visible")||(k.classList.add("focus-visible"),k.setAttribute("data-focus-visible-added",""))}function l(k){k.hasAttribute("data-focus-visible-added")&&(k.classList.remove("focus-visible"),k.removeAttribute("data-focus-visible-added"))}function f(k){k.metaKey||k.altKey||k.ctrlKey||(s(r.activeElement)&&c(r.activeElement),o=!0)}function u(k){o=!1}function d(k){s(k.target)&&(o||p(k.target))&&c(k.target)}function y(k){s(k.target)&&(k.target.classList.contains("focus-visible")||k.target.hasAttribute("data-focus-visible-added"))&&(n=!0,window.clearTimeout(i),i=window.setTimeout(function(){n=!1},100),l(k.target))}function L(k){document.visibilityState==="hidden"&&(n&&(o=!0),X())}function X(){document.addEventListener("mousemove",J),document.addEventListener("mousedown",J),document.addEventListener("mouseup",J),document.addEventListener("pointermove",J),document.addEventListener("pointerdown",J),document.addEventListener("pointerup",J),document.addEventListener("touchmove",J),document.addEventListener("touchstart",J),document.addEventListener("touchend",J)}function te(){document.removeEventListener("mousemove",J),document.removeEventListener("mousedown",J),document.removeEventListener("mouseup",J),document.removeEventListener("pointermove",J),document.removeEventListener("pointerdown",J),document.removeEventListener("pointerup",J),document.removeEventListener("touchmove",J),document.removeEventListener("touchstart",J),document.removeEventListener("touchend",J)}function J(k){k.target.nodeName&&k.target.nodeName.toLowerCase()==="html"||(o=!1,te())}document.addEventListener("keydown",f,!0),document.addEventListener("mousedown",u,!0),document.addEventListener("pointerdown",u,!0),document.addEventListener("touchstart",u,!0),document.addEventListener("visibilitychange",L,!0),X(),r.addEventListener("focus",d,!0),r.addEventListener("blur",y,!0),r.nodeType===Node.DOCUMENT_FRAGMENT_NODE&&r.host?r.host.setAttribute("data-js-focus-visible",""):r.nodeType===Node.DOCUMENT_NODE&&(document.documentElement.classList.add("js-focus-visible"),document.documentElement.setAttribute("data-js-focus-visible",""))}if(typeof window!="undefined"&&typeof document!="undefined"){window.applyFocusVisiblePolyfill=e;var t;try{t=new CustomEvent("focus-visible-polyfill-ready")}catch(r){t=document.createEvent("CustomEvent"),t.initCustomEvent("focus-visible-polyfill-ready",!1,!1,{})}window.dispatchEvent(t)}typeof document!="undefined"&&e(document)})});var qr=xr((hy,On)=>{"use strict";/*!
+ * escape-html
+ * Copyright(c) 2012-2013 TJ Holowaychuk
+ * Copyright(c) 2015 Andreas Lubbe
+ * Copyright(c) 2015 Tiancheng "Timothy" Gu
+ * MIT Licensed
+ */var $a=/["'&<>]/;On.exports=Pa;function Pa(e){var t=""+e,r=$a.exec(t);if(!r)return t;var o,n="",i=0,a=0;for(i=r.index;i{/*!
+ * clipboard.js v2.0.11
+ * https://clipboardjs.com/
+ *
+ * Licensed MIT © Zeno Rocha
+ */(function(t,r){typeof It=="object"&&typeof Yr=="object"?Yr.exports=r():typeof define=="function"&&define.amd?define([],r):typeof It=="object"?It.ClipboardJS=r():t.ClipboardJS=r()})(It,function(){return function(){var e={686:function(o,n,i){"use strict";i.d(n,{default:function(){return Ui}});var a=i(279),s=i.n(a),p=i(370),c=i.n(p),l=i(817),f=i.n(l);function u(V){try{return document.execCommand(V)}catch(A){return!1}}var d=function(A){var M=f()(A);return u("cut"),M},y=d;function L(V){var A=document.documentElement.getAttribute("dir")==="rtl",M=document.createElement("textarea");M.style.fontSize="12pt",M.style.border="0",M.style.padding="0",M.style.margin="0",M.style.position="absolute",M.style[A?"right":"left"]="-9999px";var F=window.pageYOffset||document.documentElement.scrollTop;return M.style.top="".concat(F,"px"),M.setAttribute("readonly",""),M.value=V,M}var X=function(A,M){var F=L(A);M.container.appendChild(F);var D=f()(F);return u("copy"),F.remove(),D},te=function(A){var M=arguments.length>1&&arguments[1]!==void 0?arguments[1]:{container:document.body},F="";return typeof A=="string"?F=X(A,M):A instanceof HTMLInputElement&&!["text","search","url","tel","password"].includes(A==null?void 0:A.type)?F=X(A.value,M):(F=f()(A),u("copy")),F},J=te;function k(V){"@babel/helpers - typeof";return typeof Symbol=="function"&&typeof Symbol.iterator=="symbol"?k=function(M){return typeof M}:k=function(M){return M&&typeof Symbol=="function"&&M.constructor===Symbol&&M!==Symbol.prototype?"symbol":typeof M},k(V)}var ft=function(){var A=arguments.length>0&&arguments[0]!==void 0?arguments[0]:{},M=A.action,F=M===void 0?"copy":M,D=A.container,Y=A.target,$e=A.text;if(F!=="copy"&&F!=="cut")throw new Error('Invalid "action" value, use either "copy" or "cut"');if(Y!==void 0)if(Y&&k(Y)==="object"&&Y.nodeType===1){if(F==="copy"&&Y.hasAttribute("disabled"))throw new Error('Invalid "target" attribute. Please use "readonly" instead of "disabled" attribute');if(F==="cut"&&(Y.hasAttribute("readonly")||Y.hasAttribute("disabled")))throw new Error(`Invalid "target" attribute. You can't cut text from elements with "readonly" or "disabled" attributes`)}else throw new Error('Invalid "target" value, use a valid Element');if($e)return J($e,{container:D});if(Y)return F==="cut"?y(Y):J(Y,{container:D})},qe=ft;function Fe(V){"@babel/helpers - typeof";return typeof Symbol=="function"&&typeof Symbol.iterator=="symbol"?Fe=function(M){return typeof M}:Fe=function(M){return M&&typeof Symbol=="function"&&M.constructor===Symbol&&M!==Symbol.prototype?"symbol":typeof M},Fe(V)}function ki(V,A){if(!(V instanceof A))throw new TypeError("Cannot call a class as a function")}function no(V,A){for(var M=0;M0&&arguments[0]!==void 0?arguments[0]:{};this.action=typeof D.action=="function"?D.action:this.defaultAction,this.target=typeof D.target=="function"?D.target:this.defaultTarget,this.text=typeof D.text=="function"?D.text:this.defaultText,this.container=Fe(D.container)==="object"?D.container:document.body}},{key:"listenClick",value:function(D){var Y=this;this.listener=c()(D,"click",function($e){return Y.onClick($e)})}},{key:"onClick",value:function(D){var Y=D.delegateTarget||D.currentTarget,$e=this.action(Y)||"copy",Dt=qe({action:$e,container:this.container,target:this.target(Y),text:this.text(Y)});this.emit(Dt?"success":"error",{action:$e,text:Dt,trigger:Y,clearSelection:function(){Y&&Y.focus(),window.getSelection().removeAllRanges()}})}},{key:"defaultAction",value:function(D){return vr("action",D)}},{key:"defaultTarget",value:function(D){var Y=vr("target",D);if(Y)return document.querySelector(Y)}},{key:"defaultText",value:function(D){return vr("text",D)}},{key:"destroy",value:function(){this.listener.destroy()}}],[{key:"copy",value:function(D){var Y=arguments.length>1&&arguments[1]!==void 0?arguments[1]:{container:document.body};return J(D,Y)}},{key:"cut",value:function(D){return y(D)}},{key:"isSupported",value:function(){var D=arguments.length>0&&arguments[0]!==void 0?arguments[0]:["copy","cut"],Y=typeof D=="string"?[D]:D,$e=!!document.queryCommandSupported;return Y.forEach(function(Dt){$e=$e&&!!document.queryCommandSupported(Dt)}),$e}}]),M}(s()),Ui=Fi},828:function(o){var n=9;if(typeof Element!="undefined"&&!Element.prototype.matches){var i=Element.prototype;i.matches=i.matchesSelector||i.mozMatchesSelector||i.msMatchesSelector||i.oMatchesSelector||i.webkitMatchesSelector}function a(s,p){for(;s&&s.nodeType!==n;){if(typeof s.matches=="function"&&s.matches(p))return s;s=s.parentNode}}o.exports=a},438:function(o,n,i){var a=i(828);function s(l,f,u,d,y){var L=c.apply(this,arguments);return l.addEventListener(u,L,y),{destroy:function(){l.removeEventListener(u,L,y)}}}function p(l,f,u,d,y){return typeof l.addEventListener=="function"?s.apply(null,arguments):typeof u=="function"?s.bind(null,document).apply(null,arguments):(typeof l=="string"&&(l=document.querySelectorAll(l)),Array.prototype.map.call(l,function(L){return s(L,f,u,d,y)}))}function c(l,f,u,d){return function(y){y.delegateTarget=a(y.target,f),y.delegateTarget&&d.call(l,y)}}o.exports=p},879:function(o,n){n.node=function(i){return i!==void 0&&i instanceof HTMLElement&&i.nodeType===1},n.nodeList=function(i){var a=Object.prototype.toString.call(i);return i!==void 0&&(a==="[object NodeList]"||a==="[object HTMLCollection]")&&"length"in i&&(i.length===0||n.node(i[0]))},n.string=function(i){return typeof i=="string"||i instanceof String},n.fn=function(i){var a=Object.prototype.toString.call(i);return a==="[object Function]"}},370:function(o,n,i){var a=i(879),s=i(438);function p(u,d,y){if(!u&&!d&&!y)throw new Error("Missing required arguments");if(!a.string(d))throw new TypeError("Second argument must be a String");if(!a.fn(y))throw new TypeError("Third argument must be a Function");if(a.node(u))return c(u,d,y);if(a.nodeList(u))return l(u,d,y);if(a.string(u))return f(u,d,y);throw new TypeError("First argument must be a String, HTMLElement, HTMLCollection, or NodeList")}function c(u,d,y){return u.addEventListener(d,y),{destroy:function(){u.removeEventListener(d,y)}}}function l(u,d,y){return Array.prototype.forEach.call(u,function(L){L.addEventListener(d,y)}),{destroy:function(){Array.prototype.forEach.call(u,function(L){L.removeEventListener(d,y)})}}}function f(u,d,y){return s(document.body,u,d,y)}o.exports=p},817:function(o){function n(i){var a;if(i.nodeName==="SELECT")i.focus(),a=i.value;else if(i.nodeName==="INPUT"||i.nodeName==="TEXTAREA"){var s=i.hasAttribute("readonly");s||i.setAttribute("readonly",""),i.select(),i.setSelectionRange(0,i.value.length),s||i.removeAttribute("readonly"),a=i.value}else{i.hasAttribute("contenteditable")&&i.focus();var p=window.getSelection(),c=document.createRange();c.selectNodeContents(i),p.removeAllRanges(),p.addRange(c),a=p.toString()}return a}o.exports=n},279:function(o){function n(){}n.prototype={on:function(i,a,s){var p=this.e||(this.e={});return(p[i]||(p[i]=[])).push({fn:a,ctx:s}),this},once:function(i,a,s){var p=this;function c(){p.off(i,c),a.apply(s,arguments)}return c._=a,this.on(i,c,s)},emit:function(i){var a=[].slice.call(arguments,1),s=((this.e||(this.e={}))[i]||[]).slice(),p=0,c=s.length;for(p;p0&&i[i.length-1])&&(c[0]===6||c[0]===2)){r=0;continue}if(c[0]===3&&(!i||c[1]>i[0]&&c[1]=e.length&&(e=void 0),{value:e&&e[o++],done:!e}}};throw new TypeError(t?"Object is not iterable.":"Symbol.iterator is not defined.")}function N(e,t){var r=typeof Symbol=="function"&&e[Symbol.iterator];if(!r)return e;var o=r.call(e),n,i=[],a;try{for(;(t===void 0||t-- >0)&&!(n=o.next()).done;)i.push(n.value)}catch(s){a={error:s}}finally{try{n&&!n.done&&(r=o.return)&&r.call(o)}finally{if(a)throw a.error}}return i}function q(e,t,r){if(r||arguments.length===2)for(var o=0,n=t.length,i;o1||p(d,L)})},y&&(n[d]=y(n[d])))}function p(d,y){try{c(o[d](y))}catch(L){u(i[0][3],L)}}function c(d){d.value instanceof nt?Promise.resolve(d.value.v).then(l,f):u(i[0][2],d)}function l(d){p("next",d)}function f(d){p("throw",d)}function u(d,y){d(y),i.shift(),i.length&&p(i[0][0],i[0][1])}}function uo(e){if(!Symbol.asyncIterator)throw new TypeError("Symbol.asyncIterator is not defined.");var t=e[Symbol.asyncIterator],r;return t?t.call(e):(e=typeof he=="function"?he(e):e[Symbol.iterator](),r={},o("next"),o("throw"),o("return"),r[Symbol.asyncIterator]=function(){return this},r);function o(i){r[i]=e[i]&&function(a){return new Promise(function(s,p){a=e[i](a),n(s,p,a.done,a.value)})}}function n(i,a,s,p){Promise.resolve(p).then(function(c){i({value:c,done:s})},a)}}function H(e){return typeof e=="function"}function ut(e){var t=function(o){Error.call(o),o.stack=new Error().stack},r=e(t);return r.prototype=Object.create(Error.prototype),r.prototype.constructor=r,r}var zt=ut(function(e){return function(r){e(this),this.message=r?r.length+` errors occurred during unsubscription:
+`+r.map(function(o,n){return n+1+") "+o.toString()}).join(`
+ `):"",this.name="UnsubscriptionError",this.errors=r}});function Qe(e,t){if(e){var r=e.indexOf(t);0<=r&&e.splice(r,1)}}var Ue=function(){function e(t){this.initialTeardown=t,this.closed=!1,this._parentage=null,this._finalizers=null}return e.prototype.unsubscribe=function(){var t,r,o,n,i;if(!this.closed){this.closed=!0;var a=this._parentage;if(a)if(this._parentage=null,Array.isArray(a))try{for(var s=he(a),p=s.next();!p.done;p=s.next()){var c=p.value;c.remove(this)}}catch(L){t={error:L}}finally{try{p&&!p.done&&(r=s.return)&&r.call(s)}finally{if(t)throw t.error}}else a.remove(this);var l=this.initialTeardown;if(H(l))try{l()}catch(L){i=L instanceof zt?L.errors:[L]}var f=this._finalizers;if(f){this._finalizers=null;try{for(var u=he(f),d=u.next();!d.done;d=u.next()){var y=d.value;try{ho(y)}catch(L){i=i!=null?i:[],L instanceof zt?i=q(q([],N(i)),N(L.errors)):i.push(L)}}}catch(L){o={error:L}}finally{try{d&&!d.done&&(n=u.return)&&n.call(u)}finally{if(o)throw o.error}}}if(i)throw new zt(i)}},e.prototype.add=function(t){var r;if(t&&t!==this)if(this.closed)ho(t);else{if(t instanceof e){if(t.closed||t._hasParent(this))return;t._addParent(this)}(this._finalizers=(r=this._finalizers)!==null&&r!==void 0?r:[]).push(t)}},e.prototype._hasParent=function(t){var r=this._parentage;return r===t||Array.isArray(r)&&r.includes(t)},e.prototype._addParent=function(t){var r=this._parentage;this._parentage=Array.isArray(r)?(r.push(t),r):r?[r,t]:t},e.prototype._removeParent=function(t){var r=this._parentage;r===t?this._parentage=null:Array.isArray(r)&&Qe(r,t)},e.prototype.remove=function(t){var r=this._finalizers;r&&Qe(r,t),t instanceof e&&t._removeParent(this)},e.EMPTY=function(){var t=new e;return t.closed=!0,t}(),e}();var Tr=Ue.EMPTY;function qt(e){return e instanceof Ue||e&&"closed"in e&&H(e.remove)&&H(e.add)&&H(e.unsubscribe)}function ho(e){H(e)?e():e.unsubscribe()}var Pe={onUnhandledError:null,onStoppedNotification:null,Promise:void 0,useDeprecatedSynchronousErrorHandling:!1,useDeprecatedNextContext:!1};var dt={setTimeout:function(e,t){for(var r=[],o=2;o0},enumerable:!1,configurable:!0}),t.prototype._trySubscribe=function(r){return this._throwIfClosed(),e.prototype._trySubscribe.call(this,r)},t.prototype._subscribe=function(r){return this._throwIfClosed(),this._checkFinalizedStatuses(r),this._innerSubscribe(r)},t.prototype._innerSubscribe=function(r){var o=this,n=this,i=n.hasError,a=n.isStopped,s=n.observers;return i||a?Tr:(this.currentObservers=null,s.push(r),new Ue(function(){o.currentObservers=null,Qe(s,r)}))},t.prototype._checkFinalizedStatuses=function(r){var o=this,n=o.hasError,i=o.thrownError,a=o.isStopped;n?r.error(i):a&&r.complete()},t.prototype.asObservable=function(){var r=new j;return r.source=this,r},t.create=function(r,o){return new To(r,o)},t}(j);var To=function(e){oe(t,e);function t(r,o){var n=e.call(this)||this;return n.destination=r,n.source=o,n}return t.prototype.next=function(r){var o,n;(n=(o=this.destination)===null||o===void 0?void 0:o.next)===null||n===void 0||n.call(o,r)},t.prototype.error=function(r){var o,n;(n=(o=this.destination)===null||o===void 0?void 0:o.error)===null||n===void 0||n.call(o,r)},t.prototype.complete=function(){var r,o;(o=(r=this.destination)===null||r===void 0?void 0:r.complete)===null||o===void 0||o.call(r)},t.prototype._subscribe=function(r){var o,n;return(n=(o=this.source)===null||o===void 0?void 0:o.subscribe(r))!==null&&n!==void 0?n:Tr},t}(g);var _r=function(e){oe(t,e);function t(r){var o=e.call(this)||this;return o._value=r,o}return Object.defineProperty(t.prototype,"value",{get:function(){return this.getValue()},enumerable:!1,configurable:!0}),t.prototype._subscribe=function(r){var o=e.prototype._subscribe.call(this,r);return!o.closed&&r.next(this._value),o},t.prototype.getValue=function(){var r=this,o=r.hasError,n=r.thrownError,i=r._value;if(o)throw n;return this._throwIfClosed(),i},t.prototype.next=function(r){e.prototype.next.call(this,this._value=r)},t}(g);var At={now:function(){return(At.delegate||Date).now()},delegate:void 0};var Ct=function(e){oe(t,e);function t(r,o,n){r===void 0&&(r=1/0),o===void 0&&(o=1/0),n===void 0&&(n=At);var i=e.call(this)||this;return i._bufferSize=r,i._windowTime=o,i._timestampProvider=n,i._buffer=[],i._infiniteTimeWindow=!0,i._infiniteTimeWindow=o===1/0,i._bufferSize=Math.max(1,r),i._windowTime=Math.max(1,o),i}return t.prototype.next=function(r){var o=this,n=o.isStopped,i=o._buffer,a=o._infiniteTimeWindow,s=o._timestampProvider,p=o._windowTime;n||(i.push(r),!a&&i.push(s.now()+p)),this._trimBuffer(),e.prototype.next.call(this,r)},t.prototype._subscribe=function(r){this._throwIfClosed(),this._trimBuffer();for(var o=this._innerSubscribe(r),n=this,i=n._infiniteTimeWindow,a=n._buffer,s=a.slice(),p=0;p0?e.prototype.schedule.call(this,r,o):(this.delay=o,this.state=r,this.scheduler.flush(this),this)},t.prototype.execute=function(r,o){return o>0||this.closed?e.prototype.execute.call(this,r,o):this._execute(r,o)},t.prototype.requestAsyncId=function(r,o,n){return n===void 0&&(n=0),n!=null&&n>0||n==null&&this.delay>0?e.prototype.requestAsyncId.call(this,r,o,n):(r.flush(this),0)},t}(gt);var Lo=function(e){oe(t,e);function t(){return e!==null&&e.apply(this,arguments)||this}return t}(yt);var kr=new Lo(Oo);var Mo=function(e){oe(t,e);function t(r,o){var n=e.call(this,r,o)||this;return n.scheduler=r,n.work=o,n}return t.prototype.requestAsyncId=function(r,o,n){return n===void 0&&(n=0),n!==null&&n>0?e.prototype.requestAsyncId.call(this,r,o,n):(r.actions.push(this),r._scheduled||(r._scheduled=vt.requestAnimationFrame(function(){return r.flush(void 0)})))},t.prototype.recycleAsyncId=function(r,o,n){var i;if(n===void 0&&(n=0),n!=null?n>0:this.delay>0)return e.prototype.recycleAsyncId.call(this,r,o,n);var a=r.actions;o!=null&&((i=a[a.length-1])===null||i===void 0?void 0:i.id)!==o&&(vt.cancelAnimationFrame(o),r._scheduled=void 0)},t}(gt);var _o=function(e){oe(t,e);function t(){return e!==null&&e.apply(this,arguments)||this}return t.prototype.flush=function(r){this._active=!0;var o=this._scheduled;this._scheduled=void 0;var n=this.actions,i;r=r||n.shift();do if(i=r.execute(r.state,r.delay))break;while((r=n[0])&&r.id===o&&n.shift());if(this._active=!1,i){for(;(r=n[0])&&r.id===o&&n.shift();)r.unsubscribe();throw i}},t}(yt);var me=new _o(Mo);var S=new j(function(e){return e.complete()});function Yt(e){return e&&H(e.schedule)}function Hr(e){return e[e.length-1]}function Xe(e){return H(Hr(e))?e.pop():void 0}function ke(e){return Yt(Hr(e))?e.pop():void 0}function Bt(e,t){return typeof Hr(e)=="number"?e.pop():t}var xt=function(e){return e&&typeof e.length=="number"&&typeof e!="function"};function Gt(e){return H(e==null?void 0:e.then)}function Jt(e){return H(e[bt])}function Xt(e){return Symbol.asyncIterator&&H(e==null?void 0:e[Symbol.asyncIterator])}function Zt(e){return new TypeError("You provided "+(e!==null&&typeof e=="object"?"an invalid object":"'"+e+"'")+" where a stream was expected. You can provide an Observable, Promise, ReadableStream, Array, AsyncIterable, or Iterable.")}function Zi(){return typeof Symbol!="function"||!Symbol.iterator?"@@iterator":Symbol.iterator}var er=Zi();function tr(e){return H(e==null?void 0:e[er])}function rr(e){return fo(this,arguments,function(){var r,o,n,i;return Nt(this,function(a){switch(a.label){case 0:r=e.getReader(),a.label=1;case 1:a.trys.push([1,,9,10]),a.label=2;case 2:return[4,nt(r.read())];case 3:return o=a.sent(),n=o.value,i=o.done,i?[4,nt(void 0)]:[3,5];case 4:return[2,a.sent()];case 5:return[4,nt(n)];case 6:return[4,a.sent()];case 7:return a.sent(),[3,2];case 8:return[3,10];case 9:return r.releaseLock(),[7];case 10:return[2]}})})}function or(e){return H(e==null?void 0:e.getReader)}function U(e){if(e instanceof j)return e;if(e!=null){if(Jt(e))return ea(e);if(xt(e))return ta(e);if(Gt(e))return ra(e);if(Xt(e))return Ao(e);if(tr(e))return oa(e);if(or(e))return na(e)}throw Zt(e)}function ea(e){return new j(function(t){var r=e[bt]();if(H(r.subscribe))return r.subscribe(t);throw new TypeError("Provided object does not correctly implement Symbol.observable")})}function ta(e){return new j(function(t){for(var r=0;r=2;return function(o){return o.pipe(e?b(function(n,i){return e(n,i,o)}):le,Te(1),r?De(t):Qo(function(){return new ir}))}}function jr(e){return e<=0?function(){return S}:E(function(t,r){var o=[];t.subscribe(T(r,function(n){o.push(n),e=2,!0))}function pe(e){e===void 0&&(e={});var t=e.connector,r=t===void 0?function(){return new g}:t,o=e.resetOnError,n=o===void 0?!0:o,i=e.resetOnComplete,a=i===void 0?!0:i,s=e.resetOnRefCountZero,p=s===void 0?!0:s;return function(c){var l,f,u,d=0,y=!1,L=!1,X=function(){f==null||f.unsubscribe(),f=void 0},te=function(){X(),l=u=void 0,y=L=!1},J=function(){var k=l;te(),k==null||k.unsubscribe()};return E(function(k,ft){d++,!L&&!y&&X();var qe=u=u!=null?u:r();ft.add(function(){d--,d===0&&!L&&!y&&(f=Ur(J,p))}),qe.subscribe(ft),!l&&d>0&&(l=new at({next:function(Fe){return qe.next(Fe)},error:function(Fe){L=!0,X(),f=Ur(te,n,Fe),qe.error(Fe)},complete:function(){y=!0,X(),f=Ur(te,a),qe.complete()}}),U(k).subscribe(l))})(c)}}function Ur(e,t){for(var r=[],o=2;oe.next(document)),e}function P(e,t=document){return Array.from(t.querySelectorAll(e))}function R(e,t=document){let r=fe(e,t);if(typeof r=="undefined")throw new ReferenceError(`Missing element: expected "${e}" to be present`);return r}function fe(e,t=document){return t.querySelector(e)||void 0}function Ie(){var e,t,r,o;return(o=(r=(t=(e=document.activeElement)==null?void 0:e.shadowRoot)==null?void 0:t.activeElement)!=null?r:document.activeElement)!=null?o:void 0}var wa=O(h(document.body,"focusin"),h(document.body,"focusout")).pipe(_e(1),Q(void 0),m(()=>Ie()||document.body),G(1));function et(e){return wa.pipe(m(t=>e.contains(t)),K())}function $t(e,t){return C(()=>O(h(e,"mouseenter").pipe(m(()=>!0)),h(e,"mouseleave").pipe(m(()=>!1))).pipe(t?Ht(r=>Le(+!r*t)):le,Q(e.matches(":hover"))))}function Jo(e,t){if(typeof t=="string"||typeof t=="number")e.innerHTML+=t.toString();else if(t instanceof Node)e.appendChild(t);else if(Array.isArray(t))for(let r of t)Jo(e,r)}function x(e,t,...r){let o=document.createElement(e);if(t)for(let n of Object.keys(t))typeof t[n]!="undefined"&&(typeof t[n]!="boolean"?o.setAttribute(n,t[n]):o.setAttribute(n,""));for(let n of r)Jo(o,n);return o}function sr(e){if(e>999){let t=+((e-950)%1e3>99);return`${((e+1e-6)/1e3).toFixed(t)}k`}else return e.toString()}function Tt(e){let t=x("script",{src:e});return C(()=>(document.head.appendChild(t),O(h(t,"load"),h(t,"error").pipe(v(()=>$r(()=>new ReferenceError(`Invalid script: ${e}`))))).pipe(m(()=>{}),_(()=>document.head.removeChild(t)),Te(1))))}var Xo=new g,Ta=C(()=>typeof ResizeObserver=="undefined"?Tt("https://unpkg.com/resize-observer-polyfill"):I(void 0)).pipe(m(()=>new ResizeObserver(e=>e.forEach(t=>Xo.next(t)))),v(e=>O(Ye,I(e)).pipe(_(()=>e.disconnect()))),G(1));function ce(e){return{width:e.offsetWidth,height:e.offsetHeight}}function ge(e){let t=e;for(;t.clientWidth===0&&t.parentElement;)t=t.parentElement;return Ta.pipe(w(r=>r.observe(t)),v(r=>Xo.pipe(b(o=>o.target===t),_(()=>r.unobserve(t)))),m(()=>ce(e)),Q(ce(e)))}function St(e){return{width:e.scrollWidth,height:e.scrollHeight}}function cr(e){let t=e.parentElement;for(;t&&(e.scrollWidth<=t.scrollWidth&&e.scrollHeight<=t.scrollHeight);)t=(e=t).parentElement;return t?e:void 0}function Zo(e){let t=[],r=e.parentElement;for(;r;)(e.clientWidth>r.clientWidth||e.clientHeight>r.clientHeight)&&t.push(r),r=(e=r).parentElement;return t.length===0&&t.push(document.documentElement),t}function Ve(e){return{x:e.offsetLeft,y:e.offsetTop}}function en(e){let t=e.getBoundingClientRect();return{x:t.x+window.scrollX,y:t.y+window.scrollY}}function tn(e){return O(h(window,"load"),h(window,"resize")).pipe(Me(0,me),m(()=>Ve(e)),Q(Ve(e)))}function pr(e){return{x:e.scrollLeft,y:e.scrollTop}}function Ne(e){return O(h(e,"scroll"),h(window,"scroll"),h(window,"resize")).pipe(Me(0,me),m(()=>pr(e)),Q(pr(e)))}var rn=new g,Sa=C(()=>I(new IntersectionObserver(e=>{for(let t of e)rn.next(t)},{threshold:0}))).pipe(v(e=>O(Ye,I(e)).pipe(_(()=>e.disconnect()))),G(1));function tt(e){return Sa.pipe(w(t=>t.observe(e)),v(t=>rn.pipe(b(({target:r})=>r===e),_(()=>t.unobserve(e)),m(({isIntersecting:r})=>r))))}function on(e,t=16){return Ne(e).pipe(m(({y:r})=>{let o=ce(e),n=St(e);return r>=n.height-o.height-t}),K())}var lr={drawer:R("[data-md-toggle=drawer]"),search:R("[data-md-toggle=search]")};function nn(e){return lr[e].checked}function Je(e,t){lr[e].checked!==t&&lr[e].click()}function ze(e){let t=lr[e];return h(t,"change").pipe(m(()=>t.checked),Q(t.checked))}function Oa(e,t){switch(e.constructor){case HTMLInputElement:return e.type==="radio"?/^Arrow/.test(t):!0;case HTMLSelectElement:case HTMLTextAreaElement:return!0;default:return e.isContentEditable}}function La(){return O(h(window,"compositionstart").pipe(m(()=>!0)),h(window,"compositionend").pipe(m(()=>!1))).pipe(Q(!1))}function an(){let e=h(window,"keydown").pipe(b(t=>!(t.metaKey||t.ctrlKey)),m(t=>({mode:nn("search")?"search":"global",type:t.key,claim(){t.preventDefault(),t.stopPropagation()}})),b(({mode:t,type:r})=>{if(t==="global"){let o=Ie();if(typeof o!="undefined")return!Oa(o,r)}return!0}),pe());return La().pipe(v(t=>t?S:e))}function ye(){return new URL(location.href)}function lt(e,t=!1){if(B("navigation.instant")&&!t){let r=x("a",{href:e.href});document.body.appendChild(r),r.click(),r.remove()}else location.href=e.href}function sn(){return new g}function cn(){return location.hash.slice(1)}function pn(e){let t=x("a",{href:e});t.addEventListener("click",r=>r.stopPropagation()),t.click()}function Ma(e){return O(h(window,"hashchange"),e).pipe(m(cn),Q(cn()),b(t=>t.length>0),G(1))}function ln(e){return Ma(e).pipe(m(t=>fe(`[id="${t}"]`)),b(t=>typeof t!="undefined"))}function Pt(e){let t=matchMedia(e);return ar(r=>t.addListener(()=>r(t.matches))).pipe(Q(t.matches))}function mn(){let e=matchMedia("print");return O(h(window,"beforeprint").pipe(m(()=>!0)),h(window,"afterprint").pipe(m(()=>!1))).pipe(Q(e.matches))}function Nr(e,t){return e.pipe(v(r=>r?t():S))}function zr(e,t){return new j(r=>{let o=new XMLHttpRequest;return o.open("GET",`${e}`),o.responseType="blob",o.addEventListener("load",()=>{o.status>=200&&o.status<300?(r.next(o.response),r.complete()):r.error(new Error(o.statusText))}),o.addEventListener("error",()=>{r.error(new Error("Network error"))}),o.addEventListener("abort",()=>{r.complete()}),typeof(t==null?void 0:t.progress$)!="undefined"&&(o.addEventListener("progress",n=>{var i;if(n.lengthComputable)t.progress$.next(n.loaded/n.total*100);else{let a=(i=o.getResponseHeader("Content-Length"))!=null?i:0;t.progress$.next(n.loaded/+a*100)}}),t.progress$.next(5)),o.send(),()=>o.abort()})}function je(e,t){return zr(e,t).pipe(v(r=>r.text()),m(r=>JSON.parse(r)),G(1))}function fn(e,t){let r=new DOMParser;return zr(e,t).pipe(v(o=>o.text()),m(o=>r.parseFromString(o,"text/html")),G(1))}function un(e,t){let r=new DOMParser;return zr(e,t).pipe(v(o=>o.text()),m(o=>r.parseFromString(o,"text/xml")),G(1))}function dn(){return{x:Math.max(0,scrollX),y:Math.max(0,scrollY)}}function hn(){return O(h(window,"scroll",{passive:!0}),h(window,"resize",{passive:!0})).pipe(m(dn),Q(dn()))}function bn(){return{width:innerWidth,height:innerHeight}}function vn(){return h(window,"resize",{passive:!0}).pipe(m(bn),Q(bn()))}function gn(){return z([hn(),vn()]).pipe(m(([e,t])=>({offset:e,size:t})),G(1))}function mr(e,{viewport$:t,header$:r}){let o=t.pipe(ee("size")),n=z([o,r]).pipe(m(()=>Ve(e)));return z([r,t,n]).pipe(m(([{height:i},{offset:a,size:s},{x:p,y:c}])=>({offset:{x:a.x-p,y:a.y-c+i},size:s})))}function _a(e){return h(e,"message",t=>t.data)}function Aa(e){let t=new g;return t.subscribe(r=>e.postMessage(r)),t}function yn(e,t=new Worker(e)){let r=_a(t),o=Aa(t),n=new g;n.subscribe(o);let i=o.pipe(Z(),ie(!0));return n.pipe(Z(),Re(r.pipe(W(i))),pe())}var Ca=R("#__config"),Ot=JSON.parse(Ca.textContent);Ot.base=`${new URL(Ot.base,ye())}`;function xe(){return Ot}function B(e){return Ot.features.includes(e)}function Ee(e,t){return typeof t!="undefined"?Ot.translations[e].replace("#",t.toString()):Ot.translations[e]}function Se(e,t=document){return R(`[data-md-component=${e}]`,t)}function ae(e,t=document){return P(`[data-md-component=${e}]`,t)}function ka(e){let t=R(".md-typeset > :first-child",e);return h(t,"click",{once:!0}).pipe(m(()=>R(".md-typeset",e)),m(r=>({hash:__md_hash(r.innerHTML)})))}function xn(e){if(!B("announce.dismiss")||!e.childElementCount)return S;if(!e.hidden){let t=R(".md-typeset",e);__md_hash(t.innerHTML)===__md_get("__announce")&&(e.hidden=!0)}return C(()=>{let t=new g;return t.subscribe(({hash:r})=>{e.hidden=!0,__md_set("__announce",r)}),ka(e).pipe(w(r=>t.next(r)),_(()=>t.complete()),m(r=>$({ref:e},r)))})}function Ha(e,{target$:t}){return t.pipe(m(r=>({hidden:r!==e})))}function En(e,t){let r=new g;return r.subscribe(({hidden:o})=>{e.hidden=o}),Ha(e,t).pipe(w(o=>r.next(o)),_(()=>r.complete()),m(o=>$({ref:e},o)))}function Rt(e,t){return t==="inline"?x("div",{class:"md-tooltip md-tooltip--inline",id:e,role:"tooltip"},x("div",{class:"md-tooltip__inner md-typeset"})):x("div",{class:"md-tooltip",id:e,role:"tooltip"},x("div",{class:"md-tooltip__inner md-typeset"}))}function wn(...e){return x("div",{class:"md-tooltip2",role:"tooltip"},x("div",{class:"md-tooltip2__inner md-typeset"},e))}function Tn(e,t){if(t=t?`${t}_annotation_${e}`:void 0,t){let r=t?`#${t}`:void 0;return x("aside",{class:"md-annotation",tabIndex:0},Rt(t),x("a",{href:r,class:"md-annotation__index",tabIndex:-1},x("span",{"data-md-annotation-id":e})))}else return x("aside",{class:"md-annotation",tabIndex:0},Rt(t),x("span",{class:"md-annotation__index",tabIndex:-1},x("span",{"data-md-annotation-id":e})))}function Sn(e){return x("button",{class:"md-clipboard md-icon",title:Ee("clipboard.copy"),"data-clipboard-target":`#${e} > code`})}var Ln=Mt(qr());function Qr(e,t){let r=t&2,o=t&1,n=Object.keys(e.terms).filter(p=>!e.terms[p]).reduce((p,c)=>[...p,x("del",null,(0,Ln.default)(c))," "],[]).slice(0,-1),i=xe(),a=new URL(e.location,i.base);B("search.highlight")&&a.searchParams.set("h",Object.entries(e.terms).filter(([,p])=>p).reduce((p,[c])=>`${p} ${c}`.trim(),""));let{tags:s}=xe();return x("a",{href:`${a}`,class:"md-search-result__link",tabIndex:-1},x("article",{class:"md-search-result__article md-typeset","data-md-score":e.score.toFixed(2)},r>0&&x("div",{class:"md-search-result__icon md-icon"}),r>0&&x("h1",null,e.title),r<=0&&x("h2",null,e.title),o>0&&e.text.length>0&&e.text,e.tags&&x("nav",{class:"md-tags"},e.tags.map(p=>{let c=s?p in s?`md-tag-icon md-tag--${s[p]}`:"md-tag-icon":"";return x("span",{class:`md-tag ${c}`},p)})),o>0&&n.length>0&&x("p",{class:"md-search-result__terms"},Ee("search.result.term.missing"),": ",...n)))}function Mn(e){let t=e[0].score,r=[...e],o=xe(),n=r.findIndex(l=>!`${new URL(l.location,o.base)}`.includes("#")),[i]=r.splice(n,1),a=r.findIndex(l=>l.scoreQr(l,1)),...p.length?[x("details",{class:"md-search-result__more"},x("summary",{tabIndex:-1},x("div",null,p.length>0&&p.length===1?Ee("search.result.more.one"):Ee("search.result.more.other",p.length))),...p.map(l=>Qr(l,1)))]:[]];return x("li",{class:"md-search-result__item"},c)}function _n(e){return x("ul",{class:"md-source__facts"},Object.entries(e).map(([t,r])=>x("li",{class:`md-source__fact md-source__fact--${t}`},typeof r=="number"?sr(r):r)))}function Kr(e){let t=`tabbed-control tabbed-control--${e}`;return x("div",{class:t,hidden:!0},x("button",{class:"tabbed-button",tabIndex:-1,"aria-hidden":"true"}))}function An(e){return x("div",{class:"md-typeset__scrollwrap"},x("div",{class:"md-typeset__table"},e))}function Ra(e){var o;let t=xe(),r=new URL(`../${e.version}/`,t.base);return x("li",{class:"md-version__item"},x("a",{href:`${r}`,class:"md-version__link"},e.title,((o=t.version)==null?void 0:o.alias)&&e.aliases.length>0&&x("span",{class:"md-version__alias"},e.aliases[0])))}function Cn(e,t){var o;let r=xe();return e=e.filter(n=>{var i;return!((i=n.properties)!=null&&i.hidden)}),x("div",{class:"md-version"},x("button",{class:"md-version__current","aria-label":Ee("select.version")},t.title,((o=r.version)==null?void 0:o.alias)&&t.aliases.length>0&&x("span",{class:"md-version__alias"},t.aliases[0])),x("ul",{class:"md-version__list"},e.map(Ra)))}var Ia=0;function ja(e){let t=z([et(e),$t(e)]).pipe(m(([o,n])=>o||n),K()),r=C(()=>Zo(e)).pipe(ne(Ne),pt(1),He(t),m(()=>en(e)));return t.pipe(Ae(o=>o),v(()=>z([t,r])),m(([o,n])=>({active:o,offset:n})),pe())}function Fa(e,t){let{content$:r,viewport$:o}=t,n=`__tooltip2_${Ia++}`;return C(()=>{let i=new g,a=new _r(!1);i.pipe(Z(),ie(!1)).subscribe(a);let s=a.pipe(Ht(c=>Le(+!c*250,kr)),K(),v(c=>c?r:S),w(c=>c.id=n),pe());z([i.pipe(m(({active:c})=>c)),s.pipe(v(c=>$t(c,250)),Q(!1))]).pipe(m(c=>c.some(l=>l))).subscribe(a);let p=a.pipe(b(c=>c),re(s,o),m(([c,l,{size:f}])=>{let u=e.getBoundingClientRect(),d=u.width/2;if(l.role==="tooltip")return{x:d,y:8+u.height};if(u.y>=f.height/2){let{height:y}=ce(l);return{x:d,y:-16-y}}else return{x:d,y:16+u.height}}));return z([s,i,p]).subscribe(([c,{offset:l},f])=>{c.style.setProperty("--md-tooltip-host-x",`${l.x}px`),c.style.setProperty("--md-tooltip-host-y",`${l.y}px`),c.style.setProperty("--md-tooltip-x",`${f.x}px`),c.style.setProperty("--md-tooltip-y",`${f.y}px`),c.classList.toggle("md-tooltip2--top",f.y<0),c.classList.toggle("md-tooltip2--bottom",f.y>=0)}),a.pipe(b(c=>c),re(s,(c,l)=>l),b(c=>c.role==="tooltip")).subscribe(c=>{let l=ce(R(":scope > *",c));c.style.setProperty("--md-tooltip-width",`${l.width}px`),c.style.setProperty("--md-tooltip-tail","0px")}),a.pipe(K(),ve(me),re(s)).subscribe(([c,l])=>{l.classList.toggle("md-tooltip2--active",c)}),z([a.pipe(b(c=>c)),s]).subscribe(([c,l])=>{l.role==="dialog"?(e.setAttribute("aria-controls",n),e.setAttribute("aria-haspopup","dialog")):e.setAttribute("aria-describedby",n)}),a.pipe(b(c=>!c)).subscribe(()=>{e.removeAttribute("aria-controls"),e.removeAttribute("aria-describedby"),e.removeAttribute("aria-haspopup")}),ja(e).pipe(w(c=>i.next(c)),_(()=>i.complete()),m(c=>$({ref:e},c)))})}function mt(e,{viewport$:t},r=document.body){return Fa(e,{content$:new j(o=>{let n=e.title,i=wn(n);return o.next(i),e.removeAttribute("title"),r.append(i),()=>{i.remove(),e.setAttribute("title",n)}}),viewport$:t})}function Ua(e,t){let r=C(()=>z([tn(e),Ne(t)])).pipe(m(([{x:o,y:n},i])=>{let{width:a,height:s}=ce(e);return{x:o-i.x+a/2,y:n-i.y+s/2}}));return et(e).pipe(v(o=>r.pipe(m(n=>({active:o,offset:n})),Te(+!o||1/0))))}function kn(e,t,{target$:r}){let[o,n]=Array.from(e.children);return C(()=>{let i=new g,a=i.pipe(Z(),ie(!0));return i.subscribe({next({offset:s}){e.style.setProperty("--md-tooltip-x",`${s.x}px`),e.style.setProperty("--md-tooltip-y",`${s.y}px`)},complete(){e.style.removeProperty("--md-tooltip-x"),e.style.removeProperty("--md-tooltip-y")}}),tt(e).pipe(W(a)).subscribe(s=>{e.toggleAttribute("data-md-visible",s)}),O(i.pipe(b(({active:s})=>s)),i.pipe(_e(250),b(({active:s})=>!s))).subscribe({next({active:s}){s?e.prepend(o):o.remove()},complete(){e.prepend(o)}}),i.pipe(Me(16,me)).subscribe(({active:s})=>{o.classList.toggle("md-tooltip--active",s)}),i.pipe(pt(125,me),b(()=>!!e.offsetParent),m(()=>e.offsetParent.getBoundingClientRect()),m(({x:s})=>s)).subscribe({next(s){s?e.style.setProperty("--md-tooltip-0",`${-s}px`):e.style.removeProperty("--md-tooltip-0")},complete(){e.style.removeProperty("--md-tooltip-0")}}),h(n,"click").pipe(W(a),b(s=>!(s.metaKey||s.ctrlKey))).subscribe(s=>{s.stopPropagation(),s.preventDefault()}),h(n,"mousedown").pipe(W(a),re(i)).subscribe(([s,{active:p}])=>{var c;if(s.button!==0||s.metaKey||s.ctrlKey)s.preventDefault();else if(p){s.preventDefault();let l=e.parentElement.closest(".md-annotation");l instanceof HTMLElement?l.focus():(c=Ie())==null||c.blur()}}),r.pipe(W(a),b(s=>s===o),Ge(125)).subscribe(()=>e.focus()),Ua(e,t).pipe(w(s=>i.next(s)),_(()=>i.complete()),m(s=>$({ref:e},s)))})}function Wa(e){return e.tagName==="CODE"?P(".c, .c1, .cm",e):[e]}function Da(e){let t=[];for(let r of Wa(e)){let o=[],n=document.createNodeIterator(r,NodeFilter.SHOW_TEXT);for(let i=n.nextNode();i;i=n.nextNode())o.push(i);for(let i of o){let a;for(;a=/(\(\d+\))(!)?/.exec(i.textContent);){let[,s,p]=a;if(typeof p=="undefined"){let c=i.splitText(a.index);i=c.splitText(s.length),t.push(c)}else{i.textContent=s,t.push(i);break}}}}return t}function Hn(e,t){t.append(...Array.from(e.childNodes))}function fr(e,t,{target$:r,print$:o}){let n=t.closest("[id]"),i=n==null?void 0:n.id,a=new Map;for(let s of Da(t)){let[,p]=s.textContent.match(/\((\d+)\)/);fe(`:scope > li:nth-child(${p})`,e)&&(a.set(p,Tn(p,i)),s.replaceWith(a.get(p)))}return a.size===0?S:C(()=>{let s=new g,p=s.pipe(Z(),ie(!0)),c=[];for(let[l,f]of a)c.push([R(".md-typeset",f),R(`:scope > li:nth-child(${l})`,e)]);return o.pipe(W(p)).subscribe(l=>{e.hidden=!l,e.classList.toggle("md-annotation-list",l);for(let[f,u]of c)l?Hn(f,u):Hn(u,f)}),O(...[...a].map(([,l])=>kn(l,t,{target$:r}))).pipe(_(()=>s.complete()),pe())})}function $n(e){if(e.nextElementSibling){let t=e.nextElementSibling;if(t.tagName==="OL")return t;if(t.tagName==="P"&&!t.children.length)return $n(t)}}function Pn(e,t){return C(()=>{let r=$n(e);return typeof r!="undefined"?fr(r,e,t):S})}var Rn=Mt(Br());var Va=0;function In(e){if(e.nextElementSibling){let t=e.nextElementSibling;if(t.tagName==="OL")return t;if(t.tagName==="P"&&!t.children.length)return In(t)}}function Na(e){return ge(e).pipe(m(({width:t})=>({scrollable:St(e).width>t})),ee("scrollable"))}function jn(e,t){let{matches:r}=matchMedia("(hover)"),o=C(()=>{let n=new g,i=n.pipe(jr(1));n.subscribe(({scrollable:c})=>{c&&r?e.setAttribute("tabindex","0"):e.removeAttribute("tabindex")});let a=[];if(Rn.default.isSupported()&&(e.closest(".copy")||B("content.code.copy")&&!e.closest(".no-copy"))){let c=e.closest("pre");c.id=`__code_${Va++}`;let l=Sn(c.id);c.insertBefore(l,e),B("content.tooltips")&&a.push(mt(l,{viewport$}))}let s=e.closest(".highlight");if(s instanceof HTMLElement){let c=In(s);if(typeof c!="undefined"&&(s.classList.contains("annotate")||B("content.code.annotate"))){let l=fr(c,e,t);a.push(ge(s).pipe(W(i),m(({width:f,height:u})=>f&&u),K(),v(f=>f?l:S)))}}return P(":scope > span[id]",e).length&&e.classList.add("md-code__content"),Na(e).pipe(w(c=>n.next(c)),_(()=>n.complete()),m(c=>$({ref:e},c)),Re(...a))});return B("content.lazy")?tt(e).pipe(b(n=>n),Te(1),v(()=>o)):o}function za(e,{target$:t,print$:r}){let o=!0;return O(t.pipe(m(n=>n.closest("details:not([open])")),b(n=>e===n),m(()=>({action:"open",reveal:!0}))),r.pipe(b(n=>n||!o),w(()=>o=e.open),m(n=>({action:n?"open":"close"}))))}function Fn(e,t){return C(()=>{let r=new g;return r.subscribe(({action:o,reveal:n})=>{e.toggleAttribute("open",o==="open"),n&&e.scrollIntoView()}),za(e,t).pipe(w(o=>r.next(o)),_(()=>r.complete()),m(o=>$({ref:e},o)))})}var Un=".node circle,.node ellipse,.node path,.node polygon,.node rect{fill:var(--md-mermaid-node-bg-color);stroke:var(--md-mermaid-node-fg-color)}marker{fill:var(--md-mermaid-edge-color)!important}.edgeLabel .label rect{fill:#0000}.flowchartTitleText{fill:var(--md-mermaid-label-fg-color)}.label{color:var(--md-mermaid-label-fg-color);font-family:var(--md-mermaid-font-family)}.label foreignObject{line-height:normal;overflow:visible}.label div .edgeLabel{color:var(--md-mermaid-label-fg-color)}.edgeLabel,.edgeLabel p,.label div .edgeLabel{background-color:var(--md-mermaid-label-bg-color)}.edgeLabel,.edgeLabel p{fill:var(--md-mermaid-label-bg-color);color:var(--md-mermaid-edge-color)}.edgePath .path,.flowchart-link{stroke:var(--md-mermaid-edge-color);stroke-width:.05rem}.edgePath .arrowheadPath{fill:var(--md-mermaid-edge-color);stroke:none}.cluster rect{fill:var(--md-default-fg-color--lightest);stroke:var(--md-default-fg-color--lighter)}.cluster span{color:var(--md-mermaid-label-fg-color);font-family:var(--md-mermaid-font-family)}g #flowchart-circleEnd,g #flowchart-circleStart,g #flowchart-crossEnd,g #flowchart-crossStart,g #flowchart-pointEnd,g #flowchart-pointStart{stroke:none}.classDiagramTitleText{fill:var(--md-mermaid-label-fg-color)}g.classGroup line,g.classGroup rect{fill:var(--md-mermaid-node-bg-color);stroke:var(--md-mermaid-node-fg-color)}g.classGroup text{fill:var(--md-mermaid-label-fg-color);font-family:var(--md-mermaid-font-family)}.classLabel .box{fill:var(--md-mermaid-label-bg-color);background-color:var(--md-mermaid-label-bg-color);opacity:1}.classLabel .label{fill:var(--md-mermaid-label-fg-color);font-family:var(--md-mermaid-font-family)}.node .divider{stroke:var(--md-mermaid-node-fg-color)}.relation{stroke:var(--md-mermaid-edge-color)}.cardinality{fill:var(--md-mermaid-label-fg-color);font-family:var(--md-mermaid-font-family)}.cardinality text{fill:inherit!important}defs #classDiagram-compositionEnd,defs #classDiagram-compositionStart,defs #classDiagram-dependencyEnd,defs #classDiagram-dependencyStart,defs #classDiagram-extensionEnd,defs #classDiagram-extensionStart{fill:var(--md-mermaid-edge-color)!important;stroke:var(--md-mermaid-edge-color)!important}defs #classDiagram-aggregationEnd,defs #classDiagram-aggregationStart{fill:var(--md-mermaid-label-bg-color)!important;stroke:var(--md-mermaid-edge-color)!important}.statediagramTitleText{fill:var(--md-mermaid-label-fg-color)}g.stateGroup rect{fill:var(--md-mermaid-node-bg-color);stroke:var(--md-mermaid-node-fg-color)}g.stateGroup .state-title{fill:var(--md-mermaid-label-fg-color)!important;font-family:var(--md-mermaid-font-family)}g.stateGroup .composit{fill:var(--md-mermaid-label-bg-color)}.nodeLabel,.nodeLabel p{color:var(--md-mermaid-label-fg-color);font-family:var(--md-mermaid-font-family)}a .nodeLabel{text-decoration:underline}.node circle.state-end,.node circle.state-start,.start-state{fill:var(--md-mermaid-edge-color);stroke:none}.end-state-inner,.end-state-outer{fill:var(--md-mermaid-edge-color)}.end-state-inner,.node circle.state-end{stroke:var(--md-mermaid-label-bg-color)}.transition{stroke:var(--md-mermaid-edge-color)}[id^=state-fork] rect,[id^=state-join] rect{fill:var(--md-mermaid-edge-color)!important;stroke:none!important}.statediagram-cluster.statediagram-cluster .inner{fill:var(--md-default-bg-color)}.statediagram-cluster rect{fill:var(--md-mermaid-node-bg-color);stroke:var(--md-mermaid-node-fg-color)}.statediagram-state rect.divider{fill:var(--md-default-fg-color--lightest);stroke:var(--md-default-fg-color--lighter)}defs #statediagram-barbEnd{stroke:var(--md-mermaid-edge-color)}.entityTitleText{fill:var(--md-mermaid-label-fg-color)}.attributeBoxEven,.attributeBoxOdd{fill:var(--md-mermaid-node-bg-color);stroke:var(--md-mermaid-node-fg-color)}.entityBox{fill:var(--md-mermaid-label-bg-color);stroke:var(--md-mermaid-node-fg-color)}.entityLabel{fill:var(--md-mermaid-label-fg-color);font-family:var(--md-mermaid-font-family)}.relationshipLabelBox{fill:var(--md-mermaid-label-bg-color);fill-opacity:1;background-color:var(--md-mermaid-label-bg-color);opacity:1}.relationshipLabel{fill:var(--md-mermaid-label-fg-color)}.relationshipLine{stroke:var(--md-mermaid-edge-color)}defs #ONE_OR_MORE_END *,defs #ONE_OR_MORE_START *,defs #ONLY_ONE_END *,defs #ONLY_ONE_START *,defs #ZERO_OR_MORE_END *,defs #ZERO_OR_MORE_START *,defs #ZERO_OR_ONE_END *,defs #ZERO_OR_ONE_START *{stroke:var(--md-mermaid-edge-color)!important}defs #ZERO_OR_MORE_END circle,defs #ZERO_OR_MORE_START circle{fill:var(--md-mermaid-label-bg-color)}text:not([class]):last-child{fill:var(--md-mermaid-label-fg-color)}.actor{fill:var(--md-mermaid-sequence-actor-bg-color);stroke:var(--md-mermaid-sequence-actor-border-color)}text.actor>tspan{fill:var(--md-mermaid-sequence-actor-fg-color);font-family:var(--md-mermaid-font-family)}line{stroke:var(--md-mermaid-sequence-actor-line-color)}.actor-man circle,.actor-man line{fill:var(--md-mermaid-sequence-actorman-bg-color);stroke:var(--md-mermaid-sequence-actorman-line-color)}.messageLine0,.messageLine1{stroke:var(--md-mermaid-sequence-message-line-color)}.note{fill:var(--md-mermaid-sequence-note-bg-color);stroke:var(--md-mermaid-sequence-note-border-color)}.loopText,.loopText>tspan,.messageText,.noteText>tspan{stroke:none;font-family:var(--md-mermaid-font-family)!important}.messageText{fill:var(--md-mermaid-sequence-message-fg-color)}.loopText,.loopText>tspan{fill:var(--md-mermaid-sequence-loop-fg-color)}.noteText>tspan{fill:var(--md-mermaid-sequence-note-fg-color)}#arrowhead path{fill:var(--md-mermaid-sequence-message-line-color);stroke:none}.loopLine{fill:var(--md-mermaid-sequence-loop-bg-color);stroke:var(--md-mermaid-sequence-loop-border-color)}.labelBox{fill:var(--md-mermaid-sequence-label-bg-color);stroke:none}.labelText,.labelText>span{fill:var(--md-mermaid-sequence-label-fg-color);font-family:var(--md-mermaid-font-family)}.sequenceNumber{fill:var(--md-mermaid-sequence-number-fg-color)}rect.rect{fill:var(--md-mermaid-sequence-box-bg-color);stroke:none}rect.rect+text.text{fill:var(--md-mermaid-sequence-box-fg-color)}defs #sequencenumber{fill:var(--md-mermaid-sequence-number-bg-color)!important}";var Gr,Qa=0;function Ka(){return typeof mermaid=="undefined"||mermaid instanceof Element?Tt("https://unpkg.com/mermaid@11/dist/mermaid.min.js"):I(void 0)}function Wn(e){return e.classList.remove("mermaid"),Gr||(Gr=Ka().pipe(w(()=>mermaid.initialize({startOnLoad:!1,themeCSS:Un,sequence:{actorFontSize:"16px",messageFontSize:"16px",noteFontSize:"16px"}})),m(()=>{}),G(1))),Gr.subscribe(()=>co(this,null,function*(){e.classList.add("mermaid");let t=`__mermaid_${Qa++}`,r=x("div",{class:"mermaid"}),o=e.textContent,{svg:n,fn:i}=yield mermaid.render(t,o),a=r.attachShadow({mode:"closed"});a.innerHTML=n,e.replaceWith(r),i==null||i(a)})),Gr.pipe(m(()=>({ref:e})))}var Dn=x("table");function Vn(e){return e.replaceWith(Dn),Dn.replaceWith(An(e)),I({ref:e})}function Ya(e){let t=e.find(r=>r.checked)||e[0];return O(...e.map(r=>h(r,"change").pipe(m(()=>R(`label[for="${r.id}"]`))))).pipe(Q(R(`label[for="${t.id}"]`)),m(r=>({active:r})))}function Nn(e,{viewport$:t,target$:r}){let o=R(".tabbed-labels",e),n=P(":scope > input",e),i=Kr("prev");e.append(i);let a=Kr("next");return e.append(a),C(()=>{let s=new g,p=s.pipe(Z(),ie(!0));z([s,ge(e),tt(e)]).pipe(W(p),Me(1,me)).subscribe({next([{active:c},l]){let f=Ve(c),{width:u}=ce(c);e.style.setProperty("--md-indicator-x",`${f.x}px`),e.style.setProperty("--md-indicator-width",`${u}px`);let d=pr(o);(f.xd.x+l.width)&&o.scrollTo({left:Math.max(0,f.x-16),behavior:"smooth"})},complete(){e.style.removeProperty("--md-indicator-x"),e.style.removeProperty("--md-indicator-width")}}),z([Ne(o),ge(o)]).pipe(W(p)).subscribe(([c,l])=>{let f=St(o);i.hidden=c.x<16,a.hidden=c.x>f.width-l.width-16}),O(h(i,"click").pipe(m(()=>-1)),h(a,"click").pipe(m(()=>1))).pipe(W(p)).subscribe(c=>{let{width:l}=ce(o);o.scrollBy({left:l*c,behavior:"smooth"})}),r.pipe(W(p),b(c=>n.includes(c))).subscribe(c=>c.click()),o.classList.add("tabbed-labels--linked");for(let c of n){let l=R(`label[for="${c.id}"]`);l.replaceChildren(x("a",{href:`#${l.htmlFor}`,tabIndex:-1},...Array.from(l.childNodes))),h(l.firstElementChild,"click").pipe(W(p),b(f=>!(f.metaKey||f.ctrlKey)),w(f=>{f.preventDefault(),f.stopPropagation()})).subscribe(()=>{history.replaceState({},"",`#${l.htmlFor}`),l.click()})}return B("content.tabs.link")&&s.pipe(Ce(1),re(t)).subscribe(([{active:c},{offset:l}])=>{let f=c.innerText.trim();if(c.hasAttribute("data-md-switching"))c.removeAttribute("data-md-switching");else{let u=e.offsetTop-l.y;for(let y of P("[data-tabs]"))for(let L of P(":scope > input",y)){let X=R(`label[for="${L.id}"]`);if(X!==c&&X.innerText.trim()===f){X.setAttribute("data-md-switching",""),L.click();break}}window.scrollTo({top:e.offsetTop-u});let d=__md_get("__tabs")||[];__md_set("__tabs",[...new Set([f,...d])])}}),s.pipe(W(p)).subscribe(()=>{for(let c of P("audio, video",e))c.pause()}),Ya(n).pipe(w(c=>s.next(c)),_(()=>s.complete()),m(c=>$({ref:e},c)))}).pipe(Ke(se))}function zn(e,{viewport$:t,target$:r,print$:o}){return O(...P(".annotate:not(.highlight)",e).map(n=>Pn(n,{target$:r,print$:o})),...P("pre:not(.mermaid) > code",e).map(n=>jn(n,{target$:r,print$:o})),...P("pre.mermaid",e).map(n=>Wn(n)),...P("table:not([class])",e).map(n=>Vn(n)),...P("details",e).map(n=>Fn(n,{target$:r,print$:o})),...P("[data-tabs]",e).map(n=>Nn(n,{viewport$:t,target$:r})),...P("[title]",e).filter(()=>B("content.tooltips")).map(n=>mt(n,{viewport$:t})))}function Ba(e,{alert$:t}){return t.pipe(v(r=>O(I(!0),I(!1).pipe(Ge(2e3))).pipe(m(o=>({message:r,active:o})))))}function qn(e,t){let r=R(".md-typeset",e);return C(()=>{let o=new g;return o.subscribe(({message:n,active:i})=>{e.classList.toggle("md-dialog--active",i),r.textContent=n}),Ba(e,t).pipe(w(n=>o.next(n)),_(()=>o.complete()),m(n=>$({ref:e},n)))})}var Ga=0;function Ja(e,t){document.body.append(e);let{width:r}=ce(e);e.style.setProperty("--md-tooltip-width",`${r}px`),e.remove();let o=cr(t),n=typeof o!="undefined"?Ne(o):I({x:0,y:0}),i=O(et(t),$t(t)).pipe(K());return z([i,n]).pipe(m(([a,s])=>{let{x:p,y:c}=Ve(t),l=ce(t),f=t.closest("table");return f&&t.parentElement&&(p+=f.offsetLeft+t.parentElement.offsetLeft,c+=f.offsetTop+t.parentElement.offsetTop),{active:a,offset:{x:p-s.x+l.width/2-r/2,y:c-s.y+l.height+8}}}))}function Qn(e){let t=e.title;if(!t.length)return S;let r=`__tooltip_${Ga++}`,o=Rt(r,"inline"),n=R(".md-typeset",o);return n.innerHTML=t,C(()=>{let i=new g;return i.subscribe({next({offset:a}){o.style.setProperty("--md-tooltip-x",`${a.x}px`),o.style.setProperty("--md-tooltip-y",`${a.y}px`)},complete(){o.style.removeProperty("--md-tooltip-x"),o.style.removeProperty("--md-tooltip-y")}}),O(i.pipe(b(({active:a})=>a)),i.pipe(_e(250),b(({active:a})=>!a))).subscribe({next({active:a}){a?(e.insertAdjacentElement("afterend",o),e.setAttribute("aria-describedby",r),e.removeAttribute("title")):(o.remove(),e.removeAttribute("aria-describedby"),e.setAttribute("title",t))},complete(){o.remove(),e.removeAttribute("aria-describedby"),e.setAttribute("title",t)}}),i.pipe(Me(16,me)).subscribe(({active:a})=>{o.classList.toggle("md-tooltip--active",a)}),i.pipe(pt(125,me),b(()=>!!e.offsetParent),m(()=>e.offsetParent.getBoundingClientRect()),m(({x:a})=>a)).subscribe({next(a){a?o.style.setProperty("--md-tooltip-0",`${-a}px`):o.style.removeProperty("--md-tooltip-0")},complete(){o.style.removeProperty("--md-tooltip-0")}}),Ja(o,e).pipe(w(a=>i.next(a)),_(()=>i.complete()),m(a=>$({ref:e},a)))}).pipe(Ke(se))}function Xa({viewport$:e}){if(!B("header.autohide"))return I(!1);let t=e.pipe(m(({offset:{y:n}})=>n),Be(2,1),m(([n,i])=>[nMath.abs(i-n.y)>100),m(([,[n]])=>n),K()),o=ze("search");return z([e,o]).pipe(m(([{offset:n},i])=>n.y>400&&!i),K(),v(n=>n?r:I(!1)),Q(!1))}function Kn(e,t){return C(()=>z([ge(e),Xa(t)])).pipe(m(([{height:r},o])=>({height:r,hidden:o})),K((r,o)=>r.height===o.height&&r.hidden===o.hidden),G(1))}function Yn(e,{header$:t,main$:r}){return C(()=>{let o=new g,n=o.pipe(Z(),ie(!0));o.pipe(ee("active"),He(t)).subscribe(([{active:a},{hidden:s}])=>{e.classList.toggle("md-header--shadow",a&&!s),e.hidden=s});let i=ue(P("[title]",e)).pipe(b(()=>B("content.tooltips")),ne(a=>Qn(a)));return r.subscribe(o),t.pipe(W(n),m(a=>$({ref:e},a)),Re(i.pipe(W(n))))})}function Za(e,{viewport$:t,header$:r}){return mr(e,{viewport$:t,header$:r}).pipe(m(({offset:{y:o}})=>{let{height:n}=ce(e);return{active:o>=n}}),ee("active"))}function Bn(e,t){return C(()=>{let r=new g;r.subscribe({next({active:n}){e.classList.toggle("md-header__title--active",n)},complete(){e.classList.remove("md-header__title--active")}});let o=fe(".md-content h1");return typeof o=="undefined"?S:Za(o,t).pipe(w(n=>r.next(n)),_(()=>r.complete()),m(n=>$({ref:e},n)))})}function Gn(e,{viewport$:t,header$:r}){let o=r.pipe(m(({height:i})=>i),K()),n=o.pipe(v(()=>ge(e).pipe(m(({height:i})=>({top:e.offsetTop,bottom:e.offsetTop+i})),ee("bottom"))));return z([o,n,t]).pipe(m(([i,{top:a,bottom:s},{offset:{y:p},size:{height:c}}])=>(c=Math.max(0,c-Math.max(0,a-p,i)-Math.max(0,c+p-s)),{offset:a-i,height:c,active:a-i<=p})),K((i,a)=>i.offset===a.offset&&i.height===a.height&&i.active===a.active))}function es(e){let t=__md_get("__palette")||{index:e.findIndex(o=>matchMedia(o.getAttribute("data-md-color-media")).matches)},r=Math.max(0,Math.min(t.index,e.length-1));return I(...e).pipe(ne(o=>h(o,"change").pipe(m(()=>o))),Q(e[r]),m(o=>({index:e.indexOf(o),color:{media:o.getAttribute("data-md-color-media"),scheme:o.getAttribute("data-md-color-scheme"),primary:o.getAttribute("data-md-color-primary"),accent:o.getAttribute("data-md-color-accent")}})),G(1))}function Jn(e){let t=P("input",e),r=x("meta",{name:"theme-color"});document.head.appendChild(r);let o=x("meta",{name:"color-scheme"});document.head.appendChild(o);let n=Pt("(prefers-color-scheme: light)");return C(()=>{let i=new g;return i.subscribe(a=>{if(document.body.setAttribute("data-md-color-switching",""),a.color.media==="(prefers-color-scheme)"){let s=matchMedia("(prefers-color-scheme: light)"),p=document.querySelector(s.matches?"[data-md-color-media='(prefers-color-scheme: light)']":"[data-md-color-media='(prefers-color-scheme: dark)']");a.color.scheme=p.getAttribute("data-md-color-scheme"),a.color.primary=p.getAttribute("data-md-color-primary"),a.color.accent=p.getAttribute("data-md-color-accent")}for(let[s,p]of Object.entries(a.color))document.body.setAttribute(`data-md-color-${s}`,p);for(let s=0;sa.key==="Enter"),re(i,(a,s)=>s)).subscribe(({index:a})=>{a=(a+1)%t.length,t[a].click(),t[a].focus()}),i.pipe(m(()=>{let a=Se("header"),s=window.getComputedStyle(a);return o.content=s.colorScheme,s.backgroundColor.match(/\d+/g).map(p=>(+p).toString(16).padStart(2,"0")).join("")})).subscribe(a=>r.content=`#${a}`),i.pipe(ve(se)).subscribe(()=>{document.body.removeAttribute("data-md-color-switching")}),es(t).pipe(W(n.pipe(Ce(1))),ct(),w(a=>i.next(a)),_(()=>i.complete()),m(a=>$({ref:e},a)))})}function Xn(e,{progress$:t}){return C(()=>{let r=new g;return r.subscribe(({value:o})=>{e.style.setProperty("--md-progress-value",`${o}`)}),t.pipe(w(o=>r.next({value:o})),_(()=>r.complete()),m(o=>({ref:e,value:o})))})}var Jr=Mt(Br());function ts(e){e.setAttribute("data-md-copying","");let t=e.closest("[data-copy]"),r=t?t.getAttribute("data-copy"):e.innerText;return e.removeAttribute("data-md-copying"),r.trimEnd()}function Zn({alert$:e}){Jr.default.isSupported()&&new j(t=>{new Jr.default("[data-clipboard-target], [data-clipboard-text]",{text:r=>r.getAttribute("data-clipboard-text")||ts(R(r.getAttribute("data-clipboard-target")))}).on("success",r=>t.next(r))}).pipe(w(t=>{t.trigger.focus()}),m(()=>Ee("clipboard.copied"))).subscribe(e)}function ei(e,t){return e.protocol=t.protocol,e.hostname=t.hostname,e}function rs(e,t){let r=new Map;for(let o of P("url",e)){let n=R("loc",o),i=[ei(new URL(n.textContent),t)];r.set(`${i[0]}`,i);for(let a of P("[rel=alternate]",o)){let s=a.getAttribute("href");s!=null&&i.push(ei(new URL(s),t))}}return r}function ur(e){return un(new URL("sitemap.xml",e)).pipe(m(t=>rs(t,new URL(e))),de(()=>I(new Map)))}function os(e,t){if(!(e.target instanceof Element))return S;let r=e.target.closest("a");if(r===null)return S;if(r.target||e.metaKey||e.ctrlKey)return S;let o=new URL(r.href);return o.search=o.hash="",t.has(`${o}`)?(e.preventDefault(),I(new URL(r.href))):S}function ti(e){let t=new Map;for(let r of P(":scope > *",e.head))t.set(r.outerHTML,r);return t}function ri(e){for(let t of P("[href], [src]",e))for(let r of["href","src"]){let o=t.getAttribute(r);if(o&&!/^(?:[a-z]+:)?\/\//i.test(o)){t[r]=t[r];break}}return I(e)}function ns(e){for(let o of["[data-md-component=announce]","[data-md-component=container]","[data-md-component=header-topic]","[data-md-component=outdated]","[data-md-component=logo]","[data-md-component=skip]",...B("navigation.tabs.sticky")?["[data-md-component=tabs]"]:[]]){let n=fe(o),i=fe(o,e);typeof n!="undefined"&&typeof i!="undefined"&&n.replaceWith(i)}let t=ti(document);for(let[o,n]of ti(e))t.has(o)?t.delete(o):document.head.appendChild(n);for(let o of t.values()){let n=o.getAttribute("name");n!=="theme-color"&&n!=="color-scheme"&&o.remove()}let r=Se("container");return We(P("script",r)).pipe(v(o=>{let n=e.createElement("script");if(o.src){for(let i of o.getAttributeNames())n.setAttribute(i,o.getAttribute(i));return o.replaceWith(n),new j(i=>{n.onload=()=>i.complete()})}else return n.textContent=o.textContent,o.replaceWith(n),S}),Z(),ie(document))}function oi({location$:e,viewport$:t,progress$:r}){let o=xe();if(location.protocol==="file:")return S;let n=ur(o.base);I(document).subscribe(ri);let i=h(document.body,"click").pipe(He(n),v(([p,c])=>os(p,c)),pe()),a=h(window,"popstate").pipe(m(ye),pe());i.pipe(re(t)).subscribe(([p,{offset:c}])=>{history.replaceState(c,""),history.pushState(null,"",p)}),O(i,a).subscribe(e);let s=e.pipe(ee("pathname"),v(p=>fn(p,{progress$:r}).pipe(de(()=>(lt(p,!0),S)))),v(ri),v(ns),pe());return O(s.pipe(re(e,(p,c)=>c)),s.pipe(v(()=>e),ee("pathname"),v(()=>e),ee("hash")),e.pipe(K((p,c)=>p.pathname===c.pathname&&p.hash===c.hash),v(()=>i),w(()=>history.back()))).subscribe(p=>{var c,l;history.state!==null||!p.hash?window.scrollTo(0,(l=(c=history.state)==null?void 0:c.y)!=null?l:0):(history.scrollRestoration="auto",pn(p.hash),history.scrollRestoration="manual")}),e.subscribe(()=>{history.scrollRestoration="manual"}),h(window,"beforeunload").subscribe(()=>{history.scrollRestoration="auto"}),t.pipe(ee("offset"),_e(100)).subscribe(({offset:p})=>{history.replaceState(p,"")}),s}var ni=Mt(qr());function ii(e){let t=e.separator.split("|").map(n=>n.replace(/(\(\?[!=<][^)]+\))/g,"").length===0?"\uFFFD":n).join("|"),r=new RegExp(t,"img"),o=(n,i,a)=>`${i}${a} `;return n=>{n=n.replace(/[\s*+\-:~^]+/g," ").trim();let i=new RegExp(`(^|${e.separator}|)(${n.replace(/[|\\{}()[\]^$+*?.-]/g,"\\$&").replace(r,"|")})`,"img");return a=>(0,ni.default)(a).replace(i,o).replace(/<\/mark>(\s+)]*>/img,"$1")}}function jt(e){return e.type===1}function dr(e){return e.type===3}function ai(e,t){let r=yn(e);return O(I(location.protocol!=="file:"),ze("search")).pipe(Ae(o=>o),v(()=>t)).subscribe(({config:o,docs:n})=>r.next({type:0,data:{config:o,docs:n,options:{suggest:B("search.suggest")}}})),r}function si(e){var l;let{selectedVersionSitemap:t,selectedVersionBaseURL:r,currentLocation:o,currentBaseURL:n}=e,i=(l=Xr(n))==null?void 0:l.pathname;if(i===void 0)return;let a=ss(o.pathname,i);if(a===void 0)return;let s=ps(t.keys());if(!t.has(s))return;let p=Xr(a,s);if(!p||!t.has(p.href))return;let c=Xr(a,r);if(c)return c.hash=o.hash,c.search=o.search,c}function Xr(e,t){try{return new URL(e,t)}catch(r){return}}function ss(e,t){if(e.startsWith(t))return e.slice(t.length)}function cs(e,t){let r=Math.min(e.length,t.length),o;for(o=0;oS)),o=r.pipe(m(n=>{let[,i]=t.base.match(/([^/]+)\/?$/);return n.find(({version:a,aliases:s})=>a===i||s.includes(i))||n[0]}));r.pipe(m(n=>new Map(n.map(i=>[`${new URL(`../${i.version}/`,t.base)}`,i]))),v(n=>h(document.body,"click").pipe(b(i=>!i.metaKey&&!i.ctrlKey),re(o),v(([i,a])=>{if(i.target instanceof Element){let s=i.target.closest("a");if(s&&!s.target&&n.has(s.href)){let p=s.href;return!i.target.closest(".md-version")&&n.get(p)===a?S:(i.preventDefault(),I(new URL(p)))}}return S}),v(i=>ur(i).pipe(m(a=>{var s;return(s=si({selectedVersionSitemap:a,selectedVersionBaseURL:i,currentLocation:ye(),currentBaseURL:t.base}))!=null?s:i})))))).subscribe(n=>lt(n,!0)),z([r,o]).subscribe(([n,i])=>{R(".md-header__topic").appendChild(Cn(n,i))}),e.pipe(v(()=>o)).subscribe(n=>{var a;let i=__md_get("__outdated",sessionStorage);if(i===null){i=!0;let s=((a=t.version)==null?void 0:a.default)||"latest";Array.isArray(s)||(s=[s]);e:for(let p of s)for(let c of n.aliases.concat(n.version))if(new RegExp(p,"i").test(c)){i=!1;break e}__md_set("__outdated",i,sessionStorage)}if(i)for(let s of ae("outdated"))s.hidden=!1})}function ls(e,{worker$:t}){let{searchParams:r}=ye();r.has("q")&&(Je("search",!0),e.value=r.get("q"),e.focus(),ze("search").pipe(Ae(i=>!i)).subscribe(()=>{let i=ye();i.searchParams.delete("q"),history.replaceState({},"",`${i}`)}));let o=et(e),n=O(t.pipe(Ae(jt)),h(e,"keyup"),o).pipe(m(()=>e.value),K());return z([n,o]).pipe(m(([i,a])=>({value:i,focus:a})),G(1))}function pi(e,{worker$:t}){let r=new g,o=r.pipe(Z(),ie(!0));z([t.pipe(Ae(jt)),r],(i,a)=>a).pipe(ee("value")).subscribe(({value:i})=>t.next({type:2,data:i})),r.pipe(ee("focus")).subscribe(({focus:i})=>{i&&Je("search",i)}),h(e.form,"reset").pipe(W(o)).subscribe(()=>e.focus());let n=R("header [for=__search]");return h(n,"click").subscribe(()=>e.focus()),ls(e,{worker$:t}).pipe(w(i=>r.next(i)),_(()=>r.complete()),m(i=>$({ref:e},i)),G(1))}function li(e,{worker$:t,query$:r}){let o=new g,n=on(e.parentElement).pipe(b(Boolean)),i=e.parentElement,a=R(":scope > :first-child",e),s=R(":scope > :last-child",e);ze("search").subscribe(l=>s.setAttribute("role",l?"list":"presentation")),o.pipe(re(r),Wr(t.pipe(Ae(jt)))).subscribe(([{items:l},{value:f}])=>{switch(l.length){case 0:a.textContent=f.length?Ee("search.result.none"):Ee("search.result.placeholder");break;case 1:a.textContent=Ee("search.result.one");break;default:let u=sr(l.length);a.textContent=Ee("search.result.other",u)}});let p=o.pipe(w(()=>s.innerHTML=""),v(({items:l})=>O(I(...l.slice(0,10)),I(...l.slice(10)).pipe(Be(4),Vr(n),v(([f])=>f)))),m(Mn),pe());return p.subscribe(l=>s.appendChild(l)),p.pipe(ne(l=>{let f=fe("details",l);return typeof f=="undefined"?S:h(f,"toggle").pipe(W(o),m(()=>f))})).subscribe(l=>{l.open===!1&&l.offsetTop<=i.scrollTop&&i.scrollTo({top:l.offsetTop})}),t.pipe(b(dr),m(({data:l})=>l)).pipe(w(l=>o.next(l)),_(()=>o.complete()),m(l=>$({ref:e},l)))}function ms(e,{query$:t}){return t.pipe(m(({value:r})=>{let o=ye();return o.hash="",r=r.replace(/\s+/g,"+").replace(/&/g,"%26").replace(/=/g,"%3D"),o.search=`q=${r}`,{url:o}}))}function mi(e,t){let r=new g,o=r.pipe(Z(),ie(!0));return r.subscribe(({url:n})=>{e.setAttribute("data-clipboard-text",e.href),e.href=`${n}`}),h(e,"click").pipe(W(o)).subscribe(n=>n.preventDefault()),ms(e,t).pipe(w(n=>r.next(n)),_(()=>r.complete()),m(n=>$({ref:e},n)))}function fi(e,{worker$:t,keyboard$:r}){let o=new g,n=Se("search-query"),i=O(h(n,"keydown"),h(n,"focus")).pipe(ve(se),m(()=>n.value),K());return o.pipe(He(i),m(([{suggest:s},p])=>{let c=p.split(/([\s-]+)/);if(s!=null&&s.length&&c[c.length-1]){let l=s[s.length-1];l.startsWith(c[c.length-1])&&(c[c.length-1]=l)}else c.length=0;return c})).subscribe(s=>e.innerHTML=s.join("").replace(/\s/g," ")),r.pipe(b(({mode:s})=>s==="search")).subscribe(s=>{switch(s.type){case"ArrowRight":e.innerText.length&&n.selectionStart===n.value.length&&(n.value=e.innerText);break}}),t.pipe(b(dr),m(({data:s})=>s)).pipe(w(s=>o.next(s)),_(()=>o.complete()),m(()=>({ref:e})))}function ui(e,{index$:t,keyboard$:r}){let o=xe();try{let n=ai(o.search,t),i=Se("search-query",e),a=Se("search-result",e);h(e,"click").pipe(b(({target:p})=>p instanceof Element&&!!p.closest("a"))).subscribe(()=>Je("search",!1)),r.pipe(b(({mode:p})=>p==="search")).subscribe(p=>{let c=Ie();switch(p.type){case"Enter":if(c===i){let l=new Map;for(let f of P(":first-child [href]",a)){let u=f.firstElementChild;l.set(f,parseFloat(u.getAttribute("data-md-score")))}if(l.size){let[[f]]=[...l].sort(([,u],[,d])=>d-u);f.click()}p.claim()}break;case"Escape":case"Tab":Je("search",!1),i.blur();break;case"ArrowUp":case"ArrowDown":if(typeof c=="undefined")i.focus();else{let l=[i,...P(":not(details) > [href], summary, details[open] [href]",a)],f=Math.max(0,(Math.max(0,l.indexOf(c))+l.length+(p.type==="ArrowUp"?-1:1))%l.length);l[f].focus()}p.claim();break;default:i!==Ie()&&i.focus()}}),r.pipe(b(({mode:p})=>p==="global")).subscribe(p=>{switch(p.type){case"f":case"s":case"/":i.focus(),i.select(),p.claim();break}});let s=pi(i,{worker$:n});return O(s,li(a,{worker$:n,query$:s})).pipe(Re(...ae("search-share",e).map(p=>mi(p,{query$:s})),...ae("search-suggest",e).map(p=>fi(p,{worker$:n,keyboard$:r}))))}catch(n){return e.hidden=!0,Ye}}function di(e,{index$:t,location$:r}){return z([t,r.pipe(Q(ye()),b(o=>!!o.searchParams.get("h")))]).pipe(m(([o,n])=>ii(o.config)(n.searchParams.get("h"))),m(o=>{var a;let n=new Map,i=document.createNodeIterator(e,NodeFilter.SHOW_TEXT);for(let s=i.nextNode();s;s=i.nextNode())if((a=s.parentElement)!=null&&a.offsetHeight){let p=s.textContent,c=o(p);c.length>p.length&&n.set(s,c)}for(let[s,p]of n){let{childNodes:c}=x("span",null,p);s.replaceWith(...Array.from(c))}return{ref:e,nodes:n}}))}function fs(e,{viewport$:t,main$:r}){let o=e.closest(".md-grid"),n=o.offsetTop-o.parentElement.offsetTop;return z([r,t]).pipe(m(([{offset:i,height:a},{offset:{y:s}}])=>(a=a+Math.min(n,Math.max(0,s-i))-n,{height:a,locked:s>=i+n})),K((i,a)=>i.height===a.height&&i.locked===a.locked))}function Zr(e,o){var n=o,{header$:t}=n,r=so(n,["header$"]);let i=R(".md-sidebar__scrollwrap",e),{y:a}=Ve(i);return C(()=>{let s=new g,p=s.pipe(Z(),ie(!0)),c=s.pipe(Me(0,me));return c.pipe(re(t)).subscribe({next([{height:l},{height:f}]){i.style.height=`${l-2*a}px`,e.style.top=`${f}px`},complete(){i.style.height="",e.style.top=""}}),c.pipe(Ae()).subscribe(()=>{for(let l of P(".md-nav__link--active[href]",e)){if(!l.clientHeight)continue;let f=l.closest(".md-sidebar__scrollwrap");if(typeof f!="undefined"){let u=l.offsetTop-f.offsetTop,{height:d}=ce(f);f.scrollTo({top:u-d/2})}}}),ue(P("label[tabindex]",e)).pipe(ne(l=>h(l,"click").pipe(ve(se),m(()=>l),W(p)))).subscribe(l=>{let f=R(`[id="${l.htmlFor}"]`);R(`[aria-labelledby="${l.id}"]`).setAttribute("aria-expanded",`${f.checked}`)}),fs(e,r).pipe(w(l=>s.next(l)),_(()=>s.complete()),m(l=>$({ref:e},l)))})}function hi(e,t){if(typeof t!="undefined"){let r=`https://api.github.com/repos/${e}/${t}`;return st(je(`${r}/releases/latest`).pipe(de(()=>S),m(o=>({version:o.tag_name})),De({})),je(r).pipe(de(()=>S),m(o=>({stars:o.stargazers_count,forks:o.forks_count})),De({}))).pipe(m(([o,n])=>$($({},o),n)))}else{let r=`https://api.github.com/users/${e}`;return je(r).pipe(m(o=>({repositories:o.public_repos})),De({}))}}function bi(e,t){let r=`https://${e}/api/v4/projects/${encodeURIComponent(t)}`;return st(je(`${r}/releases/permalink/latest`).pipe(de(()=>S),m(({tag_name:o})=>({version:o})),De({})),je(r).pipe(de(()=>S),m(({star_count:o,forks_count:n})=>({stars:o,forks:n})),De({}))).pipe(m(([o,n])=>$($({},o),n)))}function vi(e){let t=e.match(/^.+github\.com\/([^/]+)\/?([^/]+)?/i);if(t){let[,r,o]=t;return hi(r,o)}if(t=e.match(/^.+?([^/]*gitlab[^/]+)\/(.+?)\/?$/i),t){let[,r,o]=t;return bi(r,o)}return S}var us;function ds(e){return us||(us=C(()=>{let t=__md_get("__source",sessionStorage);if(t)return I(t);if(ae("consent").length){let o=__md_get("__consent");if(!(o&&o.github))return S}return vi(e.href).pipe(w(o=>__md_set("__source",o,sessionStorage)))}).pipe(de(()=>S),b(t=>Object.keys(t).length>0),m(t=>({facts:t})),G(1)))}function gi(e){let t=R(":scope > :last-child",e);return C(()=>{let r=new g;return r.subscribe(({facts:o})=>{t.appendChild(_n(o)),t.classList.add("md-source__repository--active")}),ds(e).pipe(w(o=>r.next(o)),_(()=>r.complete()),m(o=>$({ref:e},o)))})}function hs(e,{viewport$:t,header$:r}){return ge(document.body).pipe(v(()=>mr(e,{header$:r,viewport$:t})),m(({offset:{y:o}})=>({hidden:o>=10})),ee("hidden"))}function yi(e,t){return C(()=>{let r=new g;return r.subscribe({next({hidden:o}){e.hidden=o},complete(){e.hidden=!1}}),(B("navigation.tabs.sticky")?I({hidden:!1}):hs(e,t)).pipe(w(o=>r.next(o)),_(()=>r.complete()),m(o=>$({ref:e},o)))})}function bs(e,{viewport$:t,header$:r}){let o=new Map,n=P(".md-nav__link",e);for(let s of n){let p=decodeURIComponent(s.hash.substring(1)),c=fe(`[id="${p}"]`);typeof c!="undefined"&&o.set(s,c)}let i=r.pipe(ee("height"),m(({height:s})=>{let p=Se("main"),c=R(":scope > :first-child",p);return s+.8*(c.offsetTop-p.offsetTop)}),pe());return ge(document.body).pipe(ee("height"),v(s=>C(()=>{let p=[];return I([...o].reduce((c,[l,f])=>{for(;p.length&&o.get(p[p.length-1]).tagName>=f.tagName;)p.pop();let u=f.offsetTop;for(;!u&&f.parentElement;)f=f.parentElement,u=f.offsetTop;let d=f.offsetParent;for(;d;d=d.offsetParent)u+=d.offsetTop;return c.set([...p=[...p,l]].reverse(),u)},new Map))}).pipe(m(p=>new Map([...p].sort(([,c],[,l])=>c-l))),He(i),v(([p,c])=>t.pipe(Fr(([l,f],{offset:{y:u},size:d})=>{let y=u+d.height>=Math.floor(s.height);for(;f.length;){let[,L]=f[0];if(L-c=u&&!y)f=[l.pop(),...f];else break}return[l,f]},[[],[...p]]),K((l,f)=>l[0]===f[0]&&l[1]===f[1])))))).pipe(m(([s,p])=>({prev:s.map(([c])=>c),next:p.map(([c])=>c)})),Q({prev:[],next:[]}),Be(2,1),m(([s,p])=>s.prev.length {let i=new g,a=i.pipe(Z(),ie(!0));if(i.subscribe(({prev:s,next:p})=>{for(let[c]of p)c.classList.remove("md-nav__link--passed"),c.classList.remove("md-nav__link--active");for(let[c,[l]]of s.entries())l.classList.add("md-nav__link--passed"),l.classList.toggle("md-nav__link--active",c===s.length-1)}),B("toc.follow")){let s=O(t.pipe(_e(1),m(()=>{})),t.pipe(_e(250),m(()=>"smooth")));i.pipe(b(({prev:p})=>p.length>0),He(o.pipe(ve(se))),re(s)).subscribe(([[{prev:p}],c])=>{let[l]=p[p.length-1];if(l.offsetHeight){let f=cr(l);if(typeof f!="undefined"){let u=l.offsetTop-f.offsetTop,{height:d}=ce(f);f.scrollTo({top:u-d/2,behavior:c})}}})}return B("navigation.tracking")&&t.pipe(W(a),ee("offset"),_e(250),Ce(1),W(n.pipe(Ce(1))),ct({delay:250}),re(i)).subscribe(([,{prev:s}])=>{let p=ye(),c=s[s.length-1];if(c&&c.length){let[l]=c,{hash:f}=new URL(l.href);p.hash!==f&&(p.hash=f,history.replaceState({},"",`${p}`))}else p.hash="",history.replaceState({},"",`${p}`)}),bs(e,{viewport$:t,header$:r}).pipe(w(s=>i.next(s)),_(()=>i.complete()),m(s=>$({ref:e},s)))})}function vs(e,{viewport$:t,main$:r,target$:o}){let n=t.pipe(m(({offset:{y:a}})=>a),Be(2,1),m(([a,s])=>a>s&&s>0),K()),i=r.pipe(m(({active:a})=>a));return z([i,n]).pipe(m(([a,s])=>!(a&&s)),K(),W(o.pipe(Ce(1))),ie(!0),ct({delay:250}),m(a=>({hidden:a})))}function Ei(e,{viewport$:t,header$:r,main$:o,target$:n}){let i=new g,a=i.pipe(Z(),ie(!0));return i.subscribe({next({hidden:s}){e.hidden=s,s?(e.setAttribute("tabindex","-1"),e.blur()):e.removeAttribute("tabindex")},complete(){e.style.top="",e.hidden=!0,e.removeAttribute("tabindex")}}),r.pipe(W(a),ee("height")).subscribe(({height:s})=>{e.style.top=`${s+16}px`}),h(e,"click").subscribe(s=>{s.preventDefault(),window.scrollTo({top:0})}),vs(e,{viewport$:t,main$:o,target$:n}).pipe(w(s=>i.next(s)),_(()=>i.complete()),m(s=>$({ref:e},s)))}function wi({document$:e,viewport$:t}){e.pipe(v(()=>P(".md-ellipsis")),ne(r=>tt(r).pipe(W(e.pipe(Ce(1))),b(o=>o),m(()=>r),Te(1))),b(r=>r.offsetWidth{let o=r.innerText,n=r.closest("a")||r;return n.title=o,B("content.tooltips")?mt(n,{viewport$:t}).pipe(W(e.pipe(Ce(1))),_(()=>n.removeAttribute("title"))):S})).subscribe(),B("content.tooltips")&&e.pipe(v(()=>P(".md-status")),ne(r=>mt(r,{viewport$:t}))).subscribe()}function Ti({document$:e,tablet$:t}){e.pipe(v(()=>P(".md-toggle--indeterminate")),w(r=>{r.indeterminate=!0,r.checked=!1}),ne(r=>h(r,"change").pipe(Dr(()=>r.classList.contains("md-toggle--indeterminate")),m(()=>r))),re(t)).subscribe(([r,o])=>{r.classList.remove("md-toggle--indeterminate"),o&&(r.checked=!1)})}function gs(){return/(iPad|iPhone|iPod)/.test(navigator.userAgent)}function Si({document$:e}){e.pipe(v(()=>P("[data-md-scrollfix]")),w(t=>t.removeAttribute("data-md-scrollfix")),b(gs),ne(t=>h(t,"touchstart").pipe(m(()=>t)))).subscribe(t=>{let r=t.scrollTop;r===0?t.scrollTop=1:r+t.offsetHeight===t.scrollHeight&&(t.scrollTop=r-1)})}function Oi({viewport$:e,tablet$:t}){z([ze("search"),t]).pipe(m(([r,o])=>r&&!o),v(r=>I(r).pipe(Ge(r?400:100))),re(e)).subscribe(([r,{offset:{y:o}}])=>{if(r)document.body.setAttribute("data-md-scrolllock",""),document.body.style.top=`-${o}px`;else{let n=-1*parseInt(document.body.style.top,10);document.body.removeAttribute("data-md-scrolllock"),document.body.style.top="",n&&window.scrollTo(0,n)}})}Object.entries||(Object.entries=function(e){let t=[];for(let r of Object.keys(e))t.push([r,e[r]]);return t});Object.values||(Object.values=function(e){let t=[];for(let r of Object.keys(e))t.push(e[r]);return t});typeof Element!="undefined"&&(Element.prototype.scrollTo||(Element.prototype.scrollTo=function(e,t){typeof e=="object"?(this.scrollLeft=e.left,this.scrollTop=e.top):(this.scrollLeft=e,this.scrollTop=t)}),Element.prototype.replaceWith||(Element.prototype.replaceWith=function(...e){let t=this.parentNode;if(t){e.length===0&&t.removeChild(this);for(let r=e.length-1;r>=0;r--){let o=e[r];typeof o=="string"?o=document.createTextNode(o):o.parentNode&&o.parentNode.removeChild(o),r?t.insertBefore(this.previousSibling,o):t.replaceChild(o,this)}}}));function ys(){return location.protocol==="file:"?Tt(`${new URL("search/search_index.js",eo.base)}`).pipe(m(()=>__index),G(1)):je(new URL("search/search_index.json",eo.base))}document.documentElement.classList.remove("no-js");document.documentElement.classList.add("js");var ot=Go(),Ut=sn(),Lt=ln(Ut),to=an(),Oe=gn(),hr=Pt("(min-width: 960px)"),Mi=Pt("(min-width: 1220px)"),_i=mn(),eo=xe(),Ai=document.forms.namedItem("search")?ys():Ye,ro=new g;Zn({alert$:ro});var oo=new g;B("navigation.instant")&&oi({location$:Ut,viewport$:Oe,progress$:oo}).subscribe(ot);var Li;((Li=eo.version)==null?void 0:Li.provider)==="mike"&&ci({document$:ot});O(Ut,Lt).pipe(Ge(125)).subscribe(()=>{Je("drawer",!1),Je("search",!1)});to.pipe(b(({mode:e})=>e==="global")).subscribe(e=>{switch(e.type){case"p":case",":let t=fe("link[rel=prev]");typeof t!="undefined"&<(t);break;case"n":case".":let r=fe("link[rel=next]");typeof r!="undefined"&<(r);break;case"Enter":let o=Ie();o instanceof HTMLLabelElement&&o.click()}});wi({viewport$:Oe,document$:ot});Ti({document$:ot,tablet$:hr});Si({document$:ot});Oi({viewport$:Oe,tablet$:hr});var rt=Kn(Se("header"),{viewport$:Oe}),Ft=ot.pipe(m(()=>Se("main")),v(e=>Gn(e,{viewport$:Oe,header$:rt})),G(1)),xs=O(...ae("consent").map(e=>En(e,{target$:Lt})),...ae("dialog").map(e=>qn(e,{alert$:ro})),...ae("palette").map(e=>Jn(e)),...ae("progress").map(e=>Xn(e,{progress$:oo})),...ae("search").map(e=>ui(e,{index$:Ai,keyboard$:to})),...ae("source").map(e=>gi(e))),Es=C(()=>O(...ae("announce").map(e=>xn(e)),...ae("content").map(e=>zn(e,{viewport$:Oe,target$:Lt,print$:_i})),...ae("content").map(e=>B("search.highlight")?di(e,{index$:Ai,location$:Ut}):S),...ae("header").map(e=>Yn(e,{viewport$:Oe,header$:rt,main$:Ft})),...ae("header-title").map(e=>Bn(e,{viewport$:Oe,header$:rt})),...ae("sidebar").map(e=>e.getAttribute("data-md-type")==="navigation"?Nr(Mi,()=>Zr(e,{viewport$:Oe,header$:rt,main$:Ft})):Nr(hr,()=>Zr(e,{viewport$:Oe,header$:rt,main$:Ft}))),...ae("tabs").map(e=>yi(e,{viewport$:Oe,header$:rt})),...ae("toc").map(e=>xi(e,{viewport$:Oe,header$:rt,main$:Ft,target$:Lt})),...ae("top").map(e=>Ei(e,{viewport$:Oe,header$:rt,main$:Ft,target$:Lt})))),Ci=ot.pipe(v(()=>Es),Re(xs),G(1));Ci.subscribe();window.document$=ot;window.location$=Ut;window.target$=Lt;window.keyboard$=to;window.viewport$=Oe;window.tablet$=hr;window.screen$=Mi;window.print$=_i;window.alert$=ro;window.progress$=oo;window.component$=Ci;})();
+//# sourceMappingURL=bundle.60a45f97.min.js.map
+
diff --git a/site/assets/javascripts/bundle.60a45f97.min.js.map b/site/assets/javascripts/bundle.60a45f97.min.js.map
new file mode 100644
index 00000000..7edbc6f4
--- /dev/null
+++ b/site/assets/javascripts/bundle.60a45f97.min.js.map
@@ -0,0 +1,7 @@
+{
+ "version": 3,
+ "sources": ["node_modules/focus-visible/dist/focus-visible.js", "node_modules/escape-html/index.js", "node_modules/clipboard/dist/clipboard.js", "src/templates/assets/javascripts/bundle.ts", "node_modules/tslib/tslib.es6.mjs", "node_modules/rxjs/src/internal/util/isFunction.ts", "node_modules/rxjs/src/internal/util/createErrorClass.ts", "node_modules/rxjs/src/internal/util/UnsubscriptionError.ts", "node_modules/rxjs/src/internal/util/arrRemove.ts", "node_modules/rxjs/src/internal/Subscription.ts", "node_modules/rxjs/src/internal/config.ts", "node_modules/rxjs/src/internal/scheduler/timeoutProvider.ts", "node_modules/rxjs/src/internal/util/reportUnhandledError.ts", "node_modules/rxjs/src/internal/util/noop.ts", "node_modules/rxjs/src/internal/NotificationFactories.ts", "node_modules/rxjs/src/internal/util/errorContext.ts", "node_modules/rxjs/src/internal/Subscriber.ts", "node_modules/rxjs/src/internal/symbol/observable.ts", "node_modules/rxjs/src/internal/util/identity.ts", "node_modules/rxjs/src/internal/util/pipe.ts", "node_modules/rxjs/src/internal/Observable.ts", "node_modules/rxjs/src/internal/util/lift.ts", "node_modules/rxjs/src/internal/operators/OperatorSubscriber.ts", "node_modules/rxjs/src/internal/scheduler/animationFrameProvider.ts", "node_modules/rxjs/src/internal/util/ObjectUnsubscribedError.ts", "node_modules/rxjs/src/internal/Subject.ts", "node_modules/rxjs/src/internal/BehaviorSubject.ts", "node_modules/rxjs/src/internal/scheduler/dateTimestampProvider.ts", "node_modules/rxjs/src/internal/ReplaySubject.ts", "node_modules/rxjs/src/internal/scheduler/Action.ts", "node_modules/rxjs/src/internal/scheduler/intervalProvider.ts", "node_modules/rxjs/src/internal/scheduler/AsyncAction.ts", "node_modules/rxjs/src/internal/Scheduler.ts", "node_modules/rxjs/src/internal/scheduler/AsyncScheduler.ts", "node_modules/rxjs/src/internal/scheduler/async.ts", "node_modules/rxjs/src/internal/scheduler/QueueAction.ts", "node_modules/rxjs/src/internal/scheduler/QueueScheduler.ts", "node_modules/rxjs/src/internal/scheduler/queue.ts", "node_modules/rxjs/src/internal/scheduler/AnimationFrameAction.ts", "node_modules/rxjs/src/internal/scheduler/AnimationFrameScheduler.ts", "node_modules/rxjs/src/internal/scheduler/animationFrame.ts", "node_modules/rxjs/src/internal/observable/empty.ts", "node_modules/rxjs/src/internal/util/isScheduler.ts", "node_modules/rxjs/src/internal/util/args.ts", "node_modules/rxjs/src/internal/util/isArrayLike.ts", "node_modules/rxjs/src/internal/util/isPromise.ts", "node_modules/rxjs/src/internal/util/isInteropObservable.ts", "node_modules/rxjs/src/internal/util/isAsyncIterable.ts", "node_modules/rxjs/src/internal/util/throwUnobservableError.ts", "node_modules/rxjs/src/internal/symbol/iterator.ts", "node_modules/rxjs/src/internal/util/isIterable.ts", "node_modules/rxjs/src/internal/util/isReadableStreamLike.ts", "node_modules/rxjs/src/internal/observable/innerFrom.ts", "node_modules/rxjs/src/internal/util/executeSchedule.ts", "node_modules/rxjs/src/internal/operators/observeOn.ts", "node_modules/rxjs/src/internal/operators/subscribeOn.ts", "node_modules/rxjs/src/internal/scheduled/scheduleObservable.ts", "node_modules/rxjs/src/internal/scheduled/schedulePromise.ts", "node_modules/rxjs/src/internal/scheduled/scheduleArray.ts", "node_modules/rxjs/src/internal/scheduled/scheduleIterable.ts", "node_modules/rxjs/src/internal/scheduled/scheduleAsyncIterable.ts", "node_modules/rxjs/src/internal/scheduled/scheduleReadableStreamLike.ts", "node_modules/rxjs/src/internal/scheduled/scheduled.ts", "node_modules/rxjs/src/internal/observable/from.ts", "node_modules/rxjs/src/internal/observable/of.ts", "node_modules/rxjs/src/internal/observable/throwError.ts", "node_modules/rxjs/src/internal/util/EmptyError.ts", "node_modules/rxjs/src/internal/util/isDate.ts", "node_modules/rxjs/src/internal/operators/map.ts", "node_modules/rxjs/src/internal/util/mapOneOrManyArgs.ts", "node_modules/rxjs/src/internal/util/argsArgArrayOrObject.ts", "node_modules/rxjs/src/internal/util/createObject.ts", "node_modules/rxjs/src/internal/observable/combineLatest.ts", "node_modules/rxjs/src/internal/operators/mergeInternals.ts", "node_modules/rxjs/src/internal/operators/mergeMap.ts", "node_modules/rxjs/src/internal/operators/mergeAll.ts", "node_modules/rxjs/src/internal/operators/concatAll.ts", "node_modules/rxjs/src/internal/observable/concat.ts", "node_modules/rxjs/src/internal/observable/defer.ts", "node_modules/rxjs/src/internal/observable/fromEvent.ts", "node_modules/rxjs/src/internal/observable/fromEventPattern.ts", "node_modules/rxjs/src/internal/observable/timer.ts", "node_modules/rxjs/src/internal/observable/merge.ts", "node_modules/rxjs/src/internal/observable/never.ts", "node_modules/rxjs/src/internal/util/argsOrArgArray.ts", "node_modules/rxjs/src/internal/operators/filter.ts", "node_modules/rxjs/src/internal/observable/zip.ts", "node_modules/rxjs/src/internal/operators/audit.ts", "node_modules/rxjs/src/internal/operators/auditTime.ts", "node_modules/rxjs/src/internal/operators/bufferCount.ts", "node_modules/rxjs/src/internal/operators/catchError.ts", "node_modules/rxjs/src/internal/operators/scanInternals.ts", "node_modules/rxjs/src/internal/operators/combineLatest.ts", "node_modules/rxjs/src/internal/operators/combineLatestWith.ts", "node_modules/rxjs/src/internal/operators/debounce.ts", "node_modules/rxjs/src/internal/operators/debounceTime.ts", "node_modules/rxjs/src/internal/operators/defaultIfEmpty.ts", "node_modules/rxjs/src/internal/operators/take.ts", "node_modules/rxjs/src/internal/operators/ignoreElements.ts", "node_modules/rxjs/src/internal/operators/mapTo.ts", "node_modules/rxjs/src/internal/operators/delayWhen.ts", "node_modules/rxjs/src/internal/operators/delay.ts", "node_modules/rxjs/src/internal/operators/distinctUntilChanged.ts", "node_modules/rxjs/src/internal/operators/distinctUntilKeyChanged.ts", "node_modules/rxjs/src/internal/operators/throwIfEmpty.ts", "node_modules/rxjs/src/internal/operators/endWith.ts", "node_modules/rxjs/src/internal/operators/finalize.ts", "node_modules/rxjs/src/internal/operators/first.ts", "node_modules/rxjs/src/internal/operators/takeLast.ts", "node_modules/rxjs/src/internal/operators/merge.ts", "node_modules/rxjs/src/internal/operators/mergeWith.ts", "node_modules/rxjs/src/internal/operators/repeat.ts", "node_modules/rxjs/src/internal/operators/scan.ts", "node_modules/rxjs/src/internal/operators/share.ts", "node_modules/rxjs/src/internal/operators/shareReplay.ts", "node_modules/rxjs/src/internal/operators/skip.ts", "node_modules/rxjs/src/internal/operators/skipUntil.ts", "node_modules/rxjs/src/internal/operators/startWith.ts", "node_modules/rxjs/src/internal/operators/switchMap.ts", "node_modules/rxjs/src/internal/operators/takeUntil.ts", "node_modules/rxjs/src/internal/operators/takeWhile.ts", "node_modules/rxjs/src/internal/operators/tap.ts", "node_modules/rxjs/src/internal/operators/throttle.ts", "node_modules/rxjs/src/internal/operators/throttleTime.ts", "node_modules/rxjs/src/internal/operators/withLatestFrom.ts", "node_modules/rxjs/src/internal/operators/zip.ts", "node_modules/rxjs/src/internal/operators/zipWith.ts", "src/templates/assets/javascripts/browser/document/index.ts", "src/templates/assets/javascripts/browser/element/_/index.ts", "src/templates/assets/javascripts/browser/element/focus/index.ts", "src/templates/assets/javascripts/browser/element/hover/index.ts", "src/templates/assets/javascripts/utilities/h/index.ts", "src/templates/assets/javascripts/utilities/round/index.ts", "src/templates/assets/javascripts/browser/script/index.ts", "src/templates/assets/javascripts/browser/element/size/_/index.ts", "src/templates/assets/javascripts/browser/element/size/content/index.ts", "src/templates/assets/javascripts/browser/element/offset/_/index.ts", "src/templates/assets/javascripts/browser/element/offset/content/index.ts", "src/templates/assets/javascripts/browser/element/visibility/index.ts", "src/templates/assets/javascripts/browser/toggle/index.ts", "src/templates/assets/javascripts/browser/keyboard/index.ts", "src/templates/assets/javascripts/browser/location/_/index.ts", "src/templates/assets/javascripts/browser/location/hash/index.ts", "src/templates/assets/javascripts/browser/media/index.ts", "src/templates/assets/javascripts/browser/request/index.ts", "src/templates/assets/javascripts/browser/viewport/offset/index.ts", "src/templates/assets/javascripts/browser/viewport/size/index.ts", "src/templates/assets/javascripts/browser/viewport/_/index.ts", "src/templates/assets/javascripts/browser/viewport/at/index.ts", "src/templates/assets/javascripts/browser/worker/index.ts", "src/templates/assets/javascripts/_/index.ts", "src/templates/assets/javascripts/components/_/index.ts", "src/templates/assets/javascripts/components/announce/index.ts", "src/templates/assets/javascripts/components/consent/index.ts", "src/templates/assets/javascripts/templates/tooltip/index.tsx", "src/templates/assets/javascripts/templates/annotation/index.tsx", "src/templates/assets/javascripts/templates/clipboard/index.tsx", "src/templates/assets/javascripts/templates/search/index.tsx", "src/templates/assets/javascripts/templates/source/index.tsx", "src/templates/assets/javascripts/templates/tabbed/index.tsx", "src/templates/assets/javascripts/templates/table/index.tsx", "src/templates/assets/javascripts/templates/version/index.tsx", "src/templates/assets/javascripts/components/tooltip2/index.ts", "src/templates/assets/javascripts/components/content/annotation/_/index.ts", "src/templates/assets/javascripts/components/content/annotation/list/index.ts", "src/templates/assets/javascripts/components/content/annotation/block/index.ts", "src/templates/assets/javascripts/components/content/code/_/index.ts", "src/templates/assets/javascripts/components/content/details/index.ts", "src/templates/assets/javascripts/components/content/mermaid/index.css", "src/templates/assets/javascripts/components/content/mermaid/index.ts", "src/templates/assets/javascripts/components/content/table/index.ts", "src/templates/assets/javascripts/components/content/tabs/index.ts", "src/templates/assets/javascripts/components/content/_/index.ts", "src/templates/assets/javascripts/components/dialog/index.ts", "src/templates/assets/javascripts/components/tooltip/index.ts", "src/templates/assets/javascripts/components/header/_/index.ts", "src/templates/assets/javascripts/components/header/title/index.ts", "src/templates/assets/javascripts/components/main/index.ts", "src/templates/assets/javascripts/components/palette/index.ts", "src/templates/assets/javascripts/components/progress/index.ts", "src/templates/assets/javascripts/integrations/clipboard/index.ts", "src/templates/assets/javascripts/integrations/sitemap/index.ts", "src/templates/assets/javascripts/integrations/instant/index.ts", "src/templates/assets/javascripts/integrations/search/highlighter/index.ts", "src/templates/assets/javascripts/integrations/search/worker/message/index.ts", "src/templates/assets/javascripts/integrations/search/worker/_/index.ts", "src/templates/assets/javascripts/integrations/version/findurl/index.ts", "src/templates/assets/javascripts/integrations/version/index.ts", "src/templates/assets/javascripts/components/search/query/index.ts", "src/templates/assets/javascripts/components/search/result/index.ts", "src/templates/assets/javascripts/components/search/share/index.ts", "src/templates/assets/javascripts/components/search/suggest/index.ts", "src/templates/assets/javascripts/components/search/_/index.ts", "src/templates/assets/javascripts/components/search/highlight/index.ts", "src/templates/assets/javascripts/components/sidebar/index.ts", "src/templates/assets/javascripts/components/source/facts/github/index.ts", "src/templates/assets/javascripts/components/source/facts/gitlab/index.ts", "src/templates/assets/javascripts/components/source/facts/_/index.ts", "src/templates/assets/javascripts/components/source/_/index.ts", "src/templates/assets/javascripts/components/tabs/index.ts", "src/templates/assets/javascripts/components/toc/index.ts", "src/templates/assets/javascripts/components/top/index.ts", "src/templates/assets/javascripts/patches/ellipsis/index.ts", "src/templates/assets/javascripts/patches/indeterminate/index.ts", "src/templates/assets/javascripts/patches/scrollfix/index.ts", "src/templates/assets/javascripts/patches/scrolllock/index.ts", "src/templates/assets/javascripts/polyfills/index.ts"],
+ "sourcesContent": ["(function (global, factory) {\n typeof exports === 'object' && typeof module !== 'undefined' ? factory() :\n typeof define === 'function' && define.amd ? define(factory) :\n (factory());\n}(this, (function () { 'use strict';\n\n /**\n * Applies the :focus-visible polyfill at the given scope.\n * A scope in this case is either the top-level Document or a Shadow Root.\n *\n * @param {(Document|ShadowRoot)} scope\n * @see https://github.com/WICG/focus-visible\n */\n function applyFocusVisiblePolyfill(scope) {\n var hadKeyboardEvent = true;\n var hadFocusVisibleRecently = false;\n var hadFocusVisibleRecentlyTimeout = null;\n\n var inputTypesAllowlist = {\n text: true,\n search: true,\n url: true,\n tel: true,\n email: true,\n password: true,\n number: true,\n date: true,\n month: true,\n week: true,\n time: true,\n datetime: true,\n 'datetime-local': true\n };\n\n /**\n * Helper function for legacy browsers and iframes which sometimes focus\n * elements like document, body, and non-interactive SVG.\n * @param {Element} el\n */\n function isValidFocusTarget(el) {\n if (\n el &&\n el !== document &&\n el.nodeName !== 'HTML' &&\n el.nodeName !== 'BODY' &&\n 'classList' in el &&\n 'contains' in el.classList\n ) {\n return true;\n }\n return false;\n }\n\n /**\n * Computes whether the given element should automatically trigger the\n * `focus-visible` class being added, i.e. whether it should always match\n * `:focus-visible` when focused.\n * @param {Element} el\n * @return {boolean}\n */\n function focusTriggersKeyboardModality(el) {\n var type = el.type;\n var tagName = el.tagName;\n\n if (tagName === 'INPUT' && inputTypesAllowlist[type] && !el.readOnly) {\n return true;\n }\n\n if (tagName === 'TEXTAREA' && !el.readOnly) {\n return true;\n }\n\n if (el.isContentEditable) {\n return true;\n }\n\n return false;\n }\n\n /**\n * Add the `focus-visible` class to the given element if it was not added by\n * the author.\n * @param {Element} el\n */\n function addFocusVisibleClass(el) {\n if (el.classList.contains('focus-visible')) {\n return;\n }\n el.classList.add('focus-visible');\n el.setAttribute('data-focus-visible-added', '');\n }\n\n /**\n * Remove the `focus-visible` class from the given element if it was not\n * originally added by the author.\n * @param {Element} el\n */\n function removeFocusVisibleClass(el) {\n if (!el.hasAttribute('data-focus-visible-added')) {\n return;\n }\n el.classList.remove('focus-visible');\n el.removeAttribute('data-focus-visible-added');\n }\n\n /**\n * If the most recent user interaction was via the keyboard;\n * and the key press did not include a meta, alt/option, or control key;\n * then the modality is keyboard. Otherwise, the modality is not keyboard.\n * Apply `focus-visible` to any current active element and keep track\n * of our keyboard modality state with `hadKeyboardEvent`.\n * @param {KeyboardEvent} e\n */\n function onKeyDown(e) {\n if (e.metaKey || e.altKey || e.ctrlKey) {\n return;\n }\n\n if (isValidFocusTarget(scope.activeElement)) {\n addFocusVisibleClass(scope.activeElement);\n }\n\n hadKeyboardEvent = true;\n }\n\n /**\n * If at any point a user clicks with a pointing device, ensure that we change\n * the modality away from keyboard.\n * This avoids the situation where a user presses a key on an already focused\n * element, and then clicks on a different element, focusing it with a\n * pointing device, while we still think we're in keyboard modality.\n * @param {Event} e\n */\n function onPointerDown(e) {\n hadKeyboardEvent = false;\n }\n\n /**\n * On `focus`, add the `focus-visible` class to the target if:\n * - the target received focus as a result of keyboard navigation, or\n * - the event target is an element that will likely require interaction\n * via the keyboard (e.g. a text box)\n * @param {Event} e\n */\n function onFocus(e) {\n // Prevent IE from focusing the document or HTML element.\n if (!isValidFocusTarget(e.target)) {\n return;\n }\n\n if (hadKeyboardEvent || focusTriggersKeyboardModality(e.target)) {\n addFocusVisibleClass(e.target);\n }\n }\n\n /**\n * On `blur`, remove the `focus-visible` class from the target.\n * @param {Event} e\n */\n function onBlur(e) {\n if (!isValidFocusTarget(e.target)) {\n return;\n }\n\n if (\n e.target.classList.contains('focus-visible') ||\n e.target.hasAttribute('data-focus-visible-added')\n ) {\n // To detect a tab/window switch, we look for a blur event followed\n // rapidly by a visibility change.\n // If we don't see a visibility change within 100ms, it's probably a\n // regular focus change.\n hadFocusVisibleRecently = true;\n window.clearTimeout(hadFocusVisibleRecentlyTimeout);\n hadFocusVisibleRecentlyTimeout = window.setTimeout(function() {\n hadFocusVisibleRecently = false;\n }, 100);\n removeFocusVisibleClass(e.target);\n }\n }\n\n /**\n * If the user changes tabs, keep track of whether or not the previously\n * focused element had .focus-visible.\n * @param {Event} e\n */\n function onVisibilityChange(e) {\n if (document.visibilityState === 'hidden') {\n // If the tab becomes active again, the browser will handle calling focus\n // on the element (Safari actually calls it twice).\n // If this tab change caused a blur on an element with focus-visible,\n // re-apply the class when the user switches back to the tab.\n if (hadFocusVisibleRecently) {\n hadKeyboardEvent = true;\n }\n addInitialPointerMoveListeners();\n }\n }\n\n /**\n * Add a group of listeners to detect usage of any pointing devices.\n * These listeners will be added when the polyfill first loads, and anytime\n * the window is blurred, so that they are active when the window regains\n * focus.\n */\n function addInitialPointerMoveListeners() {\n document.addEventListener('mousemove', onInitialPointerMove);\n document.addEventListener('mousedown', onInitialPointerMove);\n document.addEventListener('mouseup', onInitialPointerMove);\n document.addEventListener('pointermove', onInitialPointerMove);\n document.addEventListener('pointerdown', onInitialPointerMove);\n document.addEventListener('pointerup', onInitialPointerMove);\n document.addEventListener('touchmove', onInitialPointerMove);\n document.addEventListener('touchstart', onInitialPointerMove);\n document.addEventListener('touchend', onInitialPointerMove);\n }\n\n function removeInitialPointerMoveListeners() {\n document.removeEventListener('mousemove', onInitialPointerMove);\n document.removeEventListener('mousedown', onInitialPointerMove);\n document.removeEventListener('mouseup', onInitialPointerMove);\n document.removeEventListener('pointermove', onInitialPointerMove);\n document.removeEventListener('pointerdown', onInitialPointerMove);\n document.removeEventListener('pointerup', onInitialPointerMove);\n document.removeEventListener('touchmove', onInitialPointerMove);\n document.removeEventListener('touchstart', onInitialPointerMove);\n document.removeEventListener('touchend', onInitialPointerMove);\n }\n\n /**\n * When the polfyill first loads, assume the user is in keyboard modality.\n * If any event is received from a pointing device (e.g. mouse, pointer,\n * touch), turn off keyboard modality.\n * This accounts for situations where focus enters the page from the URL bar.\n * @param {Event} e\n */\n function onInitialPointerMove(e) {\n // Work around a Safari quirk that fires a mousemove on whenever the\n // window blurs, even if you're tabbing out of the page. \u00AF\\_(\u30C4)_/\u00AF\n if (e.target.nodeName && e.target.nodeName.toLowerCase() === 'html') {\n return;\n }\n\n hadKeyboardEvent = false;\n removeInitialPointerMoveListeners();\n }\n\n // For some kinds of state, we are interested in changes at the global scope\n // only. For example, global pointer input, global key presses and global\n // visibility change should affect the state at every scope:\n document.addEventListener('keydown', onKeyDown, true);\n document.addEventListener('mousedown', onPointerDown, true);\n document.addEventListener('pointerdown', onPointerDown, true);\n document.addEventListener('touchstart', onPointerDown, true);\n document.addEventListener('visibilitychange', onVisibilityChange, true);\n\n addInitialPointerMoveListeners();\n\n // For focus and blur, we specifically care about state changes in the local\n // scope. This is because focus / blur events that originate from within a\n // shadow root are not re-dispatched from the host element if it was already\n // the active element in its own scope:\n scope.addEventListener('focus', onFocus, true);\n scope.addEventListener('blur', onBlur, true);\n\n // We detect that a node is a ShadowRoot by ensuring that it is a\n // DocumentFragment and also has a host property. This check covers native\n // implementation and polyfill implementation transparently. If we only cared\n // about the native implementation, we could just check if the scope was\n // an instance of a ShadowRoot.\n if (scope.nodeType === Node.DOCUMENT_FRAGMENT_NODE && scope.host) {\n // Since a ShadowRoot is a special kind of DocumentFragment, it does not\n // have a root element to add a class to. So, we add this attribute to the\n // host element instead:\n scope.host.setAttribute('data-js-focus-visible', '');\n } else if (scope.nodeType === Node.DOCUMENT_NODE) {\n document.documentElement.classList.add('js-focus-visible');\n document.documentElement.setAttribute('data-js-focus-visible', '');\n }\n }\n\n // It is important to wrap all references to global window and document in\n // these checks to support server-side rendering use cases\n // @see https://github.com/WICG/focus-visible/issues/199\n if (typeof window !== 'undefined' && typeof document !== 'undefined') {\n // Make the polyfill helper globally available. This can be used as a signal\n // to interested libraries that wish to coordinate with the polyfill for e.g.,\n // applying the polyfill to a shadow root:\n window.applyFocusVisiblePolyfill = applyFocusVisiblePolyfill;\n\n // Notify interested libraries of the polyfill's presence, in case the\n // polyfill was loaded lazily:\n var event;\n\n try {\n event = new CustomEvent('focus-visible-polyfill-ready');\n } catch (error) {\n // IE11 does not support using CustomEvent as a constructor directly:\n event = document.createEvent('CustomEvent');\n event.initCustomEvent('focus-visible-polyfill-ready', false, false, {});\n }\n\n window.dispatchEvent(event);\n }\n\n if (typeof document !== 'undefined') {\n // Apply the polyfill to the global document, so that no JavaScript\n // coordination is required to use the polyfill in the top-level document:\n applyFocusVisiblePolyfill(document);\n }\n\n})));\n", "/*!\n * escape-html\n * Copyright(c) 2012-2013 TJ Holowaychuk\n * Copyright(c) 2015 Andreas Lubbe\n * Copyright(c) 2015 Tiancheng \"Timothy\" Gu\n * MIT Licensed\n */\n\n'use strict';\n\n/**\n * Module variables.\n * @private\n */\n\nvar matchHtmlRegExp = /[\"'&<>]/;\n\n/**\n * Module exports.\n * @public\n */\n\nmodule.exports = escapeHtml;\n\n/**\n * Escape special characters in the given string of html.\n *\n * @param {string} string The string to escape for inserting into HTML\n * @return {string}\n * @public\n */\n\nfunction escapeHtml(string) {\n var str = '' + string;\n var match = matchHtmlRegExp.exec(str);\n\n if (!match) {\n return str;\n }\n\n var escape;\n var html = '';\n var index = 0;\n var lastIndex = 0;\n\n for (index = match.index; index < str.length; index++) {\n switch (str.charCodeAt(index)) {\n case 34: // \"\n escape = '"';\n break;\n case 38: // &\n escape = '&';\n break;\n case 39: // '\n escape = ''';\n break;\n case 60: // <\n escape = '<';\n break;\n case 62: // >\n escape = '>';\n break;\n default:\n continue;\n }\n\n if (lastIndex !== index) {\n html += str.substring(lastIndex, index);\n }\n\n lastIndex = index + 1;\n html += escape;\n }\n\n return lastIndex !== index\n ? html + str.substring(lastIndex, index)\n : html;\n}\n", "/*!\n * clipboard.js v2.0.11\n * https://clipboardjs.com/\n *\n * Licensed MIT \u00A9 Zeno Rocha\n */\n(function webpackUniversalModuleDefinition(root, factory) {\n\tif(typeof exports === 'object' && typeof module === 'object')\n\t\tmodule.exports = factory();\n\telse if(typeof define === 'function' && define.amd)\n\t\tdefine([], factory);\n\telse if(typeof exports === 'object')\n\t\texports[\"ClipboardJS\"] = factory();\n\telse\n\t\troot[\"ClipboardJS\"] = factory();\n})(this, function() {\nreturn /******/ (function() { // webpackBootstrap\n/******/ \tvar __webpack_modules__ = ({\n\n/***/ 686:\n/***/ (function(__unused_webpack_module, __webpack_exports__, __webpack_require__) {\n\n\"use strict\";\n\n// EXPORTS\n__webpack_require__.d(__webpack_exports__, {\n \"default\": function() { return /* binding */ clipboard; }\n});\n\n// EXTERNAL MODULE: ./node_modules/tiny-emitter/index.js\nvar tiny_emitter = __webpack_require__(279);\nvar tiny_emitter_default = /*#__PURE__*/__webpack_require__.n(tiny_emitter);\n// EXTERNAL MODULE: ./node_modules/good-listener/src/listen.js\nvar listen = __webpack_require__(370);\nvar listen_default = /*#__PURE__*/__webpack_require__.n(listen);\n// EXTERNAL MODULE: ./node_modules/select/src/select.js\nvar src_select = __webpack_require__(817);\nvar select_default = /*#__PURE__*/__webpack_require__.n(src_select);\n;// CONCATENATED MODULE: ./src/common/command.js\n/**\n * Executes a given operation type.\n * @param {String} type\n * @return {Boolean}\n */\nfunction command(type) {\n try {\n return document.execCommand(type);\n } catch (err) {\n return false;\n }\n}\n;// CONCATENATED MODULE: ./src/actions/cut.js\n\n\n/**\n * Cut action wrapper.\n * @param {String|HTMLElement} target\n * @return {String}\n */\n\nvar ClipboardActionCut = function ClipboardActionCut(target) {\n var selectedText = select_default()(target);\n command('cut');\n return selectedText;\n};\n\n/* harmony default export */ var actions_cut = (ClipboardActionCut);\n;// CONCATENATED MODULE: ./src/common/create-fake-element.js\n/**\n * Creates a fake textarea element with a value.\n * @param {String} value\n * @return {HTMLElement}\n */\nfunction createFakeElement(value) {\n var isRTL = document.documentElement.getAttribute('dir') === 'rtl';\n var fakeElement = document.createElement('textarea'); // Prevent zooming on iOS\n\n fakeElement.style.fontSize = '12pt'; // Reset box model\n\n fakeElement.style.border = '0';\n fakeElement.style.padding = '0';\n fakeElement.style.margin = '0'; // Move element out of screen horizontally\n\n fakeElement.style.position = 'absolute';\n fakeElement.style[isRTL ? 'right' : 'left'] = '-9999px'; // Move element to the same position vertically\n\n var yPosition = window.pageYOffset || document.documentElement.scrollTop;\n fakeElement.style.top = \"\".concat(yPosition, \"px\");\n fakeElement.setAttribute('readonly', '');\n fakeElement.value = value;\n return fakeElement;\n}\n;// CONCATENATED MODULE: ./src/actions/copy.js\n\n\n\n/**\n * Create fake copy action wrapper using a fake element.\n * @param {String} target\n * @param {Object} options\n * @return {String}\n */\n\nvar fakeCopyAction = function fakeCopyAction(value, options) {\n var fakeElement = createFakeElement(value);\n options.container.appendChild(fakeElement);\n var selectedText = select_default()(fakeElement);\n command('copy');\n fakeElement.remove();\n return selectedText;\n};\n/**\n * Copy action wrapper.\n * @param {String|HTMLElement} target\n * @param {Object} options\n * @return {String}\n */\n\n\nvar ClipboardActionCopy = function ClipboardActionCopy(target) {\n var options = arguments.length > 1 && arguments[1] !== undefined ? arguments[1] : {\n container: document.body\n };\n var selectedText = '';\n\n if (typeof target === 'string') {\n selectedText = fakeCopyAction(target, options);\n } else if (target instanceof HTMLInputElement && !['text', 'search', 'url', 'tel', 'password'].includes(target === null || target === void 0 ? void 0 : target.type)) {\n // If input type doesn't support `setSelectionRange`. Simulate it. https://developer.mozilla.org/en-US/docs/Web/API/HTMLInputElement/setSelectionRange\n selectedText = fakeCopyAction(target.value, options);\n } else {\n selectedText = select_default()(target);\n command('copy');\n }\n\n return selectedText;\n};\n\n/* harmony default export */ var actions_copy = (ClipboardActionCopy);\n;// CONCATENATED MODULE: ./src/actions/default.js\nfunction _typeof(obj) { \"@babel/helpers - typeof\"; if (typeof Symbol === \"function\" && typeof Symbol.iterator === \"symbol\") { _typeof = function _typeof(obj) { return typeof obj; }; } else { _typeof = function _typeof(obj) { return obj && typeof Symbol === \"function\" && obj.constructor === Symbol && obj !== Symbol.prototype ? \"symbol\" : typeof obj; }; } return _typeof(obj); }\n\n\n\n/**\n * Inner function which performs selection from either `text` or `target`\n * properties and then executes copy or cut operations.\n * @param {Object} options\n */\n\nvar ClipboardActionDefault = function ClipboardActionDefault() {\n var options = arguments.length > 0 && arguments[0] !== undefined ? arguments[0] : {};\n // Defines base properties passed from constructor.\n var _options$action = options.action,\n action = _options$action === void 0 ? 'copy' : _options$action,\n container = options.container,\n target = options.target,\n text = options.text; // Sets the `action` to be performed which can be either 'copy' or 'cut'.\n\n if (action !== 'copy' && action !== 'cut') {\n throw new Error('Invalid \"action\" value, use either \"copy\" or \"cut\"');\n } // Sets the `target` property using an element that will be have its content copied.\n\n\n if (target !== undefined) {\n if (target && _typeof(target) === 'object' && target.nodeType === 1) {\n if (action === 'copy' && target.hasAttribute('disabled')) {\n throw new Error('Invalid \"target\" attribute. Please use \"readonly\" instead of \"disabled\" attribute');\n }\n\n if (action === 'cut' && (target.hasAttribute('readonly') || target.hasAttribute('disabled'))) {\n throw new Error('Invalid \"target\" attribute. You can\\'t cut text from elements with \"readonly\" or \"disabled\" attributes');\n }\n } else {\n throw new Error('Invalid \"target\" value, use a valid Element');\n }\n } // Define selection strategy based on `text` property.\n\n\n if (text) {\n return actions_copy(text, {\n container: container\n });\n } // Defines which selection strategy based on `target` property.\n\n\n if (target) {\n return action === 'cut' ? actions_cut(target) : actions_copy(target, {\n container: container\n });\n }\n};\n\n/* harmony default export */ var actions_default = (ClipboardActionDefault);\n;// CONCATENATED MODULE: ./src/clipboard.js\nfunction clipboard_typeof(obj) { \"@babel/helpers - typeof\"; if (typeof Symbol === \"function\" && typeof Symbol.iterator === \"symbol\") { clipboard_typeof = function _typeof(obj) { return typeof obj; }; } else { clipboard_typeof = function _typeof(obj) { return obj && typeof Symbol === \"function\" && obj.constructor === Symbol && obj !== Symbol.prototype ? \"symbol\" : typeof obj; }; } return clipboard_typeof(obj); }\n\nfunction _classCallCheck(instance, Constructor) { if (!(instance instanceof Constructor)) { throw new TypeError(\"Cannot call a class as a function\"); } }\n\nfunction _defineProperties(target, props) { for (var i = 0; i < props.length; i++) { var descriptor = props[i]; descriptor.enumerable = descriptor.enumerable || false; descriptor.configurable = true; if (\"value\" in descriptor) descriptor.writable = true; Object.defineProperty(target, descriptor.key, descriptor); } }\n\nfunction _createClass(Constructor, protoProps, staticProps) { if (protoProps) _defineProperties(Constructor.prototype, protoProps); if (staticProps) _defineProperties(Constructor, staticProps); return Constructor; }\n\nfunction _inherits(subClass, superClass) { if (typeof superClass !== \"function\" && superClass !== null) { throw new TypeError(\"Super expression must either be null or a function\"); } subClass.prototype = Object.create(superClass && superClass.prototype, { constructor: { value: subClass, writable: true, configurable: true } }); if (superClass) _setPrototypeOf(subClass, superClass); }\n\nfunction _setPrototypeOf(o, p) { _setPrototypeOf = Object.setPrototypeOf || function _setPrototypeOf(o, p) { o.__proto__ = p; return o; }; return _setPrototypeOf(o, p); }\n\nfunction _createSuper(Derived) { var hasNativeReflectConstruct = _isNativeReflectConstruct(); return function _createSuperInternal() { var Super = _getPrototypeOf(Derived), result; if (hasNativeReflectConstruct) { var NewTarget = _getPrototypeOf(this).constructor; result = Reflect.construct(Super, arguments, NewTarget); } else { result = Super.apply(this, arguments); } return _possibleConstructorReturn(this, result); }; }\n\nfunction _possibleConstructorReturn(self, call) { if (call && (clipboard_typeof(call) === \"object\" || typeof call === \"function\")) { return call; } return _assertThisInitialized(self); }\n\nfunction _assertThisInitialized(self) { if (self === void 0) { throw new ReferenceError(\"this hasn't been initialised - super() hasn't been called\"); } return self; }\n\nfunction _isNativeReflectConstruct() { if (typeof Reflect === \"undefined\" || !Reflect.construct) return false; if (Reflect.construct.sham) return false; if (typeof Proxy === \"function\") return true; try { Date.prototype.toString.call(Reflect.construct(Date, [], function () {})); return true; } catch (e) { return false; } }\n\nfunction _getPrototypeOf(o) { _getPrototypeOf = Object.setPrototypeOf ? Object.getPrototypeOf : function _getPrototypeOf(o) { return o.__proto__ || Object.getPrototypeOf(o); }; return _getPrototypeOf(o); }\n\n\n\n\n\n\n/**\n * Helper function to retrieve attribute value.\n * @param {String} suffix\n * @param {Element} element\n */\n\nfunction getAttributeValue(suffix, element) {\n var attribute = \"data-clipboard-\".concat(suffix);\n\n if (!element.hasAttribute(attribute)) {\n return;\n }\n\n return element.getAttribute(attribute);\n}\n/**\n * Base class which takes one or more elements, adds event listeners to them,\n * and instantiates a new `ClipboardAction` on each click.\n */\n\n\nvar Clipboard = /*#__PURE__*/function (_Emitter) {\n _inherits(Clipboard, _Emitter);\n\n var _super = _createSuper(Clipboard);\n\n /**\n * @param {String|HTMLElement|HTMLCollection|NodeList} trigger\n * @param {Object} options\n */\n function Clipboard(trigger, options) {\n var _this;\n\n _classCallCheck(this, Clipboard);\n\n _this = _super.call(this);\n\n _this.resolveOptions(options);\n\n _this.listenClick(trigger);\n\n return _this;\n }\n /**\n * Defines if attributes would be resolved using internal setter functions\n * or custom functions that were passed in the constructor.\n * @param {Object} options\n */\n\n\n _createClass(Clipboard, [{\n key: \"resolveOptions\",\n value: function resolveOptions() {\n var options = arguments.length > 0 && arguments[0] !== undefined ? arguments[0] : {};\n this.action = typeof options.action === 'function' ? options.action : this.defaultAction;\n this.target = typeof options.target === 'function' ? options.target : this.defaultTarget;\n this.text = typeof options.text === 'function' ? options.text : this.defaultText;\n this.container = clipboard_typeof(options.container) === 'object' ? options.container : document.body;\n }\n /**\n * Adds a click event listener to the passed trigger.\n * @param {String|HTMLElement|HTMLCollection|NodeList} trigger\n */\n\n }, {\n key: \"listenClick\",\n value: function listenClick(trigger) {\n var _this2 = this;\n\n this.listener = listen_default()(trigger, 'click', function (e) {\n return _this2.onClick(e);\n });\n }\n /**\n * Defines a new `ClipboardAction` on each click event.\n * @param {Event} e\n */\n\n }, {\n key: \"onClick\",\n value: function onClick(e) {\n var trigger = e.delegateTarget || e.currentTarget;\n var action = this.action(trigger) || 'copy';\n var text = actions_default({\n action: action,\n container: this.container,\n target: this.target(trigger),\n text: this.text(trigger)\n }); // Fires an event based on the copy operation result.\n\n this.emit(text ? 'success' : 'error', {\n action: action,\n text: text,\n trigger: trigger,\n clearSelection: function clearSelection() {\n if (trigger) {\n trigger.focus();\n }\n\n window.getSelection().removeAllRanges();\n }\n });\n }\n /**\n * Default `action` lookup function.\n * @param {Element} trigger\n */\n\n }, {\n key: \"defaultAction\",\n value: function defaultAction(trigger) {\n return getAttributeValue('action', trigger);\n }\n /**\n * Default `target` lookup function.\n * @param {Element} trigger\n */\n\n }, {\n key: \"defaultTarget\",\n value: function defaultTarget(trigger) {\n var selector = getAttributeValue('target', trigger);\n\n if (selector) {\n return document.querySelector(selector);\n }\n }\n /**\n * Allow fire programmatically a copy action\n * @param {String|HTMLElement} target\n * @param {Object} options\n * @returns Text copied.\n */\n\n }, {\n key: \"defaultText\",\n\n /**\n * Default `text` lookup function.\n * @param {Element} trigger\n */\n value: function defaultText(trigger) {\n return getAttributeValue('text', trigger);\n }\n /**\n * Destroy lifecycle.\n */\n\n }, {\n key: \"destroy\",\n value: function destroy() {\n this.listener.destroy();\n }\n }], [{\n key: \"copy\",\n value: function copy(target) {\n var options = arguments.length > 1 && arguments[1] !== undefined ? arguments[1] : {\n container: document.body\n };\n return actions_copy(target, options);\n }\n /**\n * Allow fire programmatically a cut action\n * @param {String|HTMLElement} target\n * @returns Text cutted.\n */\n\n }, {\n key: \"cut\",\n value: function cut(target) {\n return actions_cut(target);\n }\n /**\n * Returns the support of the given action, or all actions if no action is\n * given.\n * @param {String} [action]\n */\n\n }, {\n key: \"isSupported\",\n value: function isSupported() {\n var action = arguments.length > 0 && arguments[0] !== undefined ? arguments[0] : ['copy', 'cut'];\n var actions = typeof action === 'string' ? [action] : action;\n var support = !!document.queryCommandSupported;\n actions.forEach(function (action) {\n support = support && !!document.queryCommandSupported(action);\n });\n return support;\n }\n }]);\n\n return Clipboard;\n}((tiny_emitter_default()));\n\n/* harmony default export */ var clipboard = (Clipboard);\n\n/***/ }),\n\n/***/ 828:\n/***/ (function(module) {\n\nvar DOCUMENT_NODE_TYPE = 9;\n\n/**\n * A polyfill for Element.matches()\n */\nif (typeof Element !== 'undefined' && !Element.prototype.matches) {\n var proto = Element.prototype;\n\n proto.matches = proto.matchesSelector ||\n proto.mozMatchesSelector ||\n proto.msMatchesSelector ||\n proto.oMatchesSelector ||\n proto.webkitMatchesSelector;\n}\n\n/**\n * Finds the closest parent that matches a selector.\n *\n * @param {Element} element\n * @param {String} selector\n * @return {Function}\n */\nfunction closest (element, selector) {\n while (element && element.nodeType !== DOCUMENT_NODE_TYPE) {\n if (typeof element.matches === 'function' &&\n element.matches(selector)) {\n return element;\n }\n element = element.parentNode;\n }\n}\n\nmodule.exports = closest;\n\n\n/***/ }),\n\n/***/ 438:\n/***/ (function(module, __unused_webpack_exports, __webpack_require__) {\n\nvar closest = __webpack_require__(828);\n\n/**\n * Delegates event to a selector.\n *\n * @param {Element} element\n * @param {String} selector\n * @param {String} type\n * @param {Function} callback\n * @param {Boolean} useCapture\n * @return {Object}\n */\nfunction _delegate(element, selector, type, callback, useCapture) {\n var listenerFn = listener.apply(this, arguments);\n\n element.addEventListener(type, listenerFn, useCapture);\n\n return {\n destroy: function() {\n element.removeEventListener(type, listenerFn, useCapture);\n }\n }\n}\n\n/**\n * Delegates event to a selector.\n *\n * @param {Element|String|Array} [elements]\n * @param {String} selector\n * @param {String} type\n * @param {Function} callback\n * @param {Boolean} useCapture\n * @return {Object}\n */\nfunction delegate(elements, selector, type, callback, useCapture) {\n // Handle the regular Element usage\n if (typeof elements.addEventListener === 'function') {\n return _delegate.apply(null, arguments);\n }\n\n // Handle Element-less usage, it defaults to global delegation\n if (typeof type === 'function') {\n // Use `document` as the first parameter, then apply arguments\n // This is a short way to .unshift `arguments` without running into deoptimizations\n return _delegate.bind(null, document).apply(null, arguments);\n }\n\n // Handle Selector-based usage\n if (typeof elements === 'string') {\n elements = document.querySelectorAll(elements);\n }\n\n // Handle Array-like based usage\n return Array.prototype.map.call(elements, function (element) {\n return _delegate(element, selector, type, callback, useCapture);\n });\n}\n\n/**\n * Finds closest match and invokes callback.\n *\n * @param {Element} element\n * @param {String} selector\n * @param {String} type\n * @param {Function} callback\n * @return {Function}\n */\nfunction listener(element, selector, type, callback) {\n return function(e) {\n e.delegateTarget = closest(e.target, selector);\n\n if (e.delegateTarget) {\n callback.call(element, e);\n }\n }\n}\n\nmodule.exports = delegate;\n\n\n/***/ }),\n\n/***/ 879:\n/***/ (function(__unused_webpack_module, exports) {\n\n/**\n * Check if argument is a HTML element.\n *\n * @param {Object} value\n * @return {Boolean}\n */\nexports.node = function(value) {\n return value !== undefined\n && value instanceof HTMLElement\n && value.nodeType === 1;\n};\n\n/**\n * Check if argument is a list of HTML elements.\n *\n * @param {Object} value\n * @return {Boolean}\n */\nexports.nodeList = function(value) {\n var type = Object.prototype.toString.call(value);\n\n return value !== undefined\n && (type === '[object NodeList]' || type === '[object HTMLCollection]')\n && ('length' in value)\n && (value.length === 0 || exports.node(value[0]));\n};\n\n/**\n * Check if argument is a string.\n *\n * @param {Object} value\n * @return {Boolean}\n */\nexports.string = function(value) {\n return typeof value === 'string'\n || value instanceof String;\n};\n\n/**\n * Check if argument is a function.\n *\n * @param {Object} value\n * @return {Boolean}\n */\nexports.fn = function(value) {\n var type = Object.prototype.toString.call(value);\n\n return type === '[object Function]';\n};\n\n\n/***/ }),\n\n/***/ 370:\n/***/ (function(module, __unused_webpack_exports, __webpack_require__) {\n\nvar is = __webpack_require__(879);\nvar delegate = __webpack_require__(438);\n\n/**\n * Validates all params and calls the right\n * listener function based on its target type.\n *\n * @param {String|HTMLElement|HTMLCollection|NodeList} target\n * @param {String} type\n * @param {Function} callback\n * @return {Object}\n */\nfunction listen(target, type, callback) {\n if (!target && !type && !callback) {\n throw new Error('Missing required arguments');\n }\n\n if (!is.string(type)) {\n throw new TypeError('Second argument must be a String');\n }\n\n if (!is.fn(callback)) {\n throw new TypeError('Third argument must be a Function');\n }\n\n if (is.node(target)) {\n return listenNode(target, type, callback);\n }\n else if (is.nodeList(target)) {\n return listenNodeList(target, type, callback);\n }\n else if (is.string(target)) {\n return listenSelector(target, type, callback);\n }\n else {\n throw new TypeError('First argument must be a String, HTMLElement, HTMLCollection, or NodeList');\n }\n}\n\n/**\n * Adds an event listener to a HTML element\n * and returns a remove listener function.\n *\n * @param {HTMLElement} node\n * @param {String} type\n * @param {Function} callback\n * @return {Object}\n */\nfunction listenNode(node, type, callback) {\n node.addEventListener(type, callback);\n\n return {\n destroy: function() {\n node.removeEventListener(type, callback);\n }\n }\n}\n\n/**\n * Add an event listener to a list of HTML elements\n * and returns a remove listener function.\n *\n * @param {NodeList|HTMLCollection} nodeList\n * @param {String} type\n * @param {Function} callback\n * @return {Object}\n */\nfunction listenNodeList(nodeList, type, callback) {\n Array.prototype.forEach.call(nodeList, function(node) {\n node.addEventListener(type, callback);\n });\n\n return {\n destroy: function() {\n Array.prototype.forEach.call(nodeList, function(node) {\n node.removeEventListener(type, callback);\n });\n }\n }\n}\n\n/**\n * Add an event listener to a selector\n * and returns a remove listener function.\n *\n * @param {String} selector\n * @param {String} type\n * @param {Function} callback\n * @return {Object}\n */\nfunction listenSelector(selector, type, callback) {\n return delegate(document.body, selector, type, callback);\n}\n\nmodule.exports = listen;\n\n\n/***/ }),\n\n/***/ 817:\n/***/ (function(module) {\n\nfunction select(element) {\n var selectedText;\n\n if (element.nodeName === 'SELECT') {\n element.focus();\n\n selectedText = element.value;\n }\n else if (element.nodeName === 'INPUT' || element.nodeName === 'TEXTAREA') {\n var isReadOnly = element.hasAttribute('readonly');\n\n if (!isReadOnly) {\n element.setAttribute('readonly', '');\n }\n\n element.select();\n element.setSelectionRange(0, element.value.length);\n\n if (!isReadOnly) {\n element.removeAttribute('readonly');\n }\n\n selectedText = element.value;\n }\n else {\n if (element.hasAttribute('contenteditable')) {\n element.focus();\n }\n\n var selection = window.getSelection();\n var range = document.createRange();\n\n range.selectNodeContents(element);\n selection.removeAllRanges();\n selection.addRange(range);\n\n selectedText = selection.toString();\n }\n\n return selectedText;\n}\n\nmodule.exports = select;\n\n\n/***/ }),\n\n/***/ 279:\n/***/ (function(module) {\n\nfunction E () {\n // Keep this empty so it's easier to inherit from\n // (via https://github.com/lipsmack from https://github.com/scottcorgan/tiny-emitter/issues/3)\n}\n\nE.prototype = {\n on: function (name, callback, ctx) {\n var e = this.e || (this.e = {});\n\n (e[name] || (e[name] = [])).push({\n fn: callback,\n ctx: ctx\n });\n\n return this;\n },\n\n once: function (name, callback, ctx) {\n var self = this;\n function listener () {\n self.off(name, listener);\n callback.apply(ctx, arguments);\n };\n\n listener._ = callback\n return this.on(name, listener, ctx);\n },\n\n emit: function (name) {\n var data = [].slice.call(arguments, 1);\n var evtArr = ((this.e || (this.e = {}))[name] || []).slice();\n var i = 0;\n var len = evtArr.length;\n\n for (i; i < len; i++) {\n evtArr[i].fn.apply(evtArr[i].ctx, data);\n }\n\n return this;\n },\n\n off: function (name, callback) {\n var e = this.e || (this.e = {});\n var evts = e[name];\n var liveEvents = [];\n\n if (evts && callback) {\n for (var i = 0, len = evts.length; i < len; i++) {\n if (evts[i].fn !== callback && evts[i].fn._ !== callback)\n liveEvents.push(evts[i]);\n }\n }\n\n // Remove event from queue to prevent memory leak\n // Suggested by https://github.com/lazd\n // Ref: https://github.com/scottcorgan/tiny-emitter/commit/c6ebfaa9bc973b33d110a84a307742b7cf94c953#commitcomment-5024910\n\n (liveEvents.length)\n ? e[name] = liveEvents\n : delete e[name];\n\n return this;\n }\n};\n\nmodule.exports = E;\nmodule.exports.TinyEmitter = E;\n\n\n/***/ })\n\n/******/ \t});\n/************************************************************************/\n/******/ \t// The module cache\n/******/ \tvar __webpack_module_cache__ = {};\n/******/ \t\n/******/ \t// The require function\n/******/ \tfunction __webpack_require__(moduleId) {\n/******/ \t\t// Check if module is in cache\n/******/ \t\tif(__webpack_module_cache__[moduleId]) {\n/******/ \t\t\treturn __webpack_module_cache__[moduleId].exports;\n/******/ \t\t}\n/******/ \t\t// Create a new module (and put it into the cache)\n/******/ \t\tvar module = __webpack_module_cache__[moduleId] = {\n/******/ \t\t\t// no module.id needed\n/******/ \t\t\t// no module.loaded needed\n/******/ \t\t\texports: {}\n/******/ \t\t};\n/******/ \t\n/******/ \t\t// Execute the module function\n/******/ \t\t__webpack_modules__[moduleId](module, module.exports, __webpack_require__);\n/******/ \t\n/******/ \t\t// Return the exports of the module\n/******/ \t\treturn module.exports;\n/******/ \t}\n/******/ \t\n/************************************************************************/\n/******/ \t/* webpack/runtime/compat get default export */\n/******/ \t!function() {\n/******/ \t\t// getDefaultExport function for compatibility with non-harmony modules\n/******/ \t\t__webpack_require__.n = function(module) {\n/******/ \t\t\tvar getter = module && module.__esModule ?\n/******/ \t\t\t\tfunction() { return module['default']; } :\n/******/ \t\t\t\tfunction() { return module; };\n/******/ \t\t\t__webpack_require__.d(getter, { a: getter });\n/******/ \t\t\treturn getter;\n/******/ \t\t};\n/******/ \t}();\n/******/ \t\n/******/ \t/* webpack/runtime/define property getters */\n/******/ \t!function() {\n/******/ \t\t// define getter functions for harmony exports\n/******/ \t\t__webpack_require__.d = function(exports, definition) {\n/******/ \t\t\tfor(var key in definition) {\n/******/ \t\t\t\tif(__webpack_require__.o(definition, key) && !__webpack_require__.o(exports, key)) {\n/******/ \t\t\t\t\tObject.defineProperty(exports, key, { enumerable: true, get: definition[key] });\n/******/ \t\t\t\t}\n/******/ \t\t\t}\n/******/ \t\t};\n/******/ \t}();\n/******/ \t\n/******/ \t/* webpack/runtime/hasOwnProperty shorthand */\n/******/ \t!function() {\n/******/ \t\t__webpack_require__.o = function(obj, prop) { return Object.prototype.hasOwnProperty.call(obj, prop); }\n/******/ \t}();\n/******/ \t\n/************************************************************************/\n/******/ \t// module exports must be returned from runtime so entry inlining is disabled\n/******/ \t// startup\n/******/ \t// Load entry module and return exports\n/******/ \treturn __webpack_require__(686);\n/******/ })()\n.default;\n});", "/*\n * Copyright (c) 2016-2025 Martin Donath \n *\n * Permission is hereby granted, free of charge, to any person obtaining a copy\n * of this software and associated documentation files (the \"Software\"), to\n * deal in the Software without restriction, including without limitation the\n * rights to use, copy, modify, merge, publish, distribute, sublicense, and/or\n * sell copies of the Software, and to permit persons to whom the Software is\n * furnished to do so, subject to the following conditions:\n *\n * The above copyright notice and this permission notice shall be included in\n * all copies or substantial portions of the Software.\n *\n * THE SOFTWARE IS PROVIDED \"AS IS\", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR\n * IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,\n * FITNESS FOR A PARTICULAR PURPOSE AND NON-INFRINGEMENT. IN NO EVENT SHALL THE\n * AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER\n * LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING\n * FROM, OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS\n * IN THE SOFTWARE.\n */\n\nimport \"focus-visible\"\n\nimport {\n EMPTY,\n NEVER,\n Observable,\n Subject,\n defer,\n delay,\n filter,\n map,\n merge,\n mergeWith,\n shareReplay,\n switchMap\n} from \"rxjs\"\n\nimport { configuration, feature } from \"./_\"\nimport {\n at,\n getActiveElement,\n getOptionalElement,\n requestJSON,\n setLocation,\n setToggle,\n watchDocument,\n watchKeyboard,\n watchLocation,\n watchLocationTarget,\n watchMedia,\n watchPrint,\n watchScript,\n watchViewport\n} from \"./browser\"\nimport {\n getComponentElement,\n getComponentElements,\n mountAnnounce,\n mountBackToTop,\n mountConsent,\n mountContent,\n mountDialog,\n mountHeader,\n mountHeaderTitle,\n mountPalette,\n mountProgress,\n mountSearch,\n mountSearchHiglight,\n mountSidebar,\n mountSource,\n mountTableOfContents,\n mountTabs,\n watchHeader,\n watchMain\n} from \"./components\"\nimport {\n SearchIndex,\n setupClipboardJS,\n setupInstantNavigation,\n setupVersionSelector\n} from \"./integrations\"\nimport {\n patchEllipsis,\n patchIndeterminate,\n patchScrollfix,\n patchScrolllock\n} from \"./patches\"\nimport \"./polyfills\"\n\n/* ----------------------------------------------------------------------------\n * Functions - @todo refactor\n * ------------------------------------------------------------------------- */\n\n/**\n * Fetch search index\n *\n * @returns Search index observable\n */\nfunction fetchSearchIndex(): Observable {\n if (location.protocol === \"file:\") {\n return watchScript(\n `${new URL(\"search/search_index.js\", config.base)}`\n )\n .pipe(\n // @ts-ignore - @todo fix typings\n map(() => __index),\n shareReplay(1)\n )\n } else {\n return requestJSON(\n new URL(\"search/search_index.json\", config.base)\n )\n }\n}\n\n/* ----------------------------------------------------------------------------\n * Application\n * ------------------------------------------------------------------------- */\n\n/* Yay, JavaScript is available */\ndocument.documentElement.classList.remove(\"no-js\")\ndocument.documentElement.classList.add(\"js\")\n\n/* Set up navigation observables and subjects */\nconst document$ = watchDocument()\nconst location$ = watchLocation()\nconst target$ = watchLocationTarget(location$)\nconst keyboard$ = watchKeyboard()\n\n/* Set up media observables */\nconst viewport$ = watchViewport()\nconst tablet$ = watchMedia(\"(min-width: 960px)\")\nconst screen$ = watchMedia(\"(min-width: 1220px)\")\nconst print$ = watchPrint()\n\n/* Retrieve search index, if search is enabled */\nconst config = configuration()\nconst index$ = document.forms.namedItem(\"search\")\n ? fetchSearchIndex()\n : NEVER\n\n/* Set up Clipboard.js integration */\nconst alert$ = new Subject()\nsetupClipboardJS({ alert$ })\n\n/* Set up progress indicator */\nconst progress$ = new Subject()\n\n/* Set up instant navigation, if enabled */\nif (feature(\"navigation.instant\"))\n setupInstantNavigation({ location$, viewport$, progress$ })\n .subscribe(document$)\n\n/* Set up version selector */\nif (config.version?.provider === \"mike\")\n setupVersionSelector({ document$ })\n\n/* Always close drawer and search on navigation */\nmerge(location$, target$)\n .pipe(\n delay(125)\n )\n .subscribe(() => {\n setToggle(\"drawer\", false)\n setToggle(\"search\", false)\n })\n\n/* Set up global keyboard handlers */\nkeyboard$\n .pipe(\n filter(({ mode }) => mode === \"global\")\n )\n .subscribe(key => {\n switch (key.type) {\n\n /* Go to previous page */\n case \"p\":\n case \",\":\n const prev = getOptionalElement(\"link[rel=prev]\")\n if (typeof prev !== \"undefined\")\n setLocation(prev)\n break\n\n /* Go to next page */\n case \"n\":\n case \".\":\n const next = getOptionalElement(\"link[rel=next]\")\n if (typeof next !== \"undefined\")\n setLocation(next)\n break\n\n /* Expand navigation, see https://bit.ly/3ZjG5io */\n case \"Enter\":\n const active = getActiveElement()\n if (active instanceof HTMLLabelElement)\n active.click()\n }\n })\n\n/* Set up patches */\npatchEllipsis({ viewport$, document$ })\npatchIndeterminate({ document$, tablet$ })\npatchScrollfix({ document$ })\npatchScrolllock({ viewport$, tablet$ })\n\n/* Set up header and main area observable */\nconst header$ = watchHeader(getComponentElement(\"header\"), { viewport$ })\nconst main$ = document$\n .pipe(\n map(() => getComponentElement(\"main\")),\n switchMap(el => watchMain(el, { viewport$, header$ })),\n shareReplay(1)\n )\n\n/* Set up control component observables */\nconst control$ = merge(\n\n /* Consent */\n ...getComponentElements(\"consent\")\n .map(el => mountConsent(el, { target$ })),\n\n /* Dialog */\n ...getComponentElements(\"dialog\")\n .map(el => mountDialog(el, { alert$ })),\n\n /* Color palette */\n ...getComponentElements(\"palette\")\n .map(el => mountPalette(el)),\n\n /* Progress bar */\n ...getComponentElements(\"progress\")\n .map(el => mountProgress(el, { progress$ })),\n\n /* Search */\n ...getComponentElements(\"search\")\n .map(el => mountSearch(el, { index$, keyboard$ })),\n\n /* Repository information */\n ...getComponentElements(\"source\")\n .map(el => mountSource(el))\n)\n\n/* Set up content component observables */\nconst content$ = defer(() => merge(\n\n /* Announcement bar */\n ...getComponentElements(\"announce\")\n .map(el => mountAnnounce(el)),\n\n /* Content */\n ...getComponentElements(\"content\")\n .map(el => mountContent(el, { viewport$, target$, print$ })),\n\n /* Search highlighting */\n ...getComponentElements(\"content\")\n .map(el => feature(\"search.highlight\")\n ? mountSearchHiglight(el, { index$, location$ })\n : EMPTY\n ),\n\n /* Header */\n ...getComponentElements(\"header\")\n .map(el => mountHeader(el, { viewport$, header$, main$ })),\n\n /* Header title */\n ...getComponentElements(\"header-title\")\n .map(el => mountHeaderTitle(el, { viewport$, header$ })),\n\n /* Sidebar */\n ...getComponentElements(\"sidebar\")\n .map(el => el.getAttribute(\"data-md-type\") === \"navigation\"\n ? at(screen$, () => mountSidebar(el, { viewport$, header$, main$ }))\n : at(tablet$, () => mountSidebar(el, { viewport$, header$, main$ }))\n ),\n\n /* Navigation tabs */\n ...getComponentElements(\"tabs\")\n .map(el => mountTabs(el, { viewport$, header$ })),\n\n /* Table of contents */\n ...getComponentElements(\"toc\")\n .map(el => mountTableOfContents(el, {\n viewport$, header$, main$, target$\n })),\n\n /* Back-to-top button */\n ...getComponentElements(\"top\")\n .map(el => mountBackToTop(el, { viewport$, header$, main$, target$ }))\n))\n\n/* Set up component observables */\nconst component$ = document$\n .pipe(\n switchMap(() => content$),\n mergeWith(control$),\n shareReplay(1)\n )\n\n/* Subscribe to all components */\ncomponent$.subscribe()\n\n/* ----------------------------------------------------------------------------\n * Exports\n * ------------------------------------------------------------------------- */\n\nwindow.document$ = document$ /* Document observable */\nwindow.location$ = location$ /* Location subject */\nwindow.target$ = target$ /* Location target observable */\nwindow.keyboard$ = keyboard$ /* Keyboard observable */\nwindow.viewport$ = viewport$ /* Viewport observable */\nwindow.tablet$ = tablet$ /* Media tablet observable */\nwindow.screen$ = screen$ /* Media screen observable */\nwindow.print$ = print$ /* Media print observable */\nwindow.alert$ = alert$ /* Alert subject */\nwindow.progress$ = progress$ /* Progress indicator subject */\nwindow.component$ = component$ /* Component observable */\n", "/******************************************************************************\nCopyright (c) Microsoft Corporation.\n\nPermission to use, copy, modify, and/or distribute this software for any\npurpose with or without fee is hereby granted.\n\nTHE SOFTWARE IS PROVIDED \"AS IS\" AND THE AUTHOR DISCLAIMS ALL WARRANTIES WITH\nREGARD TO THIS SOFTWARE INCLUDING ALL IMPLIED WARRANTIES OF MERCHANTABILITY\nAND FITNESS. IN NO EVENT SHALL THE AUTHOR BE LIABLE FOR ANY SPECIAL, DIRECT,\nINDIRECT, OR CONSEQUENTIAL DAMAGES OR ANY DAMAGES WHATSOEVER RESULTING FROM\nLOSS OF USE, DATA OR PROFITS, WHETHER IN AN ACTION OF CONTRACT, NEGLIGENCE OR\nOTHER TORTIOUS ACTION, ARISING OUT OF OR IN CONNECTION WITH THE USE OR\nPERFORMANCE OF THIS SOFTWARE.\n***************************************************************************** */\n/* global Reflect, Promise, SuppressedError, Symbol, Iterator */\n\nvar extendStatics = function(d, b) {\n extendStatics = Object.setPrototypeOf ||\n ({ __proto__: [] } instanceof Array && function (d, b) { d.__proto__ = b; }) ||\n function (d, b) { for (var p in b) if (Object.prototype.hasOwnProperty.call(b, p)) d[p] = b[p]; };\n return extendStatics(d, b);\n};\n\nexport function __extends(d, b) {\n if (typeof b !== \"function\" && b !== null)\n throw new TypeError(\"Class extends value \" + String(b) + \" is not a constructor or null\");\n extendStatics(d, b);\n function __() { this.constructor = d; }\n d.prototype = b === null ? Object.create(b) : (__.prototype = b.prototype, new __());\n}\n\nexport var __assign = function() {\n __assign = Object.assign || function __assign(t) {\n for (var s, i = 1, n = arguments.length; i < n; i++) {\n s = arguments[i];\n for (var p in s) if (Object.prototype.hasOwnProperty.call(s, p)) t[p] = s[p];\n }\n return t;\n }\n return __assign.apply(this, arguments);\n}\n\nexport function __rest(s, e) {\n var t = {};\n for (var p in s) if (Object.prototype.hasOwnProperty.call(s, p) && e.indexOf(p) < 0)\n t[p] = s[p];\n if (s != null && typeof Object.getOwnPropertySymbols === \"function\")\n for (var i = 0, p = Object.getOwnPropertySymbols(s); i < p.length; i++) {\n if (e.indexOf(p[i]) < 0 && Object.prototype.propertyIsEnumerable.call(s, p[i]))\n t[p[i]] = s[p[i]];\n }\n return t;\n}\n\nexport function __decorate(decorators, target, key, desc) {\n var c = arguments.length, r = c < 3 ? target : desc === null ? desc = Object.getOwnPropertyDescriptor(target, key) : desc, d;\n if (typeof Reflect === \"object\" && typeof Reflect.decorate === \"function\") r = Reflect.decorate(decorators, target, key, desc);\n else for (var i = decorators.length - 1; i >= 0; i--) if (d = decorators[i]) r = (c < 3 ? d(r) : c > 3 ? d(target, key, r) : d(target, key)) || r;\n return c > 3 && r && Object.defineProperty(target, key, r), r;\n}\n\nexport function __param(paramIndex, decorator) {\n return function (target, key) { decorator(target, key, paramIndex); }\n}\n\nexport function __esDecorate(ctor, descriptorIn, decorators, contextIn, initializers, extraInitializers) {\n function accept(f) { if (f !== void 0 && typeof f !== \"function\") throw new TypeError(\"Function expected\"); return f; }\n var kind = contextIn.kind, key = kind === \"getter\" ? \"get\" : kind === \"setter\" ? \"set\" : \"value\";\n var target = !descriptorIn && ctor ? contextIn[\"static\"] ? ctor : ctor.prototype : null;\n var descriptor = descriptorIn || (target ? Object.getOwnPropertyDescriptor(target, contextIn.name) : {});\n var _, done = false;\n for (var i = decorators.length - 1; i >= 0; i--) {\n var context = {};\n for (var p in contextIn) context[p] = p === \"access\" ? {} : contextIn[p];\n for (var p in contextIn.access) context.access[p] = contextIn.access[p];\n context.addInitializer = function (f) { if (done) throw new TypeError(\"Cannot add initializers after decoration has completed\"); extraInitializers.push(accept(f || null)); };\n var result = (0, decorators[i])(kind === \"accessor\" ? { get: descriptor.get, set: descriptor.set } : descriptor[key], context);\n if (kind === \"accessor\") {\n if (result === void 0) continue;\n if (result === null || typeof result !== \"object\") throw new TypeError(\"Object expected\");\n if (_ = accept(result.get)) descriptor.get = _;\n if (_ = accept(result.set)) descriptor.set = _;\n if (_ = accept(result.init)) initializers.unshift(_);\n }\n else if (_ = accept(result)) {\n if (kind === \"field\") initializers.unshift(_);\n else descriptor[key] = _;\n }\n }\n if (target) Object.defineProperty(target, contextIn.name, descriptor);\n done = true;\n};\n\nexport function __runInitializers(thisArg, initializers, value) {\n var useValue = arguments.length > 2;\n for (var i = 0; i < initializers.length; i++) {\n value = useValue ? initializers[i].call(thisArg, value) : initializers[i].call(thisArg);\n }\n return useValue ? value : void 0;\n};\n\nexport function __propKey(x) {\n return typeof x === \"symbol\" ? x : \"\".concat(x);\n};\n\nexport function __setFunctionName(f, name, prefix) {\n if (typeof name === \"symbol\") name = name.description ? \"[\".concat(name.description, \"]\") : \"\";\n return Object.defineProperty(f, \"name\", { configurable: true, value: prefix ? \"\".concat(prefix, \" \", name) : name });\n};\n\nexport function __metadata(metadataKey, metadataValue) {\n if (typeof Reflect === \"object\" && typeof Reflect.metadata === \"function\") return Reflect.metadata(metadataKey, metadataValue);\n}\n\nexport function __awaiter(thisArg, _arguments, P, generator) {\n function adopt(value) { return value instanceof P ? value : new P(function (resolve) { resolve(value); }); }\n return new (P || (P = Promise))(function (resolve, reject) {\n function fulfilled(value) { try { step(generator.next(value)); } catch (e) { reject(e); } }\n function rejected(value) { try { step(generator[\"throw\"](value)); } catch (e) { reject(e); } }\n function step(result) { result.done ? resolve(result.value) : adopt(result.value).then(fulfilled, rejected); }\n step((generator = generator.apply(thisArg, _arguments || [])).next());\n });\n}\n\nexport function __generator(thisArg, body) {\n var _ = { label: 0, sent: function() { if (t[0] & 1) throw t[1]; return t[1]; }, trys: [], ops: [] }, f, y, t, g = Object.create((typeof Iterator === \"function\" ? Iterator : Object).prototype);\n return g.next = verb(0), g[\"throw\"] = verb(1), g[\"return\"] = verb(2), typeof Symbol === \"function\" && (g[Symbol.iterator] = function() { return this; }), g;\n function verb(n) { return function (v) { return step([n, v]); }; }\n function step(op) {\n if (f) throw new TypeError(\"Generator is already executing.\");\n while (g && (g = 0, op[0] && (_ = 0)), _) try {\n if (f = 1, y && (t = op[0] & 2 ? y[\"return\"] : op[0] ? y[\"throw\"] || ((t = y[\"return\"]) && t.call(y), 0) : y.next) && !(t = t.call(y, op[1])).done) return t;\n if (y = 0, t) op = [op[0] & 2, t.value];\n switch (op[0]) {\n case 0: case 1: t = op; break;\n case 4: _.label++; return { value: op[1], done: false };\n case 5: _.label++; y = op[1]; op = [0]; continue;\n case 7: op = _.ops.pop(); _.trys.pop(); continue;\n default:\n if (!(t = _.trys, t = t.length > 0 && t[t.length - 1]) && (op[0] === 6 || op[0] === 2)) { _ = 0; continue; }\n if (op[0] === 3 && (!t || (op[1] > t[0] && op[1] < t[3]))) { _.label = op[1]; break; }\n if (op[0] === 6 && _.label < t[1]) { _.label = t[1]; t = op; break; }\n if (t && _.label < t[2]) { _.label = t[2]; _.ops.push(op); break; }\n if (t[2]) _.ops.pop();\n _.trys.pop(); continue;\n }\n op = body.call(thisArg, _);\n } catch (e) { op = [6, e]; y = 0; } finally { f = t = 0; }\n if (op[0] & 5) throw op[1]; return { value: op[0] ? op[1] : void 0, done: true };\n }\n}\n\nexport var __createBinding = Object.create ? (function(o, m, k, k2) {\n if (k2 === undefined) k2 = k;\n var desc = Object.getOwnPropertyDescriptor(m, k);\n if (!desc || (\"get\" in desc ? !m.__esModule : desc.writable || desc.configurable)) {\n desc = { enumerable: true, get: function() { return m[k]; } };\n }\n Object.defineProperty(o, k2, desc);\n}) : (function(o, m, k, k2) {\n if (k2 === undefined) k2 = k;\n o[k2] = m[k];\n});\n\nexport function __exportStar(m, o) {\n for (var p in m) if (p !== \"default\" && !Object.prototype.hasOwnProperty.call(o, p)) __createBinding(o, m, p);\n}\n\nexport function __values(o) {\n var s = typeof Symbol === \"function\" && Symbol.iterator, m = s && o[s], i = 0;\n if (m) return m.call(o);\n if (o && typeof o.length === \"number\") return {\n next: function () {\n if (o && i >= o.length) o = void 0;\n return { value: o && o[i++], done: !o };\n }\n };\n throw new TypeError(s ? \"Object is not iterable.\" : \"Symbol.iterator is not defined.\");\n}\n\nexport function __read(o, n) {\n var m = typeof Symbol === \"function\" && o[Symbol.iterator];\n if (!m) return o;\n var i = m.call(o), r, ar = [], e;\n try {\n while ((n === void 0 || n-- > 0) && !(r = i.next()).done) ar.push(r.value);\n }\n catch (error) { e = { error: error }; }\n finally {\n try {\n if (r && !r.done && (m = i[\"return\"])) m.call(i);\n }\n finally { if (e) throw e.error; }\n }\n return ar;\n}\n\n/** @deprecated */\nexport function __spread() {\n for (var ar = [], i = 0; i < arguments.length; i++)\n ar = ar.concat(__read(arguments[i]));\n return ar;\n}\n\n/** @deprecated */\nexport function __spreadArrays() {\n for (var s = 0, i = 0, il = arguments.length; i < il; i++) s += arguments[i].length;\n for (var r = Array(s), k = 0, i = 0; i < il; i++)\n for (var a = arguments[i], j = 0, jl = a.length; j < jl; j++, k++)\n r[k] = a[j];\n return r;\n}\n\nexport function __spreadArray(to, from, pack) {\n if (pack || arguments.length === 2) for (var i = 0, l = from.length, ar; i < l; i++) {\n if (ar || !(i in from)) {\n if (!ar) ar = Array.prototype.slice.call(from, 0, i);\n ar[i] = from[i];\n }\n }\n return to.concat(ar || Array.prototype.slice.call(from));\n}\n\nexport function __await(v) {\n return this instanceof __await ? (this.v = v, this) : new __await(v);\n}\n\nexport function __asyncGenerator(thisArg, _arguments, generator) {\n if (!Symbol.asyncIterator) throw new TypeError(\"Symbol.asyncIterator is not defined.\");\n var g = generator.apply(thisArg, _arguments || []), i, q = [];\n return i = Object.create((typeof AsyncIterator === \"function\" ? AsyncIterator : Object).prototype), verb(\"next\"), verb(\"throw\"), verb(\"return\", awaitReturn), i[Symbol.asyncIterator] = function () { return this; }, i;\n function awaitReturn(f) { return function (v) { return Promise.resolve(v).then(f, reject); }; }\n function verb(n, f) { if (g[n]) { i[n] = function (v) { return new Promise(function (a, b) { q.push([n, v, a, b]) > 1 || resume(n, v); }); }; if (f) i[n] = f(i[n]); } }\n function resume(n, v) { try { step(g[n](v)); } catch (e) { settle(q[0][3], e); } }\n function step(r) { r.value instanceof __await ? Promise.resolve(r.value.v).then(fulfill, reject) : settle(q[0][2], r); }\n function fulfill(value) { resume(\"next\", value); }\n function reject(value) { resume(\"throw\", value); }\n function settle(f, v) { if (f(v), q.shift(), q.length) resume(q[0][0], q[0][1]); }\n}\n\nexport function __asyncDelegator(o) {\n var i, p;\n return i = {}, verb(\"next\"), verb(\"throw\", function (e) { throw e; }), verb(\"return\"), i[Symbol.iterator] = function () { return this; }, i;\n function verb(n, f) { i[n] = o[n] ? function (v) { return (p = !p) ? { value: __await(o[n](v)), done: false } : f ? f(v) : v; } : f; }\n}\n\nexport function __asyncValues(o) {\n if (!Symbol.asyncIterator) throw new TypeError(\"Symbol.asyncIterator is not defined.\");\n var m = o[Symbol.asyncIterator], i;\n return m ? m.call(o) : (o = typeof __values === \"function\" ? __values(o) : o[Symbol.iterator](), i = {}, verb(\"next\"), verb(\"throw\"), verb(\"return\"), i[Symbol.asyncIterator] = function () { return this; }, i);\n function verb(n) { i[n] = o[n] && function (v) { return new Promise(function (resolve, reject) { v = o[n](v), settle(resolve, reject, v.done, v.value); }); }; }\n function settle(resolve, reject, d, v) { Promise.resolve(v).then(function(v) { resolve({ value: v, done: d }); }, reject); }\n}\n\nexport function __makeTemplateObject(cooked, raw) {\n if (Object.defineProperty) { Object.defineProperty(cooked, \"raw\", { value: raw }); } else { cooked.raw = raw; }\n return cooked;\n};\n\nvar __setModuleDefault = Object.create ? (function(o, v) {\n Object.defineProperty(o, \"default\", { enumerable: true, value: v });\n}) : function(o, v) {\n o[\"default\"] = v;\n};\n\nexport function __importStar(mod) {\n if (mod && mod.__esModule) return mod;\n var result = {};\n if (mod != null) for (var k in mod) if (k !== \"default\" && Object.prototype.hasOwnProperty.call(mod, k)) __createBinding(result, mod, k);\n __setModuleDefault(result, mod);\n return result;\n}\n\nexport function __importDefault(mod) {\n return (mod && mod.__esModule) ? mod : { default: mod };\n}\n\nexport function __classPrivateFieldGet(receiver, state, kind, f) {\n if (kind === \"a\" && !f) throw new TypeError(\"Private accessor was defined without a getter\");\n if (typeof state === \"function\" ? receiver !== state || !f : !state.has(receiver)) throw new TypeError(\"Cannot read private member from an object whose class did not declare it\");\n return kind === \"m\" ? f : kind === \"a\" ? f.call(receiver) : f ? f.value : state.get(receiver);\n}\n\nexport function __classPrivateFieldSet(receiver, state, value, kind, f) {\n if (kind === \"m\") throw new TypeError(\"Private method is not writable\");\n if (kind === \"a\" && !f) throw new TypeError(\"Private accessor was defined without a setter\");\n if (typeof state === \"function\" ? receiver !== state || !f : !state.has(receiver)) throw new TypeError(\"Cannot write private member to an object whose class did not declare it\");\n return (kind === \"a\" ? f.call(receiver, value) : f ? f.value = value : state.set(receiver, value)), value;\n}\n\nexport function __classPrivateFieldIn(state, receiver) {\n if (receiver === null || (typeof receiver !== \"object\" && typeof receiver !== \"function\")) throw new TypeError(\"Cannot use 'in' operator on non-object\");\n return typeof state === \"function\" ? receiver === state : state.has(receiver);\n}\n\nexport function __addDisposableResource(env, value, async) {\n if (value !== null && value !== void 0) {\n if (typeof value !== \"object\" && typeof value !== \"function\") throw new TypeError(\"Object expected.\");\n var dispose, inner;\n if (async) {\n if (!Symbol.asyncDispose) throw new TypeError(\"Symbol.asyncDispose is not defined.\");\n dispose = value[Symbol.asyncDispose];\n }\n if (dispose === void 0) {\n if (!Symbol.dispose) throw new TypeError(\"Symbol.dispose is not defined.\");\n dispose = value[Symbol.dispose];\n if (async) inner = dispose;\n }\n if (typeof dispose !== \"function\") throw new TypeError(\"Object not disposable.\");\n if (inner) dispose = function() { try { inner.call(this); } catch (e) { return Promise.reject(e); } };\n env.stack.push({ value: value, dispose: dispose, async: async });\n }\n else if (async) {\n env.stack.push({ async: true });\n }\n return value;\n}\n\nvar _SuppressedError = typeof SuppressedError === \"function\" ? SuppressedError : function (error, suppressed, message) {\n var e = new Error(message);\n return e.name = \"SuppressedError\", e.error = error, e.suppressed = suppressed, e;\n};\n\nexport function __disposeResources(env) {\n function fail(e) {\n env.error = env.hasError ? new _SuppressedError(e, env.error, \"An error was suppressed during disposal.\") : e;\n env.hasError = true;\n }\n var r, s = 0;\n function next() {\n while (r = env.stack.pop()) {\n try {\n if (!r.async && s === 1) return s = 0, env.stack.push(r), Promise.resolve().then(next);\n if (r.dispose) {\n var result = r.dispose.call(r.value);\n if (r.async) return s |= 2, Promise.resolve(result).then(next, function(e) { fail(e); return next(); });\n }\n else s |= 1;\n }\n catch (e) {\n fail(e);\n }\n }\n if (s === 1) return env.hasError ? Promise.reject(env.error) : Promise.resolve();\n if (env.hasError) throw env.error;\n }\n return next();\n}\n\nexport default {\n __extends,\n __assign,\n __rest,\n __decorate,\n __param,\n __metadata,\n __awaiter,\n __generator,\n __createBinding,\n __exportStar,\n __values,\n __read,\n __spread,\n __spreadArrays,\n __spreadArray,\n __await,\n __asyncGenerator,\n __asyncDelegator,\n __asyncValues,\n __makeTemplateObject,\n __importStar,\n __importDefault,\n __classPrivateFieldGet,\n __classPrivateFieldSet,\n __classPrivateFieldIn,\n __addDisposableResource,\n __disposeResources,\n};\n", "/**\n * Returns true if the object is a function.\n * @param value The value to check\n */\nexport function isFunction(value: any): value is (...args: any[]) => any {\n return typeof value === 'function';\n}\n", "/**\n * Used to create Error subclasses until the community moves away from ES5.\n *\n * This is because compiling from TypeScript down to ES5 has issues with subclassing Errors\n * as well as other built-in types: https://github.com/Microsoft/TypeScript/issues/12123\n *\n * @param createImpl A factory function to create the actual constructor implementation. The returned\n * function should be a named function that calls `_super` internally.\n */\nexport function createErrorClass(createImpl: (_super: any) => any): T {\n const _super = (instance: any) => {\n Error.call(instance);\n instance.stack = new Error().stack;\n };\n\n const ctorFunc = createImpl(_super);\n ctorFunc.prototype = Object.create(Error.prototype);\n ctorFunc.prototype.constructor = ctorFunc;\n return ctorFunc;\n}\n", "import { createErrorClass } from './createErrorClass';\n\nexport interface UnsubscriptionError extends Error {\n readonly errors: any[];\n}\n\nexport interface UnsubscriptionErrorCtor {\n /**\n * @deprecated Internal implementation detail. Do not construct error instances.\n * Cannot be tagged as internal: https://github.com/ReactiveX/rxjs/issues/6269\n */\n new (errors: any[]): UnsubscriptionError;\n}\n\n/**\n * An error thrown when one or more errors have occurred during the\n * `unsubscribe` of a {@link Subscription}.\n */\nexport const UnsubscriptionError: UnsubscriptionErrorCtor = createErrorClass(\n (_super) =>\n function UnsubscriptionErrorImpl(this: any, errors: (Error | string)[]) {\n _super(this);\n this.message = errors\n ? `${errors.length} errors occurred during unsubscription:\n${errors.map((err, i) => `${i + 1}) ${err.toString()}`).join('\\n ')}`\n : '';\n this.name = 'UnsubscriptionError';\n this.errors = errors;\n }\n);\n", "/**\n * Removes an item from an array, mutating it.\n * @param arr The array to remove the item from\n * @param item The item to remove\n */\nexport function arrRemove(arr: T[] | undefined | null, item: T) {\n if (arr) {\n const index = arr.indexOf(item);\n 0 <= index && arr.splice(index, 1);\n }\n}\n", "import { isFunction } from './util/isFunction';\nimport { UnsubscriptionError } from './util/UnsubscriptionError';\nimport { SubscriptionLike, TeardownLogic, Unsubscribable } from './types';\nimport { arrRemove } from './util/arrRemove';\n\n/**\n * Represents a disposable resource, such as the execution of an Observable. A\n * Subscription has one important method, `unsubscribe`, that takes no argument\n * and just disposes the resource held by the subscription.\n *\n * Additionally, subscriptions may be grouped together through the `add()`\n * method, which will attach a child Subscription to the current Subscription.\n * When a Subscription is unsubscribed, all its children (and its grandchildren)\n * will be unsubscribed as well.\n *\n * @class Subscription\n */\nexport class Subscription implements SubscriptionLike {\n /** @nocollapse */\n public static EMPTY = (() => {\n const empty = new Subscription();\n empty.closed = true;\n return empty;\n })();\n\n /**\n * A flag to indicate whether this Subscription has already been unsubscribed.\n */\n public closed = false;\n\n private _parentage: Subscription[] | Subscription | null = null;\n\n /**\n * The list of registered finalizers to execute upon unsubscription. Adding and removing from this\n * list occurs in the {@link #add} and {@link #remove} methods.\n */\n private _finalizers: Exclude[] | null = null;\n\n /**\n * @param initialTeardown A function executed first as part of the finalization\n * process that is kicked off when {@link #unsubscribe} is called.\n */\n constructor(private initialTeardown?: () => void) {}\n\n /**\n * Disposes the resources held by the subscription. May, for instance, cancel\n * an ongoing Observable execution or cancel any other type of work that\n * started when the Subscription was created.\n * @return {void}\n */\n unsubscribe(): void {\n let errors: any[] | undefined;\n\n if (!this.closed) {\n this.closed = true;\n\n // Remove this from it's parents.\n const { _parentage } = this;\n if (_parentage) {\n this._parentage = null;\n if (Array.isArray(_parentage)) {\n for (const parent of _parentage) {\n parent.remove(this);\n }\n } else {\n _parentage.remove(this);\n }\n }\n\n const { initialTeardown: initialFinalizer } = this;\n if (isFunction(initialFinalizer)) {\n try {\n initialFinalizer();\n } catch (e) {\n errors = e instanceof UnsubscriptionError ? e.errors : [e];\n }\n }\n\n const { _finalizers } = this;\n if (_finalizers) {\n this._finalizers = null;\n for (const finalizer of _finalizers) {\n try {\n execFinalizer(finalizer);\n } catch (err) {\n errors = errors ?? [];\n if (err instanceof UnsubscriptionError) {\n errors = [...errors, ...err.errors];\n } else {\n errors.push(err);\n }\n }\n }\n }\n\n if (errors) {\n throw new UnsubscriptionError(errors);\n }\n }\n }\n\n /**\n * Adds a finalizer to this subscription, so that finalization will be unsubscribed/called\n * when this subscription is unsubscribed. If this subscription is already {@link #closed},\n * because it has already been unsubscribed, then whatever finalizer is passed to it\n * will automatically be executed (unless the finalizer itself is also a closed subscription).\n *\n * Closed Subscriptions cannot be added as finalizers to any subscription. Adding a closed\n * subscription to a any subscription will result in no operation. (A noop).\n *\n * Adding a subscription to itself, or adding `null` or `undefined` will not perform any\n * operation at all. (A noop).\n *\n * `Subscription` instances that are added to this instance will automatically remove themselves\n * if they are unsubscribed. Functions and {@link Unsubscribable} objects that you wish to remove\n * will need to be removed manually with {@link #remove}\n *\n * @param teardown The finalization logic to add to this subscription.\n */\n add(teardown: TeardownLogic): void {\n // Only add the finalizer if it's not undefined\n // and don't add a subscription to itself.\n if (teardown && teardown !== this) {\n if (this.closed) {\n // If this subscription is already closed,\n // execute whatever finalizer is handed to it automatically.\n execFinalizer(teardown);\n } else {\n if (teardown instanceof Subscription) {\n // We don't add closed subscriptions, and we don't add the same subscription\n // twice. Subscription unsubscribe is idempotent.\n if (teardown.closed || teardown._hasParent(this)) {\n return;\n }\n teardown._addParent(this);\n }\n (this._finalizers = this._finalizers ?? []).push(teardown);\n }\n }\n }\n\n /**\n * Checks to see if a this subscription already has a particular parent.\n * This will signal that this subscription has already been added to the parent in question.\n * @param parent the parent to check for\n */\n private _hasParent(parent: Subscription) {\n const { _parentage } = this;\n return _parentage === parent || (Array.isArray(_parentage) && _parentage.includes(parent));\n }\n\n /**\n * Adds a parent to this subscription so it can be removed from the parent if it\n * unsubscribes on it's own.\n *\n * NOTE: THIS ASSUMES THAT {@link _hasParent} HAS ALREADY BEEN CHECKED.\n * @param parent The parent subscription to add\n */\n private _addParent(parent: Subscription) {\n const { _parentage } = this;\n this._parentage = Array.isArray(_parentage) ? (_parentage.push(parent), _parentage) : _parentage ? [_parentage, parent] : parent;\n }\n\n /**\n * Called on a child when it is removed via {@link #remove}.\n * @param parent The parent to remove\n */\n private _removeParent(parent: Subscription) {\n const { _parentage } = this;\n if (_parentage === parent) {\n this._parentage = null;\n } else if (Array.isArray(_parentage)) {\n arrRemove(_parentage, parent);\n }\n }\n\n /**\n * Removes a finalizer from this subscription that was previously added with the {@link #add} method.\n *\n * Note that `Subscription` instances, when unsubscribed, will automatically remove themselves\n * from every other `Subscription` they have been added to. This means that using the `remove` method\n * is not a common thing and should be used thoughtfully.\n *\n * If you add the same finalizer instance of a function or an unsubscribable object to a `Subscription` instance\n * more than once, you will need to call `remove` the same number of times to remove all instances.\n *\n * All finalizer instances are removed to free up memory upon unsubscription.\n *\n * @param teardown The finalizer to remove from this subscription\n */\n remove(teardown: Exclude): void {\n const { _finalizers } = this;\n _finalizers && arrRemove(_finalizers, teardown);\n\n if (teardown instanceof Subscription) {\n teardown._removeParent(this);\n }\n }\n}\n\nexport const EMPTY_SUBSCRIPTION = Subscription.EMPTY;\n\nexport function isSubscription(value: any): value is Subscription {\n return (\n value instanceof Subscription ||\n (value && 'closed' in value && isFunction(value.remove) && isFunction(value.add) && isFunction(value.unsubscribe))\n );\n}\n\nfunction execFinalizer(finalizer: Unsubscribable | (() => void)) {\n if (isFunction(finalizer)) {\n finalizer();\n } else {\n finalizer.unsubscribe();\n }\n}\n", "import { Subscriber } from './Subscriber';\nimport { ObservableNotification } from './types';\n\n/**\n * The {@link GlobalConfig} object for RxJS. It is used to configure things\n * like how to react on unhandled errors.\n */\nexport const config: GlobalConfig = {\n onUnhandledError: null,\n onStoppedNotification: null,\n Promise: undefined,\n useDeprecatedSynchronousErrorHandling: false,\n useDeprecatedNextContext: false,\n};\n\n/**\n * The global configuration object for RxJS, used to configure things\n * like how to react on unhandled errors. Accessible via {@link config}\n * object.\n */\nexport interface GlobalConfig {\n /**\n * A registration point for unhandled errors from RxJS. These are errors that\n * cannot were not handled by consuming code in the usual subscription path. For\n * example, if you have this configured, and you subscribe to an observable without\n * providing an error handler, errors from that subscription will end up here. This\n * will _always_ be called asynchronously on another job in the runtime. This is because\n * we do not want errors thrown in this user-configured handler to interfere with the\n * behavior of the library.\n */\n onUnhandledError: ((err: any) => void) | null;\n\n /**\n * A registration point for notifications that cannot be sent to subscribers because they\n * have completed, errored or have been explicitly unsubscribed. By default, next, complete\n * and error notifications sent to stopped subscribers are noops. However, sometimes callers\n * might want a different behavior. For example, with sources that attempt to report errors\n * to stopped subscribers, a caller can configure RxJS to throw an unhandled error instead.\n * This will _always_ be called asynchronously on another job in the runtime. This is because\n * we do not want errors thrown in this user-configured handler to interfere with the\n * behavior of the library.\n */\n onStoppedNotification: ((notification: ObservableNotification, subscriber: Subscriber) => void) | null;\n\n /**\n * The promise constructor used by default for {@link Observable#toPromise toPromise} and {@link Observable#forEach forEach}\n * methods.\n *\n * @deprecated As of version 8, RxJS will no longer support this sort of injection of a\n * Promise constructor. If you need a Promise implementation other than native promises,\n * please polyfill/patch Promise as you see appropriate. Will be removed in v8.\n */\n Promise?: PromiseConstructorLike;\n\n /**\n * If true, turns on synchronous error rethrowing, which is a deprecated behavior\n * in v6 and higher. This behavior enables bad patterns like wrapping a subscribe\n * call in a try/catch block. It also enables producer interference, a nasty bug\n * where a multicast can be broken for all observers by a downstream consumer with\n * an unhandled error. DO NOT USE THIS FLAG UNLESS IT'S NEEDED TO BUY TIME\n * FOR MIGRATION REASONS.\n *\n * @deprecated As of version 8, RxJS will no longer support synchronous throwing\n * of unhandled errors. All errors will be thrown on a separate call stack to prevent bad\n * behaviors described above. Will be removed in v8.\n */\n useDeprecatedSynchronousErrorHandling: boolean;\n\n /**\n * If true, enables an as-of-yet undocumented feature from v5: The ability to access\n * `unsubscribe()` via `this` context in `next` functions created in observers passed\n * to `subscribe`.\n *\n * This is being removed because the performance was severely problematic, and it could also cause\n * issues when types other than POJOs are passed to subscribe as subscribers, as they will likely have\n * their `this` context overwritten.\n *\n * @deprecated As of version 8, RxJS will no longer support altering the\n * context of next functions provided as part of an observer to Subscribe. Instead,\n * you will have access to a subscription or a signal or token that will allow you to do things like\n * unsubscribe and test closed status. Will be removed in v8.\n */\n useDeprecatedNextContext: boolean;\n}\n", "import type { TimerHandle } from './timerHandle';\ntype SetTimeoutFunction = (handler: () => void, timeout?: number, ...args: any[]) => TimerHandle;\ntype ClearTimeoutFunction = (handle: TimerHandle) => void;\n\ninterface TimeoutProvider {\n setTimeout: SetTimeoutFunction;\n clearTimeout: ClearTimeoutFunction;\n delegate:\n | {\n setTimeout: SetTimeoutFunction;\n clearTimeout: ClearTimeoutFunction;\n }\n | undefined;\n}\n\nexport const timeoutProvider: TimeoutProvider = {\n // When accessing the delegate, use the variable rather than `this` so that\n // the functions can be called without being bound to the provider.\n setTimeout(handler: () => void, timeout?: number, ...args) {\n const { delegate } = timeoutProvider;\n if (delegate?.setTimeout) {\n return delegate.setTimeout(handler, timeout, ...args);\n }\n return setTimeout(handler, timeout, ...args);\n },\n clearTimeout(handle) {\n const { delegate } = timeoutProvider;\n return (delegate?.clearTimeout || clearTimeout)(handle as any);\n },\n delegate: undefined,\n};\n", "import { config } from '../config';\nimport { timeoutProvider } from '../scheduler/timeoutProvider';\n\n/**\n * Handles an error on another job either with the user-configured {@link onUnhandledError},\n * or by throwing it on that new job so it can be picked up by `window.onerror`, `process.on('error')`, etc.\n *\n * This should be called whenever there is an error that is out-of-band with the subscription\n * or when an error hits a terminal boundary of the subscription and no error handler was provided.\n *\n * @param err the error to report\n */\nexport function reportUnhandledError(err: any) {\n timeoutProvider.setTimeout(() => {\n const { onUnhandledError } = config;\n if (onUnhandledError) {\n // Execute the user-configured error handler.\n onUnhandledError(err);\n } else {\n // Throw so it is picked up by the runtime's uncaught error mechanism.\n throw err;\n }\n });\n}\n", "/* tslint:disable:no-empty */\nexport function noop() { }\n", "import { CompleteNotification, NextNotification, ErrorNotification } from './types';\n\n/**\n * A completion object optimized for memory use and created to be the\n * same \"shape\" as other notifications in v8.\n * @internal\n */\nexport const COMPLETE_NOTIFICATION = (() => createNotification('C', undefined, undefined) as CompleteNotification)();\n\n/**\n * Internal use only. Creates an optimized error notification that is the same \"shape\"\n * as other notifications.\n * @internal\n */\nexport function errorNotification(error: any): ErrorNotification {\n return createNotification('E', undefined, error) as any;\n}\n\n/**\n * Internal use only. Creates an optimized next notification that is the same \"shape\"\n * as other notifications.\n * @internal\n */\nexport function nextNotification(value: T) {\n return createNotification('N', value, undefined) as NextNotification;\n}\n\n/**\n * Ensures that all notifications created internally have the same \"shape\" in v8.\n *\n * TODO: This is only exported to support a crazy legacy test in `groupBy`.\n * @internal\n */\nexport function createNotification(kind: 'N' | 'E' | 'C', value: any, error: any) {\n return {\n kind,\n value,\n error,\n };\n}\n", "import { config } from '../config';\n\nlet context: { errorThrown: boolean; error: any } | null = null;\n\n/**\n * Handles dealing with errors for super-gross mode. Creates a context, in which\n * any synchronously thrown errors will be passed to {@link captureError}. Which\n * will record the error such that it will be rethrown after the call back is complete.\n * TODO: Remove in v8\n * @param cb An immediately executed function.\n */\nexport function errorContext(cb: () => void) {\n if (config.useDeprecatedSynchronousErrorHandling) {\n const isRoot = !context;\n if (isRoot) {\n context = { errorThrown: false, error: null };\n }\n cb();\n if (isRoot) {\n const { errorThrown, error } = context!;\n context = null;\n if (errorThrown) {\n throw error;\n }\n }\n } else {\n // This is the general non-deprecated path for everyone that\n // isn't crazy enough to use super-gross mode (useDeprecatedSynchronousErrorHandling)\n cb();\n }\n}\n\n/**\n * Captures errors only in super-gross mode.\n * @param err the error to capture\n */\nexport function captureError(err: any) {\n if (config.useDeprecatedSynchronousErrorHandling && context) {\n context.errorThrown = true;\n context.error = err;\n }\n}\n", "import { isFunction } from './util/isFunction';\nimport { Observer, ObservableNotification } from './types';\nimport { isSubscription, Subscription } from './Subscription';\nimport { config } from './config';\nimport { reportUnhandledError } from './util/reportUnhandledError';\nimport { noop } from './util/noop';\nimport { nextNotification, errorNotification, COMPLETE_NOTIFICATION } from './NotificationFactories';\nimport { timeoutProvider } from './scheduler/timeoutProvider';\nimport { captureError } from './util/errorContext';\n\n/**\n * Implements the {@link Observer} interface and extends the\n * {@link Subscription} class. While the {@link Observer} is the public API for\n * consuming the values of an {@link Observable}, all Observers get converted to\n * a Subscriber, in order to provide Subscription-like capabilities such as\n * `unsubscribe`. Subscriber is a common type in RxJS, and crucial for\n * implementing operators, but it is rarely used as a public API.\n *\n * @class Subscriber\n */\nexport class Subscriber extends Subscription implements Observer {\n /**\n * A static factory for a Subscriber, given a (potentially partial) definition\n * of an Observer.\n * @param next The `next` callback of an Observer.\n * @param error The `error` callback of an\n * Observer.\n * @param complete The `complete` callback of an\n * Observer.\n * @return A Subscriber wrapping the (partially defined)\n * Observer represented by the given arguments.\n * @nocollapse\n * @deprecated Do not use. Will be removed in v8. There is no replacement for this\n * method, and there is no reason to be creating instances of `Subscriber` directly.\n * If you have a specific use case, please file an issue.\n */\n static create(next?: (x?: T) => void, error?: (e?: any) => void, complete?: () => void): Subscriber {\n return new SafeSubscriber(next, error, complete);\n }\n\n /** @deprecated Internal implementation detail, do not use directly. Will be made internal in v8. */\n protected isStopped: boolean = false;\n /** @deprecated Internal implementation detail, do not use directly. Will be made internal in v8. */\n protected destination: Subscriber | Observer; // this `any` is the escape hatch to erase extra type param (e.g. R)\n\n /**\n * @deprecated Internal implementation detail, do not use directly. Will be made internal in v8.\n * There is no reason to directly create an instance of Subscriber. This type is exported for typings reasons.\n */\n constructor(destination?: Subscriber | Observer) {\n super();\n if (destination) {\n this.destination = destination;\n // Automatically chain subscriptions together here.\n // if destination is a Subscription, then it is a Subscriber.\n if (isSubscription(destination)) {\n destination.add(this);\n }\n } else {\n this.destination = EMPTY_OBSERVER;\n }\n }\n\n /**\n * The {@link Observer} callback to receive notifications of type `next` from\n * the Observable, with a value. The Observable may call this method 0 or more\n * times.\n * @param {T} [value] The `next` value.\n * @return {void}\n */\n next(value?: T): void {\n if (this.isStopped) {\n handleStoppedNotification(nextNotification(value), this);\n } else {\n this._next(value!);\n }\n }\n\n /**\n * The {@link Observer} callback to receive notifications of type `error` from\n * the Observable, with an attached `Error`. Notifies the Observer that\n * the Observable has experienced an error condition.\n * @param {any} [err] The `error` exception.\n * @return {void}\n */\n error(err?: any): void {\n if (this.isStopped) {\n handleStoppedNotification(errorNotification(err), this);\n } else {\n this.isStopped = true;\n this._error(err);\n }\n }\n\n /**\n * The {@link Observer} callback to receive a valueless notification of type\n * `complete` from the Observable. Notifies the Observer that the Observable\n * has finished sending push-based notifications.\n * @return {void}\n */\n complete(): void {\n if (this.isStopped) {\n handleStoppedNotification(COMPLETE_NOTIFICATION, this);\n } else {\n this.isStopped = true;\n this._complete();\n }\n }\n\n unsubscribe(): void {\n if (!this.closed) {\n this.isStopped = true;\n super.unsubscribe();\n this.destination = null!;\n }\n }\n\n protected _next(value: T): void {\n this.destination.next(value);\n }\n\n protected _error(err: any): void {\n try {\n this.destination.error(err);\n } finally {\n this.unsubscribe();\n }\n }\n\n protected _complete(): void {\n try {\n this.destination.complete();\n } finally {\n this.unsubscribe();\n }\n }\n}\n\n/**\n * This bind is captured here because we want to be able to have\n * compatibility with monoid libraries that tend to use a method named\n * `bind`. In particular, a library called Monio requires this.\n */\nconst _bind = Function.prototype.bind;\n\nfunction bind any>(fn: Fn, thisArg: any): Fn {\n return _bind.call(fn, thisArg);\n}\n\n/**\n * Internal optimization only, DO NOT EXPOSE.\n * @internal\n */\nclass ConsumerObserver implements Observer {\n constructor(private partialObserver: Partial>) {}\n\n next(value: T): void {\n const { partialObserver } = this;\n if (partialObserver.next) {\n try {\n partialObserver.next(value);\n } catch (error) {\n handleUnhandledError(error);\n }\n }\n }\n\n error(err: any): void {\n const { partialObserver } = this;\n if (partialObserver.error) {\n try {\n partialObserver.error(err);\n } catch (error) {\n handleUnhandledError(error);\n }\n } else {\n handleUnhandledError(err);\n }\n }\n\n complete(): void {\n const { partialObserver } = this;\n if (partialObserver.complete) {\n try {\n partialObserver.complete();\n } catch (error) {\n handleUnhandledError(error);\n }\n }\n }\n}\n\nexport class SafeSubscriber extends Subscriber {\n constructor(\n observerOrNext?: Partial> | ((value: T) => void) | null,\n error?: ((e?: any) => void) | null,\n complete?: (() => void) | null\n ) {\n super();\n\n let partialObserver: Partial>;\n if (isFunction(observerOrNext) || !observerOrNext) {\n // The first argument is a function, not an observer. The next\n // two arguments *could* be observers, or they could be empty.\n partialObserver = {\n next: (observerOrNext ?? undefined) as (((value: T) => void) | undefined),\n error: error ?? undefined,\n complete: complete ?? undefined,\n };\n } else {\n // The first argument is a partial observer.\n let context: any;\n if (this && config.useDeprecatedNextContext) {\n // This is a deprecated path that made `this.unsubscribe()` available in\n // next handler functions passed to subscribe. This only exists behind a flag\n // now, as it is *very* slow.\n context = Object.create(observerOrNext);\n context.unsubscribe = () => this.unsubscribe();\n partialObserver = {\n next: observerOrNext.next && bind(observerOrNext.next, context),\n error: observerOrNext.error && bind(observerOrNext.error, context),\n complete: observerOrNext.complete && bind(observerOrNext.complete, context),\n };\n } else {\n // The \"normal\" path. Just use the partial observer directly.\n partialObserver = observerOrNext;\n }\n }\n\n // Wrap the partial observer to ensure it's a full observer, and\n // make sure proper error handling is accounted for.\n this.destination = new ConsumerObserver(partialObserver);\n }\n}\n\nfunction handleUnhandledError(error: any) {\n if (config.useDeprecatedSynchronousErrorHandling) {\n captureError(error);\n } else {\n // Ideal path, we report this as an unhandled error,\n // which is thrown on a new call stack.\n reportUnhandledError(error);\n }\n}\n\n/**\n * An error handler used when no error handler was supplied\n * to the SafeSubscriber -- meaning no error handler was supplied\n * do the `subscribe` call on our observable.\n * @param err The error to handle\n */\nfunction defaultErrorHandler(err: any) {\n throw err;\n}\n\n/**\n * A handler for notifications that cannot be sent to a stopped subscriber.\n * @param notification The notification being sent\n * @param subscriber The stopped subscriber\n */\nfunction handleStoppedNotification(notification: ObservableNotification, subscriber: Subscriber) {\n const { onStoppedNotification } = config;\n onStoppedNotification && timeoutProvider.setTimeout(() => onStoppedNotification(notification, subscriber));\n}\n\n/**\n * The observer used as a stub for subscriptions where the user did not\n * pass any arguments to `subscribe`. Comes with the default error handling\n * behavior.\n */\nexport const EMPTY_OBSERVER: Readonly> & { closed: true } = {\n closed: true,\n next: noop,\n error: defaultErrorHandler,\n complete: noop,\n};\n", "/**\n * Symbol.observable or a string \"@@observable\". Used for interop\n *\n * @deprecated We will no longer be exporting this symbol in upcoming versions of RxJS.\n * Instead polyfill and use Symbol.observable directly *or* use https://www.npmjs.com/package/symbol-observable\n */\nexport const observable: string | symbol = (() => (typeof Symbol === 'function' && Symbol.observable) || '@@observable')();\n", "/**\n * This function takes one parameter and just returns it. Simply put,\n * this is like `(x: T): T => x`.\n *\n * ## Examples\n *\n * This is useful in some cases when using things like `mergeMap`\n *\n * ```ts\n * import { interval, take, map, range, mergeMap, identity } from 'rxjs';\n *\n * const source$ = interval(1000).pipe(take(5));\n *\n * const result$ = source$.pipe(\n * map(i => range(i)),\n * mergeMap(identity) // same as mergeMap(x => x)\n * );\n *\n * result$.subscribe({\n * next: console.log\n * });\n * ```\n *\n * Or when you want to selectively apply an operator\n *\n * ```ts\n * import { interval, take, identity } from 'rxjs';\n *\n * const shouldLimit = () => Math.random() < 0.5;\n *\n * const source$ = interval(1000);\n *\n * const result$ = source$.pipe(shouldLimit() ? take(5) : identity);\n *\n * result$.subscribe({\n * next: console.log\n * });\n * ```\n *\n * @param x Any value that is returned by this function\n * @returns The value passed as the first parameter to this function\n */\nexport function identity(x: T): T {\n return x;\n}\n", "import { identity } from './identity';\nimport { UnaryFunction } from '../types';\n\nexport function pipe(): typeof identity;\nexport function pipe(fn1: UnaryFunction): UnaryFunction;\nexport function pipe(fn1: UnaryFunction, fn2: UnaryFunction): UnaryFunction;\nexport function pipe(fn1: UnaryFunction, fn2: UnaryFunction, fn3: UnaryFunction): UnaryFunction;\nexport function pipe(\n fn1: UnaryFunction,\n fn2: UnaryFunction,\n fn3: UnaryFunction,\n fn4: UnaryFunction\n): UnaryFunction;\nexport function pipe(\n fn1: UnaryFunction,\n fn2: UnaryFunction,\n fn3: UnaryFunction,\n fn4: UnaryFunction,\n fn5: UnaryFunction\n): UnaryFunction;\nexport function pipe(\n fn1: UnaryFunction,\n fn2: UnaryFunction,\n fn3: UnaryFunction,\n fn4: UnaryFunction,\n fn5: UnaryFunction,\n fn6: UnaryFunction\n): UnaryFunction;\nexport function pipe(\n fn1: UnaryFunction,\n fn2: UnaryFunction,\n fn3: UnaryFunction,\n fn4: UnaryFunction,\n fn5: UnaryFunction,\n fn6: UnaryFunction,\n fn7: UnaryFunction\n): UnaryFunction;\nexport function pipe(\n fn1: UnaryFunction,\n fn2: UnaryFunction,\n fn3: UnaryFunction,\n fn4: UnaryFunction,\n fn5: UnaryFunction,\n fn6: UnaryFunction,\n fn7: UnaryFunction,\n fn8: UnaryFunction\n): UnaryFunction;\nexport function pipe(\n fn1: UnaryFunction,\n fn2: UnaryFunction,\n fn3: UnaryFunction,\n fn4: UnaryFunction,\n fn5: UnaryFunction,\n fn6: UnaryFunction,\n fn7: UnaryFunction,\n fn8: UnaryFunction,\n fn9: UnaryFunction\n): UnaryFunction;\nexport function pipe(\n fn1: UnaryFunction,\n fn2: UnaryFunction,\n fn3: UnaryFunction,\n fn4: UnaryFunction,\n fn5: UnaryFunction,\n fn6: UnaryFunction,\n fn7: UnaryFunction,\n fn8: UnaryFunction,\n fn9: UnaryFunction,\n ...fns: UnaryFunction[]\n): UnaryFunction;\n\n/**\n * pipe() can be called on one or more functions, each of which can take one argument (\"UnaryFunction\")\n * and uses it to return a value.\n * It returns a function that takes one argument, passes it to the first UnaryFunction, and then\n * passes the result to the next one, passes that result to the next one, and so on. \n */\nexport function pipe(...fns: Array>): UnaryFunction {\n return pipeFromArray(fns);\n}\n\n/** @internal */\nexport function pipeFromArray(fns: Array>): UnaryFunction {\n if (fns.length === 0) {\n return identity as UnaryFunction;\n }\n\n if (fns.length === 1) {\n return fns[0];\n }\n\n return function piped(input: T): R {\n return fns.reduce((prev: any, fn: UnaryFunction) => fn(prev), input as any);\n };\n}\n", "import { Operator } from './Operator';\nimport { SafeSubscriber, Subscriber } from './Subscriber';\nimport { isSubscription, Subscription } from './Subscription';\nimport { TeardownLogic, OperatorFunction, Subscribable, Observer } from './types';\nimport { observable as Symbol_observable } from './symbol/observable';\nimport { pipeFromArray } from './util/pipe';\nimport { config } from './config';\nimport { isFunction } from './util/isFunction';\nimport { errorContext } from './util/errorContext';\n\n/**\n * A representation of any set of values over any amount of time. This is the most basic building block\n * of RxJS.\n *\n * @class Observable\n */\nexport class Observable implements Subscribable {\n /**\n * @deprecated Internal implementation detail, do not use directly. Will be made internal in v8.\n */\n source: Observable | undefined;\n\n /**\n * @deprecated Internal implementation detail, do not use directly. Will be made internal in v8.\n */\n operator: Operator | undefined;\n\n /**\n * @constructor\n * @param {Function} subscribe the function that is called when the Observable is\n * initially subscribed to. This function is given a Subscriber, to which new values\n * can be `next`ed, or an `error` method can be called to raise an error, or\n * `complete` can be called to notify of a successful completion.\n */\n constructor(subscribe?: (this: Observable, subscriber: Subscriber) => TeardownLogic) {\n if (subscribe) {\n this._subscribe = subscribe;\n }\n }\n\n // HACK: Since TypeScript inherits static properties too, we have to\n // fight against TypeScript here so Subject can have a different static create signature\n /**\n * Creates a new Observable by calling the Observable constructor\n * @owner Observable\n * @method create\n * @param {Function} subscribe? the subscriber function to be passed to the Observable constructor\n * @return {Observable} a new observable\n * @nocollapse\n * @deprecated Use `new Observable()` instead. Will be removed in v8.\n */\n static create: (...args: any[]) => any = (subscribe?: (subscriber: Subscriber) => TeardownLogic) => {\n return new Observable(subscribe);\n };\n\n /**\n * Creates a new Observable, with this Observable instance as the source, and the passed\n * operator defined as the new observable's operator.\n * @method lift\n * @param operator the operator defining the operation to take on the observable\n * @return a new observable with the Operator applied\n * @deprecated Internal implementation detail, do not use directly. Will be made internal in v8.\n * If you have implemented an operator using `lift`, it is recommended that you create an\n * operator by simply returning `new Observable()` directly. See \"Creating new operators from\n * scratch\" section here: https://rxjs.dev/guide/operators\n */\n lift(operator?: Operator): Observable {\n const observable = new Observable();\n observable.source = this;\n observable.operator = operator;\n return observable;\n }\n\n subscribe(observerOrNext?: Partial> | ((value: T) => void)): Subscription;\n /** @deprecated Instead of passing separate callback arguments, use an observer argument. Signatures taking separate callback arguments will be removed in v8. Details: https://rxjs.dev/deprecations/subscribe-arguments */\n subscribe(next?: ((value: T) => void) | null, error?: ((error: any) => void) | null, complete?: (() => void) | null): Subscription;\n /**\n * Invokes an execution of an Observable and registers Observer handlers for notifications it will emit.\n *\n * Use it when you have all these Observables, but still nothing is happening. \n *\n * `subscribe` is not a regular operator, but a method that calls Observable's internal `subscribe` function. It\n * might be for example a function that you passed to Observable's constructor, but most of the time it is\n * a library implementation, which defines what will be emitted by an Observable, and when it be will emitted. This means\n * that calling `subscribe` is actually the moment when Observable starts its work, not when it is created, as it is often\n * the thought.\n *\n * Apart from starting the execution of an Observable, this method allows you to listen for values\n * that an Observable emits, as well as for when it completes or errors. You can achieve this in two\n * of the following ways.\n *\n * The first way is creating an object that implements {@link Observer} interface. It should have methods\n * defined by that interface, but note that it should be just a regular JavaScript object, which you can create\n * yourself in any way you want (ES6 class, classic function constructor, object literal etc.). In particular, do\n * not attempt to use any RxJS implementation details to create Observers - you don't need them. Remember also\n * that your object does not have to implement all methods. If you find yourself creating a method that doesn't\n * do anything, you can simply omit it. Note however, if the `error` method is not provided and an error happens,\n * it will be thrown asynchronously. Errors thrown asynchronously cannot be caught using `try`/`catch`. Instead,\n * use the {@link onUnhandledError} configuration option or use a runtime handler (like `window.onerror` or\n * `process.on('error)`) to be notified of unhandled errors. Because of this, it's recommended that you provide\n * an `error` method to avoid missing thrown errors.\n *\n * The second way is to give up on Observer object altogether and simply provide callback functions in place of its methods.\n * This means you can provide three functions as arguments to `subscribe`, where the first function is equivalent\n * of a `next` method, the second of an `error` method and the third of a `complete` method. Just as in case of an Observer,\n * if you do not need to listen for something, you can omit a function by passing `undefined` or `null`,\n * since `subscribe` recognizes these functions by where they were placed in function call. When it comes\n * to the `error` function, as with an Observer, if not provided, errors emitted by an Observable will be thrown asynchronously.\n *\n * You can, however, subscribe with no parameters at all. This may be the case where you're not interested in terminal events\n * and you also handled emissions internally by using operators (e.g. using `tap`).\n *\n * Whichever style of calling `subscribe` you use, in both cases it returns a Subscription object.\n * This object allows you to call `unsubscribe` on it, which in turn will stop the work that an Observable does and will clean\n * up all resources that an Observable used. Note that cancelling a subscription will not call `complete` callback\n * provided to `subscribe` function, which is reserved for a regular completion signal that comes from an Observable.\n *\n * Remember that callbacks provided to `subscribe` are not guaranteed to be called asynchronously.\n * It is an Observable itself that decides when these functions will be called. For example {@link of}\n * by default emits all its values synchronously. Always check documentation for how given Observable\n * will behave when subscribed and if its default behavior can be modified with a `scheduler`.\n *\n * #### Examples\n *\n * Subscribe with an {@link guide/observer Observer}\n *\n * ```ts\n * import { of } from 'rxjs';\n *\n * const sumObserver = {\n * sum: 0,\n * next(value) {\n * console.log('Adding: ' + value);\n * this.sum = this.sum + value;\n * },\n * error() {\n * // We actually could just remove this method,\n * // since we do not really care about errors right now.\n * },\n * complete() {\n * console.log('Sum equals: ' + this.sum);\n * }\n * };\n *\n * of(1, 2, 3) // Synchronously emits 1, 2, 3 and then completes.\n * .subscribe(sumObserver);\n *\n * // Logs:\n * // 'Adding: 1'\n * // 'Adding: 2'\n * // 'Adding: 3'\n * // 'Sum equals: 6'\n * ```\n *\n * Subscribe with functions ({@link deprecations/subscribe-arguments deprecated})\n *\n * ```ts\n * import { of } from 'rxjs'\n *\n * let sum = 0;\n *\n * of(1, 2, 3).subscribe(\n * value => {\n * console.log('Adding: ' + value);\n * sum = sum + value;\n * },\n * undefined,\n * () => console.log('Sum equals: ' + sum)\n * );\n *\n * // Logs:\n * // 'Adding: 1'\n * // 'Adding: 2'\n * // 'Adding: 3'\n * // 'Sum equals: 6'\n * ```\n *\n * Cancel a subscription\n *\n * ```ts\n * import { interval } from 'rxjs';\n *\n * const subscription = interval(1000).subscribe({\n * next(num) {\n * console.log(num)\n * },\n * complete() {\n * // Will not be called, even when cancelling subscription.\n * console.log('completed!');\n * }\n * });\n *\n * setTimeout(() => {\n * subscription.unsubscribe();\n * console.log('unsubscribed!');\n * }, 2500);\n *\n * // Logs:\n * // 0 after 1s\n * // 1 after 2s\n * // 'unsubscribed!' after 2.5s\n * ```\n *\n * @param {Observer|Function} observerOrNext (optional) Either an observer with methods to be called,\n * or the first of three possible handlers, which is the handler for each value emitted from the subscribed\n * Observable.\n * @param {Function} error (optional) A handler for a terminal event resulting from an error. If no error handler is provided,\n * the error will be thrown asynchronously as unhandled.\n * @param {Function} complete (optional) A handler for a terminal event resulting from successful completion.\n * @return {Subscription} a subscription reference to the registered handlers\n * @method subscribe\n */\n subscribe(\n observerOrNext?: Partial> | ((value: T) => void) | null,\n error?: ((error: any) => void) | null,\n complete?: (() => void) | null\n ): Subscription {\n const subscriber = isSubscriber(observerOrNext) ? observerOrNext : new SafeSubscriber(observerOrNext, error, complete);\n\n errorContext(() => {\n const { operator, source } = this;\n subscriber.add(\n operator\n ? // We're dealing with a subscription in the\n // operator chain to one of our lifted operators.\n operator.call(subscriber, source)\n : source\n ? // If `source` has a value, but `operator` does not, something that\n // had intimate knowledge of our API, like our `Subject`, must have\n // set it. We're going to just call `_subscribe` directly.\n this._subscribe(subscriber)\n : // In all other cases, we're likely wrapping a user-provided initializer\n // function, so we need to catch errors and handle them appropriately.\n this._trySubscribe(subscriber)\n );\n });\n\n return subscriber;\n }\n\n /** @internal */\n protected _trySubscribe(sink: Subscriber): TeardownLogic {\n try {\n return this._subscribe(sink);\n } catch (err) {\n // We don't need to return anything in this case,\n // because it's just going to try to `add()` to a subscription\n // above.\n sink.error(err);\n }\n }\n\n /**\n * Used as a NON-CANCELLABLE means of subscribing to an observable, for use with\n * APIs that expect promises, like `async/await`. You cannot unsubscribe from this.\n *\n * **WARNING**: Only use this with observables you *know* will complete. If the source\n * observable does not complete, you will end up with a promise that is hung up, and\n * potentially all of the state of an async function hanging out in memory. To avoid\n * this situation, look into adding something like {@link timeout}, {@link take},\n * {@link takeWhile}, or {@link takeUntil} amongst others.\n *\n * #### Example\n *\n * ```ts\n * import { interval, take } from 'rxjs';\n *\n * const source$ = interval(1000).pipe(take(4));\n *\n * async function getTotal() {\n * let total = 0;\n *\n * await source$.forEach(value => {\n * total += value;\n * console.log('observable -> ' + value);\n * });\n *\n * return total;\n * }\n *\n * getTotal().then(\n * total => console.log('Total: ' + total)\n * );\n *\n * // Expected:\n * // 'observable -> 0'\n * // 'observable -> 1'\n * // 'observable -> 2'\n * // 'observable -> 3'\n * // 'Total: 6'\n * ```\n *\n * @param next a handler for each value emitted by the observable\n * @return a promise that either resolves on observable completion or\n * rejects with the handled error\n */\n forEach(next: (value: T) => void): Promise;\n\n /**\n * @param next a handler for each value emitted by the observable\n * @param promiseCtor a constructor function used to instantiate the Promise\n * @return a promise that either resolves on observable completion or\n * rejects with the handled error\n * @deprecated Passing a Promise constructor will no longer be available\n * in upcoming versions of RxJS. This is because it adds weight to the library, for very\n * little benefit. If you need this functionality, it is recommended that you either\n * polyfill Promise, or you create an adapter to convert the returned native promise\n * to whatever promise implementation you wanted. Will be removed in v8.\n */\n forEach(next: (value: T) => void, promiseCtor: PromiseConstructorLike): Promise;\n\n forEach(next: (value: T) => void, promiseCtor?: PromiseConstructorLike): Promise {\n promiseCtor = getPromiseCtor(promiseCtor);\n\n return new promiseCtor((resolve, reject) => {\n const subscriber = new SafeSubscriber({\n next: (value) => {\n try {\n next(value);\n } catch (err) {\n reject(err);\n subscriber.unsubscribe();\n }\n },\n error: reject,\n complete: resolve,\n });\n this.subscribe(subscriber);\n }) as Promise;\n }\n\n /** @internal */\n protected _subscribe(subscriber: Subscriber): TeardownLogic {\n return this.source?.subscribe(subscriber);\n }\n\n /**\n * An interop point defined by the es7-observable spec https://github.com/zenparsing/es-observable\n * @method Symbol.observable\n * @return {Observable} this instance of the observable\n */\n [Symbol_observable]() {\n return this;\n }\n\n /* tslint:disable:max-line-length */\n pipe(): Observable;\n pipe(op1: OperatorFunction): Observable;\n pipe (op1: OperatorFunction, op2: OperatorFunction): Observable;\n pipe(op1: OperatorFunction, op2: OperatorFunction, op3: OperatorFunction): Observable;\n pipe(\n op1: OperatorFunction,\n op2: OperatorFunction,\n op3: OperatorFunction,\n op4: OperatorFunction\n ): Observable;\n pipe(\n op1: OperatorFunction,\n op2: OperatorFunction,\n op3: OperatorFunction,\n op4: OperatorFunction,\n op5: OperatorFunction\n ): Observable;\n pipe(\n op1: OperatorFunction,\n op2: OperatorFunction,\n op3: OperatorFunction,\n op4: OperatorFunction,\n op5: OperatorFunction,\n op6: OperatorFunction\n ): Observable;\n pipe(\n op1: OperatorFunction,\n op2: OperatorFunction,\n op3: OperatorFunction,\n op4: OperatorFunction,\n op5: OperatorFunction,\n op6: OperatorFunction,\n op7: OperatorFunction\n ): Observable;\n pipe(\n op1: OperatorFunction,\n op2: OperatorFunction,\n op3: OperatorFunction,\n op4: OperatorFunction,\n op5: OperatorFunction,\n op6: OperatorFunction,\n op7: OperatorFunction,\n op8: OperatorFunction\n ): Observable;\n pipe(\n op1: OperatorFunction,\n op2: OperatorFunction,\n op3: OperatorFunction,\n op4: OperatorFunction,\n op5: OperatorFunction,\n op6: OperatorFunction,\n op7: OperatorFunction,\n op8: OperatorFunction,\n op9: OperatorFunction\n ): Observable;\n pipe(\n op1: OperatorFunction,\n op2: OperatorFunction,\n op3: OperatorFunction,\n op4: OperatorFunction,\n op5: OperatorFunction,\n op6: OperatorFunction,\n op7: OperatorFunction,\n op8: OperatorFunction,\n op9: OperatorFunction,\n ...operations: OperatorFunction[]\n ): Observable;\n /* tslint:enable:max-line-length */\n\n /**\n * Used to stitch together functional operators into a chain.\n * @method pipe\n * @return {Observable} the Observable result of all of the operators having\n * been called in the order they were passed in.\n *\n * ## Example\n *\n * ```ts\n * import { interval, filter, map, scan } from 'rxjs';\n *\n * interval(1000)\n * .pipe(\n * filter(x => x % 2 === 0),\n * map(x => x + x),\n * scan((acc, x) => acc + x)\n * )\n * .subscribe(x => console.log(x));\n * ```\n */\n pipe(...operations: OperatorFunction[]): Observable {\n return pipeFromArray(operations)(this);\n }\n\n /* tslint:disable:max-line-length */\n /** @deprecated Replaced with {@link firstValueFrom} and {@link lastValueFrom}. Will be removed in v8. Details: https://rxjs.dev/deprecations/to-promise */\n toPromise(): Promise;\n /** @deprecated Replaced with {@link firstValueFrom} and {@link lastValueFrom}. Will be removed in v8. Details: https://rxjs.dev/deprecations/to-promise */\n toPromise(PromiseCtor: typeof Promise): Promise;\n /** @deprecated Replaced with {@link firstValueFrom} and {@link lastValueFrom}. Will be removed in v8. Details: https://rxjs.dev/deprecations/to-promise */\n toPromise(PromiseCtor: PromiseConstructorLike): Promise;\n /* tslint:enable:max-line-length */\n\n /**\n * Subscribe to this Observable and get a Promise resolving on\n * `complete` with the last emission (if any).\n *\n * **WARNING**: Only use this with observables you *know* will complete. If the source\n * observable does not complete, you will end up with a promise that is hung up, and\n * potentially all of the state of an async function hanging out in memory. To avoid\n * this situation, look into adding something like {@link timeout}, {@link take},\n * {@link takeWhile}, or {@link takeUntil} amongst others.\n *\n * @method toPromise\n * @param [promiseCtor] a constructor function used to instantiate\n * the Promise\n * @return A Promise that resolves with the last value emit, or\n * rejects on an error. If there were no emissions, Promise\n * resolves with undefined.\n * @deprecated Replaced with {@link firstValueFrom} and {@link lastValueFrom}. Will be removed in v8. Details: https://rxjs.dev/deprecations/to-promise\n */\n toPromise(promiseCtor?: PromiseConstructorLike): Promise {\n promiseCtor = getPromiseCtor(promiseCtor);\n\n return new promiseCtor((resolve, reject) => {\n let value: T | undefined;\n this.subscribe(\n (x: T) => (value = x),\n (err: any) => reject(err),\n () => resolve(value)\n );\n }) as Promise;\n }\n}\n\n/**\n * Decides between a passed promise constructor from consuming code,\n * A default configured promise constructor, and the native promise\n * constructor and returns it. If nothing can be found, it will throw\n * an error.\n * @param promiseCtor The optional promise constructor to passed by consuming code\n */\nfunction getPromiseCtor(promiseCtor: PromiseConstructorLike | undefined) {\n return promiseCtor ?? config.Promise ?? Promise;\n}\n\nfunction isObserver(value: any): value is Observer {\n return value && isFunction(value.next) && isFunction(value.error) && isFunction(value.complete);\n}\n\nfunction isSubscriber(value: any): value is Subscriber {\n return (value && value instanceof Subscriber) || (isObserver(value) && isSubscription(value));\n}\n", "import { Observable } from '../Observable';\nimport { Subscriber } from '../Subscriber';\nimport { OperatorFunction } from '../types';\nimport { isFunction } from './isFunction';\n\n/**\n * Used to determine if an object is an Observable with a lift function.\n */\nexport function hasLift(source: any): source is { lift: InstanceType['lift'] } {\n return isFunction(source?.lift);\n}\n\n/**\n * Creates an `OperatorFunction`. Used to define operators throughout the library in a concise way.\n * @param init The logic to connect the liftedSource to the subscriber at the moment of subscription.\n */\nexport function operate(\n init: (liftedSource: Observable, subscriber: Subscriber) => (() => void) | void\n): OperatorFunction {\n return (source: Observable) => {\n if (hasLift(source)) {\n return source.lift(function (this: Subscriber